Skip to content
Merged
Show file tree
Hide file tree
Changes from all commits
Commits
File filter

Filter by extension

Filter by extension

Conversations
Failed to load comments.
Loading
Jump to
Jump to file
Failed to load files.
Loading
Diff view
Diff view
8 changes: 4 additions & 4 deletions llvm/include/llvm/Analysis/DDG.h
Original file line number Diff line number Diff line change
Expand Up @@ -96,7 +96,7 @@ class RootDDGNode : public DDGNode {
RootDDGNode() : DDGNode(NodeKind::Root) {}
RootDDGNode(const RootDDGNode &N) = delete;
RootDDGNode(RootDDGNode &&N) : DDGNode(std::move(N)) {}
~RootDDGNode() = default;
~RootDDGNode() override = default;

/// Define classof to be able to use isa<>, cast<>, dyn_cast<>, etc.
static bool classof(const DDGNode *N) {
Expand All @@ -114,7 +114,7 @@ class LLVM_ABI SimpleDDGNode : public DDGNode {
SimpleDDGNode(Instruction &I);
SimpleDDGNode(const SimpleDDGNode &N);
SimpleDDGNode(SimpleDDGNode &&N);
~SimpleDDGNode();
~SimpleDDGNode() override;

SimpleDDGNode &operator=(const SimpleDDGNode &N) = default;

Expand Down Expand Up @@ -176,7 +176,7 @@ class LLVM_ABI PiBlockDDGNode : public DDGNode {
PiBlockDDGNode(const PiNodeList &List);
PiBlockDDGNode(const PiBlockDDGNode &N);
PiBlockDDGNode(PiBlockDDGNode &&N);
~PiBlockDDGNode();
~PiBlockDDGNode() override;

PiBlockDDGNode &operator=(const PiBlockDDGNode &N) = default;

Expand Down Expand Up @@ -318,7 +318,7 @@ class LLVM_ABI DataDependenceGraph : public DDGBase, public DDGInfo {
: DDGBase(std::move(G)), DDGInfo(std::move(G)) {}
DataDependenceGraph(Function &F, DependenceInfo &DI);
DataDependenceGraph(Loop &L, LoopInfo &LI, DependenceInfo &DI);
~DataDependenceGraph();
~DataDependenceGraph() override;

/// If node \p N belongs to a pi-block return a pointer to the pi-block,
/// otherwise return null.
Expand Down
2 changes: 1 addition & 1 deletion llvm/include/llvm/Analysis/InteractiveModelRunner.h
Original file line number Diff line number Diff line change
Expand Up @@ -51,7 +51,7 @@ class LLVM_ABI InteractiveModelRunner : public MLModelRunner {
Log->flush();
}

virtual ~InteractiveModelRunner();
~InteractiveModelRunner() override;

private:
void *evaluateUntyped() override;
Expand Down
4 changes: 2 additions & 2 deletions llvm/include/llvm/Analysis/MLInlineAdvisor.h
Original file line number Diff line number Diff line change
Expand Up @@ -33,7 +33,7 @@ class MLInlineAdvisor : public InlineAdvisor {
GetModelRunner,
std::function<bool(CallBase &)> GetDefaultAdvice);

virtual ~MLInlineAdvisor() = default;
~MLInlineAdvisor() override = default;

void onPassEntry(LazyCallGraph::SCC *SCC) override;
void onPassExit(LazyCallGraph::SCC *SCC) override;
Expand Down Expand Up @@ -105,7 +105,7 @@ class MLInlineAdvice : public InlineAdvice {
public:
MLInlineAdvice(MLInlineAdvisor *Advisor, CallBase &CB,
OptimizationRemarkEmitter &ORE, bool Recommendation);
virtual ~MLInlineAdvice() = default;
~MLInlineAdvice() override = default;

void recordInliningImpl() override;
void recordInliningWithCalleeDeletedImpl() override;
Expand Down
2 changes: 1 addition & 1 deletion llvm/include/llvm/Analysis/ReleaseModeModelRunner.h
Original file line number Diff line number Diff line change
Expand Up @@ -106,7 +106,7 @@ class ReleaseModeModelRunner final : public MLModelRunner {
assert(ResultIndex >= 0 && "Cannot find DecisionName in inlining model");
}

virtual ~ReleaseModeModelRunner() = default;
~ReleaseModeModelRunner() override = default;

static bool classof(const MLModelRunner *R) {
return R->getKind() == MLModelRunner::Kind::Release;
Expand Down
2 changes: 1 addition & 1 deletion llvm/include/llvm/Analysis/StackSafetyAnalysis.h
Original file line number Diff line number Diff line change
Expand Up @@ -156,7 +156,7 @@ class StackSafetyGlobalInfoWrapperPass : public ModulePass {
static char ID;

StackSafetyGlobalInfoWrapperPass();
~StackSafetyGlobalInfoWrapperPass();
~StackSafetyGlobalInfoWrapperPass() override;

const StackSafetyGlobalInfo &getResult() const { return SSGI; }

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -32,7 +32,7 @@ class LLVM_ABI CFIFunctionFrameAnalyzer : public CFIFunctionFrameReceiver {
public:
CFIFunctionFrameAnalyzer(MCContext &Context, const MCInstrInfo &MCII)
: CFIFunctionFrameReceiver(Context), MCII(MCII) {}
~CFIFunctionFrameAnalyzer();
~CFIFunctionFrameAnalyzer() override;

void startFunctionFrame(bool IsEH,
ArrayRef<MCCFIInstruction> Prologue) override;
Expand Down
2 changes: 1 addition & 1 deletion llvm/include/llvm/DWARFLinker/Classic/DWARFStreamer.h
Original file line number Diff line number Diff line change
Expand Up @@ -48,7 +48,7 @@ class LLVM_ABI DwarfStreamer : public DwarfEmitter {
raw_pwrite_stream &OutFile,
DWARFLinkerBase::MessageHandlerTy Warning)
: OutFile(OutFile), OutFileType(OutFileType), WarningHandler(Warning) {}
virtual ~DwarfStreamer() = default;
~DwarfStreamer() override = default;

static Expected<std::unique_ptr<DwarfStreamer>> createStreamer(
const Triple &TheTriple, DWARFLinkerBase::OutputFileType FileType,
Expand Down
2 changes: 1 addition & 1 deletion llvm/include/llvm/DWARFLinker/Parallel/DWARFLinker.h
Original file line number Diff line number Diff line change
Expand Up @@ -120,7 +120,7 @@ using SectionHandlerTy =

class DWARFLinker : public DWARFLinkerBase {
public:
virtual ~DWARFLinker() = default;
~DWARFLinker() override = default;

/// Creates dwarf linker instance.
LLVM_ABI static std::unique_ptr<DWARFLinker>
Expand Down
2 changes: 1 addition & 1 deletion llvm/include/llvm/Debuginfod/BuildIDFetcher.h
Original file line number Diff line number Diff line change
Expand Up @@ -24,7 +24,7 @@ class DebuginfodFetcher : public object::BuildIDFetcher {
public:
DebuginfodFetcher(std::vector<std::string> DebugFileDirectories)
: BuildIDFetcher(std::move(DebugFileDirectories)) {}
virtual ~DebuginfodFetcher() = default;
~DebuginfodFetcher() override = default;

/// Fetches the given Build ID using debuginfod and returns a local path to
/// the resulting file.
Expand Down
9 changes: 4 additions & 5 deletions llvm/include/llvm/IR/DroppedVariableStatsIR.h
Original file line number Diff line number Diff line change
Expand Up @@ -71,13 +71,12 @@ class LLVM_ABI DroppedVariableStatsIR : public DroppedVariableStats {
StringRef PassLevel);

/// Override base class method to run on an llvm::Function specifically.
virtual void
visitEveryInstruction(unsigned &DroppedCount,
DenseMap<VarID, DILocation *> &InlinedAtsMap,
VarID Var) override;
void visitEveryInstruction(unsigned &DroppedCount,
DenseMap<VarID, DILocation *> &InlinedAtsMap,
VarID Var) override;

/// Override base class method to run on #dbg_values specifically.
virtual void visitEveryDebugRecord(
void visitEveryDebugRecord(
DenseSet<VarID> &VarIDSet,
DenseMap<StringRef, DenseMap<VarID, DILocation *>> &InlinedAtsMap,
StringRef FuncName, bool Before) override;
Expand Down
2 changes: 1 addition & 1 deletion llvm/include/llvm/IR/OptBisect.h
Original file line number Diff line number Diff line change
Expand Up @@ -51,7 +51,7 @@ class LLVM_ABI OptBisect : public OptPassGate {
/// through LLVMContext.
OptBisect() = default;

virtual ~OptBisect() = default;
~OptBisect() override = default;

/// Checks the bisect limit to determine if the specified pass should run.
///
Expand Down
12 changes: 6 additions & 6 deletions llvm/include/llvm/MCA/HardwareUnits/LSUnit.h
Original file line number Diff line number Diff line change
Expand Up @@ -57,7 +57,7 @@ class LLVM_ABI LSUnitBase : public HardwareUnit {
LSUnitBase(const MCSchedModel &SM, unsigned LoadQueueSize,
unsigned StoreQueueSize, bool AssumeNoAlias);

virtual ~LSUnitBase();
~LSUnitBase() override;

/// Returns the total number of entries in the load queue.
unsigned getLoadQueueSize() const { return LQSize; }
Expand Down Expand Up @@ -465,19 +465,19 @@ class LLVM_ABI LSUnit : public LSUnitBase {
/// 6. A store has to wait until an older store barrier is fully executed.
unsigned dispatch(const InstRef &IR) override;

virtual void onInstructionIssued(const InstRef &IR) override {
void onInstructionIssued(const InstRef &IR) override {
unsigned GroupID = IR.getInstruction()->getLSUTokenID();
Groups[GroupID]->onInstructionIssued(IR);
}

virtual void onInstructionRetired(const InstRef &IR) override;
void onInstructionRetired(const InstRef &IR) override;

virtual void onInstructionExecuted(const InstRef &IR) override;
void onInstructionExecuted(const InstRef &IR) override;

virtual void cycleEvent() override;
void cycleEvent() override;

#ifndef NDEBUG
virtual void dump() const override;
void dump() const override;
#endif

private:
Expand Down
2 changes: 1 addition & 1 deletion llvm/include/llvm/MCA/HardwareUnits/ResourceManager.h
Original file line number Diff line number Diff line change
Expand Up @@ -121,7 +121,7 @@ class LLVM_ABI DefaultResourceStrategy final : public ResourceStrategy {
DefaultResourceStrategy(uint64_t UnitMask)
: ResourceUnitMask(UnitMask), NextInSequenceMask(UnitMask),
RemovedFromNextInSequence(0) {}
virtual ~DefaultResourceStrategy() = default;
~DefaultResourceStrategy() override = default;

uint64_t select(uint64_t ReadyMask) override;
void used(uint64_t Mask) override;
Expand Down
2 changes: 1 addition & 1 deletion llvm/include/llvm/MCA/HardwareUnits/Scheduler.h
Original file line number Diff line number Diff line change
Expand Up @@ -47,7 +47,7 @@ class LLVM_ABI DefaultSchedulerStrategy : public SchedulerStrategy {

public:
DefaultSchedulerStrategy() = default;
virtual ~DefaultSchedulerStrategy();
~DefaultSchedulerStrategy() override;

bool compare(const InstRef &Lhs, const InstRef &Rhs) const override {
int LhsRank = computeRank(Lhs);
Expand Down
2 changes: 1 addition & 1 deletion llvm/include/llvm/MCA/View.h
Original file line number Diff line number Diff line change
Expand Up @@ -26,7 +26,7 @@ namespace mca {

class LLVM_ABI View : public HWEventListener {
public:
virtual ~View() = default;
~View() override = default;

virtual void printView(llvm::raw_ostream &OS) const = 0;
virtual StringRef getNameAsString() const = 0;
Expand Down
2 changes: 1 addition & 1 deletion llvm/include/llvm/ObjCopy/ConfigManager.h
Original file line number Diff line number Diff line change
Expand Up @@ -23,7 +23,7 @@ namespace llvm {
namespace objcopy {

struct LLVM_ABI ConfigManager : public MultiFormatConfig {
virtual ~ConfigManager() {}
~ConfigManager() override {}

const CommonConfig &getCommonConfig() const override { return Common; }

Expand Down
4 changes: 2 additions & 2 deletions llvm/include/llvm/Object/GOFFObjectFile.h
Original file line number Diff line number Diff line change
Expand Up @@ -91,10 +91,10 @@ class LLVM_ABI GOFFObjectFile : public ObjectFile {

// SectionRef.
void moveSectionNext(DataRefImpl &Sec) const override;
virtual Expected<StringRef> getSectionName(DataRefImpl Sec) const override;
Expected<StringRef> getSectionName(DataRefImpl Sec) const override;
uint64_t getSectionAddress(DataRefImpl Sec) const override;
uint64_t getSectionSize(DataRefImpl Sec) const override;
virtual Expected<ArrayRef<uint8_t>>
Expected<ArrayRef<uint8_t>>
getSectionContents(DataRefImpl Sec) const override;
uint64_t getSectionIndex(DataRefImpl Sec) const override { return Sec.d.a; }
uint64_t getSectionAlignment(DataRefImpl Sec) const override;
Expand Down
2 changes: 1 addition & 1 deletion llvm/include/llvm/ProfileData/MemProfReader.h
Original file line number Diff line number Diff line change
Expand Up @@ -110,7 +110,7 @@ class LLVM_ABI RawMemProfReader final : public MemProfReader {
public:
RawMemProfReader(const RawMemProfReader &) = delete;
RawMemProfReader &operator=(const RawMemProfReader &) = delete;
virtual ~RawMemProfReader() override;
~RawMemProfReader() override;

// Prints the contents of the profile in YAML format.
void printYAML(raw_ostream &OS);
Expand Down
2 changes: 1 addition & 1 deletion llvm/include/llvm/ProfileData/PGOCtxProfWriter.h
Original file line number Diff line number Diff line change
Expand Up @@ -92,7 +92,7 @@ class LLVM_ABI PGOCtxProfileWriter final : public ctx_profile::ProfileWriter {
PGOCtxProfileWriter(raw_ostream &Out,
std::optional<unsigned> VersionOverride = std::nullopt,
bool IncludeEmpty = false);
~PGOCtxProfileWriter() { Writer.ExitBlock(); }
~PGOCtxProfileWriter() override { Writer.ExitBlock(); }

void startContextSection() override;
void writeContextual(const ctx_profile::ContextNode &RootNode,
Expand Down
2 changes: 1 addition & 1 deletion llvm/include/llvm/SandboxIR/BasicBlock.h
Original file line number Diff line number Diff line change
Expand Up @@ -78,7 +78,7 @@ class BasicBlock : public Value {
}

public:
~BasicBlock() = default;
~BasicBlock() override = default;
/// For isa/dyn_cast.
static bool classof(const Value *From) {
return From->getSubclassID() == Value::ClassID::Block;
Expand Down
2 changes: 1 addition & 1 deletion llvm/include/llvm/SandboxIR/PassManager.h
Original file line number Diff line number Diff line change
Expand Up @@ -49,7 +49,7 @@ class PassManager : public ParentPass {
}
PassManager(const PassManager &) = delete;
PassManager(PassManager &&) = default;
virtual ~PassManager() = default;
~PassManager() override = default;
PassManager &operator=(const PassManager &) = delete;

public:
Expand Down
2 changes: 1 addition & 1 deletion llvm/include/llvm/Target/TargetLoweringObjectFile.h
Original file line number Diff line number Diff line change
Expand Up @@ -74,7 +74,7 @@ class LLVM_ABI TargetLoweringObjectFile : public MCObjectFileInfo {
TargetLoweringObjectFile(const TargetLoweringObjectFile &) = delete;
TargetLoweringObjectFile &
operator=(const TargetLoweringObjectFile &) = delete;
virtual ~TargetLoweringObjectFile();
~TargetLoweringObjectFile() override;

Mangler &getMangler() const { return *Mang; }

Expand Down
4 changes: 2 additions & 2 deletions llvm/include/llvm/Transforms/IPO/Attributor.h
Original file line number Diff line number Diff line change
Expand Up @@ -3325,7 +3325,7 @@ struct LLVM_ABI AbstractAttribute : public IRPosition, public AADepGraphNode {
AbstractAttribute(const IRPosition &IRP) : IRPosition(IRP) {}

/// Virtual destructor.
virtual ~AbstractAttribute() = default;
~AbstractAttribute() override = default;

/// Compile time access to the IR attribute kind.
static constexpr Attribute::AttrKind IRAttributeKind = Attribute::None;
Expand Down Expand Up @@ -5588,7 +5588,7 @@ struct AACallEdges : public StateWrapper<BooleanState, AbstractAttribute>,
// Synthetic root node for the Attributor's internal call graph.
struct AttributorCallGraph : public AACallGraphNode {
AttributorCallGraph(Attributor &A) : AACallGraphNode(A) {}
virtual ~AttributorCallGraph() = default;
~AttributorCallGraph() override = default;

AACallEdgeIterator optimisticEdgesBegin() const override {
return AACallEdgeIterator(A, A.Functions.begin());
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -305,7 +305,7 @@ class MemDGNode final : public DGNode {
return make_range(MemSuccs.begin(), MemSuccs.end());
}
#ifndef NDEBUG
virtual void print(raw_ostream &OS, bool PrintDeps = true) const override;
void print(raw_ostream &OS, bool PrintDeps = true) const override;
#endif // NDEBUG
};

Expand Down
2 changes: 1 addition & 1 deletion llvm/include/llvm/XRay/FDRRecords.h
Original file line number Diff line number Diff line change
Expand Up @@ -101,7 +101,7 @@ class MetadataRecord : public Record {

MetadataType metadataType() const { return MT; }

virtual ~MetadataRecord() = default;
~MetadataRecord() override = default;
};

// What follows are specific Metadata record types which encapsulate the
Expand Down
2 changes: 1 addition & 1 deletion llvm/include/llvm/XRay/FDRTraceWriter.h
Original file line number Diff line number Diff line change
Expand Up @@ -30,7 +30,7 @@ class LLVM_ABI FDRTraceWriter : public RecordVisitor {
public:
// Construct an FDRTraceWriter associated with an output stream.
explicit FDRTraceWriter(raw_ostream &O, const XRayFileHeader &H);
~FDRTraceWriter();
~FDRTraceWriter() override;

Error visit(BufferExtents &) override;
Error visit(WallclockRecord &) override;
Expand Down
2 changes: 1 addition & 1 deletion llvm/lib/Analysis/InlineCost.cpp
Original file line number Diff line number Diff line change
Expand Up @@ -1242,7 +1242,7 @@ class InlineCostCallAnalyzer final : public CallAnalyzer {
return std::nullopt;
}

virtual ~InlineCostCallAnalyzer() = default;
~InlineCostCallAnalyzer() override = default;
int getThreshold() const { return Threshold; }
int getCost() const { return Cost; }
int getStaticBonusApplied() const { return StaticBonusApplied; }
Expand Down
4 changes: 2 additions & 2 deletions llvm/lib/IR/AsmWriter.cpp
Original file line number Diff line number Diff line change
Expand Up @@ -843,7 +843,7 @@ class SlotTracker : public AbstractSlotTrackerStorage {
SlotTracker(const SlotTracker &) = delete;
SlotTracker &operator=(const SlotTracker &) = delete;

~SlotTracker() = default;
~SlotTracker() override = default;

void setProcessHook(
std::function<void(AbstractSlotTrackerStorage *, const Module *, bool)>);
Expand Down Expand Up @@ -5323,7 +5323,7 @@ struct MDTreeAsmWriterContext : public AsmWriterContext {
--Level;
}

~MDTreeAsmWriterContext() {
~MDTreeAsmWriterContext() override {
for (const auto &Entry : Buffer) {
MainOS << "\n";
unsigned NumIndent = Entry.first * 2U;
Expand Down
6 changes: 3 additions & 3 deletions llvm/lib/LTO/LTO.cpp
Original file line number Diff line number Diff line change
Expand Up @@ -1711,7 +1711,7 @@ class SecondRoundThinBackend : public InProcessThinBackend {
/*ShouldEmitImportsFiles=*/false),
IRFiles(std::move(IRFiles)), CombinedCGDataHash(CombinedCGDataHash) {}

virtual Error runThinLTOBackendThread(
Error runThinLTOBackendThread(
AddStreamFn AddStream, FileCache Cache, unsigned Task, BitcodeModule BM,
ModuleSummaryIndex &CombinedIndex,
const FunctionImporter::ImportMapTy &ImportList,
Expand Down Expand Up @@ -2271,8 +2271,8 @@ class OutOfProcessThinBackend : public CGThinBackend {
RemoteCompilerPrependArgs(RemoteCompilerPrependArgs),
RemoteCompilerArgs(RemoteCompilerArgs), SaveTemps(SaveTemps) {}

virtual void setup(unsigned ThinLTONumTasks, unsigned ThinLTOTaskOffset,
llvm::Triple Triple) override {
void setup(unsigned ThinLTONumTasks, unsigned ThinLTOTaskOffset,
llvm::Triple Triple) override {
UID = itostr(sys::Process::getProcessId());
Jobs.resize((size_t)ThinLTONumTasks);
this->ThinLTOTaskOffset = ThinLTOTaskOffset;
Expand Down
Loading