123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631632633634635636637638639640641642643644645646647648649650651652653654655656657658659660661662663664665666667668669670671672673674675676677678679680681682683684685686687688689690691692693694695696697698699700701702703704705706707708709710711 |
- //===- llvm/CodeGen/AsmPrinter/AccelTable.cpp - Accelerator Tables --------===//
- //
- // Part of the LLVM Project, under the Apache License v2.0 with LLVM Exceptions.
- // See https://llvm.org/LICENSE.txt for license information.
- // SPDX-License-Identifier: Apache-2.0 WITH LLVM-exception
- //
- //===----------------------------------------------------------------------===//
- //
- // This file contains support for writing accelerator tables.
- //
- //===----------------------------------------------------------------------===//
- #include "llvm/CodeGen/AccelTable.h"
- #include "DwarfCompileUnit.h"
- #include "llvm/ADT/STLExtras.h"
- #include "llvm/ADT/StringMap.h"
- #include "llvm/ADT/Twine.h"
- #include "llvm/BinaryFormat/Dwarf.h"
- #include "llvm/CodeGen/AsmPrinter.h"
- #include "llvm/CodeGen/DIE.h"
- #include "llvm/MC/MCExpr.h"
- #include "llvm/MC/MCStreamer.h"
- #include "llvm/MC/MCSymbol.h"
- #include "llvm/Support/raw_ostream.h"
- #include "llvm/Target/TargetLoweringObjectFile.h"
- #include <algorithm>
- #include <cstddef>
- #include <cstdint>
- #include <limits>
- #include <vector>
- using namespace llvm;
- void AccelTableBase::computeBucketCount() {
- // First get the number of unique hashes.
- std::vector<uint32_t> Uniques;
- Uniques.reserve(Entries.size());
- for (const auto &E : Entries)
- Uniques.push_back(E.second.HashValue);
- array_pod_sort(Uniques.begin(), Uniques.end());
- std::vector<uint32_t>::iterator P =
- std::unique(Uniques.begin(), Uniques.end());
- UniqueHashCount = std::distance(Uniques.begin(), P);
- if (UniqueHashCount > 1024)
- BucketCount = UniqueHashCount / 4;
- else if (UniqueHashCount > 16)
- BucketCount = UniqueHashCount / 2;
- else
- BucketCount = std::max<uint32_t>(UniqueHashCount, 1);
- }
- void AccelTableBase::finalize(AsmPrinter *Asm, StringRef Prefix) {
- // Create the individual hash data outputs.
- for (auto &E : Entries) {
- // Unique the entries.
- llvm::stable_sort(E.second.Values,
- [](const AccelTableData *A, const AccelTableData *B) {
- return *A < *B;
- });
- E.second.Values.erase(
- std::unique(E.second.Values.begin(), E.second.Values.end()),
- E.second.Values.end());
- }
- // Figure out how many buckets we need, then compute the bucket contents and
- // the final ordering. The hashes and offsets can be emitted by walking these
- // data structures. We add temporary symbols to the data so they can be
- // referenced when emitting the offsets.
- computeBucketCount();
- // Compute bucket contents and final ordering.
- Buckets.resize(BucketCount);
- for (auto &E : Entries) {
- uint32_t Bucket = E.second.HashValue % BucketCount;
- Buckets[Bucket].push_back(&E.second);
- E.second.Sym = Asm->createTempSymbol(Prefix);
- }
- // Sort the contents of the buckets by hash value so that hash collisions end
- // up together. Stable sort makes testing easier and doesn't cost much more.
- for (auto &Bucket : Buckets)
- llvm::stable_sort(Bucket, [](HashData *LHS, HashData *RHS) {
- return LHS->HashValue < RHS->HashValue;
- });
- }
- namespace {
- /// Base class for writing out Accelerator tables. It holds the common
- /// functionality for the two Accelerator table types.
- class AccelTableWriter {
- protected:
- AsmPrinter *const Asm; ///< Destination.
- const AccelTableBase &Contents; ///< Data to emit.
- /// Controls whether to emit duplicate hash and offset table entries for names
- /// with identical hashes. Apple tables don't emit duplicate entries, DWARF v5
- /// tables do.
- const bool SkipIdenticalHashes;
- void emitHashes() const;
- /// Emit offsets to lists of entries with identical names. The offsets are
- /// relative to the Base argument.
- void emitOffsets(const MCSymbol *Base) const;
- public:
- AccelTableWriter(AsmPrinter *Asm, const AccelTableBase &Contents,
- bool SkipIdenticalHashes)
- : Asm(Asm), Contents(Contents), SkipIdenticalHashes(SkipIdenticalHashes) {
- }
- };
- class AppleAccelTableWriter : public AccelTableWriter {
- using Atom = AppleAccelTableData::Atom;
- /// The fixed header of an Apple Accelerator Table.
- struct Header {
- uint32_t Magic = MagicHash;
- uint16_t Version = 1;
- uint16_t HashFunction = dwarf::DW_hash_function_djb;
- uint32_t BucketCount;
- uint32_t HashCount;
- uint32_t HeaderDataLength;
- /// 'HASH' magic value to detect endianness.
- static const uint32_t MagicHash = 0x48415348;
- Header(uint32_t BucketCount, uint32_t UniqueHashCount, uint32_t DataLength)
- : BucketCount(BucketCount), HashCount(UniqueHashCount),
- HeaderDataLength(DataLength) {}
- void emit(AsmPrinter *Asm) const;
- #ifndef NDEBUG
- void print(raw_ostream &OS) const;
- void dump() const { print(dbgs()); }
- #endif
- };
- /// The HeaderData describes the structure of an Apple accelerator table
- /// through a list of Atoms.
- struct HeaderData {
- /// In the case of data that is referenced via DW_FORM_ref_* the offset
- /// base is used to describe the offset for all forms in the list of atoms.
- uint32_t DieOffsetBase;
- const SmallVector<Atom, 4> Atoms;
- HeaderData(ArrayRef<Atom> AtomList, uint32_t Offset = 0)
- : DieOffsetBase(Offset), Atoms(AtomList.begin(), AtomList.end()) {}
- void emit(AsmPrinter *Asm) const;
- #ifndef NDEBUG
- void print(raw_ostream &OS) const;
- void dump() const { print(dbgs()); }
- #endif
- };
- Header Header;
- HeaderData HeaderData;
- const MCSymbol *SecBegin;
- void emitBuckets() const;
- void emitData() const;
- public:
- AppleAccelTableWriter(AsmPrinter *Asm, const AccelTableBase &Contents,
- ArrayRef<Atom> Atoms, const MCSymbol *SecBegin)
- : AccelTableWriter(Asm, Contents, true),
- Header(Contents.getBucketCount(), Contents.getUniqueHashCount(),
- 8 + (Atoms.size() * 4)),
- HeaderData(Atoms), SecBegin(SecBegin) {}
- void emit() const;
- #ifndef NDEBUG
- void print(raw_ostream &OS) const;
- void dump() const { print(dbgs()); }
- #endif
- };
- /// Class responsible for emitting a DWARF v5 Accelerator Table. The only
- /// public function is emit(), which performs the actual emission.
- ///
- /// The class is templated in its data type. This allows us to emit both dyamic
- /// and static data entries. A callback abstract the logic to provide a CU
- /// index for a given entry, which is different per data type, but identical
- /// for every entry in the same table.
- template <typename DataT>
- class Dwarf5AccelTableWriter : public AccelTableWriter {
- struct Header {
- uint16_t Version = 5;
- uint16_t Padding = 0;
- uint32_t CompUnitCount;
- uint32_t LocalTypeUnitCount = 0;
- uint32_t ForeignTypeUnitCount = 0;
- uint32_t BucketCount;
- uint32_t NameCount;
- uint32_t AbbrevTableSize = 0;
- uint32_t AugmentationStringSize = sizeof(AugmentationString);
- char AugmentationString[8] = {'L', 'L', 'V', 'M', '0', '7', '0', '0'};
- Header(uint32_t CompUnitCount, uint32_t BucketCount, uint32_t NameCount)
- : CompUnitCount(CompUnitCount), BucketCount(BucketCount),
- NameCount(NameCount) {}
- void emit(Dwarf5AccelTableWriter &Ctx);
- };
- struct AttributeEncoding {
- dwarf::Index Index;
- dwarf::Form Form;
- };
- Header Header;
- DenseMap<uint32_t, SmallVector<AttributeEncoding, 2>> Abbreviations;
- ArrayRef<MCSymbol *> CompUnits;
- llvm::function_ref<unsigned(const DataT &)> getCUIndexForEntry;
- MCSymbol *ContributionEnd = nullptr;
- MCSymbol *AbbrevStart = Asm->createTempSymbol("names_abbrev_start");
- MCSymbol *AbbrevEnd = Asm->createTempSymbol("names_abbrev_end");
- MCSymbol *EntryPool = Asm->createTempSymbol("names_entries");
- DenseSet<uint32_t> getUniqueTags() const;
- // Right now, we emit uniform attributes for all tags.
- SmallVector<AttributeEncoding, 2> getUniformAttributes() const;
- void emitCUList() const;
- void emitBuckets() const;
- void emitStringOffsets() const;
- void emitAbbrevs() const;
- void emitEntry(const DataT &Entry) const;
- void emitData() const;
- public:
- Dwarf5AccelTableWriter(
- AsmPrinter *Asm, const AccelTableBase &Contents,
- ArrayRef<MCSymbol *> CompUnits,
- llvm::function_ref<unsigned(const DataT &)> GetCUIndexForEntry);
- void emit();
- };
- } // namespace
- void AccelTableWriter::emitHashes() const {
- uint64_t PrevHash = std::numeric_limits<uint64_t>::max();
- unsigned BucketIdx = 0;
- for (auto &Bucket : Contents.getBuckets()) {
- for (auto &Hash : Bucket) {
- uint32_t HashValue = Hash->HashValue;
- if (SkipIdenticalHashes && PrevHash == HashValue)
- continue;
- Asm->OutStreamer->AddComment("Hash in Bucket " + Twine(BucketIdx));
- Asm->emitInt32(HashValue);
- PrevHash = HashValue;
- }
- BucketIdx++;
- }
- }
- void AccelTableWriter::emitOffsets(const MCSymbol *Base) const {
- const auto &Buckets = Contents.getBuckets();
- uint64_t PrevHash = std::numeric_limits<uint64_t>::max();
- for (size_t i = 0, e = Buckets.size(); i < e; ++i) {
- for (auto *Hash : Buckets[i]) {
- uint32_t HashValue = Hash->HashValue;
- if (SkipIdenticalHashes && PrevHash == HashValue)
- continue;
- PrevHash = HashValue;
- Asm->OutStreamer->AddComment("Offset in Bucket " + Twine(i));
- Asm->emitLabelDifference(Hash->Sym, Base, Asm->getDwarfOffsetByteSize());
- }
- }
- }
- void AppleAccelTableWriter::Header::emit(AsmPrinter *Asm) const {
- Asm->OutStreamer->AddComment("Header Magic");
- Asm->emitInt32(Magic);
- Asm->OutStreamer->AddComment("Header Version");
- Asm->emitInt16(Version);
- Asm->OutStreamer->AddComment("Header Hash Function");
- Asm->emitInt16(HashFunction);
- Asm->OutStreamer->AddComment("Header Bucket Count");
- Asm->emitInt32(BucketCount);
- Asm->OutStreamer->AddComment("Header Hash Count");
- Asm->emitInt32(HashCount);
- Asm->OutStreamer->AddComment("Header Data Length");
- Asm->emitInt32(HeaderDataLength);
- }
- void AppleAccelTableWriter::HeaderData::emit(AsmPrinter *Asm) const {
- Asm->OutStreamer->AddComment("HeaderData Die Offset Base");
- Asm->emitInt32(DieOffsetBase);
- Asm->OutStreamer->AddComment("HeaderData Atom Count");
- Asm->emitInt32(Atoms.size());
- for (const Atom &A : Atoms) {
- Asm->OutStreamer->AddComment(dwarf::AtomTypeString(A.Type));
- Asm->emitInt16(A.Type);
- Asm->OutStreamer->AddComment(dwarf::FormEncodingString(A.Form));
- Asm->emitInt16(A.Form);
- }
- }
- void AppleAccelTableWriter::emitBuckets() const {
- const auto &Buckets = Contents.getBuckets();
- unsigned index = 0;
- for (size_t i = 0, e = Buckets.size(); i < e; ++i) {
- Asm->OutStreamer->AddComment("Bucket " + Twine(i));
- if (!Buckets[i].empty())
- Asm->emitInt32(index);
- else
- Asm->emitInt32(std::numeric_limits<uint32_t>::max());
- // Buckets point in the list of hashes, not to the data. Do not increment
- // the index multiple times in case of hash collisions.
- uint64_t PrevHash = std::numeric_limits<uint64_t>::max();
- for (auto *HD : Buckets[i]) {
- uint32_t HashValue = HD->HashValue;
- if (PrevHash != HashValue)
- ++index;
- PrevHash = HashValue;
- }
- }
- }
- void AppleAccelTableWriter::emitData() const {
- const auto &Buckets = Contents.getBuckets();
- for (const AccelTableBase::HashList &Bucket : Buckets) {
- uint64_t PrevHash = std::numeric_limits<uint64_t>::max();
- for (auto &Hash : Bucket) {
- // Terminate the previous entry if there is no hash collision with the
- // current one.
- if (PrevHash != std::numeric_limits<uint64_t>::max() &&
- PrevHash != Hash->HashValue)
- Asm->emitInt32(0);
- // Remember to emit the label for our offset.
- Asm->OutStreamer->emitLabel(Hash->Sym);
- Asm->OutStreamer->AddComment(Hash->Name.getString());
- Asm->emitDwarfStringOffset(Hash->Name);
- Asm->OutStreamer->AddComment("Num DIEs");
- Asm->emitInt32(Hash->Values.size());
- for (const auto *V : Hash->Values)
- static_cast<const AppleAccelTableData *>(V)->emit(Asm);
- PrevHash = Hash->HashValue;
- }
- // Emit the final end marker for the bucket.
- if (!Bucket.empty())
- Asm->emitInt32(0);
- }
- }
- void AppleAccelTableWriter::emit() const {
- Header.emit(Asm);
- HeaderData.emit(Asm);
- emitBuckets();
- emitHashes();
- emitOffsets(SecBegin);
- emitData();
- }
- template <typename DataT>
- void Dwarf5AccelTableWriter<DataT>::Header::emit(Dwarf5AccelTableWriter &Ctx) {
- assert(CompUnitCount > 0 && "Index must have at least one CU.");
- AsmPrinter *Asm = Ctx.Asm;
- Ctx.ContributionEnd =
- Asm->emitDwarfUnitLength("names", "Header: unit length");
- Asm->OutStreamer->AddComment("Header: version");
- Asm->emitInt16(Version);
- Asm->OutStreamer->AddComment("Header: padding");
- Asm->emitInt16(Padding);
- Asm->OutStreamer->AddComment("Header: compilation unit count");
- Asm->emitInt32(CompUnitCount);
- Asm->OutStreamer->AddComment("Header: local type unit count");
- Asm->emitInt32(LocalTypeUnitCount);
- Asm->OutStreamer->AddComment("Header: foreign type unit count");
- Asm->emitInt32(ForeignTypeUnitCount);
- Asm->OutStreamer->AddComment("Header: bucket count");
- Asm->emitInt32(BucketCount);
- Asm->OutStreamer->AddComment("Header: name count");
- Asm->emitInt32(NameCount);
- Asm->OutStreamer->AddComment("Header: abbreviation table size");
- Asm->emitLabelDifference(Ctx.AbbrevEnd, Ctx.AbbrevStart, sizeof(uint32_t));
- Asm->OutStreamer->AddComment("Header: augmentation string size");
- assert(AugmentationStringSize % 4 == 0);
- Asm->emitInt32(AugmentationStringSize);
- Asm->OutStreamer->AddComment("Header: augmentation string");
- Asm->OutStreamer->emitBytes({AugmentationString, AugmentationStringSize});
- }
- template <typename DataT>
- DenseSet<uint32_t> Dwarf5AccelTableWriter<DataT>::getUniqueTags() const {
- DenseSet<uint32_t> UniqueTags;
- for (auto &Bucket : Contents.getBuckets()) {
- for (auto *Hash : Bucket) {
- for (auto *Value : Hash->Values) {
- unsigned Tag = static_cast<const DataT *>(Value)->getDieTag();
- UniqueTags.insert(Tag);
- }
- }
- }
- return UniqueTags;
- }
- template <typename DataT>
- SmallVector<typename Dwarf5AccelTableWriter<DataT>::AttributeEncoding, 2>
- Dwarf5AccelTableWriter<DataT>::getUniformAttributes() const {
- SmallVector<AttributeEncoding, 2> UA;
- if (CompUnits.size() > 1) {
- size_t LargestCUIndex = CompUnits.size() - 1;
- dwarf::Form Form = DIEInteger::BestForm(/*IsSigned*/ false, LargestCUIndex);
- UA.push_back({dwarf::DW_IDX_compile_unit, Form});
- }
- UA.push_back({dwarf::DW_IDX_die_offset, dwarf::DW_FORM_ref4});
- return UA;
- }
- template <typename DataT>
- void Dwarf5AccelTableWriter<DataT>::emitCUList() const {
- for (const auto &CU : enumerate(CompUnits)) {
- Asm->OutStreamer->AddComment("Compilation unit " + Twine(CU.index()));
- Asm->emitDwarfSymbolReference(CU.value());
- }
- }
- template <typename DataT>
- void Dwarf5AccelTableWriter<DataT>::emitBuckets() const {
- uint32_t Index = 1;
- for (const auto &Bucket : enumerate(Contents.getBuckets())) {
- Asm->OutStreamer->AddComment("Bucket " + Twine(Bucket.index()));
- Asm->emitInt32(Bucket.value().empty() ? 0 : Index);
- Index += Bucket.value().size();
- }
- }
- template <typename DataT>
- void Dwarf5AccelTableWriter<DataT>::emitStringOffsets() const {
- for (const auto &Bucket : enumerate(Contents.getBuckets())) {
- for (auto *Hash : Bucket.value()) {
- DwarfStringPoolEntryRef String = Hash->Name;
- Asm->OutStreamer->AddComment("String in Bucket " + Twine(Bucket.index()) +
- ": " + String.getString());
- Asm->emitDwarfStringOffset(String);
- }
- }
- }
- template <typename DataT>
- void Dwarf5AccelTableWriter<DataT>::emitAbbrevs() const {
- Asm->OutStreamer->emitLabel(AbbrevStart);
- for (const auto &Abbrev : Abbreviations) {
- Asm->OutStreamer->AddComment("Abbrev code");
- assert(Abbrev.first != 0);
- Asm->emitULEB128(Abbrev.first);
- Asm->OutStreamer->AddComment(dwarf::TagString(Abbrev.first));
- Asm->emitULEB128(Abbrev.first);
- for (const auto &AttrEnc : Abbrev.second) {
- Asm->emitULEB128(AttrEnc.Index, dwarf::IndexString(AttrEnc.Index).data());
- Asm->emitULEB128(AttrEnc.Form,
- dwarf::FormEncodingString(AttrEnc.Form).data());
- }
- Asm->emitULEB128(0, "End of abbrev");
- Asm->emitULEB128(0, "End of abbrev");
- }
- Asm->emitULEB128(0, "End of abbrev list");
- Asm->OutStreamer->emitLabel(AbbrevEnd);
- }
- template <typename DataT>
- void Dwarf5AccelTableWriter<DataT>::emitEntry(const DataT &Entry) const {
- auto AbbrevIt = Abbreviations.find(Entry.getDieTag());
- assert(AbbrevIt != Abbreviations.end() &&
- "Why wasn't this abbrev generated?");
- Asm->emitULEB128(AbbrevIt->first, "Abbreviation code");
- for (const auto &AttrEnc : AbbrevIt->second) {
- Asm->OutStreamer->AddComment(dwarf::IndexString(AttrEnc.Index));
- switch (AttrEnc.Index) {
- case dwarf::DW_IDX_compile_unit: {
- DIEInteger ID(getCUIndexForEntry(Entry));
- ID.emitValue(Asm, AttrEnc.Form);
- break;
- }
- case dwarf::DW_IDX_die_offset:
- assert(AttrEnc.Form == dwarf::DW_FORM_ref4);
- Asm->emitInt32(Entry.getDieOffset());
- break;
- default:
- llvm_unreachable("Unexpected index attribute!");
- }
- }
- }
- template <typename DataT> void Dwarf5AccelTableWriter<DataT>::emitData() const {
- Asm->OutStreamer->emitLabel(EntryPool);
- for (auto &Bucket : Contents.getBuckets()) {
- for (auto *Hash : Bucket) {
- // Remember to emit the label for our offset.
- Asm->OutStreamer->emitLabel(Hash->Sym);
- for (const auto *Value : Hash->Values)
- emitEntry(*static_cast<const DataT *>(Value));
- Asm->OutStreamer->AddComment("End of list: " + Hash->Name.getString());
- Asm->emitInt8(0);
- }
- }
- }
- template <typename DataT>
- Dwarf5AccelTableWriter<DataT>::Dwarf5AccelTableWriter(
- AsmPrinter *Asm, const AccelTableBase &Contents,
- ArrayRef<MCSymbol *> CompUnits,
- llvm::function_ref<unsigned(const DataT &)> getCUIndexForEntry)
- : AccelTableWriter(Asm, Contents, false),
- Header(CompUnits.size(), Contents.getBucketCount(),
- Contents.getUniqueNameCount()),
- CompUnits(CompUnits), getCUIndexForEntry(std::move(getCUIndexForEntry)) {
- DenseSet<uint32_t> UniqueTags = getUniqueTags();
- SmallVector<AttributeEncoding, 2> UniformAttributes = getUniformAttributes();
- Abbreviations.reserve(UniqueTags.size());
- for (uint32_t Tag : UniqueTags)
- Abbreviations.try_emplace(Tag, UniformAttributes);
- }
- template <typename DataT> void Dwarf5AccelTableWriter<DataT>::emit() {
- Header.emit(*this);
- emitCUList();
- emitBuckets();
- emitHashes();
- emitStringOffsets();
- emitOffsets(EntryPool);
- emitAbbrevs();
- emitData();
- Asm->OutStreamer->emitValueToAlignment(4, 0);
- Asm->OutStreamer->emitLabel(ContributionEnd);
- }
- void llvm::emitAppleAccelTableImpl(AsmPrinter *Asm, AccelTableBase &Contents,
- StringRef Prefix, const MCSymbol *SecBegin,
- ArrayRef<AppleAccelTableData::Atom> Atoms) {
- Contents.finalize(Asm, Prefix);
- AppleAccelTableWriter(Asm, Contents, Atoms, SecBegin).emit();
- }
- void llvm::emitDWARF5AccelTable(
- AsmPrinter *Asm, AccelTable<DWARF5AccelTableData> &Contents,
- const DwarfDebug &DD, ArrayRef<std::unique_ptr<DwarfCompileUnit>> CUs) {
- std::vector<MCSymbol *> CompUnits;
- SmallVector<unsigned, 1> CUIndex(CUs.size());
- int Count = 0;
- for (const auto &CU : enumerate(CUs)) {
- if (CU.value()->getCUNode()->getNameTableKind() !=
- DICompileUnit::DebugNameTableKind::Default)
- continue;
- CUIndex[CU.index()] = Count++;
- assert(CU.index() == CU.value()->getUniqueID());
- const DwarfCompileUnit *MainCU =
- DD.useSplitDwarf() ? CU.value()->getSkeleton() : CU.value().get();
- CompUnits.push_back(MainCU->getLabelBegin());
- }
- if (CompUnits.empty())
- return;
- Asm->OutStreamer->SwitchSection(
- Asm->getObjFileLowering().getDwarfDebugNamesSection());
- Contents.finalize(Asm, "names");
- Dwarf5AccelTableWriter<DWARF5AccelTableData>(
- Asm, Contents, CompUnits,
- [&](const DWARF5AccelTableData &Entry) {
- const DIE *CUDie = Entry.getDie().getUnitDie();
- return CUIndex[DD.lookupCU(CUDie)->getUniqueID()];
- })
- .emit();
- }
- void llvm::emitDWARF5AccelTable(
- AsmPrinter *Asm, AccelTable<DWARF5AccelTableStaticData> &Contents,
- ArrayRef<MCSymbol *> CUs,
- llvm::function_ref<unsigned(const DWARF5AccelTableStaticData &)>
- getCUIndexForEntry) {
- Contents.finalize(Asm, "names");
- Dwarf5AccelTableWriter<DWARF5AccelTableStaticData>(Asm, Contents, CUs,
- getCUIndexForEntry)
- .emit();
- }
- void AppleAccelTableOffsetData::emit(AsmPrinter *Asm) const {
- assert(Die.getDebugSectionOffset() <= UINT32_MAX &&
- "The section offset exceeds the limit.");
- Asm->emitInt32(Die.getDebugSectionOffset());
- }
- void AppleAccelTableTypeData::emit(AsmPrinter *Asm) const {
- assert(Die.getDebugSectionOffset() <= UINT32_MAX &&
- "The section offset exceeds the limit.");
- Asm->emitInt32(Die.getDebugSectionOffset());
- Asm->emitInt16(Die.getTag());
- Asm->emitInt8(0);
- }
- void AppleAccelTableStaticOffsetData::emit(AsmPrinter *Asm) const {
- Asm->emitInt32(Offset);
- }
- void AppleAccelTableStaticTypeData::emit(AsmPrinter *Asm) const {
- Asm->emitInt32(Offset);
- Asm->emitInt16(Tag);
- Asm->emitInt8(ObjCClassIsImplementation ? dwarf::DW_FLAG_type_implementation
- : 0);
- Asm->emitInt32(QualifiedNameHash);
- }
- constexpr AppleAccelTableData::Atom AppleAccelTableTypeData::Atoms[];
- constexpr AppleAccelTableData::Atom AppleAccelTableOffsetData::Atoms[];
- constexpr AppleAccelTableData::Atom AppleAccelTableStaticOffsetData::Atoms[];
- constexpr AppleAccelTableData::Atom AppleAccelTableStaticTypeData::Atoms[];
- #ifndef NDEBUG
- void AppleAccelTableWriter::Header::print(raw_ostream &OS) const {
- OS << "Magic: " << format("0x%x", Magic) << "\n"
- << "Version: " << Version << "\n"
- << "Hash Function: " << HashFunction << "\n"
- << "Bucket Count: " << BucketCount << "\n"
- << "Header Data Length: " << HeaderDataLength << "\n";
- }
- void AppleAccelTableData::Atom::print(raw_ostream &OS) const {
- OS << "Type: " << dwarf::AtomTypeString(Type) << "\n"
- << "Form: " << dwarf::FormEncodingString(Form) << "\n";
- }
- void AppleAccelTableWriter::HeaderData::print(raw_ostream &OS) const {
- OS << "DIE Offset Base: " << DieOffsetBase << "\n";
- for (auto Atom : Atoms)
- Atom.print(OS);
- }
- void AppleAccelTableWriter::print(raw_ostream &OS) const {
- Header.print(OS);
- HeaderData.print(OS);
- Contents.print(OS);
- SecBegin->print(OS, nullptr);
- }
- void AccelTableBase::HashData::print(raw_ostream &OS) const {
- OS << "Name: " << Name.getString() << "\n";
- OS << " Hash Value: " << format("0x%x", HashValue) << "\n";
- OS << " Symbol: ";
- if (Sym)
- OS << *Sym;
- else
- OS << "<none>";
- OS << "\n";
- for (auto *Value : Values)
- Value->print(OS);
- }
- void AccelTableBase::print(raw_ostream &OS) const {
- // Print Content.
- OS << "Entries: \n";
- for (const auto &Entry : Entries) {
- OS << "Name: " << Entry.first() << "\n";
- for (auto *V : Entry.second.Values)
- V->print(OS);
- }
- OS << "Buckets and Hashes: \n";
- for (auto &Bucket : Buckets)
- for (auto &Hash : Bucket)
- Hash->print(OS);
- OS << "Data: \n";
- for (auto &E : Entries)
- E.second.print(OS);
- }
- void DWARF5AccelTableData::print(raw_ostream &OS) const {
- OS << " Offset: " << getDieOffset() << "\n";
- OS << " Tag: " << dwarf::TagString(getDieTag()) << "\n";
- }
- void DWARF5AccelTableStaticData::print(raw_ostream &OS) const {
- OS << " Offset: " << getDieOffset() << "\n";
- OS << " Tag: " << dwarf::TagString(getDieTag()) << "\n";
- }
- void AppleAccelTableOffsetData::print(raw_ostream &OS) const {
- OS << " Offset: " << Die.getOffset() << "\n";
- }
- void AppleAccelTableTypeData::print(raw_ostream &OS) const {
- OS << " Offset: " << Die.getOffset() << "\n";
- OS << " Tag: " << dwarf::TagString(Die.getTag()) << "\n";
- }
- void AppleAccelTableStaticOffsetData::print(raw_ostream &OS) const {
- OS << " Static Offset: " << Offset << "\n";
- }
- void AppleAccelTableStaticTypeData::print(raw_ostream &OS) const {
- OS << " Static Offset: " << Offset << "\n";
- OS << " QualifiedNameHash: " << format("%x\n", QualifiedNameHash) << "\n";
- OS << " Tag: " << dwarf::TagString(Tag) << "\n";
- OS << " ObjCClassIsImplementation: "
- << (ObjCClassIsImplementation ? "true" : "false");
- OS << "\n";
- }
- #endif
|