1
0
Fork 0

remove some containers from common.h (#9223)

* remove some containers from Common.h

* enterprise fixes
This commit is contained in:
Jan Christoph Uhde 2019-06-07 13:27:24 +02:00 committed by Jan
parent b632d58c80
commit 3f603f024f
65 changed files with 147 additions and 62 deletions

View File

@ -34,6 +34,7 @@
#include <velocypack/Iterator.h>
#include <velocypack/Sink.h>
#include <velocypack/velocypack-aliases.h>
#include <set>
#include "Basics/ReadLocker.h"
#include "Basics/StringBuffer.h"

View File

@ -28,6 +28,7 @@
#include "Basics/Common.h"
#include <list>
#include <deque>
#include <boost/uuid/uuid.hpp>
#include <boost/uuid/uuid_generators.hpp>

View File

@ -27,6 +27,7 @@
#include "AgentInterface.h"
#include "Basics/ConditionVariable.h"
#include "Node.h"
#include <map>
namespace arangodb {
namespace consensus {

View File

@ -49,7 +49,7 @@ std::shared_ptr<AqlTransaction> AqlTransaction::create(
#endif
return std::make_shared<AqlTransaction>(transactionContext, collections, options, isMainTransaction);
}
/// @brief add a list of collections to the transaction
Result AqlTransaction::addCollections(std::map<std::string, aql::Collection*> const& collections) {
Result res;

View File

@ -32,6 +32,8 @@
#include "Transaction/StandaloneContext.h"
#include "VocBase/vocbase.h"
#include <map>
namespace arangodb {
namespace aql {
@ -70,7 +72,7 @@ class AqlTransaction : public transaction::Methods {
AqlTransaction(std::shared_ptr<transaction::Context> const& transactionContext,
std::map<std::string, aql::Collection*> const* collections,
transaction::Options const& options, bool isMainTransaction);
/// @brief add a collection to the transaction
Result processCollection(aql::Collection*);

View File

@ -27,6 +27,8 @@
#include "Basics/Common.h"
#include "VocBase/AccessMode.h"
#include <map>
struct TRI_vocbase_t;
namespace arangodb {

View File

@ -29,6 +29,8 @@
#include <velocypack/Builder.h>
#include <velocypack/Slice.h>
#include <unordered_set>
namespace arangodb {
namespace aql {
class ExecutionPlan;

View File

@ -31,6 +31,7 @@
#include "Cluster/ClusterInfo.h"
#include "VocBase/AccessMode.h"
#include <set>
#include <stack>
#include <boost/variant.hpp>

View File

@ -28,6 +28,7 @@
#include <velocypack/Builder.h>
#include <velocypack/Slice.h>
#include <map>
namespace arangodb {
namespace velocypack {
@ -63,7 +64,7 @@ struct ExecutionStats {
/// @brief sets query execution time from the outside
void setExecutionTime(double value) { executionTime = value; }
/// @brief sets the peak memory usage from the outside
void setPeakMemoryUsage(size_t value) { peakMemoryUsage = value; }

View File

@ -29,6 +29,8 @@
#include "Aql/types.h"
#include "Basics/Common.h"
#include <unordered_set>
namespace arangodb {
namespace aql {

View File

@ -29,6 +29,7 @@
#include "Basics/RollingVector.h"
#include <velocypack/Builder.h>
#include <map>
namespace arangodb {
namespace aql {
@ -134,7 +135,7 @@ class Optimizer {
void addPlan(std::unique_ptr<ExecutionPlan>, OptimizerRule const*, bool, int newLevel = 0);
void disableRule(int rule);
bool isDisabled(int rule) const;
/// @brief getPlans, ownership of the plans remains with the optimizer

View File

@ -23,6 +23,8 @@
#ifndef ARANGOD_AQL_OPTIMIZER_RULES_FEATURE_H
#define ARANGOD_AQL_OPTIMIZER_RULES_FEATURE_H 1
#include <map>
#include "ApplicationFeatures/ApplicationFeature.h"
#include "Aql/OptimizerRule.h"

View File

@ -29,6 +29,7 @@
#include "Basics/Mutex.h"
#include "Basics/ReadWriteLock.h"
#include <unordered_set>
#include <memory>
struct TRI_vocbase_t;
@ -64,7 +65,7 @@ struct QueryCacheResultEntry {
QueryCacheResultEntry(uint64_t hash, QueryString const& queryString,
std::shared_ptr<arangodb::velocypack::Builder> const& queryResult,
std::shared_ptr<arangodb::velocypack::Builder> const& bindVars,
std::unordered_map<std::string, std::string>&& dataSources
std::unordered_map<std::string, std::string>&& dataSources
);
~QueryCacheResultEntry() = default;
@ -74,7 +75,7 @@ struct QueryCacheResultEntry {
std::shared_ptr<arangodb::velocypack::Builder> const _queryResult;
std::shared_ptr<arangodb::velocypack::Builder> const _bindVars;
// stores datasource guid -> datasource name
std::unordered_map<std::string, std::string> const _dataSources;
std::unordered_map<std::string, std::string> const _dataSources;
std::shared_ptr<arangodb::velocypack::Builder> _stats;
size_t _size;
size_t _rows;
@ -145,7 +146,7 @@ struct QueryCacheDatabaseEntry {
/// @brief hash table that contains all data souce-specific query results
/// maps from data sources GUIDs to a set of query results as defined in
/// _entriesByHash
std::unordered_map<std::string, std::pair<bool, std::unordered_set<uint64_t>>> _entriesByDataSourceGuid;
std::unordered_map<std::string, std::pair<bool, std::unordered_set<uint64_t>>> _entriesByDataSourceGuid;
/// @brief beginning of linked list of result entries
QueryCacheResultEntry* _head;

View File

@ -32,6 +32,8 @@
#include "Utils/Cursor.h"
#include "VocBase/vocbase.h"
#include <deque>
namespace arangodb {
namespace aql {

View File

@ -24,6 +24,8 @@
#ifndef ARANGOD_AQL_QUERY_OPTIONS_H
#define ARANGOD_AQL_QUERY_OPTIONS_H 1
#include <unordered_set>
#include "Basics/Common.h"
#include "Transaction/Options.h"

View File

@ -24,6 +24,7 @@
#ifndef ARANGOD_AQL_QUERY_RESULT_H
#define ARANGOD_AQL_QUERY_RESULT_H 1
#include <unordered_set>
#include "Basics/Common.h"
#include "Basics/Result.h"
@ -41,21 +42,21 @@ namespace aql {
struct QueryResult {
QueryResult& operator=(QueryResult const& other) = delete;
QueryResult(QueryResult&& other) = default;
QueryResult()
QueryResult()
: result(),
cached(false) {}
explicit QueryResult(Result const& res)
: result(res),
cached(false) {}
explicit QueryResult(Result&& res)
: result(std::move(res)),
cached(false) {}
virtual ~QueryResult() {}
void reset(Result const& res) {
result.reset(res);
cached = false;
@ -63,7 +64,7 @@ struct QueryResult {
extra.reset();
context.reset();
}
void reset(Result&& res) {
result.reset(std::move(res));
cached = false;
@ -71,7 +72,7 @@ struct QueryResult {
extra.reset();
context.reset();
}
// Result-like interface
bool ok() const { return result.ok(); }
bool fail() const { return result.fail(); }
@ -79,7 +80,7 @@ struct QueryResult {
bool is(int errorNumber) const { return result.errorNumber() == errorNumber; }
bool isNot(int errorNumber) const { return !is(errorNumber); }
std::string errorMessage() const { return result.errorMessage(); }
public:
Result result;
bool cached;

View File

@ -28,6 +28,7 @@
#include "Auth/Common.h"
#include <velocypack/Slice.h>
#include <set>
namespace arangodb {
namespace auth {

View File

@ -25,6 +25,8 @@
#ifndef ARANGOD_AUTHENTICATION_USER_H
#define ARANGOD_AUTHENTICATION_USER_H 1
#include <set>
#include "Auth/Common.h"
#include "VocBase/voc-types.h"

View File

@ -27,7 +27,7 @@
#include <boost/variant.hpp>
#include <velocypack/velocypack-common.h>
#include <map>
#include "ClusterInfo.h"
namespace arangodb {

View File

@ -23,6 +23,8 @@
#include "HeartbeatThread.h"
#include <map>
#include <date/date.h>
#include <velocypack/Iterator.h>
#include <velocypack/velocypack-aliases.h>
@ -992,7 +994,7 @@ void HeartbeatThread::runCoordinator() {
}
ClusterInfo::instance()->setFailedServers(failedServers);
transaction::cluster::abortTransactionsWithFailedServers();
std::shared_ptr<pregel::PregelFeature> prgl = pregel::PregelFeature::instance();
if (prgl) {
pregel::RecoveryManager* mngr = prgl->recoveryManager();
@ -1000,8 +1002,8 @@ void HeartbeatThread::runCoordinator() {
mngr->updatedFailedServers(failedServers);
}
}
} else {
LOG_TOPIC("cd95f", WARN, Logger::HEARTBEAT)
<< "FailedServers is not an object. ignoring for now";

View File

@ -21,6 +21,8 @@
/// @author Matthew Von-Maszewski
////////////////////////////////////////////////////////////////////////////////
#include <set>
#include "MaintenanceFeature.h"
#include "ApplicationFeatures/ApplicationServer.h"
@ -431,7 +433,7 @@ std::shared_ptr<Action> MaintenanceFeature::findReadyAction(std::unordered_set<s
// contain any fast track, so we can idle.
break;
}
// When we get here, there is currently nothing to do, so we might
// as well clean up those jobs in the _actionRegistry, which are
// in state DONE:

View File

@ -29,6 +29,7 @@
#include "Graph/ShortestPathFinder.h"
#include <velocypack/StringRef.h>
#include <deque>
namespace arangodb {

View File

@ -26,6 +26,7 @@
#include <velocypack/Buffer.h>
#include <chrono>
#include <utility>
#include <set>
#include "Aql/Query.h"
#include "Aql/VariableGenerator.h"

View File

@ -25,6 +25,7 @@
#define ARANGODB_GRAPH_SHORTEST_PATH_PRIORITY_QUEUE_H 1
#include "Basics/Common.h"
#include <deque>
namespace arangodb {
namespace graph {

View File

@ -27,6 +27,7 @@
#include "Basics/Common.h"
#include "Graph/EdgeDocumentToken.h"
#include <velocypack/StringRef.h>
#include <deque>
namespace arangodb {

View File

@ -25,6 +25,7 @@
#include "Basics/Common.h"
#include <velocypack/StringRef.h>
#include <unordered_set>
namespace arangodb {
class ManagedDocumentResult;

View File

@ -28,6 +28,7 @@
#include "VocBase/voc-types.h"
#include <velocypack/velocypack-aliases.h>
#include <set>
struct TRI_vocbase_t;
@ -91,4 +92,4 @@ class IResearchRocksDBRecoveryHelper final : public RocksDBRecoveryHelper {
} // end namespace iresearch
} // end namespace arangodb
#endif
#endif

View File

@ -24,7 +24,8 @@
#ifndef ARANGOD_MMFILES_FULLTEXT_INDEX_H
#define ARANGOD_MMFILES_FULLTEXT_INDEX_H 1
#include "Basics/Common.h"
#include <set>
#include "Indexes/IndexIterator.h"
#include "MMFiles/MMFilesIndex.h"
#include "MMFiles/mmfiles-fulltext-common.h"
@ -72,7 +73,7 @@ class MMFilesFulltextIndex final : public MMFilesIndex {
void load() override {}
void unload() override;
std::unique_ptr<IndexIterator> iteratorForCondition(transaction::Methods* trx,
std::unique_ptr<IndexIterator> iteratorForCondition(transaction::Methods* trx,
arangodb::aql::AstNode const* node,
arangodb::aql::Variable const* reference,
IndexIteratorOptions const& opts) override final;

View File

@ -21,6 +21,8 @@
/// @author Dr. Frank Celler
////////////////////////////////////////////////////////////////////////////////
#include <set>
#include "MMFilesSkiplistIndex.h"
#include "Aql/AstNode.h"
#include "Aql/SortCondition.h"
@ -1137,7 +1139,7 @@ bool MMFilesSkiplistIndex::findMatchingConditions(
}
std::unique_ptr<IndexIterator> MMFilesSkiplistIndex::iteratorForCondition(
transaction::Methods* trx,
transaction::Methods* trx,
arangodb::aql::AstNode const* node,
arangodb::aql::Variable const* reference, IndexIteratorOptions const& opts) {
TRI_ASSERT(!isSorted() || opts.sorted);

View File

@ -24,6 +24,8 @@
#ifndef ARANGOD_MMFILES_MMFILES_FULLTEXT_INDEX_H
#define ARANGOD_MMFILES_MMFILES_FULLTEXT_INDEX_H 1
#include <set>
#include "VocBase/LocalDocumentId.h"
#include "VocBase/voc-types.h"
#include "mmfiles-fulltext-common.h"

View File

@ -24,6 +24,8 @@
#ifndef ARANGOD_MMFILES_MMFILES_FULLTEXT_LIST_H
#define ARANGOD_MMFILES_MMFILES_FULLTEXT_LIST_H 1
#include <set>
#include "VocBase/voc-types.h"
#include "mmfiles-fulltext-common.h"

View File

@ -27,6 +27,8 @@
#ifndef ARANGODB_PREGEL_COMMON_MFORMATS_H
#define ARANGODB_PREGEL_COMMON_MFORMATS_H 1
#include <map>
#include "Pregel/Graph.h"
#include "Pregel/GraphFormat.h"
#include "Pregel/MessageFormat.h"

View File

@ -27,6 +27,7 @@
#include <atomic>
#include <string>
#include <map>
#include "Basics/Common.h"
#include "Basics/StringHeap.h"

View File

@ -23,6 +23,8 @@
#ifndef ARANGODB_PREGEL_RECOVERY_H
#define ARANGODB_PREGEL_RECOVERY_H 1
#include <map>
#include <velocypack/velocypack-aliases.h>
#include <velocypack/vpack.h>
//#include "Cluster/AgencyCallbackRegistry.h"

View File

@ -23,6 +23,9 @@
#ifndef ARANGODB_PREGEL_WORKER_CONFIG_H
#define ARANGODB_PREGEL_WORKER_CONFIG_H 1
#include <set>
#include <map>
#include <velocypack/velocypack-aliases.h>
#include <algorithm>
#include "Basics/Common.h"
@ -57,7 +60,7 @@ class WorkerConfig {
inline bool asynchronousMode() const { return _asynchronousMode; }
inline bool lazyLoading() const { return _lazyLoading; }
inline bool useMemoryMaps() const { return _useMemoryMaps; }
inline uint64_t parallelism() const { return _parallelism; }
@ -88,7 +91,7 @@ class WorkerConfig {
}
return StaticStrings::Empty;
}
// same content on every worker, has to stay equal!!!!
inline std::vector<ShardID> const& globalShardIDs() const {
return _globalShardIDs;
@ -146,7 +149,7 @@ class WorkerConfig {
std::unordered_map<std::string, std::string> _collectionPlanIdMap;
std::map<ShardID, std::string> _shardToCollectionName;
// Map from edge collection to their shards, only iterated over keep sorted
std::map<CollectionID, std::vector<ShardID>> _vertexCollectionShards, _edgeCollectionShards;

View File

@ -25,6 +25,7 @@
#define ARANGOD_REPLICATION_REPLICATION_APPLIER_CONFIGURATION_H 1
#include "Basics/Common.h"
#include <set>
namespace arangodb {
namespace velocypack {

View File

@ -25,6 +25,7 @@
#ifndef ARANGOD_REPLICATION_UTILITIES_H
#define ARANGOD_REPLICATION_UTILITIES_H 1
#include <map>
#include <mutex>
#include <string>
#include <unordered_map>

View File

@ -28,6 +28,8 @@
#include "VocBase/voc-types.h"
#include <mutex>
#include <map>
#include <set>
#include <rocksdb/types.h>
@ -112,10 +114,10 @@ struct RocksDBCollectionMeta final {
/// @brief deserialize collection metadata, only called on startup
arangodb::Result deserializeMeta(rocksdb::DB*, LogicalCollection&);
public:
// static helper methods to modify collection meta entries in rocksdb
/// @brief load collection document count
static DocCount loadCollectionCount(rocksdb::DB*, uint64_t objectId);

View File

@ -24,7 +24,9 @@
#ifndef ARANGOD_ROCKSDB_ROCKSDB_INDEX_ESTIMATOR_H
#define ARANGOD_ROCKSDB_ROCKSDB_INDEX_ESTIMATOR_H 1
#include "Basics/Common.h"
#include <set>
#include <map>
#include "Basics/Exceptions.h"
#include "Basics/ReadLocker.h"
#include "Basics/ReadWriteLock.h"
@ -521,7 +523,7 @@ class RocksDBCuckooIndexEstimator {
Result res = basics::catchVoidToResult([&]() -> void {
std::vector<Key> inserts;
std::vector<Key> removals;
// truncate will increase this sequence
rocksdb::SequenceNumber ignoreSeq = 0;
while (true) {
@ -529,7 +531,7 @@ class RocksDBCuckooIndexEstimator {
// find out if we have buffers to apply
{
WRITE_LOCKER(locker, _lock);
{
// check for a truncate marker
auto it = _truncateBuffer.begin(); // sorted ASC
@ -542,7 +544,7 @@ class RocksDBCuckooIndexEstimator {
}
}
TRI_ASSERT(ignoreSeq <= commitSeq);
// check for inserts
auto it = _insertBuffers.begin(); // sorted ASC
while (it != _insertBuffers.end() && it->first <= commitSeq) {
@ -555,10 +557,10 @@ class RocksDBCuckooIndexEstimator {
TRI_ASSERT(!inserts.empty());
appliedSeq = std::max(appliedSeq, it->first);
_insertBuffers.erase(it);
break;
}
// check for removals
it = _removalBuffers.begin(); // sorted ASC
while (it != _removalBuffers.end() && it->first <= commitSeq) {
@ -574,22 +576,22 @@ class RocksDBCuckooIndexEstimator {
break;
}
}
if (foundTruncate) {
clear(); // clear estimates
}
// no inserts or removals left to apply, drop out of loop
if (inserts.empty() && removals.empty()) {
break;
}
// apply inserts
for (auto const& key : inserts) {
insert(key);
}
inserts.clear();
// apply removals
for (auto const& key : removals) {
remove(key);

View File

@ -24,8 +24,7 @@
#ifndef ARANGOD_CLUSTER_SHARDING_INFO_H
#define ARANGOD_CLUSTER_SHARDING_INFO_H 1
#include "Basics/Common.h"
#include <unordered_set>
#include <velocypack/Builder.h>
#include <velocypack/Slice.h>

View File

@ -35,6 +35,8 @@
#include "VocBase/AccessMode.h"
#include "VocBase/voc-types.h"
#include <map>
#ifdef ARANGODB_ENABLE_MAINTAINER_MODE
#define LOG_TRX(logid, llevel, trx, tlevel) \
@ -186,7 +188,7 @@ class TransactionState {
/// @brief make a exclusive transaction, only valid before begin
void setExclusiveAccessType();
/// @brief whether or not a transaction is read-only
bool isReadOnlyTransaction() const {
return (_type == AccessMode::Type::READ);
@ -194,7 +196,7 @@ class TransactionState {
/// @brief whether or not a transaction only has exculsive or read accesses
bool isOnlyExclusiveTransaction() const;
/// @brief servers already contacted
arangodb::HashSet<std::string> const& knownServers() const {
return _knownServers;
@ -203,17 +205,17 @@ class TransactionState {
bool knowsServer(std::string const& uuid) const {
return _knownServers.find(uuid) != _knownServers.end();
}
/// @brief add a server to the known set
void addKnownServer(std::string const& uuid) {
_knownServers.emplace(uuid);
}
/// @brief remove a server from the known set
void removeKnownServer(std::string const& uuid) {
_knownServers.erase(uuid);
}
void clearKnownServers() {
_knownServers.clear();
}
@ -233,7 +235,7 @@ class TransactionState {
/// @brief check if current user can access this collection
Result checkCollectionPermission(std::string const& cname, AccessMode::Type) const;
protected:
TRI_vocbase_t& _vocbase; /// @brief vocbase for this transaction
TRI_voc_tid_t const _id; /// @brief local trx id
@ -255,13 +257,13 @@ class TransactionState {
private:
/// a collection of stored cookies
std::map<void const*, Cookie::ptr> _cookies;
/// @brief servers we already talked to for this transactions
arangodb::HashSet<std::string> _knownServers;
/// @brief reference counter of # of 'Methods' instances using this object
std::atomic<int> _nestingLevel;
bool _registeredTransaction;
};

View File

@ -24,6 +24,8 @@
#ifndef ARANGOD_STORAGE_ENGINE_WAL_ACCESS_H
#define ARANGOD_STORAGE_ENGINE_WAL_ACCESS_H 1
#include <map>
#include "Basics/Result.h"
#include "Utils/CollectionGuard.h"
#include "Utils/DatabaseGuard.h"
@ -109,7 +111,7 @@ class WalAccess {
/// In case collection is == 0,
bool includeSystem = false;
/// export _queues and _jobs collection
bool includeFoxxQueues = false;

View File

@ -24,6 +24,7 @@
#ifndef ARANGOD_COLLECTION_EXPORT_H
#define ARANGOD_COLLECTION_EXPORT_H 1
#include <unordered_set>
#include "Basics/Common.h"
namespace arangodb {

View File

@ -29,6 +29,8 @@
#include <velocypack/Slice.h>
#include <velocypack/Value.h>
#include <unordered_set>
/// @brief tick type (56bit)
typedef uint64_t TRI_voc_tick_t;

View File

@ -28,6 +28,8 @@
#include "ApplicationFeatures/ApplicationServer.h"
#include "Basics/Exceptions.h"
#include <unordered_set>
namespace arangodb {
namespace application_features {
@ -220,4 +222,4 @@ class ApplicationFeature {
} // namespace application_features
} // namespace arangodb
#endif
#endif

View File

@ -47,14 +47,10 @@
#include <algorithm>
#include <atomic>
#include <cmath>
#include <deque>
#include <functional>
#include <map>
#include <memory>
#include <set>
#include <string>
#include <unordered_map>
#include <unordered_set>
#include <vector>
#define TRI_WITHIN_COMMON 1

View File

@ -27,6 +27,7 @@
#include "Basics/Common.h"
#include "Basics/Mutex.h"
#include "Basics/MutexLocker.h"
#include <unordered_set>
namespace arangodb {
namespace basics {

View File

@ -25,6 +25,7 @@
#ifndef ARANGODB_BASICS_UTF8HELPER_H
#define ARANGODB_BASICS_UTF8HELPER_H 1
#include <set>
#include "Basics/Common.h"
#include <velocypack/StringRef.h>

View File

@ -29,6 +29,7 @@
#include "Logger/Logger.h"
#include <velocypack/StringRef.h>
#include <set>
#ifdef ARANGODB_ENABLE_MAINTAINER_MODE
#if ARANGODB_ENABLE_BACKTRACE

View File

@ -27,6 +27,7 @@
#include "Basics/Common.h"
#include "Endpoint/Endpoint.h"
#include <map>
namespace arangodb {
class EndpointList {

View File

@ -25,6 +25,7 @@
#include <string>
#include <vector>
#include <set>
#include <s2/s2latlng.h>
#include <s2/s2region_coverer.h>

View File

@ -29,6 +29,8 @@
#include "Basics/Mutex.h"
#include "Logger/LogLevel.h"
#include <map>
namespace arangodb {
class LogTopic;
struct LogMessage;

View File

@ -27,6 +27,7 @@
#include "Basics/Common.h"
#include <iosfwd>
#include <unordered_set>
namespace arangodb {
namespace LogTimeFormats {

View File

@ -25,6 +25,7 @@
#include "Basics/MutexLocker.h"
#include "Logger/Logger.h"
#include <map>
#ifdef USE_ENTERPRISE
#include "Enterprise/Audit/AuditFeature.h"

View File

@ -23,6 +23,8 @@
#ifndef ARANGODB_MASKINGS_MASKINGS_H
#define ARANGODB_MASKINGS_MASKINGS_H 1
#include <map>
#include "Basics/Common.h"
#include <velocypack/Builder.h>

View File

@ -24,6 +24,8 @@
#define ARANGODB_PROGRAM_OPTIONS_INI_FILE_PARSER_H 1
#include <regex>
#include <map>
#include <set>
#include "ProgramOptions/ProgramOptions.h"
@ -37,8 +39,8 @@ class IniFileParser {
// parse a config file. returns true if all is well, false otherwise
// errors that occur during parse are reported to _options
bool parse(std::string const& filename, bool endPassAfterwards);
// parse a config file, with the contents already read into <buf>.
// parse a config file, with the contents already read into <buf>.
// returns true if all is well, false otherwise
// errors that occur during parse are reported to _options
bool parseContent(std::string const& filename, std::string const& buf, bool endPassAfterwards);

View File

@ -35,6 +35,7 @@
#include <limits>
#include <numeric>
#include <type_traits>
#include <unordered_set>
namespace arangodb {
namespace options {
@ -104,7 +105,7 @@ inline T toNumber(std::string value, T base) {
value = value.substr(0, n - 1);
}
}
char const* p = value.data();
char const* e = p + value.size();
// skip leading whitespace

View File

@ -26,6 +26,8 @@
#include "Basics/Common.h"
#include "ProgramOptions/Option.h"
#include <map>
namespace arangodb {
namespace options {

View File

@ -24,6 +24,8 @@
#ifndef ARANGODB_REST_VERSION_H
#define ARANGODB_REST_VERSION_H 1
#include <map>
#include "Basics/Common.h"
#include "Basics/build.h"

View File

@ -30,6 +30,7 @@
#include <openssl/ssl.h>
#include "Basics/asio_ns.h"
#include <unordered_set>
namespace arangodb {
// SSL protocol methods

View File

@ -24,9 +24,11 @@
#ifndef ARANGODB_UTILITIES_SCRIPT_LOADER_H
#define ARANGODB_UTILITIES_SCRIPT_LOADER_H 1
#include <map>
#include "Basics/Common.h"
#include "Basics/Mutex.h"
namespace arangodb {
////////////////////////////////////////////////////////////////////////////////

View File

@ -22,7 +22,8 @@
#include "gtest/gtest.h"
#include "Basics/Common.h"
#include <map>
#include "Basics/StringUtils.h"
#include "Geo/GeoJson.h"
#include "Geo/GeoUtils.h"

View File

@ -24,8 +24,8 @@
#ifndef ARANGODB_IRESEARCH__IRESEARCH_AGENCY_COMM_MANAGER_MOCK_H
#define ARANGODB_IRESEARCH__IRESEARCH_AGENCY_COMM_MANAGER_MOCK_H 1
#include <map>
#include "utils/file_utils.hpp"
#include "Agency/AgencyComm.h"
////////////////////////////////////////////////////////////////////////////////
@ -123,4 +123,4 @@ class GeneralClientConnectionMapMock: public GeneralClientConnectionMock {
virtual void response(arangodb::basics::StringBuffer& buffer) override;
};
#endif
#endif

View File

@ -22,6 +22,7 @@
////////////////////////////////////////////////////////////////////////////////
#include "gtest/gtest.h"
#include <unordered_set>
#include "IResearch/VelocyPackHelper.h"

View File

@ -21,9 +21,11 @@
/// @author Vasiliy Nabatchikov
////////////////////////////////////////////////////////////////////////////////
#ifndef ARANGODB_TESTS_MOCKS_STORAGE_ENGINE_MOCK_H
#ifndef ARANGODB_TESTS_MOCKS_STORAGE_ENGINE_MOCK_H
#define ARANGODB_TESTS_MOCKS_STORAGE_ENGINE_MOCK_H 1
#include <deque>
#include "Basics/Result.h"
#include "Indexes/IndexIterator.h"
#include "StorageEngine/StorageEngine.h"