Roll-back r250822.

Summary: It breaks the build for the ASTMatchers

Subscribers: klimek, cfe-commits

Differential Revision: http://reviews.llvm.org/D13893

llvm-svn: 250827
This commit is contained in:
Angel Garcia Gomez 2015-10-20 13:23:58 +00:00
parent 7fd67e25aa
commit 637d1e6694
150 changed files with 232 additions and 222 deletions

View File

@ -43,7 +43,7 @@ class ASTConsumer {
public:
ASTConsumer() : SemaConsumer(false) { }
virtual ~ASTConsumer() = default;
virtual ~ASTConsumer() {}
/// Initialize - This is called to initialize the consumer, providing the
/// ASTContext.

View File

@ -333,7 +333,7 @@ template<typename T>
class CanProxy : public CanProxyAdaptor<T> {
public:
/// \brief Build a NULL proxy.
CanProxy() = default;
CanProxy() { }
/// \brief Build a proxy to the given canonical type.
CanProxy(CanQual<T> Stored) { this->Stored = Stored; }
@ -389,7 +389,7 @@ struct CanTypeIterator
CanQualType,
typename std::iterator_traits<InputIterator>::difference_type,
CanProxy<Type>, CanQualType> {
CanTypeIterator() = default;
CanTypeIterator() {}
explicit CanTypeIterator(InputIterator Iter)
: CanTypeIterator::iterator_adaptor_base(std::move(Iter)) {}

View File

@ -180,7 +180,7 @@ class CXXRecordDecl::friend_iterator {
friend class CXXRecordDecl;
explicit friend_iterator(FriendDecl *Ptr) : Ptr(Ptr) {}
public:
friend_iterator() = default;
friend_iterator() {}
typedef FriendDecl *value_type;
typedef FriendDecl *reference;

View File

@ -664,7 +664,7 @@ protected:
typename std::iterator_traits<typename llvm::FoldingSetVector<
EntryType>::iterator>::iterator_category,
DeclType *, ptrdiff_t, DeclType *, DeclType *> {
SpecIterator() = default;
SpecIterator() {}
explicit SpecIterator(
typename llvm::FoldingSetVector<EntryType>::iterator SetIter)
: SpecIterator::iterator_adaptor_base(std::move(SetIter)) {}

View File

@ -337,7 +337,7 @@ public:
{}
public:
Classification() = default;
Classification() {}
Kinds getKind() const { return static_cast<Kinds>(Kind); }
ModifiableType getModifiable() const {
@ -4076,7 +4076,7 @@ public:
friend class DesignatedInitExpr;
public:
Designator() = default;
Designator() {}
/// @brief Initializes a field designator.
Designator(const IdentifierInfo *FieldName, SourceLocation DotLoc,

View File

@ -2278,7 +2278,7 @@ public:
: Expr(ArrayTypeTraitExprClass, Empty), ATT(0), Value(false),
QueriedType() { }
virtual ~ArrayTypeTraitExpr() = default;
virtual ~ArrayTypeTraitExpr() { }
SourceLocation getLocStart() const LLVM_READONLY { return Loc; }
SourceLocation getLocEnd() const LLVM_READONLY { return RParen; }

View File

@ -64,7 +64,7 @@ public:
ManglerKind Kind)
: Context(Context), Diags(Diags), Kind(Kind) {}
virtual ~MangleContext() = default;
virtual ~MangleContext() { }
ASTContext &getASTContext() const { return Context; }

View File

@ -32,7 +32,7 @@ class VarDecl;
/// literals within a particular context.
class MangleNumberingContext : public RefCountedBase<MangleNumberingContext> {
public:
virtual ~MangleNumberingContext() = default;
virtual ~MangleNumberingContext() {}
/// \brief Retrieve the mangling number of a new lambda expression with the
/// given call operator within this context.

View File

@ -248,7 +248,7 @@ Decl *getPrimaryMergedDecl(Decl *D);
template<typename decl_type>
class Mergeable {
public:
Mergeable() = default;
Mergeable() {}
/// \brief Return the first declaration of this declaration or itself if this
/// is the only declaration.

View File

@ -81,7 +81,7 @@ class StmtIteratorImpl : public StmtIteratorBase,
protected:
StmtIteratorImpl(const StmtIteratorBase& RHS) : StmtIteratorBase(RHS) {}
public:
StmtIteratorImpl() = default;
StmtIteratorImpl() {}
StmtIteratorImpl(Stmt **s) : StmtIteratorBase(s) {}
StmtIteratorImpl(Decl **dgi, Decl **dge) : StmtIteratorBase(dgi, dge) {}
StmtIteratorImpl(const VariableArrayType *t) : StmtIteratorBase(t) {}

View File

@ -59,7 +59,7 @@ class UnresolvedSetImpl {
// UnresolvedSet.
private:
template <unsigned N> friend class UnresolvedSet;
UnresolvedSetImpl() = default;
UnresolvedSetImpl() {}
UnresolvedSetImpl(const UnresolvedSetImpl &) {}
public:

View File

@ -298,7 +298,7 @@ public:
bool isMicrosoft() const { return IsMicrosoftABI; }
virtual ~VTableContextBase() = default;
virtual ~VTableContextBase() {}
protected:
typedef llvm::DenseMap<const CXXMethodDecl *, ThunkInfoVectorTy> ThunksMapTy;

View File

@ -131,7 +131,7 @@ public:
/// BoundNodesTree.
class Visitor {
public:
virtual ~Visitor() = default;
virtual ~Visitor() {}
/// \brief Called multiple times during a single call to VisitMatches(...).
///
@ -209,7 +209,7 @@ public:
template <typename T>
class MatcherInterface : public DynMatcherInterface {
public:
~MatcherInterface() override = default;
~MatcherInterface() override {}
/// \brief Returns true if 'Node' can be matched.
///
@ -798,7 +798,7 @@ public:
AMM_ParentOnly
};
virtual ~ASTMatchFinder() = default;
virtual ~ASTMatchFinder() {}
/// \brief Returns true if the given class is directly or indirectly derived
/// from a base type matching \c base.
@ -1376,7 +1376,7 @@ class VariadicDynCastAllOfMatcher
BindableMatcher<SourceT>, Matcher<TargetT>,
makeDynCastAllOfComposite<SourceT, TargetT> > {
public:
VariadicDynCastAllOfMatcher() = default;
VariadicDynCastAllOfMatcher() {}
};
/// \brief A \c VariadicAllOfMatcher<T> object is a variadic functor that takes
@ -1394,7 +1394,7 @@ class VariadicAllOfMatcher : public llvm::VariadicFunction<
BindableMatcher<T>, Matcher<T>,
makeAllOfComposite<T> > {
public:
VariadicAllOfMatcher() = default;
VariadicAllOfMatcher() {}
};
/// \brief Matches nodes of type \c TLoc for which the inner
@ -1515,7 +1515,7 @@ public:
struct Func : public llvm::VariadicFunction<Self, Matcher<InnerTBase>,
&Self::create> {
Func() = default;
Func() {}
};
private:

View File

@ -606,7 +606,7 @@ enum PositionContext { FieldWidthPos = 0, PrecisionPos = 1 };
class FormatStringHandler {
public:
FormatStringHandler() = default;
FormatStringHandler() {}
virtual ~FormatStringHandler();
virtual void HandleNullChar(const char *nullCharacter) {}

View File

@ -53,7 +53,7 @@ public:
class Observer {
virtual void anchor();
public:
virtual ~Observer() = default;
virtual ~Observer() {}
/// A callback invoked right before invoking the
/// liveness transfer function on the given statement.

View File

@ -48,7 +48,7 @@ enum UnreachableKind {
class Callback {
virtual void anchor();
public:
virtual ~Callback() = default;
virtual ~Callback() {}
virtual void HandleUnreachable(UnreachableKind UK,
SourceLocation L,
SourceRange ConditionVal,

View File

@ -176,7 +176,7 @@ template <class Self>
class VisitReducer : public Traversal<Self, VisitReducerBase>,
public VisitReducerBase {
public:
VisitReducer() = default;
VisitReducer() {}
public:
R_SExpr reduceNull() { return true; }

View File

@ -99,7 +99,7 @@ public:
class UninitVariablesHandler {
public:
UninitVariablesHandler() = default;
UninitVariablesHandler() {}
virtual ~UninitVariablesHandler();
/// Called when the uninitialized variable is used at the given expression.

View File

@ -44,7 +44,7 @@ namespace idx { class TranslationUnit; }
/// to AnalysisDeclContext.
class ManagedAnalysis {
protected:
ManagedAnalysis() = default;
ManagedAnalysis() {}
public:
virtual ~ManagedAnalysis();
@ -289,7 +289,7 @@ class StackFrameContext : public LocationContext {
Block(blk), Index(idx) {}
public:
~StackFrameContext() override = default;
~StackFrameContext() override {}
const Stmt *getCallSite() const { return CallSite; }
@ -324,7 +324,7 @@ class ScopeContext : public LocationContext {
: LocationContext(Scope, ctx, parent), Enter(s) {}
public:
~ScopeContext() override = default;
~ScopeContext() override {}
void Profile(llvm::FoldingSetNodeID &ID) override;
@ -352,7 +352,7 @@ class BlockInvocationContext : public LocationContext {
: LocationContext(Block, ctx, parent), BD(bd), ContextData(contextData) {}
public:
~BlockInvocationContext() override = default;
~BlockInvocationContext() override {}
const BlockDecl *getBlockDecl() const { return BD; }

View File

@ -704,11 +704,11 @@ public:
/// operator error is found when building the CFG.
class CFGCallback {
public:
CFGCallback() = default;
CFGCallback() {}
virtual void compareAlwaysTrue(const BinaryOperator *B, bool isAlwaysTrue) {}
virtual void compareBitwiseEquality(const BinaryOperator *B,
bool isAlwaysTrue) {}
virtual ~CFGCallback() = default;
virtual ~CFGCallback() {}
};
/// CFG - Represents a source-level, intra-procedural CFG that represents the

View File

@ -51,7 +51,7 @@ protected:
std::unique_ptr<FileSystemStatCache> NextStatCache;
public:
virtual ~FileSystemStatCache() = default;
virtual ~FileSystemStatCache() {}
enum LookupResult {
CacheExists, ///< We know the file exists and its cached stat data.

View File

@ -385,7 +385,7 @@ private:
void operator=(const IdentifierIterator &) = delete;
protected:
IdentifierIterator() = default;
IdentifierIterator() { }
public:
virtual ~IdentifierIterator();

View File

@ -88,7 +88,7 @@ public:
// FIXME: This really shouldn't be copyable, but is currently copied in some
// error handling in Driver::generateCompilationDiagnostics.
Command(const Command &) = default;
virtual ~Command() = default;
virtual ~Command() {}
virtual void Print(llvm::raw_ostream &OS, const char *Terminator, bool Quote,
CrashReportInfo *CrashInfo = nullptr) const;

View File

@ -20,7 +20,7 @@ namespace edit {
class EditsReceiver {
public:
virtual ~EditsReceiver() = default;
virtual ~EditsReceiver() { }
virtual void insert(SourceLocation loc, StringRef text) = 0;
virtual void replace(CharSourceRange range, StringRef text) = 0;

View File

@ -58,8 +58,8 @@ struct Location {
/// the various constructs that are found in serialized diagnostics.
class SerializedDiagnosticReader {
public:
SerializedDiagnosticReader() = default;
virtual ~SerializedDiagnosticReader() = default;
SerializedDiagnosticReader() {}
virtual ~SerializedDiagnosticReader() {}
/// \brief Read the diagnostics in \c File
std::error_code readDiagnostics(StringRef File);

View File

@ -161,7 +161,7 @@ public:
unsigned Min, Max;
bool MatchAnyLine;
virtual ~Directive() = default;
virtual ~Directive() { }
// Returns true if directive text is valid.
// Otherwise returns false and populates E.

View File

@ -40,7 +40,7 @@ class ModuleMapParser;
/// reads module map files.
class ModuleMapCallbacks {
public:
virtual ~ModuleMapCallbacks() = default;
virtual ~ModuleMapCallbacks() {}
/// \brief Called when a module map file has been read.
///

View File

@ -64,7 +64,7 @@ protected:
PTHLexer(Preprocessor& pp, FileID FID, const unsigned char *D,
const unsigned char* ppcond, PTHManager &PM);
public:
~PTHLexer() override = default;
~PTHLexer() override {}
/// Lex - Return the next token.
bool Lex(Token &Tok);

View File

@ -81,7 +81,7 @@ protected:
ParsingFilename(false),
LexingRawMode(false) {}
virtual ~PreprocessorLexer() = default;
virtual ~PreprocessorLexer() {}
virtual void IndirectLex(Token& Result) = 0;

View File

@ -1313,7 +1313,7 @@ public:
TypeDiagnoser(bool Suppressed = false) : Suppressed(Suppressed) { }
virtual void diagnose(Sema &S, SourceLocation Loc, QualType T) = 0;
virtual ~TypeDiagnoser() = default;
virtual ~TypeDiagnoser() {}
};
static int getPrintable(int I) { return I; }
@ -2297,7 +2297,7 @@ public:
virtual SemaDiagnosticBuilder diagnoseConversion(
Sema &S, SourceLocation Loc, QualType T, QualType ConvTy) = 0;
virtual ~ContextualImplicitConverter() = default;
virtual ~ContextualImplicitConverter() {}
};
class ICEConvertDiagnoser : public ContextualImplicitConverter {
@ -8597,7 +8597,7 @@ public:
virtual void diagnoseNotICE(Sema &S, SourceLocation Loc, SourceRange SR) =0;
virtual void diagnoseFold(Sema &S, SourceLocation Loc, SourceRange SR);
virtual ~VerifyICEDiagnoser() = default;
virtual ~VerifyICEDiagnoser() { }
};
/// VerifyIntegerConstantExpression - Verifies that an expression is an ICE,

View File

@ -255,7 +255,7 @@ public:
IsObjCIvarLookup(false), IsAddressOfOperand(false), Typo(Typo),
TypoNNS(TypoNNS) {}
virtual ~CorrectionCandidateCallback() = default;
virtual ~CorrectionCandidateCallback() {}
/// \brief Simple predicate used by the default RankCandidate to
/// determine whether to return an edit distance of 0 or InvalidDistance.

View File

@ -57,7 +57,7 @@ public:
class NodeResolver {
virtual void anchor();
public:
virtual ~NodeResolver() = default;
virtual ~NodeResolver() {}
virtual const ExplodedNode*
getOriginalNode(const ExplodedNode *N) = 0;
};
@ -529,7 +529,7 @@ class BugReporterContext {
public:
BugReporterContext(GRBugReporter& br) : BR(br) {}
virtual ~BugReporterContext() = default;
virtual ~BugReporterContext() {}
GRBugReporter& getBugReporter() { return BR; }

View File

@ -42,7 +42,7 @@ public:
BugType(const CheckerBase *checker, StringRef name, StringRef cat)
: Check(checker->getCheckName()), Name(name), Category(cat),
SuppressonSink(false) {}
virtual ~BugType() = default;
virtual ~BugType() {}
// FIXME: Should these be made strings as well?
StringRef getName() const { return Name; }

View File

@ -481,7 +481,7 @@ private:
public:
StackHintGeneratorForSymbol(SymbolRef S, StringRef M) : Sym(S), Msg(M) {}
~StackHintGeneratorForSymbol() override = default;
~StackHintGeneratorForSymbol() override {}
/// \brief Search the call expression for the symbol Sym and dispatch the
/// 'getMessageForX()' methods to construct a specific message.

View File

@ -168,7 +168,7 @@ protected:
RegionAndSymbolInvalidationTraits *ETraits) const {}
public:
virtual ~CallEvent() = default;
virtual ~CallEvent() {}
/// \brief Returns the kind of call this is.
virtual Kind getKind() const = 0;

View File

@ -254,7 +254,7 @@ public:
assert(hasNoSinksInFrontier());
}
virtual ~NodeBuilder() = default;
virtual ~NodeBuilder() {}
/// \brief Generates a node in the ExplodedGraph.
ExplodedNode *generateNode(const ProgramPoint &PP,

View File

@ -68,7 +68,7 @@ public:
ArrayIndexTy(context.IntTy),
ArrayIndexWidth(context.getTypeSize(ArrayIndexTy)) {}
virtual ~SValBuilder() = default;
virtual ~SValBuilder() {}
bool haveSameType(const SymExpr *Sym1, const SymExpr *Sym2) {
return haveSameType(Sym1->getType(), Sym2->getType());

View File

@ -49,7 +49,7 @@ protected:
StoreManager(ProgramStateManager &stateMgr);
public:
virtual ~StoreManager() = default;
virtual ~StoreManager() {}
/// Return the value bound to specified location in a given state.
/// \param[in] store The analysis state.

View File

@ -43,7 +43,7 @@ class MemRegion;
class SubEngine {
virtual void anchor();
public:
virtual ~SubEngine() = default;
virtual ~SubEngine() {}
virtual ProgramStateRef getInitialState(const LocationContext *InitLoc) = 0;

View File

@ -57,7 +57,7 @@ protected:
SymExpr(Kind k) : K(k) {}
public:
virtual ~SymExpr() = default;
virtual ~SymExpr() {}
Kind getKind() const { return K; }
@ -109,7 +109,7 @@ protected:
SymbolData(Kind k, SymbolID sym) : SymExpr(k), Sym(sym) {}
public:
~SymbolData() override = default;
~SymbolData() override {}
SymbolID getSymbolID() const { return Sym; }

View File

@ -37,7 +37,7 @@ template<> struct ProgramStateTrait<TaintMap>
class TaintManager {
TaintManager() = default;
TaintManager() {}
};
}

View File

@ -82,7 +82,7 @@ public:
class Visitor {
public:
Visitor() = default;
Visitor() {}
virtual ~Visitor();
virtual bool visit(const WorkListUnit &U) = 0;
};

View File

@ -25,7 +25,7 @@ namespace clang {
namespace tooling {
struct PathComparator {
virtual ~PathComparator() = default;
virtual ~PathComparator() {}
virtual bool equivalent(StringRef FileA, StringRef FileB) const = 0;
};
class FileMatchTrieNode;

View File

@ -110,7 +110,7 @@ std::unique_ptr<FrontendActionFactory> newFrontendActionFactory();
/// newFrontendActionFactory.
class SourceFileCallbacks {
public:
virtual ~SourceFileCallbacks() = default;
virtual ~SourceFileCallbacks() {}
/// \brief Called before a source file is processed by a FrontEndAction.
/// \see clang::FrontendAction::BeginSourceFileAction

View File

@ -498,7 +498,7 @@ public:
} // end anonymous namespace.
/// \brief Anchor for VTable.
MigrationProcess::RewriteListener::~RewriteListener() = default;
MigrationProcess::RewriteListener::~RewriteListener() { }
MigrationProcess::MigrationProcess(
const CompilerInvocation &CI,

View File

@ -594,7 +594,7 @@ SourceLocation TransformActionsImpl::getLocForEndOfToken(SourceLocation loc,
return PP.getLocForEndOfToken(loc);
}
TransformActions::RewriteReceiver::~RewriteReceiver() = default;
TransformActions::RewriteReceiver::~RewriteReceiver() { }
TransformActions::TransformActions(DiagnosticsEngine &diag,
CapturedDiagList &capturedDiags,

View File

@ -27,7 +27,7 @@ using namespace clang;
using namespace arcmt;
using namespace trans;
ASTTraverser::~ASTTraverser() = default;
ASTTraverser::~ASTTraverser() { }
bool MigrationPass::CFBridgingFunctionsDefined() {
if (!EnableCFBridgeFns.hasValue())

View File

@ -7914,7 +7914,7 @@ QualType ASTContext::getCorrespondingUnsignedType(QualType T) const {
}
}
ASTMutationListener::~ASTMutationListener() = default;
ASTMutationListener::~ASTMutationListener() { }
void ASTMutationListener::DeducedReturnType(const FunctionDecl *FD,
QualType ReturnType) {}
@ -8502,7 +8502,7 @@ MangleContext *ASTContext::createMangleContext() {
llvm_unreachable("Unsupported ABI");
}
CXXABI::~CXXABI() = default;
CXXABI::~CXXABI() {}
size_t ASTContext::getSideTableAllocatedMemory() const {
return ASTRecordLayouts.getMemorySize() +

View File

@ -5344,7 +5344,7 @@ ASTImporter::ASTImporter(ASTContext &ToContext, FileManager &ToFileManager,
= ToContext.getTranslationUnitDecl();
}
ASTImporter::~ASTImporter() = default;
ASTImporter::~ASTImporter() { }
QualType ASTImporter::Import(QualType FromT) {
if (FromT.isNull())

View File

@ -236,7 +236,7 @@ void PrettyStackTraceDecl::print(raw_ostream &OS) const {
//===----------------------------------------------------------------------===//
// Out-of-line virtual method providing a home for Decl.
Decl::~Decl() = default;
Decl::~Decl() { }
void Decl::setDeclContext(DeclContext *DC) {
DeclCtx = DC;
@ -836,7 +836,7 @@ bool DeclContext::classof(const Decl *D) {
}
}
DeclContext::~DeclContext() = default;
DeclContext::~DeclContext() { }
/// \brief Find the parent context of this context that will be
/// used for unqualified name lookup.

View File

@ -21,7 +21,7 @@
using namespace clang;
ExternalASTSource::~ExternalASTSource() = default;
ExternalASTSource::~ExternalASTSource() { }
llvm::Optional<ExternalASTSource::ASTSourceDescriptor>
ExternalASTSource::getSourceDescriptor(unsigned ID) {

View File

@ -2338,4 +2338,4 @@ void Stmt::printPretty(raw_ostream &OS,
//===----------------------------------------------------------------------===//
// Implement virtual destructor.
PrinterHelper::~PrinterHelper() = default;
PrinterHelper::~PrinterHelper() {}

View File

@ -2229,7 +2229,7 @@ VTableLayout::VTableLayout(uint64_t NumVTableComponents,
});
}
VTableLayout::~VTableLayout() = default;
VTableLayout::~VTableLayout() { }
ItaniumVTableContext::ItaniumVTableContext(ASTContext &Context)
: VTableContextBase(/*MS=*/false) {}

View File

@ -902,13 +902,13 @@ MatchFinder::MatchResult::MatchResult(const BoundNodes &Nodes,
: Nodes(Nodes), Context(Context),
SourceManager(&Context->getSourceManager()) {}
MatchFinder::MatchCallback::~MatchCallback() = default;
MatchFinder::ParsingDoneTestCallback::~ParsingDoneTestCallback() = default;
MatchFinder::MatchCallback::~MatchCallback() {}
MatchFinder::ParsingDoneTestCallback::~ParsingDoneTestCallback() {}
MatchFinder::MatchFinder(MatchFinderOptions Options)
: Options(std::move(Options)), ParsingDone(nullptr) {}
MatchFinder::~MatchFinder() = default;
MatchFinder::~MatchFinder() {}
void MatchFinder::addMatcher(const DeclarationMatcher &NodeMatch,
MatchCallback *Action) {

View File

@ -103,7 +103,7 @@ public:
/// arguments, and various other methods for type introspection.
class MatcherDescriptor {
public:
virtual ~MatcherDescriptor() = default;
virtual ~MatcherDescriptor() {}
virtual VariantMatcher create(SourceRange NameRange,
ArrayRef<ParserValue> Args,
Diagnostics *Error) const = 0;
@ -491,7 +491,7 @@ public:
OverloadedMatcherDescriptor(ArrayRef<MatcherDescriptor *> Callbacks)
: Overloads(Callbacks.begin(), Callbacks.end()) {}
~OverloadedMatcherDescriptor() override = default;
~OverloadedMatcherDescriptor() override {}
VariantMatcher create(SourceRange NameRange,
ArrayRef<ParserValue> Args,

View File

@ -257,7 +257,7 @@ private:
const char *CodeCompletionLocation;
};
Parser::Sema::~Sema() = default;
Parser::Sema::~Sema() {}
std::vector<ArgKind> Parser::Sema::getAcceptedCompletionTypes(
llvm::ArrayRef<std::pair<MatcherCtor, unsigned>> Context) {
@ -526,7 +526,7 @@ Parser::Parser(CodeTokenizer *Tokenizer, Sema *S,
: Tokenizer(Tokenizer), S(S ? S : &*DefaultRegistrySema),
NamedValues(NamedValues), Error(Error) {}
Parser::RegistrySema::~RegistrySema() = default;
Parser::RegistrySema::~RegistrySema() {}
llvm::Optional<MatcherCtor>
Parser::RegistrySema::lookupMatcherCtor(StringRef MatcherName) {

View File

@ -75,7 +75,7 @@ VariantMatcher::MatcherOps::constructVariadicOperator(
return DynTypedMatcher::constructVariadic(Op, NodeKind, DynMatchers);
}
VariantMatcher::Payload::~Payload() = default;
VariantMatcher::Payload::~Payload() {}
class VariantMatcher::SinglePayload : public VariantMatcher::Payload {
public:
@ -113,7 +113,7 @@ public:
PolymorphicPayload(std::vector<DynTypedMatcher> MatchersIn)
: Matchers(std::move(MatchersIn)) {}
~PolymorphicPayload() override = default;
~PolymorphicPayload() override {}
llvm::Optional<DynTypedMatcher> getSingleMatcher() const override {
if (Matchers.size() != 1)

View File

@ -551,7 +551,7 @@ ManagedAnalysis *&AnalysisDeclContext::getAnalysisImpl(const void *tag) {
// Cleanup.
//===----------------------------------------------------------------------===//
ManagedAnalysis::~ManagedAnalysis() = default;
ManagedAnalysis::~ManagedAnalysis() {}
AnalysisDeclContext::~AnalysisDeclContext() {
delete forcedBlkExprs;
@ -568,7 +568,7 @@ AnalysisDeclContextManager::~AnalysisDeclContextManager() {
llvm::DeleteContainerSeconds(Contexts);
}
LocationContext::~LocationContext() = default;
LocationContext::~LocationContext() {}
LocationContextManager::~LocationContextManager() {
clear();

View File

@ -4010,7 +4010,7 @@ public:
}
}
~StmtPrinterHelper() override = default;
~StmtPrinterHelper() override {}
const LangOptions &getLangOpts() const { return LangOpts; }
void setBlockID(signed i) { currentBlock = i; }

View File

@ -11,5 +11,5 @@
using namespace clang;
CodeInjector::CodeInjector() = default;
CodeInjector::~CodeInjector() = default;
CodeInjector::CodeInjector() {}
CodeInjector::~CodeInjector() {}

View File

@ -52,7 +52,7 @@ using namespace clang;
using namespace consumed;
// Key method definition
ConsumedWarningsHandlerBase::~ConsumedWarningsHandlerBase() = default;
ConsumedWarningsHandlerBase::~ConsumedWarningsHandlerBase() {}
static SourceLocation getFirstStmtLoc(const CFGBlock *Block) {
// Find the source location of the first statement in the block, if the block

View File

@ -26,7 +26,7 @@ using clang::analyze_format_string::ConversionSpecifier;
using namespace clang;
// Key function to FormatStringHandler.
FormatStringHandler::~FormatStringHandler() = default;
FormatStringHandler::~FormatStringHandler() {}
//===----------------------------------------------------------------------===//
// Functions for parsing format strings components in both printf and

View File

@ -16,7 +16,7 @@
using namespace clang;
ProgramPointTag::~ProgramPointTag() = default;
ProgramPointTag::~ProgramPointTag() {}
ProgramPoint ProgramPoint::getProgramPoint(const Stmt *S, ProgramPoint::Kind K,
const LocationContext *LC,

View File

@ -48,7 +48,7 @@ using namespace clang;
using namespace threadSafety;
// Key method definition
ThreadSafetyHandler::~ThreadSafetyHandler() = default;
ThreadSafetyHandler::~ThreadSafetyHandler() {}
namespace {
class TILPrinter :
@ -107,7 +107,7 @@ public:
: CapabilityExpr(CE), LKind(LK), AcquireLoc(Loc), Asserted(Asrt),
Declared(Declrd) {}
virtual ~FactEntry() = default;
virtual ~FactEntry() {}
LockKind kind() const { return LKind; }
SourceLocation loc() const { return AcquireLoc; }

View File

@ -837,7 +837,7 @@ struct PruneBlocksHandler : public UninitVariablesHandler {
: hadUse(numBlocks, false), hadAnyUse(false),
currentBlock(0) {}
~PruneBlocksHandler() override = default;
~PruneBlocksHandler() override {}
/// Records if a CFGBlock had a potential use of an uninitialized variable.
llvm::BitVector hadUse;
@ -922,4 +922,4 @@ void clang::runUninitializedVariablesAnalysis(
}
}
UninitVariablesHandler::~UninitVariablesHandler() = default;
UninitVariablesHandler::~UninitVariablesHandler() {}

View File

@ -393,7 +393,7 @@ bool DiagnosticsEngine::EmitCurrentDiagnostic(bool Force) {
}
DiagnosticConsumer::~DiagnosticConsumer() = default;
DiagnosticConsumer::~DiagnosticConsumer() {}
void DiagnosticConsumer::HandleDiagnostic(DiagnosticsEngine::Level DiagLevel,
const Diagnostic &Info) {
@ -981,7 +981,7 @@ bool DiagnosticConsumer::IncludeInDiagnosticCounts() const { return true; }
void IgnoringDiagConsumer::anchor() { }
ForwardingDiagnosticConsumer::~ForwardingDiagnosticConsumer() = default;
ForwardingDiagnosticConsumer::~ForwardingDiagnosticConsumer() {}
void ForwardingDiagnosticConsumer::HandleDiagnostic(
DiagnosticsEngine::Level DiagLevel,

View File

@ -605,5 +605,5 @@ void FileManager::PrintStats() const {
}
// Virtual destructors for abstract base classes that need live in Basic.
PCHContainerWriter::~PCHContainerWriter() = default;
PCHContainerReader::~PCHContainerReader() = default;
PCHContainerWriter::~PCHContainerWriter() {}
PCHContainerReader::~PCHContainerReader() {}

View File

@ -53,9 +53,9 @@ IdentifierInfo::IdentifierInfo() {
// IdentifierTable Implementation
//===----------------------------------------------------------------------===//
IdentifierIterator::~IdentifierIterator() = default;
IdentifierIterator::~IdentifierIterator() { }
IdentifierInfoLookup::~IdentifierInfoLookup() = default;
IdentifierInfoLookup::~IdentifierInfoLookup() {}
namespace {
/// \brief A simple identifier lookup iterator that represents an

View File

@ -2204,7 +2204,7 @@ LLVM_DUMP_METHOD void SourceManager::dump() const {
}
}
ExternalSLocEntrySource::~ExternalSLocEntrySource() = default;
ExternalSLocEntrySource::~ExternalSLocEntrySource() { }
/// Return the amount of memory used by memory buffers, breaking down
/// by heap-backed versus mmap'ed memory.

View File

@ -100,7 +100,7 @@ TargetInfo::TargetInfo(const llvm::Triple &T) : TargetOpts(), Triple(T) {
}
// Out of line virtual dtor for TargetInfo.
TargetInfo::~TargetInfo() = default;
TargetInfo::~TargetInfo() {}
/// getTypeName - Return the user string for the specified integer type enum.
/// For example, SignedShort -> "short".

View File

@ -84,9 +84,9 @@ bool Status::exists() const {
return isStatusKnown() && Type != file_type::file_not_found;
}
File::~File() = default;
File::~File() {}
FileSystem::~FileSystem() = default;
FileSystem::~FileSystem() {}
ErrorOr<std::unique_ptr<MemoryBuffer>>
FileSystem::getBufferForFile(const llvm::Twine &Name, int64_t FileSize,
@ -315,7 +315,7 @@ OverlayFileSystem::setCurrentWorkingDirectory(const Twine &Path) {
return std::error_code();
}
clang::vfs::detail::DirIterImpl::~DirIterImpl() = default;
clang::vfs::detail::DirIterImpl::~DirIterImpl() { }
namespace {
class OverlayFSDirIterImpl : public clang::vfs::detail::DirIterImpl {
@ -398,7 +398,7 @@ class InMemoryNode {
public:
InMemoryNode(Status Stat, InMemoryNodeKind Kind)
: Stat(std::move(Stat)), Kind(Kind) {}
virtual ~InMemoryNode() = default;
virtual ~InMemoryNode() {}
const Status &getStatus() const { return Stat; }
InMemoryNodeKind getKind() const { return Kind; }
virtual std::string toString(unsigned Indent) const = 0;
@ -482,7 +482,7 @@ InMemoryFileSystem::InMemoryFileSystem(bool UseNormalizedPaths)
llvm::sys::fs::perms::all_all))),
UseNormalizedPaths(UseNormalizedPaths) {}
InMemoryFileSystem::~InMemoryFileSystem() = default;
InMemoryFileSystem::~InMemoryFileSystem() {}
std::string InMemoryFileSystem::toString() const {
return Root->toString(/*Indent=*/0);

View File

@ -40,7 +40,7 @@ CGBlockInfo::CGBlockInfo(const BlockDecl *block, StringRef name)
}
// Anchor the vtable to this translation unit.
BlockByrefHelpers::~BlockByrefHelpers() = default;
BlockByrefHelpers::~BlockByrefHelpers() {}
/// Build the given block as a global block.
static llvm::Constant *buildGlobalBlock(CodeGenModule &CGM,

View File

@ -22,7 +22,7 @@
using namespace clang;
using namespace CodeGen;
CGCUDARuntime::~CGCUDARuntime() = default;
CGCUDARuntime::~CGCUDARuntime() {}
RValue CGCUDARuntime::EmitCUDAKernelCallExpr(CodeGenFunction &CGF,
const CUDAKernelCallExpr *E,

View File

@ -18,7 +18,7 @@
using namespace clang;
using namespace CodeGen;
CGCXXABI::~CGCXXABI() = default;
CGCXXABI::~CGCXXABI() { }
void CGCXXABI::ErrorUnsupportedABI(CodeGenFunction &CGF, StringRef S) {
DiagnosticsEngine &Diags = CGF.CGM.getDiags();

View File

@ -584,7 +584,7 @@ struct TypeExpansion {
const TypeExpansionKind Kind;
TypeExpansion(TypeExpansionKind K) : Kind(K) {}
virtual ~TypeExpansion() = default;
virtual ~TypeExpansion() {}
};
struct ConstantArrayExpansion : TypeExpansion {

View File

@ -3058,4 +3058,4 @@ CodeGenFunction::EmitBlockCopyAndAutorelease(llvm::Value *Block, QualType Ty) {
}
CGObjCRuntime::~CGObjCRuntime() = default;
CGObjCRuntime::~CGObjCRuntime() {}

View File

@ -22,7 +22,7 @@
using namespace clang;
using namespace CodeGen;
CGOpenCLRuntime::~CGOpenCLRuntime() = default;
CGOpenCLRuntime::~CGOpenCLRuntime() {}
void CGOpenCLRuntime::EmitWorkGroupLocalVarDecl(CodeGenFunction &CGF,
const VarDecl &D) {

View File

@ -369,7 +369,7 @@ private:
public:
explicit CGOpenMPRuntime(CodeGenModule &CGM);
virtual ~CGOpenMPRuntime() = default;
virtual ~CGOpenMPRuntime() {}
virtual void clear();
/// \brief Emits outlined function for the specified OpenMP parallel directive

View File

@ -1801,7 +1801,7 @@ Address CodeGenFunction::EmitFieldAnnotations(const FieldDecl *D,
return Address(V, Addr.getAlignment());
}
CodeGenFunction::CGCapturedStmtInfo::~CGCapturedStmtInfo() = default;
CodeGenFunction::CGCapturedStmtInfo::~CGCapturedStmtInfo() { }
CodeGenFunction::SanitizerScope::SanitizerScope(CodeGenFunction *CGF)
: CGF(CGF) {

View File

@ -36,7 +36,8 @@ CodeGenTBAA::CodeGenTBAA(ASTContext &Ctx, llvm::LLVMContext& VMContext,
MDHelper(VMContext), Root(nullptr), Char(nullptr) {
}
CodeGenTBAA::~CodeGenTBAA() = default;
CodeGenTBAA::~CodeGenTBAA() {
}
llvm::MDNode *CodeGenTBAA::getRoot() {
// Define the root of the tree. This identifies the tree, so that

View File

@ -66,7 +66,7 @@ Address ABIInfo::EmitMSVAArg(CodeGenFunction &CGF, Address VAListAddr,
return Address::invalid();
}
ABIInfo::~ABIInfo() = default;
ABIInfo::~ABIInfo() {}
static CGCXXABI::RecordArgABI getRecordArgABI(const RecordType *RT,
CGCXXABI &CXXABI) {

View File

@ -19,4 +19,5 @@ Tool::Tool(const char *_Name, const char *_ShortName, const ToolChain &TC,
ResponseSupport(_ResponseSupport), ResponseEncoding(_ResponseEncoding),
ResponseFlag(_ResponseFlag) {}
Tool::~Tool() = default;
Tool::~Tool() {
}

View File

@ -72,7 +72,8 @@ ToolChain::ToolChain(const Driver &D, const llvm::Triple &T,
<< A->getValue() << A->getAsString(Args);
}
ToolChain::~ToolChain() = default;
ToolChain::~ToolChain() {
}
vfs::FileSystem &ToolChain::getVFS() const { return getDriver().getVFS(); }

View File

@ -156,9 +156,9 @@ StringRef MachO::getMachOArchName(const ArgList &Args) const {
}
}
Darwin::~Darwin() = default;
Darwin::~Darwin() {}
MachO::~MachO() = default;
MachO::~MachO() {}
std::string MachO::ComputeEffectiveClangTriple(const ArgList &Args,
types::ID InputType) const {
@ -2102,7 +2102,7 @@ Generic_GCC::Generic_GCC(const Driver &D, const llvm::Triple &Triple,
getProgramPaths().push_back(getDriver().Dir);
}
Generic_GCC::~Generic_GCC() = default;
Generic_GCC::~Generic_GCC() {}
Tool *Generic_GCC::getTool(Action::ActionClass AC) const {
switch (AC) {
@ -2339,7 +2339,7 @@ HexagonToolChain::HexagonToolChain(const Driver &D, const llvm::Triple &Triple,
GetTargetCPU(Args), InstalledDir, LibPaths);
}
HexagonToolChain::~HexagonToolChain() = default;
HexagonToolChain::~HexagonToolChain() {}
Tool *HexagonToolChain::buildAssembler() const {
return new tools::hexagon::Assembler(*this);
@ -2642,7 +2642,7 @@ TCEToolChain::TCEToolChain(const Driver &D, const llvm::Triple &Triple,
getProgramPaths().push_back(Path);
}
TCEToolChain::~TCEToolChain() = default;
TCEToolChain::~TCEToolChain() {}
bool TCEToolChain::IsMathErrnoDefault() const { return true; }
@ -3987,7 +3987,7 @@ MyriadToolChain::MyriadToolChain(const Driver &D, const llvm::Triple &Triple,
}
}
MyriadToolChain::~MyriadToolChain() = default;
MyriadToolChain::~MyriadToolChain() {}
void MyriadToolChain::AddClangSystemIncludeArgs(const ArgList &DriverArgs,
ArgStringList &CC1Args) const {

View File

@ -36,7 +36,7 @@ public:
/// \brief Contains starting character index and length of split.
typedef std::pair<StringRef::size_type, unsigned> Split;
virtual ~BreakableToken() = default;
virtual ~BreakableToken() {}
/// \brief Returns the number of lines in this token in the original code.
virtual unsigned getLineCount() const = 0;

View File

@ -67,7 +67,7 @@ bool FormatToken::isSimpleTypeSpecifier() const {
}
}
TokenRole::~TokenRole() = default;
TokenRole::~TokenRole() {}
void TokenRole::precomputeFormattingInfos(const FormatToken *Token) {}

View File

@ -477,7 +477,7 @@ public:
UnwrappedLineFormatter *BlockFormatter)
: Indenter(Indenter), Whitespaces(Whitespaces), Style(Style),
BlockFormatter(BlockFormatter) {}
virtual ~LineFormatter() = default;
virtual ~LineFormatter() {}
/// \brief Formats an \c AnnotatedLine and returns the penalty.
///

View File

@ -25,7 +25,7 @@ namespace format {
class FormatTokenSource {
public:
virtual ~FormatTokenSource() = default;
virtual ~FormatTokenSource() {}
virtual FormatToken *getNextToken() = 0;
virtual unsigned getPosition() = 0;

View File

@ -51,7 +51,7 @@ struct UnwrappedLine {
class UnwrappedLineConsumer {
public:
virtual ~UnwrappedLineConsumer() = default;
virtual ~UnwrappedLineConsumer() {}
virtual void consumeUnwrappedLine(const UnwrappedLine &Line) = 0;
virtual void finishRun() = 0;
};

View File

@ -2841,7 +2841,7 @@ void ASTUnit::ConcurrencyState::finish() {
#else // NDEBUG
ASTUnit::ConcurrencyState::ConcurrencyState() { Mutex = nullptr; }
ASTUnit::ConcurrencyState::~ConcurrencyState() = default;
ASTUnit::ConcurrencyState::~ConcurrencyState() {}
void ASTUnit::ConcurrencyState::start() {}
void ASTUnit::ConcurrencyState::finish() {}

View File

@ -47,7 +47,7 @@ class PTHEntry {
Offset TokenData, PPCondData;
public:
PTHEntry() = default;
PTHEntry() {}
PTHEntry(Offset td, Offset ppcd)
: TokenData(td), PPCondData(ppcd) {}
@ -547,7 +547,7 @@ class StatListener : public FileSystemStatCache {
PTHMap &PM;
public:
StatListener(PTHMap &pm) : PM(pm) {}
~StatListener() override = default;
~StatListener() override {}
LookupResult getStat(const char *Path, FileData &Data, bool isFile,
std::unique_ptr<vfs::File> *F,

View File

@ -59,7 +59,7 @@ CompilerInvocationBase::CompilerInvocationBase(const CompilerInvocationBase &X)
HeaderSearchOpts(new HeaderSearchOptions(X.getHeaderSearchOpts())),
PreprocessorOpts(new PreprocessorOptions(X.getPreprocessorOpts())) {}
CompilerInvocationBase::~CompilerInvocationBase() = default;
CompilerInvocationBase::~CompilerInvocationBase() {}
//===----------------------------------------------------------------------===//
// Deserialization (from args)

View File

@ -137,7 +137,7 @@ bool DependencyCollector::sawDependency(StringRef Filename, bool FromModule,
(needSystemDependencies() || !IsSystem);
}
DependencyCollector::~DependencyCollector() = default;
DependencyCollector::~DependencyCollector() { }
void DependencyCollector::attachToPreprocessor(Preprocessor &PP) {
PP.addPPCallbacks(
llvm::make_unique<DepCollectorPPCallbacks>(*this, PP.getSourceManager()));

View File

@ -69,7 +69,7 @@ DiagnosticRenderer::DiagnosticRenderer(const LangOptions &LangOpts,
DiagnosticOptions *DiagOpts)
: LangOpts(LangOpts), DiagOpts(DiagOpts), LastLevel() {}
DiagnosticRenderer::~DiagnosticRenderer() = default;
DiagnosticRenderer::~DiagnosticRenderer() {}
namespace {
@ -577,7 +577,7 @@ void DiagnosticRenderer::emitMacroExpansions(SourceLocation Loc,
emitSingleMacroExpansion(*I, Level, Ranges, SM);
}
DiagnosticNoteRenderer::~DiagnosticNoteRenderer() = default;
DiagnosticNoteRenderer::~DiagnosticNoteRenderer() {}
void DiagnosticNoteRenderer::emitIncludeLocation(SourceLocation Loc,
PresumedLoc PLoc,

View File

@ -126,7 +126,7 @@ public:
FrontendAction::FrontendAction() : Instance(nullptr) {}
FrontendAction::~FrontendAction() = default;
FrontendAction::~FrontendAction() {}
void FrontendAction::setCurrentInput(const FrontendInputFile &CurrentInput,
std::unique_ptr<ASTUnit> AST) {

View File

@ -262,7 +262,7 @@ MultiplexConsumer::MultiplexConsumer(
}
}
MultiplexConsumer::~MultiplexConsumer() = default;
MultiplexConsumer::~MultiplexConsumer() {}
void MultiplexConsumer::Initialize(ASTContext &Context) {
for (auto &Consumer : Consumers)

View File

@ -200,4 +200,4 @@ void FixItRewriter::Diag(SourceLocation Loc, unsigned DiagID) {
Diags.setClient(this, false);
}
FixItOptions::~FixItOptions() = default;
FixItOptions::~FixItOptions() {}

View File

@ -38,7 +38,7 @@ HTMLPrintAction::CreateASTConsumer(CompilerInstance &CI, StringRef InFile) {
}
FixItAction::FixItAction() {}
FixItAction::~FixItAction() = default;
FixItAction::~FixItAction() {}
std::unique_ptr<ASTConsumer>
FixItAction::CreateASTConsumer(CompilerInstance &CI, StringRef InFile) {

View File

@ -244,7 +244,7 @@ namespace {
DiagnosticsEngine &D, const LangOptions &LOpts,
bool silenceMacroWarn, bool LineInfo);
~RewriteModernObjC() override = default;
~RewriteModernObjC() override {}
void HandleTranslationUnit(ASTContext &C) override;

View File

@ -193,7 +193,7 @@ namespace {
DiagnosticsEngine &D, const LangOptions &LOpts,
bool silenceMacroWarn);
~RewriteObjC() override = default;
~RewriteObjC() override {}
void HandleTranslationUnit(ASTContext &C) override;
@ -512,7 +512,7 @@ namespace {
D, LOpts,
silenceMacroWarn) {}
~RewriteObjCFragileABI() override = default;
~RewriteObjCFragileABI() override {}
void Initialize(ASTContext &context) override;
// Rewriting metadata

Some files were not shown because too many files have changed in this diff Show More