From 61bb3b8ade824472846847bf52a28bc8931fe9f7 Mon Sep 17 00:00:00 2001 From: alexander kozhikhov Date: Wed, 23 Jan 2019 00:07:05 +0300 Subject: [PATCH 001/709] simple linear regression --- .../AggregateFunctionMLMethod.cpp | 40 ++++ .../AggregateFunctionMLMethod.h | 180 ++++++++++++++++++ .../registerAggregateFunctions.cpp | 2 + dbms/src/Columns/ColumnAggregateFunction.cpp | 30 +++ dbms/src/Columns/ColumnAggregateFunction.h | 3 + dbms/src/Functions/evalMLMethod.cpp | 95 +++++++++ .../registerFunctionsMiscellaneous.cpp | 2 + .../0_stateless/00900_mytest.reference | 1 + .../queries/0_stateless/00900_mytest.sql | 48 +++++ 9 files changed, 401 insertions(+) create mode 100644 dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp create mode 100644 dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h create mode 100644 dbms/src/Functions/evalMLMethod.cpp create mode 100644 dbms/tests/queries/0_stateless/00900_mytest.reference create mode 100644 dbms/tests/queries/0_stateless/00900_mytest.sql diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp new file mode 100644 index 00000000000..43b342fb7ac --- /dev/null +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp @@ -0,0 +1,40 @@ +#include +#include +#include +#include + + +namespace DB +{ + + namespace + { + + using FuncLinearRegression = AggregateFunctionMLMethod; + + template + AggregateFunctionPtr createAggregateFunctionMLMethod( + const std::string & name, const DataTypes & arguments, const Array & parameters) + { + if (parameters.size() > 1) + throw Exception("Aggregate function " + name + " requires at most one parameter", ErrorCodes::NUMBER_OF_ARGUMENTS_DOESNT_MATCH); + + Float64 lr; + if (parameters.empty()) + lr = Float64(0.01); + else + lr = static_cast(parameters[0].template get()); + + if (arguments.size() < 2) + throw Exception("Aggregate function " + name + " requires at least two arguments", ErrorCodes::NUMBER_OF_ARGUMENTS_DOESNT_MATCH); + + return std::make_shared(arguments.size() - 1, lr); + } + + } + + void registerAggregateFunctionMLMethod(AggregateFunctionFactory & factory) { + factory.registerFunction("LinearRegression", createAggregateFunctionMLMethod); + } + +} \ No newline at end of file diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h new file mode 100644 index 00000000000..1e45303b454 --- /dev/null +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h @@ -0,0 +1,180 @@ +#pragma once + +#include + +#include +#include + +#include +#include +#include + +#include + +#include +#include + +#include +#include +#include +#include + + +namespace DB { + +struct LinearRegressionData { + Float64 bias{0.0}; + std::vector w1; + Float64 learning_rate{0.01}; + UInt32 iter_num = 0; + UInt32 param_num = 0; + + + void add(Float64 target, std::vector& feature, Float64 learning_rate_, UInt32 param_num_) { + if (w1.empty()) { + learning_rate = learning_rate_; + param_num = param_num_; + w1.resize(param_num); + } + + Float64 derivative = (target - bias); + for (size_t i = 0; i < param_num; ++i) + { + derivative -= w1[i] * feature[i]; + } + derivative *= (2 * learning_rate); + + bias += derivative; + for (size_t i = 0; i < param_num; ++i) + { + w1[i] += derivative * feature[i]; + } + + ++iter_num; + } + + void merge(const LinearRegressionData & rhs) { + if (iter_num == 0 && rhs.iter_num == 0) + throw std::runtime_error("Strange..."); + + if (param_num == 0) { + param_num = rhs.param_num; + w1.resize(param_num); + } + + Float64 frac = static_cast(iter_num) / (iter_num + rhs.iter_num); + Float64 rhs_frac = static_cast(rhs.iter_num) / (iter_num + rhs.iter_num); + + for (size_t i = 0; i < param_num; ++i) + { + w1[i] = w1[i] * frac + rhs.w1[i] * rhs_frac; + } + + bias = bias * frac + rhs.bias * rhs_frac; + iter_num += rhs.iter_num; + } + + void write(WriteBuffer & buf) const { + writeBinary(bias, buf); + writeBinary(w1, buf); + writeBinary(iter_num, buf); + } + + void read(ReadBuffer & buf) { + readBinary(bias, buf); + readBinary(w1, buf); + readBinary(iter_num, buf); + } + Float64 predict(std::vector& predict_feature) const { + Float64 res{0.0}; + for (size_t i = 0; i < static_cast(param_num); ++i) + { + res += predict_feature[i] * w1[i]; + } + res += bias; + + return res; + } +}; + +template < + /// Implemented Machine Learning method + typename Data, + /// Name of the method + typename Name +> +class AggregateFunctionMLMethod final : public IAggregateFunctionDataHelper> +{ +public: + String getName() const override { return Name::name; } + + explicit AggregateFunctionMLMethod(UInt32 param_num, Float64 learning_rate) + : param_num(param_num), learning_rate(learning_rate) + { + } + + DataTypePtr getReturnType() const override + { + return std::make_shared>(); + } + + void add(AggregateDataPtr place, const IColumn ** columns, size_t row_num, Arena *) const override + { + const auto & target = static_cast &>(*columns[0]); + + std::vector x(param_num); + for (size_t i = 0; i < param_num; ++i) + { + x[i] = static_cast &>(*columns[i + 1]).getData()[row_num]; + } + + this->data(place).add(target.getData()[row_num], x, learning_rate, param_num); + + } + + void merge(AggregateDataPtr place, ConstAggregateDataPtr rhs, Arena *) const override + { + this->data(place).merge(this->data(rhs)); + } + + void serialize(ConstAggregateDataPtr place, WriteBuffer & buf) const override + { + this->data(place).write(buf); + } + + void deserialize(AggregateDataPtr place, ReadBuffer & buf, Arena *) const override + { + this->data(place).read(buf); + } + + void predictResultInto(ConstAggregateDataPtr place, IColumn & to, Block & block, size_t row_num, const ColumnNumbers & arguments) const + { + auto &column = dynamic_cast &>(to); + + std::vector predict_features(arguments.size() - 1); +// for (size_t row_num = 0, rows = block.rows(); row_num < rows; ++row_num) { + for (size_t i = 1; i < arguments.size(); ++i) { +// predict_features[i] = array_elements[i].get(); + predict_features[i - 1] = applyVisitor(FieldVisitorConvertToNumber(), (*block.getByPosition(arguments[i]).column)[row_num]); + } +// column.getData().push_back(this->data(place).predict(predict_features)); + column.getData().push_back(this->data(place).predict(predict_features)); +// } + } + + void insertResultInto(ConstAggregateDataPtr place, IColumn & to) const override { + auto &column = dynamic_cast &>(to); + std::ignore = column; + std::ignore = place; + } + + const char * getHeaderFilePath() const override { return __FILE__; } + +private: + UInt32 param_num; + Float64 learning_rate; +}; + +struct NameLinearRegression { static constexpr auto name = "LinearRegression"; }; + +} \ No newline at end of file diff --git a/dbms/src/AggregateFunctions/registerAggregateFunctions.cpp b/dbms/src/AggregateFunctions/registerAggregateFunctions.cpp index f5e15b6a887..fefcee3301b 100644 --- a/dbms/src/AggregateFunctions/registerAggregateFunctions.cpp +++ b/dbms/src/AggregateFunctions/registerAggregateFunctions.cpp @@ -27,6 +27,7 @@ void registerAggregateFunctionUniqUpTo(AggregateFunctionFactory &); void registerAggregateFunctionTopK(AggregateFunctionFactory &); void registerAggregateFunctionsBitwise(AggregateFunctionFactory &); void registerAggregateFunctionsMaxIntersections(AggregateFunctionFactory &); +void registerAggregateFunctionMLMethod(AggregateFunctionFactory &); void registerAggregateFunctionCombinatorIf(AggregateFunctionCombinatorFactory &); void registerAggregateFunctionCombinatorArray(AggregateFunctionCombinatorFactory &); @@ -65,6 +66,7 @@ void registerAggregateFunctions() registerAggregateFunctionsMaxIntersections(factory); registerAggregateFunctionHistogram(factory); registerAggregateFunctionRetention(factory); + registerAggregateFunctionMLMethod(factory); } { diff --git a/dbms/src/Columns/ColumnAggregateFunction.cpp b/dbms/src/Columns/ColumnAggregateFunction.cpp index 7d3e001998a..a2e03401824 100644 --- a/dbms/src/Columns/ColumnAggregateFunction.cpp +++ b/dbms/src/Columns/ColumnAggregateFunction.cpp @@ -8,6 +8,7 @@ #include #include +#include namespace DB { @@ -80,6 +81,35 @@ MutableColumnPtr ColumnAggregateFunction::convertToValues() const return res; } +//MutableColumnPtr ColumnAggregateFunction::predictValues(std::vector predict_feature) const +MutableColumnPtr ColumnAggregateFunction::predictValues(Block & block, const ColumnNumbers & arguments) const +{ + if (const AggregateFunctionState * function_state = typeid_cast(func.get())) + { + auto res = createView(); + res->set(function_state->getNestedFunction()); + res->data.assign(data.begin(), data.end()); + return res; + } + + MutableColumnPtr res = func->getReturnType()->createColumn(); + res->reserve(data.size()); + +// const AggregateFunctionMLMethod * ML_function = typeid_cast(func.get()); + auto ML_function = typeid_cast *>(func.get()); + if (ML_function) + { + size_t row_num = 0; + for (auto val : data) { + ML_function->predictResultInto(val, *res, block, row_num, arguments); + ++row_num; + } + } else { + + } + + return res; +} void ColumnAggregateFunction::ensureOwnership() { diff --git a/dbms/src/Columns/ColumnAggregateFunction.h b/dbms/src/Columns/ColumnAggregateFunction.h index cd352007095..b4cb611dccb 100644 --- a/dbms/src/Columns/ColumnAggregateFunction.h +++ b/dbms/src/Columns/ColumnAggregateFunction.h @@ -10,6 +10,7 @@ #include #include +#include namespace DB { @@ -115,6 +116,8 @@ public: std::string getName() const override { return "AggregateFunction(" + func->getName() + ")"; } const char * getFamilyName() const override { return "AggregateFunction"; } + MutableColumnPtr predictValues(Block & block, const ColumnNumbers & arguments) const; + size_t size() const override { return getData().size(); diff --git a/dbms/src/Functions/evalMLMethod.cpp b/dbms/src/Functions/evalMLMethod.cpp new file mode 100644 index 00000000000..c31c9227782 --- /dev/null +++ b/dbms/src/Functions/evalMLMethod.cpp @@ -0,0 +1,95 @@ +#include +#include +#include +#include +#include +#include + +#include +#include +#include + +#include +#include + +namespace DB +{ + + namespace ErrorCodes + { + extern const int ILLEGAL_COLUMN; + extern const int ILLEGAL_TYPE_OF_ARGUMENT; + } + + +/** finalizeAggregation(agg_state) - get the result from the aggregation state. +* Takes state of aggregate function. Returns result of aggregation (finalized state). +*/ + class FunctionEvalMLMethod : public IFunction + { + public: + static constexpr auto name = "evalMLMethod"; + static FunctionPtr create(const Context &) + { + return std::make_shared(); + } + + String getName() const override + { + return name; + } + + bool isVariadic() const override { + return true; + } + size_t getNumberOfArguments() const override + { + return 0; + } + + DataTypePtr getReturnTypeImpl(const DataTypes & arguments) const override + { + const DataTypeAggregateFunction * type = checkAndGetDataType(arguments[0].get()); + if (!type) + throw Exception("Argument for function " + getName() + " must have type AggregateFunction - state of aggregate function.", + ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT); + + return type->getReturnType(); + } + + void executeImpl(Block & block, const ColumnNumbers & arguments, size_t result, size_t /*input_rows_count*/) override + { + const ColumnAggregateFunction * column_with_states + = typeid_cast(&*block.getByPosition(arguments.at(0)).column); + if (!column_with_states) + throw Exception("Illegal column " + block.getByPosition(arguments.at(0)).column->getName() + + " of first argument of function " + + getName(), + ErrorCodes::ILLEGAL_COLUMN); + +// const ColumnArray * col_array = checkAndGetColumnConstData(block.getByPosition(arguments[1]).column.get()); +// if (!col_array) +// throw std::runtime_error("wtf"); + +// const IColumn & array_elements = col_array->getData(); + +/* + std::vector predict_features(arguments.size()); + for (size_t i = 1; i < arguments.size(); ++i) + { +// predict_features[i] = array_elements[i].get(); + predict_features[i - 1] = typeid_cast(block.getByPosition(arguments[i]).column.get())->getValue(); + } + block.getByPosition(result).column = column_with_states->predictValues(predict_features); +*/ + block.getByPosition(result).column = column_with_states->predictValues(block, arguments); + } + + }; + + void registerFunctionEvalMLMethod(FunctionFactory & factory) + { + factory.registerFunction(); + } + +} \ No newline at end of file diff --git a/dbms/src/Functions/registerFunctionsMiscellaneous.cpp b/dbms/src/Functions/registerFunctionsMiscellaneous.cpp index d985fb6bf97..718a4b5d459 100644 --- a/dbms/src/Functions/registerFunctionsMiscellaneous.cpp +++ b/dbms/src/Functions/registerFunctionsMiscellaneous.cpp @@ -42,6 +42,7 @@ void registerFunctionLowCardinalityKeys(FunctionFactory &); void registerFunctionsIn(FunctionFactory &); void registerFunctionJoinGet(FunctionFactory &); void registerFunctionFilesystem(FunctionFactory &); +void registerFunctionEvalMLMethod(FunctionFactory &); void registerFunctionsMiscellaneous(FunctionFactory & factory) { @@ -84,6 +85,7 @@ void registerFunctionsMiscellaneous(FunctionFactory & factory) registerFunctionsIn(factory); registerFunctionJoinGet(factory); registerFunctionFilesystem(factory); + registerFunctionEvalMLMethod(factory); } } diff --git a/dbms/tests/queries/0_stateless/00900_mytest.reference b/dbms/tests/queries/0_stateless/00900_mytest.reference new file mode 100644 index 00000000000..8a3290dd346 --- /dev/null +++ b/dbms/tests/queries/0_stateless/00900_mytest.reference @@ -0,0 +1 @@ +66.80107268499746 \ No newline at end of file diff --git a/dbms/tests/queries/0_stateless/00900_mytest.sql b/dbms/tests/queries/0_stateless/00900_mytest.sql new file mode 100644 index 00000000000..b920a4b3b0b --- /dev/null +++ b/dbms/tests/queries/0_stateless/00900_mytest.sql @@ -0,0 +1,48 @@ +CREATE DATABASE IF NOT EXISTS test; +DROP TABLE IF EXISTS test.defaults; +CREATE TABLE IF NOT EXISTS test.defaults +( + param1 Float64, + param2 Float64, + target Float64, + predict1 Float64, + predict2 Float64 +) ENGINE = Memory; +-- -- insert into test.defaults values (2.533, 0.543, 3.181), (1.999, 1.765, 0.470), (0.631, 2.580, -1.845), (-1.164, 0.889, 0.640), (2.110, 0.768, 2.519), (1.251, 0.483, 2.659), (-3.958, 1.299, -1.576), (-2.152, -1.316, 4.556), (3.269, 1.441, 1.753), (4.206, -1.635, 8.373), (-3.479, -0.544, 2.349), (4.006, 0.167, 4.670), (-4.478, 2.400, -4.039), (1.856, 0.256, 3.417), (1.470, 1.685, 0.366), (-4.052, 2.326, -3.678), (-0.971, -0.969, 4.453), (0.881, -1.848, 7.137), (-1.551, -1.766, 5.756), (-0.988, -0.945, 4.395), (-4.636, 1.074, -1.466), (-4.074, -1.486, 3.934), (0.754, 2.627, -1.877), (1.035, 0.889, 1.738), (3.707, -1.281, 7.415), (-2.215, 1.110, -0.327), (-2.965, -1.316, 4.150), (-3.581, 1.063, -0.917), (0.548, 0.343, 2.588), (3.023, -0.870, 6.251), (4.053, -1.441, 7.909), (-0.750, 0.639, 1.348), (-4.411, 1.636, -2.477), (1.786, 0.398, 3.096), (-2.514, 0.033, 1.676), (4.935, -0.840, 7.148), (1.075, -0.921, 5.380), (-3.418, 2.177, -3.063), (3.122, 1.883, 0.795), (-2.254, -1.389, 4.650), (-4.603, 2.909, -5.119), (-1.886, -1.220, 4.497), (-0.509, -1.498, 5.741), (2.192, 1.882, 0.332), (4.056, -1.108, 7.244), (-1.918, 0.230, 1.581), (4.867, 1.516, 2.401), (-0.993, -0.011, 2.526), (-0.757, -1.192, 5.006), (-4.161, 2.059, -3.198), (2.258, 1.157, 1.814), (-3.878, -0.052, 1.165), (1.915, 2.998, -2.038), (-2.164, 2.379, -2.841), (-0.114, -1.914, 6.772), (3.812, 2.138, 0.630), (-1.863, 1.508, -0.947), (-2.964, 0.398, 0.722), (-2.046, -0.193, 2.363), (-1.525, -0.836, 3.910), (-4.557, -0.582, 1.886), (1.031, -0.461, 4.437), (-0.802, 0.699, 1.201), (3.982, 2.084, 0.824), (-2.243, 2.726, -3.573), (-3.989, -0.803, 2.611), (4.900, 0.253, 4.944), (-1.208, -1.587, 5.571), (0.370, 2.579, -1.972), (2.824, 0.964, 2.484), (-1.290, -0.128, 2.611), (0.190, 2.058, -1.021), (4.058, 2.122, 0.784), (4.879, 0.945, 3.549), (1.119, 1.992, -0.424), (4.050, 2.005, 1.015), (-0.064, 1.485, -0.002), (-2.496, 0.456, 0.840), (-1.835, 1.586, -1.090), (0.603, 1.856, -0.411), (-3.062, -0.966, 3.401), (-3.351, 0.430, 0.465), (-2.724, -1.331, 4.299), (3.291, -1.027, 6.699), (-4.263, 0.785, -0.701), (-3.289, -0.886, 3.128), (4.627, 1.331, 2.651), (-0.618, 0.602, 1.486), (0.056, 1.778, -0.528), (4.823, 1.154, 3.103), (-3.983, 0.509, -0.010), (-4.474, -1.400, 3.563), (-3.782, 2.996, -4.883), (4.515, -0.656, 6.569), (1.269, 2.592, -1.549), (-1.710, -0.241, 2.627), (2.171, 1.453, 1.180), (-1.931, -1.845, 5.726), (1.767, -1.798, 7.480), (4.352, 2.369, 0.438), (-4.498, 2.611, -4.472), (0.067, 0.517, 2.000), (4.151, 0.624, 3.827), (0.409, -0.969, 5.142), (0.193, -1.713, 6.522), (-2.487, 2.827, -3.898), (-4.363, 2.011, -3.203), (-2.383, 2.554, -3.299), (-4.457, -0.958, 2.687), (3.342, -0.360, 5.392), (0.902, 2.978, -2.505), (4.073, -1.524, 8.084), (3.036, 1.672, 1.173), (2.169, -0.564, 5.213), (-4.780, 0.962, -1.313), (-1.815, 2.096, -2.100), (-1.445, 0.458, 1.362), (1.891, -1.437, 6.820), (1.942, -1.761, 7.493), (-4.613, -1.551, 3.795), (-3.472, -1.110, 3.485), (-2.026, 1.961, -1.935), (0.091, -0.961, 4.967), (3.902, -1.336, 7.622), (-3.483, -0.769, 2.796), (-0.066, -1.233, 5.433), (2.597, 2.789, -1.280), (-1.657, -1.842, 5.856), (0.232, -1.420, 5.957), (-3.321, 1.609, -1.879), (2.673, 2.781, -1.226), (0.869, 0.072, 3.291), (1.444, -1.271, 6.264), (1.190, 1.460, 0.675), (3.497, 0.870, 3.008), (-2.884, -1.303, 4.163), (3.620, 0.381, 4.047), (2.594, 0.247, 3.803), (-3.902, -1.315, 3.678), (-4.753, -1.005, 2.634), (0.881, 0.675, 2.091), (0.414, 2.071, -0.935), (3.458, -0.920, 6.568), (-2.986, -0.411, 2.329), (3.076, -1.960, 8.458), (2.951, 2.988, -1.501), (2.408, 1.301, 1.603), (4.725, 0.366, 4.631), (4.924, -1.762, 8.985), (3.719, 0.970, 2.920), (-0.295, 0.257, 2.340), (-4.607, 2.548, -4.400), (0.288, 1.953, -0.761), (-3.311, 0.844, -0.344), (3.679, -0.642, 6.123), (-2.310, -0.838, 3.522), (-4.397, -0.226, 1.254), (-4.366, -0.024, 0.864), (2.405, 1.458, 1.286), (-4.296, -1.071, 2.994), (0.452, -1.901, 7.028), (-0.214, -0.467, 3.827), (2.559, 1.547, 1.185), (0.990, 1.539, 0.417), (0.478, -0.089, 3.417), (-2.734, -1.007, 3.646), (3.483, 0.247, 4.247), (3.507, 2.727, -0.701), (-4.399, 2.437, -4.073), (3.785, 0.036, 4.820), (-0.824, 2.417, -2.245), (-2.588, 0.369, 0.968), (-3.037, -1.639, 4.759), (4.531, -0.499, 6.264), (4.742, -1.161, 7.693), (-0.063, -0.595, 4.159), (0.697, 2.281, -1.212), (0.413, 0.607, 1.992), (-4.081, 0.383, 0.194), (0.712, 2.638, -1.920), (-1.620, 1.092, 0.006), (-3.425, -0.911, 3.109), (-0.124, 1.711, -0.484), (4.347, 1.387, 2.399), (-3.237, -0.900, 3.182), (-3.961, 0.358, 0.304), (4.326, -0.068, 5.298), (3.846, 1.725, 1.473), (-2.089, 0.953, 0.049), (-1.025, -1.470, 5.428), (2.061, -0.156, 4.343), (1.547, -1.827, 7.427), (2.786, 0.460, 3.473), (0.076, 0.659, 1.720), (3.597, 1.966, 0.866), (-0.933, -1.180, 4.894), (4.647, 1.190, 2.943), (-0.032, 0.544, 1.896), (4.461, -1.806, 8.843), (-0.586, 1.821, -0.934), (3.725, 1.715, 1.432), (-2.091, 2.714, -3.474), (4.494, -1.494, 8.236), (3.766, -0.209, 5.301), (-1.991, 1.776, -1.548), (-4.992, -0.742, 1.989), (-2.400, 1.828, -1.855), (-1.329, 0.143, 2.050), (1.954, 1.759, 0.459), (-4.422, 1.507, -2.224), (-2.243, -1.126, 4.131), (4.417, -1.080, 7.368), (1.737, -1.144, 6.157), (2.661, -1.084, 6.498), (-3.198, 0.443, 0.515), (4.191, -1.250, 7.596), (-2.419, -0.163, 2.116), (1.910, -1.173, 6.301), (-0.241, 1.902, -0.925), (-4.415, 2.479, -4.165), (3.307, -0.465, 5.583), (-2.382, 1.364, -0.920), (-3.154, 2.953, -4.483), (-2.562, 2.803, -3.888), (3.076, 0.195, 4.149), (-0.101, 0.896, 1.157), (-2.067, 1.120, -0.273), (-4.680, 2.756, -4.851), (-4.283, -0.607, 2.072), (4.013, -1.072, 7.150), (-4.401, -0.896, 2.591), (4.544, 2.498, 0.276), (4.075, -1.204, 7.445), (-3.463, 1.242, -1.216), (3.992, 2.782, -0.568), (-4.503, 0.239, 0.270), (-3.095, 1.161, -0.870), (0.768, -0.904, 5.192), (1.255, 2.870, -2.112), (-1.537, -0.049, 2.330), (2.851, -1.182, 6.789), (1.974, -0.922, 5.832), (4.447, 2.719, -0.214), (-3.413, 0.555, 0.184), (4.943, 2.120, 1.231), (3.645, -0.413, 5.648), (-4.776, 0.079, 0.453), (1.991, 1.565, 0.866), (2.413, 1.793, 0.620), (4.245, 2.663, -0.205), (-2.022, -1.180, 4.350), (-2.285, -1.246, 4.350), (2.276, 0.488, 3.162), (2.582, -0.037, 4.365), (-4.875, 1.468, -2.374), (-2.492, 2.730, -3.706), (2.696, -1.833, 8.013), (4.618, -1.127, 7.563), (-4.156, 0.987, -1.053), (1.873, -1.566, 7.068), (1.699, 0.794, 2.262), (-3.181, 1.640, -1.871), (-3.225, 1.526, -1.664), (-2.679, -1.811, 5.281), (3.717, 1.532, 1.794), (1.288, -0.999, 5.642), (-1.057, 0.044, 2.384), (-0.147, 1.108, 0.711), (-3.827, -1.139, 3.365), (0.872, -1.482, 6.399), (1.982, 0.286, 3.418), (-1.381, 2.374, -2.439), (-1.091, 2.010, -1.565), (-1.192, 2.751, -3.097), (1.468, -0.992, 5.718), (2.249, 0.949, 2.228), (3.064, 0.911, 2.711), (-1.576, -1.584, 5.380), (2.130, -1.489, 7.043), (4.386, -1.284, 7.761), (1.662, -1.645, 7.121), (-3.395, 1.784, -2.265), (4.618, 1.951, 1.406), (-0.299, 0.378, 2.095), (-2.911, 2.131, -2.717), (0.876, 2.869, -2.301), (-1.785, 0.961, 0.186), (-4.188, 2.442, -3.977), (-1.128, 0.127, 2.181), (1.755, -1.215, 6.307), (-2.276, 0.596, 0.669), (-4.630, 1.978, -3.272), (-0.454, 0.275, 2.224), (-1.950, -1.385, 4.794), (-0.889, 2.696, -2.837), (-4.832, -0.038, 0.661), (3.738, 0.604, 3.662), (-0.224, -0.465, 3.819); +insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0), (-1.099, 2.755, -3.060, 20.0, 40.0), (1.090, 2.945, -2.346, 20.0, 40.0), (0.305, 2.179, -1.205, 20.0, 40.0), (-0.925, 0.702, 1.134, 20.0, 40.0), (3.178, -1.316, 7.221, 20.0, 40.0), (-2.756, -0.473, 2.569, 20.0, 40.0), (3.665, 2.303, 0.226, 20.0, 40.0), (1.662, 1.951, -0.070, 20.0, 40.0), (2.869, 0.593, 3.249, 20.0, 40.0), (0.818, -0.593, 4.594, 20.0, 40.0), (-1.917, 0.916, 0.209, 20.0, 40.0), (2.706, 1.523, 1.307, 20.0, 40.0), (0.219, 2.162, -1.214, 20.0, 40.0), (-4.510, 1.376, -2.007, 20.0, 40.0), (4.284, -0.515, 6.173, 20.0, 40.0), (-1.101, 2.810, -3.170, 20.0, 40.0), (-1.810, -1.117, 4.329, 20.0, 40.0), (0.055, 1.115, 0.797, 20.0, 40.0), (-2.178, 2.904, -3.898, 20.0, 40.0), (-3.494, -1.814, 4.882, 20.0, 40.0), (3.027, 0.476, 3.562, 20.0, 40.0), (-1.434, 1.151, -0.018, 20.0, 40.0), (1.180, 0.992, 1.606, 20.0, 40.0), (0.015, 0.971, 1.067, 20.0, 40.0), (-0.511, -0.875, 4.495, 20.0, 40.0), (0.961, 2.348, -1.216, 20.0, 40.0), (-2.279, 0.038, 1.785, 20.0, 40.0), (-1.568, -0.248, 2.712, 20.0, 40.0), (-0.496, 0.366, 2.020, 20.0, 40.0), (1.177, -1.401, 6.390, 20.0, 40.0), (2.882, -1.442, 7.325, 20.0, 40.0), (-1.066, 1.817, -1.167, 20.0, 40.0), (-2.144, 2.791, -3.655, 20.0, 40.0), (-4.370, 2.228, -3.642, 20.0, 40.0), (3.996, 2.775, -0.553, 20.0, 40.0), (0.289, 2.055, -0.965, 20.0, 40.0), (-0.588, -1.601, 5.908, 20.0, 40.0), (-1.801, 0.417, 1.265, 20.0, 40.0), (4.375, -1.499, 8.186, 20.0, 40.0), (-2.618, 0.038, 1.615, 20.0, 40.0), (3.616, -0.833, 6.475, 20.0, 40.0), (-4.045, -1.558, 4.094, 20.0, 40.0), (-3.962, 0.636, -0.253, 20.0, 40.0), (3.505, 2.625, -0.497, 20.0, 40.0), (3.029, -0.523, 5.560, 20.0, 40.0), (-3.520, -0.474, 2.188, 20.0, 40.0), (2.430, -1.469, 7.154, 20.0, 40.0), (1.547, -1.654, 7.082, 20.0, 40.0), (-1.370, 0.575, 1.165, 20.0, 40.0), (-1.869, -1.555, 5.176, 20.0, 40.0), (3.536, 2.841, -0.913, 20.0, 40.0), (-3.810, 1.220, -1.344, 20.0, 40.0), (-1.971, 1.462, -0.910, 20.0, 40.0), (-0.243, 0.167, 2.545, 20.0, 40.0), (-1.403, 2.645, -2.991, 20.0, 40.0), (0.532, -0.114, 3.494, 20.0, 40.0), (-1.678, 0.975, 0.212, 20.0, 40.0), (-0.656, 2.140, -1.609, 20.0, 40.0), (1.743, 2.631, -1.390, 20.0, 40.0), (2.586, 2.943, -1.593, 20.0, 40.0), (-0.512, 2.969, -3.195, 20.0, 40.0), (2.283, -0.100, 4.342, 20.0, 40.0), (-4.293, 0.872, -0.890, 20.0, 40.0), (3.411, 1.300, 2.106, 20.0, 40.0), (-0.281, 2.951, -3.042, 20.0, 40.0), (-4.442, 0.384, 0.012, 20.0, 40.0), (1.194, 1.746, 0.104, 20.0, 40.0), (-1.152, 1.862, -1.300, 20.0, 40.0), (1.362, -1.341, 6.363, 20.0, 40.0), (-4.488, 2.618, -4.481, 20.0, 40.0), (3.419, -0.564, 5.837, 20.0, 40.0), (-3.392, 0.396, 0.512, 20.0, 40.0), (-1.629, -0.909, 4.003, 20.0, 40.0), (4.447, -1.088, 7.399, 20.0, 40.0), (-1.232, 1.699, -1.014, 20.0, 40.0), (-1.286, -0.609, 3.575, 20.0, 40.0), (2.437, 2.796, -1.374, 20.0, 40.0), (-4.864, 1.989, -3.410, 20.0, 40.0), (-1.716, -1.399, 4.940, 20.0, 40.0), (-3.084, 1.858, -2.259, 20.0, 40.0), (2.828, -0.319, 5.053, 20.0, 40.0), (-1.226, 2.586, -2.786, 20.0, 40.0), (2.456, 0.092, 4.044, 20.0, 40.0), (-0.989, 2.375, -2.245, 20.0, 40.0), (3.268, 0.935, 2.765, 20.0, 40.0), (-4.128, -1.995, 4.927, 20.0, 40.0), (-1.083, 2.197, -1.935, 20.0, 40.0), (-3.471, -1.198, 3.660, 20.0, 40.0), (4.617, -1.136, 7.579, 20.0, 40.0), (2.054, -1.675, 7.378, 20.0, 40.0), (4.106, 2.326, 0.402, 20.0, 40.0), (1.558, 0.310, 3.158, 20.0, 40.0), (0.792, 0.900, 1.596, 20.0, 40.0), (-3.229, 0.300, 0.785, 20.0, 40.0), (3.787, -0.793, 6.479, 20.0, 40.0), (1.786, 2.288, -0.684, 20.0, 40.0), (2.643, 0.223, 3.875, 20.0, 40.0), (-3.592, 2.122, -3.040, 20.0, 40.0), (4.519, -1.760, 8.779, 20.0, 40.0), (3.221, 2.255, 0.101, 20.0, 40.0), (4.151, 1.788, 1.500, 20.0, 40.0), (-1.033, -1.195, 4.874, 20.0, 40.0), (-1.636, -1.037, 4.257, 20.0, 40.0), (-3.548, 1.911, -2.596, 20.0, 40.0), (4.829, -0.293, 6.001, 20.0, 40.0), (-4.684, -1.664, 3.986, 20.0, 40.0), (4.531, -0.503, 6.271, 20.0, 40.0), (-3.503, -1.606, 4.460, 20.0, 40.0), (-2.036, -1.522, 5.027, 20.0, 40.0), (-0.473, -0.617, 3.997, 20.0, 40.0), (-1.554, -1.630, 5.483, 20.0, 40.0), (-3.567, -1.043, 3.302, 20.0, 40.0), (-2.038, 0.579, 0.823, 20.0, 40.0), (-3.040, 0.857, -0.233, 20.0, 40.0), (4.610, 0.562, 4.181, 20.0, 40.0), (-3.323, -1.938, 5.215, 20.0, 40.0), (4.314, 1.720, 1.717, 20.0, 40.0), (-1.220, 0.615, 1.161, 20.0, 40.0), (-2.556, 1.120, -0.519, 20.0, 40.0), (-3.717, -0.108, 1.358, 20.0, 40.0), (4.689, -1.826, 8.996, 20.0, 40.0), (3.452, 0.506, 3.713, 20.0, 40.0), (2.472, 0.612, 3.012, 20.0, 40.0), (3.452, 0.450, 3.826, 20.0, 40.0), (1.207, 2.585, -1.567, 20.0, 40.0), (-4.826, 1.090, -1.593, 20.0, 40.0), (3.116, -1.118, 6.794, 20.0, 40.0), (0.448, 2.732, -2.240, 20.0, 40.0), (-1.096, -0.525, 3.503, 20.0, 40.0), (-4.680, -0.238, 1.137, 20.0, 40.0), (2.552, -1.403, 7.082, 20.0, 40.0), (0.719, 2.997, -2.635, 20.0, 40.0), (0.347, -1.966, 7.105, 20.0, 40.0), (2.958, -0.404, 5.288, 20.0, 40.0), (0.722, -1.950, 7.261, 20.0, 40.0), (-2.851, -0.986, 3.546, 20.0, 40.0), (-4.316, -0.439, 1.721, 20.0, 40.0), (-1.685, -0.201, 2.560, 20.0, 40.0), (1.856, 0.190, 3.549, 20.0, 40.0), (-2.052, 0.206, 1.562, 20.0, 40.0), (-2.504, -0.646, 3.041, 20.0, 40.0), (3.235, 0.882, 2.854, 20.0, 40.0), (-1.366, -1.573, 5.463, 20.0, 40.0), (-3.447, 2.419, -3.562, 20.0, 40.0), (4.155, 2.092, 0.893, 20.0, 40.0), (-0.935, 0.209, 2.116, 20.0, 40.0), (3.117, -1.821, 8.201, 20.0, 40.0), (3.759, 0.577, 3.725, 20.0, 40.0), (-0.938, 2.992, -3.453, 20.0, 40.0), (-0.525, 2.341, -1.945, 20.0, 40.0), (4.540, 2.625, 0.019, 20.0, 40.0), (-2.097, 1.190, -0.429, 20.0, 40.0), (-2.672, 1.983, -2.302, 20.0, 40.0), (-3.038, -1.490, 4.460, 20.0, 40.0), (-0.943, 2.149, -1.770, 20.0, 40.0), (0.739, 1.598, 0.174, 20.0, 40.0), (1.828, 1.853, 0.208, 20.0, 40.0), (4.856, 0.137, 5.153, 20.0, 40.0), (-1.617, 0.468, 1.255, 20.0, 40.0), (-1.972, 2.053, -2.092, 20.0, 40.0), (-4.633, 1.389, -2.094, 20.0, 40.0), (-3.628, -1.156, 3.498, 20.0, 40.0), (3.597, 1.034, 2.731, 20.0, 40.0), (-1.488, -0.002, 2.261, 20.0, 40.0), (0.749, 1.921, -0.468, 20.0, 40.0), (1.304, -1.371, 6.394, 20.0, 40.0), (4.587, 2.936, -0.579, 20.0, 40.0), (-2.241, 1.791, -1.703, 20.0, 40.0), (-2.945, 1.372, -1.216, 20.0, 40.0), (1.375, 0.395, 2.898, 20.0, 40.0), (-1.281, -0.641, 3.642, 20.0, 40.0), (2.178, 0.895, 2.299, 20.0, 40.0), (3.031, -0.786, 6.087, 20.0, 40.0), (-1.385, -0.375, 3.058, 20.0, 40.0), (4.041, -0.431, 5.882, 20.0, 40.0), (0.480, -0.507, 4.254, 20.0, 40.0), (-3.797, 0.140, 0.822, 20.0, 40.0), (2.355, 2.502, -0.827, 20.0, 40.0), (1.376, -1.583, 6.854, 20.0, 40.0), (0.164, 1.405, 0.273, 20.0, 40.0), (-1.273, 1.471, -0.579, 20.0, 40.0), (0.770, 2.246, -1.107, 20.0, 40.0), (4.552, 2.904, -0.533, 20.0, 40.0), (4.259, -1.772, 8.674, 20.0, 40.0), (-0.309, 1.159, 0.528, 20.0, 40.0), (3.581, 2.700, -0.610, 20.0, 40.0), (-3.202, 0.346, 0.707, 20.0, 40.0), (-1.575, 1.242, -0.271, 20.0, 40.0), (-1.584, -0.493, 3.194, 20.0, 40.0), (-3.778, 0.150, 0.810, 20.0, 40.0), (-4.675, 1.749, -2.835, 20.0, 40.0), (3.567, -0.792, 6.367, 20.0, 40.0), (-0.417, 1.399, -0.006, 20.0, 40.0), (-4.672, 2.007, -3.349, 20.0, 40.0), (-1.034, 0.196, 2.090, 20.0, 40.0), (-3.796, 2.496, -3.890, 20.0, 40.0), (3.532, -0.497, 5.759, 20.0, 40.0), (4.868, -1.359, 8.151, 20.0, 40.0), (-0.769, 0.302, 2.011, 20.0, 40.0), (4.475, 2.612, 0.014, 20.0, 40.0), (-3.532, -0.395, 2.024, 20.0, 40.0), (0.322, 0.675, 1.812, 20.0, 40.0), (-2.028, -1.942, 5.870, 20.0, 40.0), (1.810, -1.244, 6.392, 20.0, 40.0), (-0.783, 1.242, 0.124, 20.0, 40.0), (-4.745, -1.300, 3.227, 20.0, 40.0), (1.902, 1.973, 0.005, 20.0, 40.0), (-3.453, -1.429, 4.132, 20.0, 40.0), (1.559, 0.986, 1.808, 20.0, 40.0), (0.128, 2.754, -2.443, 20.0, 40.0), (2.759, 1.727, 0.926, 20.0, 40.0), (-4.468, 1.690, -2.614, 20.0, 40.0), (-2.368, -1.922, 5.659, 20.0, 40.0), (-2.766, 2.128, -2.640, 20.0, 40.0), (0.967, -1.825, 7.133, 20.0, 40.0), (-2.854, 2.855, -4.136, 20.0, 40.0), (-2.944, 1.875, -2.222, 20.0, 40.0), (-2.632, -0.983, 3.649, 20.0, 40.0), (2.427, 2.239, -0.266, 20.0, 40.0), (-1.726, -0.838, 3.812, 20.0, 40.0), (0.007, -0.903, 4.809, 20.0, 40.0), (-2.013, 1.092, -0.191, 20.0, 40.0), (-0.449, 0.970, 0.836, 20.0, 40.0), (1.396, 0.411, 2.876, 20.0, 40.0), (-1.115, -1.790, 6.023, 20.0, 40.0), (3.748, 1.917, 1.039, 20.0, 40.0), (2.978, 1.043, 2.404, 20.0, 40.0), (-3.969, 2.514, -4.013, 20.0, 40.0), (4.455, -0.050, 5.328, 20.0, 40.0), (-3.065, -0.846, 3.160, 20.0, 40.0), (-1.069, 2.167, -1.869, 20.0, 40.0), (3.016, -1.393, 7.294, 20.0, 40.0), (0.045, -1.928, 6.879, 20.0, 40.0), (-2.555, -0.984, 3.690, 20.0, 40.0), (-1.995, -0.054, 2.111, 20.0, 40.0), (4.600, -0.509, 6.318, 20.0, 40.0), (-1.942, 1.215, -0.402, 20.0, 40.0), (1.262, 2.765, -1.899, 20.0, 40.0), (2.617, -1.106, 6.521, 20.0, 40.0), (1.737, 0.554, 2.761, 20.0, 40.0), (-2.197, 0.632, 0.638, 20.0, 40.0), (4.768, 2.618, 0.147, 20.0, 40.0), (-3.737, -0.939, 3.010, 20.0, 40.0), (-2.623, 0.595, 0.499, 20.0, 40.0), (4.752, -0.340, 6.057, 20.0, 40.0), (2.333, -1.037, 6.240, 20.0, 40.0), (4.234, -1.882, 8.881, 20.0, 40.0), (-3.393, -0.812, 2.927, 20.0, 40.0), (0.885, 1.383, 0.678, 20.0, 40.0), (0.123, 2.937, -2.812, 20.0, 40.0), (2.969, 0.760, 2.964, 20.0, 40.0), (-4.929, 1.251, -1.967, 20.0, 40.0), (1.916, 2.223, -0.488, 20.0, 40.0), (-0.020, -1.740, 6.469, 20.0, 40.0), (0.702, -1.272, 5.895, 20.0, 40.0), (2.496, 2.648, -1.048, 20.0, 40.0), (4.067, -1.475, 7.984, 20.0, 40.0), (-3.717, 1.851, -2.561, 20.0, 40.0), (1.678, -0.624, 5.088, 20.0, 40.0), (1.073, 0.695, 2.146, 20.0, 40.0), (1.842, -0.749, 5.419, 20.0, 40.0), (-3.518, 1.909, -2.578, 20.0, 40.0), (2.229, 1.189, 1.737, 20.0, 40.0), (4.987, 2.893, -0.292, 20.0, 40.0), (-4.809, 1.043, -1.490, 20.0, 40.0), (-0.241, -0.728, 4.334, 20.0, 40.0), (-3.331, 0.590, 0.156, 20.0, 40.0), (-0.455, 2.621, -2.470, 20.0, 40.0), (1.492, 1.223, 1.301, 20.0, 40.0), (3.948, 2.841, -0.709, 20.0, 40.0), (0.732, 0.446, 2.475, 20.0, 40.0), (2.400, 2.390, -0.579, 20.0, 40.0), (-2.718, 1.427, -1.213, 20.0, 40.0), (-1.826, 1.451, -0.815, 20.0, 40.0), (1.125, 0.438, 2.686, 20.0, 40.0), (-4.918, 1.880, -3.219, 20.0, 40.0), (3.068, -0.442, 5.418, 20.0, 40.0), (1.982, 1.201, 1.589, 20.0, 40.0), (0.701, -1.709, 6.768, 20.0, 40.0), (-1.496, 2.564, -2.877, 20.0, 40.0), (-3.812, 0.974, -0.853, 20.0, 40.0), (-3.405, 2.018, -2.739, 20.0, 40.0), (2.211, 2.889, -1.674, 20.0, 40.0), (-2.481, 2.931, -4.103, 20.0, 40.0), (-3.721, 2.765, -4.391, 20.0, 40.0), (-1.768, -1.292, 4.699, 20.0, 40.0), (-4.462, 1.058, -1.347, 20.0, 40.0), (-3.516, -1.942, 5.126, 20.0, 40.0), (0.485, 2.420, -1.597, 20.0, 40.0), (-0.492, 0.242, 2.270, 20.0, 40.0), (4.245, 1.689, 1.744, 20.0, 40.0), (2.234, 0.364, 3.389, 20.0, 40.0), (2.629, 2.224, -0.134, 20.0, 40.0), (-4.375, 1.221, -1.630, 20.0, 40.0), (-0.618, 1.374, -0.057, 20.0, 40.0), (-2.580, -1.604, 4.918, 20.0, 40.0), (0.159, 1.104, 0.871, 20.0, 40.0), (-3.597, 0.975, -0.749, 20.0, 40.0); +-- insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0), (-1.099, 2.755, -3.060, 20.0, 40.0), (1.090, 2.945, -2.346, 20.0, 40.0), (0.305, 2.179, -1.205, 20.0, 40.0), (-0.925, 0.702, 1.134, 20.0, 40.0), (3.178, -1.316, 7.221, 20.0, 40.0), (-2.756, -0.473, 2.569, 20.0, 40.0), (3.665, 2.303, 0.226, 20.0, 40.0), (1.662, 1.951, -0.070, 20.0, 40.0), (2.869, 0.593, 3.249, 20.0, 40.0), (0.818, -0.593, 4.594, 20.0, 40.0), (-1.917, 0.916, 0.209, 20.0, 40.0), (2.706, 1.523, 1.307, 20.0, 40.0), (0.219, 2.162, -1.214, 20.0, 40.0), (-4.510, 1.376, -2.007, 20.0, 40.0), (4.284, -0.515, 6.173, 20.0, 40.0), (-1.101, 2.810, -3.170, 20.0, 40.0), (-1.810, -1.117, 4.329, 20.0, 40.0), (0.055, 1.115, 0.797, 20.0, 40.0), (-2.178, 2.904, -3.898, 20.0, 40.0), (-3.494, -1.814, 4.882, 20.0, 40.0), (3.027, 0.476, 3.562, 20.0, 40.0), (-1.434, 1.151, -0.018, 20.0, 40.0), (1.180, 0.992, 1.606, 20.0, 40.0), (0.015, 0.971, 1.067, 20.0, 40.0), (-0.511, -0.875, 4.495, 20.0, 40.0), (0.961, 2.348, -1.216, 20.0, 40.0), (-2.279, 0.038, 1.785, 20.0, 40.0), (-1.568, -0.248, 2.712, 20.0, 40.0), (-0.496, 0.366, 2.020, 20.0, 40.0), (1.177, -1.401, 6.390, 20.0, 40.0), (2.882, -1.442, 7.325, 20.0, 40.0), (-1.066, 1.817, -1.167, 20.0, 40.0), (-2.144, 2.791, -3.655, 20.0, 40.0), (-4.370, 2.228, -3.642, 20.0, 40.0), (3.996, 2.775, -0.553, 20.0, 40.0), (0.289, 2.055, -0.965, 20.0, 40.0), (-0.588, -1.601, 5.908, 20.0, 40.0), (-1.801, 0.417, 1.265, 20.0, 40.0), (4.375, -1.499, 8.186, 20.0, 40.0), (-2.618, 0.038, 1.615, 20.0, 40.0), (3.616, -0.833, 6.475, 20.0, 40.0), (-4.045, -1.558, 4.094, 20.0, 40.0), (-3.962, 0.636, -0.253, 20.0, 40.0), (3.505, 2.625, -0.497, 20.0, 40.0), (3.029, -0.523, 5.560, 20.0, 40.0), (-3.520, -0.474, 2.188, 20.0, 40.0), (2.430, -1.469, 7.154, 20.0, 40.0), (1.547, -1.654, 7.082, 20.0, 40.0), (-1.370, 0.575, 1.165, 20.0, 40.0), (-1.869, -1.555, 5.176, 20.0, 40.0), (3.536, 2.841, -0.913, 20.0, 40.0), (-3.810, 1.220, -1.344, 20.0, 40.0), (-1.971, 1.462, -0.910, 20.0, 40.0), (-0.243, 0.167, 2.545, 20.0, 40.0), (-1.403, 2.645, -2.991, 20.0, 40.0), (0.532, -0.114, 3.494, 20.0, 40.0), (-1.678, 0.975, 0.212, 20.0, 40.0), (-0.656, 2.140, -1.609, 20.0, 40.0), (1.743, 2.631, -1.390, 20.0, 40.0), (2.586, 2.943, -1.593, 20.0, 40.0), (-0.512, 2.969, -3.195, 20.0, 40.0), (2.283, -0.100, 4.342, 20.0, 40.0), (-4.293, 0.872, -0.890, 20.0, 40.0), (3.411, 1.300, 2.106, 20.0, 40.0), (-0.281, 2.951, -3.042, 20.0, 40.0), (-4.442, 0.384, 0.012, 20.0, 40.0), (1.194, 1.746, 0.104, 20.0, 40.0), (-1.152, 1.862, -1.300, 20.0, 40.0), (1.362, -1.341, 6.363, 20.0, 40.0), (-4.488, 2.618, -4.481, 20.0, 40.0), (3.419, -0.564, 5.837, 20.0, 40.0), (-3.392, 0.396, 0.512, 20.0, 40.0), (-1.629, -0.909, 4.003, 20.0, 40.0), (4.447, -1.088, 7.399, 20.0, 40.0), (-1.232, 1.699, -1.014, 20.0, 40.0), (-1.286, -0.609, 3.575, 20.0, 40.0), (2.437, 2.796, -1.374, 20.0, 40.0), (-4.864, 1.989, -3.410, 20.0, 40.0), (-1.716, -1.399, 4.940, 20.0, 40.0), (-3.084, 1.858, -2.259, 20.0, 40.0), (2.828, -0.319, 5.053, 20.0, 40.0), (-1.226, 2.586, -2.786, 20.0, 40.0), (2.456, 0.092, 4.044, 20.0, 40.0), (-0.989, 2.375, -2.245, 20.0, 40.0), (3.268, 0.935, 2.765, 20.0, 40.0), (-4.128, -1.995, 4.927, 20.0, 40.0), (-1.083, 2.197, -1.935, 20.0, 40.0), (-3.471, -1.198, 3.660, 20.0, 40.0), (4.617, -1.136, 7.579, 20.0, 40.0), (2.054, -1.675, 7.378, 20.0, 40.0), (4.106, 2.326, 0.402, 20.0, 40.0), (1.558, 0.310, 3.158, 20.0, 40.0), (0.792, 0.900, 1.596, 20.0, 40.0), (-3.229, 0.300, 0.785, 20.0, 40.0), (3.787, -0.793, 6.479, 20.0, 40.0), (1.786, 2.288, -0.684, 20.0, 40.0), (2.643, 0.223, 3.875, 20.0, 40.0), (-3.592, 2.122, -3.040, 20.0, 40.0), (4.519, -1.760, 8.779, 20.0, 40.0), (3.221, 2.255, 0.101, 20.0, 40.0), (4.151, 1.788, 1.500, 20.0, 40.0), (-1.033, -1.195, 4.874, 20.0, 40.0), (-1.636, -1.037, 4.257, 20.0, 40.0), (-3.548, 1.911, -2.596, 20.0, 40.0), (4.829, -0.293, 6.001, 20.0, 40.0), (-4.684, -1.664, 3.986, 20.0, 40.0), (4.531, -0.503, 6.271, 20.0, 40.0), (-3.503, -1.606, 4.460, 20.0, 40.0), (-2.036, -1.522, 5.027, 20.0, 40.0), (-0.473, -0.617, 3.997, 20.0, 40.0), (-1.554, -1.630, 5.483, 20.0, 40.0), (-3.567, -1.043, 3.302, 20.0, 40.0), (-2.038, 0.579, 0.823, 20.0, 40.0), (-3.040, 0.857, -0.233, 20.0, 40.0), (4.610, 0.562, 4.181, 20.0, 40.0), (-3.323, -1.938, 5.215, 20.0, 40.0), (4.314, 1.720, 1.717, 20.0, 40.0), (-1.220, 0.615, 1.161, 20.0, 40.0), (-2.556, 1.120, -0.519, 20.0, 40.0), (-3.717, -0.108, 1.358, 20.0, 40.0), (4.689, -1.826, 8.996, 20.0, 40.0), (3.452, 0.506, 3.713, 20.0, 40.0), (2.472, 0.612, 3.012, 20.0, 40.0), (3.452, 0.450, 3.826, 20.0, 40.0), (1.207, 2.585, -1.567, 20.0, 40.0), (-4.826, 1.090, -1.593, 20.0, 40.0), (3.116, -1.118, 6.794, 20.0, 40.0), (0.448, 2.732, -2.240, 20.0, 40.0), (-1.096, -0.525, 3.503, 20.0, 40.0), (-4.680, -0.238, 1.137, 20.0, 40.0), (2.552, -1.403, 7.082, 20.0, 40.0), (0.719, 2.997, -2.635, 20.0, 40.0), (0.347, -1.966, 7.105, 20.0, 40.0), (2.958, -0.404, 5.288, 20.0, 40.0), (0.722, -1.950, 7.261, 20.0, 40.0), (-2.851, -0.986, 3.546, 20.0, 40.0), (-4.316, -0.439, 1.721, 20.0, 40.0), (-1.685, -0.201, 2.560, 20.0, 40.0), (1.856, 0.190, 3.549, 20.0, 40.0), (-2.052, 0.206, 1.562, 20.0, 40.0), (-2.504, -0.646, 3.041, 20.0, 40.0), (3.235, 0.882, 2.854, 20.0, 40.0), (-1.366, -1.573, 5.463, 20.0, 40.0), (-3.447, 2.419, -3.562, 20.0, 40.0), (4.155, 2.092, 0.893, 20.0, 40.0), (-0.935, 0.209, 2.116, 20.0, 40.0), (3.117, -1.821, 8.201, 20.0, 40.0), (3.759, 0.577, 3.725, 20.0, 40.0), (-0.938, 2.992, -3.453, 20.0, 40.0), (-0.525, 2.341, -1.945, 20.0, 40.0), (4.540, 2.625, 0.019, 20.0, 40.0), (-2.097, 1.190, -0.429, 20.0, 40.0), (-2.672, 1.983, -2.302, 20.0, 40.0), (-3.038, -1.490, 4.460, 20.0, 40.0), (-0.943, 2.149, -1.770, 20.0, 40.0), (0.739, 1.598, 0.174, 20.0, 40.0), (1.828, 1.853, 0.208, 20.0, 40.0), (4.856, 0.137, 5.153, 20.0, 40.0), (-1.617, 0.468, 1.255, 20.0, 40.0), (-1.972, 2.053, -2.092, 20.0, 40.0), (-4.633, 1.389, -2.094, 20.0, 40.0), (-3.628, -1.156, 3.498, 20.0, 40.0), (3.597, 1.034, 2.731, 20.0, 40.0), (-1.488, -0.002, 2.261, 20.0, 40.0), (0.749, 1.921, -0.468, 20.0, 40.0), (1.304, -1.371, 6.394, 20.0, 40.0), (4.587, 2.936, -0.579, 20.0, 40.0), (-2.241, 1.791, -1.703, 20.0, 40.0), (-2.945, 1.372, -1.216, 20.0, 40.0), (1.375, 0.395, 2.898, 20.0, 40.0), (-1.281, -0.641, 3.642, 20.0, 40.0), (2.178, 0.895, 2.299, 20.0, 40.0), (3.031, -0.786, 6.087, 20.0, 40.0), (-1.385, -0.375, 3.058, 20.0, 40.0), (4.041, -0.431, 5.882, 20.0, 40.0), (0.480, -0.507, 4.254, 20.0, 40.0), (-3.797, 0.140, 0.822, 20.0, 40.0), (2.355, 2.502, -0.827, 20.0, 40.0), (1.376, -1.583, 6.854, 20.0, 40.0), (0.164, 1.405, 0.273, 20.0, 40.0), (-1.273, 1.471, -0.579, 20.0, 40.0), (0.770, 2.246, -1.107, 20.0, 40.0), (4.552, 2.904, -0.533, 20.0, 40.0), (4.259, -1.772, 8.674, 20.0, 40.0), (-0.309, 1.159, 0.528, 20.0, 40.0), (3.581, 2.700, -0.610, 20.0, 40.0), (-3.202, 0.346, 0.707, 20.0, 40.0), (-1.575, 1.242, -0.271, 20.0, 40.0), (-1.584, -0.493, 3.194, 20.0, 40.0), (-3.778, 0.150, 0.810, 20.0, 40.0), (-4.675, 1.749, -2.835, 20.0, 40.0), (3.567, -0.792, 6.367, 20.0, 40.0), (-0.417, 1.399, -0.006, 20.0, 40.0), (-4.672, 2.007, -3.349, 20.0, 40.0), (-1.034, 0.196, 2.090, 20.0, 40.0), (-3.796, 2.496, -3.890, 20.0, 40.0), (3.532, -0.497, 5.759, 20.0, 40.0), (4.868, -1.359, 8.151, 20.0, 40.0), (-0.769, 0.302, 2.011, 20.0, 40.0), (4.475, 2.612, 0.014, 20.0, 40.0), (-3.532, -0.395, 2.024, 20.0, 40.0), (0.322, 0.675, 1.812, 20.0, 40.0), (-2.028, -1.942, 5.870, 20.0, 40.0), (1.810, -1.244, 6.392, 20.0, 40.0), (-0.783, 1.242, 0.124, 20.0, 40.0), (-4.745, -1.300, 3.227, 20.0, 40.0), (1.902, 1.973, 0.005, 20.0, 40.0), (-3.453, -1.429, 4.132, 20.0, 40.0), (1.559, 0.986, 1.808, 20.0, 40.0), (0.128, 2.754, -2.443, 20.0, 40.0), (2.759, 1.727, 0.926, 20.0, 40.0), (-4.468, 1.690, -2.614, 20.0, 40.0), (-2.368, -1.922, 5.659, 20.0, 40.0), (-2.766, 2.128, -2.640, 20.0, 40.0), (0.967, -1.825, 7.133, 20.0, 40.0), (-2.854, 2.855, -4.136, 20.0, 40.0), (-2.944, 1.875, -2.222, 20.0, 40.0), (-2.632, -0.983, 3.649, 20.0, 40.0), (2.427, 2.239, -0.266, 20.0, 40.0), (-1.726, -0.838, 3.812, 20.0, 40.0), (0.007, -0.903, 4.809, 20.0, 40.0), (-2.013, 1.092, -0.191, 20.0, 40.0), (-0.449, 0.970, 0.836, 20.0, 40.0), (1.396, 0.411, 2.876, 20.0, 40.0), (-1.115, -1.790, 6.023, 20.0, 40.0), (3.748, 1.917, 1.039, 20.0, 40.0), (2.978, 1.043, 2.404, 20.0, 40.0), (-3.969, 2.514, -4.013, 20.0, 40.0), (4.455, -0.050, 5.328, 20.0, 40.0), (-3.065, -0.846, 3.160, 20.0, 40.0), (-1.069, 2.167, -1.869, 20.0, 40.0), (3.016, -1.393, 7.294, 20.0, 40.0), (0.045, -1.928, 6.879, 20.0, 40.0), (-2.555, -0.984, 3.690, 20.0, 40.0), (-1.995, -0.054, 2.111, 20.0, 40.0), (4.600, -0.509, 6.318, 20.0, 40.0), (-1.942, 1.215, -0.402, 20.0, 40.0), (1.262, 2.765, -1.899, 20.0, 40.0), (2.617, -1.106, 6.521, 20.0, 40.0), (1.737, 0.554, 2.761, 20.0, 40.0), (-2.197, 0.632, 0.638, 20.0, 40.0), (4.768, 2.618, 0.147, 20.0, 40.0), (-3.737, -0.939, 3.010, 20.0, 40.0), (-2.623, 0.595, 0.499, 20.0, 40.0), (4.752, -0.340, 6.057, 20.0, 40.0), (2.333, -1.037, 6.240, 20.0, 40.0), (4.234, -1.882, 8.881, 20.0, 40.0), (-3.393, -0.812, 2.927, 20.0, 40.0), (0.885, 1.383, 0.678, 20.0, 40.0), (0.123, 2.937, -2.812, 20.0, 40.0), (2.969, 0.760, 2.964, 20.0, 40.0), (-4.929, 1.251, -1.967, 20.0, 40.0), (1.916, 2.223, -0.488, 20.0, 40.0), (-0.020, -1.740, 6.469, 20.0, 40.0), (0.702, -1.272, 5.895, 20.0, 40.0), (2.496, 2.648, -1.048, 20.0, 40.0), (4.067, -1.475, 7.984, 20.0, 40.0), (-3.717, 1.851, -2.561, 20.0, 40.0), (1.678, -0.624, 5.088, 20.0, 40.0), (1.073, 0.695, 2.146, 20.0, 40.0), (1.842, -0.749, 5.419, 20.0, 40.0), (-3.518, 1.909, -2.578, 20.0, 40.0), (2.229, 1.189, 1.737, 20.0, 40.0), (4.987, 2.893, -0.292, 20.0, 40.0), (-4.809, 1.043, -1.490, 20.0, 40.0), (-0.241, -0.728, 4.334, 20.0, 40.0), (-3.331, 0.590, 0.156, 20.0, 40.0), (-0.455, 2.621, -2.470, 20.0, 40.0), (1.492, 1.223, 1.301, 20.0, 40.0), (3.948, 2.841, -0.709, 20.0, 40.0), (0.732, 0.446, 2.475, 20.0, 40.0), (2.400, 2.390, -0.579, 20.0, 40.0), (-2.718, 1.427, -1.213, 20.0, 40.0), (-1.826, 1.451, -0.815, 20.0, 40.0), (1.125, 0.438, 2.686, 20.0, 40.0), (-4.918, 1.880, -3.219, 20.0, 40.0), (3.068, -0.442, 5.418, 20.0, 40.0), (1.982, 1.201, 1.589, 20.0, 40.0), (0.701, -1.709, 6.768, 20.0, 40.0), (-1.496, 2.564, -2.877, 20.0, 40.0), (-3.812, 0.974, -0.853, 20.0, 40.0), (-3.405, 2.018, -2.739, 20.0, 40.0), (2.211, 2.889, -1.674, 20.0, 40.0), (-2.481, 2.931, -4.103, 20.0, 40.0), (-3.721, 2.765, -4.391, 20.0, 40.0), (-1.768, -1.292, 4.699, 20.0, 40.0), (-4.462, 1.058, -1.347, 20.0, 40.0), (-3.516, -1.942, 5.126, 20.0, 40.0), (0.485, 2.420, -1.597, 20.0, 40.0), (-0.492, 0.242, 2.270, 20.0, 40.0), (4.245, 1.689, 1.744, 20.0, 40.0), (2.234, 0.364, 3.389, 20.0, 40.0), (2.629, 2.224, -0.134, 20.0, 40.0), (-4.375, 1.221, -1.630, 20.0, 40.0), (-0.618, 1.374, -0.057, 20.0, 40.0), (-2.580, -1.604, 4.918, 20.0, 40.0), (0.159, 1.104, 0.871, 20.0, 40.0), (-3.597, 0.975, -0.749, 20.0, 40.0); +-- +DROP TABLE IF EXISTS test.model; +create table test.model engine = Memory as select LinearRegressionState(0.01)(target, param1, param2) as state from test.defaults; +-- -- select toTypeName(state) from test.model; +-- -- +-- -- DROP TABLE IF EXISTS test.tests; +-- -- CREATE TABLE IF NOT EXISTS test.tests +-- -- ( +-- -- predict1 Float64, +-- -- predict2 Float64, +-- -- state1 AggregateFunction(LinReg(0.01), Float64, Float64, Float64) +-- -- ) ENGINE = Memory; +-- -- insert into test.tests select 20.0, 40.0, LinRegState(0.01)(target, param1, param2) from test.defaults; +-- -- select evalLinReg(state1, predict1, predict2) from test.tests; +-- +-- +-- +-- -- DROP TABLE IF EXISTS test.prediction; +-- -- CREATE TABLE IF NOT EXISTS test.prediction +-- -- ( +-- -- predict1 Float64, +-- -- predict2 Float64 +-- -- ) ENGINE = Memory; +-- +-- +-- -- insert into test.prediction values (20.0, 40.0); +-- +-- -- select multiply(param1, param2) from test.defaults; +-- +-- -- select evalLinReg(LinRegState(0.01)(target, param1, param2), 20.0, 40.0) from test.defaults; +select evalMLMethod(state, predict1, predict2) from test.model cross join test.defaults; +-- -- select evalLinReg(state, predict1, predict2) from test.model inner join (select * from test.tests) using state; +-- -- select evalLinReg(state1, predict1, predict2) from test.tests; +-- +-- -- select negate(target) from test.defaults; \ No newline at end of file From 19ca2f3af848956cd2e486bfa94c68b60b8c4464 Mon Sep 17 00:00:00 2001 From: alexander kozhikhov Date: Wed, 23 Jan 2019 01:18:07 +0300 Subject: [PATCH 002/709] linear regression --- dbms/src/Columns/ColumnAggregateFunction.cpp | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/dbms/src/Columns/ColumnAggregateFunction.cpp b/dbms/src/Columns/ColumnAggregateFunction.cpp index a2e03401824..5a0d079efd6 100644 --- a/dbms/src/Columns/ColumnAggregateFunction.cpp +++ b/dbms/src/Columns/ColumnAggregateFunction.cpp @@ -8,7 +8,7 @@ #include #include -#include +#include namespace DB { From fd8f9c4fba2c76fc9365cffca50782a580e3f45a Mon Sep 17 00:00:00 2001 From: alexander kozhikhov Date: Wed, 23 Jan 2019 04:29:53 +0300 Subject: [PATCH 003/709] changes after review --- .../AggregateFunctionMLMethod.cpp | 61 +++++----- .../AggregateFunctionMLMethod.h | 104 ++++++++++-------- .../AggregateFunctions/IAggregateFunction.h | 2 +- dbms/src/Columns/ColumnAggregateFunction.cpp | 61 +++++++--- dbms/src/Columns/ColumnAggregateFunction.h | 1 + dbms/src/Functions/evalMLMethod.cpp | 1 + 6 files changed, 141 insertions(+), 89 deletions(-) diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp index 43b342fb7ac..7503a300a47 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp @@ -7,34 +7,45 @@ namespace DB { - namespace +namespace +{ + +using FuncLinearRegression = AggregateFunctionMLMethod; + +template +AggregateFunctionPtr createAggregateFunctionMLMethod( + const std::string & name, const DataTypes & argument_types, const Array & parameters) +{ + if (parameters.size() > 1) + throw Exception("Aggregate function " + name + " requires at most one parameter", ErrorCodes::NUMBER_OF_ARGUMENTS_DOESNT_MATCH); + + for (size_t i = 0; i < argument_types.size(); ++i) { - - using FuncLinearRegression = AggregateFunctionMLMethod; - - template - AggregateFunctionPtr createAggregateFunctionMLMethod( - const std::string & name, const DataTypes & arguments, const Array & parameters) - { - if (parameters.size() > 1) - throw Exception("Aggregate function " + name + " requires at most one parameter", ErrorCodes::NUMBER_OF_ARGUMENTS_DOESNT_MATCH); - - Float64 lr; - if (parameters.empty()) - lr = Float64(0.01); - else - lr = static_cast(parameters[0].template get()); - - if (arguments.size() < 2) - throw Exception("Aggregate function " + name + " requires at least two arguments", ErrorCodes::NUMBER_OF_ARGUMENTS_DOESNT_MATCH); - - return std::make_shared(arguments.size() - 1, lr); - } - + if (!WhichDataType(argument_types[i]).isFloat64()) + throw Exception("Illegal type " + argument_types[i]->getName() + " of argument " + + std::to_string(i) + "for aggregate function " + name, + ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT); } - void registerAggregateFunctionMLMethod(AggregateFunctionFactory & factory) { - factory.registerFunction("LinearRegression", createAggregateFunctionMLMethod); + Float64 learning_rate; + if (parameters.empty()) + { + learning_rate = Float64(0.01); + } else + { + learning_rate = applyVisitor(FieldVisitorConvertToNumber(), parameters[0]); } + if (argument_types.size() < 2) + throw Exception("Aggregate function " + name + " requires at least two arguments", ErrorCodes::NUMBER_OF_ARGUMENTS_DOESNT_MATCH); + + return std::make_shared(argument_types.size() - 1, learning_rate); +} + +} + +void registerAggregateFunctionMLMethod(AggregateFunctionFactory & factory) { + factory.registerFunction("LinearRegression", createAggregateFunctionMLMethod); +} + } \ No newline at end of file diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h index 1e45303b454..cdb3c88261c 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h @@ -22,74 +22,82 @@ namespace DB { -struct LinearRegressionData { +namespace ErrorCodes +{ + extern const int NUMBER_OF_ARGUMENTS_DOESNT_MATCH; + extern const int BAD_ARGUMENTS; +} + + +struct LinearRegressionData +{ + LinearRegressionData() + {} + LinearRegressionData(Float64 learning_rate_, UInt32 param_num_) + : learning_rate(learning_rate_) { + weights.resize(param_num_); + } + Float64 bias{0.0}; - std::vector w1; - Float64 learning_rate{0.01}; + std::vector weights; + Float64 learning_rate; UInt32 iter_num = 0; - UInt32 param_num = 0; - - - void add(Float64 target, std::vector& feature, Float64 learning_rate_, UInt32 param_num_) { - if (w1.empty()) { - learning_rate = learning_rate_; - param_num = param_num_; - w1.resize(param_num); - } + void add(Float64 target, const IColumn ** columns, size_t row_num) + { Float64 derivative = (target - bias); - for (size_t i = 0; i < param_num; ++i) + for (size_t i = 0; i < weights.size(); ++i) { - derivative -= w1[i] * feature[i]; + derivative -= weights[i] * static_cast &>(*columns[i + 1]).getData()[row_num]; + } derivative *= (2 * learning_rate); bias += derivative; - for (size_t i = 0; i < param_num; ++i) + for (size_t i = 0; i < weights.size(); ++i) { - w1[i] += derivative * feature[i]; + weights[i] += derivative * static_cast &>(*columns[i + 1]).getData()[row_num];; } ++iter_num; } - void merge(const LinearRegressionData & rhs) { + void merge(const LinearRegressionData & rhs) + { if (iter_num == 0 && rhs.iter_num == 0) - throw std::runtime_error("Strange..."); - - if (param_num == 0) { - param_num = rhs.param_num; - w1.resize(param_num); - } + return; Float64 frac = static_cast(iter_num) / (iter_num + rhs.iter_num); Float64 rhs_frac = static_cast(rhs.iter_num) / (iter_num + rhs.iter_num); - for (size_t i = 0; i < param_num; ++i) + for (size_t i = 0; i < weights.size(); ++i) { - w1[i] = w1[i] * frac + rhs.w1[i] * rhs_frac; + weights[i] = weights[i] * frac + rhs.weights[i] * rhs_frac; } bias = bias * frac + rhs.bias * rhs_frac; iter_num += rhs.iter_num; } - void write(WriteBuffer & buf) const { + void write(WriteBuffer & buf) const + { writeBinary(bias, buf); - writeBinary(w1, buf); + writeBinary(weights, buf); writeBinary(iter_num, buf); } - void read(ReadBuffer & buf) { + void read(ReadBuffer & buf) + { readBinary(bias, buf); - readBinary(w1, buf); + readBinary(weights, buf); readBinary(iter_num, buf); } - Float64 predict(std::vector& predict_feature) const { + Float64 predict(const std::vector& predict_feature) const + { Float64 res{0.0}; - for (size_t i = 0; i < static_cast(param_num); ++i) + for (size_t i = 0; i < predict_feature.size(); ++i) { - res += predict_feature[i] * w1[i]; + res += predict_feature[i] * weights[i]; } res += bias; @@ -118,18 +126,16 @@ public: return std::make_shared>(); } + void create(AggregateDataPtr place) const override + { + new (place) Data(learning_rate, param_num); + } + void add(AggregateDataPtr place, const IColumn ** columns, size_t row_num, Arena *) const override { const auto & target = static_cast &>(*columns[0]); - std::vector x(param_num); - for (size_t i = 0; i < param_num; ++i) - { - x[i] = static_cast &>(*columns[i + 1]).getData()[row_num]; - } - - this->data(place).add(target.getData()[row_num], x, learning_rate, param_num); - + this->data(place).add(target.getData()[row_num], columns, row_num); } void merge(AggregateDataPtr place, ConstAggregateDataPtr rhs, Arena *) const override @@ -149,20 +155,26 @@ public: void predictResultInto(ConstAggregateDataPtr place, IColumn & to, Block & block, size_t row_num, const ColumnNumbers & arguments) const { + if (arguments.size() != param_num + 1) + throw Exception("Predict got incorrect number of arguments. Got: " + std::to_string(arguments.size()) + ". Required: " + std::to_string(param_num + 1), + ErrorCodes::NUMBER_OF_ARGUMENTS_DOESNT_MATCH); + auto &column = dynamic_cast &>(to); std::vector predict_features(arguments.size() - 1); -// for (size_t row_num = 0, rows = block.rows(); row_num < rows; ++row_num) { for (size_t i = 1; i < arguments.size(); ++i) { -// predict_features[i] = array_elements[i].get(); - predict_features[i - 1] = applyVisitor(FieldVisitorConvertToNumber(), (*block.getByPosition(arguments[i]).column)[row_num]); + const auto& element = (*block.getByPosition(arguments[i]).column)[row_num]; + if (element.getType() != Field::Types::Float64) + throw Exception("Prediction arguments must be values of type Float", + ErrorCodes::BAD_ARGUMENTS); + + predict_features[i - 1] = element.get(); } -// column.getData().push_back(this->data(place).predict(predict_features)); column.getData().push_back(this->data(place).predict(predict_features)); -// } } - void insertResultInto(ConstAggregateDataPtr place, IColumn & to) const override { + void insertResultInto(ConstAggregateDataPtr place, IColumn & to) const override + { auto &column = dynamic_cast &>(to); std::ignore = column; std::ignore = place; diff --git a/dbms/src/AggregateFunctions/IAggregateFunction.h b/dbms/src/AggregateFunctions/IAggregateFunction.h index 85de0e0c7ff..281c7cf4ee8 100644 --- a/dbms/src/AggregateFunctions/IAggregateFunction.h +++ b/dbms/src/AggregateFunctions/IAggregateFunction.h @@ -137,7 +137,7 @@ protected: static const Data & data(ConstAggregateDataPtr place) { return *reinterpret_cast(place); } public: - void create(AggregateDataPtr place) const override + virtual void create(AggregateDataPtr place) const override { new (place) Data; } diff --git a/dbms/src/Columns/ColumnAggregateFunction.cpp b/dbms/src/Columns/ColumnAggregateFunction.cpp index 5a0d079efd6..8716da8fffa 100644 --- a/dbms/src/Columns/ColumnAggregateFunction.cpp +++ b/dbms/src/Columns/ColumnAggregateFunction.cpp @@ -17,6 +17,7 @@ namespace ErrorCodes { extern const int PARAMETER_OUT_OF_BOUND; extern const int SIZES_OF_COLUMNS_DOESNT_MATCH; + extern const int ILLEGAL_TYPE_OF_ARGUMENT; } @@ -32,6 +33,23 @@ void ColumnAggregateFunction::addArena(ArenaPtr arena_) arenas.push_back(arena_); } +bool ColumnAggregateFunction::convertion(MutableColumnPtr* res_) const +{ + if (const AggregateFunctionState * function_state = typeid_cast(func.get())) + { + auto res = createView(); + res->set(function_state->getNestedFunction()); + res->data.assign(data.begin(), data.end()); + *res_ = std::move(res); + return true; + } + + MutableColumnPtr res = func->getReturnType()->createColumn(); + res->reserve(data.size()); + *res_ = std::move(res); + return false; +} + MutableColumnPtr ColumnAggregateFunction::convertToValues() const { /** If the aggregate function returns an unfinalized/unfinished state, @@ -64,38 +82,46 @@ MutableColumnPtr ColumnAggregateFunction::convertToValues() const * AggregateFunction(quantileTiming(0.5), UInt64) * into UInt16 - already finished result of `quantileTiming`. */ - if (const AggregateFunctionState * function_state = typeid_cast(func.get())) +// if (const AggregateFunctionState * function_state = typeid_cast(func.get())) +// { +// auto res = createView(); +// res->set(function_state->getNestedFunction()); +// res->data.assign(data.begin(), data.end()); +// return res; +// } +// +// MutableColumnPtr res = func->getReturnType()->createColumn(); +// res->reserve(data.size()); + MutableColumnPtr res; + if (convertion(&res)) { - auto res = createView(); - res->set(function_state->getNestedFunction()); - res->data.assign(data.begin(), data.end()); return res; } - MutableColumnPtr res = func->getReturnType()->createColumn(); - res->reserve(data.size()); - for (auto val : data) func->insertResultInto(val, *res); return res; } -//MutableColumnPtr ColumnAggregateFunction::predictValues(std::vector predict_feature) const MutableColumnPtr ColumnAggregateFunction::predictValues(Block & block, const ColumnNumbers & arguments) const { - if (const AggregateFunctionState * function_state = typeid_cast(func.get())) +// if (const AggregateFunctionState * function_state = typeid_cast(func.get())) +// { +// auto res = createView(); +// res->set(function_state->getNestedFunction()); +// res->data.assign(data.begin(), data.end()); +// return res; +// } +// +// MutableColumnPtr res = func->getReturnType()->createColumn(); +// res->reserve(data.size()); + MutableColumnPtr res; + if (convertion(&res)) { - auto res = createView(); - res->set(function_state->getNestedFunction()); - res->data.assign(data.begin(), data.end()); return res; } - MutableColumnPtr res = func->getReturnType()->createColumn(); - res->reserve(data.size()); - -// const AggregateFunctionMLMethod * ML_function = typeid_cast(func.get()); auto ML_function = typeid_cast *>(func.get()); if (ML_function) { @@ -105,7 +131,8 @@ MutableColumnPtr ColumnAggregateFunction::predictValues(Block & block, const Col ++row_num; } } else { - + throw Exception("Illegal aggregate function is passed", + ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT); } return res; diff --git a/dbms/src/Columns/ColumnAggregateFunction.h b/dbms/src/Columns/ColumnAggregateFunction.h index b4cb611dccb..42a147c831e 100644 --- a/dbms/src/Columns/ColumnAggregateFunction.h +++ b/dbms/src/Columns/ColumnAggregateFunction.h @@ -116,6 +116,7 @@ public: std::string getName() const override { return "AggregateFunction(" + func->getName() + ")"; } const char * getFamilyName() const override { return "AggregateFunction"; } + bool convertion(MutableColumnPtr* res_) const; MutableColumnPtr predictValues(Block & block, const ColumnNumbers & arguments) const; size_t size() const override diff --git a/dbms/src/Functions/evalMLMethod.cpp b/dbms/src/Functions/evalMLMethod.cpp index c31c9227782..e299206dbd2 100644 --- a/dbms/src/Functions/evalMLMethod.cpp +++ b/dbms/src/Functions/evalMLMethod.cpp @@ -59,6 +59,7 @@ namespace DB void executeImpl(Block & block, const ColumnNumbers & arguments, size_t result, size_t /*input_rows_count*/) override { + // завести МЛ_аггр_функции как отдельный класс, чтобы тут сразу это проверять, а не делать это внутри predictValues() const ColumnAggregateFunction * column_with_states = typeid_cast(&*block.getByPosition(arguments.at(0)).column); if (!column_with_states) From 03deb677b964cb5bc7bc92fcb5881e92b7ef8e64 Mon Sep 17 00:00:00 2001 From: Maxim Kuznetsov Date: Wed, 23 Jan 2019 14:58:05 +0300 Subject: [PATCH 004/709] Code style --- .../AggregateFunctionMLMethod.h | 38 ++++++++++++------- 1 file changed, 25 insertions(+), 13 deletions(-) diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h index 1e45303b454..252cf6e579c 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h @@ -20,9 +20,11 @@ #include -namespace DB { +namespace DB +{ -struct LinearRegressionData { +struct LinearRegressionData +{ Float64 bias{0.0}; std::vector w1; Float64 learning_rate{0.01}; @@ -30,8 +32,10 @@ struct LinearRegressionData { UInt32 param_num = 0; - void add(Float64 target, std::vector& feature, Float64 learning_rate_, UInt32 param_num_) { - if (w1.empty()) { + void add(Float64 target, std::vector& feature, Float64 learning_rate_, UInt32 param_num_) + { + if (w1.empty()) + { learning_rate = learning_rate_; param_num = param_num_; w1.resize(param_num); @@ -53,11 +57,13 @@ struct LinearRegressionData { ++iter_num; } - void merge(const LinearRegressionData & rhs) { + void merge(const LinearRegressionData & rhs) + { if (iter_num == 0 && rhs.iter_num == 0) throw std::runtime_error("Strange..."); - if (param_num == 0) { + if (param_num == 0) + { param_num = rhs.param_num; w1.resize(param_num); } @@ -74,18 +80,22 @@ struct LinearRegressionData { iter_num += rhs.iter_num; } - void write(WriteBuffer & buf) const { + void write(WriteBuffer & buf) const + { writeBinary(bias, buf); writeBinary(w1, buf); writeBinary(iter_num, buf); } - void read(ReadBuffer & buf) { + void read(ReadBuffer & buf) + { readBinary(bias, buf); readBinary(w1, buf); readBinary(iter_num, buf); } - Float64 predict(std::vector& predict_feature) const { + + Float64 predict(std::vector& predict_feature) const + { Float64 res{0.0}; for (size_t i = 0; i < static_cast(param_num); ++i) { @@ -152,8 +162,9 @@ public: auto &column = dynamic_cast &>(to); std::vector predict_features(arguments.size() - 1); -// for (size_t row_num = 0, rows = block.rows(); row_num < rows; ++row_num) { - for (size_t i = 1; i < arguments.size(); ++i) { +// for (size_t row_num = 0, rows = block.rows(); row_num < rows; ++row_num) + for (size_t i = 1; i < arguments.size(); ++i) + { // predict_features[i] = array_elements[i].get(); predict_features[i - 1] = applyVisitor(FieldVisitorConvertToNumber(), (*block.getByPosition(arguments[i]).column)[row_num]); } @@ -162,7 +173,8 @@ public: // } } - void insertResultInto(ConstAggregateDataPtr place, IColumn & to) const override { + void insertResultInto(ConstAggregateDataPtr place, IColumn & to) const override + { auto &column = dynamic_cast &>(to); std::ignore = column; std::ignore = place; @@ -177,4 +189,4 @@ private: struct NameLinearRegression { static constexpr auto name = "LinearRegression"; }; -} \ No newline at end of file +} From b9972f8e67a0972a7e47cd0ee7fe69c01758bd6e Mon Sep 17 00:00:00 2001 From: Masha Date: Wed, 23 Jan 2019 14:53:50 +0000 Subject: [PATCH 005/709] code style AggregateFunctionMLMethod.cpp --- .../AggregateFunctionMLMethod.cpp | 13 ++++++------- 1 file changed, 6 insertions(+), 7 deletions(-) diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp index 7503a300a47..f1781c92bc9 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp @@ -22,11 +22,10 @@ AggregateFunctionPtr createAggregateFunctionMLMethod( for (size_t i = 0; i < argument_types.size(); ++i) { if (!WhichDataType(argument_types[i]).isFloat64()) - throw Exception("Illegal type " + argument_types[i]->getName() + " of argument " + - std::to_string(i) + "for aggregate function " + name, - ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT); + throw Exception("Illegal type " + argument_types[i]->getName() + " of argument " + + std::to_string(i) + "for aggregate function " + name, + ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT); } - Float64 learning_rate; if (parameters.empty()) { @@ -35,7 +34,6 @@ AggregateFunctionPtr createAggregateFunctionMLMethod( { learning_rate = applyVisitor(FieldVisitorConvertToNumber(), parameters[0]); } - if (argument_types.size() < 2) throw Exception("Aggregate function " + name + " requires at least two arguments", ErrorCodes::NUMBER_OF_ARGUMENTS_DOESNT_MATCH); @@ -44,8 +42,9 @@ AggregateFunctionPtr createAggregateFunctionMLMethod( } -void registerAggregateFunctionMLMethod(AggregateFunctionFactory & factory) { +void registerAggregateFunctionMLMethod(AggregateFunctionFactory & factory) +{ factory.registerFunction("LinearRegression", createAggregateFunctionMLMethod); } -} \ No newline at end of file +} From b229498203c32e478f5df503a746b2b180dc2ffa Mon Sep 17 00:00:00 2001 From: alexander kozhikhov Date: Wed, 23 Jan 2019 21:03:26 +0300 Subject: [PATCH 006/709] mini-batches --- .../AggregateFunctionMLMethod.cpp | 19 +- .../AggregateFunctionMLMethod.h | 68 +++- dbms/src/Columns/ColumnAggregateFunction.cpp | 2 +- .../0_stateless/00900_mytest.reference | 301 +++++++++++++++++- .../queries/0_stateless/00900_mytest.sql | 2 +- 5 files changed, 371 insertions(+), 21 deletions(-) diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp index 7503a300a47..b225757d273 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp @@ -16,8 +16,8 @@ template AggregateFunctionPtr createAggregateFunctionMLMethod( const std::string & name, const DataTypes & argument_types, const Array & parameters) { - if (parameters.size() > 1) - throw Exception("Aggregate function " + name + " requires at most one parameter", ErrorCodes::NUMBER_OF_ARGUMENTS_DOESNT_MATCH); + if (parameters.size() > 2) + throw Exception("Aggregate function " + name + " requires at most two parameters", ErrorCodes::NUMBER_OF_ARGUMENTS_DOESNT_MATCH); for (size_t i = 0; i < argument_types.size(); ++i) { @@ -27,19 +27,22 @@ AggregateFunctionPtr createAggregateFunctionMLMethod( ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT); } - Float64 learning_rate; - if (parameters.empty()) - { - learning_rate = Float64(0.01); - } else + Float64 learning_rate = Float64(0.01); + UInt32 batch_size = 1; + if (!parameters.empty()) { learning_rate = applyVisitor(FieldVisitorConvertToNumber(), parameters[0]); } + if (parameters.size() > 1) + { + batch_size = applyVisitor(FieldVisitorConvertToNumber(), parameters[1]); + + } if (argument_types.size() < 2) throw Exception("Aggregate function " + name + " requires at least two arguments", ErrorCodes::NUMBER_OF_ARGUMENTS_DOESNT_MATCH); - return std::make_shared(argument_types.size() - 1, learning_rate); + return std::make_shared(argument_types.size() - 1, learning_rate, batch_size); } } diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h index cdb3c88261c..bcf27983bc3 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h @@ -33,33 +33,63 @@ struct LinearRegressionData { LinearRegressionData() {} - LinearRegressionData(Float64 learning_rate_, UInt32 param_num_) - : learning_rate(learning_rate_) { - weights.resize(param_num_); + LinearRegressionData(Float64 learning_rate_, UInt32 param_num_, UInt32 batch_size_) + : learning_rate(learning_rate_), batch_size(batch_size_) { + weights.resize(param_num_, Float64{0.0}); + batch_gradient.resize(param_num_ + 1, Float64{0.0}); + cur_batch = 0; } Float64 bias{0.0}; std::vector weights; Float64 learning_rate; UInt32 iter_num = 0; + std::vector batch_gradient; + UInt32 cur_batch; + UInt32 batch_size; - void add(Float64 target, const IColumn ** columns, size_t row_num) + void update_gradient(Float64 target, const IColumn ** columns, size_t row_num) { Float64 derivative = (target - bias); for (size_t i = 0; i < weights.size(); ++i) { derivative -= weights[i] * static_cast &>(*columns[i + 1]).getData()[row_num]; - } derivative *= (2 * learning_rate); - bias += derivative; +// bias += derivative; + batch_gradient[weights.size()] += derivative; for (size_t i = 0; i < weights.size(); ++i) { - weights[i] += derivative * static_cast &>(*columns[i + 1]).getData()[row_num];; + batch_gradient[i] += derivative * static_cast &>(*columns[i + 1]).getData()[row_num];; } + } + + void update_weights() + { + if (!cur_batch) + return; + + for (size_t i = 0; i < weights.size(); ++i) + { + weights[i] += batch_gradient[i] / cur_batch; + } + bias += batch_gradient[weights.size()] / cur_batch; + + batch_gradient.assign(batch_gradient.size(), Float64{0.0}); ++iter_num; + cur_batch = 0; + } + + void add(Float64 target, const IColumn ** columns, size_t row_num) + { + update_gradient(target, columns, row_num); + ++cur_batch; + if (cur_batch == batch_size) + { + update_weights(); + } } void merge(const LinearRegressionData & rhs) @@ -67,6 +97,10 @@ struct LinearRegressionData if (iter_num == 0 && rhs.iter_num == 0) return; + update_weights(); + /// нельзя обновить из-за константости +// rhs.update_weights(); + Float64 frac = static_cast(iter_num) / (iter_num + rhs.iter_num); Float64 rhs_frac = static_cast(rhs.iter_num) / (iter_num + rhs.iter_num); @@ -84,6 +118,8 @@ struct LinearRegressionData writeBinary(bias, buf); writeBinary(weights, buf); writeBinary(iter_num, buf); + writeBinary(batch_gradient, buf); + writeBinary(cur_batch, buf); } void read(ReadBuffer & buf) @@ -91,9 +127,19 @@ struct LinearRegressionData readBinary(bias, buf); readBinary(weights, buf); readBinary(iter_num, buf); + readBinary(batch_gradient, buf); + readBinary(cur_batch, buf); } + Float64 predict(const std::vector& predict_feature) const { + /// не обновляем веса при предикте, т.к. это может замедлить предсказание + /// однако можно например обновлять их при каждом мердже не зависимо от того, сколько элементнов в батче +// if (cur_batch) +// { +// update_weights(); +// } + Float64 res{0.0}; for (size_t i = 0; i < predict_feature.size(); ++i) { @@ -116,8 +162,8 @@ class AggregateFunctionMLMethod final : public IAggregateFunctionDataHelperdata(place).add(target.getData()[row_num], columns, row_num); } + /// хочется не константный rhs void merge(AggregateDataPtr place, ConstAggregateDataPtr rhs, Arena *) const override { this->data(place).merge(this->data(rhs)); @@ -185,6 +232,7 @@ public: private: UInt32 param_num; Float64 learning_rate; + UInt32 batch_size; }; struct NameLinearRegression { static constexpr auto name = "LinearRegression"; }; diff --git a/dbms/src/Columns/ColumnAggregateFunction.cpp b/dbms/src/Columns/ColumnAggregateFunction.cpp index 8716da8fffa..1dca1780974 100644 --- a/dbms/src/Columns/ColumnAggregateFunction.cpp +++ b/dbms/src/Columns/ColumnAggregateFunction.cpp @@ -122,7 +122,7 @@ MutableColumnPtr ColumnAggregateFunction::predictValues(Block & block, const Col return res; } - auto ML_function = typeid_cast *>(func.get()); + auto ML_function = typeid_cast *>(func.get()); if (ML_function) { size_t row_num = 0; diff --git a/dbms/tests/queries/0_stateless/00900_mytest.reference b/dbms/tests/queries/0_stateless/00900_mytest.reference index 8a3290dd346..8a9f3c31da5 100644 --- a/dbms/tests/queries/0_stateless/00900_mytest.reference +++ b/dbms/tests/queries/0_stateless/00900_mytest.reference @@ -1 +1,300 @@ -66.80107268499746 \ No newline at end of file +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 +-66.99407003753556 diff --git a/dbms/tests/queries/0_stateless/00900_mytest.sql b/dbms/tests/queries/0_stateless/00900_mytest.sql index b920a4b3b0b..8fa676b2668 100644 --- a/dbms/tests/queries/0_stateless/00900_mytest.sql +++ b/dbms/tests/queries/0_stateless/00900_mytest.sql @@ -13,7 +13,7 @@ insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0 -- insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0), (-1.099, 2.755, -3.060, 20.0, 40.0), (1.090, 2.945, -2.346, 20.0, 40.0), (0.305, 2.179, -1.205, 20.0, 40.0), (-0.925, 0.702, 1.134, 20.0, 40.0), (3.178, -1.316, 7.221, 20.0, 40.0), (-2.756, -0.473, 2.569, 20.0, 40.0), (3.665, 2.303, 0.226, 20.0, 40.0), (1.662, 1.951, -0.070, 20.0, 40.0), (2.869, 0.593, 3.249, 20.0, 40.0), (0.818, -0.593, 4.594, 20.0, 40.0), (-1.917, 0.916, 0.209, 20.0, 40.0), (2.706, 1.523, 1.307, 20.0, 40.0), (0.219, 2.162, -1.214, 20.0, 40.0), (-4.510, 1.376, -2.007, 20.0, 40.0), (4.284, -0.515, 6.173, 20.0, 40.0), (-1.101, 2.810, -3.170, 20.0, 40.0), (-1.810, -1.117, 4.329, 20.0, 40.0), (0.055, 1.115, 0.797, 20.0, 40.0), (-2.178, 2.904, -3.898, 20.0, 40.0), (-3.494, -1.814, 4.882, 20.0, 40.0), (3.027, 0.476, 3.562, 20.0, 40.0), (-1.434, 1.151, -0.018, 20.0, 40.0), (1.180, 0.992, 1.606, 20.0, 40.0), (0.015, 0.971, 1.067, 20.0, 40.0), (-0.511, -0.875, 4.495, 20.0, 40.0), (0.961, 2.348, -1.216, 20.0, 40.0), (-2.279, 0.038, 1.785, 20.0, 40.0), (-1.568, -0.248, 2.712, 20.0, 40.0), (-0.496, 0.366, 2.020, 20.0, 40.0), (1.177, -1.401, 6.390, 20.0, 40.0), (2.882, -1.442, 7.325, 20.0, 40.0), (-1.066, 1.817, -1.167, 20.0, 40.0), (-2.144, 2.791, -3.655, 20.0, 40.0), (-4.370, 2.228, -3.642, 20.0, 40.0), (3.996, 2.775, -0.553, 20.0, 40.0), (0.289, 2.055, -0.965, 20.0, 40.0), (-0.588, -1.601, 5.908, 20.0, 40.0), (-1.801, 0.417, 1.265, 20.0, 40.0), (4.375, -1.499, 8.186, 20.0, 40.0), (-2.618, 0.038, 1.615, 20.0, 40.0), (3.616, -0.833, 6.475, 20.0, 40.0), (-4.045, -1.558, 4.094, 20.0, 40.0), (-3.962, 0.636, -0.253, 20.0, 40.0), (3.505, 2.625, -0.497, 20.0, 40.0), (3.029, -0.523, 5.560, 20.0, 40.0), (-3.520, -0.474, 2.188, 20.0, 40.0), (2.430, -1.469, 7.154, 20.0, 40.0), (1.547, -1.654, 7.082, 20.0, 40.0), (-1.370, 0.575, 1.165, 20.0, 40.0), (-1.869, -1.555, 5.176, 20.0, 40.0), (3.536, 2.841, -0.913, 20.0, 40.0), (-3.810, 1.220, -1.344, 20.0, 40.0), (-1.971, 1.462, -0.910, 20.0, 40.0), (-0.243, 0.167, 2.545, 20.0, 40.0), (-1.403, 2.645, -2.991, 20.0, 40.0), (0.532, -0.114, 3.494, 20.0, 40.0), (-1.678, 0.975, 0.212, 20.0, 40.0), (-0.656, 2.140, -1.609, 20.0, 40.0), (1.743, 2.631, -1.390, 20.0, 40.0), (2.586, 2.943, -1.593, 20.0, 40.0), (-0.512, 2.969, -3.195, 20.0, 40.0), (2.283, -0.100, 4.342, 20.0, 40.0), (-4.293, 0.872, -0.890, 20.0, 40.0), (3.411, 1.300, 2.106, 20.0, 40.0), (-0.281, 2.951, -3.042, 20.0, 40.0), (-4.442, 0.384, 0.012, 20.0, 40.0), (1.194, 1.746, 0.104, 20.0, 40.0), (-1.152, 1.862, -1.300, 20.0, 40.0), (1.362, -1.341, 6.363, 20.0, 40.0), (-4.488, 2.618, -4.481, 20.0, 40.0), (3.419, -0.564, 5.837, 20.0, 40.0), (-3.392, 0.396, 0.512, 20.0, 40.0), (-1.629, -0.909, 4.003, 20.0, 40.0), (4.447, -1.088, 7.399, 20.0, 40.0), (-1.232, 1.699, -1.014, 20.0, 40.0), (-1.286, -0.609, 3.575, 20.0, 40.0), (2.437, 2.796, -1.374, 20.0, 40.0), (-4.864, 1.989, -3.410, 20.0, 40.0), (-1.716, -1.399, 4.940, 20.0, 40.0), (-3.084, 1.858, -2.259, 20.0, 40.0), (2.828, -0.319, 5.053, 20.0, 40.0), (-1.226, 2.586, -2.786, 20.0, 40.0), (2.456, 0.092, 4.044, 20.0, 40.0), (-0.989, 2.375, -2.245, 20.0, 40.0), (3.268, 0.935, 2.765, 20.0, 40.0), (-4.128, -1.995, 4.927, 20.0, 40.0), (-1.083, 2.197, -1.935, 20.0, 40.0), (-3.471, -1.198, 3.660, 20.0, 40.0), (4.617, -1.136, 7.579, 20.0, 40.0), (2.054, -1.675, 7.378, 20.0, 40.0), (4.106, 2.326, 0.402, 20.0, 40.0), (1.558, 0.310, 3.158, 20.0, 40.0), (0.792, 0.900, 1.596, 20.0, 40.0), (-3.229, 0.300, 0.785, 20.0, 40.0), (3.787, -0.793, 6.479, 20.0, 40.0), (1.786, 2.288, -0.684, 20.0, 40.0), (2.643, 0.223, 3.875, 20.0, 40.0), (-3.592, 2.122, -3.040, 20.0, 40.0), (4.519, -1.760, 8.779, 20.0, 40.0), (3.221, 2.255, 0.101, 20.0, 40.0), (4.151, 1.788, 1.500, 20.0, 40.0), (-1.033, -1.195, 4.874, 20.0, 40.0), (-1.636, -1.037, 4.257, 20.0, 40.0), (-3.548, 1.911, -2.596, 20.0, 40.0), (4.829, -0.293, 6.001, 20.0, 40.0), (-4.684, -1.664, 3.986, 20.0, 40.0), (4.531, -0.503, 6.271, 20.0, 40.0), (-3.503, -1.606, 4.460, 20.0, 40.0), (-2.036, -1.522, 5.027, 20.0, 40.0), (-0.473, -0.617, 3.997, 20.0, 40.0), (-1.554, -1.630, 5.483, 20.0, 40.0), (-3.567, -1.043, 3.302, 20.0, 40.0), (-2.038, 0.579, 0.823, 20.0, 40.0), (-3.040, 0.857, -0.233, 20.0, 40.0), (4.610, 0.562, 4.181, 20.0, 40.0), (-3.323, -1.938, 5.215, 20.0, 40.0), (4.314, 1.720, 1.717, 20.0, 40.0), (-1.220, 0.615, 1.161, 20.0, 40.0), (-2.556, 1.120, -0.519, 20.0, 40.0), (-3.717, -0.108, 1.358, 20.0, 40.0), (4.689, -1.826, 8.996, 20.0, 40.0), (3.452, 0.506, 3.713, 20.0, 40.0), (2.472, 0.612, 3.012, 20.0, 40.0), (3.452, 0.450, 3.826, 20.0, 40.0), (1.207, 2.585, -1.567, 20.0, 40.0), (-4.826, 1.090, -1.593, 20.0, 40.0), (3.116, -1.118, 6.794, 20.0, 40.0), (0.448, 2.732, -2.240, 20.0, 40.0), (-1.096, -0.525, 3.503, 20.0, 40.0), (-4.680, -0.238, 1.137, 20.0, 40.0), (2.552, -1.403, 7.082, 20.0, 40.0), (0.719, 2.997, -2.635, 20.0, 40.0), (0.347, -1.966, 7.105, 20.0, 40.0), (2.958, -0.404, 5.288, 20.0, 40.0), (0.722, -1.950, 7.261, 20.0, 40.0), (-2.851, -0.986, 3.546, 20.0, 40.0), (-4.316, -0.439, 1.721, 20.0, 40.0), (-1.685, -0.201, 2.560, 20.0, 40.0), (1.856, 0.190, 3.549, 20.0, 40.0), (-2.052, 0.206, 1.562, 20.0, 40.0), (-2.504, -0.646, 3.041, 20.0, 40.0), (3.235, 0.882, 2.854, 20.0, 40.0), (-1.366, -1.573, 5.463, 20.0, 40.0), (-3.447, 2.419, -3.562, 20.0, 40.0), (4.155, 2.092, 0.893, 20.0, 40.0), (-0.935, 0.209, 2.116, 20.0, 40.0), (3.117, -1.821, 8.201, 20.0, 40.0), (3.759, 0.577, 3.725, 20.0, 40.0), (-0.938, 2.992, -3.453, 20.0, 40.0), (-0.525, 2.341, -1.945, 20.0, 40.0), (4.540, 2.625, 0.019, 20.0, 40.0), (-2.097, 1.190, -0.429, 20.0, 40.0), (-2.672, 1.983, -2.302, 20.0, 40.0), (-3.038, -1.490, 4.460, 20.0, 40.0), (-0.943, 2.149, -1.770, 20.0, 40.0), (0.739, 1.598, 0.174, 20.0, 40.0), (1.828, 1.853, 0.208, 20.0, 40.0), (4.856, 0.137, 5.153, 20.0, 40.0), (-1.617, 0.468, 1.255, 20.0, 40.0), (-1.972, 2.053, -2.092, 20.0, 40.0), (-4.633, 1.389, -2.094, 20.0, 40.0), (-3.628, -1.156, 3.498, 20.0, 40.0), (3.597, 1.034, 2.731, 20.0, 40.0), (-1.488, -0.002, 2.261, 20.0, 40.0), (0.749, 1.921, -0.468, 20.0, 40.0), (1.304, -1.371, 6.394, 20.0, 40.0), (4.587, 2.936, -0.579, 20.0, 40.0), (-2.241, 1.791, -1.703, 20.0, 40.0), (-2.945, 1.372, -1.216, 20.0, 40.0), (1.375, 0.395, 2.898, 20.0, 40.0), (-1.281, -0.641, 3.642, 20.0, 40.0), (2.178, 0.895, 2.299, 20.0, 40.0), (3.031, -0.786, 6.087, 20.0, 40.0), (-1.385, -0.375, 3.058, 20.0, 40.0), (4.041, -0.431, 5.882, 20.0, 40.0), (0.480, -0.507, 4.254, 20.0, 40.0), (-3.797, 0.140, 0.822, 20.0, 40.0), (2.355, 2.502, -0.827, 20.0, 40.0), (1.376, -1.583, 6.854, 20.0, 40.0), (0.164, 1.405, 0.273, 20.0, 40.0), (-1.273, 1.471, -0.579, 20.0, 40.0), (0.770, 2.246, -1.107, 20.0, 40.0), (4.552, 2.904, -0.533, 20.0, 40.0), (4.259, -1.772, 8.674, 20.0, 40.0), (-0.309, 1.159, 0.528, 20.0, 40.0), (3.581, 2.700, -0.610, 20.0, 40.0), (-3.202, 0.346, 0.707, 20.0, 40.0), (-1.575, 1.242, -0.271, 20.0, 40.0), (-1.584, -0.493, 3.194, 20.0, 40.0), (-3.778, 0.150, 0.810, 20.0, 40.0), (-4.675, 1.749, -2.835, 20.0, 40.0), (3.567, -0.792, 6.367, 20.0, 40.0), (-0.417, 1.399, -0.006, 20.0, 40.0), (-4.672, 2.007, -3.349, 20.0, 40.0), (-1.034, 0.196, 2.090, 20.0, 40.0), (-3.796, 2.496, -3.890, 20.0, 40.0), (3.532, -0.497, 5.759, 20.0, 40.0), (4.868, -1.359, 8.151, 20.0, 40.0), (-0.769, 0.302, 2.011, 20.0, 40.0), (4.475, 2.612, 0.014, 20.0, 40.0), (-3.532, -0.395, 2.024, 20.0, 40.0), (0.322, 0.675, 1.812, 20.0, 40.0), (-2.028, -1.942, 5.870, 20.0, 40.0), (1.810, -1.244, 6.392, 20.0, 40.0), (-0.783, 1.242, 0.124, 20.0, 40.0), (-4.745, -1.300, 3.227, 20.0, 40.0), (1.902, 1.973, 0.005, 20.0, 40.0), (-3.453, -1.429, 4.132, 20.0, 40.0), (1.559, 0.986, 1.808, 20.0, 40.0), (0.128, 2.754, -2.443, 20.0, 40.0), (2.759, 1.727, 0.926, 20.0, 40.0), (-4.468, 1.690, -2.614, 20.0, 40.0), (-2.368, -1.922, 5.659, 20.0, 40.0), (-2.766, 2.128, -2.640, 20.0, 40.0), (0.967, -1.825, 7.133, 20.0, 40.0), (-2.854, 2.855, -4.136, 20.0, 40.0), (-2.944, 1.875, -2.222, 20.0, 40.0), (-2.632, -0.983, 3.649, 20.0, 40.0), (2.427, 2.239, -0.266, 20.0, 40.0), (-1.726, -0.838, 3.812, 20.0, 40.0), (0.007, -0.903, 4.809, 20.0, 40.0), (-2.013, 1.092, -0.191, 20.0, 40.0), (-0.449, 0.970, 0.836, 20.0, 40.0), (1.396, 0.411, 2.876, 20.0, 40.0), (-1.115, -1.790, 6.023, 20.0, 40.0), (3.748, 1.917, 1.039, 20.0, 40.0), (2.978, 1.043, 2.404, 20.0, 40.0), (-3.969, 2.514, -4.013, 20.0, 40.0), (4.455, -0.050, 5.328, 20.0, 40.0), (-3.065, -0.846, 3.160, 20.0, 40.0), (-1.069, 2.167, -1.869, 20.0, 40.0), (3.016, -1.393, 7.294, 20.0, 40.0), (0.045, -1.928, 6.879, 20.0, 40.0), (-2.555, -0.984, 3.690, 20.0, 40.0), (-1.995, -0.054, 2.111, 20.0, 40.0), (4.600, -0.509, 6.318, 20.0, 40.0), (-1.942, 1.215, -0.402, 20.0, 40.0), (1.262, 2.765, -1.899, 20.0, 40.0), (2.617, -1.106, 6.521, 20.0, 40.0), (1.737, 0.554, 2.761, 20.0, 40.0), (-2.197, 0.632, 0.638, 20.0, 40.0), (4.768, 2.618, 0.147, 20.0, 40.0), (-3.737, -0.939, 3.010, 20.0, 40.0), (-2.623, 0.595, 0.499, 20.0, 40.0), (4.752, -0.340, 6.057, 20.0, 40.0), (2.333, -1.037, 6.240, 20.0, 40.0), (4.234, -1.882, 8.881, 20.0, 40.0), (-3.393, -0.812, 2.927, 20.0, 40.0), (0.885, 1.383, 0.678, 20.0, 40.0), (0.123, 2.937, -2.812, 20.0, 40.0), (2.969, 0.760, 2.964, 20.0, 40.0), (-4.929, 1.251, -1.967, 20.0, 40.0), (1.916, 2.223, -0.488, 20.0, 40.0), (-0.020, -1.740, 6.469, 20.0, 40.0), (0.702, -1.272, 5.895, 20.0, 40.0), (2.496, 2.648, -1.048, 20.0, 40.0), (4.067, -1.475, 7.984, 20.0, 40.0), (-3.717, 1.851, -2.561, 20.0, 40.0), (1.678, -0.624, 5.088, 20.0, 40.0), (1.073, 0.695, 2.146, 20.0, 40.0), (1.842, -0.749, 5.419, 20.0, 40.0), (-3.518, 1.909, -2.578, 20.0, 40.0), (2.229, 1.189, 1.737, 20.0, 40.0), (4.987, 2.893, -0.292, 20.0, 40.0), (-4.809, 1.043, -1.490, 20.0, 40.0), (-0.241, -0.728, 4.334, 20.0, 40.0), (-3.331, 0.590, 0.156, 20.0, 40.0), (-0.455, 2.621, -2.470, 20.0, 40.0), (1.492, 1.223, 1.301, 20.0, 40.0), (3.948, 2.841, -0.709, 20.0, 40.0), (0.732, 0.446, 2.475, 20.0, 40.0), (2.400, 2.390, -0.579, 20.0, 40.0), (-2.718, 1.427, -1.213, 20.0, 40.0), (-1.826, 1.451, -0.815, 20.0, 40.0), (1.125, 0.438, 2.686, 20.0, 40.0), (-4.918, 1.880, -3.219, 20.0, 40.0), (3.068, -0.442, 5.418, 20.0, 40.0), (1.982, 1.201, 1.589, 20.0, 40.0), (0.701, -1.709, 6.768, 20.0, 40.0), (-1.496, 2.564, -2.877, 20.0, 40.0), (-3.812, 0.974, -0.853, 20.0, 40.0), (-3.405, 2.018, -2.739, 20.0, 40.0), (2.211, 2.889, -1.674, 20.0, 40.0), (-2.481, 2.931, -4.103, 20.0, 40.0), (-3.721, 2.765, -4.391, 20.0, 40.0), (-1.768, -1.292, 4.699, 20.0, 40.0), (-4.462, 1.058, -1.347, 20.0, 40.0), (-3.516, -1.942, 5.126, 20.0, 40.0), (0.485, 2.420, -1.597, 20.0, 40.0), (-0.492, 0.242, 2.270, 20.0, 40.0), (4.245, 1.689, 1.744, 20.0, 40.0), (2.234, 0.364, 3.389, 20.0, 40.0), (2.629, 2.224, -0.134, 20.0, 40.0), (-4.375, 1.221, -1.630, 20.0, 40.0), (-0.618, 1.374, -0.057, 20.0, 40.0), (-2.580, -1.604, 4.918, 20.0, 40.0), (0.159, 1.104, 0.871, 20.0, 40.0), (-3.597, 0.975, -0.749, 20.0, 40.0); -- DROP TABLE IF EXISTS test.model; -create table test.model engine = Memory as select LinearRegressionState(0.01)(target, param1, param2) as state from test.defaults; +create table test.model engine = Memory as select LinearRegressionState(0.1, 5)(target, param1, param2) as state from test.defaults; -- -- select toTypeName(state) from test.model; -- -- -- -- DROP TABLE IF EXISTS test.tests; From 73d83d0ab615c6dd0dc6a357289be578e8445f1c Mon Sep 17 00:00:00 2001 From: Maxim Kuznetsov Date: Thu, 24 Jan 2019 17:22:35 +0300 Subject: [PATCH 007/709] Added LinearModelData --- .../AggregateFunctionMLMethod.h | 98 +++++++++++++++++++ 1 file changed, 98 insertions(+) diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h index 650665fc673..0c443a859f8 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h @@ -29,6 +29,104 @@ namespace ErrorCodes extern const int BAD_ARGUMENTS; } +class IGradientComputer +{ +public: + virtual ~IGradientComputer() + {} + + void add(/* weights, */Float64 target, const IColumn ** columns, size_t row_num) final + { + ++cur_batch; + std::vector cur_grad = compute_gradient(/*...*/); + for (size_t i = 0; i != batch_gradient.size(); ++i) { + batch_gradient[i] += cur_grad[i]; + } + } + + std::vector get() final + { + std::vector result(batch_gradient.size()); + for (size_t i = 0; i != batch_gradient.size(); ++i) { + result[i] = batch_gradient[i] / cur_batch; + batch_gradient[i] = 0.0; + } + cur_batch = 0; + return result; + } + +protected: + virtual std::vector compute_gradient(/* weights, */Float64 target, const IColumn ** columns, size_t row_num) = 0; + +private: + UInt32 cur_batch = 0; + std::vector batch_gradient; // gradient for bias lies in batch_gradient[batch_gradient.size() - 1] +}; + +class LinearRegression : public IGradientComputer +{ +public: + virtual ~LinearRegression() + {} + +protected: + virtual std::vector compute_gradient(/* weights, */Float64 target, const IColumn ** columns, size_t row_num) + { + // TODO + } +}; + +class IWeightsUpdater +{ +public: + virtual ~IWeightsUpdater() + {} + + virtual void update(/* weights, gradient */) = 0; +}; + +class GradientDescent : public IWeightsUpdater +{ +public: + virtual ~GradientDescent() + {} + + virtual void update(/* weights, gradient */) = 0 { + // TODO + } +}; + +struct LinearModelData +{ + LinearModelData() + {} + + LinearModelData(Float64 learning_rate_, UInt32 param_num_, UInt32 batch_size_) + : learning_rate(learning_rate_), batch_size(batch_size_) { + weights.resize(param_num_, Float64{0.0}); + batch_gradient.resize(param_num_ + 1, Float64{0.0}); + cur_batch = 0; + } + + std::vector weights; + Float64 bias{0.0}; + std::shared_ptr gradient_computer; + std::shared_ptr weights_updater; + + void add(Float64 target, const IColumn ** columns, size_t row_num) + { + gradient_cumputer->add(target, columns, row_num); + if (cur_batch == batch_size) + { + cur_batch = 0; + weights_updater->update(/* weights */, gradient_computer->get()); + } + } + + void merge(const LinearModelData & rhs) + { + } +}; struct LinearRegressionData { From 57cd47a1943c4902919021af6d27b1a972704386 Mon Sep 17 00:00:00 2001 From: alexander kozhikhov Date: Sat, 26 Jan 2019 15:38:42 +0300 Subject: [PATCH 008/709] LinearModelData completed --- .../AggregateFunctionMLMethod.cpp | 33 ++- .../AggregateFunctionMLMethod.h | 220 ++++++++---------- dbms/src/Columns/ColumnAggregateFunction.cpp | 3 +- .../queries/0_stateless/00900_mytest.sql | 2 +- 4 files changed, 132 insertions(+), 126 deletions(-) diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp index f419bb9592c..ae0ede33096 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp @@ -10,14 +10,14 @@ namespace DB namespace { -using FuncLinearRegression = AggregateFunctionMLMethod; +using FuncLinearRegression = AggregateFunctionMLMethod; template AggregateFunctionPtr createAggregateFunctionMLMethod( const std::string & name, const DataTypes & argument_types, const Array & parameters) { - if (parameters.size() > 2) - throw Exception("Aggregate function " + name + " requires at most two parameters", ErrorCodes::NUMBER_OF_ARGUMENTS_DOESNT_MATCH); + if (parameters.size() > 4) + throw Exception("Aggregate function " + name + " requires at most four parameters", ErrorCodes::NUMBER_OF_ARGUMENTS_DOESNT_MATCH); for (size_t i = 0; i < argument_types.size(); ++i) { @@ -29,6 +29,9 @@ AggregateFunctionPtr createAggregateFunctionMLMethod( Float64 learning_rate = Float64(0.01); UInt32 batch_size = 1; + + std::shared_ptr gc; + std::shared_ptr wu; if (!parameters.empty()) { learning_rate = applyVisitor(FieldVisitorConvertToNumber(), parameters[0]); @@ -39,10 +42,32 @@ AggregateFunctionPtr createAggregateFunctionMLMethod( } + /// Gradient_Computer for LinearRegression has LinearRegression gradient computer + if (std::is_same::value) + { + gc = std::make_shared(argument_types.size()); + } else + { + throw Exception("Such gradient computer is not implemented yet", ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT); + } + if (parameters.size() > 2) + { + if (applyVisitor(FieldVisitorConvertToNumber(), parameters[2]) == Float64{1.0}) + { + wu = std::make_shared(); + } else + { + throw Exception("Such weights updater is not implemented yet", ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT); + } + } else + { + wu = std::make_unique(); + } + if (argument_types.size() < 2) throw Exception("Aggregate function " + name + " requires at least two arguments", ErrorCodes::NUMBER_OF_ARGUMENTS_DOESNT_MATCH); - return std::make_shared(argument_types.size() - 1, learning_rate, batch_size); + return std::make_shared(argument_types.size() - 1, gc, wu, learning_rate, batch_size); } } diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h index 0c443a859f8..0aca5485203 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h @@ -32,122 +32,47 @@ namespace ErrorCodes class IGradientComputer { public: - virtual ~IGradientComputer() + IGradientComputer(UInt32 sz) + : batch_gradient(sz, 0) {} + virtual ~IGradientComputer() = default; - void add(/* weights, */Float64 target, const IColumn ** columns, size_t row_num) final + virtual void compute(const std::vector & weights, Float64 bias, Float64 learning_rate, + Float64 target, const IColumn ** columns, size_t row_num) = 0; + + void reset() { - ++cur_batch; - std::vector cur_grad = compute_gradient(/*...*/); - for (size_t i = 0; i != batch_gradient.size(); ++i) { - batch_gradient[i] += cur_grad[i]; - } + batch_gradient.assign(batch_gradient.size(), 0); } - std::vector get() final + void write(WriteBuffer & buf) const { - std::vector result(batch_gradient.size()); - for (size_t i = 0; i != batch_gradient.size(); ++i) { - result[i] = batch_gradient[i] / cur_batch; - batch_gradient[i] = 0.0; - } - cur_batch = 0; - return result; + writeBinary(batch_gradient, buf); + } + + void read(ReadBuffer & buf) + { + readBinary(batch_gradient, buf); + } + + const std::vector & get() const + { + return batch_gradient; } protected: - virtual std::vector compute_gradient(/* weights, */Float64 target, const IColumn ** columns, size_t row_num) = 0; - -private: - UInt32 cur_batch = 0; std::vector batch_gradient; // gradient for bias lies in batch_gradient[batch_gradient.size() - 1] }; class LinearRegression : public IGradientComputer { public: - virtual ~LinearRegression() + LinearRegression(UInt32 sz) + : IGradientComputer(sz) {} -protected: - virtual std::vector compute_gradient(/* weights, */Float64 target, const IColumn ** columns, size_t row_num) - { - // TODO - } -}; - -class IWeightsUpdater -{ -public: - virtual ~IWeightsUpdater() - {} - - virtual void update(/* weights, gradient */) = 0; -}; - -class GradientDescent : public IWeightsUpdater -{ -public: - virtual ~GradientDescent() - {} - - virtual void update(/* weights, gradient */) = 0 { - // TODO - } -}; - -struct LinearModelData -{ - LinearModelData() - {} - - LinearModelData(Float64 learning_rate_, UInt32 param_num_, UInt32 batch_size_) - : learning_rate(learning_rate_), batch_size(batch_size_) { - weights.resize(param_num_, Float64{0.0}); - batch_gradient.resize(param_num_ + 1, Float64{0.0}); - cur_batch = 0; - } - - std::vector weights; - Float64 bias{0.0}; - std::shared_ptr gradient_computer; - std::shared_ptr weights_updater; - - void add(Float64 target, const IColumn ** columns, size_t row_num) - { - gradient_cumputer->add(target, columns, row_num); - if (cur_batch == batch_size) - { - cur_batch = 0; - weights_updater->update(/* weights */, gradient_computer->get()); - } - } - - void merge(const LinearModelData & rhs) - { - } -}; - -struct LinearRegressionData -{ - LinearRegressionData() - {} - LinearRegressionData(Float64 learning_rate_, UInt32 param_num_, UInt32 batch_size_) - : learning_rate(learning_rate_), batch_size(batch_size_) { - weights.resize(param_num_, Float64{0.0}); - batch_gradient.resize(param_num_ + 1, Float64{0.0}); - cur_batch = 0; - } - - Float64 bias{0.0}; - std::vector weights; - Float64 learning_rate; - UInt32 iter_num = 0; - std::vector batch_gradient; - UInt32 cur_batch; - UInt32 batch_size; - - void update_gradient(Float64 target, const IColumn ** columns, size_t row_num) + void compute(const std::vector & weights, Float64 bias, Float64 learning_rate, + Float64 target, const IColumn ** columns, size_t row_num) override { Float64 derivative = (target - bias); for (size_t i = 0; i < weights.size(); ++i) @@ -156,47 +81,72 @@ struct LinearRegressionData } derivative *= (2 * learning_rate); -// bias += derivative; batch_gradient[weights.size()] += derivative; for (size_t i = 0; i < weights.size(); ++i) { batch_gradient[i] += derivative * static_cast &>(*columns[i + 1]).getData()[row_num];; } } +}; - void update_weights() - { - if (!cur_batch) - return; +class IWeightsUpdater +{ +public: + virtual ~IWeightsUpdater() = default; + virtual void update(UInt32 cur_batch, std::vector & weights, Float64 & bias, const std::vector & gradient) = 0; +}; + +class StochasticGradientDescent : public IWeightsUpdater +{ +public: + void update(UInt32 cur_batch, std::vector & weights, Float64 & bias, const std::vector & batch_gradient) override { for (size_t i = 0; i < weights.size(); ++i) { weights[i] += batch_gradient[i] / cur_batch; } bias += batch_gradient[weights.size()] / cur_batch; + } +}; - batch_gradient.assign(batch_gradient.size(), Float64{0.0}); +class LinearModelData +{ +public: + LinearModelData() + {} - ++iter_num; + LinearModelData(Float64 learning_rate, + UInt32 param_num, + UInt32 batch_size, + std::shared_ptr gc, + std::shared_ptr wu) + : learning_rate(learning_rate), + batch_size(batch_size), + gradient_computer(std::move(gc)), + weights_updater(std::move(wu)) + { + weights.resize(param_num, Float64{0.0}); cur_batch = 0; } + + void add(Float64 target, const IColumn ** columns, size_t row_num) { - update_gradient(target, columns, row_num); + gradient_computer->compute(weights, bias, learning_rate, target, columns, row_num); ++cur_batch; if (cur_batch == batch_size) { - update_weights(); + update_state(); } } - void merge(const LinearRegressionData & rhs) + void merge(const LinearModelData & rhs) { if (iter_num == 0 && rhs.iter_num == 0) return; - update_weights(); + update_state(); /// нельзя обновить из-за константости // rhs.update_weights(); @@ -217,8 +167,8 @@ struct LinearRegressionData writeBinary(bias, buf); writeBinary(weights, buf); writeBinary(iter_num, buf); - writeBinary(batch_gradient, buf); writeBinary(cur_batch, buf); + gradient_computer->write(buf); } void read(ReadBuffer & buf) @@ -226,11 +176,11 @@ struct LinearRegressionData readBinary(bias, buf); readBinary(weights, buf); readBinary(iter_num, buf); - readBinary(batch_gradient, buf); readBinary(cur_batch, buf); + gradient_computer->read(buf); } - Float64 predict(const std::vector& predict_feature) const + Float64 predict(const std::vector & predict_feature) const { /// не обновляем веса при предикте, т.к. это может замедлить предсказание /// однако можно например обновлять их при каждом мердже не зависимо от того, сколько элементнов в батче @@ -248,6 +198,27 @@ struct LinearRegressionData return res; } + +private: + std::vector weights; + Float64 learning_rate; + UInt32 batch_size; + Float64 bias{0.0}; + UInt32 iter_num = 0; + UInt32 cur_batch; + std::shared_ptr gradient_computer; + std::shared_ptr weights_updater; + + void update_state() + { + if (cur_batch == 0) + return; + + weights_updater->update(cur_batch, weights, bias, gradient_computer->get()); + cur_batch = 0; + ++iter_num; + gradient_computer->reset(); + } }; template < @@ -261,10 +232,17 @@ class AggregateFunctionMLMethod final : public IAggregateFunctionDataHelper gradient_computer, + std::shared_ptr weights_updater, + Float64 learning_rate, + UInt32 batch_size) + : param_num(param_num), + learning_rate(learning_rate), + batch_size(batch_size), + gc(std::move(gradient_computer)), + wu(std::move(weights_updater)) + {} DataTypePtr getReturnType() const override { @@ -273,7 +251,7 @@ public: void create(AggregateDataPtr place) const override { - new (place) Data(learning_rate, param_num, batch_size); + new (place) Data(learning_rate, param_num, batch_size, gc, wu); } void add(AggregateDataPtr place, const IColumn ** columns, size_t row_num, Arena *) const override @@ -322,9 +300,9 @@ public: void insertResultInto(ConstAggregateDataPtr place, IColumn & to) const override { - auto &column = dynamic_cast &>(to); - std::ignore = column; std::ignore = place; + std::ignore = to; + return; } const char * getHeaderFilePath() const override { return __FILE__; } @@ -333,6 +311,8 @@ private: UInt32 param_num; Float64 learning_rate; UInt32 batch_size; + std::shared_ptr gc; + std::shared_ptr wu; }; struct NameLinearRegression { static constexpr auto name = "LinearRegression"; }; diff --git a/dbms/src/Columns/ColumnAggregateFunction.cpp b/dbms/src/Columns/ColumnAggregateFunction.cpp index 1dca1780974..efa24fc56ba 100644 --- a/dbms/src/Columns/ColumnAggregateFunction.cpp +++ b/dbms/src/Columns/ColumnAggregateFunction.cpp @@ -122,7 +122,8 @@ MutableColumnPtr ColumnAggregateFunction::predictValues(Block & block, const Col return res; } - auto ML_function = typeid_cast *>(func.get()); +// auto ML_function = typeid_cast *>(func.get()); + auto ML_function = typeid_cast *>(func.get()); if (ML_function) { size_t row_num = 0; diff --git a/dbms/tests/queries/0_stateless/00900_mytest.sql b/dbms/tests/queries/0_stateless/00900_mytest.sql index 8fa676b2668..ddb99c77d19 100644 --- a/dbms/tests/queries/0_stateless/00900_mytest.sql +++ b/dbms/tests/queries/0_stateless/00900_mytest.sql @@ -13,7 +13,7 @@ insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0 -- insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0), (-1.099, 2.755, -3.060, 20.0, 40.0), (1.090, 2.945, -2.346, 20.0, 40.0), (0.305, 2.179, -1.205, 20.0, 40.0), (-0.925, 0.702, 1.134, 20.0, 40.0), (3.178, -1.316, 7.221, 20.0, 40.0), (-2.756, -0.473, 2.569, 20.0, 40.0), (3.665, 2.303, 0.226, 20.0, 40.0), (1.662, 1.951, -0.070, 20.0, 40.0), (2.869, 0.593, 3.249, 20.0, 40.0), (0.818, -0.593, 4.594, 20.0, 40.0), (-1.917, 0.916, 0.209, 20.0, 40.0), (2.706, 1.523, 1.307, 20.0, 40.0), (0.219, 2.162, -1.214, 20.0, 40.0), (-4.510, 1.376, -2.007, 20.0, 40.0), (4.284, -0.515, 6.173, 20.0, 40.0), (-1.101, 2.810, -3.170, 20.0, 40.0), (-1.810, -1.117, 4.329, 20.0, 40.0), (0.055, 1.115, 0.797, 20.0, 40.0), (-2.178, 2.904, -3.898, 20.0, 40.0), (-3.494, -1.814, 4.882, 20.0, 40.0), (3.027, 0.476, 3.562, 20.0, 40.0), (-1.434, 1.151, -0.018, 20.0, 40.0), (1.180, 0.992, 1.606, 20.0, 40.0), (0.015, 0.971, 1.067, 20.0, 40.0), (-0.511, -0.875, 4.495, 20.0, 40.0), (0.961, 2.348, -1.216, 20.0, 40.0), (-2.279, 0.038, 1.785, 20.0, 40.0), (-1.568, -0.248, 2.712, 20.0, 40.0), (-0.496, 0.366, 2.020, 20.0, 40.0), (1.177, -1.401, 6.390, 20.0, 40.0), (2.882, -1.442, 7.325, 20.0, 40.0), (-1.066, 1.817, -1.167, 20.0, 40.0), (-2.144, 2.791, -3.655, 20.0, 40.0), (-4.370, 2.228, -3.642, 20.0, 40.0), (3.996, 2.775, -0.553, 20.0, 40.0), (0.289, 2.055, -0.965, 20.0, 40.0), (-0.588, -1.601, 5.908, 20.0, 40.0), (-1.801, 0.417, 1.265, 20.0, 40.0), (4.375, -1.499, 8.186, 20.0, 40.0), (-2.618, 0.038, 1.615, 20.0, 40.0), (3.616, -0.833, 6.475, 20.0, 40.0), (-4.045, -1.558, 4.094, 20.0, 40.0), (-3.962, 0.636, -0.253, 20.0, 40.0), (3.505, 2.625, -0.497, 20.0, 40.0), (3.029, -0.523, 5.560, 20.0, 40.0), (-3.520, -0.474, 2.188, 20.0, 40.0), (2.430, -1.469, 7.154, 20.0, 40.0), (1.547, -1.654, 7.082, 20.0, 40.0), (-1.370, 0.575, 1.165, 20.0, 40.0), (-1.869, -1.555, 5.176, 20.0, 40.0), (3.536, 2.841, -0.913, 20.0, 40.0), (-3.810, 1.220, -1.344, 20.0, 40.0), (-1.971, 1.462, -0.910, 20.0, 40.0), (-0.243, 0.167, 2.545, 20.0, 40.0), (-1.403, 2.645, -2.991, 20.0, 40.0), (0.532, -0.114, 3.494, 20.0, 40.0), (-1.678, 0.975, 0.212, 20.0, 40.0), (-0.656, 2.140, -1.609, 20.0, 40.0), (1.743, 2.631, -1.390, 20.0, 40.0), (2.586, 2.943, -1.593, 20.0, 40.0), (-0.512, 2.969, -3.195, 20.0, 40.0), (2.283, -0.100, 4.342, 20.0, 40.0), (-4.293, 0.872, -0.890, 20.0, 40.0), (3.411, 1.300, 2.106, 20.0, 40.0), (-0.281, 2.951, -3.042, 20.0, 40.0), (-4.442, 0.384, 0.012, 20.0, 40.0), (1.194, 1.746, 0.104, 20.0, 40.0), (-1.152, 1.862, -1.300, 20.0, 40.0), (1.362, -1.341, 6.363, 20.0, 40.0), (-4.488, 2.618, -4.481, 20.0, 40.0), (3.419, -0.564, 5.837, 20.0, 40.0), (-3.392, 0.396, 0.512, 20.0, 40.0), (-1.629, -0.909, 4.003, 20.0, 40.0), (4.447, -1.088, 7.399, 20.0, 40.0), (-1.232, 1.699, -1.014, 20.0, 40.0), (-1.286, -0.609, 3.575, 20.0, 40.0), (2.437, 2.796, -1.374, 20.0, 40.0), (-4.864, 1.989, -3.410, 20.0, 40.0), (-1.716, -1.399, 4.940, 20.0, 40.0), (-3.084, 1.858, -2.259, 20.0, 40.0), (2.828, -0.319, 5.053, 20.0, 40.0), (-1.226, 2.586, -2.786, 20.0, 40.0), (2.456, 0.092, 4.044, 20.0, 40.0), (-0.989, 2.375, -2.245, 20.0, 40.0), (3.268, 0.935, 2.765, 20.0, 40.0), (-4.128, -1.995, 4.927, 20.0, 40.0), (-1.083, 2.197, -1.935, 20.0, 40.0), (-3.471, -1.198, 3.660, 20.0, 40.0), (4.617, -1.136, 7.579, 20.0, 40.0), (2.054, -1.675, 7.378, 20.0, 40.0), (4.106, 2.326, 0.402, 20.0, 40.0), (1.558, 0.310, 3.158, 20.0, 40.0), (0.792, 0.900, 1.596, 20.0, 40.0), (-3.229, 0.300, 0.785, 20.0, 40.0), (3.787, -0.793, 6.479, 20.0, 40.0), (1.786, 2.288, -0.684, 20.0, 40.0), (2.643, 0.223, 3.875, 20.0, 40.0), (-3.592, 2.122, -3.040, 20.0, 40.0), (4.519, -1.760, 8.779, 20.0, 40.0), (3.221, 2.255, 0.101, 20.0, 40.0), (4.151, 1.788, 1.500, 20.0, 40.0), (-1.033, -1.195, 4.874, 20.0, 40.0), (-1.636, -1.037, 4.257, 20.0, 40.0), (-3.548, 1.911, -2.596, 20.0, 40.0), (4.829, -0.293, 6.001, 20.0, 40.0), (-4.684, -1.664, 3.986, 20.0, 40.0), (4.531, -0.503, 6.271, 20.0, 40.0), (-3.503, -1.606, 4.460, 20.0, 40.0), (-2.036, -1.522, 5.027, 20.0, 40.0), (-0.473, -0.617, 3.997, 20.0, 40.0), (-1.554, -1.630, 5.483, 20.0, 40.0), (-3.567, -1.043, 3.302, 20.0, 40.0), (-2.038, 0.579, 0.823, 20.0, 40.0), (-3.040, 0.857, -0.233, 20.0, 40.0), (4.610, 0.562, 4.181, 20.0, 40.0), (-3.323, -1.938, 5.215, 20.0, 40.0), (4.314, 1.720, 1.717, 20.0, 40.0), (-1.220, 0.615, 1.161, 20.0, 40.0), (-2.556, 1.120, -0.519, 20.0, 40.0), (-3.717, -0.108, 1.358, 20.0, 40.0), (4.689, -1.826, 8.996, 20.0, 40.0), (3.452, 0.506, 3.713, 20.0, 40.0), (2.472, 0.612, 3.012, 20.0, 40.0), (3.452, 0.450, 3.826, 20.0, 40.0), (1.207, 2.585, -1.567, 20.0, 40.0), (-4.826, 1.090, -1.593, 20.0, 40.0), (3.116, -1.118, 6.794, 20.0, 40.0), (0.448, 2.732, -2.240, 20.0, 40.0), (-1.096, -0.525, 3.503, 20.0, 40.0), (-4.680, -0.238, 1.137, 20.0, 40.0), (2.552, -1.403, 7.082, 20.0, 40.0), (0.719, 2.997, -2.635, 20.0, 40.0), (0.347, -1.966, 7.105, 20.0, 40.0), (2.958, -0.404, 5.288, 20.0, 40.0), (0.722, -1.950, 7.261, 20.0, 40.0), (-2.851, -0.986, 3.546, 20.0, 40.0), (-4.316, -0.439, 1.721, 20.0, 40.0), (-1.685, -0.201, 2.560, 20.0, 40.0), (1.856, 0.190, 3.549, 20.0, 40.0), (-2.052, 0.206, 1.562, 20.0, 40.0), (-2.504, -0.646, 3.041, 20.0, 40.0), (3.235, 0.882, 2.854, 20.0, 40.0), (-1.366, -1.573, 5.463, 20.0, 40.0), (-3.447, 2.419, -3.562, 20.0, 40.0), (4.155, 2.092, 0.893, 20.0, 40.0), (-0.935, 0.209, 2.116, 20.0, 40.0), (3.117, -1.821, 8.201, 20.0, 40.0), (3.759, 0.577, 3.725, 20.0, 40.0), (-0.938, 2.992, -3.453, 20.0, 40.0), (-0.525, 2.341, -1.945, 20.0, 40.0), (4.540, 2.625, 0.019, 20.0, 40.0), (-2.097, 1.190, -0.429, 20.0, 40.0), (-2.672, 1.983, -2.302, 20.0, 40.0), (-3.038, -1.490, 4.460, 20.0, 40.0), (-0.943, 2.149, -1.770, 20.0, 40.0), (0.739, 1.598, 0.174, 20.0, 40.0), (1.828, 1.853, 0.208, 20.0, 40.0), (4.856, 0.137, 5.153, 20.0, 40.0), (-1.617, 0.468, 1.255, 20.0, 40.0), (-1.972, 2.053, -2.092, 20.0, 40.0), (-4.633, 1.389, -2.094, 20.0, 40.0), (-3.628, -1.156, 3.498, 20.0, 40.0), (3.597, 1.034, 2.731, 20.0, 40.0), (-1.488, -0.002, 2.261, 20.0, 40.0), (0.749, 1.921, -0.468, 20.0, 40.0), (1.304, -1.371, 6.394, 20.0, 40.0), (4.587, 2.936, -0.579, 20.0, 40.0), (-2.241, 1.791, -1.703, 20.0, 40.0), (-2.945, 1.372, -1.216, 20.0, 40.0), (1.375, 0.395, 2.898, 20.0, 40.0), (-1.281, -0.641, 3.642, 20.0, 40.0), (2.178, 0.895, 2.299, 20.0, 40.0), (3.031, -0.786, 6.087, 20.0, 40.0), (-1.385, -0.375, 3.058, 20.0, 40.0), (4.041, -0.431, 5.882, 20.0, 40.0), (0.480, -0.507, 4.254, 20.0, 40.0), (-3.797, 0.140, 0.822, 20.0, 40.0), (2.355, 2.502, -0.827, 20.0, 40.0), (1.376, -1.583, 6.854, 20.0, 40.0), (0.164, 1.405, 0.273, 20.0, 40.0), (-1.273, 1.471, -0.579, 20.0, 40.0), (0.770, 2.246, -1.107, 20.0, 40.0), (4.552, 2.904, -0.533, 20.0, 40.0), (4.259, -1.772, 8.674, 20.0, 40.0), (-0.309, 1.159, 0.528, 20.0, 40.0), (3.581, 2.700, -0.610, 20.0, 40.0), (-3.202, 0.346, 0.707, 20.0, 40.0), (-1.575, 1.242, -0.271, 20.0, 40.0), (-1.584, -0.493, 3.194, 20.0, 40.0), (-3.778, 0.150, 0.810, 20.0, 40.0), (-4.675, 1.749, -2.835, 20.0, 40.0), (3.567, -0.792, 6.367, 20.0, 40.0), (-0.417, 1.399, -0.006, 20.0, 40.0), (-4.672, 2.007, -3.349, 20.0, 40.0), (-1.034, 0.196, 2.090, 20.0, 40.0), (-3.796, 2.496, -3.890, 20.0, 40.0), (3.532, -0.497, 5.759, 20.0, 40.0), (4.868, -1.359, 8.151, 20.0, 40.0), (-0.769, 0.302, 2.011, 20.0, 40.0), (4.475, 2.612, 0.014, 20.0, 40.0), (-3.532, -0.395, 2.024, 20.0, 40.0), (0.322, 0.675, 1.812, 20.0, 40.0), (-2.028, -1.942, 5.870, 20.0, 40.0), (1.810, -1.244, 6.392, 20.0, 40.0), (-0.783, 1.242, 0.124, 20.0, 40.0), (-4.745, -1.300, 3.227, 20.0, 40.0), (1.902, 1.973, 0.005, 20.0, 40.0), (-3.453, -1.429, 4.132, 20.0, 40.0), (1.559, 0.986, 1.808, 20.0, 40.0), (0.128, 2.754, -2.443, 20.0, 40.0), (2.759, 1.727, 0.926, 20.0, 40.0), (-4.468, 1.690, -2.614, 20.0, 40.0), (-2.368, -1.922, 5.659, 20.0, 40.0), (-2.766, 2.128, -2.640, 20.0, 40.0), (0.967, -1.825, 7.133, 20.0, 40.0), (-2.854, 2.855, -4.136, 20.0, 40.0), (-2.944, 1.875, -2.222, 20.0, 40.0), (-2.632, -0.983, 3.649, 20.0, 40.0), (2.427, 2.239, -0.266, 20.0, 40.0), (-1.726, -0.838, 3.812, 20.0, 40.0), (0.007, -0.903, 4.809, 20.0, 40.0), (-2.013, 1.092, -0.191, 20.0, 40.0), (-0.449, 0.970, 0.836, 20.0, 40.0), (1.396, 0.411, 2.876, 20.0, 40.0), (-1.115, -1.790, 6.023, 20.0, 40.0), (3.748, 1.917, 1.039, 20.0, 40.0), (2.978, 1.043, 2.404, 20.0, 40.0), (-3.969, 2.514, -4.013, 20.0, 40.0), (4.455, -0.050, 5.328, 20.0, 40.0), (-3.065, -0.846, 3.160, 20.0, 40.0), (-1.069, 2.167, -1.869, 20.0, 40.0), (3.016, -1.393, 7.294, 20.0, 40.0), (0.045, -1.928, 6.879, 20.0, 40.0), (-2.555, -0.984, 3.690, 20.0, 40.0), (-1.995, -0.054, 2.111, 20.0, 40.0), (4.600, -0.509, 6.318, 20.0, 40.0), (-1.942, 1.215, -0.402, 20.0, 40.0), (1.262, 2.765, -1.899, 20.0, 40.0), (2.617, -1.106, 6.521, 20.0, 40.0), (1.737, 0.554, 2.761, 20.0, 40.0), (-2.197, 0.632, 0.638, 20.0, 40.0), (4.768, 2.618, 0.147, 20.0, 40.0), (-3.737, -0.939, 3.010, 20.0, 40.0), (-2.623, 0.595, 0.499, 20.0, 40.0), (4.752, -0.340, 6.057, 20.0, 40.0), (2.333, -1.037, 6.240, 20.0, 40.0), (4.234, -1.882, 8.881, 20.0, 40.0), (-3.393, -0.812, 2.927, 20.0, 40.0), (0.885, 1.383, 0.678, 20.0, 40.0), (0.123, 2.937, -2.812, 20.0, 40.0), (2.969, 0.760, 2.964, 20.0, 40.0), (-4.929, 1.251, -1.967, 20.0, 40.0), (1.916, 2.223, -0.488, 20.0, 40.0), (-0.020, -1.740, 6.469, 20.0, 40.0), (0.702, -1.272, 5.895, 20.0, 40.0), (2.496, 2.648, -1.048, 20.0, 40.0), (4.067, -1.475, 7.984, 20.0, 40.0), (-3.717, 1.851, -2.561, 20.0, 40.0), (1.678, -0.624, 5.088, 20.0, 40.0), (1.073, 0.695, 2.146, 20.0, 40.0), (1.842, -0.749, 5.419, 20.0, 40.0), (-3.518, 1.909, -2.578, 20.0, 40.0), (2.229, 1.189, 1.737, 20.0, 40.0), (4.987, 2.893, -0.292, 20.0, 40.0), (-4.809, 1.043, -1.490, 20.0, 40.0), (-0.241, -0.728, 4.334, 20.0, 40.0), (-3.331, 0.590, 0.156, 20.0, 40.0), (-0.455, 2.621, -2.470, 20.0, 40.0), (1.492, 1.223, 1.301, 20.0, 40.0), (3.948, 2.841, -0.709, 20.0, 40.0), (0.732, 0.446, 2.475, 20.0, 40.0), (2.400, 2.390, -0.579, 20.0, 40.0), (-2.718, 1.427, -1.213, 20.0, 40.0), (-1.826, 1.451, -0.815, 20.0, 40.0), (1.125, 0.438, 2.686, 20.0, 40.0), (-4.918, 1.880, -3.219, 20.0, 40.0), (3.068, -0.442, 5.418, 20.0, 40.0), (1.982, 1.201, 1.589, 20.0, 40.0), (0.701, -1.709, 6.768, 20.0, 40.0), (-1.496, 2.564, -2.877, 20.0, 40.0), (-3.812, 0.974, -0.853, 20.0, 40.0), (-3.405, 2.018, -2.739, 20.0, 40.0), (2.211, 2.889, -1.674, 20.0, 40.0), (-2.481, 2.931, -4.103, 20.0, 40.0), (-3.721, 2.765, -4.391, 20.0, 40.0), (-1.768, -1.292, 4.699, 20.0, 40.0), (-4.462, 1.058, -1.347, 20.0, 40.0), (-3.516, -1.942, 5.126, 20.0, 40.0), (0.485, 2.420, -1.597, 20.0, 40.0), (-0.492, 0.242, 2.270, 20.0, 40.0), (4.245, 1.689, 1.744, 20.0, 40.0), (2.234, 0.364, 3.389, 20.0, 40.0), (2.629, 2.224, -0.134, 20.0, 40.0), (-4.375, 1.221, -1.630, 20.0, 40.0), (-0.618, 1.374, -0.057, 20.0, 40.0), (-2.580, -1.604, 4.918, 20.0, 40.0), (0.159, 1.104, 0.871, 20.0, 40.0), (-3.597, 0.975, -0.749, 20.0, 40.0); -- DROP TABLE IF EXISTS test.model; -create table test.model engine = Memory as select LinearRegressionState(0.1, 5)(target, param1, param2) as state from test.defaults; +create table test.model engine = Memory as select LinearRegressionState(0.1, 5, 1.0)(target, param1, param2) as state from test.defaults; -- -- select toTypeName(state) from test.model; -- -- -- -- DROP TABLE IF EXISTS test.tests; From 286fa25ad928cf750cc5e51cecfa610364c18abf Mon Sep 17 00:00:00 2001 From: Masha Date: Mon, 28 Jan 2019 10:39:57 +0000 Subject: [PATCH 009/709] logreg and momentum --- .../AggregateFunctionMLMethod.cpp | 9 +- .../AggregateFunctionMLMethod.h | 111 ++++++++++++++++-- dbms/src/Columns/ColumnAggregateFunction.cpp | 18 ++- 3 files changed, 123 insertions(+), 15 deletions(-) diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp index ae0ede33096..6aa983defc4 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp @@ -11,7 +11,7 @@ namespace { using FuncLinearRegression = AggregateFunctionMLMethod; - +using FuncLogicRegression = AggregateFunctionMLMethod; template AggregateFunctionPtr createAggregateFunctionMLMethod( const std::string & name, const DataTypes & argument_types, const Array & parameters) @@ -46,6 +46,9 @@ AggregateFunctionPtr createAggregateFunctionMLMethod( if (std::is_same::value) { gc = std::make_shared(argument_types.size()); + } else if (std::is_same::value) + { + gc = std::make_shared(argument_types.size()); } else { throw Exception("Such gradient computer is not implemented yet", ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT); @@ -55,6 +58,9 @@ AggregateFunctionPtr createAggregateFunctionMLMethod( if (applyVisitor(FieldVisitorConvertToNumber(), parameters[2]) == Float64{1.0}) { wu = std::make_shared(); + } else if (applyVisitor(FieldVisitorConvertToNumber(), parameters[2]) == Float64{2.0}) + { + wu = std::make_shared(); } else { throw Exception("Such weights updater is not implemented yet", ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT); @@ -75,6 +81,7 @@ AggregateFunctionPtr createAggregateFunctionMLMethod( void registerAggregateFunctionMLMethod(AggregateFunctionFactory & factory) { factory.registerFunction("LinearRegression", createAggregateFunctionMLMethod); + factory.registerFunction("LogicRegression", createAggregateFunctionMLMethod); } } diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h index 0aca5485203..598ff23b5d9 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h @@ -59,6 +59,7 @@ public: { return batch_gradient; } + virtual Float64 predict(const std::vector & predict_feature, const std::vector & weights, Float64 bias) const = 0; protected: std::vector batch_gradient; // gradient for bias lies in batch_gradient[batch_gradient.size() - 1] @@ -87,6 +88,73 @@ public: batch_gradient[i] += derivative * static_cast &>(*columns[i + 1]).getData()[row_num];; } } + Float64 predict(const std::vector & predict_feature, const std::vector & weights, Float64 bias) const override + { + /// не обновляем веса при предикте, т.к. это может замедлить предсказание + /// однако можно например обновлять их при каждом мердже не зависимо от того, сколько элементнов в батче +// if (cur_batch) +// { +// update_weights(); +// } + + Float64 res{0.0}; + for (size_t i = 0; i < predict_feature.size(); ++i) + { + res += predict_feature[i] * weights[i]; + } + res += bias; + + return res; + } +}; +class LogicRegression : public IGradientComputer +{ +public: + LogicRegression(UInt32 sz) + : IGradientComputer(sz) + {} + + void compute(const std::vector & weights, Float64 bias, Float64 learning_rate, + Float64 target, const IColumn ** columns, size_t row_num) override + { + //Float64 derivative = (target - bias); + //for (size_t i = 0; i < weights.size(); ++i) + //{ + // derivative -= weights[i] * static_cast &>(*columns[i + 1]).getData()[row_num]; + //} + //derivative *= (2 * learning_rate); + Float64 derivative = bias; + for (size_t i = 0; i < weights.size(); ++i) + { + derivative += weights[i] * static_cast &>(*columns[i + 1]).getData()[row_num];; + } + derivative *= target; + derivative = learning_rate * exp(derivative); + + batch_gradient[weights.size()] += target / (derivative + 1);; + for (size_t i = 0; i < weights.size(); ++i) + { + batch_gradient[i] += target / (derivative + 1) * static_cast &>(*columns[i + 1]).getData()[row_num]; + } + } + Float64 predict(const std::vector & predict_feature, const std::vector & weights, Float64 bias) const override + { + /// не обновляем веса при предикте, т.к. это может замедлить предсказание + /// однако можно например обновлять их при каждом мердже не зависимо от того, сколько элементнов в батче +// if (cur_batch) +// { +// update_weights(); +// } + + Float64 res{0.0}; + for (size_t i = 0; i < predict_feature.size(); ++i) + { + res += predict_feature[i] * weights[i]; + } + res += bias; + res = 1 / (1 + exp(-res)); + return res; + } }; class IWeightsUpdater @@ -95,6 +163,7 @@ public: virtual ~IWeightsUpdater() = default; virtual void update(UInt32 cur_batch, std::vector & weights, Float64 & bias, const std::vector & gradient) = 0; + virtual void merge(const std::shared_ptr, Float64, Float64) {} }; class StochasticGradientDescent : public IWeightsUpdater @@ -108,7 +177,37 @@ public: bias += batch_gradient[weights.size()] / cur_batch; } }; +class Momentum : public IWeightsUpdater +{ +public: + Momentum() {} + Momentum (Float64 alpha) : alpha_(alpha) {} + void update(UInt32 cur_batch, std::vector & weights, Float64 & bias, const std::vector & batch_gradient) override { + if (hk_.size() == 0) + { + hk_.resize(batch_gradient.size(), Float64{0.0}); + } + for (size_t i = 0; i < batch_gradient.size(); ++i) + { + hk_[i] = hk_[i] * alpha_ + batch_gradient[i]; + } + for (size_t i = 0; i < weights.size(); ++i) + { + weights[i] += hk_[i] / cur_batch; + } + bias += hk_[weights.size()] / cur_batch; + } + virtual void merge(const std::shared_ptr rhs, Float64 frac, Float64 rhs_frac) override { + auto momentum_rhs = std::dynamic_pointer_cast(rhs); + for (size_t i = 0; i < hk_.size(); ++i) + { + hk_[i] = hk_[i] * frac + momentum_rhs->hk_[i] * rhs_frac; + } + } +Float64 alpha_{0.1}; +std::vector hk_; +}; class LinearModelData { public: @@ -160,6 +259,7 @@ public: bias = bias * frac + rhs.bias * rhs_frac; iter_num += rhs.iter_num; + weights_updater->merge(rhs.weights_updater, frac, rhs_frac); } void write(WriteBuffer & buf) const @@ -189,14 +289,7 @@ public: // update_weights(); // } - Float64 res{0.0}; - for (size_t i = 0; i < predict_feature.size(); ++i) - { - res += predict_feature[i] * weights[i]; - } - res += bias; - - return res; + return gradient_computer->predict(predict_feature, weights, bias); } private: @@ -316,5 +409,5 @@ private: }; struct NameLinearRegression { static constexpr auto name = "LinearRegression"; }; - +struct NameLogicRegression { static constexpr auto name = "LogicRegression"; }; } diff --git a/dbms/src/Columns/ColumnAggregateFunction.cpp b/dbms/src/Columns/ColumnAggregateFunction.cpp index efa24fc56ba..c60060f1f79 100644 --- a/dbms/src/Columns/ColumnAggregateFunction.cpp +++ b/dbms/src/Columns/ColumnAggregateFunction.cpp @@ -123,19 +123,27 @@ MutableColumnPtr ColumnAggregateFunction::predictValues(Block & block, const Col } // auto ML_function = typeid_cast *>(func.get()); - auto ML_function = typeid_cast *>(func.get()); - if (ML_function) + auto ML_function_Linear = typeid_cast *>(func.get()); + auto ML_function_Logic = typeid_cast *>(func.get()); + if (ML_function_Linear) { size_t row_num = 0; for (auto val : data) { - ML_function->predictResultInto(val, *res, block, row_num, arguments); + ML_function_Linear->predictResultInto(val, *res, block, row_num, arguments); ++row_num; } - } else { + } else if (ML_function_Logic) + { + size_t row_num = 0; + for (auto val : data) { + ML_function_Logic->predictResultInto(val, *res, block, row_num, arguments); + ++row_num; + } + } else + { throw Exception("Illegal aggregate function is passed", ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT); } - return res; } From 243a68d500ad5cb63271eabdedf23b71b7b67ac3 Mon Sep 17 00:00:00 2001 From: Masha Date: Mon, 28 Jan 2019 10:51:33 +0000 Subject: [PATCH 010/709] tests for momentum and logreg --- .../tests/queries/0_stateless/00900_stest.sql | 48 +++++++++++++++++++ .../queries/0_stateless/00901_mytest.sql | 46 ++++++++++++++++++ 2 files changed, 94 insertions(+) create mode 100644 dbms/tests/queries/0_stateless/00900_stest.sql create mode 100644 dbms/tests/queries/0_stateless/00901_mytest.sql diff --git a/dbms/tests/queries/0_stateless/00900_stest.sql b/dbms/tests/queries/0_stateless/00900_stest.sql new file mode 100644 index 00000000000..0a0acfdee11 --- /dev/null +++ b/dbms/tests/queries/0_stateless/00900_stest.sql @@ -0,0 +1,48 @@ +CREATE DATABASE IF NOT EXISTS test; +DROP TABLE IF EXISTS test.defaults; +CREATE TABLE IF NOT EXISTS test.defaults +( + param1 Float64, + param2 Float64, + target Float64, + predict1 Float64, + predict2 Float64 +) ENGINE = Memory; +-- -- insert into test.defaults values (2.533, 0.543, 3.181), (1.999, 1.765, 0.470), (0.631, 2.580, -1.845), (-1.164, 0.889, 0.640), (2.110, 0.768, 2.519), (1.251, 0.483, 2.659), (-3.958, 1.299, -1.576), (-2.152, -1.316, 4.556), (3.269, 1.441, 1.753), (4.206, -1.635, 8.373), (-3.479, -0.544, 2.349), (4.006, 0.167, 4.670), (-4.478, 2.400, -4.039), (1.856, 0.256, 3.417), (1.470, 1.685, 0.366), (-4.052, 2.326, -3.678), (-0.971, -0.969, 4.453), (0.881, -1.848, 7.137), (-1.551, -1.766, 5.756), (-0.988, -0.945, 4.395), (-4.636, 1.074, -1.466), (-4.074, -1.486, 3.934), (0.754, 2.627, -1.877), (1.035, 0.889, 1.738), (3.707, -1.281, 7.415), (-2.215, 1.110, -0.327), (-2.965, -1.316, 4.150), (-3.581, 1.063, -0.917), (0.548, 0.343, 2.588), (3.023, -0.870, 6.251), (4.053, -1.441, 7.909), (-0.750, 0.639, 1.348), (-4.411, 1.636, -2.477), (1.786, 0.398, 3.096), (-2.514, 0.033, 1.676), (4.935, -0.840, 7.148), (1.075, -0.921, 5.380), (-3.418, 2.177, -3.063), (3.122, 1.883, 0.795), (-2.254, -1.389, 4.650), (-4.603, 2.909, -5.119), (-1.886, -1.220, 4.497), (-0.509, -1.498, 5.741), (2.192, 1.882, 0.332), (4.056, -1.108, 7.244), (-1.918, 0.230, 1.581), (4.867, 1.516, 2.401), (-0.993, -0.011, 2.526), (-0.757, -1.192, 5.006), (-4.161, 2.059, -3.198), (2.258, 1.157, 1.814), (-3.878, -0.052, 1.165), (1.915, 2.998, -2.038), (-2.164, 2.379, -2.841), (-0.114, -1.914, 6.772), (3.812, 2.138, 0.630), (-1.863, 1.508, -0.947), (-2.964, 0.398, 0.722), (-2.046, -0.193, 2.363), (-1.525, -0.836, 3.910), (-4.557, -0.582, 1.886), (1.031, -0.461, 4.437), (-0.802, 0.699, 1.201), (3.982, 2.084, 0.824), (-2.243, 2.726, -3.573), (-3.989, -0.803, 2.611), (4.900, 0.253, 4.944), (-1.208, -1.587, 5.571), (0.370, 2.579, -1.972), (2.824, 0.964, 2.484), (-1.290, -0.128, 2.611), (0.190, 2.058, -1.021), (4.058, 2.122, 0.784), (4.879, 0.945, 3.549), (1.119, 1.992, -0.424), (4.050, 2.005, 1.015), (-0.064, 1.485, -0.002), (-2.496, 0.456, 0.840), (-1.835, 1.586, -1.090), (0.603, 1.856, -0.411), (-3.062, -0.966, 3.401), (-3.351, 0.430, 0.465), (-2.724, -1.331, 4.299), (3.291, -1.027, 6.699), (-4.263, 0.785, -0.701), (-3.289, -0.886, 3.128), (4.627, 1.331, 2.651), (-0.618, 0.602, 1.486), (0.056, 1.778, -0.528), (4.823, 1.154, 3.103), (-3.983, 0.509, -0.010), (-4.474, -1.400, 3.563), (-3.782, 2.996, -4.883), (4.515, -0.656, 6.569), (1.269, 2.592, -1.549), (-1.710, -0.241, 2.627), (2.171, 1.453, 1.180), (-1.931, -1.845, 5.726), (1.767, -1.798, 7.480), (4.352, 2.369, 0.438), (-4.498, 2.611, -4.472), (0.067, 0.517, 2.000), (4.151, 0.624, 3.827), (0.409, -0.969, 5.142), (0.193, -1.713, 6.522), (-2.487, 2.827, -3.898), (-4.363, 2.011, -3.203), (-2.383, 2.554, -3.299), (-4.457, -0.958, 2.687), (3.342, -0.360, 5.392), (0.902, 2.978, -2.505), (4.073, -1.524, 8.084), (3.036, 1.672, 1.173), (2.169, -0.564, 5.213), (-4.780, 0.962, -1.313), (-1.815, 2.096, -2.100), (-1.445, 0.458, 1.362), (1.891, -1.437, 6.820), (1.942, -1.761, 7.493), (-4.613, -1.551, 3.795), (-3.472, -1.110, 3.485), (-2.026, 1.961, -1.935), (0.091, -0.961, 4.967), (3.902, -1.336, 7.622), (-3.483, -0.769, 2.796), (-0.066, -1.233, 5.433), (2.597, 2.789, -1.280), (-1.657, -1.842, 5.856), (0.232, -1.420, 5.957), (-3.321, 1.609, -1.879), (2.673, 2.781, -1.226), (0.869, 0.072, 3.291), (1.444, -1.271, 6.264), (1.190, 1.460, 0.675), (3.497, 0.870, 3.008), (-2.884, -1.303, 4.163), (3.620, 0.381, 4.047), (2.594, 0.247, 3.803), (-3.902, -1.315, 3.678), (-4.753, -1.005, 2.634), (0.881, 0.675, 2.091), (0.414, 2.071, -0.935), (3.458, -0.920, 6.568), (-2.986, -0.411, 2.329), (3.076, -1.960, 8.458), (2.951, 2.988, -1.501), (2.408, 1.301, 1.603), (4.725, 0.366, 4.631), (4.924, -1.762, 8.985), (3.719, 0.970, 2.920), (-0.295, 0.257, 2.340), (-4.607, 2.548, -4.400), (0.288, 1.953, -0.761), (-3.311, 0.844, -0.344), (3.679, -0.642, 6.123), (-2.310, -0.838, 3.522), (-4.397, -0.226, 1.254), (-4.366, -0.024, 0.864), (2.405, 1.458, 1.286), (-4.296, -1.071, 2.994), (0.452, -1.901, 7.028), (-0.214, -0.467, 3.827), (2.559, 1.547, 1.185), (0.990, 1.539, 0.417), (0.478, -0.089, 3.417), (-2.734, -1.007, 3.646), (3.483, 0.247, 4.247), (3.507, 2.727, -0.701), (-4.399, 2.437, -4.073), (3.785, 0.036, 4.820), (-0.824, 2.417, -2.245), (-2.588, 0.369, 0.968), (-3.037, -1.639, 4.759), (4.531, -0.499, 6.264), (4.742, -1.161, 7.693), (-0.063, -0.595, 4.159), (0.697, 2.281, -1.212), (0.413, 0.607, 1.992), (-4.081, 0.383, 0.194), (0.712, 2.638, -1.920), (-1.620, 1.092, 0.006), (-3.425, -0.911, 3.109), (-0.124, 1.711, -0.484), (4.347, 1.387, 2.399), (-3.237, -0.900, 3.182), (-3.961, 0.358, 0.304), (4.326, -0.068, 5.298), (3.846, 1.725, 1.473), (-2.089, 0.953, 0.049), (-1.025, -1.470, 5.428), (2.061, -0.156, 4.343), (1.547, -1.827, 7.427), (2.786, 0.460, 3.473), (0.076, 0.659, 1.720), (3.597, 1.966, 0.866), (-0.933, -1.180, 4.894), (4.647, 1.190, 2.943), (-0.032, 0.544, 1.896), (4.461, -1.806, 8.843), (-0.586, 1.821, -0.934), (3.725, 1.715, 1.432), (-2.091, 2.714, -3.474), (4.494, -1.494, 8.236), (3.766, -0.209, 5.301), (-1.991, 1.776, -1.548), (-4.992, -0.742, 1.989), (-2.400, 1.828, -1.855), (-1.329, 0.143, 2.050), (1.954, 1.759, 0.459), (-4.422, 1.507, -2.224), (-2.243, -1.126, 4.131), (4.417, -1.080, 7.368), (1.737, -1.144, 6.157), (2.661, -1.084, 6.498), (-3.198, 0.443, 0.515), (4.191, -1.250, 7.596), (-2.419, -0.163, 2.116), (1.910, -1.173, 6.301), (-0.241, 1.902, -0.925), (-4.415, 2.479, -4.165), (3.307, -0.465, 5.583), (-2.382, 1.364, -0.920), (-3.154, 2.953, -4.483), (-2.562, 2.803, -3.888), (3.076, 0.195, 4.149), (-0.101, 0.896, 1.157), (-2.067, 1.120, -0.273), (-4.680, 2.756, -4.851), (-4.283, -0.607, 2.072), (4.013, -1.072, 7.150), (-4.401, -0.896, 2.591), (4.544, 2.498, 0.276), (4.075, -1.204, 7.445), (-3.463, 1.242, -1.216), (3.992, 2.782, -0.568), (-4.503, 0.239, 0.270), (-3.095, 1.161, -0.870), (0.768, -0.904, 5.192), (1.255, 2.870, -2.112), (-1.537, -0.049, 2.330), (2.851, -1.182, 6.789), (1.974, -0.922, 5.832), (4.447, 2.719, -0.214), (-3.413, 0.555, 0.184), (4.943, 2.120, 1.231), (3.645, -0.413, 5.648), (-4.776, 0.079, 0.453), (1.991, 1.565, 0.866), (2.413, 1.793, 0.620), (4.245, 2.663, -0.205), (-2.022, -1.180, 4.350), (-2.285, -1.246, 4.350), (2.276, 0.488, 3.162), (2.582, -0.037, 4.365), (-4.875, 1.468, -2.374), (-2.492, 2.730, -3.706), (2.696, -1.833, 8.013), (4.618, -1.127, 7.563), (-4.156, 0.987, -1.053), (1.873, -1.566, 7.068), (1.699, 0.794, 2.262), (-3.181, 1.640, -1.871), (-3.225, 1.526, -1.664), (-2.679, -1.811, 5.281), (3.717, 1.532, 1.794), (1.288, -0.999, 5.642), (-1.057, 0.044, 2.384), (-0.147, 1.108, 0.711), (-3.827, -1.139, 3.365), (0.872, -1.482, 6.399), (1.982, 0.286, 3.418), (-1.381, 2.374, -2.439), (-1.091, 2.010, -1.565), (-1.192, 2.751, -3.097), (1.468, -0.992, 5.718), (2.249, 0.949, 2.228), (3.064, 0.911, 2.711), (-1.576, -1.584, 5.380), (2.130, -1.489, 7.043), (4.386, -1.284, 7.761), (1.662, -1.645, 7.121), (-3.395, 1.784, -2.265), (4.618, 1.951, 1.406), (-0.299, 0.378, 2.095), (-2.911, 2.131, -2.717), (0.876, 2.869, -2.301), (-1.785, 0.961, 0.186), (-4.188, 2.442, -3.977), (-1.128, 0.127, 2.181), (1.755, -1.215, 6.307), (-2.276, 0.596, 0.669), (-4.630, 1.978, -3.272), (-0.454, 0.275, 2.224), (-1.950, -1.385, 4.794), (-0.889, 2.696, -2.837), (-4.832, -0.038, 0.661), (3.738, 0.604, 3.662), (-0.224, -0.465, 3.819); +insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0), (-1.099, 2.755, -3.060, 20.0, 40.0), (1.090, 2.945, -2.346, 20.0, 40.0), (0.305, 2.179, -1.205, 20.0, 40.0), (-0.925, 0.702, 1.134, 20.0, 40.0), (3.178, -1.316, 7.221, 20.0, 40.0), (-2.756, -0.473, 2.569, 20.0, 40.0), (3.665, 2.303, 0.226, 20.0, 40.0), (1.662, 1.951, -0.070, 20.0, 40.0), (2.869, 0.593, 3.249, 20.0, 40.0), (0.818, -0.593, 4.594, 20.0, 40.0), (-1.917, 0.916, 0.209, 20.0, 40.0), (2.706, 1.523, 1.307, 20.0, 40.0), (0.219, 2.162, -1.214, 20.0, 40.0), (-4.510, 1.376, -2.007, 20.0, 40.0), (4.284, -0.515, 6.173, 20.0, 40.0), (-1.101, 2.810, -3.170, 20.0, 40.0), (-1.810, -1.117, 4.329, 20.0, 40.0), (0.055, 1.115, 0.797, 20.0, 40.0), (-2.178, 2.904, -3.898, 20.0, 40.0), (-3.494, -1.814, 4.882, 20.0, 40.0), (3.027, 0.476, 3.562, 20.0, 40.0), (-1.434, 1.151, -0.018, 20.0, 40.0), (1.180, 0.992, 1.606, 20.0, 40.0), (0.015, 0.971, 1.067, 20.0, 40.0), (-0.511, -0.875, 4.495, 20.0, 40.0), (0.961, 2.348, -1.216, 20.0, 40.0), (-2.279, 0.038, 1.785, 20.0, 40.0), (-1.568, -0.248, 2.712, 20.0, 40.0), (-0.496, 0.366, 2.020, 20.0, 40.0), (1.177, -1.401, 6.390, 20.0, 40.0), (2.882, -1.442, 7.325, 20.0, 40.0), (-1.066, 1.817, -1.167, 20.0, 40.0), (-2.144, 2.791, -3.655, 20.0, 40.0), (-4.370, 2.228, -3.642, 20.0, 40.0), (3.996, 2.775, -0.553, 20.0, 40.0), (0.289, 2.055, -0.965, 20.0, 40.0), (-0.588, -1.601, 5.908, 20.0, 40.0), (-1.801, 0.417, 1.265, 20.0, 40.0), (4.375, -1.499, 8.186, 20.0, 40.0), (-2.618, 0.038, 1.615, 20.0, 40.0), (3.616, -0.833, 6.475, 20.0, 40.0), (-4.045, -1.558, 4.094, 20.0, 40.0), (-3.962, 0.636, -0.253, 20.0, 40.0), (3.505, 2.625, -0.497, 20.0, 40.0), (3.029, -0.523, 5.560, 20.0, 40.0), (-3.520, -0.474, 2.188, 20.0, 40.0), (2.430, -1.469, 7.154, 20.0, 40.0), (1.547, -1.654, 7.082, 20.0, 40.0), (-1.370, 0.575, 1.165, 20.0, 40.0), (-1.869, -1.555, 5.176, 20.0, 40.0), (3.536, 2.841, -0.913, 20.0, 40.0), (-3.810, 1.220, -1.344, 20.0, 40.0), (-1.971, 1.462, -0.910, 20.0, 40.0), (-0.243, 0.167, 2.545, 20.0, 40.0), (-1.403, 2.645, -2.991, 20.0, 40.0), (0.532, -0.114, 3.494, 20.0, 40.0), (-1.678, 0.975, 0.212, 20.0, 40.0), (-0.656, 2.140, -1.609, 20.0, 40.0), (1.743, 2.631, -1.390, 20.0, 40.0), (2.586, 2.943, -1.593, 20.0, 40.0), (-0.512, 2.969, -3.195, 20.0, 40.0), (2.283, -0.100, 4.342, 20.0, 40.0), (-4.293, 0.872, -0.890, 20.0, 40.0), (3.411, 1.300, 2.106, 20.0, 40.0), (-0.281, 2.951, -3.042, 20.0, 40.0), (-4.442, 0.384, 0.012, 20.0, 40.0), (1.194, 1.746, 0.104, 20.0, 40.0), (-1.152, 1.862, -1.300, 20.0, 40.0), (1.362, -1.341, 6.363, 20.0, 40.0), (-4.488, 2.618, -4.481, 20.0, 40.0), (3.419, -0.564, 5.837, 20.0, 40.0), (-3.392, 0.396, 0.512, 20.0, 40.0), (-1.629, -0.909, 4.003, 20.0, 40.0), (4.447, -1.088, 7.399, 20.0, 40.0), (-1.232, 1.699, -1.014, 20.0, 40.0), (-1.286, -0.609, 3.575, 20.0, 40.0), (2.437, 2.796, -1.374, 20.0, 40.0), (-4.864, 1.989, -3.410, 20.0, 40.0), (-1.716, -1.399, 4.940, 20.0, 40.0), (-3.084, 1.858, -2.259, 20.0, 40.0), (2.828, -0.319, 5.053, 20.0, 40.0), (-1.226, 2.586, -2.786, 20.0, 40.0), (2.456, 0.092, 4.044, 20.0, 40.0), (-0.989, 2.375, -2.245, 20.0, 40.0), (3.268, 0.935, 2.765, 20.0, 40.0), (-4.128, -1.995, 4.927, 20.0, 40.0), (-1.083, 2.197, -1.935, 20.0, 40.0), (-3.471, -1.198, 3.660, 20.0, 40.0), (4.617, -1.136, 7.579, 20.0, 40.0), (2.054, -1.675, 7.378, 20.0, 40.0), (4.106, 2.326, 0.402, 20.0, 40.0), (1.558, 0.310, 3.158, 20.0, 40.0), (0.792, 0.900, 1.596, 20.0, 40.0), (-3.229, 0.300, 0.785, 20.0, 40.0), (3.787, -0.793, 6.479, 20.0, 40.0), (1.786, 2.288, -0.684, 20.0, 40.0), (2.643, 0.223, 3.875, 20.0, 40.0), (-3.592, 2.122, -3.040, 20.0, 40.0), (4.519, -1.760, 8.779, 20.0, 40.0), (3.221, 2.255, 0.101, 20.0, 40.0), (4.151, 1.788, 1.500, 20.0, 40.0), (-1.033, -1.195, 4.874, 20.0, 40.0), (-1.636, -1.037, 4.257, 20.0, 40.0), (-3.548, 1.911, -2.596, 20.0, 40.0), (4.829, -0.293, 6.001, 20.0, 40.0), (-4.684, -1.664, 3.986, 20.0, 40.0), (4.531, -0.503, 6.271, 20.0, 40.0), (-3.503, -1.606, 4.460, 20.0, 40.0), (-2.036, -1.522, 5.027, 20.0, 40.0), (-0.473, -0.617, 3.997, 20.0, 40.0), (-1.554, -1.630, 5.483, 20.0, 40.0), (-3.567, -1.043, 3.302, 20.0, 40.0), (-2.038, 0.579, 0.823, 20.0, 40.0), (-3.040, 0.857, -0.233, 20.0, 40.0), (4.610, 0.562, 4.181, 20.0, 40.0), (-3.323, -1.938, 5.215, 20.0, 40.0), (4.314, 1.720, 1.717, 20.0, 40.0), (-1.220, 0.615, 1.161, 20.0, 40.0), (-2.556, 1.120, -0.519, 20.0, 40.0), (-3.717, -0.108, 1.358, 20.0, 40.0), (4.689, -1.826, 8.996, 20.0, 40.0), (3.452, 0.506, 3.713, 20.0, 40.0), (2.472, 0.612, 3.012, 20.0, 40.0), (3.452, 0.450, 3.826, 20.0, 40.0), (1.207, 2.585, -1.567, 20.0, 40.0), (-4.826, 1.090, -1.593, 20.0, 40.0), (3.116, -1.118, 6.794, 20.0, 40.0), (0.448, 2.732, -2.240, 20.0, 40.0), (-1.096, -0.525, 3.503, 20.0, 40.0), (-4.680, -0.238, 1.137, 20.0, 40.0), (2.552, -1.403, 7.082, 20.0, 40.0), (0.719, 2.997, -2.635, 20.0, 40.0), (0.347, -1.966, 7.105, 20.0, 40.0), (2.958, -0.404, 5.288, 20.0, 40.0), (0.722, -1.950, 7.261, 20.0, 40.0), (-2.851, -0.986, 3.546, 20.0, 40.0), (-4.316, -0.439, 1.721, 20.0, 40.0), (-1.685, -0.201, 2.560, 20.0, 40.0), (1.856, 0.190, 3.549, 20.0, 40.0), (-2.052, 0.206, 1.562, 20.0, 40.0), (-2.504, -0.646, 3.041, 20.0, 40.0), (3.235, 0.882, 2.854, 20.0, 40.0), (-1.366, -1.573, 5.463, 20.0, 40.0), (-3.447, 2.419, -3.562, 20.0, 40.0), (4.155, 2.092, 0.893, 20.0, 40.0), (-0.935, 0.209, 2.116, 20.0, 40.0), (3.117, -1.821, 8.201, 20.0, 40.0), (3.759, 0.577, 3.725, 20.0, 40.0), (-0.938, 2.992, -3.453, 20.0, 40.0), (-0.525, 2.341, -1.945, 20.0, 40.0), (4.540, 2.625, 0.019, 20.0, 40.0), (-2.097, 1.190, -0.429, 20.0, 40.0), (-2.672, 1.983, -2.302, 20.0, 40.0), (-3.038, -1.490, 4.460, 20.0, 40.0), (-0.943, 2.149, -1.770, 20.0, 40.0), (0.739, 1.598, 0.174, 20.0, 40.0), (1.828, 1.853, 0.208, 20.0, 40.0), (4.856, 0.137, 5.153, 20.0, 40.0), (-1.617, 0.468, 1.255, 20.0, 40.0), (-1.972, 2.053, -2.092, 20.0, 40.0), (-4.633, 1.389, -2.094, 20.0, 40.0), (-3.628, -1.156, 3.498, 20.0, 40.0), (3.597, 1.034, 2.731, 20.0, 40.0), (-1.488, -0.002, 2.261, 20.0, 40.0), (0.749, 1.921, -0.468, 20.0, 40.0), (1.304, -1.371, 6.394, 20.0, 40.0), (4.587, 2.936, -0.579, 20.0, 40.0), (-2.241, 1.791, -1.703, 20.0, 40.0), (-2.945, 1.372, -1.216, 20.0, 40.0), (1.375, 0.395, 2.898, 20.0, 40.0), (-1.281, -0.641, 3.642, 20.0, 40.0), (2.178, 0.895, 2.299, 20.0, 40.0), (3.031, -0.786, 6.087, 20.0, 40.0), (-1.385, -0.375, 3.058, 20.0, 40.0), (4.041, -0.431, 5.882, 20.0, 40.0), (0.480, -0.507, 4.254, 20.0, 40.0), (-3.797, 0.140, 0.822, 20.0, 40.0), (2.355, 2.502, -0.827, 20.0, 40.0), (1.376, -1.583, 6.854, 20.0, 40.0), (0.164, 1.405, 0.273, 20.0, 40.0), (-1.273, 1.471, -0.579, 20.0, 40.0), (0.770, 2.246, -1.107, 20.0, 40.0), (4.552, 2.904, -0.533, 20.0, 40.0), (4.259, -1.772, 8.674, 20.0, 40.0), (-0.309, 1.159, 0.528, 20.0, 40.0), (3.581, 2.700, -0.610, 20.0, 40.0), (-3.202, 0.346, 0.707, 20.0, 40.0), (-1.575, 1.242, -0.271, 20.0, 40.0), (-1.584, -0.493, 3.194, 20.0, 40.0), (-3.778, 0.150, 0.810, 20.0, 40.0), (-4.675, 1.749, -2.835, 20.0, 40.0), (3.567, -0.792, 6.367, 20.0, 40.0), (-0.417, 1.399, -0.006, 20.0, 40.0), (-4.672, 2.007, -3.349, 20.0, 40.0), (-1.034, 0.196, 2.090, 20.0, 40.0), (-3.796, 2.496, -3.890, 20.0, 40.0), (3.532, -0.497, 5.759, 20.0, 40.0), (4.868, -1.359, 8.151, 20.0, 40.0), (-0.769, 0.302, 2.011, 20.0, 40.0), (4.475, 2.612, 0.014, 20.0, 40.0), (-3.532, -0.395, 2.024, 20.0, 40.0), (0.322, 0.675, 1.812, 20.0, 40.0), (-2.028, -1.942, 5.870, 20.0, 40.0), (1.810, -1.244, 6.392, 20.0, 40.0), (-0.783, 1.242, 0.124, 20.0, 40.0), (-4.745, -1.300, 3.227, 20.0, 40.0), (1.902, 1.973, 0.005, 20.0, 40.0), (-3.453, -1.429, 4.132, 20.0, 40.0), (1.559, 0.986, 1.808, 20.0, 40.0), (0.128, 2.754, -2.443, 20.0, 40.0), (2.759, 1.727, 0.926, 20.0, 40.0), (-4.468, 1.690, -2.614, 20.0, 40.0), (-2.368, -1.922, 5.659, 20.0, 40.0), (-2.766, 2.128, -2.640, 20.0, 40.0), (0.967, -1.825, 7.133, 20.0, 40.0), (-2.854, 2.855, -4.136, 20.0, 40.0), (-2.944, 1.875, -2.222, 20.0, 40.0), (-2.632, -0.983, 3.649, 20.0, 40.0), (2.427, 2.239, -0.266, 20.0, 40.0), (-1.726, -0.838, 3.812, 20.0, 40.0), (0.007, -0.903, 4.809, 20.0, 40.0), (-2.013, 1.092, -0.191, 20.0, 40.0), (-0.449, 0.970, 0.836, 20.0, 40.0), (1.396, 0.411, 2.876, 20.0, 40.0), (-1.115, -1.790, 6.023, 20.0, 40.0), (3.748, 1.917, 1.039, 20.0, 40.0), (2.978, 1.043, 2.404, 20.0, 40.0), (-3.969, 2.514, -4.013, 20.0, 40.0), (4.455, -0.050, 5.328, 20.0, 40.0), (-3.065, -0.846, 3.160, 20.0, 40.0), (-1.069, 2.167, -1.869, 20.0, 40.0), (3.016, -1.393, 7.294, 20.0, 40.0), (0.045, -1.928, 6.879, 20.0, 40.0), (-2.555, -0.984, 3.690, 20.0, 40.0), (-1.995, -0.054, 2.111, 20.0, 40.0), (4.600, -0.509, 6.318, 20.0, 40.0), (-1.942, 1.215, -0.402, 20.0, 40.0), (1.262, 2.765, -1.899, 20.0, 40.0), (2.617, -1.106, 6.521, 20.0, 40.0), (1.737, 0.554, 2.761, 20.0, 40.0), (-2.197, 0.632, 0.638, 20.0, 40.0), (4.768, 2.618, 0.147, 20.0, 40.0), (-3.737, -0.939, 3.010, 20.0, 40.0), (-2.623, 0.595, 0.499, 20.0, 40.0), (4.752, -0.340, 6.057, 20.0, 40.0), (2.333, -1.037, 6.240, 20.0, 40.0), (4.234, -1.882, 8.881, 20.0, 40.0), (-3.393, -0.812, 2.927, 20.0, 40.0), (0.885, 1.383, 0.678, 20.0, 40.0), (0.123, 2.937, -2.812, 20.0, 40.0), (2.969, 0.760, 2.964, 20.0, 40.0), (-4.929, 1.251, -1.967, 20.0, 40.0), (1.916, 2.223, -0.488, 20.0, 40.0), (-0.020, -1.740, 6.469, 20.0, 40.0), (0.702, -1.272, 5.895, 20.0, 40.0), (2.496, 2.648, -1.048, 20.0, 40.0), (4.067, -1.475, 7.984, 20.0, 40.0), (-3.717, 1.851, -2.561, 20.0, 40.0), (1.678, -0.624, 5.088, 20.0, 40.0), (1.073, 0.695, 2.146, 20.0, 40.0), (1.842, -0.749, 5.419, 20.0, 40.0), (-3.518, 1.909, -2.578, 20.0, 40.0), (2.229, 1.189, 1.737, 20.0, 40.0), (4.987, 2.893, -0.292, 20.0, 40.0), (-4.809, 1.043, -1.490, 20.0, 40.0), (-0.241, -0.728, 4.334, 20.0, 40.0), (-3.331, 0.590, 0.156, 20.0, 40.0), (-0.455, 2.621, -2.470, 20.0, 40.0), (1.492, 1.223, 1.301, 20.0, 40.0), (3.948, 2.841, -0.709, 20.0, 40.0), (0.732, 0.446, 2.475, 20.0, 40.0), (2.400, 2.390, -0.579, 20.0, 40.0), (-2.718, 1.427, -1.213, 20.0, 40.0), (-1.826, 1.451, -0.815, 20.0, 40.0), (1.125, 0.438, 2.686, 20.0, 40.0), (-4.918, 1.880, -3.219, 20.0, 40.0), (3.068, -0.442, 5.418, 20.0, 40.0), (1.982, 1.201, 1.589, 20.0, 40.0), (0.701, -1.709, 6.768, 20.0, 40.0), (-1.496, 2.564, -2.877, 20.0, 40.0), (-3.812, 0.974, -0.853, 20.0, 40.0), (-3.405, 2.018, -2.739, 20.0, 40.0), (2.211, 2.889, -1.674, 20.0, 40.0), (-2.481, 2.931, -4.103, 20.0, 40.0), (-3.721, 2.765, -4.391, 20.0, 40.0), (-1.768, -1.292, 4.699, 20.0, 40.0), (-4.462, 1.058, -1.347, 20.0, 40.0), (-3.516, -1.942, 5.126, 20.0, 40.0), (0.485, 2.420, -1.597, 20.0, 40.0), (-0.492, 0.242, 2.270, 20.0, 40.0), (4.245, 1.689, 1.744, 20.0, 40.0), (2.234, 0.364, 3.389, 20.0, 40.0), (2.629, 2.224, -0.134, 20.0, 40.0), (-4.375, 1.221, -1.630, 20.0, 40.0), (-0.618, 1.374, -0.057, 20.0, 40.0), (-2.580, -1.604, 4.918, 20.0, 40.0), (0.159, 1.104, 0.871, 20.0, 40.0), (-3.597, 0.975, -0.749, 20.0, 40.0); +-- insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0), (-1.099, 2.755, -3.060, 20.0, 40.0), (1.090, 2.945, -2.346, 20.0, 40.0), (0.305, 2.179, -1.205, 20.0, 40.0), (-0.925, 0.702, 1.134, 20.0, 40.0), (3.178, -1.316, 7.221, 20.0, 40.0), (-2.756, -0.473, 2.569, 20.0, 40.0), (3.665, 2.303, 0.226, 20.0, 40.0), (1.662, 1.951, -0.070, 20.0, 40.0), (2.869, 0.593, 3.249, 20.0, 40.0), (0.818, -0.593, 4.594, 20.0, 40.0), (-1.917, 0.916, 0.209, 20.0, 40.0), (2.706, 1.523, 1.307, 20.0, 40.0), (0.219, 2.162, -1.214, 20.0, 40.0), (-4.510, 1.376, -2.007, 20.0, 40.0), (4.284, -0.515, 6.173, 20.0, 40.0), (-1.101, 2.810, -3.170, 20.0, 40.0), (-1.810, -1.117, 4.329, 20.0, 40.0), (0.055, 1.115, 0.797, 20.0, 40.0), (-2.178, 2.904, -3.898, 20.0, 40.0), (-3.494, -1.814, 4.882, 20.0, 40.0), (3.027, 0.476, 3.562, 20.0, 40.0), (-1.434, 1.151, -0.018, 20.0, 40.0), (1.180, 0.992, 1.606, 20.0, 40.0), (0.015, 0.971, 1.067, 20.0, 40.0), (-0.511, -0.875, 4.495, 20.0, 40.0), (0.961, 2.348, -1.216, 20.0, 40.0), (-2.279, 0.038, 1.785, 20.0, 40.0), (-1.568, -0.248, 2.712, 20.0, 40.0), (-0.496, 0.366, 2.020, 20.0, 40.0), (1.177, -1.401, 6.390, 20.0, 40.0), (2.882, -1.442, 7.325, 20.0, 40.0), (-1.066, 1.817, -1.167, 20.0, 40.0), (-2.144, 2.791, -3.655, 20.0, 40.0), (-4.370, 2.228, -3.642, 20.0, 40.0), (3.996, 2.775, -0.553, 20.0, 40.0), (0.289, 2.055, -0.965, 20.0, 40.0), (-0.588, -1.601, 5.908, 20.0, 40.0), (-1.801, 0.417, 1.265, 20.0, 40.0), (4.375, -1.499, 8.186, 20.0, 40.0), (-2.618, 0.038, 1.615, 20.0, 40.0), (3.616, -0.833, 6.475, 20.0, 40.0), (-4.045, -1.558, 4.094, 20.0, 40.0), (-3.962, 0.636, -0.253, 20.0, 40.0), (3.505, 2.625, -0.497, 20.0, 40.0), (3.029, -0.523, 5.560, 20.0, 40.0), (-3.520, -0.474, 2.188, 20.0, 40.0), (2.430, -1.469, 7.154, 20.0, 40.0), (1.547, -1.654, 7.082, 20.0, 40.0), (-1.370, 0.575, 1.165, 20.0, 40.0), (-1.869, -1.555, 5.176, 20.0, 40.0), (3.536, 2.841, -0.913, 20.0, 40.0), (-3.810, 1.220, -1.344, 20.0, 40.0), (-1.971, 1.462, -0.910, 20.0, 40.0), (-0.243, 0.167, 2.545, 20.0, 40.0), (-1.403, 2.645, -2.991, 20.0, 40.0), (0.532, -0.114, 3.494, 20.0, 40.0), (-1.678, 0.975, 0.212, 20.0, 40.0), (-0.656, 2.140, -1.609, 20.0, 40.0), (1.743, 2.631, -1.390, 20.0, 40.0), (2.586, 2.943, -1.593, 20.0, 40.0), (-0.512, 2.969, -3.195, 20.0, 40.0), (2.283, -0.100, 4.342, 20.0, 40.0), (-4.293, 0.872, -0.890, 20.0, 40.0), (3.411, 1.300, 2.106, 20.0, 40.0), (-0.281, 2.951, -3.042, 20.0, 40.0), (-4.442, 0.384, 0.012, 20.0, 40.0), (1.194, 1.746, 0.104, 20.0, 40.0), (-1.152, 1.862, -1.300, 20.0, 40.0), (1.362, -1.341, 6.363, 20.0, 40.0), (-4.488, 2.618, -4.481, 20.0, 40.0), (3.419, -0.564, 5.837, 20.0, 40.0), (-3.392, 0.396, 0.512, 20.0, 40.0), (-1.629, -0.909, 4.003, 20.0, 40.0), (4.447, -1.088, 7.399, 20.0, 40.0), (-1.232, 1.699, -1.014, 20.0, 40.0), (-1.286, -0.609, 3.575, 20.0, 40.0), (2.437, 2.796, -1.374, 20.0, 40.0), (-4.864, 1.989, -3.410, 20.0, 40.0), (-1.716, -1.399, 4.940, 20.0, 40.0), (-3.084, 1.858, -2.259, 20.0, 40.0), (2.828, -0.319, 5.053, 20.0, 40.0), (-1.226, 2.586, -2.786, 20.0, 40.0), (2.456, 0.092, 4.044, 20.0, 40.0), (-0.989, 2.375, -2.245, 20.0, 40.0), (3.268, 0.935, 2.765, 20.0, 40.0), (-4.128, -1.995, 4.927, 20.0, 40.0), (-1.083, 2.197, -1.935, 20.0, 40.0), (-3.471, -1.198, 3.660, 20.0, 40.0), (4.617, -1.136, 7.579, 20.0, 40.0), (2.054, -1.675, 7.378, 20.0, 40.0), (4.106, 2.326, 0.402, 20.0, 40.0), (1.558, 0.310, 3.158, 20.0, 40.0), (0.792, 0.900, 1.596, 20.0, 40.0), (-3.229, 0.300, 0.785, 20.0, 40.0), (3.787, -0.793, 6.479, 20.0, 40.0), (1.786, 2.288, -0.684, 20.0, 40.0), (2.643, 0.223, 3.875, 20.0, 40.0), (-3.592, 2.122, -3.040, 20.0, 40.0), (4.519, -1.760, 8.779, 20.0, 40.0), (3.221, 2.255, 0.101, 20.0, 40.0), (4.151, 1.788, 1.500, 20.0, 40.0), (-1.033, -1.195, 4.874, 20.0, 40.0), (-1.636, -1.037, 4.257, 20.0, 40.0), (-3.548, 1.911, -2.596, 20.0, 40.0), (4.829, -0.293, 6.001, 20.0, 40.0), (-4.684, -1.664, 3.986, 20.0, 40.0), (4.531, -0.503, 6.271, 20.0, 40.0), (-3.503, -1.606, 4.460, 20.0, 40.0), (-2.036, -1.522, 5.027, 20.0, 40.0), (-0.473, -0.617, 3.997, 20.0, 40.0), (-1.554, -1.630, 5.483, 20.0, 40.0), (-3.567, -1.043, 3.302, 20.0, 40.0), (-2.038, 0.579, 0.823, 20.0, 40.0), (-3.040, 0.857, -0.233, 20.0, 40.0), (4.610, 0.562, 4.181, 20.0, 40.0), (-3.323, -1.938, 5.215, 20.0, 40.0), (4.314, 1.720, 1.717, 20.0, 40.0), (-1.220, 0.615, 1.161, 20.0, 40.0), (-2.556, 1.120, -0.519, 20.0, 40.0), (-3.717, -0.108, 1.358, 20.0, 40.0), (4.689, -1.826, 8.996, 20.0, 40.0), (3.452, 0.506, 3.713, 20.0, 40.0), (2.472, 0.612, 3.012, 20.0, 40.0), (3.452, 0.450, 3.826, 20.0, 40.0), (1.207, 2.585, -1.567, 20.0, 40.0), (-4.826, 1.090, -1.593, 20.0, 40.0), (3.116, -1.118, 6.794, 20.0, 40.0), (0.448, 2.732, -2.240, 20.0, 40.0), (-1.096, -0.525, 3.503, 20.0, 40.0), (-4.680, -0.238, 1.137, 20.0, 40.0), (2.552, -1.403, 7.082, 20.0, 40.0), (0.719, 2.997, -2.635, 20.0, 40.0), (0.347, -1.966, 7.105, 20.0, 40.0), (2.958, -0.404, 5.288, 20.0, 40.0), (0.722, -1.950, 7.261, 20.0, 40.0), (-2.851, -0.986, 3.546, 20.0, 40.0), (-4.316, -0.439, 1.721, 20.0, 40.0), (-1.685, -0.201, 2.560, 20.0, 40.0), (1.856, 0.190, 3.549, 20.0, 40.0), (-2.052, 0.206, 1.562, 20.0, 40.0), (-2.504, -0.646, 3.041, 20.0, 40.0), (3.235, 0.882, 2.854, 20.0, 40.0), (-1.366, -1.573, 5.463, 20.0, 40.0), (-3.447, 2.419, -3.562, 20.0, 40.0), (4.155, 2.092, 0.893, 20.0, 40.0), (-0.935, 0.209, 2.116, 20.0, 40.0), (3.117, -1.821, 8.201, 20.0, 40.0), (3.759, 0.577, 3.725, 20.0, 40.0), (-0.938, 2.992, -3.453, 20.0, 40.0), (-0.525, 2.341, -1.945, 20.0, 40.0), (4.540, 2.625, 0.019, 20.0, 40.0), (-2.097, 1.190, -0.429, 20.0, 40.0), (-2.672, 1.983, -2.302, 20.0, 40.0), (-3.038, -1.490, 4.460, 20.0, 40.0), (-0.943, 2.149, -1.770, 20.0, 40.0), (0.739, 1.598, 0.174, 20.0, 40.0), (1.828, 1.853, 0.208, 20.0, 40.0), (4.856, 0.137, 5.153, 20.0, 40.0), (-1.617, 0.468, 1.255, 20.0, 40.0), (-1.972, 2.053, -2.092, 20.0, 40.0), (-4.633, 1.389, -2.094, 20.0, 40.0), (-3.628, -1.156, 3.498, 20.0, 40.0), (3.597, 1.034, 2.731, 20.0, 40.0), (-1.488, -0.002, 2.261, 20.0, 40.0), (0.749, 1.921, -0.468, 20.0, 40.0), (1.304, -1.371, 6.394, 20.0, 40.0), (4.587, 2.936, -0.579, 20.0, 40.0), (-2.241, 1.791, -1.703, 20.0, 40.0), (-2.945, 1.372, -1.216, 20.0, 40.0), (1.375, 0.395, 2.898, 20.0, 40.0), (-1.281, -0.641, 3.642, 20.0, 40.0), (2.178, 0.895, 2.299, 20.0, 40.0), (3.031, -0.786, 6.087, 20.0, 40.0), (-1.385, -0.375, 3.058, 20.0, 40.0), (4.041, -0.431, 5.882, 20.0, 40.0), (0.480, -0.507, 4.254, 20.0, 40.0), (-3.797, 0.140, 0.822, 20.0, 40.0), (2.355, 2.502, -0.827, 20.0, 40.0), (1.376, -1.583, 6.854, 20.0, 40.0), (0.164, 1.405, 0.273, 20.0, 40.0), (-1.273, 1.471, -0.579, 20.0, 40.0), (0.770, 2.246, -1.107, 20.0, 40.0), (4.552, 2.904, -0.533, 20.0, 40.0), (4.259, -1.772, 8.674, 20.0, 40.0), (-0.309, 1.159, 0.528, 20.0, 40.0), (3.581, 2.700, -0.610, 20.0, 40.0), (-3.202, 0.346, 0.707, 20.0, 40.0), (-1.575, 1.242, -0.271, 20.0, 40.0), (-1.584, -0.493, 3.194, 20.0, 40.0), (-3.778, 0.150, 0.810, 20.0, 40.0), (-4.675, 1.749, -2.835, 20.0, 40.0), (3.567, -0.792, 6.367, 20.0, 40.0), (-0.417, 1.399, -0.006, 20.0, 40.0), (-4.672, 2.007, -3.349, 20.0, 40.0), (-1.034, 0.196, 2.090, 20.0, 40.0), (-3.796, 2.496, -3.890, 20.0, 40.0), (3.532, -0.497, 5.759, 20.0, 40.0), (4.868, -1.359, 8.151, 20.0, 40.0), (-0.769, 0.302, 2.011, 20.0, 40.0), (4.475, 2.612, 0.014, 20.0, 40.0), (-3.532, -0.395, 2.024, 20.0, 40.0), (0.322, 0.675, 1.812, 20.0, 40.0), (-2.028, -1.942, 5.870, 20.0, 40.0), (1.810, -1.244, 6.392, 20.0, 40.0), (-0.783, 1.242, 0.124, 20.0, 40.0), (-4.745, -1.300, 3.227, 20.0, 40.0), (1.902, 1.973, 0.005, 20.0, 40.0), (-3.453, -1.429, 4.132, 20.0, 40.0), (1.559, 0.986, 1.808, 20.0, 40.0), (0.128, 2.754, -2.443, 20.0, 40.0), (2.759, 1.727, 0.926, 20.0, 40.0), (-4.468, 1.690, -2.614, 20.0, 40.0), (-2.368, -1.922, 5.659, 20.0, 40.0), (-2.766, 2.128, -2.640, 20.0, 40.0), (0.967, -1.825, 7.133, 20.0, 40.0), (-2.854, 2.855, -4.136, 20.0, 40.0), (-2.944, 1.875, -2.222, 20.0, 40.0), (-2.632, -0.983, 3.649, 20.0, 40.0), (2.427, 2.239, -0.266, 20.0, 40.0), (-1.726, -0.838, 3.812, 20.0, 40.0), (0.007, -0.903, 4.809, 20.0, 40.0), (-2.013, 1.092, -0.191, 20.0, 40.0), (-0.449, 0.970, 0.836, 20.0, 40.0), (1.396, 0.411, 2.876, 20.0, 40.0), (-1.115, -1.790, 6.023, 20.0, 40.0), (3.748, 1.917, 1.039, 20.0, 40.0), (2.978, 1.043, 2.404, 20.0, 40.0), (-3.969, 2.514, -4.013, 20.0, 40.0), (4.455, -0.050, 5.328, 20.0, 40.0), (-3.065, -0.846, 3.160, 20.0, 40.0), (-1.069, 2.167, -1.869, 20.0, 40.0), (3.016, -1.393, 7.294, 20.0, 40.0), (0.045, -1.928, 6.879, 20.0, 40.0), (-2.555, -0.984, 3.690, 20.0, 40.0), (-1.995, -0.054, 2.111, 20.0, 40.0), (4.600, -0.509, 6.318, 20.0, 40.0), (-1.942, 1.215, -0.402, 20.0, 40.0), (1.262, 2.765, -1.899, 20.0, 40.0), (2.617, -1.106, 6.521, 20.0, 40.0), (1.737, 0.554, 2.761, 20.0, 40.0), (-2.197, 0.632, 0.638, 20.0, 40.0), (4.768, 2.618, 0.147, 20.0, 40.0), (-3.737, -0.939, 3.010, 20.0, 40.0), (-2.623, 0.595, 0.499, 20.0, 40.0), (4.752, -0.340, 6.057, 20.0, 40.0), (2.333, -1.037, 6.240, 20.0, 40.0), (4.234, -1.882, 8.881, 20.0, 40.0), (-3.393, -0.812, 2.927, 20.0, 40.0), (0.885, 1.383, 0.678, 20.0, 40.0), (0.123, 2.937, -2.812, 20.0, 40.0), (2.969, 0.760, 2.964, 20.0, 40.0), (-4.929, 1.251, -1.967, 20.0, 40.0), (1.916, 2.223, -0.488, 20.0, 40.0), (-0.020, -1.740, 6.469, 20.0, 40.0), (0.702, -1.272, 5.895, 20.0, 40.0), (2.496, 2.648, -1.048, 20.0, 40.0), (4.067, -1.475, 7.984, 20.0, 40.0), (-3.717, 1.851, -2.561, 20.0, 40.0), (1.678, -0.624, 5.088, 20.0, 40.0), (1.073, 0.695, 2.146, 20.0, 40.0), (1.842, -0.749, 5.419, 20.0, 40.0), (-3.518, 1.909, -2.578, 20.0, 40.0), (2.229, 1.189, 1.737, 20.0, 40.0), (4.987, 2.893, -0.292, 20.0, 40.0), (-4.809, 1.043, -1.490, 20.0, 40.0), (-0.241, -0.728, 4.334, 20.0, 40.0), (-3.331, 0.590, 0.156, 20.0, 40.0), (-0.455, 2.621, -2.470, 20.0, 40.0), (1.492, 1.223, 1.301, 20.0, 40.0), (3.948, 2.841, -0.709, 20.0, 40.0), (0.732, 0.446, 2.475, 20.0, 40.0), (2.400, 2.390, -0.579, 20.0, 40.0), (-2.718, 1.427, -1.213, 20.0, 40.0), (-1.826, 1.451, -0.815, 20.0, 40.0), (1.125, 0.438, 2.686, 20.0, 40.0), (-4.918, 1.880, -3.219, 20.0, 40.0), (3.068, -0.442, 5.418, 20.0, 40.0), (1.982, 1.201, 1.589, 20.0, 40.0), (0.701, -1.709, 6.768, 20.0, 40.0), (-1.496, 2.564, -2.877, 20.0, 40.0), (-3.812, 0.974, -0.853, 20.0, 40.0), (-3.405, 2.018, -2.739, 20.0, 40.0), (2.211, 2.889, -1.674, 20.0, 40.0), (-2.481, 2.931, -4.103, 20.0, 40.0), (-3.721, 2.765, -4.391, 20.0, 40.0), (-1.768, -1.292, 4.699, 20.0, 40.0), (-4.462, 1.058, -1.347, 20.0, 40.0), (-3.516, -1.942, 5.126, 20.0, 40.0), (0.485, 2.420, -1.597, 20.0, 40.0), (-0.492, 0.242, 2.270, 20.0, 40.0), (4.245, 1.689, 1.744, 20.0, 40.0), (2.234, 0.364, 3.389, 20.0, 40.0), (2.629, 2.224, -0.134, 20.0, 40.0), (-4.375, 1.221, -1.630, 20.0, 40.0), (-0.618, 1.374, -0.057, 20.0, 40.0), (-2.580, -1.604, 4.918, 20.0, 40.0), (0.159, 1.104, 0.871, 20.0, 40.0), (-3.597, 0.975, -0.749, 20.0, 40.0); +-- +DROP TABLE IF EXISTS test.model; +create table test.model engine = Memory as select LinearRegressionState(0.1, 5, 2.0)(target, param1, param2) as state from test.defaults; +-- -- select toTypeName(state) from test.model; +-- -- +-- -- DROP TABLE IF EXISTS test.tests; +-- -- CREATE TABLE IF NOT EXISTS test.tests +-- -- ( +-- -- predict1 Float64, +-- -- predict2 Float64, +-- -- state1 AggregateFunction(LinReg(0.01), Float64, Float64, Float64) +-- -- ) ENGINE = Memory; +-- -- insert into test.tests select 20.0, 40.0, LinRegState(0.01)(target, param1, param2) from test.defaults; +-- -- select evalLinReg(state1, predict1, predict2) from test.tests; +-- +-- +-- +-- -- DROP TABLE IF EXISTS test.prediction; +-- -- CREATE TABLE IF NOT EXISTS test.prediction +-- -- ( +-- -- predict1 Float64, +-- -- predict2 Float64 +-- -- ) ENGINE = Memory; +-- +-- +-- -- insert into test.prediction values (20.0, 40.0); +-- +-- -- select multiply(param1, param2) from test.defaults; +-- +-- -- select evalLinReg(LinRegState(0.01)(target, param1, param2), 20.0, 40.0) from test.defaults; +select evalMLMethod(state, predict1, predict2) from test.model cross join test.defaults; +-- -- select evalLinReg(state, predict1, predict2) from test.model inner join (select * from test.tests) using state; +-- -- select evalLinReg(state1, predict1, predict2) from test.tests; +-- +-- -- select negate(target) from test.defaults; diff --git a/dbms/tests/queries/0_stateless/00901_mytest.sql b/dbms/tests/queries/0_stateless/00901_mytest.sql new file mode 100644 index 00000000000..e9278ecb77d --- /dev/null +++ b/dbms/tests/queries/0_stateless/00901_mytest.sql @@ -0,0 +1,46 @@ +CREATE DATABASE IF NOT EXISTS test; +DROP TABLE IF EXISTS test.defaults; +CREATE TABLE IF NOT EXISTS test.defaults +( + param1 Float64, + param2 Float64, + target Float64, + predict1 Float64, + predict2 Float64 +) ENGINE = Memory; +-- -- insert into test.defaults values (2.533, 0.543, 3.181), (1.999, 1.765, 0.470), (0.631, 2.580, -1.845), (-1.164, 0.889, 0.640), (2.110, 0.768, 2.519), (1.251, 0.483, 2.659), (-3.958, 1.299, -1.576), (-2.152, -1.316, 4.556), (3.269, 1.441, 1.753), (4.206, -1.635, 8.373), (-3.479, -0.544, 2.349), (4.006, 0.167, 4.670), (-4.478, 2.400, -4.039), (1.856, 0.256, 3.417), (1.470, 1.685, 0.366), (-4.052, 2.326, -3.678), (-0.971, -0.969, 4.453), (0.881, -1.848, 7.137), (-1.551, -1.766, 5.756), (-0.988, -0.945, 4.395), (-4.636, 1.074, -1.466), (-4.074, -1.486, 3.934), (0.754, 2.627, -1.877), (1.035, 0.889, 1.738), (3.707, -1.281, 7.415), (-2.215, 1.110, -0.327), (-2.965, -1.316, 4.150), (-3.581, 1.063, -0.917), (0.548, 0.343, 2.588), (3.023, -0.870, 6.251), (4.053, -1.441, 7.909), (-0.750, 0.639, 1.348), (-4.411, 1.636, -2.477), (1.786, 0.398, 3.096), (-2.514, 0.033, 1.676), (4.935, -0.840, 7.148), (1.075, -0.921, 5.380), (-3.418, 2.177, -3.063), (3.122, 1.883, 0.795), (-2.254, -1.389, 4.650), (-4.603, 2.909, -5.119), (-1.886, -1.220, 4.497), (-0.509, -1.498, 5.741), (2.192, 1.882, 0.332), (4.056, -1.108, 7.244), (-1.918, 0.230, 1.581), (4.867, 1.516, 2.401), (-0.993, -0.011, 2.526), (-0.757, -1.192, 5.006), (-4.161, 2.059, -3.198), (2.258, 1.157, 1.814), (-3.878, -0.052, 1.165), (1.915, 2.998, -2.038), (-2.164, 2.379, -2.841), (-0.114, -1.914, 6.772), (3.812, 2.138, 0.630), (-1.863, 1.508, -0.947), (-2.964, 0.398, 0.722), (-2.046, -0.193, 2.363), (-1.525, -0.836, 3.910), (-4.557, -0.582, 1.886), (1.031, -0.461, 4.437), (-0.802, 0.699, 1.201), (3.982, 2.084, 0.824), (-2.243, 2.726, -3.573), (-3.989, -0.803, 2.611), (4.900, 0.253, 4.944), (-1.208, -1.587, 5.571), (0.370, 2.579, -1.972), (2.824, 0.964, 2.484), (-1.290, -0.128, 2.611), (0.190, 2.058, -1.021), (4.058, 2.122, 0.784), (4.879, 0.945, 3.549), (1.119, 1.992, -0.424), (4.050, 2.005, 1.015), (-0.064, 1.485, -0.002), (-2.496, 0.456, 0.840), (-1.835, 1.586, -1.090), (0.603, 1.856, -0.411), (-3.062, -0.966, 3.401), (-3.351, 0.430, 0.465), (-2.724, -1.331, 4.299), (3.291, -1.027, 6.699), (-4.263, 0.785, -0.701), (-3.289, -0.886, 3.128), (4.627, 1.331, 2.651), (-0.618, 0.602, 1.486), (0.056, 1.778, -0.528), (4.823, 1.154, 3.103), (-3.983, 0.509, -0.010), (-4.474, -1.400, 3.563), (-3.782, 2.996, -4.883), (4.515, -0.656, 6.569), (1.269, 2.592, -1.549), (-1.710, -0.241, 2.627), (2.171, 1.453, 1.180), (-1.931, -1.845, 5.726), (1.767, -1.798, 7.480), (4.352, 2.369, 0.438), (-4.498, 2.611, -4.472), (0.067, 0.517, 2.000), (4.151, 0.624, 3.827), (0.409, -0.969, 5.142), (0.193, -1.713, 6.522), (-2.487, 2.827, -3.898), (-4.363, 2.011, -3.203), (-2.383, 2.554, -3.299), (-4.457, -0.958, 2.687), (3.342, -0.360, 5.392), (0.902, 2.978, -2.505), (4.073, -1.524, 8.084), (3.036, 1.672, 1.173), (2.169, -0.564, 5.213), (-4.780, 0.962, -1.313), (-1.815, 2.096, -2.100), (-1.445, 0.458, 1.362), (1.891, -1.437, 6.820), (1.942, -1.761, 7.493), (-4.613, -1.551, 3.795), (-3.472, -1.110, 3.485), (-2.026, 1.961, -1.935), (0.091, -0.961, 4.967), (3.902, -1.336, 7.622), (-3.483, -0.769, 2.796), (-0.066, -1.233, 5.433), (2.597, 2.789, -1.280), (-1.657, -1.842, 5.856), (0.232, -1.420, 5.957), (-3.321, 1.609, -1.879), (2.673, 2.781, -1.226), (0.869, 0.072, 3.291), (1.444, -1.271, 6.264), (1.190, 1.460, 0.675), (3.497, 0.870, 3.008), (-2.884, -1.303, 4.163), (3.620, 0.381, 4.047), (2.594, 0.247, 3.803), (-3.902, -1.315, 3.678), (-4.753, -1.005, 2.634), (0.881, 0.675, 2.091), (0.414, 2.071, -0.935), (3.458, -0.920, 6.568), (-2.986, -0.411, 2.329), (3.076, -1.960, 8.458), (2.951, 2.988, -1.501), (2.408, 1.301, 1.603), (4.725, 0.366, 4.631), (4.924, -1.762, 8.985), (3.719, 0.970, 2.920), (-0.295, 0.257, 2.340), (-4.607, 2.548, -4.400), (0.288, 1.953, -0.761), (-3.311, 0.844, -0.344), (3.679, -0.642, 6.123), (-2.310, -0.838, 3.522), (-4.397, -0.226, 1.254), (-4.366, -0.024, 0.864), (2.405, 1.458, 1.286), (-4.296, -1.071, 2.994), (0.452, -1.901, 7.028), (-0.214, -0.467, 3.827), (2.559, 1.547, 1.185), (0.990, 1.539, 0.417), (0.478, -0.089, 3.417), (-2.734, -1.007, 3.646), (3.483, 0.247, 4.247), (3.507, 2.727, -0.701), (-4.399, 2.437, -4.073), (3.785, 0.036, 4.820), (-0.824, 2.417, -2.245), (-2.588, 0.369, 0.968), (-3.037, -1.639, 4.759), (4.531, -0.499, 6.264), (4.742, -1.161, 7.693), (-0.063, -0.595, 4.159), (0.697, 2.281, -1.212), (0.413, 0.607, 1.992), (-4.081, 0.383, 0.194), (0.712, 2.638, -1.920), (-1.620, 1.092, 0.006), (-3.425, -0.911, 3.109), (-0.124, 1.711, -0.484), (4.347, 1.387, 2.399), (-3.237, -0.900, 3.182), (-3.961, 0.358, 0.304), (4.326, -0.068, 5.298), (3.846, 1.725, 1.473), (-2.089, 0.953, 0.049), (-1.025, -1.470, 5.428), (2.061, -0.156, 4.343), (1.547, -1.827, 7.427), (2.786, 0.460, 3.473), (0.076, 0.659, 1.720), (3.597, 1.966, 0.866), (-0.933, -1.180, 4.894), (4.647, 1.190, 2.943), (-0.032, 0.544, 1.896), (4.461, -1.806, 8.843), (-0.586, 1.821, -0.934), (3.725, 1.715, 1.432), (-2.091, 2.714, -3.474), (4.494, -1.494, 8.236), (3.766, -0.209, 5.301), (-1.991, 1.776, -1.548), (-4.992, -0.742, 1.989), (-2.400, 1.828, -1.855), (-1.329, 0.143, 2.050), (1.954, 1.759, 0.459), (-4.422, 1.507, -2.224), (-2.243, -1.126, 4.131), (4.417, -1.080, 7.368), (1.737, -1.144, 6.157), (2.661, -1.084, 6.498), (-3.198, 0.443, 0.515), (4.191, -1.250, 7.596), (-2.419, -0.163, 2.116), (1.910, -1.173, 6.301), (-0.241, 1.902, -0.925), (-4.415, 2.479, -4.165), (3.307, -0.465, 5.583), (-2.382, 1.364, -0.920), (-3.154, 2.953, -4.483), (-2.562, 2.803, -3.888), (3.076, 0.195, 4.149), (-0.101, 0.896, 1.157), (-2.067, 1.120, -0.273), (-4.680, 2.756, -4.851), (-4.283, -0.607, 2.072), (4.013, -1.072, 7.150), (-4.401, -0.896, 2.591), (4.544, 2.498, 0.276), (4.075, -1.204, 7.445), (-3.463, 1.242, -1.216), (3.992, 2.782, -0.568), (-4.503, 0.239, 0.270), (-3.095, 1.161, -0.870), (0.768, -0.904, 5.192), (1.255, 2.870, -2.112), (-1.537, -0.049, 2.330), (2.851, -1.182, 6.789), (1.974, -0.922, 5.832), (4.447, 2.719, -0.214), (-3.413, 0.555, 0.184), (4.943, 2.120, 1.231), (3.645, -0.413, 5.648), (-4.776, 0.079, 0.453), (1.991, 1.565, 0.866), (2.413, 1.793, 0.620), (4.245, 2.663, -0.205), (-2.022, -1.180, 4.350), (-2.285, -1.246, 4.350), (2.276, 0.488, 3.162), (2.582, -0.037, 4.365), (-4.875, 1.468, -2.374), (-2.492, 2.730, -3.706), (2.696, -1.833, 8.013), (4.618, -1.127, 7.563), (-4.156, 0.987, -1.053), (1.873, -1.566, 7.068), (1.699, 0.794, 2.262), (-3.181, 1.640, -1.871), (-3.225, 1.526, -1.664), (-2.679, -1.811, 5.281), (3.717, 1.532, 1.794), (1.288, -0.999, 5.642), (-1.057, 0.044, 2.384), (-0.147, 1.108, 0.711), (-3.827, -1.139, 3.365), (0.872, -1.482, 6.399), (1.982, 0.286, 3.418), (-1.381, 2.374, -2.439), (-1.091, 2.010, -1.565), (-1.192, 2.751, -3.097), (1.468, -0.992, 5.718), (2.249, 0.949, 2.228), (3.064, 0.911, 2.711), (-1.576, -1.584, 5.380), (2.130, -1.489, 7.043), (4.386, -1.284, 7.761), (1.662, -1.645, 7.121), (-3.395, 1.784, -2.265), (4.618, 1.951, 1.406), (-0.299, 0.378, 2.095), (-2.911, 2.131, -2.717), (0.876, 2.869, -2.301), (-1.785, 0.961, 0.186), (-4.188, 2.442, -3.977), (-1.128, 0.127, 2.181), (1.755, -1.215, 6.307), (-2.276, 0.596, 0.669), (-4.630, 1.978, -3.272), (-0.454, 0.275, 2.224), (-1.950, -1.385, 4.794), (-0.889, 2.696, -2.837), (-4.832, -0.038, 0.661), (3.738, 0.604, 3.662), (-0.224, -0.465, 3.819); +-- -- insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0), (-1.099, 2.755, -3.060, 20.0, 40.0), (1.090, 2.945, -2.346, 20.0, 40.0), (0.305, 2.179, -1.205, 20.0, 40.0), (-0.925, 0.702, 1.134, 20.0, 40.0), (3.178, -1.316, 7.221, 20.0, 40.0), (-2.756, -0.473, 2.569, 20.0, 40.0), (3.665, 2.303, 0.226, 20.0, 40.0), (1.662, 1.951, -0.070, 20.0, 40.0), (2.869, 0.593, 3.249, 20.0, 40.0), (0.818, -0.593, 4.594, 20.0, 40.0), (-1.917, 0.916, 0.209, 20.0, 40.0), (2.706, 1.523, 1.307, 20.0, 40.0), (0.219, 2.162, -1.214, 20.0, 40.0), (-4.510, 1.376, -2.007, 20.0, 40.0), (4.284, -0.515, 6.173, 20.0, 40.0), (-1.101, 2.810, -3.170, 20.0, 40.0), (-1.810, -1.117, 4.329, 20.0, 40.0), (0.055, 1.115, 0.797, 20.0, 40.0), (-2.178, 2.904, -3.898, 20.0, 40.0), (-3.494, -1.814, 4.882, 20.0, 40.0), (3.027, 0.476, 3.562, 20.0, 40.0), (-1.434, 1.151, -0.018, 20.0, 40.0), (1.180, 0.992, 1.606, 20.0, 40.0), (0.015, 0.971, 1.067, 20.0, 40.0), (-0.511, -0.875, 4.495, 20.0, 40.0), (0.961, 2.348, -1.216, 20.0, 40.0), (-2.279, 0.038, 1.785, 20.0, 40.0), (-1.568, -0.248, 2.712, 20.0, 40.0), (-0.496, 0.366, 2.020, 20.0, 40.0), (1.177, -1.401, 6.390, 20.0, 40.0), (2.882, -1.442, 7.325, 20.0, 40.0), (-1.066, 1.817, -1.167, 20.0, 40.0), (-2.144, 2.791, -3.655, 20.0, 40.0), (-4.370, 2.228, -3.642, 20.0, 40.0), (3.996, 2.775, -0.553, 20.0, 40.0), (0.289, 2.055, -0.965, 20.0, 40.0), (-0.588, -1.601, 5.908, 20.0, 40.0), (-1.801, 0.417, 1.265, 20.0, 40.0), (4.375, -1.499, 8.186, 20.0, 40.0), (-2.618, 0.038, 1.615, 20.0, 40.0), (3.616, -0.833, 6.475, 20.0, 40.0), (-4.045, -1.558, 4.094, 20.0, 40.0), (-3.962, 0.636, -0.253, 20.0, 40.0), (3.505, 2.625, -0.497, 20.0, 40.0), (3.029, -0.523, 5.560, 20.0, 40.0), (-3.520, -0.474, 2.188, 20.0, 40.0), (2.430, -1.469, 7.154, 20.0, 40.0), (1.547, -1.654, 7.082, 20.0, 40.0), (-1.370, 0.575, 1.165, 20.0, 40.0), (-1.869, -1.555, 5.176, 20.0, 40.0), (3.536, 2.841, -0.913, 20.0, 40.0), (-3.810, 1.220, -1.344, 20.0, 40.0), (-1.971, 1.462, -0.910, 20.0, 40.0), (-0.243, 0.167, 2.545, 20.0, 40.0), (-1.403, 2.645, -2.991, 20.0, 40.0), (0.532, -0.114, 3.494, 20.0, 40.0), (-1.678, 0.975, 0.212, 20.0, 40.0), (-0.656, 2.140, -1.609, 20.0, 40.0), (1.743, 2.631, -1.390, 20.0, 40.0), (2.586, 2.943, -1.593, 20.0, 40.0), (-0.512, 2.969, -3.195, 20.0, 40.0), (2.283, -0.100, 4.342, 20.0, 40.0), (-4.293, 0.872, -0.890, 20.0, 40.0), (3.411, 1.300, 2.106, 20.0, 40.0), (-0.281, 2.951, -3.042, 20.0, 40.0), (-4.442, 0.384, 0.012, 20.0, 40.0), (1.194, 1.746, 0.104, 20.0, 40.0), (-1.152, 1.862, -1.300, 20.0, 40.0), (1.362, -1.341, 6.363, 20.0, 40.0), (-4.488, 2.618, -4.481, 20.0, 40.0), (3.419, -0.564, 5.837, 20.0, 40.0), (-3.392, 0.396, 0.512, 20.0, 40.0), (-1.629, -0.909, 4.003, 20.0, 40.0), (4.447, -1.088, 7.399, 20.0, 40.0), (-1.232, 1.699, -1.014, 20.0, 40.0), (-1.286, -0.609, 3.575, 20.0, 40.0), (2.437, 2.796, -1.374, 20.0, 40.0), (-4.864, 1.989, -3.410, 20.0, 40.0), (-1.716, -1.399, 4.940, 20.0, 40.0), (-3.084, 1.858, -2.259, 20.0, 40.0), (2.828, -0.319, 5.053, 20.0, 40.0), (-1.226, 2.586, -2.786, 20.0, 40.0), (2.456, 0.092, 4.044, 20.0, 40.0), (-0.989, 2.375, -2.245, 20.0, 40.0), (3.268, 0.935, 2.765, 20.0, 40.0), (-4.128, -1.995, 4.927, 20.0, 40.0), (-1.083, 2.197, -1.935, 20.0, 40.0), (-3.471, -1.198, 3.660, 20.0, 40.0), (4.617, -1.136, 7.579, 20.0, 40.0), (2.054, -1.675, 7.378, 20.0, 40.0), (4.106, 2.326, 0.402, 20.0, 40.0), (1.558, 0.310, 3.158, 20.0, 40.0), (0.792, 0.900, 1.596, 20.0, 40.0), (-3.229, 0.300, 0.785, 20.0, 40.0), (3.787, -0.793, 6.479, 20.0, 40.0), (1.786, 2.288, -0.684, 20.0, 40.0), (2.643, 0.223, 3.875, 20.0, 40.0), (-3.592, 2.122, -3.040, 20.0, 40.0), (4.519, -1.760, 8.779, 20.0, 40.0), (3.221, 2.255, 0.101, 20.0, 40.0), (4.151, 1.788, 1.500, 20.0, 40.0), (-1.033, -1.195, 4.874, 20.0, 40.0), (-1.636, -1.037, 4.257, 20.0, 40.0), (-3.548, 1.911, -2.596, 20.0, 40.0), (4.829, -0.293, 6.001, 20.0, 40.0), (-4.684, -1.664, 3.986, 20.0, 40.0), (4.531, -0.503, 6.271, 20.0, 40.0), (-3.503, -1.606, 4.460, 20.0, 40.0), (-2.036, -1.522, 5.027, 20.0, 40.0), (-0.473, -0.617, 3.997, 20.0, 40.0), (-1.554, -1.630, 5.483, 20.0, 40.0), (-3.567, -1.043, 3.302, 20.0, 40.0), (-2.038, 0.579, 0.823, 20.0, 40.0), (-3.040, 0.857, -0.233, 20.0, 40.0), (4.610, 0.562, 4.181, 20.0, 40.0), (-3.323, -1.938, 5.215, 20.0, 40.0), (4.314, 1.720, 1.717, 20.0, 40.0), (-1.220, 0.615, 1.161, 20.0, 40.0), (-2.556, 1.120, -0.519, 20.0, 40.0), (-3.717, -0.108, 1.358, 20.0, 40.0), (4.689, -1.826, 8.996, 20.0, 40.0), (3.452, 0.506, 3.713, 20.0, 40.0), (2.472, 0.612, 3.012, 20.0, 40.0), (3.452, 0.450, 3.826, 20.0, 40.0), (1.207, 2.585, -1.567, 20.0, 40.0), (-4.826, 1.090, -1.593, 20.0, 40.0), (3.116, -1.118, 6.794, 20.0, 40.0), (0.448, 2.732, -2.240, 20.0, 40.0), (-1.096, -0.525, 3.503, 20.0, 40.0), (-4.680, -0.238, 1.137, 20.0, 40.0), (2.552, -1.403, 7.082, 20.0, 40.0), (0.719, 2.997, -2.635, 20.0, 40.0), (0.347, -1.966, 7.105, 20.0, 40.0), (2.958, -0.404, 5.288, 20.0, 40.0), (0.722, -1.950, 7.261, 20.0, 40.0), (-2.851, -0.986, 3.546, 20.0, 40.0), (-4.316, -0.439, 1.721, 20.0, 40.0), (-1.685, -0.201, 2.560, 20.0, 40.0), (1.856, 0.190, 3.549, 20.0, 40.0), (-2.052, 0.206, 1.562, 20.0, 40.0), (-2.504, -0.646, 3.041, 20.0, 40.0), (3.235, 0.882, 2.854, 20.0, 40.0), (-1.366, -1.573, 5.463, 20.0, 40.0), (-3.447, 2.419, -3.562, 20.0, 40.0), (4.155, 2.092, 0.893, 20.0, 40.0), (-0.935, 0.209, 2.116, 20.0, 40.0), (3.117, -1.821, 8.201, 20.0, 40.0), (3.759, 0.577, 3.725, 20.0, 40.0), (-0.938, 2.992, -3.453, 20.0, 40.0), (-0.525, 2.341, -1.945, 20.0, 40.0), (4.540, 2.625, 0.019, 20.0, 40.0), (-2.097, 1.190, -0.429, 20.0, 40.0), (-2.672, 1.983, -2.302, 20.0, 40.0), (-3.038, -1.490, 4.460, 20.0, 40.0), (-0.943, 2.149, -1.770, 20.0, 40.0), (0.739, 1.598, 0.174, 20.0, 40.0), (1.828, 1.853, 0.208, 20.0, 40.0), (4.856, 0.137, 5.153, 20.0, 40.0), (-1.617, 0.468, 1.255, 20.0, 40.0), (-1.972, 2.053, -2.092, 20.0, 40.0), (-4.633, 1.389, -2.094, 20.0, 40.0), (-3.628, -1.156, 3.498, 20.0, 40.0), (3.597, 1.034, 2.731, 20.0, 40.0), (-1.488, -0.002, 2.261, 20.0, 40.0), (0.749, 1.921, -0.468, 20.0, 40.0), (1.304, -1.371, 6.394, 20.0, 40.0), (4.587, 2.936, -0.579, 20.0, 40.0), (-2.241, 1.791, -1.703, 20.0, 40.0), (-2.945, 1.372, -1.216, 20.0, 40.0), (1.375, 0.395, 2.898, 20.0, 40.0), (-1.281, -0.641, 3.642, 20.0, 40.0), (2.178, 0.895, 2.299, 20.0, 40.0), (3.031, -0.786, 6.087, 20.0, 40.0), (-1.385, -0.375, 3.058, 20.0, 40.0), (4.041, -0.431, 5.882, 20.0, 40.0), (0.480, -0.507, 4.254, 20.0, 40.0), (-3.797, 0.140, 0.822, 20.0, 40.0), (2.355, 2.502, -0.827, 20.0, 40.0), (1.376, -1.583, 6.854, 20.0, 40.0), (0.164, 1.405, 0.273, 20.0, 40.0), (-1.273, 1.471, -0.579, 20.0, 40.0), (0.770, 2.246, -1.107, 20.0, 40.0), (4.552, 2.904, -0.533, 20.0, 40.0), (4.259, -1.772, 8.674, 20.0, 40.0), (-0.309, 1.159, 0.528, 20.0, 40.0), (3.581, 2.700, -0.610, 20.0, 40.0), (-3.202, 0.346, 0.707, 20.0, 40.0), (-1.575, 1.242, -0.271, 20.0, 40.0), (-1.584, -0.493, 3.194, 20.0, 40.0), (-3.778, 0.150, 0.810, 20.0, 40.0), (-4.675, 1.749, -2.835, 20.0, 40.0), (3.567, -0.792, 6.367, 20.0, 40.0), (-0.417, 1.399, -0.006, 20.0, 40.0), (-4.672, 2.007, -3.349, 20.0, 40.0), (-1.034, 0.196, 2.090, 20.0, 40.0), (-3.796, 2.496, -3.890, 20.0, 40.0), (3.532, -0.497, 5.759, 20.0, 40.0), (4.868, -1.359, 8.151, 20.0, 40.0), (-0.769, 0.302, 2.011, 20.0, 40.0), (4.475, 2.612, 0.014, 20.0, 40.0), (-3.532, -0.395, 2.024, 20.0, 40.0), (0.322, 0.675, 1.812, 20.0, 40.0), (-2.028, -1.942, 5.870, 20.0, 40.0), (1.810, -1.244, 6.392, 20.0, 40.0), (-0.783, 1.242, 0.124, 20.0, 40.0), (-4.745, -1.300, 3.227, 20.0, 40.0), (1.902, 1.973, 0.005, 20.0, 40.0), (-3.453, -1.429, 4.132, 20.0, 40.0), (1.559, 0.986, 1.808, 20.0, 40.0), (0.128, 2.754, -2.443, 20.0, 40.0), (2.759, 1.727, 0.926, 20.0, 40.0), (-4.468, 1.690, -2.614, 20.0, 40.0), (-2.368, -1.922, 5.659, 20.0, 40.0), (-2.766, 2.128, -2.640, 20.0, 40.0), (0.967, -1.825, 7.133, 20.0, 40.0), (-2.854, 2.855, -4.136, 20.0, 40.0), (-2.944, 1.875, -2.222, 20.0, 40.0), (-2.632, -0.983, 3.649, 20.0, 40.0), (2.427, 2.239, -0.266, 20.0, 40.0), (-1.726, -0.838, 3.812, 20.0, 40.0), (0.007, -0.903, 4.809, 20.0, 40.0), (-2.013, 1.092, -0.191, 20.0, 40.0), (-0.449, 0.970, 0.836, 20.0, 40.0), (1.396, 0.411, 2.876, 20.0, 40.0), (-1.115, -1.790, 6.023, 20.0, 40.0), (3.748, 1.917, 1.039, 20.0, 40.0), (2.978, 1.043, 2.404, 20.0, 40.0), (-3.969, 2.514, -4.013, 20.0, 40.0), (4.455, -0.050, 5.328, 20.0, 40.0), (-3.065, -0.846, 3.160, 20.0, 40.0), (-1.069, 2.167, -1.869, 20.0, 40.0), (3.016, -1.393, 7.294, 20.0, 40.0), (0.045, -1.928, 6.879, 20.0, 40.0), (-2.555, -0.984, 3.690, 20.0, 40.0), (-1.995, -0.054, 2.111, 20.0, 40.0), (4.600, -0.509, 6.318, 20.0, 40.0), (-1.942, 1.215, -0.402, 20.0, 40.0), (1.262, 2.765, -1.899, 20.0, 40.0), (2.617, -1.106, 6.521, 20.0, 40.0), (1.737, 0.554, 2.761, 20.0, 40.0), (-2.197, 0.632, 0.638, 20.0, 40.0), (4.768, 2.618, 0.147, 20.0, 40.0), (-3.737, -0.939, 3.010, 20.0, 40.0), (-2.623, 0.595, 0.499, 20.0, 40.0), (4.752, -0.340, 6.057, 20.0, 40.0), (2.333, -1.037, 6.240, 20.0, 40.0), (4.234, -1.882, 8.881, 20.0, 40.0), (-3.393, -0.812, 2.927, 20.0, 40.0), (0.885, 1.383, 0.678, 20.0, 40.0), (0.123, 2.937, -2.812, 20.0, 40.0), (2.969, 0.760, 2.964, 20.0, 40.0), (-4.929, 1.251, -1.967, 20.0, 40.0), (1.916, 2.223, -0.488, 20.0, 40.0), (-0.020, -1.740, 6.469, 20.0, 40.0), (0.702, -1.272, 5.895, 20.0, 40.0), (2.496, 2.648, -1.048, 20.0, 40.0), (4.067, -1.475, 7.984, 20.0, 40.0), (-3.717, 1.851, -2.561, 20.0, 40.0), (1.678, -0.624, 5.088, 20.0, 40.0), (1.073, 0.695, 2.146, 20.0, 40.0), (1.842, -0.749, 5.419, 20.0, 40.0), (-3.518, 1.909, -2.578, 20.0, 40.0), (2.229, 1.189, 1.737, 20.0, 40.0), (4.987, 2.893, -0.292, 20.0, 40.0), (-4.809, 1.043, -1.490, 20.0, 40.0), (-0.241, -0.728, 4.334, 20.0, 40.0), (-3.331, 0.590, 0.156, 20.0, 40.0), (-0.455, 2.621, -2.470, 20.0, 40.0), (1.492, 1.223, 1.301, 20.0, 40.0), (3.948, 2.841, -0.709, 20.0, 40.0), (0.732, 0.446, 2.475, 20.0, 40.0), (2.400, 2.390, -0.579, 20.0, 40.0), (-2.718, 1.427, -1.213, 20.0, 40.0), (-1.826, 1.451, -0.815, 20.0, 40.0), (1.125, 0.438, 2.686, 20.0, 40.0), (-4.918, 1.880, -3.219, 20.0, 40.0), (3.068, -0.442, 5.418, 20.0, 40.0), (1.982, 1.201, 1.589, 20.0, 40.0), (0.701, -1.709, 6.768, 20.0, 40.0), (-1.496, 2.564, -2.877, 20.0, 40.0), (-3.812, 0.974, -0.853, 20.0, 40.0), (-3.405, 2.018, -2.739, 20.0, 40.0), (2.211, 2.889, -1.674, 20.0, 40.0), (-2.481, 2.931, -4.103, 20.0, 40.0), (-3.721, 2.765, -4.391, 20.0, 40.0), (-1.768, -1.292, 4.699, 20.0, 40.0), (-4.462, 1.058, -1.347, 20.0, 40.0), (-3.516, -1.942, 5.126, 20.0, 40.0), (0.485, 2.420, -1.597, 20.0, 40.0), (-0.492, 0.242, 2.270, 20.0, 40.0), (4.245, 1.689, 1.744, 20.0, 40.0), (2.234, 0.364, 3.389, 20.0, 40.0), (2.629, 2.224, -0.134, 20.0, 40.0), (-4.375, 1.221, -1.630, 20.0, 40.0), (-0.618, 1.374, -0.057, 20.0, 40.0), (-2.580, -1.604, 4.918, 20.0, 40.0), (0.159, 1.104, 0.871, 20.0, 40.0), (-3.597, 0.975, -0.749, 20.0, 40.0); +-- -- insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1) +insert into test.defaults values (1,2,1,1,2), (1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2) +-- insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0), (-1.099, 2.755, -3.060, 20.0, 40.0), (1.090, 2.945, -2.346, 20.0, 40.0), (0.305, 2.179, -1.205, 20.0, 40.0), (-0.925, 0.702, 1.134, 20.0, 40.0), (3.178, -1.316, 7.221, 20.0, 40.0), (-2.756, -0.473, 2.569, 20.0, 40.0), (3.665, 2.303, 0.226, 20.0, 40.0), (1.662, 1.951, -0.070, 20.0, 40.0), (2.869, 0.593, 3.249, 20.0, 40.0), (0.818, -0.593, 4.594, 20.0, 40.0), (-1.917, 0.916, 0.209, 20.0, 40.0), (2.706, 1.523, 1.307, 20.0, 40.0), (0.219, 2.162, -1.214, 20.0, 40.0), (-4.510, 1.376, -2.007, 20.0, 40.0), (4.284, -0.515, 6.173, 20.0, 40.0), (-1.101, 2.810, -3.170, 20.0, 40.0), (-1.810, -1.117, 4.329, 20.0, 40.0), (0.055, 1.115, 0.797, 20.0, 40.0), (-2.178, 2.904, -3.898, 20.0, 40.0), (-3.494, -1.814, 4.882, 20.0, 40.0), (3.027, 0.476, 3.562, 20.0, 40.0), (-1.434, 1.151, -0.018, 20.0, 40.0), (1.180, 0.992, 1.606, 20.0, 40.0), (0.015, 0.971, 1.067, 20.0, 40.0), (-0.511, -0.875, 4.495, 20.0, 40.0), (0.961, 2.348, -1.216, 20.0, 40.0), (-2.279, 0.038, 1.785, 20.0, 40.0), (-1.568, -0.248, 2.712, 20.0, 40.0), (-0.496, 0.366, 2.020, 20.0, 40.0), (1.177, -1.401, 6.390, 20.0, 40.0), (2.882, -1.442, 7.325, 20.0, 40.0), (-1.066, 1.817, -1.167, 20.0, 40.0), (-2.144, 2.791, -3.655, 20.0, 40.0), (-4.370, 2.228, -3.642, 20.0, 40.0), (3.996, 2.775, -0.553, 20.0, 40.0), (0.289, 2.055, -0.965, 20.0, 40.0), (-0.588, -1.601, 5.908, 20.0, 40.0), (-1.801, 0.417, 1.265, 20.0, 40.0), (4.375, -1.499, 8.186, 20.0, 40.0), (-2.618, 0.038, 1.615, 20.0, 40.0), (3.616, -0.833, 6.475, 20.0, 40.0), (-4.045, -1.558, 4.094, 20.0, 40.0), (-3.962, 0.636, -0.253, 20.0, 40.0), (3.505, 2.625, -0.497, 20.0, 40.0), (3.029, -0.523, 5.560, 20.0, 40.0), (-3.520, -0.474, 2.188, 20.0, 40.0), (2.430, -1.469, 7.154, 20.0, 40.0), (1.547, -1.654, 7.082, 20.0, 40.0), (-1.370, 0.575, 1.165, 20.0, 40.0), (-1.869, -1.555, 5.176, 20.0, 40.0), (3.536, 2.841, -0.913, 20.0, 40.0), (-3.810, 1.220, -1.344, 20.0, 40.0), (-1.971, 1.462, -0.910, 20.0, 40.0), (-0.243, 0.167, 2.545, 20.0, 40.0), (-1.403, 2.645, -2.991, 20.0, 40.0), (0.532, -0.114, 3.494, 20.0, 40.0), (-1.678, 0.975, 0.212, 20.0, 40.0), (-0.656, 2.140, -1.609, 20.0, 40.0), (1.743, 2.631, -1.390, 20.0, 40.0), (2.586, 2.943, -1.593, 20.0, 40.0), (-0.512, 2.969, -3.195, 20.0, 40.0), (2.283, -0.100, 4.342, 20.0, 40.0), (-4.293, 0.872, -0.890, 20.0, 40.0), (3.411, 1.300, 2.106, 20.0, 40.0), (-0.281, 2.951, -3.042, 20.0, 40.0), (-4.442, 0.384, 0.012, 20.0, 40.0), (1.194, 1.746, 0.104, 20.0, 40.0), (-1.152, 1.862, -1.300, 20.0, 40.0), (1.362, -1.341, 6.363, 20.0, 40.0), (-4.488, 2.618, -4.481, 20.0, 40.0), (3.419, -0.564, 5.837, 20.0, 40.0), (-3.392, 0.396, 0.512, 20.0, 40.0), (-1.629, -0.909, 4.003, 20.0, 40.0), (4.447, -1.088, 7.399, 20.0, 40.0), (-1.232, 1.699, -1.014, 20.0, 40.0), (-1.286, -0.609, 3.575, 20.0, 40.0), (2.437, 2.796, -1.374, 20.0, 40.0), (-4.864, 1.989, -3.410, 20.0, 40.0), (-1.716, -1.399, 4.940, 20.0, 40.0), (-3.084, 1.858, -2.259, 20.0, 40.0), (2.828, -0.319, 5.053, 20.0, 40.0), (-1.226, 2.586, -2.786, 20.0, 40.0), (2.456, 0.092, 4.044, 20.0, 40.0), (-0.989, 2.375, -2.245, 20.0, 40.0), (3.268, 0.935, 2.765, 20.0, 40.0), (-4.128, -1.995, 4.927, 20.0, 40.0), (-1.083, 2.197, -1.935, 20.0, 40.0), (-3.471, -1.198, 3.660, 20.0, 40.0), (4.617, -1.136, 7.579, 20.0, 40.0), (2.054, -1.675, 7.378, 20.0, 40.0), (4.106, 2.326, 0.402, 20.0, 40.0), (1.558, 0.310, 3.158, 20.0, 40.0), (0.792, 0.900, 1.596, 20.0, 40.0), (-3.229, 0.300, 0.785, 20.0, 40.0), (3.787, -0.793, 6.479, 20.0, 40.0), (1.786, 2.288, -0.684, 20.0, 40.0), (2.643, 0.223, 3.875, 20.0, 40.0), (-3.592, 2.122, -3.040, 20.0, 40.0), (4.519, -1.760, 8.779, 20.0, 40.0), (3.221, 2.255, 0.101, 20.0, 40.0), (4.151, 1.788, 1.500, 20.0, 40.0), (-1.033, -1.195, 4.874, 20.0, 40.0), (-1.636, -1.037, 4.257, 20.0, 40.0), (-3.548, 1.911, -2.596, 20.0, 40.0), (4.829, -0.293, 6.001, 20.0, 40.0), (-4.684, -1.664, 3.986, 20.0, 40.0), (4.531, -0.503, 6.271, 20.0, 40.0), (-3.503, -1.606, 4.460, 20.0, 40.0), (-2.036, -1.522, 5.027, 20.0, 40.0), (-0.473, -0.617, 3.997, 20.0, 40.0), (-1.554, -1.630, 5.483, 20.0, 40.0), (-3.567, -1.043, 3.302, 20.0, 40.0), (-2.038, 0.579, 0.823, 20.0, 40.0), (-3.040, 0.857, -0.233, 20.0, 40.0), (4.610, 0.562, 4.181, 20.0, 40.0), (-3.323, -1.938, 5.215, 20.0, 40.0), (4.314, 1.720, 1.717, 20.0, 40.0), (-1.220, 0.615, 1.161, 20.0, 40.0), (-2.556, 1.120, -0.519, 20.0, 40.0), (-3.717, -0.108, 1.358, 20.0, 40.0), (4.689, -1.826, 8.996, 20.0, 40.0), (3.452, 0.506, 3.713, 20.0, 40.0), (2.472, 0.612, 3.012, 20.0, 40.0), (3.452, 0.450, 3.826, 20.0, 40.0), (1.207, 2.585, -1.567, 20.0, 40.0), (-4.826, 1.090, -1.593, 20.0, 40.0), (3.116, -1.118, 6.794, 20.0, 40.0), (0.448, 2.732, -2.240, 20.0, 40.0), (-1.096, -0.525, 3.503, 20.0, 40.0), (-4.680, -0.238, 1.137, 20.0, 40.0), (2.552, -1.403, 7.082, 20.0, 40.0), (0.719, 2.997, -2.635, 20.0, 40.0), (0.347, -1.966, 7.105, 20.0, 40.0), (2.958, -0.404, 5.288, 20.0, 40.0), (0.722, -1.950, 7.261, 20.0, 40.0), (-2.851, -0.986, 3.546, 20.0, 40.0), (-4.316, -0.439, 1.721, 20.0, 40.0), (-1.685, -0.201, 2.560, 20.0, 40.0), (1.856, 0.190, 3.549, 20.0, 40.0), (-2.052, 0.206, 1.562, 20.0, 40.0), (-2.504, -0.646, 3.041, 20.0, 40.0), (3.235, 0.882, 2.854, 20.0, 40.0), (-1.366, -1.573, 5.463, 20.0, 40.0), (-3.447, 2.419, -3.562, 20.0, 40.0), (4.155, 2.092, 0.893, 20.0, 40.0), (-0.935, 0.209, 2.116, 20.0, 40.0), (3.117, -1.821, 8.201, 20.0, 40.0), (3.759, 0.577, 3.725, 20.0, 40.0), (-0.938, 2.992, -3.453, 20.0, 40.0), (-0.525, 2.341, -1.945, 20.0, 40.0), (4.540, 2.625, 0.019, 20.0, 40.0), (-2.097, 1.190, -0.429, 20.0, 40.0), (-2.672, 1.983, -2.302, 20.0, 40.0), (-3.038, -1.490, 4.460, 20.0, 40.0), (-0.943, 2.149, -1.770, 20.0, 40.0), (0.739, 1.598, 0.174, 20.0, 40.0), (1.828, 1.853, 0.208, 20.0, 40.0), (4.856, 0.137, 5.153, 20.0, 40.0), (-1.617, 0.468, 1.255, 20.0, 40.0), (-1.972, 2.053, -2.092, 20.0, 40.0), (-4.633, 1.389, -2.094, 20.0, 40.0), (-3.628, -1.156, 3.498, 20.0, 40.0), (3.597, 1.034, 2.731, 20.0, 40.0), (-1.488, -0.002, 2.261, 20.0, 40.0), (0.749, 1.921, -0.468, 20.0, 40.0), (1.304, -1.371, 6.394, 20.0, 40.0), (4.587, 2.936, -0.579, 20.0, 40.0), (-2.241, 1.791, -1.703, 20.0, 40.0), (-2.945, 1.372, -1.216, 20.0, 40.0), (1.375, 0.395, 2.898, 20.0, 40.0), (-1.281, -0.641, 3.642, 20.0, 40.0), (2.178, 0.895, 2.299, 20.0, 40.0), (3.031, -0.786, 6.087, 20.0, 40.0), (-1.385, -0.375, 3.058, 20.0, 40.0), (4.041, -0.431, 5.882, 20.0, 40.0), (0.480, -0.507, 4.254, 20.0, 40.0), (-3.797, 0.140, 0.822, 20.0, 40.0), (2.355, 2.502, -0.827, 20.0, 40.0), (1.376, -1.583, 6.854, 20.0, 40.0), (0.164, 1.405, 0.273, 20.0, 40.0), (-1.273, 1.471, -0.579, 20.0, 40.0), (0.770, 2.246, -1.107, 20.0, 40.0), (4.552, 2.904, -0.533, 20.0, 40.0), (4.259, -1.772, 8.674, 20.0, 40.0), (-0.309, 1.159, 0.528, 20.0, 40.0), (3.581, 2.700, -0.610, 20.0, 40.0), (-3.202, 0.346, 0.707, 20.0, 40.0), (-1.575, 1.242, -0.271, 20.0, 40.0), (-1.584, -0.493, 3.194, 20.0, 40.0), (-3.778, 0.150, 0.810, 20.0, 40.0), (-4.675, 1.749, -2.835, 20.0, 40.0), (3.567, -0.792, 6.367, 20.0, 40.0), (-0.417, 1.399, -0.006, 20.0, 40.0), (-4.672, 2.007, -3.349, 20.0, 40.0), (-1.034, 0.196, 2.090, 20.0, 40.0), (-3.796, 2.496, -3.890, 20.0, 40.0), (3.532, -0.497, 5.759, 20.0, 40.0), (4.868, -1.359, 8.151, 20.0, 40.0), (-0.769, 0.302, 2.011, 20.0, 40.0), (4.475, 2.612, 0.014, 20.0, 40.0), (-3.532, -0.395, 2.024, 20.0, 40.0), (0.322, 0.675, 1.812, 20.0, 40.0), (-2.028, -1.942, 5.870, 20.0, 40.0), (1.810, -1.244, 6.392, 20.0, 40.0), (-0.783, 1.242, 0.124, 20.0, 40.0), (-4.745, -1.300, 3.227, 20.0, 40.0), (1.902, 1.973, 0.005, 20.0, 40.0), (-3.453, -1.429, 4.132, 20.0, 40.0), (1.559, 0.986, 1.808, 20.0, 40.0), (0.128, 2.754, -2.443, 20.0, 40.0), (2.759, 1.727, 0.926, 20.0, 40.0), (-4.468, 1.690, -2.614, 20.0, 40.0), (-2.368, -1.922, 5.659, 20.0, 40.0), (-2.766, 2.128, -2.640, 20.0, 40.0), (0.967, -1.825, 7.133, 20.0, 40.0), (-2.854, 2.855, -4.136, 20.0, 40.0), (-2.944, 1.875, -2.222, 20.0, 40.0), (-2.632, -0.983, 3.649, 20.0, 40.0), (2.427, 2.239, -0.266, 20.0, 40.0), (-1.726, -0.838, 3.812, 20.0, 40.0), (0.007, -0.903, 4.809, 20.0, 40.0), (-2.013, 1.092, -0.191, 20.0, 40.0), (-0.449, 0.970, 0.836, 20.0, 40.0), (1.396, 0.411, 2.876, 20.0, 40.0), (-1.115, -1.790, 6.023, 20.0, 40.0), (3.748, 1.917, 1.039, 20.0, 40.0), (2.978, 1.043, 2.404, 20.0, 40.0), (-3.969, 2.514, -4.013, 20.0, 40.0), (4.455, -0.050, 5.328, 20.0, 40.0), (-3.065, -0.846, 3.160, 20.0, 40.0), (-1.069, 2.167, -1.869, 20.0, 40.0), (3.016, -1.393, 7.294, 20.0, 40.0), (0.045, -1.928, 6.879, 20.0, 40.0), (-2.555, -0.984, 3.690, 20.0, 40.0), (-1.995, -0.054, 2.111, 20.0, 40.0), (4.600, -0.509, 6.318, 20.0, 40.0), (-1.942, 1.215, -0.402, 20.0, 40.0), (1.262, 2.765, -1.899, 20.0, 40.0), (2.617, -1.106, 6.521, 20.0, 40.0), (1.737, 0.554, 2.761, 20.0, 40.0), (-2.197, 0.632, 0.638, 20.0, 40.0), (4.768, 2.618, 0.147, 20.0, 40.0), (-3.737, -0.939, 3.010, 20.0, 40.0), (-2.623, 0.595, 0.499, 20.0, 40.0), (4.752, -0.340, 6.057, 20.0, 40.0), (2.333, -1.037, 6.240, 20.0, 40.0), (4.234, -1.882, 8.881, 20.0, 40.0), (-3.393, -0.812, 2.927, 20.0, 40.0), (0.885, 1.383, 0.678, 20.0, 40.0), (0.123, 2.937, -2.812, 20.0, 40.0), (2.969, 0.760, 2.964, 20.0, 40.0), (-4.929, 1.251, -1.967, 20.0, 40.0), (1.916, 2.223, -0.488, 20.0, 40.0), (-0.020, -1.740, 6.469, 20.0, 40.0), (0.702, -1.272, 5.895, 20.0, 40.0), (2.496, 2.648, -1.048, 20.0, 40.0), (4.067, -1.475, 7.984, 20.0, 40.0), (-3.717, 1.851, -2.561, 20.0, 40.0), (1.678, -0.624, 5.088, 20.0, 40.0), (1.073, 0.695, 2.146, 20.0, 40.0), (1.842, -0.749, 5.419, 20.0, 40.0), (-3.518, 1.909, -2.578, 20.0, 40.0), (2.229, 1.189, 1.737, 20.0, 40.0), (4.987, 2.893, -0.292, 20.0, 40.0), (-4.809, 1.043, -1.490, 20.0, 40.0), (-0.241, -0.728, 4.334, 20.0, 40.0), (-3.331, 0.590, 0.156, 20.0, 40.0), (-0.455, 2.621, -2.470, 20.0, 40.0), (1.492, 1.223, 1.301, 20.0, 40.0), (3.948, 2.841, -0.709, 20.0, 40.0), (0.732, 0.446, 2.475, 20.0, 40.0), (2.400, 2.390, -0.579, 20.0, 40.0), (-2.718, 1.427, -1.213, 20.0, 40.0), (-1.826, 1.451, -0.815, 20.0, 40.0), (1.125, 0.438, 2.686, 20.0, 40.0), (-4.918, 1.880, -3.219, 20.0, 40.0), (3.068, -0.442, 5.418, 20.0, 40.0), (1.982, 1.201, 1.589, 20.0, 40.0), (0.701, -1.709, 6.768, 20.0, 40.0), (-1.496, 2.564, -2.877, 20.0, 40.0), (-3.812, 0.974, -0.853, 20.0, 40.0), (-3.405, 2.018, -2.739, 20.0, 40.0), (2.211, 2.889, -1.674, 20.0, 40.0), (-2.481, 2.931, -4.103, 20.0, 40.0), (-3.721, 2.765, -4.391, 20.0, 40.0), (-1.768, -1.292, 4.699, 20.0, 40.0), (-4.462, 1.058, -1.347, 20.0, 40.0), (-3.516, -1.942, 5.126, 20.0, 40.0), (0.485, 2.420, -1.597, 20.0, 40.0), (-0.492, 0.242, 2.270, 20.0, 40.0), (4.245, 1.689, 1.744, 20.0, 40.0), (2.234, 0.364, 3.389, 20.0, 40.0), (2.629, 2.224, -0.134, 20.0, 40.0), (-4.375, 1.221, -1.630, 20.0, 40.0), (-0.618, 1.374, -0.057, 20.0, 40.0), (-2.580, -1.604, 4.918, 20.0, 40.0), (0.159, 1.104, 0.871, 20.0, 40.0), (-3.597, 0.975, -0.749, 20.0, 40.0); +-- +DROP TABLE IF EXISTS test.model; +create table test.model engine = Memory as select LogicRegressionState(0.1, 5, 1.0)(target, param1, param2) as state from test.defaults; +-- -- select toTypeName(state) from test.model; +-- -- +-- -- DROP TABLE IF EXISTS test.tests; +-- -- CREATE TABLE IF NOT EXISTS test.tests +-- -- ( +-- -- predict1 Float64, +-- -- predict2 Float64, +-- -- state1 AggregateFunction(LinReg(0.01), Float64, Float64, Float64) +-- -- ) ENGINE = Memory; +-- -- insert into test.tests select 20.0, 40.0, LinRegState(0.01)(target, param1, param2) from test.defaults; +-- -- select evalLinReg(state1, predict1, predict2) from test.tests; +-- +-- +-- +-- -- DROP TABLE IF EXISTS test.prediction; +-- -- CREATE TABLE IF NOT EXISTS test.prediction +-- -- ( +-- -- predict1 Float64, +-- -- predict2 Float64 +-- -- ) ENGINE = Memory; +-- +-- +-- -- insert into test.prediction values (20.0, 40.0); +-- +-- -- select multiply(param1, param2) from test.defaults; +-- +-- -- select evalLinReg(LinRegState(0.01)(target, param1, param2), 20.0, 40.0) from test.defaults; +select evalMLMethod(state, predict1, predict2) from test.model cross join test.defaults; From 39f1d9756e9ff980d0dd487ec66e78d041896f13 Mon Sep 17 00:00:00 2001 From: Masha Date: Mon, 28 Jan 2019 11:54:55 +0000 Subject: [PATCH 011/709] fixed name Logistic --- .../AggregateFunctions/AggregateFunctionMLMethod.cpp | 8 ++++---- .../AggregateFunctions/AggregateFunctionMLMethod.h | 12 +++--------- dbms/src/Columns/ColumnAggregateFunction.cpp | 6 +++--- dbms/tests/queries/0_stateless/00901_mytest.sql | 2 +- 4 files changed, 11 insertions(+), 17 deletions(-) diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp index 6aa983defc4..116a62b8408 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp @@ -11,7 +11,7 @@ namespace { using FuncLinearRegression = AggregateFunctionMLMethod; -using FuncLogicRegression = AggregateFunctionMLMethod; +using FuncLogisticRegression = AggregateFunctionMLMethod; template AggregateFunctionPtr createAggregateFunctionMLMethod( const std::string & name, const DataTypes & argument_types, const Array & parameters) @@ -46,9 +46,9 @@ AggregateFunctionPtr createAggregateFunctionMLMethod( if (std::is_same::value) { gc = std::make_shared(argument_types.size()); - } else if (std::is_same::value) + } else if (std::is_same::value) { - gc = std::make_shared(argument_types.size()); + gc = std::make_shared(argument_types.size()); } else { throw Exception("Such gradient computer is not implemented yet", ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT); @@ -81,7 +81,7 @@ AggregateFunctionPtr createAggregateFunctionMLMethod( void registerAggregateFunctionMLMethod(AggregateFunctionFactory & factory) { factory.registerFunction("LinearRegression", createAggregateFunctionMLMethod); - factory.registerFunction("LogicRegression", createAggregateFunctionMLMethod); + factory.registerFunction("LogisticRegression", createAggregateFunctionMLMethod); } } diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h index 598ff23b5d9..4c85d5cff76 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h @@ -107,22 +107,16 @@ public: return res; } }; -class LogicRegression : public IGradientComputer +class LogisticRegression : public IGradientComputer { public: - LogicRegression(UInt32 sz) + LogisticRegression(UInt32 sz) : IGradientComputer(sz) {} void compute(const std::vector & weights, Float64 bias, Float64 learning_rate, Float64 target, const IColumn ** columns, size_t row_num) override { - //Float64 derivative = (target - bias); - //for (size_t i = 0; i < weights.size(); ++i) - //{ - // derivative -= weights[i] * static_cast &>(*columns[i + 1]).getData()[row_num]; - //} - //derivative *= (2 * learning_rate); Float64 derivative = bias; for (size_t i = 0; i < weights.size(); ++i) { @@ -409,5 +403,5 @@ private: }; struct NameLinearRegression { static constexpr auto name = "LinearRegression"; }; -struct NameLogicRegression { static constexpr auto name = "LogicRegression"; }; +struct NameLogisticRegression { static constexpr auto name = "LogisticRegression"; }; } diff --git a/dbms/src/Columns/ColumnAggregateFunction.cpp b/dbms/src/Columns/ColumnAggregateFunction.cpp index c60060f1f79..b9fa94f1956 100644 --- a/dbms/src/Columns/ColumnAggregateFunction.cpp +++ b/dbms/src/Columns/ColumnAggregateFunction.cpp @@ -124,7 +124,7 @@ MutableColumnPtr ColumnAggregateFunction::predictValues(Block & block, const Col // auto ML_function = typeid_cast *>(func.get()); auto ML_function_Linear = typeid_cast *>(func.get()); - auto ML_function_Logic = typeid_cast *>(func.get()); + auto ML_function_Logistic = typeid_cast *>(func.get()); if (ML_function_Linear) { size_t row_num = 0; @@ -132,11 +132,11 @@ MutableColumnPtr ColumnAggregateFunction::predictValues(Block & block, const Col ML_function_Linear->predictResultInto(val, *res, block, row_num, arguments); ++row_num; } - } else if (ML_function_Logic) + } else if (ML_function_Logistic) { size_t row_num = 0; for (auto val : data) { - ML_function_Logic->predictResultInto(val, *res, block, row_num, arguments); + ML_function_Logistic->predictResultInto(val, *res, block, row_num, arguments); ++row_num; } } else diff --git a/dbms/tests/queries/0_stateless/00901_mytest.sql b/dbms/tests/queries/0_stateless/00901_mytest.sql index e9278ecb77d..f6bf6a5978f 100644 --- a/dbms/tests/queries/0_stateless/00901_mytest.sql +++ b/dbms/tests/queries/0_stateless/00901_mytest.sql @@ -15,7 +15,7 @@ insert into test.defaults values (1,2,1,1,2), (1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2 -- insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0), (-1.099, 2.755, -3.060, 20.0, 40.0), (1.090, 2.945, -2.346, 20.0, 40.0), (0.305, 2.179, -1.205, 20.0, 40.0), (-0.925, 0.702, 1.134, 20.0, 40.0), (3.178, -1.316, 7.221, 20.0, 40.0), (-2.756, -0.473, 2.569, 20.0, 40.0), (3.665, 2.303, 0.226, 20.0, 40.0), (1.662, 1.951, -0.070, 20.0, 40.0), (2.869, 0.593, 3.249, 20.0, 40.0), (0.818, -0.593, 4.594, 20.0, 40.0), (-1.917, 0.916, 0.209, 20.0, 40.0), (2.706, 1.523, 1.307, 20.0, 40.0), (0.219, 2.162, -1.214, 20.0, 40.0), (-4.510, 1.376, -2.007, 20.0, 40.0), (4.284, -0.515, 6.173, 20.0, 40.0), (-1.101, 2.810, -3.170, 20.0, 40.0), (-1.810, -1.117, 4.329, 20.0, 40.0), (0.055, 1.115, 0.797, 20.0, 40.0), (-2.178, 2.904, -3.898, 20.0, 40.0), (-3.494, -1.814, 4.882, 20.0, 40.0), (3.027, 0.476, 3.562, 20.0, 40.0), (-1.434, 1.151, -0.018, 20.0, 40.0), (1.180, 0.992, 1.606, 20.0, 40.0), (0.015, 0.971, 1.067, 20.0, 40.0), (-0.511, -0.875, 4.495, 20.0, 40.0), (0.961, 2.348, -1.216, 20.0, 40.0), (-2.279, 0.038, 1.785, 20.0, 40.0), (-1.568, -0.248, 2.712, 20.0, 40.0), (-0.496, 0.366, 2.020, 20.0, 40.0), (1.177, -1.401, 6.390, 20.0, 40.0), (2.882, -1.442, 7.325, 20.0, 40.0), (-1.066, 1.817, -1.167, 20.0, 40.0), (-2.144, 2.791, -3.655, 20.0, 40.0), (-4.370, 2.228, -3.642, 20.0, 40.0), (3.996, 2.775, -0.553, 20.0, 40.0), (0.289, 2.055, -0.965, 20.0, 40.0), (-0.588, -1.601, 5.908, 20.0, 40.0), (-1.801, 0.417, 1.265, 20.0, 40.0), (4.375, -1.499, 8.186, 20.0, 40.0), (-2.618, 0.038, 1.615, 20.0, 40.0), (3.616, -0.833, 6.475, 20.0, 40.0), (-4.045, -1.558, 4.094, 20.0, 40.0), (-3.962, 0.636, -0.253, 20.0, 40.0), (3.505, 2.625, -0.497, 20.0, 40.0), (3.029, -0.523, 5.560, 20.0, 40.0), (-3.520, -0.474, 2.188, 20.0, 40.0), (2.430, -1.469, 7.154, 20.0, 40.0), (1.547, -1.654, 7.082, 20.0, 40.0), (-1.370, 0.575, 1.165, 20.0, 40.0), (-1.869, -1.555, 5.176, 20.0, 40.0), (3.536, 2.841, -0.913, 20.0, 40.0), (-3.810, 1.220, -1.344, 20.0, 40.0), (-1.971, 1.462, -0.910, 20.0, 40.0), (-0.243, 0.167, 2.545, 20.0, 40.0), (-1.403, 2.645, -2.991, 20.0, 40.0), (0.532, -0.114, 3.494, 20.0, 40.0), (-1.678, 0.975, 0.212, 20.0, 40.0), (-0.656, 2.140, -1.609, 20.0, 40.0), (1.743, 2.631, -1.390, 20.0, 40.0), (2.586, 2.943, -1.593, 20.0, 40.0), (-0.512, 2.969, -3.195, 20.0, 40.0), (2.283, -0.100, 4.342, 20.0, 40.0), (-4.293, 0.872, -0.890, 20.0, 40.0), (3.411, 1.300, 2.106, 20.0, 40.0), (-0.281, 2.951, -3.042, 20.0, 40.0), (-4.442, 0.384, 0.012, 20.0, 40.0), (1.194, 1.746, 0.104, 20.0, 40.0), (-1.152, 1.862, -1.300, 20.0, 40.0), (1.362, -1.341, 6.363, 20.0, 40.0), (-4.488, 2.618, -4.481, 20.0, 40.0), (3.419, -0.564, 5.837, 20.0, 40.0), (-3.392, 0.396, 0.512, 20.0, 40.0), (-1.629, -0.909, 4.003, 20.0, 40.0), (4.447, -1.088, 7.399, 20.0, 40.0), (-1.232, 1.699, -1.014, 20.0, 40.0), (-1.286, -0.609, 3.575, 20.0, 40.0), (2.437, 2.796, -1.374, 20.0, 40.0), (-4.864, 1.989, -3.410, 20.0, 40.0), (-1.716, -1.399, 4.940, 20.0, 40.0), (-3.084, 1.858, -2.259, 20.0, 40.0), (2.828, -0.319, 5.053, 20.0, 40.0), (-1.226, 2.586, -2.786, 20.0, 40.0), (2.456, 0.092, 4.044, 20.0, 40.0), (-0.989, 2.375, -2.245, 20.0, 40.0), (3.268, 0.935, 2.765, 20.0, 40.0), (-4.128, -1.995, 4.927, 20.0, 40.0), (-1.083, 2.197, -1.935, 20.0, 40.0), (-3.471, -1.198, 3.660, 20.0, 40.0), (4.617, -1.136, 7.579, 20.0, 40.0), (2.054, -1.675, 7.378, 20.0, 40.0), (4.106, 2.326, 0.402, 20.0, 40.0), (1.558, 0.310, 3.158, 20.0, 40.0), (0.792, 0.900, 1.596, 20.0, 40.0), (-3.229, 0.300, 0.785, 20.0, 40.0), (3.787, -0.793, 6.479, 20.0, 40.0), (1.786, 2.288, -0.684, 20.0, 40.0), (2.643, 0.223, 3.875, 20.0, 40.0), (-3.592, 2.122, -3.040, 20.0, 40.0), (4.519, -1.760, 8.779, 20.0, 40.0), (3.221, 2.255, 0.101, 20.0, 40.0), (4.151, 1.788, 1.500, 20.0, 40.0), (-1.033, -1.195, 4.874, 20.0, 40.0), (-1.636, -1.037, 4.257, 20.0, 40.0), (-3.548, 1.911, -2.596, 20.0, 40.0), (4.829, -0.293, 6.001, 20.0, 40.0), (-4.684, -1.664, 3.986, 20.0, 40.0), (4.531, -0.503, 6.271, 20.0, 40.0), (-3.503, -1.606, 4.460, 20.0, 40.0), (-2.036, -1.522, 5.027, 20.0, 40.0), (-0.473, -0.617, 3.997, 20.0, 40.0), (-1.554, -1.630, 5.483, 20.0, 40.0), (-3.567, -1.043, 3.302, 20.0, 40.0), (-2.038, 0.579, 0.823, 20.0, 40.0), (-3.040, 0.857, -0.233, 20.0, 40.0), (4.610, 0.562, 4.181, 20.0, 40.0), (-3.323, -1.938, 5.215, 20.0, 40.0), (4.314, 1.720, 1.717, 20.0, 40.0), (-1.220, 0.615, 1.161, 20.0, 40.0), (-2.556, 1.120, -0.519, 20.0, 40.0), (-3.717, -0.108, 1.358, 20.0, 40.0), (4.689, -1.826, 8.996, 20.0, 40.0), (3.452, 0.506, 3.713, 20.0, 40.0), (2.472, 0.612, 3.012, 20.0, 40.0), (3.452, 0.450, 3.826, 20.0, 40.0), (1.207, 2.585, -1.567, 20.0, 40.0), (-4.826, 1.090, -1.593, 20.0, 40.0), (3.116, -1.118, 6.794, 20.0, 40.0), (0.448, 2.732, -2.240, 20.0, 40.0), (-1.096, -0.525, 3.503, 20.0, 40.0), (-4.680, -0.238, 1.137, 20.0, 40.0), (2.552, -1.403, 7.082, 20.0, 40.0), (0.719, 2.997, -2.635, 20.0, 40.0), (0.347, -1.966, 7.105, 20.0, 40.0), (2.958, -0.404, 5.288, 20.0, 40.0), (0.722, -1.950, 7.261, 20.0, 40.0), (-2.851, -0.986, 3.546, 20.0, 40.0), (-4.316, -0.439, 1.721, 20.0, 40.0), (-1.685, -0.201, 2.560, 20.0, 40.0), (1.856, 0.190, 3.549, 20.0, 40.0), (-2.052, 0.206, 1.562, 20.0, 40.0), (-2.504, -0.646, 3.041, 20.0, 40.0), (3.235, 0.882, 2.854, 20.0, 40.0), (-1.366, -1.573, 5.463, 20.0, 40.0), (-3.447, 2.419, -3.562, 20.0, 40.0), (4.155, 2.092, 0.893, 20.0, 40.0), (-0.935, 0.209, 2.116, 20.0, 40.0), (3.117, -1.821, 8.201, 20.0, 40.0), (3.759, 0.577, 3.725, 20.0, 40.0), (-0.938, 2.992, -3.453, 20.0, 40.0), (-0.525, 2.341, -1.945, 20.0, 40.0), (4.540, 2.625, 0.019, 20.0, 40.0), (-2.097, 1.190, -0.429, 20.0, 40.0), (-2.672, 1.983, -2.302, 20.0, 40.0), (-3.038, -1.490, 4.460, 20.0, 40.0), (-0.943, 2.149, -1.770, 20.0, 40.0), (0.739, 1.598, 0.174, 20.0, 40.0), (1.828, 1.853, 0.208, 20.0, 40.0), (4.856, 0.137, 5.153, 20.0, 40.0), (-1.617, 0.468, 1.255, 20.0, 40.0), (-1.972, 2.053, -2.092, 20.0, 40.0), (-4.633, 1.389, -2.094, 20.0, 40.0), (-3.628, -1.156, 3.498, 20.0, 40.0), (3.597, 1.034, 2.731, 20.0, 40.0), (-1.488, -0.002, 2.261, 20.0, 40.0), (0.749, 1.921, -0.468, 20.0, 40.0), (1.304, -1.371, 6.394, 20.0, 40.0), (4.587, 2.936, -0.579, 20.0, 40.0), (-2.241, 1.791, -1.703, 20.0, 40.0), (-2.945, 1.372, -1.216, 20.0, 40.0), (1.375, 0.395, 2.898, 20.0, 40.0), (-1.281, -0.641, 3.642, 20.0, 40.0), (2.178, 0.895, 2.299, 20.0, 40.0), (3.031, -0.786, 6.087, 20.0, 40.0), (-1.385, -0.375, 3.058, 20.0, 40.0), (4.041, -0.431, 5.882, 20.0, 40.0), (0.480, -0.507, 4.254, 20.0, 40.0), (-3.797, 0.140, 0.822, 20.0, 40.0), (2.355, 2.502, -0.827, 20.0, 40.0), (1.376, -1.583, 6.854, 20.0, 40.0), (0.164, 1.405, 0.273, 20.0, 40.0), (-1.273, 1.471, -0.579, 20.0, 40.0), (0.770, 2.246, -1.107, 20.0, 40.0), (4.552, 2.904, -0.533, 20.0, 40.0), (4.259, -1.772, 8.674, 20.0, 40.0), (-0.309, 1.159, 0.528, 20.0, 40.0), (3.581, 2.700, -0.610, 20.0, 40.0), (-3.202, 0.346, 0.707, 20.0, 40.0), (-1.575, 1.242, -0.271, 20.0, 40.0), (-1.584, -0.493, 3.194, 20.0, 40.0), (-3.778, 0.150, 0.810, 20.0, 40.0), (-4.675, 1.749, -2.835, 20.0, 40.0), (3.567, -0.792, 6.367, 20.0, 40.0), (-0.417, 1.399, -0.006, 20.0, 40.0), (-4.672, 2.007, -3.349, 20.0, 40.0), (-1.034, 0.196, 2.090, 20.0, 40.0), (-3.796, 2.496, -3.890, 20.0, 40.0), (3.532, -0.497, 5.759, 20.0, 40.0), (4.868, -1.359, 8.151, 20.0, 40.0), (-0.769, 0.302, 2.011, 20.0, 40.0), (4.475, 2.612, 0.014, 20.0, 40.0), (-3.532, -0.395, 2.024, 20.0, 40.0), (0.322, 0.675, 1.812, 20.0, 40.0), (-2.028, -1.942, 5.870, 20.0, 40.0), (1.810, -1.244, 6.392, 20.0, 40.0), (-0.783, 1.242, 0.124, 20.0, 40.0), (-4.745, -1.300, 3.227, 20.0, 40.0), (1.902, 1.973, 0.005, 20.0, 40.0), (-3.453, -1.429, 4.132, 20.0, 40.0), (1.559, 0.986, 1.808, 20.0, 40.0), (0.128, 2.754, -2.443, 20.0, 40.0), (2.759, 1.727, 0.926, 20.0, 40.0), (-4.468, 1.690, -2.614, 20.0, 40.0), (-2.368, -1.922, 5.659, 20.0, 40.0), (-2.766, 2.128, -2.640, 20.0, 40.0), (0.967, -1.825, 7.133, 20.0, 40.0), (-2.854, 2.855, -4.136, 20.0, 40.0), (-2.944, 1.875, -2.222, 20.0, 40.0), (-2.632, -0.983, 3.649, 20.0, 40.0), (2.427, 2.239, -0.266, 20.0, 40.0), (-1.726, -0.838, 3.812, 20.0, 40.0), (0.007, -0.903, 4.809, 20.0, 40.0), (-2.013, 1.092, -0.191, 20.0, 40.0), (-0.449, 0.970, 0.836, 20.0, 40.0), (1.396, 0.411, 2.876, 20.0, 40.0), (-1.115, -1.790, 6.023, 20.0, 40.0), (3.748, 1.917, 1.039, 20.0, 40.0), (2.978, 1.043, 2.404, 20.0, 40.0), (-3.969, 2.514, -4.013, 20.0, 40.0), (4.455, -0.050, 5.328, 20.0, 40.0), (-3.065, -0.846, 3.160, 20.0, 40.0), (-1.069, 2.167, -1.869, 20.0, 40.0), (3.016, -1.393, 7.294, 20.0, 40.0), (0.045, -1.928, 6.879, 20.0, 40.0), (-2.555, -0.984, 3.690, 20.0, 40.0), (-1.995, -0.054, 2.111, 20.0, 40.0), (4.600, -0.509, 6.318, 20.0, 40.0), (-1.942, 1.215, -0.402, 20.0, 40.0), (1.262, 2.765, -1.899, 20.0, 40.0), (2.617, -1.106, 6.521, 20.0, 40.0), (1.737, 0.554, 2.761, 20.0, 40.0), (-2.197, 0.632, 0.638, 20.0, 40.0), (4.768, 2.618, 0.147, 20.0, 40.0), (-3.737, -0.939, 3.010, 20.0, 40.0), (-2.623, 0.595, 0.499, 20.0, 40.0), (4.752, -0.340, 6.057, 20.0, 40.0), (2.333, -1.037, 6.240, 20.0, 40.0), (4.234, -1.882, 8.881, 20.0, 40.0), (-3.393, -0.812, 2.927, 20.0, 40.0), (0.885, 1.383, 0.678, 20.0, 40.0), (0.123, 2.937, -2.812, 20.0, 40.0), (2.969, 0.760, 2.964, 20.0, 40.0), (-4.929, 1.251, -1.967, 20.0, 40.0), (1.916, 2.223, -0.488, 20.0, 40.0), (-0.020, -1.740, 6.469, 20.0, 40.0), (0.702, -1.272, 5.895, 20.0, 40.0), (2.496, 2.648, -1.048, 20.0, 40.0), (4.067, -1.475, 7.984, 20.0, 40.0), (-3.717, 1.851, -2.561, 20.0, 40.0), (1.678, -0.624, 5.088, 20.0, 40.0), (1.073, 0.695, 2.146, 20.0, 40.0), (1.842, -0.749, 5.419, 20.0, 40.0), (-3.518, 1.909, -2.578, 20.0, 40.0), (2.229, 1.189, 1.737, 20.0, 40.0), (4.987, 2.893, -0.292, 20.0, 40.0), (-4.809, 1.043, -1.490, 20.0, 40.0), (-0.241, -0.728, 4.334, 20.0, 40.0), (-3.331, 0.590, 0.156, 20.0, 40.0), (-0.455, 2.621, -2.470, 20.0, 40.0), (1.492, 1.223, 1.301, 20.0, 40.0), (3.948, 2.841, -0.709, 20.0, 40.0), (0.732, 0.446, 2.475, 20.0, 40.0), (2.400, 2.390, -0.579, 20.0, 40.0), (-2.718, 1.427, -1.213, 20.0, 40.0), (-1.826, 1.451, -0.815, 20.0, 40.0), (1.125, 0.438, 2.686, 20.0, 40.0), (-4.918, 1.880, -3.219, 20.0, 40.0), (3.068, -0.442, 5.418, 20.0, 40.0), (1.982, 1.201, 1.589, 20.0, 40.0), (0.701, -1.709, 6.768, 20.0, 40.0), (-1.496, 2.564, -2.877, 20.0, 40.0), (-3.812, 0.974, -0.853, 20.0, 40.0), (-3.405, 2.018, -2.739, 20.0, 40.0), (2.211, 2.889, -1.674, 20.0, 40.0), (-2.481, 2.931, -4.103, 20.0, 40.0), (-3.721, 2.765, -4.391, 20.0, 40.0), (-1.768, -1.292, 4.699, 20.0, 40.0), (-4.462, 1.058, -1.347, 20.0, 40.0), (-3.516, -1.942, 5.126, 20.0, 40.0), (0.485, 2.420, -1.597, 20.0, 40.0), (-0.492, 0.242, 2.270, 20.0, 40.0), (4.245, 1.689, 1.744, 20.0, 40.0), (2.234, 0.364, 3.389, 20.0, 40.0), (2.629, 2.224, -0.134, 20.0, 40.0), (-4.375, 1.221, -1.630, 20.0, 40.0), (-0.618, 1.374, -0.057, 20.0, 40.0), (-2.580, -1.604, 4.918, 20.0, 40.0), (0.159, 1.104, 0.871, 20.0, 40.0), (-3.597, 0.975, -0.749, 20.0, 40.0); -- DROP TABLE IF EXISTS test.model; -create table test.model engine = Memory as select LogicRegressionState(0.1, 5, 1.0)(target, param1, param2) as state from test.defaults; +create table test.model engine = Memory as select LogisticRegressionState(0.1, 5, 1.0)(target, param1, param2) as state from test.defaults; -- -- select toTypeName(state) from test.model; -- -- -- -- DROP TABLE IF EXISTS test.tests; From bfccafef49cf3a15de54f5a69e9817f99fc2c91b Mon Sep 17 00:00:00 2001 From: alexander kozhikhov Date: Mon, 11 Feb 2019 00:16:16 +0300 Subject: [PATCH 012/709] small test code --- .../AggregateFunctionMLMethod.h | 79 +++++++++++++++---- dbms/src/Columns/ColumnAggregateFunction.cpp | 13 ++- dbms/src/Functions/evalMLMethod.cpp | 11 +++ .../tests/queries/0_stateless/00900_stest.sql | 12 ++- ...{00900_mytest.sql => 10900_mytest_old.sql} | 14 +++- 5 files changed, 110 insertions(+), 19 deletions(-) rename dbms/tests/queries/0_stateless/{00900_mytest.sql => 10900_mytest_old.sql} (63%) diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h index 4c85d5cff76..2cffb9cbaae 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h @@ -60,6 +60,7 @@ public: return batch_gradient; } virtual Float64 predict(const std::vector & predict_feature, const std::vector & weights, Float64 bias) const = 0; + virtual void predict_for_all(ColumnVector::Container & container, Block & block, const ColumnNumbers & arguments, const std::vector & weights, Float64 bias) const = 0; protected: std::vector batch_gradient; // gradient for bias lies in batch_gradient[batch_gradient.size() - 1] @@ -85,7 +86,7 @@ public: batch_gradient[weights.size()] += derivative; for (size_t i = 0; i < weights.size(); ++i) { - batch_gradient[i] += derivative * static_cast &>(*columns[i + 1]).getData()[row_num];; + batch_gradient[i] += derivative * static_cast &>(*columns[i + 1]).getData()[row_num]; } } Float64 predict(const std::vector & predict_feature, const std::vector & weights, Float64 bias) const override @@ -106,6 +107,36 @@ public: return res; } + void predict_for_all(ColumnVector::Container & container, Block & block, const ColumnNumbers & arguments, const std::vector & weights, Float64 bias) const override + { + size_t rows_num = block.rows(); + std::cout << "\n\nROWS NUM: " << rows_num << "\n\n"; + std::vector results(rows_num, bias); + + + for (size_t i = 1; i < arguments.size(); ++i) + { + ColumnPtr cur_col = block.getByPosition(arguments[i]).column; + for (size_t row_num = 0; row_num != rows_num; ++row_num) + { + const auto &element = (*cur_col)[row_num]; + if (element.getType() != Field::Types::Float64) + throw Exception("Prediction arguments must be values of type Float", + ErrorCodes::BAD_ARGUMENTS); + + results[row_num] += weights[row_num] * element.get(); + // predict_features[i - 1] = element.get(); + } + } + + for (size_t row_num = 0; row_num != rows_num; ++row_num) + { + container.emplace_back(results[row_num]); + } +// column.getData().push_back(this->data(place).predict(predict_features)); +// column.getData().push_back(this->data(place).predict_for_all()); +// this->data(place).predict_for_all(column.getData(), block, arguments); + } }; class LogisticRegression : public IGradientComputer { @@ -149,6 +180,14 @@ public: res = 1 / (1 + exp(-res)); return res; } + void predict_for_all(ColumnVector::Container & container, Block & block, const ColumnNumbers & arguments, const std::vector & weights, Float64 bias) const override + { + std::ignore = container; + std::ignore = block; + std::ignore = arguments; + std::ignore = weights; + std::ignore = bias; + } }; class IWeightsUpdater @@ -191,6 +230,7 @@ public: } bias += hk_[weights.size()] / cur_batch; } + /// virtual? virtual void merge(const std::shared_ptr rhs, Float64 frac, Float64 rhs_frac) override { auto momentum_rhs = std::dynamic_pointer_cast(rhs); for (size_t i = 0; i < hk_.size(); ++i) @@ -199,9 +239,10 @@ public: } } -Float64 alpha_{0.1}; -std::vector hk_; + Float64 alpha_{0.1}; + std::vector hk_; }; + class LinearModelData { public: @@ -223,7 +264,6 @@ public: } - void add(Float64 target, const IColumn ** columns, size_t row_num) { gradient_computer->compute(weights, bias, learning_rate, target, columns, row_num); @@ -285,6 +325,10 @@ public: return gradient_computer->predict(predict_feature, weights, bias); } + void predict_for_all(ColumnVector::Container & container, Block & block, const ColumnNumbers & arguments) const + { + gradient_computer->predict_for_all(container, block, arguments, weights, bias); + } private: std::vector weights; @@ -366,23 +410,28 @@ public: void predictResultInto(ConstAggregateDataPtr place, IColumn & to, Block & block, size_t row_num, const ColumnNumbers & arguments) const { + std::ignore = row_num; + std::cout << "\n\n IM CALLED \n\n"; + if (arguments.size() != param_num + 1) throw Exception("Predict got incorrect number of arguments. Got: " + std::to_string(arguments.size()) + ". Required: " + std::to_string(param_num + 1), ErrorCodes::NUMBER_OF_ARGUMENTS_DOESNT_MATCH); auto &column = dynamic_cast &>(to); - std::vector predict_features(arguments.size() - 1); - for (size_t i = 1; i < arguments.size(); ++i) - { - const auto& element = (*block.getByPosition(arguments[i]).column)[row_num]; - if (element.getType() != Field::Types::Float64) - throw Exception("Prediction arguments must be values of type Float", - ErrorCodes::BAD_ARGUMENTS); - - predict_features[i - 1] = element.get(); - } - column.getData().push_back(this->data(place).predict(predict_features)); +// std::vector predict_features(arguments.size() - 1); +// for (size_t i = 1; i < arguments.size(); ++i) +// { +// const auto& element = (*block.getByPosition(arguments[i]).column)[row_num]; +// if (element.getType() != Field::Types::Float64) +// throw Exception("Prediction arguments must be values of type Float", +// ErrorCodes::BAD_ARGUMENTS); +// +//// predict_features[i - 1] = element.get(); +// } +// column.getData().push_back(this->data(place).predict(predict_features)); +// column.getData().push_back(this->data(place).predict_for_all()); + this->data(place).predict_for_all(column.getData(), block, arguments); } void insertResultInto(ConstAggregateDataPtr place, IColumn & to) const override diff --git a/dbms/src/Columns/ColumnAggregateFunction.cpp b/dbms/src/Columns/ColumnAggregateFunction.cpp index b9fa94f1956..0a84242c81f 100644 --- a/dbms/src/Columns/ColumnAggregateFunction.cpp +++ b/dbms/src/Columns/ColumnAggregateFunction.cpp @@ -33,9 +33,9 @@ void ColumnAggregateFunction::addArena(ArenaPtr arena_) arenas.push_back(arena_); } -bool ColumnAggregateFunction::convertion(MutableColumnPtr* res_) const +bool ColumnAggregateFunction::convertion(MutableColumnPtr *res_) const { - if (const AggregateFunctionState * function_state = typeid_cast(func.get())) + if (const AggregateFunctionState *function_state = typeid_cast(func.get())) { auto res = createView(); res->set(function_state->getNestedFunction()); @@ -122,16 +122,25 @@ MutableColumnPtr ColumnAggregateFunction::predictValues(Block & block, const Col return res; } + std::cout << "\n\nHELLO: " << data.size() << "\n\n"; + /// На моих тестах дважды в эту функцию приходит нечтно, имеющее data.size() == 0 однако оно по сути ничего не делает в следующих строках + if (1 != data.size()) + return res; + // auto ML_function = typeid_cast *>(func.get()); auto ML_function_Linear = typeid_cast *>(func.get()); auto ML_function_Logistic = typeid_cast *>(func.get()); if (ML_function_Linear) { size_t row_num = 0; + std::cout << "\n\nIM HERE\n" << data.size() << "\n"; for (auto val : data) { + std::cout << "HIII\n\n"; ML_function_Linear->predictResultInto(val, *res, block, row_num, arguments); ++row_num; } +// ML_function_Linear->predictResultInto(data[0], *res, block, row_num, arguments); + } else if (ML_function_Logistic) { size_t row_num = 0; diff --git a/dbms/src/Functions/evalMLMethod.cpp b/dbms/src/Functions/evalMLMethod.cpp index e299206dbd2..23e21b3605f 100644 --- a/dbms/src/Functions/evalMLMethod.cpp +++ b/dbms/src/Functions/evalMLMethod.cpp @@ -59,9 +59,20 @@ namespace DB void executeImpl(Block & block, const ColumnNumbers & arguments, size_t result, size_t /*input_rows_count*/) override { +// const ColumnAggregateFunction * column_with_states = +// typeid_cast(static_cast(&*block.getByPosition(arguments.at(0)).column)); + + +// std::cout << "\n\n\nHELOOOOO\n\n\n"; // завести МЛ_аггр_функции как отдельный класс, чтобы тут сразу это проверять, а не делать это внутри predictValues() const ColumnAggregateFunction * column_with_states = typeid_cast(&*block.getByPosition(arguments.at(0)).column); +// std::cout << "\n\n\nHELOOOOO 2\n\n\n"; + +// const ColumnConst * column_with_states +// = typeid_cast(&*block.getByPosition(arguments.at(0)).column); + + if (!column_with_states) throw Exception("Illegal column " + block.getByPosition(arguments.at(0)).column->getName() + " of first argument of function " diff --git a/dbms/tests/queries/0_stateless/00900_stest.sql b/dbms/tests/queries/0_stateless/00900_stest.sql index 0a0acfdee11..739de5aae35 100644 --- a/dbms/tests/queries/0_stateless/00900_stest.sql +++ b/dbms/tests/queries/0_stateless/00900_stest.sql @@ -41,7 +41,17 @@ create table test.model engine = Memory as select LinearRegressionState(0.1, 5, -- -- select multiply(param1, param2) from test.defaults; -- -- -- select evalLinReg(LinRegState(0.01)(target, param1, param2), 20.0, 40.0) from test.defaults; -select evalMLMethod(state, predict1, predict2) from test.model cross join test.defaults; + +-- select evalMLMethod(state, predict1, predict2) from test.model cross join test.defaults; + + +-- select evalMLMethod(state, predict1, predict2) from test.model cross join test.defaults; + +-- select evalMLMethod(state, 0.1, 0.2) from test.model; + +-- with (select state from test.model) as model select evalMLMethod(model, predict1, predict2) from test.defaults; + + -- -- select evalLinReg(state, predict1, predict2) from test.model inner join (select * from test.tests) using state; -- -- select evalLinReg(state1, predict1, predict2) from test.tests; -- diff --git a/dbms/tests/queries/0_stateless/00900_mytest.sql b/dbms/tests/queries/0_stateless/10900_mytest_old.sql similarity index 63% rename from dbms/tests/queries/0_stateless/00900_mytest.sql rename to dbms/tests/queries/0_stateless/10900_mytest_old.sql index ddb99c77d19..bdeaf50f1ae 100644 --- a/dbms/tests/queries/0_stateless/00900_mytest.sql +++ b/dbms/tests/queries/0_stateless/10900_mytest_old.sql @@ -9,9 +9,12 @@ CREATE TABLE IF NOT EXISTS test.defaults predict2 Float64 ) ENGINE = Memory; -- -- insert into test.defaults values (2.533, 0.543, 3.181), (1.999, 1.765, 0.470), (0.631, 2.580, -1.845), (-1.164, 0.889, 0.640), (2.110, 0.768, 2.519), (1.251, 0.483, 2.659), (-3.958, 1.299, -1.576), (-2.152, -1.316, 4.556), (3.269, 1.441, 1.753), (4.206, -1.635, 8.373), (-3.479, -0.544, 2.349), (4.006, 0.167, 4.670), (-4.478, 2.400, -4.039), (1.856, 0.256, 3.417), (1.470, 1.685, 0.366), (-4.052, 2.326, -3.678), (-0.971, -0.969, 4.453), (0.881, -1.848, 7.137), (-1.551, -1.766, 5.756), (-0.988, -0.945, 4.395), (-4.636, 1.074, -1.466), (-4.074, -1.486, 3.934), (0.754, 2.627, -1.877), (1.035, 0.889, 1.738), (3.707, -1.281, 7.415), (-2.215, 1.110, -0.327), (-2.965, -1.316, 4.150), (-3.581, 1.063, -0.917), (0.548, 0.343, 2.588), (3.023, -0.870, 6.251), (4.053, -1.441, 7.909), (-0.750, 0.639, 1.348), (-4.411, 1.636, -2.477), (1.786, 0.398, 3.096), (-2.514, 0.033, 1.676), (4.935, -0.840, 7.148), (1.075, -0.921, 5.380), (-3.418, 2.177, -3.063), (3.122, 1.883, 0.795), (-2.254, -1.389, 4.650), (-4.603, 2.909, -5.119), (-1.886, -1.220, 4.497), (-0.509, -1.498, 5.741), (2.192, 1.882, 0.332), (4.056, -1.108, 7.244), (-1.918, 0.230, 1.581), (4.867, 1.516, 2.401), (-0.993, -0.011, 2.526), (-0.757, -1.192, 5.006), (-4.161, 2.059, -3.198), (2.258, 1.157, 1.814), (-3.878, -0.052, 1.165), (1.915, 2.998, -2.038), (-2.164, 2.379, -2.841), (-0.114, -1.914, 6.772), (3.812, 2.138, 0.630), (-1.863, 1.508, -0.947), (-2.964, 0.398, 0.722), (-2.046, -0.193, 2.363), (-1.525, -0.836, 3.910), (-4.557, -0.582, 1.886), (1.031, -0.461, 4.437), (-0.802, 0.699, 1.201), (3.982, 2.084, 0.824), (-2.243, 2.726, -3.573), (-3.989, -0.803, 2.611), (4.900, 0.253, 4.944), (-1.208, -1.587, 5.571), (0.370, 2.579, -1.972), (2.824, 0.964, 2.484), (-1.290, -0.128, 2.611), (0.190, 2.058, -1.021), (4.058, 2.122, 0.784), (4.879, 0.945, 3.549), (1.119, 1.992, -0.424), (4.050, 2.005, 1.015), (-0.064, 1.485, -0.002), (-2.496, 0.456, 0.840), (-1.835, 1.586, -1.090), (0.603, 1.856, -0.411), (-3.062, -0.966, 3.401), (-3.351, 0.430, 0.465), (-2.724, -1.331, 4.299), (3.291, -1.027, 6.699), (-4.263, 0.785, -0.701), (-3.289, -0.886, 3.128), (4.627, 1.331, 2.651), (-0.618, 0.602, 1.486), (0.056, 1.778, -0.528), (4.823, 1.154, 3.103), (-3.983, 0.509, -0.010), (-4.474, -1.400, 3.563), (-3.782, 2.996, -4.883), (4.515, -0.656, 6.569), (1.269, 2.592, -1.549), (-1.710, -0.241, 2.627), (2.171, 1.453, 1.180), (-1.931, -1.845, 5.726), (1.767, -1.798, 7.480), (4.352, 2.369, 0.438), (-4.498, 2.611, -4.472), (0.067, 0.517, 2.000), (4.151, 0.624, 3.827), (0.409, -0.969, 5.142), (0.193, -1.713, 6.522), (-2.487, 2.827, -3.898), (-4.363, 2.011, -3.203), (-2.383, 2.554, -3.299), (-4.457, -0.958, 2.687), (3.342, -0.360, 5.392), (0.902, 2.978, -2.505), (4.073, -1.524, 8.084), (3.036, 1.672, 1.173), (2.169, -0.564, 5.213), (-4.780, 0.962, -1.313), (-1.815, 2.096, -2.100), (-1.445, 0.458, 1.362), (1.891, -1.437, 6.820), (1.942, -1.761, 7.493), (-4.613, -1.551, 3.795), (-3.472, -1.110, 3.485), (-2.026, 1.961, -1.935), (0.091, -0.961, 4.967), (3.902, -1.336, 7.622), (-3.483, -0.769, 2.796), (-0.066, -1.233, 5.433), (2.597, 2.789, -1.280), (-1.657, -1.842, 5.856), (0.232, -1.420, 5.957), (-3.321, 1.609, -1.879), (2.673, 2.781, -1.226), (0.869, 0.072, 3.291), (1.444, -1.271, 6.264), (1.190, 1.460, 0.675), (3.497, 0.870, 3.008), (-2.884, -1.303, 4.163), (3.620, 0.381, 4.047), (2.594, 0.247, 3.803), (-3.902, -1.315, 3.678), (-4.753, -1.005, 2.634), (0.881, 0.675, 2.091), (0.414, 2.071, -0.935), (3.458, -0.920, 6.568), (-2.986, -0.411, 2.329), (3.076, -1.960, 8.458), (2.951, 2.988, -1.501), (2.408, 1.301, 1.603), (4.725, 0.366, 4.631), (4.924, -1.762, 8.985), (3.719, 0.970, 2.920), (-0.295, 0.257, 2.340), (-4.607, 2.548, -4.400), (0.288, 1.953, -0.761), (-3.311, 0.844, -0.344), (3.679, -0.642, 6.123), (-2.310, -0.838, 3.522), (-4.397, -0.226, 1.254), (-4.366, -0.024, 0.864), (2.405, 1.458, 1.286), (-4.296, -1.071, 2.994), (0.452, -1.901, 7.028), (-0.214, -0.467, 3.827), (2.559, 1.547, 1.185), (0.990, 1.539, 0.417), (0.478, -0.089, 3.417), (-2.734, -1.007, 3.646), (3.483, 0.247, 4.247), (3.507, 2.727, -0.701), (-4.399, 2.437, -4.073), (3.785, 0.036, 4.820), (-0.824, 2.417, -2.245), (-2.588, 0.369, 0.968), (-3.037, -1.639, 4.759), (4.531, -0.499, 6.264), (4.742, -1.161, 7.693), (-0.063, -0.595, 4.159), (0.697, 2.281, -1.212), (0.413, 0.607, 1.992), (-4.081, 0.383, 0.194), (0.712, 2.638, -1.920), (-1.620, 1.092, 0.006), (-3.425, -0.911, 3.109), (-0.124, 1.711, -0.484), (4.347, 1.387, 2.399), (-3.237, -0.900, 3.182), (-3.961, 0.358, 0.304), (4.326, -0.068, 5.298), (3.846, 1.725, 1.473), (-2.089, 0.953, 0.049), (-1.025, -1.470, 5.428), (2.061, -0.156, 4.343), (1.547, -1.827, 7.427), (2.786, 0.460, 3.473), (0.076, 0.659, 1.720), (3.597, 1.966, 0.866), (-0.933, -1.180, 4.894), (4.647, 1.190, 2.943), (-0.032, 0.544, 1.896), (4.461, -1.806, 8.843), (-0.586, 1.821, -0.934), (3.725, 1.715, 1.432), (-2.091, 2.714, -3.474), (4.494, -1.494, 8.236), (3.766, -0.209, 5.301), (-1.991, 1.776, -1.548), (-4.992, -0.742, 1.989), (-2.400, 1.828, -1.855), (-1.329, 0.143, 2.050), (1.954, 1.759, 0.459), (-4.422, 1.507, -2.224), (-2.243, -1.126, 4.131), (4.417, -1.080, 7.368), (1.737, -1.144, 6.157), (2.661, -1.084, 6.498), (-3.198, 0.443, 0.515), (4.191, -1.250, 7.596), (-2.419, -0.163, 2.116), (1.910, -1.173, 6.301), (-0.241, 1.902, -0.925), (-4.415, 2.479, -4.165), (3.307, -0.465, 5.583), (-2.382, 1.364, -0.920), (-3.154, 2.953, -4.483), (-2.562, 2.803, -3.888), (3.076, 0.195, 4.149), (-0.101, 0.896, 1.157), (-2.067, 1.120, -0.273), (-4.680, 2.756, -4.851), (-4.283, -0.607, 2.072), (4.013, -1.072, 7.150), (-4.401, -0.896, 2.591), (4.544, 2.498, 0.276), (4.075, -1.204, 7.445), (-3.463, 1.242, -1.216), (3.992, 2.782, -0.568), (-4.503, 0.239, 0.270), (-3.095, 1.161, -0.870), (0.768, -0.904, 5.192), (1.255, 2.870, -2.112), (-1.537, -0.049, 2.330), (2.851, -1.182, 6.789), (1.974, -0.922, 5.832), (4.447, 2.719, -0.214), (-3.413, 0.555, 0.184), (4.943, 2.120, 1.231), (3.645, -0.413, 5.648), (-4.776, 0.079, 0.453), (1.991, 1.565, 0.866), (2.413, 1.793, 0.620), (4.245, 2.663, -0.205), (-2.022, -1.180, 4.350), (-2.285, -1.246, 4.350), (2.276, 0.488, 3.162), (2.582, -0.037, 4.365), (-4.875, 1.468, -2.374), (-2.492, 2.730, -3.706), (2.696, -1.833, 8.013), (4.618, -1.127, 7.563), (-4.156, 0.987, -1.053), (1.873, -1.566, 7.068), (1.699, 0.794, 2.262), (-3.181, 1.640, -1.871), (-3.225, 1.526, -1.664), (-2.679, -1.811, 5.281), (3.717, 1.532, 1.794), (1.288, -0.999, 5.642), (-1.057, 0.044, 2.384), (-0.147, 1.108, 0.711), (-3.827, -1.139, 3.365), (0.872, -1.482, 6.399), (1.982, 0.286, 3.418), (-1.381, 2.374, -2.439), (-1.091, 2.010, -1.565), (-1.192, 2.751, -3.097), (1.468, -0.992, 5.718), (2.249, 0.949, 2.228), (3.064, 0.911, 2.711), (-1.576, -1.584, 5.380), (2.130, -1.489, 7.043), (4.386, -1.284, 7.761), (1.662, -1.645, 7.121), (-3.395, 1.784, -2.265), (4.618, 1.951, 1.406), (-0.299, 0.378, 2.095), (-2.911, 2.131, -2.717), (0.876, 2.869, -2.301), (-1.785, 0.961, 0.186), (-4.188, 2.442, -3.977), (-1.128, 0.127, 2.181), (1.755, -1.215, 6.307), (-2.276, 0.596, 0.669), (-4.630, 1.978, -3.272), (-0.454, 0.275, 2.224), (-1.950, -1.385, 4.794), (-0.889, 2.696, -2.837), (-4.832, -0.038, 0.661), (3.738, 0.604, 3.662), (-0.224, -0.465, 3.819); -insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0), (-1.099, 2.755, -3.060, 20.0, 40.0), (1.090, 2.945, -2.346, 20.0, 40.0), (0.305, 2.179, -1.205, 20.0, 40.0), (-0.925, 0.702, 1.134, 20.0, 40.0), (3.178, -1.316, 7.221, 20.0, 40.0), (-2.756, -0.473, 2.569, 20.0, 40.0), (3.665, 2.303, 0.226, 20.0, 40.0), (1.662, 1.951, -0.070, 20.0, 40.0), (2.869, 0.593, 3.249, 20.0, 40.0), (0.818, -0.593, 4.594, 20.0, 40.0), (-1.917, 0.916, 0.209, 20.0, 40.0), (2.706, 1.523, 1.307, 20.0, 40.0), (0.219, 2.162, -1.214, 20.0, 40.0), (-4.510, 1.376, -2.007, 20.0, 40.0), (4.284, -0.515, 6.173, 20.0, 40.0), (-1.101, 2.810, -3.170, 20.0, 40.0), (-1.810, -1.117, 4.329, 20.0, 40.0), (0.055, 1.115, 0.797, 20.0, 40.0), (-2.178, 2.904, -3.898, 20.0, 40.0), (-3.494, -1.814, 4.882, 20.0, 40.0), (3.027, 0.476, 3.562, 20.0, 40.0), (-1.434, 1.151, -0.018, 20.0, 40.0), (1.180, 0.992, 1.606, 20.0, 40.0), (0.015, 0.971, 1.067, 20.0, 40.0), (-0.511, -0.875, 4.495, 20.0, 40.0), (0.961, 2.348, -1.216, 20.0, 40.0), (-2.279, 0.038, 1.785, 20.0, 40.0), (-1.568, -0.248, 2.712, 20.0, 40.0), (-0.496, 0.366, 2.020, 20.0, 40.0), (1.177, -1.401, 6.390, 20.0, 40.0), (2.882, -1.442, 7.325, 20.0, 40.0), (-1.066, 1.817, -1.167, 20.0, 40.0), (-2.144, 2.791, -3.655, 20.0, 40.0), (-4.370, 2.228, -3.642, 20.0, 40.0), (3.996, 2.775, -0.553, 20.0, 40.0), (0.289, 2.055, -0.965, 20.0, 40.0), (-0.588, -1.601, 5.908, 20.0, 40.0), (-1.801, 0.417, 1.265, 20.0, 40.0), (4.375, -1.499, 8.186, 20.0, 40.0), (-2.618, 0.038, 1.615, 20.0, 40.0), (3.616, -0.833, 6.475, 20.0, 40.0), (-4.045, -1.558, 4.094, 20.0, 40.0), (-3.962, 0.636, -0.253, 20.0, 40.0), (3.505, 2.625, -0.497, 20.0, 40.0), (3.029, -0.523, 5.560, 20.0, 40.0), (-3.520, -0.474, 2.188, 20.0, 40.0), (2.430, -1.469, 7.154, 20.0, 40.0), (1.547, -1.654, 7.082, 20.0, 40.0), (-1.370, 0.575, 1.165, 20.0, 40.0), (-1.869, -1.555, 5.176, 20.0, 40.0), (3.536, 2.841, -0.913, 20.0, 40.0), (-3.810, 1.220, -1.344, 20.0, 40.0), (-1.971, 1.462, -0.910, 20.0, 40.0), (-0.243, 0.167, 2.545, 20.0, 40.0), (-1.403, 2.645, -2.991, 20.0, 40.0), (0.532, -0.114, 3.494, 20.0, 40.0), (-1.678, 0.975, 0.212, 20.0, 40.0), (-0.656, 2.140, -1.609, 20.0, 40.0), (1.743, 2.631, -1.390, 20.0, 40.0), (2.586, 2.943, -1.593, 20.0, 40.0), (-0.512, 2.969, -3.195, 20.0, 40.0), (2.283, -0.100, 4.342, 20.0, 40.0), (-4.293, 0.872, -0.890, 20.0, 40.0), (3.411, 1.300, 2.106, 20.0, 40.0), (-0.281, 2.951, -3.042, 20.0, 40.0), (-4.442, 0.384, 0.012, 20.0, 40.0), (1.194, 1.746, 0.104, 20.0, 40.0), (-1.152, 1.862, -1.300, 20.0, 40.0), (1.362, -1.341, 6.363, 20.0, 40.0), (-4.488, 2.618, -4.481, 20.0, 40.0), (3.419, -0.564, 5.837, 20.0, 40.0), (-3.392, 0.396, 0.512, 20.0, 40.0), (-1.629, -0.909, 4.003, 20.0, 40.0), (4.447, -1.088, 7.399, 20.0, 40.0), (-1.232, 1.699, -1.014, 20.0, 40.0), (-1.286, -0.609, 3.575, 20.0, 40.0), (2.437, 2.796, -1.374, 20.0, 40.0), (-4.864, 1.989, -3.410, 20.0, 40.0), (-1.716, -1.399, 4.940, 20.0, 40.0), (-3.084, 1.858, -2.259, 20.0, 40.0), (2.828, -0.319, 5.053, 20.0, 40.0), (-1.226, 2.586, -2.786, 20.0, 40.0), (2.456, 0.092, 4.044, 20.0, 40.0), (-0.989, 2.375, -2.245, 20.0, 40.0), (3.268, 0.935, 2.765, 20.0, 40.0), (-4.128, -1.995, 4.927, 20.0, 40.0), (-1.083, 2.197, -1.935, 20.0, 40.0), (-3.471, -1.198, 3.660, 20.0, 40.0), (4.617, -1.136, 7.579, 20.0, 40.0), (2.054, -1.675, 7.378, 20.0, 40.0), (4.106, 2.326, 0.402, 20.0, 40.0), (1.558, 0.310, 3.158, 20.0, 40.0), (0.792, 0.900, 1.596, 20.0, 40.0), (-3.229, 0.300, 0.785, 20.0, 40.0), (3.787, -0.793, 6.479, 20.0, 40.0), (1.786, 2.288, -0.684, 20.0, 40.0), (2.643, 0.223, 3.875, 20.0, 40.0), (-3.592, 2.122, -3.040, 20.0, 40.0), (4.519, -1.760, 8.779, 20.0, 40.0), (3.221, 2.255, 0.101, 20.0, 40.0), (4.151, 1.788, 1.500, 20.0, 40.0), (-1.033, -1.195, 4.874, 20.0, 40.0), (-1.636, -1.037, 4.257, 20.0, 40.0), (-3.548, 1.911, -2.596, 20.0, 40.0), (4.829, -0.293, 6.001, 20.0, 40.0), (-4.684, -1.664, 3.986, 20.0, 40.0), (4.531, -0.503, 6.271, 20.0, 40.0), (-3.503, -1.606, 4.460, 20.0, 40.0), (-2.036, -1.522, 5.027, 20.0, 40.0), (-0.473, -0.617, 3.997, 20.0, 40.0), (-1.554, -1.630, 5.483, 20.0, 40.0), (-3.567, -1.043, 3.302, 20.0, 40.0), (-2.038, 0.579, 0.823, 20.0, 40.0), (-3.040, 0.857, -0.233, 20.0, 40.0), (4.610, 0.562, 4.181, 20.0, 40.0), (-3.323, -1.938, 5.215, 20.0, 40.0), (4.314, 1.720, 1.717, 20.0, 40.0), (-1.220, 0.615, 1.161, 20.0, 40.0), (-2.556, 1.120, -0.519, 20.0, 40.0), (-3.717, -0.108, 1.358, 20.0, 40.0), (4.689, -1.826, 8.996, 20.0, 40.0), (3.452, 0.506, 3.713, 20.0, 40.0), (2.472, 0.612, 3.012, 20.0, 40.0), (3.452, 0.450, 3.826, 20.0, 40.0), (1.207, 2.585, -1.567, 20.0, 40.0), (-4.826, 1.090, -1.593, 20.0, 40.0), (3.116, -1.118, 6.794, 20.0, 40.0), (0.448, 2.732, -2.240, 20.0, 40.0), (-1.096, -0.525, 3.503, 20.0, 40.0), (-4.680, -0.238, 1.137, 20.0, 40.0), (2.552, -1.403, 7.082, 20.0, 40.0), (0.719, 2.997, -2.635, 20.0, 40.0), (0.347, -1.966, 7.105, 20.0, 40.0), (2.958, -0.404, 5.288, 20.0, 40.0), (0.722, -1.950, 7.261, 20.0, 40.0), (-2.851, -0.986, 3.546, 20.0, 40.0), (-4.316, -0.439, 1.721, 20.0, 40.0), (-1.685, -0.201, 2.560, 20.0, 40.0), (1.856, 0.190, 3.549, 20.0, 40.0), (-2.052, 0.206, 1.562, 20.0, 40.0), (-2.504, -0.646, 3.041, 20.0, 40.0), (3.235, 0.882, 2.854, 20.0, 40.0), (-1.366, -1.573, 5.463, 20.0, 40.0), (-3.447, 2.419, -3.562, 20.0, 40.0), (4.155, 2.092, 0.893, 20.0, 40.0), (-0.935, 0.209, 2.116, 20.0, 40.0), (3.117, -1.821, 8.201, 20.0, 40.0), (3.759, 0.577, 3.725, 20.0, 40.0), (-0.938, 2.992, -3.453, 20.0, 40.0), (-0.525, 2.341, -1.945, 20.0, 40.0), (4.540, 2.625, 0.019, 20.0, 40.0), (-2.097, 1.190, -0.429, 20.0, 40.0), (-2.672, 1.983, -2.302, 20.0, 40.0), (-3.038, -1.490, 4.460, 20.0, 40.0), (-0.943, 2.149, -1.770, 20.0, 40.0), (0.739, 1.598, 0.174, 20.0, 40.0), (1.828, 1.853, 0.208, 20.0, 40.0), (4.856, 0.137, 5.153, 20.0, 40.0), (-1.617, 0.468, 1.255, 20.0, 40.0), (-1.972, 2.053, -2.092, 20.0, 40.0), (-4.633, 1.389, -2.094, 20.0, 40.0), (-3.628, -1.156, 3.498, 20.0, 40.0), (3.597, 1.034, 2.731, 20.0, 40.0), (-1.488, -0.002, 2.261, 20.0, 40.0), (0.749, 1.921, -0.468, 20.0, 40.0), (1.304, -1.371, 6.394, 20.0, 40.0), (4.587, 2.936, -0.579, 20.0, 40.0), (-2.241, 1.791, -1.703, 20.0, 40.0), (-2.945, 1.372, -1.216, 20.0, 40.0), (1.375, 0.395, 2.898, 20.0, 40.0), (-1.281, -0.641, 3.642, 20.0, 40.0), (2.178, 0.895, 2.299, 20.0, 40.0), (3.031, -0.786, 6.087, 20.0, 40.0), (-1.385, -0.375, 3.058, 20.0, 40.0), (4.041, -0.431, 5.882, 20.0, 40.0), (0.480, -0.507, 4.254, 20.0, 40.0), (-3.797, 0.140, 0.822, 20.0, 40.0), (2.355, 2.502, -0.827, 20.0, 40.0), (1.376, -1.583, 6.854, 20.0, 40.0), (0.164, 1.405, 0.273, 20.0, 40.0), (-1.273, 1.471, -0.579, 20.0, 40.0), (0.770, 2.246, -1.107, 20.0, 40.0), (4.552, 2.904, -0.533, 20.0, 40.0), (4.259, -1.772, 8.674, 20.0, 40.0), (-0.309, 1.159, 0.528, 20.0, 40.0), (3.581, 2.700, -0.610, 20.0, 40.0), (-3.202, 0.346, 0.707, 20.0, 40.0), (-1.575, 1.242, -0.271, 20.0, 40.0), (-1.584, -0.493, 3.194, 20.0, 40.0), (-3.778, 0.150, 0.810, 20.0, 40.0), (-4.675, 1.749, -2.835, 20.0, 40.0), (3.567, -0.792, 6.367, 20.0, 40.0), (-0.417, 1.399, -0.006, 20.0, 40.0), (-4.672, 2.007, -3.349, 20.0, 40.0), (-1.034, 0.196, 2.090, 20.0, 40.0), (-3.796, 2.496, -3.890, 20.0, 40.0), (3.532, -0.497, 5.759, 20.0, 40.0), (4.868, -1.359, 8.151, 20.0, 40.0), (-0.769, 0.302, 2.011, 20.0, 40.0), (4.475, 2.612, 0.014, 20.0, 40.0), (-3.532, -0.395, 2.024, 20.0, 40.0), (0.322, 0.675, 1.812, 20.0, 40.0), (-2.028, -1.942, 5.870, 20.0, 40.0), (1.810, -1.244, 6.392, 20.0, 40.0), (-0.783, 1.242, 0.124, 20.0, 40.0), (-4.745, -1.300, 3.227, 20.0, 40.0), (1.902, 1.973, 0.005, 20.0, 40.0), (-3.453, -1.429, 4.132, 20.0, 40.0), (1.559, 0.986, 1.808, 20.0, 40.0), (0.128, 2.754, -2.443, 20.0, 40.0), (2.759, 1.727, 0.926, 20.0, 40.0), (-4.468, 1.690, -2.614, 20.0, 40.0), (-2.368, -1.922, 5.659, 20.0, 40.0), (-2.766, 2.128, -2.640, 20.0, 40.0), (0.967, -1.825, 7.133, 20.0, 40.0), (-2.854, 2.855, -4.136, 20.0, 40.0), (-2.944, 1.875, -2.222, 20.0, 40.0), (-2.632, -0.983, 3.649, 20.0, 40.0), (2.427, 2.239, -0.266, 20.0, 40.0), (-1.726, -0.838, 3.812, 20.0, 40.0), (0.007, -0.903, 4.809, 20.0, 40.0), (-2.013, 1.092, -0.191, 20.0, 40.0), (-0.449, 0.970, 0.836, 20.0, 40.0), (1.396, 0.411, 2.876, 20.0, 40.0), (-1.115, -1.790, 6.023, 20.0, 40.0), (3.748, 1.917, 1.039, 20.0, 40.0), (2.978, 1.043, 2.404, 20.0, 40.0), (-3.969, 2.514, -4.013, 20.0, 40.0), (4.455, -0.050, 5.328, 20.0, 40.0), (-3.065, -0.846, 3.160, 20.0, 40.0), (-1.069, 2.167, -1.869, 20.0, 40.0), (3.016, -1.393, 7.294, 20.0, 40.0), (0.045, -1.928, 6.879, 20.0, 40.0), (-2.555, -0.984, 3.690, 20.0, 40.0), (-1.995, -0.054, 2.111, 20.0, 40.0), (4.600, -0.509, 6.318, 20.0, 40.0), (-1.942, 1.215, -0.402, 20.0, 40.0), (1.262, 2.765, -1.899, 20.0, 40.0), (2.617, -1.106, 6.521, 20.0, 40.0), (1.737, 0.554, 2.761, 20.0, 40.0), (-2.197, 0.632, 0.638, 20.0, 40.0), (4.768, 2.618, 0.147, 20.0, 40.0), (-3.737, -0.939, 3.010, 20.0, 40.0), (-2.623, 0.595, 0.499, 20.0, 40.0), (4.752, -0.340, 6.057, 20.0, 40.0), (2.333, -1.037, 6.240, 20.0, 40.0), (4.234, -1.882, 8.881, 20.0, 40.0), (-3.393, -0.812, 2.927, 20.0, 40.0), (0.885, 1.383, 0.678, 20.0, 40.0), (0.123, 2.937, -2.812, 20.0, 40.0), (2.969, 0.760, 2.964, 20.0, 40.0), (-4.929, 1.251, -1.967, 20.0, 40.0), (1.916, 2.223, -0.488, 20.0, 40.0), (-0.020, -1.740, 6.469, 20.0, 40.0), (0.702, -1.272, 5.895, 20.0, 40.0), (2.496, 2.648, -1.048, 20.0, 40.0), (4.067, -1.475, 7.984, 20.0, 40.0), (-3.717, 1.851, -2.561, 20.0, 40.0), (1.678, -0.624, 5.088, 20.0, 40.0), (1.073, 0.695, 2.146, 20.0, 40.0), (1.842, -0.749, 5.419, 20.0, 40.0), (-3.518, 1.909, -2.578, 20.0, 40.0), (2.229, 1.189, 1.737, 20.0, 40.0), (4.987, 2.893, -0.292, 20.0, 40.0), (-4.809, 1.043, -1.490, 20.0, 40.0), (-0.241, -0.728, 4.334, 20.0, 40.0), (-3.331, 0.590, 0.156, 20.0, 40.0), (-0.455, 2.621, -2.470, 20.0, 40.0), (1.492, 1.223, 1.301, 20.0, 40.0), (3.948, 2.841, -0.709, 20.0, 40.0), (0.732, 0.446, 2.475, 20.0, 40.0), (2.400, 2.390, -0.579, 20.0, 40.0), (-2.718, 1.427, -1.213, 20.0, 40.0), (-1.826, 1.451, -0.815, 20.0, 40.0), (1.125, 0.438, 2.686, 20.0, 40.0), (-4.918, 1.880, -3.219, 20.0, 40.0), (3.068, -0.442, 5.418, 20.0, 40.0), (1.982, 1.201, 1.589, 20.0, 40.0), (0.701, -1.709, 6.768, 20.0, 40.0), (-1.496, 2.564, -2.877, 20.0, 40.0), (-3.812, 0.974, -0.853, 20.0, 40.0), (-3.405, 2.018, -2.739, 20.0, 40.0), (2.211, 2.889, -1.674, 20.0, 40.0), (-2.481, 2.931, -4.103, 20.0, 40.0), (-3.721, 2.765, -4.391, 20.0, 40.0), (-1.768, -1.292, 4.699, 20.0, 40.0), (-4.462, 1.058, -1.347, 20.0, 40.0), (-3.516, -1.942, 5.126, 20.0, 40.0), (0.485, 2.420, -1.597, 20.0, 40.0), (-0.492, 0.242, 2.270, 20.0, 40.0), (4.245, 1.689, 1.744, 20.0, 40.0), (2.234, 0.364, 3.389, 20.0, 40.0), (2.629, 2.224, -0.134, 20.0, 40.0), (-4.375, 1.221, -1.630, 20.0, 40.0), (-0.618, 1.374, -0.057, 20.0, 40.0), (-2.580, -1.604, 4.918, 20.0, 40.0), (0.159, 1.104, 0.871, 20.0, 40.0), (-3.597, 0.975, -0.749, 20.0, 40.0); +-- insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0), (-1.099, 2.755, -3.060, 20.0, 40.0), (1.090, 2.945, -2.346, 20.0, 40.0), (0.305, 2.179, -1.205, 20.0, 40.0), (-0.925, 0.702, 1.134, 20.0, 40.0), (3.178, -1.316, 7.221, 20.0, 40.0), (-2.756, -0.473, 2.569, 20.0, 40.0), (3.665, 2.303, 0.226, 20.0, 40.0), (1.662, 1.951, -0.070, 20.0, 40.0), (2.869, 0.593, 3.249, 20.0, 40.0), (0.818, -0.593, 4.594, 20.0, 40.0), (-1.917, 0.916, 0.209, 20.0, 40.0), (2.706, 1.523, 1.307, 20.0, 40.0), (0.219, 2.162, -1.214, 20.0, 40.0), (-4.510, 1.376, -2.007, 20.0, 40.0), (4.284, -0.515, 6.173, 20.0, 40.0), (-1.101, 2.810, -3.170, 20.0, 40.0), (-1.810, -1.117, 4.329, 20.0, 40.0), (0.055, 1.115, 0.797, 20.0, 40.0), (-2.178, 2.904, -3.898, 20.0, 40.0), (-3.494, -1.814, 4.882, 20.0, 40.0), (3.027, 0.476, 3.562, 20.0, 40.0), (-1.434, 1.151, -0.018, 20.0, 40.0), (1.180, 0.992, 1.606, 20.0, 40.0), (0.015, 0.971, 1.067, 20.0, 40.0), (-0.511, -0.875, 4.495, 20.0, 40.0), (0.961, 2.348, -1.216, 20.0, 40.0), (-2.279, 0.038, 1.785, 20.0, 40.0), (-1.568, -0.248, 2.712, 20.0, 40.0), (-0.496, 0.366, 2.020, 20.0, 40.0), (1.177, -1.401, 6.390, 20.0, 40.0), (2.882, -1.442, 7.325, 20.0, 40.0), (-1.066, 1.817, -1.167, 20.0, 40.0), (-2.144, 2.791, -3.655, 20.0, 40.0), (-4.370, 2.228, -3.642, 20.0, 40.0), (3.996, 2.775, -0.553, 20.0, 40.0), (0.289, 2.055, -0.965, 20.0, 40.0), (-0.588, -1.601, 5.908, 20.0, 40.0), (-1.801, 0.417, 1.265, 20.0, 40.0), (4.375, -1.499, 8.186, 20.0, 40.0), (-2.618, 0.038, 1.615, 20.0, 40.0), (3.616, -0.833, 6.475, 20.0, 40.0), (-4.045, -1.558, 4.094, 20.0, 40.0), (-3.962, 0.636, -0.253, 20.0, 40.0), (3.505, 2.625, -0.497, 20.0, 40.0), (3.029, -0.523, 5.560, 20.0, 40.0), (-3.520, -0.474, 2.188, 20.0, 40.0), (2.430, -1.469, 7.154, 20.0, 40.0), (1.547, -1.654, 7.082, 20.0, 40.0), (-1.370, 0.575, 1.165, 20.0, 40.0), (-1.869, -1.555, 5.176, 20.0, 40.0), (3.536, 2.841, -0.913, 20.0, 40.0), (-3.810, 1.220, -1.344, 20.0, 40.0), (-1.971, 1.462, -0.910, 20.0, 40.0), (-0.243, 0.167, 2.545, 20.0, 40.0), (-1.403, 2.645, -2.991, 20.0, 40.0), (0.532, -0.114, 3.494, 20.0, 40.0), (-1.678, 0.975, 0.212, 20.0, 40.0), (-0.656, 2.140, -1.609, 20.0, 40.0), (1.743, 2.631, -1.390, 20.0, 40.0), (2.586, 2.943, -1.593, 20.0, 40.0), (-0.512, 2.969, -3.195, 20.0, 40.0), (2.283, -0.100, 4.342, 20.0, 40.0), (-4.293, 0.872, -0.890, 20.0, 40.0), (3.411, 1.300, 2.106, 20.0, 40.0), (-0.281, 2.951, -3.042, 20.0, 40.0), (-4.442, 0.384, 0.012, 20.0, 40.0), (1.194, 1.746, 0.104, 20.0, 40.0), (-1.152, 1.862, -1.300, 20.0, 40.0), (1.362, -1.341, 6.363, 20.0, 40.0), (-4.488, 2.618, -4.481, 20.0, 40.0), (3.419, -0.564, 5.837, 20.0, 40.0), (-3.392, 0.396, 0.512, 20.0, 40.0), (-1.629, -0.909, 4.003, 20.0, 40.0), (4.447, -1.088, 7.399, 20.0, 40.0), (-1.232, 1.699, -1.014, 20.0, 40.0), (-1.286, -0.609, 3.575, 20.0, 40.0), (2.437, 2.796, -1.374, 20.0, 40.0), (-4.864, 1.989, -3.410, 20.0, 40.0), (-1.716, -1.399, 4.940, 20.0, 40.0), (-3.084, 1.858, -2.259, 20.0, 40.0), (2.828, -0.319, 5.053, 20.0, 40.0), (-1.226, 2.586, -2.786, 20.0, 40.0), (2.456, 0.092, 4.044, 20.0, 40.0), (-0.989, 2.375, -2.245, 20.0, 40.0), (3.268, 0.935, 2.765, 20.0, 40.0), (-4.128, -1.995, 4.927, 20.0, 40.0), (-1.083, 2.197, -1.935, 20.0, 40.0), (-3.471, -1.198, 3.660, 20.0, 40.0), (4.617, -1.136, 7.579, 20.0, 40.0), (2.054, -1.675, 7.378, 20.0, 40.0), (4.106, 2.326, 0.402, 20.0, 40.0), (1.558, 0.310, 3.158, 20.0, 40.0), (0.792, 0.900, 1.596, 20.0, 40.0), (-3.229, 0.300, 0.785, 20.0, 40.0), (3.787, -0.793, 6.479, 20.0, 40.0), (1.786, 2.288, -0.684, 20.0, 40.0), (2.643, 0.223, 3.875, 20.0, 40.0), (-3.592, 2.122, -3.040, 20.0, 40.0), (4.519, -1.760, 8.779, 20.0, 40.0), (3.221, 2.255, 0.101, 20.0, 40.0), (4.151, 1.788, 1.500, 20.0, 40.0), (-1.033, -1.195, 4.874, 20.0, 40.0), (-1.636, -1.037, 4.257, 20.0, 40.0), (-3.548, 1.911, -2.596, 20.0, 40.0), (4.829, -0.293, 6.001, 20.0, 40.0), (-4.684, -1.664, 3.986, 20.0, 40.0), (4.531, -0.503, 6.271, 20.0, 40.0), (-3.503, -1.606, 4.460, 20.0, 40.0), (-2.036, -1.522, 5.027, 20.0, 40.0), (-0.473, -0.617, 3.997, 20.0, 40.0), (-1.554, -1.630, 5.483, 20.0, 40.0), (-3.567, -1.043, 3.302, 20.0, 40.0), (-2.038, 0.579, 0.823, 20.0, 40.0), (-3.040, 0.857, -0.233, 20.0, 40.0), (4.610, 0.562, 4.181, 20.0, 40.0), (-3.323, -1.938, 5.215, 20.0, 40.0), (4.314, 1.720, 1.717, 20.0, 40.0), (-1.220, 0.615, 1.161, 20.0, 40.0), (-2.556, 1.120, -0.519, 20.0, 40.0), (-3.717, -0.108, 1.358, 20.0, 40.0), (4.689, -1.826, 8.996, 20.0, 40.0), (3.452, 0.506, 3.713, 20.0, 40.0), (2.472, 0.612, 3.012, 20.0, 40.0), (3.452, 0.450, 3.826, 20.0, 40.0), (1.207, 2.585, -1.567, 20.0, 40.0), (-4.826, 1.090, -1.593, 20.0, 40.0), (3.116, -1.118, 6.794, 20.0, 40.0), (0.448, 2.732, -2.240, 20.0, 40.0), (-1.096, -0.525, 3.503, 20.0, 40.0), (-4.680, -0.238, 1.137, 20.0, 40.0), (2.552, -1.403, 7.082, 20.0, 40.0), (0.719, 2.997, -2.635, 20.0, 40.0), (0.347, -1.966, 7.105, 20.0, 40.0), (2.958, -0.404, 5.288, 20.0, 40.0), (0.722, -1.950, 7.261, 20.0, 40.0), (-2.851, -0.986, 3.546, 20.0, 40.0), (-4.316, -0.439, 1.721, 20.0, 40.0), (-1.685, -0.201, 2.560, 20.0, 40.0), (1.856, 0.190, 3.549, 20.0, 40.0), (-2.052, 0.206, 1.562, 20.0, 40.0), (-2.504, -0.646, 3.041, 20.0, 40.0), (3.235, 0.882, 2.854, 20.0, 40.0), (-1.366, -1.573, 5.463, 20.0, 40.0), (-3.447, 2.419, -3.562, 20.0, 40.0), (4.155, 2.092, 0.893, 20.0, 40.0), (-0.935, 0.209, 2.116, 20.0, 40.0), (3.117, -1.821, 8.201, 20.0, 40.0), (3.759, 0.577, 3.725, 20.0, 40.0), (-0.938, 2.992, -3.453, 20.0, 40.0), (-0.525, 2.341, -1.945, 20.0, 40.0), (4.540, 2.625, 0.019, 20.0, 40.0), (-2.097, 1.190, -0.429, 20.0, 40.0), (-2.672, 1.983, -2.302, 20.0, 40.0), (-3.038, -1.490, 4.460, 20.0, 40.0), (-0.943, 2.149, -1.770, 20.0, 40.0), (0.739, 1.598, 0.174, 20.0, 40.0), (1.828, 1.853, 0.208, 20.0, 40.0), (4.856, 0.137, 5.153, 20.0, 40.0), (-1.617, 0.468, 1.255, 20.0, 40.0), (-1.972, 2.053, -2.092, 20.0, 40.0), (-4.633, 1.389, -2.094, 20.0, 40.0), (-3.628, -1.156, 3.498, 20.0, 40.0), (3.597, 1.034, 2.731, 20.0, 40.0), (-1.488, -0.002, 2.261, 20.0, 40.0), (0.749, 1.921, -0.468, 20.0, 40.0), (1.304, -1.371, 6.394, 20.0, 40.0), (4.587, 2.936, -0.579, 20.0, 40.0), (-2.241, 1.791, -1.703, 20.0, 40.0), (-2.945, 1.372, -1.216, 20.0, 40.0), (1.375, 0.395, 2.898, 20.0, 40.0), (-1.281, -0.641, 3.642, 20.0, 40.0), (2.178, 0.895, 2.299, 20.0, 40.0), (3.031, -0.786, 6.087, 20.0, 40.0), (-1.385, -0.375, 3.058, 20.0, 40.0), (4.041, -0.431, 5.882, 20.0, 40.0), (0.480, -0.507, 4.254, 20.0, 40.0), (-3.797, 0.140, 0.822, 20.0, 40.0), (2.355, 2.502, -0.827, 20.0, 40.0), (1.376, -1.583, 6.854, 20.0, 40.0), (0.164, 1.405, 0.273, 20.0, 40.0), (-1.273, 1.471, -0.579, 20.0, 40.0), (0.770, 2.246, -1.107, 20.0, 40.0), (4.552, 2.904, -0.533, 20.0, 40.0), (4.259, -1.772, 8.674, 20.0, 40.0), (-0.309, 1.159, 0.528, 20.0, 40.0), (3.581, 2.700, -0.610, 20.0, 40.0), (-3.202, 0.346, 0.707, 20.0, 40.0), (-1.575, 1.242, -0.271, 20.0, 40.0), (-1.584, -0.493, 3.194, 20.0, 40.0), (-3.778, 0.150, 0.810, 20.0, 40.0), (-4.675, 1.749, -2.835, 20.0, 40.0), (3.567, -0.792, 6.367, 20.0, 40.0), (-0.417, 1.399, -0.006, 20.0, 40.0), (-4.672, 2.007, -3.349, 20.0, 40.0), (-1.034, 0.196, 2.090, 20.0, 40.0), (-3.796, 2.496, -3.890, 20.0, 40.0), (3.532, -0.497, 5.759, 20.0, 40.0), (4.868, -1.359, 8.151, 20.0, 40.0), (-0.769, 0.302, 2.011, 20.0, 40.0), (4.475, 2.612, 0.014, 20.0, 40.0), (-3.532, -0.395, 2.024, 20.0, 40.0), (0.322, 0.675, 1.812, 20.0, 40.0), (-2.028, -1.942, 5.870, 20.0, 40.0), (1.810, -1.244, 6.392, 20.0, 40.0), (-0.783, 1.242, 0.124, 20.0, 40.0), (-4.745, -1.300, 3.227, 20.0, 40.0), (1.902, 1.973, 0.005, 20.0, 40.0), (-3.453, -1.429, 4.132, 20.0, 40.0), (1.559, 0.986, 1.808, 20.0, 40.0), (0.128, 2.754, -2.443, 20.0, 40.0), (2.759, 1.727, 0.926, 20.0, 40.0), (-4.468, 1.690, -2.614, 20.0, 40.0), (-2.368, -1.922, 5.659, 20.0, 40.0), (-2.766, 2.128, -2.640, 20.0, 40.0), (0.967, -1.825, 7.133, 20.0, 40.0), (-2.854, 2.855, -4.136, 20.0, 40.0), (-2.944, 1.875, -2.222, 20.0, 40.0), (-2.632, -0.983, 3.649, 20.0, 40.0), (2.427, 2.239, -0.266, 20.0, 40.0), (-1.726, -0.838, 3.812, 20.0, 40.0), (0.007, -0.903, 4.809, 20.0, 40.0), (-2.013, 1.092, -0.191, 20.0, 40.0), (-0.449, 0.970, 0.836, 20.0, 40.0), (1.396, 0.411, 2.876, 20.0, 40.0), (-1.115, -1.790, 6.023, 20.0, 40.0), (3.748, 1.917, 1.039, 20.0, 40.0), (2.978, 1.043, 2.404, 20.0, 40.0), (-3.969, 2.514, -4.013, 20.0, 40.0), (4.455, -0.050, 5.328, 20.0, 40.0), (-3.065, -0.846, 3.160, 20.0, 40.0), (-1.069, 2.167, -1.869, 20.0, 40.0), (3.016, -1.393, 7.294, 20.0, 40.0), (0.045, -1.928, 6.879, 20.0, 40.0), (-2.555, -0.984, 3.690, 20.0, 40.0), (-1.995, -0.054, 2.111, 20.0, 40.0), (4.600, -0.509, 6.318, 20.0, 40.0), (-1.942, 1.215, -0.402, 20.0, 40.0), (1.262, 2.765, -1.899, 20.0, 40.0), (2.617, -1.106, 6.521, 20.0, 40.0), (1.737, 0.554, 2.761, 20.0, 40.0), (-2.197, 0.632, 0.638, 20.0, 40.0), (4.768, 2.618, 0.147, 20.0, 40.0), (-3.737, -0.939, 3.010, 20.0, 40.0), (-2.623, 0.595, 0.499, 20.0, 40.0), (4.752, -0.340, 6.057, 20.0, 40.0), (2.333, -1.037, 6.240, 20.0, 40.0), (4.234, -1.882, 8.881, 20.0, 40.0), (-3.393, -0.812, 2.927, 20.0, 40.0), (0.885, 1.383, 0.678, 20.0, 40.0), (0.123, 2.937, -2.812, 20.0, 40.0), (2.969, 0.760, 2.964, 20.0, 40.0), (-4.929, 1.251, -1.967, 20.0, 40.0), (1.916, 2.223, -0.488, 20.0, 40.0), (-0.020, -1.740, 6.469, 20.0, 40.0), (0.702, -1.272, 5.895, 20.0, 40.0), (2.496, 2.648, -1.048, 20.0, 40.0), (4.067, -1.475, 7.984, 20.0, 40.0), (-3.717, 1.851, -2.561, 20.0, 40.0), (1.678, -0.624, 5.088, 20.0, 40.0), (1.073, 0.695, 2.146, 20.0, 40.0), (1.842, -0.749, 5.419, 20.0, 40.0), (-3.518, 1.909, -2.578, 20.0, 40.0), (2.229, 1.189, 1.737, 20.0, 40.0), (4.987, 2.893, -0.292, 20.0, 40.0), (-4.809, 1.043, -1.490, 20.0, 40.0), (-0.241, -0.728, 4.334, 20.0, 40.0), (-3.331, 0.590, 0.156, 20.0, 40.0), (-0.455, 2.621, -2.470, 20.0, 40.0), (1.492, 1.223, 1.301, 20.0, 40.0), (3.948, 2.841, -0.709, 20.0, 40.0), (0.732, 0.446, 2.475, 20.0, 40.0), (2.400, 2.390, -0.579, 20.0, 40.0), (-2.718, 1.427, -1.213, 20.0, 40.0), (-1.826, 1.451, -0.815, 20.0, 40.0), (1.125, 0.438, 2.686, 20.0, 40.0), (-4.918, 1.880, -3.219, 20.0, 40.0), (3.068, -0.442, 5.418, 20.0, 40.0), (1.982, 1.201, 1.589, 20.0, 40.0), (0.701, -1.709, 6.768, 20.0, 40.0), (-1.496, 2.564, -2.877, 20.0, 40.0), (-3.812, 0.974, -0.853, 20.0, 40.0), (-3.405, 2.018, -2.739, 20.0, 40.0), (2.211, 2.889, -1.674, 20.0, 40.0), (-2.481, 2.931, -4.103, 20.0, 40.0), (-3.721, 2.765, -4.391, 20.0, 40.0), (-1.768, -1.292, 4.699, 20.0, 40.0), (-4.462, 1.058, -1.347, 20.0, 40.0), (-3.516, -1.942, 5.126, 20.0, 40.0), (0.485, 2.420, -1.597, 20.0, 40.0), (-0.492, 0.242, 2.270, 20.0, 40.0), (4.245, 1.689, 1.744, 20.0, 40.0), (2.234, 0.364, 3.389, 20.0, 40.0), (2.629, 2.224, -0.134, 20.0, 40.0), (-4.375, 1.221, -1.630, 20.0, 40.0), (-0.618, 1.374, -0.057, 20.0, 40.0), (-2.580, -1.604, 4.918, 20.0, 40.0), (0.159, 1.104, 0.871, 20.0, 40.0), (-3.597, 0.975, -0.749, 20.0, 40.0); -- insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0), (-1.099, 2.755, -3.060, 20.0, 40.0), (1.090, 2.945, -2.346, 20.0, 40.0), (0.305, 2.179, -1.205, 20.0, 40.0), (-0.925, 0.702, 1.134, 20.0, 40.0), (3.178, -1.316, 7.221, 20.0, 40.0), (-2.756, -0.473, 2.569, 20.0, 40.0), (3.665, 2.303, 0.226, 20.0, 40.0), (1.662, 1.951, -0.070, 20.0, 40.0), (2.869, 0.593, 3.249, 20.0, 40.0), (0.818, -0.593, 4.594, 20.0, 40.0), (-1.917, 0.916, 0.209, 20.0, 40.0), (2.706, 1.523, 1.307, 20.0, 40.0), (0.219, 2.162, -1.214, 20.0, 40.0), (-4.510, 1.376, -2.007, 20.0, 40.0), (4.284, -0.515, 6.173, 20.0, 40.0), (-1.101, 2.810, -3.170, 20.0, 40.0), (-1.810, -1.117, 4.329, 20.0, 40.0), (0.055, 1.115, 0.797, 20.0, 40.0), (-2.178, 2.904, -3.898, 20.0, 40.0), (-3.494, -1.814, 4.882, 20.0, 40.0), (3.027, 0.476, 3.562, 20.0, 40.0), (-1.434, 1.151, -0.018, 20.0, 40.0), (1.180, 0.992, 1.606, 20.0, 40.0), (0.015, 0.971, 1.067, 20.0, 40.0), (-0.511, -0.875, 4.495, 20.0, 40.0), (0.961, 2.348, -1.216, 20.0, 40.0), (-2.279, 0.038, 1.785, 20.0, 40.0), (-1.568, -0.248, 2.712, 20.0, 40.0), (-0.496, 0.366, 2.020, 20.0, 40.0), (1.177, -1.401, 6.390, 20.0, 40.0), (2.882, -1.442, 7.325, 20.0, 40.0), (-1.066, 1.817, -1.167, 20.0, 40.0), (-2.144, 2.791, -3.655, 20.0, 40.0), (-4.370, 2.228, -3.642, 20.0, 40.0), (3.996, 2.775, -0.553, 20.0, 40.0), (0.289, 2.055, -0.965, 20.0, 40.0), (-0.588, -1.601, 5.908, 20.0, 40.0), (-1.801, 0.417, 1.265, 20.0, 40.0), (4.375, -1.499, 8.186, 20.0, 40.0), (-2.618, 0.038, 1.615, 20.0, 40.0), (3.616, -0.833, 6.475, 20.0, 40.0), (-4.045, -1.558, 4.094, 20.0, 40.0), (-3.962, 0.636, -0.253, 20.0, 40.0), (3.505, 2.625, -0.497, 20.0, 40.0), (3.029, -0.523, 5.560, 20.0, 40.0), (-3.520, -0.474, 2.188, 20.0, 40.0), (2.430, -1.469, 7.154, 20.0, 40.0), (1.547, -1.654, 7.082, 20.0, 40.0), (-1.370, 0.575, 1.165, 20.0, 40.0), (-1.869, -1.555, 5.176, 20.0, 40.0), (3.536, 2.841, -0.913, 20.0, 40.0), (-3.810, 1.220, -1.344, 20.0, 40.0), (-1.971, 1.462, -0.910, 20.0, 40.0), (-0.243, 0.167, 2.545, 20.0, 40.0), (-1.403, 2.645, -2.991, 20.0, 40.0), (0.532, -0.114, 3.494, 20.0, 40.0), (-1.678, 0.975, 0.212, 20.0, 40.0), (-0.656, 2.140, -1.609, 20.0, 40.0), (1.743, 2.631, -1.390, 20.0, 40.0), (2.586, 2.943, -1.593, 20.0, 40.0), (-0.512, 2.969, -3.195, 20.0, 40.0), (2.283, -0.100, 4.342, 20.0, 40.0), (-4.293, 0.872, -0.890, 20.0, 40.0), (3.411, 1.300, 2.106, 20.0, 40.0), (-0.281, 2.951, -3.042, 20.0, 40.0), (-4.442, 0.384, 0.012, 20.0, 40.0), (1.194, 1.746, 0.104, 20.0, 40.0), (-1.152, 1.862, -1.300, 20.0, 40.0), (1.362, -1.341, 6.363, 20.0, 40.0), (-4.488, 2.618, -4.481, 20.0, 40.0), (3.419, -0.564, 5.837, 20.0, 40.0), (-3.392, 0.396, 0.512, 20.0, 40.0), (-1.629, -0.909, 4.003, 20.0, 40.0), (4.447, -1.088, 7.399, 20.0, 40.0), (-1.232, 1.699, -1.014, 20.0, 40.0), (-1.286, -0.609, 3.575, 20.0, 40.0), (2.437, 2.796, -1.374, 20.0, 40.0), (-4.864, 1.989, -3.410, 20.0, 40.0), (-1.716, -1.399, 4.940, 20.0, 40.0), (-3.084, 1.858, -2.259, 20.0, 40.0), (2.828, -0.319, 5.053, 20.0, 40.0), (-1.226, 2.586, -2.786, 20.0, 40.0), (2.456, 0.092, 4.044, 20.0, 40.0), (-0.989, 2.375, -2.245, 20.0, 40.0), (3.268, 0.935, 2.765, 20.0, 40.0), (-4.128, -1.995, 4.927, 20.0, 40.0), (-1.083, 2.197, -1.935, 20.0, 40.0), (-3.471, -1.198, 3.660, 20.0, 40.0), (4.617, -1.136, 7.579, 20.0, 40.0), (2.054, -1.675, 7.378, 20.0, 40.0), (4.106, 2.326, 0.402, 20.0, 40.0), (1.558, 0.310, 3.158, 20.0, 40.0), (0.792, 0.900, 1.596, 20.0, 40.0), (-3.229, 0.300, 0.785, 20.0, 40.0), (3.787, -0.793, 6.479, 20.0, 40.0), (1.786, 2.288, -0.684, 20.0, 40.0), (2.643, 0.223, 3.875, 20.0, 40.0), (-3.592, 2.122, -3.040, 20.0, 40.0), (4.519, -1.760, 8.779, 20.0, 40.0), (3.221, 2.255, 0.101, 20.0, 40.0), (4.151, 1.788, 1.500, 20.0, 40.0), (-1.033, -1.195, 4.874, 20.0, 40.0), (-1.636, -1.037, 4.257, 20.0, 40.0), (-3.548, 1.911, -2.596, 20.0, 40.0), (4.829, -0.293, 6.001, 20.0, 40.0), (-4.684, -1.664, 3.986, 20.0, 40.0), (4.531, -0.503, 6.271, 20.0, 40.0), (-3.503, -1.606, 4.460, 20.0, 40.0), (-2.036, -1.522, 5.027, 20.0, 40.0), (-0.473, -0.617, 3.997, 20.0, 40.0), (-1.554, -1.630, 5.483, 20.0, 40.0), (-3.567, -1.043, 3.302, 20.0, 40.0), (-2.038, 0.579, 0.823, 20.0, 40.0), (-3.040, 0.857, -0.233, 20.0, 40.0), (4.610, 0.562, 4.181, 20.0, 40.0), (-3.323, -1.938, 5.215, 20.0, 40.0), (4.314, 1.720, 1.717, 20.0, 40.0), (-1.220, 0.615, 1.161, 20.0, 40.0), (-2.556, 1.120, -0.519, 20.0, 40.0), (-3.717, -0.108, 1.358, 20.0, 40.0), (4.689, -1.826, 8.996, 20.0, 40.0), (3.452, 0.506, 3.713, 20.0, 40.0), (2.472, 0.612, 3.012, 20.0, 40.0), (3.452, 0.450, 3.826, 20.0, 40.0), (1.207, 2.585, -1.567, 20.0, 40.0), (-4.826, 1.090, -1.593, 20.0, 40.0), (3.116, -1.118, 6.794, 20.0, 40.0), (0.448, 2.732, -2.240, 20.0, 40.0), (-1.096, -0.525, 3.503, 20.0, 40.0), (-4.680, -0.238, 1.137, 20.0, 40.0), (2.552, -1.403, 7.082, 20.0, 40.0), (0.719, 2.997, -2.635, 20.0, 40.0), (0.347, -1.966, 7.105, 20.0, 40.0), (2.958, -0.404, 5.288, 20.0, 40.0), (0.722, -1.950, 7.261, 20.0, 40.0), (-2.851, -0.986, 3.546, 20.0, 40.0), (-4.316, -0.439, 1.721, 20.0, 40.0), (-1.685, -0.201, 2.560, 20.0, 40.0), (1.856, 0.190, 3.549, 20.0, 40.0), (-2.052, 0.206, 1.562, 20.0, 40.0), (-2.504, -0.646, 3.041, 20.0, 40.0), (3.235, 0.882, 2.854, 20.0, 40.0), (-1.366, -1.573, 5.463, 20.0, 40.0), (-3.447, 2.419, -3.562, 20.0, 40.0), (4.155, 2.092, 0.893, 20.0, 40.0), (-0.935, 0.209, 2.116, 20.0, 40.0), (3.117, -1.821, 8.201, 20.0, 40.0), (3.759, 0.577, 3.725, 20.0, 40.0), (-0.938, 2.992, -3.453, 20.0, 40.0), (-0.525, 2.341, -1.945, 20.0, 40.0), (4.540, 2.625, 0.019, 20.0, 40.0), (-2.097, 1.190, -0.429, 20.0, 40.0), (-2.672, 1.983, -2.302, 20.0, 40.0), (-3.038, -1.490, 4.460, 20.0, 40.0), (-0.943, 2.149, -1.770, 20.0, 40.0), (0.739, 1.598, 0.174, 20.0, 40.0), (1.828, 1.853, 0.208, 20.0, 40.0), (4.856, 0.137, 5.153, 20.0, 40.0), (-1.617, 0.468, 1.255, 20.0, 40.0), (-1.972, 2.053, -2.092, 20.0, 40.0), (-4.633, 1.389, -2.094, 20.0, 40.0), (-3.628, -1.156, 3.498, 20.0, 40.0), (3.597, 1.034, 2.731, 20.0, 40.0), (-1.488, -0.002, 2.261, 20.0, 40.0), (0.749, 1.921, -0.468, 20.0, 40.0), (1.304, -1.371, 6.394, 20.0, 40.0), (4.587, 2.936, -0.579, 20.0, 40.0), (-2.241, 1.791, -1.703, 20.0, 40.0), (-2.945, 1.372, -1.216, 20.0, 40.0), (1.375, 0.395, 2.898, 20.0, 40.0), (-1.281, -0.641, 3.642, 20.0, 40.0), (2.178, 0.895, 2.299, 20.0, 40.0), (3.031, -0.786, 6.087, 20.0, 40.0), (-1.385, -0.375, 3.058, 20.0, 40.0), (4.041, -0.431, 5.882, 20.0, 40.0), (0.480, -0.507, 4.254, 20.0, 40.0), (-3.797, 0.140, 0.822, 20.0, 40.0), (2.355, 2.502, -0.827, 20.0, 40.0), (1.376, -1.583, 6.854, 20.0, 40.0), (0.164, 1.405, 0.273, 20.0, 40.0), (-1.273, 1.471, -0.579, 20.0, 40.0), (0.770, 2.246, -1.107, 20.0, 40.0), (4.552, 2.904, -0.533, 20.0, 40.0), (4.259, -1.772, 8.674, 20.0, 40.0), (-0.309, 1.159, 0.528, 20.0, 40.0), (3.581, 2.700, -0.610, 20.0, 40.0), (-3.202, 0.346, 0.707, 20.0, 40.0), (-1.575, 1.242, -0.271, 20.0, 40.0), (-1.584, -0.493, 3.194, 20.0, 40.0), (-3.778, 0.150, 0.810, 20.0, 40.0), (-4.675, 1.749, -2.835, 20.0, 40.0), (3.567, -0.792, 6.367, 20.0, 40.0), (-0.417, 1.399, -0.006, 20.0, 40.0), (-4.672, 2.007, -3.349, 20.0, 40.0), (-1.034, 0.196, 2.090, 20.0, 40.0), (-3.796, 2.496, -3.890, 20.0, 40.0), (3.532, -0.497, 5.759, 20.0, 40.0), (4.868, -1.359, 8.151, 20.0, 40.0), (-0.769, 0.302, 2.011, 20.0, 40.0), (4.475, 2.612, 0.014, 20.0, 40.0), (-3.532, -0.395, 2.024, 20.0, 40.0), (0.322, 0.675, 1.812, 20.0, 40.0), (-2.028, -1.942, 5.870, 20.0, 40.0), (1.810, -1.244, 6.392, 20.0, 40.0), (-0.783, 1.242, 0.124, 20.0, 40.0), (-4.745, -1.300, 3.227, 20.0, 40.0), (1.902, 1.973, 0.005, 20.0, 40.0), (-3.453, -1.429, 4.132, 20.0, 40.0), (1.559, 0.986, 1.808, 20.0, 40.0), (0.128, 2.754, -2.443, 20.0, 40.0), (2.759, 1.727, 0.926, 20.0, 40.0), (-4.468, 1.690, -2.614, 20.0, 40.0), (-2.368, -1.922, 5.659, 20.0, 40.0), (-2.766, 2.128, -2.640, 20.0, 40.0), (0.967, -1.825, 7.133, 20.0, 40.0), (-2.854, 2.855, -4.136, 20.0, 40.0), (-2.944, 1.875, -2.222, 20.0, 40.0), (-2.632, -0.983, 3.649, 20.0, 40.0), (2.427, 2.239, -0.266, 20.0, 40.0), (-1.726, -0.838, 3.812, 20.0, 40.0), (0.007, -0.903, 4.809, 20.0, 40.0), (-2.013, 1.092, -0.191, 20.0, 40.0), (-0.449, 0.970, 0.836, 20.0, 40.0), (1.396, 0.411, 2.876, 20.0, 40.0), (-1.115, -1.790, 6.023, 20.0, 40.0), (3.748, 1.917, 1.039, 20.0, 40.0), (2.978, 1.043, 2.404, 20.0, 40.0), (-3.969, 2.514, -4.013, 20.0, 40.0), (4.455, -0.050, 5.328, 20.0, 40.0), (-3.065, -0.846, 3.160, 20.0, 40.0), (-1.069, 2.167, -1.869, 20.0, 40.0), (3.016, -1.393, 7.294, 20.0, 40.0), (0.045, -1.928, 6.879, 20.0, 40.0), (-2.555, -0.984, 3.690, 20.0, 40.0), (-1.995, -0.054, 2.111, 20.0, 40.0), (4.600, -0.509, 6.318, 20.0, 40.0), (-1.942, 1.215, -0.402, 20.0, 40.0), (1.262, 2.765, -1.899, 20.0, 40.0), (2.617, -1.106, 6.521, 20.0, 40.0), (1.737, 0.554, 2.761, 20.0, 40.0), (-2.197, 0.632, 0.638, 20.0, 40.0), (4.768, 2.618, 0.147, 20.0, 40.0), (-3.737, -0.939, 3.010, 20.0, 40.0), (-2.623, 0.595, 0.499, 20.0, 40.0), (4.752, -0.340, 6.057, 20.0, 40.0), (2.333, -1.037, 6.240, 20.0, 40.0), (4.234, -1.882, 8.881, 20.0, 40.0), (-3.393, -0.812, 2.927, 20.0, 40.0), (0.885, 1.383, 0.678, 20.0, 40.0), (0.123, 2.937, -2.812, 20.0, 40.0), (2.969, 0.760, 2.964, 20.0, 40.0), (-4.929, 1.251, -1.967, 20.0, 40.0), (1.916, 2.223, -0.488, 20.0, 40.0), (-0.020, -1.740, 6.469, 20.0, 40.0), (0.702, -1.272, 5.895, 20.0, 40.0), (2.496, 2.648, -1.048, 20.0, 40.0), (4.067, -1.475, 7.984, 20.0, 40.0), (-3.717, 1.851, -2.561, 20.0, 40.0), (1.678, -0.624, 5.088, 20.0, 40.0), (1.073, 0.695, 2.146, 20.0, 40.0), (1.842, -0.749, 5.419, 20.0, 40.0), (-3.518, 1.909, -2.578, 20.0, 40.0), (2.229, 1.189, 1.737, 20.0, 40.0), (4.987, 2.893, -0.292, 20.0, 40.0), (-4.809, 1.043, -1.490, 20.0, 40.0), (-0.241, -0.728, 4.334, 20.0, 40.0), (-3.331, 0.590, 0.156, 20.0, 40.0), (-0.455, 2.621, -2.470, 20.0, 40.0), (1.492, 1.223, 1.301, 20.0, 40.0), (3.948, 2.841, -0.709, 20.0, 40.0), (0.732, 0.446, 2.475, 20.0, 40.0), (2.400, 2.390, -0.579, 20.0, 40.0), (-2.718, 1.427, -1.213, 20.0, 40.0), (-1.826, 1.451, -0.815, 20.0, 40.0), (1.125, 0.438, 2.686, 20.0, 40.0), (-4.918, 1.880, -3.219, 20.0, 40.0), (3.068, -0.442, 5.418, 20.0, 40.0), (1.982, 1.201, 1.589, 20.0, 40.0), (0.701, -1.709, 6.768, 20.0, 40.0), (-1.496, 2.564, -2.877, 20.0, 40.0), (-3.812, 0.974, -0.853, 20.0, 40.0), (-3.405, 2.018, -2.739, 20.0, 40.0), (2.211, 2.889, -1.674, 20.0, 40.0), (-2.481, 2.931, -4.103, 20.0, 40.0), (-3.721, 2.765, -4.391, 20.0, 40.0), (-1.768, -1.292, 4.699, 20.0, 40.0), (-4.462, 1.058, -1.347, 20.0, 40.0), (-3.516, -1.942, 5.126, 20.0, 40.0), (0.485, 2.420, -1.597, 20.0, 40.0), (-0.492, 0.242, 2.270, 20.0, 40.0), (4.245, 1.689, 1.744, 20.0, 40.0), (2.234, 0.364, 3.389, 20.0, 40.0), (2.629, 2.224, -0.134, 20.0, 40.0), (-4.375, 1.221, -1.630, 20.0, 40.0), (-0.618, 1.374, -0.057, 20.0, 40.0), (-2.580, -1.604, 4.918, 20.0, 40.0), (0.159, 1.104, 0.871, 20.0, 40.0), (-3.597, 0.975, -0.749, 20.0, 40.0); -- + +insert into test.defaults values (-1.0, -2.0, 3.5, 20.0, 40.0); + DROP TABLE IF EXISTS test.model; create table test.model engine = Memory as select LinearRegressionState(0.1, 5, 1.0)(target, param1, param2) as state from test.defaults; -- -- select toTypeName(state) from test.model; @@ -41,7 +44,16 @@ create table test.model engine = Memory as select LinearRegressionState(0.1, 5, -- -- select multiply(param1, param2) from test.defaults; -- -- -- select evalLinReg(LinRegState(0.01)(target, param1, param2), 20.0, 40.0) from test.defaults; + + + select evalMLMethod(state, predict1, predict2) from test.model cross join test.defaults; + + +-- select evalMLMethod(state, 0.1, 0.2) from test.model; +-- with (select state from test.model) as model select evalMLMethod(model, predict1, predict2) from test.defaults; + + -- -- select evalLinReg(state, predict1, predict2) from test.model inner join (select * from test.tests) using state; -- -- select evalLinReg(state1, predict1, predict2) from test.tests; -- From fc4c721fa557fa46823756291517299fb2529db4 Mon Sep 17 00:00:00 2001 From: alexander kozhikhov Date: Mon, 11 Feb 2019 01:07:47 +0300 Subject: [PATCH 013/709] some review fixes --- .../AggregateFunctionMLMethod.h | 81 ++++++++++--------- dbms/src/Columns/ColumnAggregateFunction.cpp | 6 +- .../tests/queries/0_stateless/00900_stest.sql | 48 ----------- 3 files changed, 48 insertions(+), 87 deletions(-) delete mode 100644 dbms/tests/queries/0_stateless/00900_stest.sql diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h index 4c85d5cff76..545b278cce5 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h @@ -78,14 +78,14 @@ public: Float64 derivative = (target - bias); for (size_t i = 0; i < weights.size(); ++i) { - derivative -= weights[i] * static_cast &>(*columns[i + 1]).getData()[row_num]; + derivative -= weights[i] * static_cast &>(*columns[i]).getData()[row_num]; } derivative *= (2 * learning_rate); batch_gradient[weights.size()] += derivative; for (size_t i = 0; i < weights.size(); ++i) { - batch_gradient[i] += derivative * static_cast &>(*columns[i + 1]).getData()[row_num];; + batch_gradient[i] += derivative * static_cast &>(*columns[i]).getData()[row_num];; } } Float64 predict(const std::vector & predict_feature, const std::vector & weights, Float64 bias) const override @@ -107,6 +107,7 @@ public: return res; } }; + class LogisticRegression : public IGradientComputer { public: @@ -120,7 +121,7 @@ public: Float64 derivative = bias; for (size_t i = 0; i < weights.size(); ++i) { - derivative += weights[i] * static_cast &>(*columns[i + 1]).getData()[row_num];; + derivative += weights[i] * static_cast &>(*columns[i]).getData()[row_num];; } derivative *= target; derivative = learning_rate * exp(derivative); @@ -128,7 +129,7 @@ public: batch_gradient[weights.size()] += target / (derivative + 1);; for (size_t i = 0; i < weights.size(); ++i) { - batch_gradient[i] += target / (derivative + 1) * static_cast &>(*columns[i + 1]).getData()[row_num]; + batch_gradient[i] += target / (derivative + 1) * static_cast &>(*columns[i]).getData()[row_num]; } } Float64 predict(const std::vector & predict_feature, const std::vector & weights, Float64 bias) const override @@ -156,27 +157,32 @@ class IWeightsUpdater public: virtual ~IWeightsUpdater() = default; - virtual void update(UInt32 cur_batch, std::vector & weights, Float64 & bias, const std::vector & gradient) = 0; - virtual void merge(const std::shared_ptr, Float64, Float64) {} + virtual void update(UInt32 batch_size, std::vector & weights, Float64 & bias, const std::vector & gradient) = 0; + virtual void merge(const IWeightsUpdater &, Float64, Float64) {} }; class StochasticGradientDescent : public IWeightsUpdater { public: - void update(UInt32 cur_batch, std::vector & weights, Float64 & bias, const std::vector & batch_gradient) override { + void update(UInt32 batch_size, std::vector & weights, Float64 & bias, const std::vector & batch_gradient) override { + /// batch_size is already checked to be greater than 0 + for (size_t i = 0; i < weights.size(); ++i) { - weights[i] += batch_gradient[i] / cur_batch; + weights[i] += batch_gradient[i] / batch_size; } - bias += batch_gradient[weights.size()] / cur_batch; + bias += batch_gradient[weights.size()] / batch_size; } }; + class Momentum : public IWeightsUpdater { public: Momentum() {} Momentum (Float64 alpha) : alpha_(alpha) {} - void update(UInt32 cur_batch, std::vector & weights, Float64 & bias, const std::vector & batch_gradient) override { + void update(UInt32 batch_size, std::vector & weights, Float64 & bias, const std::vector & batch_gradient) override { + /// batch_size is already checked to be greater than 0 + if (hk_.size() == 0) { hk_.resize(batch_gradient.size(), Float64{0.0}); @@ -187,21 +193,23 @@ public: } for (size_t i = 0; i < weights.size(); ++i) { - weights[i] += hk_[i] / cur_batch; + weights[i] += hk_[i] / batch_size; } - bias += hk_[weights.size()] / cur_batch; + bias += hk_[weights.size()] / batch_size; } - virtual void merge(const std::shared_ptr rhs, Float64 frac, Float64 rhs_frac) override { - auto momentum_rhs = std::dynamic_pointer_cast(rhs); + virtual void merge(const IWeightsUpdater & rhs, Float64 frac, Float64 rhs_frac) override { + const auto & momentum_rhs = dynamic_cast(rhs); for (size_t i = 0; i < hk_.size(); ++i) { - hk_[i] = hk_[i] * frac + momentum_rhs->hk_[i] * rhs_frac; + hk_[i] = hk_[i] * frac + momentum_rhs.hk_[i] * rhs_frac; } } -Float64 alpha_{0.1}; -std::vector hk_; +private: + Float64 alpha_{0.1}; + std::vector hk_; }; + class LinearModelData { public: @@ -210,25 +218,26 @@ public: LinearModelData(Float64 learning_rate, UInt32 param_num, - UInt32 batch_size, + UInt32 batch_capacity, std::shared_ptr gc, std::shared_ptr wu) : learning_rate(learning_rate), - batch_size(batch_size), + batch_capacity(batch_capacity), gradient_computer(std::move(gc)), weights_updater(std::move(wu)) { weights.resize(param_num, Float64{0.0}); - cur_batch = 0; + batch_size = 0; } - - - void add(Float64 target, const IColumn ** columns, size_t row_num) + void add(const IColumn ** columns, size_t row_num) { - gradient_computer->compute(weights, bias, learning_rate, target, columns, row_num); - ++cur_batch; - if (cur_batch == batch_size) + /// first column stores target; features start from (columns + 1) + const auto & target = static_cast &>(*columns[0]).getData()[row_num]; + + gradient_computer->compute(weights, bias, learning_rate, target, columns + 1, row_num); + ++batch_size; + if (batch_size == batch_capacity) { update_state(); } @@ -253,7 +262,7 @@ public: bias = bias * frac + rhs.bias * rhs_frac; iter_num += rhs.iter_num; - weights_updater->merge(rhs.weights_updater, frac, rhs_frac); + weights_updater->merge(*rhs.weights_updater, frac, rhs_frac); } void write(WriteBuffer & buf) const @@ -261,7 +270,7 @@ public: writeBinary(bias, buf); writeBinary(weights, buf); writeBinary(iter_num, buf); - writeBinary(cur_batch, buf); + writeBinary(batch_size, buf); gradient_computer->write(buf); } @@ -270,7 +279,7 @@ public: readBinary(bias, buf); readBinary(weights, buf); readBinary(iter_num, buf); - readBinary(cur_batch, buf); + readBinary(batch_size, buf); gradient_computer->read(buf); } @@ -289,20 +298,20 @@ public: private: std::vector weights; Float64 learning_rate; - UInt32 batch_size; + UInt32 batch_capacity; Float64 bias{0.0}; UInt32 iter_num = 0; - UInt32 cur_batch; + UInt32 batch_size; std::shared_ptr gradient_computer; std::shared_ptr weights_updater; void update_state() { - if (cur_batch == 0) + if (batch_size == 0) return; - weights_updater->update(cur_batch, weights, bias, gradient_computer->get()); - cur_batch = 0; + weights_updater->update(batch_size, weights, bias, gradient_computer->get()); + batch_size = 0; ++iter_num; gradient_computer->reset(); } @@ -343,9 +352,7 @@ public: void add(AggregateDataPtr place, const IColumn ** columns, size_t row_num, Arena *) const override { - const auto & target = static_cast &>(*columns[0]); - - this->data(place).add(target.getData()[row_num], columns, row_num); + this->data(place).add(columns, row_num); } /// хочется не константный rhs diff --git a/dbms/src/Columns/ColumnAggregateFunction.cpp b/dbms/src/Columns/ColumnAggregateFunction.cpp index b9fa94f1956..2afb75ee4b1 100644 --- a/dbms/src/Columns/ColumnAggregateFunction.cpp +++ b/dbms/src/Columns/ColumnAggregateFunction.cpp @@ -128,14 +128,16 @@ MutableColumnPtr ColumnAggregateFunction::predictValues(Block & block, const Col if (ML_function_Linear) { size_t row_num = 0; - for (auto val : data) { + for (auto val : data) + { ML_function_Linear->predictResultInto(val, *res, block, row_num, arguments); ++row_num; } } else if (ML_function_Logistic) { size_t row_num = 0; - for (auto val : data) { + for (auto val : data) + { ML_function_Logistic->predictResultInto(val, *res, block, row_num, arguments); ++row_num; } diff --git a/dbms/tests/queries/0_stateless/00900_stest.sql b/dbms/tests/queries/0_stateless/00900_stest.sql deleted file mode 100644 index 0a0acfdee11..00000000000 --- a/dbms/tests/queries/0_stateless/00900_stest.sql +++ /dev/null @@ -1,48 +0,0 @@ -CREATE DATABASE IF NOT EXISTS test; -DROP TABLE IF EXISTS test.defaults; -CREATE TABLE IF NOT EXISTS test.defaults -( - param1 Float64, - param2 Float64, - target Float64, - predict1 Float64, - predict2 Float64 -) ENGINE = Memory; --- -- insert into test.defaults values (2.533, 0.543, 3.181), (1.999, 1.765, 0.470), (0.631, 2.580, -1.845), (-1.164, 0.889, 0.640), (2.110, 0.768, 2.519), (1.251, 0.483, 2.659), (-3.958, 1.299, -1.576), (-2.152, -1.316, 4.556), (3.269, 1.441, 1.753), (4.206, -1.635, 8.373), (-3.479, -0.544, 2.349), (4.006, 0.167, 4.670), (-4.478, 2.400, -4.039), (1.856, 0.256, 3.417), (1.470, 1.685, 0.366), (-4.052, 2.326, -3.678), (-0.971, -0.969, 4.453), (0.881, -1.848, 7.137), (-1.551, -1.766, 5.756), (-0.988, -0.945, 4.395), (-4.636, 1.074, -1.466), (-4.074, -1.486, 3.934), (0.754, 2.627, -1.877), (1.035, 0.889, 1.738), (3.707, -1.281, 7.415), (-2.215, 1.110, -0.327), (-2.965, -1.316, 4.150), (-3.581, 1.063, -0.917), (0.548, 0.343, 2.588), (3.023, -0.870, 6.251), (4.053, -1.441, 7.909), (-0.750, 0.639, 1.348), (-4.411, 1.636, -2.477), (1.786, 0.398, 3.096), (-2.514, 0.033, 1.676), (4.935, -0.840, 7.148), (1.075, -0.921, 5.380), (-3.418, 2.177, -3.063), (3.122, 1.883, 0.795), (-2.254, -1.389, 4.650), (-4.603, 2.909, -5.119), (-1.886, -1.220, 4.497), (-0.509, -1.498, 5.741), (2.192, 1.882, 0.332), (4.056, -1.108, 7.244), (-1.918, 0.230, 1.581), (4.867, 1.516, 2.401), (-0.993, -0.011, 2.526), (-0.757, -1.192, 5.006), (-4.161, 2.059, -3.198), (2.258, 1.157, 1.814), (-3.878, -0.052, 1.165), (1.915, 2.998, -2.038), (-2.164, 2.379, -2.841), (-0.114, -1.914, 6.772), (3.812, 2.138, 0.630), (-1.863, 1.508, -0.947), (-2.964, 0.398, 0.722), (-2.046, -0.193, 2.363), (-1.525, -0.836, 3.910), (-4.557, -0.582, 1.886), (1.031, -0.461, 4.437), (-0.802, 0.699, 1.201), (3.982, 2.084, 0.824), (-2.243, 2.726, -3.573), (-3.989, -0.803, 2.611), (4.900, 0.253, 4.944), (-1.208, -1.587, 5.571), (0.370, 2.579, -1.972), (2.824, 0.964, 2.484), (-1.290, -0.128, 2.611), (0.190, 2.058, -1.021), (4.058, 2.122, 0.784), (4.879, 0.945, 3.549), (1.119, 1.992, -0.424), (4.050, 2.005, 1.015), (-0.064, 1.485, -0.002), (-2.496, 0.456, 0.840), (-1.835, 1.586, -1.090), (0.603, 1.856, -0.411), (-3.062, -0.966, 3.401), (-3.351, 0.430, 0.465), (-2.724, -1.331, 4.299), (3.291, -1.027, 6.699), (-4.263, 0.785, -0.701), (-3.289, -0.886, 3.128), (4.627, 1.331, 2.651), (-0.618, 0.602, 1.486), (0.056, 1.778, -0.528), (4.823, 1.154, 3.103), (-3.983, 0.509, -0.010), (-4.474, -1.400, 3.563), (-3.782, 2.996, -4.883), (4.515, -0.656, 6.569), (1.269, 2.592, -1.549), (-1.710, -0.241, 2.627), (2.171, 1.453, 1.180), (-1.931, -1.845, 5.726), (1.767, -1.798, 7.480), (4.352, 2.369, 0.438), (-4.498, 2.611, -4.472), (0.067, 0.517, 2.000), (4.151, 0.624, 3.827), (0.409, -0.969, 5.142), (0.193, -1.713, 6.522), (-2.487, 2.827, -3.898), (-4.363, 2.011, -3.203), (-2.383, 2.554, -3.299), (-4.457, -0.958, 2.687), (3.342, -0.360, 5.392), (0.902, 2.978, -2.505), (4.073, -1.524, 8.084), (3.036, 1.672, 1.173), (2.169, -0.564, 5.213), (-4.780, 0.962, -1.313), (-1.815, 2.096, -2.100), (-1.445, 0.458, 1.362), (1.891, -1.437, 6.820), (1.942, -1.761, 7.493), (-4.613, -1.551, 3.795), (-3.472, -1.110, 3.485), (-2.026, 1.961, -1.935), (0.091, -0.961, 4.967), (3.902, -1.336, 7.622), (-3.483, -0.769, 2.796), (-0.066, -1.233, 5.433), (2.597, 2.789, -1.280), (-1.657, -1.842, 5.856), (0.232, -1.420, 5.957), (-3.321, 1.609, -1.879), (2.673, 2.781, -1.226), (0.869, 0.072, 3.291), (1.444, -1.271, 6.264), (1.190, 1.460, 0.675), (3.497, 0.870, 3.008), (-2.884, -1.303, 4.163), (3.620, 0.381, 4.047), (2.594, 0.247, 3.803), (-3.902, -1.315, 3.678), (-4.753, -1.005, 2.634), (0.881, 0.675, 2.091), (0.414, 2.071, -0.935), (3.458, -0.920, 6.568), (-2.986, -0.411, 2.329), (3.076, -1.960, 8.458), (2.951, 2.988, -1.501), (2.408, 1.301, 1.603), (4.725, 0.366, 4.631), (4.924, -1.762, 8.985), (3.719, 0.970, 2.920), (-0.295, 0.257, 2.340), (-4.607, 2.548, -4.400), (0.288, 1.953, -0.761), (-3.311, 0.844, -0.344), (3.679, -0.642, 6.123), (-2.310, -0.838, 3.522), (-4.397, -0.226, 1.254), (-4.366, -0.024, 0.864), (2.405, 1.458, 1.286), (-4.296, -1.071, 2.994), (0.452, -1.901, 7.028), (-0.214, -0.467, 3.827), (2.559, 1.547, 1.185), (0.990, 1.539, 0.417), (0.478, -0.089, 3.417), (-2.734, -1.007, 3.646), (3.483, 0.247, 4.247), (3.507, 2.727, -0.701), (-4.399, 2.437, -4.073), (3.785, 0.036, 4.820), (-0.824, 2.417, -2.245), (-2.588, 0.369, 0.968), (-3.037, -1.639, 4.759), (4.531, -0.499, 6.264), (4.742, -1.161, 7.693), (-0.063, -0.595, 4.159), (0.697, 2.281, -1.212), (0.413, 0.607, 1.992), (-4.081, 0.383, 0.194), (0.712, 2.638, -1.920), (-1.620, 1.092, 0.006), (-3.425, -0.911, 3.109), (-0.124, 1.711, -0.484), (4.347, 1.387, 2.399), (-3.237, -0.900, 3.182), (-3.961, 0.358, 0.304), (4.326, -0.068, 5.298), (3.846, 1.725, 1.473), (-2.089, 0.953, 0.049), (-1.025, -1.470, 5.428), (2.061, -0.156, 4.343), (1.547, -1.827, 7.427), (2.786, 0.460, 3.473), (0.076, 0.659, 1.720), (3.597, 1.966, 0.866), (-0.933, -1.180, 4.894), (4.647, 1.190, 2.943), (-0.032, 0.544, 1.896), (4.461, -1.806, 8.843), (-0.586, 1.821, -0.934), (3.725, 1.715, 1.432), (-2.091, 2.714, -3.474), (4.494, -1.494, 8.236), (3.766, -0.209, 5.301), (-1.991, 1.776, -1.548), (-4.992, -0.742, 1.989), (-2.400, 1.828, -1.855), (-1.329, 0.143, 2.050), (1.954, 1.759, 0.459), (-4.422, 1.507, -2.224), (-2.243, -1.126, 4.131), (4.417, -1.080, 7.368), (1.737, -1.144, 6.157), (2.661, -1.084, 6.498), (-3.198, 0.443, 0.515), (4.191, -1.250, 7.596), (-2.419, -0.163, 2.116), (1.910, -1.173, 6.301), (-0.241, 1.902, -0.925), (-4.415, 2.479, -4.165), (3.307, -0.465, 5.583), (-2.382, 1.364, -0.920), (-3.154, 2.953, -4.483), (-2.562, 2.803, -3.888), (3.076, 0.195, 4.149), (-0.101, 0.896, 1.157), (-2.067, 1.120, -0.273), (-4.680, 2.756, -4.851), (-4.283, -0.607, 2.072), (4.013, -1.072, 7.150), (-4.401, -0.896, 2.591), (4.544, 2.498, 0.276), (4.075, -1.204, 7.445), (-3.463, 1.242, -1.216), (3.992, 2.782, -0.568), (-4.503, 0.239, 0.270), (-3.095, 1.161, -0.870), (0.768, -0.904, 5.192), (1.255, 2.870, -2.112), (-1.537, -0.049, 2.330), (2.851, -1.182, 6.789), (1.974, -0.922, 5.832), (4.447, 2.719, -0.214), (-3.413, 0.555, 0.184), (4.943, 2.120, 1.231), (3.645, -0.413, 5.648), (-4.776, 0.079, 0.453), (1.991, 1.565, 0.866), (2.413, 1.793, 0.620), (4.245, 2.663, -0.205), (-2.022, -1.180, 4.350), (-2.285, -1.246, 4.350), (2.276, 0.488, 3.162), (2.582, -0.037, 4.365), (-4.875, 1.468, -2.374), (-2.492, 2.730, -3.706), (2.696, -1.833, 8.013), (4.618, -1.127, 7.563), (-4.156, 0.987, -1.053), (1.873, -1.566, 7.068), (1.699, 0.794, 2.262), (-3.181, 1.640, -1.871), (-3.225, 1.526, -1.664), (-2.679, -1.811, 5.281), (3.717, 1.532, 1.794), (1.288, -0.999, 5.642), (-1.057, 0.044, 2.384), (-0.147, 1.108, 0.711), (-3.827, -1.139, 3.365), (0.872, -1.482, 6.399), (1.982, 0.286, 3.418), (-1.381, 2.374, -2.439), (-1.091, 2.010, -1.565), (-1.192, 2.751, -3.097), (1.468, -0.992, 5.718), (2.249, 0.949, 2.228), (3.064, 0.911, 2.711), (-1.576, -1.584, 5.380), (2.130, -1.489, 7.043), (4.386, -1.284, 7.761), (1.662, -1.645, 7.121), (-3.395, 1.784, -2.265), (4.618, 1.951, 1.406), (-0.299, 0.378, 2.095), (-2.911, 2.131, -2.717), (0.876, 2.869, -2.301), (-1.785, 0.961, 0.186), (-4.188, 2.442, -3.977), (-1.128, 0.127, 2.181), (1.755, -1.215, 6.307), (-2.276, 0.596, 0.669), (-4.630, 1.978, -3.272), (-0.454, 0.275, 2.224), (-1.950, -1.385, 4.794), (-0.889, 2.696, -2.837), (-4.832, -0.038, 0.661), (3.738, 0.604, 3.662), (-0.224, -0.465, 3.819); -insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0), (-1.099, 2.755, -3.060, 20.0, 40.0), (1.090, 2.945, -2.346, 20.0, 40.0), (0.305, 2.179, -1.205, 20.0, 40.0), (-0.925, 0.702, 1.134, 20.0, 40.0), (3.178, -1.316, 7.221, 20.0, 40.0), (-2.756, -0.473, 2.569, 20.0, 40.0), (3.665, 2.303, 0.226, 20.0, 40.0), (1.662, 1.951, -0.070, 20.0, 40.0), (2.869, 0.593, 3.249, 20.0, 40.0), (0.818, -0.593, 4.594, 20.0, 40.0), (-1.917, 0.916, 0.209, 20.0, 40.0), (2.706, 1.523, 1.307, 20.0, 40.0), (0.219, 2.162, -1.214, 20.0, 40.0), (-4.510, 1.376, -2.007, 20.0, 40.0), (4.284, -0.515, 6.173, 20.0, 40.0), (-1.101, 2.810, -3.170, 20.0, 40.0), (-1.810, -1.117, 4.329, 20.0, 40.0), (0.055, 1.115, 0.797, 20.0, 40.0), (-2.178, 2.904, -3.898, 20.0, 40.0), (-3.494, -1.814, 4.882, 20.0, 40.0), (3.027, 0.476, 3.562, 20.0, 40.0), (-1.434, 1.151, -0.018, 20.0, 40.0), (1.180, 0.992, 1.606, 20.0, 40.0), (0.015, 0.971, 1.067, 20.0, 40.0), (-0.511, -0.875, 4.495, 20.0, 40.0), (0.961, 2.348, -1.216, 20.0, 40.0), (-2.279, 0.038, 1.785, 20.0, 40.0), (-1.568, -0.248, 2.712, 20.0, 40.0), (-0.496, 0.366, 2.020, 20.0, 40.0), (1.177, -1.401, 6.390, 20.0, 40.0), (2.882, -1.442, 7.325, 20.0, 40.0), (-1.066, 1.817, -1.167, 20.0, 40.0), (-2.144, 2.791, -3.655, 20.0, 40.0), (-4.370, 2.228, -3.642, 20.0, 40.0), (3.996, 2.775, -0.553, 20.0, 40.0), (0.289, 2.055, -0.965, 20.0, 40.0), (-0.588, -1.601, 5.908, 20.0, 40.0), (-1.801, 0.417, 1.265, 20.0, 40.0), (4.375, -1.499, 8.186, 20.0, 40.0), (-2.618, 0.038, 1.615, 20.0, 40.0), (3.616, -0.833, 6.475, 20.0, 40.0), (-4.045, -1.558, 4.094, 20.0, 40.0), (-3.962, 0.636, -0.253, 20.0, 40.0), (3.505, 2.625, -0.497, 20.0, 40.0), (3.029, -0.523, 5.560, 20.0, 40.0), (-3.520, -0.474, 2.188, 20.0, 40.0), (2.430, -1.469, 7.154, 20.0, 40.0), (1.547, -1.654, 7.082, 20.0, 40.0), (-1.370, 0.575, 1.165, 20.0, 40.0), (-1.869, -1.555, 5.176, 20.0, 40.0), (3.536, 2.841, -0.913, 20.0, 40.0), (-3.810, 1.220, -1.344, 20.0, 40.0), (-1.971, 1.462, -0.910, 20.0, 40.0), (-0.243, 0.167, 2.545, 20.0, 40.0), (-1.403, 2.645, -2.991, 20.0, 40.0), (0.532, -0.114, 3.494, 20.0, 40.0), (-1.678, 0.975, 0.212, 20.0, 40.0), (-0.656, 2.140, -1.609, 20.0, 40.0), (1.743, 2.631, -1.390, 20.0, 40.0), (2.586, 2.943, -1.593, 20.0, 40.0), (-0.512, 2.969, -3.195, 20.0, 40.0), (2.283, -0.100, 4.342, 20.0, 40.0), (-4.293, 0.872, -0.890, 20.0, 40.0), (3.411, 1.300, 2.106, 20.0, 40.0), (-0.281, 2.951, -3.042, 20.0, 40.0), (-4.442, 0.384, 0.012, 20.0, 40.0), (1.194, 1.746, 0.104, 20.0, 40.0), (-1.152, 1.862, -1.300, 20.0, 40.0), (1.362, -1.341, 6.363, 20.0, 40.0), (-4.488, 2.618, -4.481, 20.0, 40.0), (3.419, -0.564, 5.837, 20.0, 40.0), (-3.392, 0.396, 0.512, 20.0, 40.0), (-1.629, -0.909, 4.003, 20.0, 40.0), (4.447, -1.088, 7.399, 20.0, 40.0), (-1.232, 1.699, -1.014, 20.0, 40.0), (-1.286, -0.609, 3.575, 20.0, 40.0), (2.437, 2.796, -1.374, 20.0, 40.0), (-4.864, 1.989, -3.410, 20.0, 40.0), (-1.716, -1.399, 4.940, 20.0, 40.0), (-3.084, 1.858, -2.259, 20.0, 40.0), (2.828, -0.319, 5.053, 20.0, 40.0), (-1.226, 2.586, -2.786, 20.0, 40.0), (2.456, 0.092, 4.044, 20.0, 40.0), (-0.989, 2.375, -2.245, 20.0, 40.0), (3.268, 0.935, 2.765, 20.0, 40.0), (-4.128, -1.995, 4.927, 20.0, 40.0), (-1.083, 2.197, -1.935, 20.0, 40.0), (-3.471, -1.198, 3.660, 20.0, 40.0), (4.617, -1.136, 7.579, 20.0, 40.0), (2.054, -1.675, 7.378, 20.0, 40.0), (4.106, 2.326, 0.402, 20.0, 40.0), (1.558, 0.310, 3.158, 20.0, 40.0), (0.792, 0.900, 1.596, 20.0, 40.0), (-3.229, 0.300, 0.785, 20.0, 40.0), (3.787, -0.793, 6.479, 20.0, 40.0), (1.786, 2.288, -0.684, 20.0, 40.0), (2.643, 0.223, 3.875, 20.0, 40.0), (-3.592, 2.122, -3.040, 20.0, 40.0), (4.519, -1.760, 8.779, 20.0, 40.0), (3.221, 2.255, 0.101, 20.0, 40.0), (4.151, 1.788, 1.500, 20.0, 40.0), (-1.033, -1.195, 4.874, 20.0, 40.0), (-1.636, -1.037, 4.257, 20.0, 40.0), (-3.548, 1.911, -2.596, 20.0, 40.0), (4.829, -0.293, 6.001, 20.0, 40.0), (-4.684, -1.664, 3.986, 20.0, 40.0), (4.531, -0.503, 6.271, 20.0, 40.0), (-3.503, -1.606, 4.460, 20.0, 40.0), (-2.036, -1.522, 5.027, 20.0, 40.0), (-0.473, -0.617, 3.997, 20.0, 40.0), (-1.554, -1.630, 5.483, 20.0, 40.0), (-3.567, -1.043, 3.302, 20.0, 40.0), (-2.038, 0.579, 0.823, 20.0, 40.0), (-3.040, 0.857, -0.233, 20.0, 40.0), (4.610, 0.562, 4.181, 20.0, 40.0), (-3.323, -1.938, 5.215, 20.0, 40.0), (4.314, 1.720, 1.717, 20.0, 40.0), (-1.220, 0.615, 1.161, 20.0, 40.0), (-2.556, 1.120, -0.519, 20.0, 40.0), (-3.717, -0.108, 1.358, 20.0, 40.0), (4.689, -1.826, 8.996, 20.0, 40.0), (3.452, 0.506, 3.713, 20.0, 40.0), (2.472, 0.612, 3.012, 20.0, 40.0), (3.452, 0.450, 3.826, 20.0, 40.0), (1.207, 2.585, -1.567, 20.0, 40.0), (-4.826, 1.090, -1.593, 20.0, 40.0), (3.116, -1.118, 6.794, 20.0, 40.0), (0.448, 2.732, -2.240, 20.0, 40.0), (-1.096, -0.525, 3.503, 20.0, 40.0), (-4.680, -0.238, 1.137, 20.0, 40.0), (2.552, -1.403, 7.082, 20.0, 40.0), (0.719, 2.997, -2.635, 20.0, 40.0), (0.347, -1.966, 7.105, 20.0, 40.0), (2.958, -0.404, 5.288, 20.0, 40.0), (0.722, -1.950, 7.261, 20.0, 40.0), (-2.851, -0.986, 3.546, 20.0, 40.0), (-4.316, -0.439, 1.721, 20.0, 40.0), (-1.685, -0.201, 2.560, 20.0, 40.0), (1.856, 0.190, 3.549, 20.0, 40.0), (-2.052, 0.206, 1.562, 20.0, 40.0), (-2.504, -0.646, 3.041, 20.0, 40.0), (3.235, 0.882, 2.854, 20.0, 40.0), (-1.366, -1.573, 5.463, 20.0, 40.0), (-3.447, 2.419, -3.562, 20.0, 40.0), (4.155, 2.092, 0.893, 20.0, 40.0), (-0.935, 0.209, 2.116, 20.0, 40.0), (3.117, -1.821, 8.201, 20.0, 40.0), (3.759, 0.577, 3.725, 20.0, 40.0), (-0.938, 2.992, -3.453, 20.0, 40.0), (-0.525, 2.341, -1.945, 20.0, 40.0), (4.540, 2.625, 0.019, 20.0, 40.0), (-2.097, 1.190, -0.429, 20.0, 40.0), (-2.672, 1.983, -2.302, 20.0, 40.0), (-3.038, -1.490, 4.460, 20.0, 40.0), (-0.943, 2.149, -1.770, 20.0, 40.0), (0.739, 1.598, 0.174, 20.0, 40.0), (1.828, 1.853, 0.208, 20.0, 40.0), (4.856, 0.137, 5.153, 20.0, 40.0), (-1.617, 0.468, 1.255, 20.0, 40.0), (-1.972, 2.053, -2.092, 20.0, 40.0), (-4.633, 1.389, -2.094, 20.0, 40.0), (-3.628, -1.156, 3.498, 20.0, 40.0), (3.597, 1.034, 2.731, 20.0, 40.0), (-1.488, -0.002, 2.261, 20.0, 40.0), (0.749, 1.921, -0.468, 20.0, 40.0), (1.304, -1.371, 6.394, 20.0, 40.0), (4.587, 2.936, -0.579, 20.0, 40.0), (-2.241, 1.791, -1.703, 20.0, 40.0), (-2.945, 1.372, -1.216, 20.0, 40.0), (1.375, 0.395, 2.898, 20.0, 40.0), (-1.281, -0.641, 3.642, 20.0, 40.0), (2.178, 0.895, 2.299, 20.0, 40.0), (3.031, -0.786, 6.087, 20.0, 40.0), (-1.385, -0.375, 3.058, 20.0, 40.0), (4.041, -0.431, 5.882, 20.0, 40.0), (0.480, -0.507, 4.254, 20.0, 40.0), (-3.797, 0.140, 0.822, 20.0, 40.0), (2.355, 2.502, -0.827, 20.0, 40.0), (1.376, -1.583, 6.854, 20.0, 40.0), (0.164, 1.405, 0.273, 20.0, 40.0), (-1.273, 1.471, -0.579, 20.0, 40.0), (0.770, 2.246, -1.107, 20.0, 40.0), (4.552, 2.904, -0.533, 20.0, 40.0), (4.259, -1.772, 8.674, 20.0, 40.0), (-0.309, 1.159, 0.528, 20.0, 40.0), (3.581, 2.700, -0.610, 20.0, 40.0), (-3.202, 0.346, 0.707, 20.0, 40.0), (-1.575, 1.242, -0.271, 20.0, 40.0), (-1.584, -0.493, 3.194, 20.0, 40.0), (-3.778, 0.150, 0.810, 20.0, 40.0), (-4.675, 1.749, -2.835, 20.0, 40.0), (3.567, -0.792, 6.367, 20.0, 40.0), (-0.417, 1.399, -0.006, 20.0, 40.0), (-4.672, 2.007, -3.349, 20.0, 40.0), (-1.034, 0.196, 2.090, 20.0, 40.0), (-3.796, 2.496, -3.890, 20.0, 40.0), (3.532, -0.497, 5.759, 20.0, 40.0), (4.868, -1.359, 8.151, 20.0, 40.0), (-0.769, 0.302, 2.011, 20.0, 40.0), (4.475, 2.612, 0.014, 20.0, 40.0), (-3.532, -0.395, 2.024, 20.0, 40.0), (0.322, 0.675, 1.812, 20.0, 40.0), (-2.028, -1.942, 5.870, 20.0, 40.0), (1.810, -1.244, 6.392, 20.0, 40.0), (-0.783, 1.242, 0.124, 20.0, 40.0), (-4.745, -1.300, 3.227, 20.0, 40.0), (1.902, 1.973, 0.005, 20.0, 40.0), (-3.453, -1.429, 4.132, 20.0, 40.0), (1.559, 0.986, 1.808, 20.0, 40.0), (0.128, 2.754, -2.443, 20.0, 40.0), (2.759, 1.727, 0.926, 20.0, 40.0), (-4.468, 1.690, -2.614, 20.0, 40.0), (-2.368, -1.922, 5.659, 20.0, 40.0), (-2.766, 2.128, -2.640, 20.0, 40.0), (0.967, -1.825, 7.133, 20.0, 40.0), (-2.854, 2.855, -4.136, 20.0, 40.0), (-2.944, 1.875, -2.222, 20.0, 40.0), (-2.632, -0.983, 3.649, 20.0, 40.0), (2.427, 2.239, -0.266, 20.0, 40.0), (-1.726, -0.838, 3.812, 20.0, 40.0), (0.007, -0.903, 4.809, 20.0, 40.0), (-2.013, 1.092, -0.191, 20.0, 40.0), (-0.449, 0.970, 0.836, 20.0, 40.0), (1.396, 0.411, 2.876, 20.0, 40.0), (-1.115, -1.790, 6.023, 20.0, 40.0), (3.748, 1.917, 1.039, 20.0, 40.0), (2.978, 1.043, 2.404, 20.0, 40.0), (-3.969, 2.514, -4.013, 20.0, 40.0), (4.455, -0.050, 5.328, 20.0, 40.0), (-3.065, -0.846, 3.160, 20.0, 40.0), (-1.069, 2.167, -1.869, 20.0, 40.0), (3.016, -1.393, 7.294, 20.0, 40.0), (0.045, -1.928, 6.879, 20.0, 40.0), (-2.555, -0.984, 3.690, 20.0, 40.0), (-1.995, -0.054, 2.111, 20.0, 40.0), (4.600, -0.509, 6.318, 20.0, 40.0), (-1.942, 1.215, -0.402, 20.0, 40.0), (1.262, 2.765, -1.899, 20.0, 40.0), (2.617, -1.106, 6.521, 20.0, 40.0), (1.737, 0.554, 2.761, 20.0, 40.0), (-2.197, 0.632, 0.638, 20.0, 40.0), (4.768, 2.618, 0.147, 20.0, 40.0), (-3.737, -0.939, 3.010, 20.0, 40.0), (-2.623, 0.595, 0.499, 20.0, 40.0), (4.752, -0.340, 6.057, 20.0, 40.0), (2.333, -1.037, 6.240, 20.0, 40.0), (4.234, -1.882, 8.881, 20.0, 40.0), (-3.393, -0.812, 2.927, 20.0, 40.0), (0.885, 1.383, 0.678, 20.0, 40.0), (0.123, 2.937, -2.812, 20.0, 40.0), (2.969, 0.760, 2.964, 20.0, 40.0), (-4.929, 1.251, -1.967, 20.0, 40.0), (1.916, 2.223, -0.488, 20.0, 40.0), (-0.020, -1.740, 6.469, 20.0, 40.0), (0.702, -1.272, 5.895, 20.0, 40.0), (2.496, 2.648, -1.048, 20.0, 40.0), (4.067, -1.475, 7.984, 20.0, 40.0), (-3.717, 1.851, -2.561, 20.0, 40.0), (1.678, -0.624, 5.088, 20.0, 40.0), (1.073, 0.695, 2.146, 20.0, 40.0), (1.842, -0.749, 5.419, 20.0, 40.0), (-3.518, 1.909, -2.578, 20.0, 40.0), (2.229, 1.189, 1.737, 20.0, 40.0), (4.987, 2.893, -0.292, 20.0, 40.0), (-4.809, 1.043, -1.490, 20.0, 40.0), (-0.241, -0.728, 4.334, 20.0, 40.0), (-3.331, 0.590, 0.156, 20.0, 40.0), (-0.455, 2.621, -2.470, 20.0, 40.0), (1.492, 1.223, 1.301, 20.0, 40.0), (3.948, 2.841, -0.709, 20.0, 40.0), (0.732, 0.446, 2.475, 20.0, 40.0), (2.400, 2.390, -0.579, 20.0, 40.0), (-2.718, 1.427, -1.213, 20.0, 40.0), (-1.826, 1.451, -0.815, 20.0, 40.0), (1.125, 0.438, 2.686, 20.0, 40.0), (-4.918, 1.880, -3.219, 20.0, 40.0), (3.068, -0.442, 5.418, 20.0, 40.0), (1.982, 1.201, 1.589, 20.0, 40.0), (0.701, -1.709, 6.768, 20.0, 40.0), (-1.496, 2.564, -2.877, 20.0, 40.0), (-3.812, 0.974, -0.853, 20.0, 40.0), (-3.405, 2.018, -2.739, 20.0, 40.0), (2.211, 2.889, -1.674, 20.0, 40.0), (-2.481, 2.931, -4.103, 20.0, 40.0), (-3.721, 2.765, -4.391, 20.0, 40.0), (-1.768, -1.292, 4.699, 20.0, 40.0), (-4.462, 1.058, -1.347, 20.0, 40.0), (-3.516, -1.942, 5.126, 20.0, 40.0), (0.485, 2.420, -1.597, 20.0, 40.0), (-0.492, 0.242, 2.270, 20.0, 40.0), (4.245, 1.689, 1.744, 20.0, 40.0), (2.234, 0.364, 3.389, 20.0, 40.0), (2.629, 2.224, -0.134, 20.0, 40.0), (-4.375, 1.221, -1.630, 20.0, 40.0), (-0.618, 1.374, -0.057, 20.0, 40.0), (-2.580, -1.604, 4.918, 20.0, 40.0), (0.159, 1.104, 0.871, 20.0, 40.0), (-3.597, 0.975, -0.749, 20.0, 40.0); --- insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0), (-1.099, 2.755, -3.060, 20.0, 40.0), (1.090, 2.945, -2.346, 20.0, 40.0), (0.305, 2.179, -1.205, 20.0, 40.0), (-0.925, 0.702, 1.134, 20.0, 40.0), (3.178, -1.316, 7.221, 20.0, 40.0), (-2.756, -0.473, 2.569, 20.0, 40.0), (3.665, 2.303, 0.226, 20.0, 40.0), (1.662, 1.951, -0.070, 20.0, 40.0), (2.869, 0.593, 3.249, 20.0, 40.0), (0.818, -0.593, 4.594, 20.0, 40.0), (-1.917, 0.916, 0.209, 20.0, 40.0), (2.706, 1.523, 1.307, 20.0, 40.0), (0.219, 2.162, -1.214, 20.0, 40.0), (-4.510, 1.376, -2.007, 20.0, 40.0), (4.284, -0.515, 6.173, 20.0, 40.0), (-1.101, 2.810, -3.170, 20.0, 40.0), (-1.810, -1.117, 4.329, 20.0, 40.0), (0.055, 1.115, 0.797, 20.0, 40.0), (-2.178, 2.904, -3.898, 20.0, 40.0), (-3.494, -1.814, 4.882, 20.0, 40.0), (3.027, 0.476, 3.562, 20.0, 40.0), (-1.434, 1.151, -0.018, 20.0, 40.0), (1.180, 0.992, 1.606, 20.0, 40.0), (0.015, 0.971, 1.067, 20.0, 40.0), (-0.511, -0.875, 4.495, 20.0, 40.0), (0.961, 2.348, -1.216, 20.0, 40.0), (-2.279, 0.038, 1.785, 20.0, 40.0), (-1.568, -0.248, 2.712, 20.0, 40.0), (-0.496, 0.366, 2.020, 20.0, 40.0), (1.177, -1.401, 6.390, 20.0, 40.0), (2.882, -1.442, 7.325, 20.0, 40.0), (-1.066, 1.817, -1.167, 20.0, 40.0), (-2.144, 2.791, -3.655, 20.0, 40.0), (-4.370, 2.228, -3.642, 20.0, 40.0), (3.996, 2.775, -0.553, 20.0, 40.0), (0.289, 2.055, -0.965, 20.0, 40.0), (-0.588, -1.601, 5.908, 20.0, 40.0), (-1.801, 0.417, 1.265, 20.0, 40.0), (4.375, -1.499, 8.186, 20.0, 40.0), (-2.618, 0.038, 1.615, 20.0, 40.0), (3.616, -0.833, 6.475, 20.0, 40.0), (-4.045, -1.558, 4.094, 20.0, 40.0), (-3.962, 0.636, -0.253, 20.0, 40.0), (3.505, 2.625, -0.497, 20.0, 40.0), (3.029, -0.523, 5.560, 20.0, 40.0), (-3.520, -0.474, 2.188, 20.0, 40.0), (2.430, -1.469, 7.154, 20.0, 40.0), (1.547, -1.654, 7.082, 20.0, 40.0), (-1.370, 0.575, 1.165, 20.0, 40.0), (-1.869, -1.555, 5.176, 20.0, 40.0), (3.536, 2.841, -0.913, 20.0, 40.0), (-3.810, 1.220, -1.344, 20.0, 40.0), (-1.971, 1.462, -0.910, 20.0, 40.0), (-0.243, 0.167, 2.545, 20.0, 40.0), (-1.403, 2.645, -2.991, 20.0, 40.0), (0.532, -0.114, 3.494, 20.0, 40.0), (-1.678, 0.975, 0.212, 20.0, 40.0), (-0.656, 2.140, -1.609, 20.0, 40.0), (1.743, 2.631, -1.390, 20.0, 40.0), (2.586, 2.943, -1.593, 20.0, 40.0), (-0.512, 2.969, -3.195, 20.0, 40.0), (2.283, -0.100, 4.342, 20.0, 40.0), (-4.293, 0.872, -0.890, 20.0, 40.0), (3.411, 1.300, 2.106, 20.0, 40.0), (-0.281, 2.951, -3.042, 20.0, 40.0), (-4.442, 0.384, 0.012, 20.0, 40.0), (1.194, 1.746, 0.104, 20.0, 40.0), (-1.152, 1.862, -1.300, 20.0, 40.0), (1.362, -1.341, 6.363, 20.0, 40.0), (-4.488, 2.618, -4.481, 20.0, 40.0), (3.419, -0.564, 5.837, 20.0, 40.0), (-3.392, 0.396, 0.512, 20.0, 40.0), (-1.629, -0.909, 4.003, 20.0, 40.0), (4.447, -1.088, 7.399, 20.0, 40.0), (-1.232, 1.699, -1.014, 20.0, 40.0), (-1.286, -0.609, 3.575, 20.0, 40.0), (2.437, 2.796, -1.374, 20.0, 40.0), (-4.864, 1.989, -3.410, 20.0, 40.0), (-1.716, -1.399, 4.940, 20.0, 40.0), (-3.084, 1.858, -2.259, 20.0, 40.0), (2.828, -0.319, 5.053, 20.0, 40.0), (-1.226, 2.586, -2.786, 20.0, 40.0), (2.456, 0.092, 4.044, 20.0, 40.0), (-0.989, 2.375, -2.245, 20.0, 40.0), (3.268, 0.935, 2.765, 20.0, 40.0), (-4.128, -1.995, 4.927, 20.0, 40.0), (-1.083, 2.197, -1.935, 20.0, 40.0), (-3.471, -1.198, 3.660, 20.0, 40.0), (4.617, -1.136, 7.579, 20.0, 40.0), (2.054, -1.675, 7.378, 20.0, 40.0), (4.106, 2.326, 0.402, 20.0, 40.0), (1.558, 0.310, 3.158, 20.0, 40.0), (0.792, 0.900, 1.596, 20.0, 40.0), (-3.229, 0.300, 0.785, 20.0, 40.0), (3.787, -0.793, 6.479, 20.0, 40.0), (1.786, 2.288, -0.684, 20.0, 40.0), (2.643, 0.223, 3.875, 20.0, 40.0), (-3.592, 2.122, -3.040, 20.0, 40.0), (4.519, -1.760, 8.779, 20.0, 40.0), (3.221, 2.255, 0.101, 20.0, 40.0), (4.151, 1.788, 1.500, 20.0, 40.0), (-1.033, -1.195, 4.874, 20.0, 40.0), (-1.636, -1.037, 4.257, 20.0, 40.0), (-3.548, 1.911, -2.596, 20.0, 40.0), (4.829, -0.293, 6.001, 20.0, 40.0), (-4.684, -1.664, 3.986, 20.0, 40.0), (4.531, -0.503, 6.271, 20.0, 40.0), (-3.503, -1.606, 4.460, 20.0, 40.0), (-2.036, -1.522, 5.027, 20.0, 40.0), (-0.473, -0.617, 3.997, 20.0, 40.0), (-1.554, -1.630, 5.483, 20.0, 40.0), (-3.567, -1.043, 3.302, 20.0, 40.0), (-2.038, 0.579, 0.823, 20.0, 40.0), (-3.040, 0.857, -0.233, 20.0, 40.0), (4.610, 0.562, 4.181, 20.0, 40.0), (-3.323, -1.938, 5.215, 20.0, 40.0), (4.314, 1.720, 1.717, 20.0, 40.0), (-1.220, 0.615, 1.161, 20.0, 40.0), (-2.556, 1.120, -0.519, 20.0, 40.0), (-3.717, -0.108, 1.358, 20.0, 40.0), (4.689, -1.826, 8.996, 20.0, 40.0), (3.452, 0.506, 3.713, 20.0, 40.0), (2.472, 0.612, 3.012, 20.0, 40.0), (3.452, 0.450, 3.826, 20.0, 40.0), (1.207, 2.585, -1.567, 20.0, 40.0), (-4.826, 1.090, -1.593, 20.0, 40.0), (3.116, -1.118, 6.794, 20.0, 40.0), (0.448, 2.732, -2.240, 20.0, 40.0), (-1.096, -0.525, 3.503, 20.0, 40.0), (-4.680, -0.238, 1.137, 20.0, 40.0), (2.552, -1.403, 7.082, 20.0, 40.0), (0.719, 2.997, -2.635, 20.0, 40.0), (0.347, -1.966, 7.105, 20.0, 40.0), (2.958, -0.404, 5.288, 20.0, 40.0), (0.722, -1.950, 7.261, 20.0, 40.0), (-2.851, -0.986, 3.546, 20.0, 40.0), (-4.316, -0.439, 1.721, 20.0, 40.0), (-1.685, -0.201, 2.560, 20.0, 40.0), (1.856, 0.190, 3.549, 20.0, 40.0), (-2.052, 0.206, 1.562, 20.0, 40.0), (-2.504, -0.646, 3.041, 20.0, 40.0), (3.235, 0.882, 2.854, 20.0, 40.0), (-1.366, -1.573, 5.463, 20.0, 40.0), (-3.447, 2.419, -3.562, 20.0, 40.0), (4.155, 2.092, 0.893, 20.0, 40.0), (-0.935, 0.209, 2.116, 20.0, 40.0), (3.117, -1.821, 8.201, 20.0, 40.0), (3.759, 0.577, 3.725, 20.0, 40.0), (-0.938, 2.992, -3.453, 20.0, 40.0), (-0.525, 2.341, -1.945, 20.0, 40.0), (4.540, 2.625, 0.019, 20.0, 40.0), (-2.097, 1.190, -0.429, 20.0, 40.0), (-2.672, 1.983, -2.302, 20.0, 40.0), (-3.038, -1.490, 4.460, 20.0, 40.0), (-0.943, 2.149, -1.770, 20.0, 40.0), (0.739, 1.598, 0.174, 20.0, 40.0), (1.828, 1.853, 0.208, 20.0, 40.0), (4.856, 0.137, 5.153, 20.0, 40.0), (-1.617, 0.468, 1.255, 20.0, 40.0), (-1.972, 2.053, -2.092, 20.0, 40.0), (-4.633, 1.389, -2.094, 20.0, 40.0), (-3.628, -1.156, 3.498, 20.0, 40.0), (3.597, 1.034, 2.731, 20.0, 40.0), (-1.488, -0.002, 2.261, 20.0, 40.0), (0.749, 1.921, -0.468, 20.0, 40.0), (1.304, -1.371, 6.394, 20.0, 40.0), (4.587, 2.936, -0.579, 20.0, 40.0), (-2.241, 1.791, -1.703, 20.0, 40.0), (-2.945, 1.372, -1.216, 20.0, 40.0), (1.375, 0.395, 2.898, 20.0, 40.0), (-1.281, -0.641, 3.642, 20.0, 40.0), (2.178, 0.895, 2.299, 20.0, 40.0), (3.031, -0.786, 6.087, 20.0, 40.0), (-1.385, -0.375, 3.058, 20.0, 40.0), (4.041, -0.431, 5.882, 20.0, 40.0), (0.480, -0.507, 4.254, 20.0, 40.0), (-3.797, 0.140, 0.822, 20.0, 40.0), (2.355, 2.502, -0.827, 20.0, 40.0), (1.376, -1.583, 6.854, 20.0, 40.0), (0.164, 1.405, 0.273, 20.0, 40.0), (-1.273, 1.471, -0.579, 20.0, 40.0), (0.770, 2.246, -1.107, 20.0, 40.0), (4.552, 2.904, -0.533, 20.0, 40.0), (4.259, -1.772, 8.674, 20.0, 40.0), (-0.309, 1.159, 0.528, 20.0, 40.0), (3.581, 2.700, -0.610, 20.0, 40.0), (-3.202, 0.346, 0.707, 20.0, 40.0), (-1.575, 1.242, -0.271, 20.0, 40.0), (-1.584, -0.493, 3.194, 20.0, 40.0), (-3.778, 0.150, 0.810, 20.0, 40.0), (-4.675, 1.749, -2.835, 20.0, 40.0), (3.567, -0.792, 6.367, 20.0, 40.0), (-0.417, 1.399, -0.006, 20.0, 40.0), (-4.672, 2.007, -3.349, 20.0, 40.0), (-1.034, 0.196, 2.090, 20.0, 40.0), (-3.796, 2.496, -3.890, 20.0, 40.0), (3.532, -0.497, 5.759, 20.0, 40.0), (4.868, -1.359, 8.151, 20.0, 40.0), (-0.769, 0.302, 2.011, 20.0, 40.0), (4.475, 2.612, 0.014, 20.0, 40.0), (-3.532, -0.395, 2.024, 20.0, 40.0), (0.322, 0.675, 1.812, 20.0, 40.0), (-2.028, -1.942, 5.870, 20.0, 40.0), (1.810, -1.244, 6.392, 20.0, 40.0), (-0.783, 1.242, 0.124, 20.0, 40.0), (-4.745, -1.300, 3.227, 20.0, 40.0), (1.902, 1.973, 0.005, 20.0, 40.0), (-3.453, -1.429, 4.132, 20.0, 40.0), (1.559, 0.986, 1.808, 20.0, 40.0), (0.128, 2.754, -2.443, 20.0, 40.0), (2.759, 1.727, 0.926, 20.0, 40.0), (-4.468, 1.690, -2.614, 20.0, 40.0), (-2.368, -1.922, 5.659, 20.0, 40.0), (-2.766, 2.128, -2.640, 20.0, 40.0), (0.967, -1.825, 7.133, 20.0, 40.0), (-2.854, 2.855, -4.136, 20.0, 40.0), (-2.944, 1.875, -2.222, 20.0, 40.0), (-2.632, -0.983, 3.649, 20.0, 40.0), (2.427, 2.239, -0.266, 20.0, 40.0), (-1.726, -0.838, 3.812, 20.0, 40.0), (0.007, -0.903, 4.809, 20.0, 40.0), (-2.013, 1.092, -0.191, 20.0, 40.0), (-0.449, 0.970, 0.836, 20.0, 40.0), (1.396, 0.411, 2.876, 20.0, 40.0), (-1.115, -1.790, 6.023, 20.0, 40.0), (3.748, 1.917, 1.039, 20.0, 40.0), (2.978, 1.043, 2.404, 20.0, 40.0), (-3.969, 2.514, -4.013, 20.0, 40.0), (4.455, -0.050, 5.328, 20.0, 40.0), (-3.065, -0.846, 3.160, 20.0, 40.0), (-1.069, 2.167, -1.869, 20.0, 40.0), (3.016, -1.393, 7.294, 20.0, 40.0), (0.045, -1.928, 6.879, 20.0, 40.0), (-2.555, -0.984, 3.690, 20.0, 40.0), (-1.995, -0.054, 2.111, 20.0, 40.0), (4.600, -0.509, 6.318, 20.0, 40.0), (-1.942, 1.215, -0.402, 20.0, 40.0), (1.262, 2.765, -1.899, 20.0, 40.0), (2.617, -1.106, 6.521, 20.0, 40.0), (1.737, 0.554, 2.761, 20.0, 40.0), (-2.197, 0.632, 0.638, 20.0, 40.0), (4.768, 2.618, 0.147, 20.0, 40.0), (-3.737, -0.939, 3.010, 20.0, 40.0), (-2.623, 0.595, 0.499, 20.0, 40.0), (4.752, -0.340, 6.057, 20.0, 40.0), (2.333, -1.037, 6.240, 20.0, 40.0), (4.234, -1.882, 8.881, 20.0, 40.0), (-3.393, -0.812, 2.927, 20.0, 40.0), (0.885, 1.383, 0.678, 20.0, 40.0), (0.123, 2.937, -2.812, 20.0, 40.0), (2.969, 0.760, 2.964, 20.0, 40.0), (-4.929, 1.251, -1.967, 20.0, 40.0), (1.916, 2.223, -0.488, 20.0, 40.0), (-0.020, -1.740, 6.469, 20.0, 40.0), (0.702, -1.272, 5.895, 20.0, 40.0), (2.496, 2.648, -1.048, 20.0, 40.0), (4.067, -1.475, 7.984, 20.0, 40.0), (-3.717, 1.851, -2.561, 20.0, 40.0), (1.678, -0.624, 5.088, 20.0, 40.0), (1.073, 0.695, 2.146, 20.0, 40.0), (1.842, -0.749, 5.419, 20.0, 40.0), (-3.518, 1.909, -2.578, 20.0, 40.0), (2.229, 1.189, 1.737, 20.0, 40.0), (4.987, 2.893, -0.292, 20.0, 40.0), (-4.809, 1.043, -1.490, 20.0, 40.0), (-0.241, -0.728, 4.334, 20.0, 40.0), (-3.331, 0.590, 0.156, 20.0, 40.0), (-0.455, 2.621, -2.470, 20.0, 40.0), (1.492, 1.223, 1.301, 20.0, 40.0), (3.948, 2.841, -0.709, 20.0, 40.0), (0.732, 0.446, 2.475, 20.0, 40.0), (2.400, 2.390, -0.579, 20.0, 40.0), (-2.718, 1.427, -1.213, 20.0, 40.0), (-1.826, 1.451, -0.815, 20.0, 40.0), (1.125, 0.438, 2.686, 20.0, 40.0), (-4.918, 1.880, -3.219, 20.0, 40.0), (3.068, -0.442, 5.418, 20.0, 40.0), (1.982, 1.201, 1.589, 20.0, 40.0), (0.701, -1.709, 6.768, 20.0, 40.0), (-1.496, 2.564, -2.877, 20.0, 40.0), (-3.812, 0.974, -0.853, 20.0, 40.0), (-3.405, 2.018, -2.739, 20.0, 40.0), (2.211, 2.889, -1.674, 20.0, 40.0), (-2.481, 2.931, -4.103, 20.0, 40.0), (-3.721, 2.765, -4.391, 20.0, 40.0), (-1.768, -1.292, 4.699, 20.0, 40.0), (-4.462, 1.058, -1.347, 20.0, 40.0), (-3.516, -1.942, 5.126, 20.0, 40.0), (0.485, 2.420, -1.597, 20.0, 40.0), (-0.492, 0.242, 2.270, 20.0, 40.0), (4.245, 1.689, 1.744, 20.0, 40.0), (2.234, 0.364, 3.389, 20.0, 40.0), (2.629, 2.224, -0.134, 20.0, 40.0), (-4.375, 1.221, -1.630, 20.0, 40.0), (-0.618, 1.374, -0.057, 20.0, 40.0), (-2.580, -1.604, 4.918, 20.0, 40.0), (0.159, 1.104, 0.871, 20.0, 40.0), (-3.597, 0.975, -0.749, 20.0, 40.0); --- -DROP TABLE IF EXISTS test.model; -create table test.model engine = Memory as select LinearRegressionState(0.1, 5, 2.0)(target, param1, param2) as state from test.defaults; --- -- select toTypeName(state) from test.model; --- -- --- -- DROP TABLE IF EXISTS test.tests; --- -- CREATE TABLE IF NOT EXISTS test.tests --- -- ( --- -- predict1 Float64, --- -- predict2 Float64, --- -- state1 AggregateFunction(LinReg(0.01), Float64, Float64, Float64) --- -- ) ENGINE = Memory; --- -- insert into test.tests select 20.0, 40.0, LinRegState(0.01)(target, param1, param2) from test.defaults; --- -- select evalLinReg(state1, predict1, predict2) from test.tests; --- --- --- --- -- DROP TABLE IF EXISTS test.prediction; --- -- CREATE TABLE IF NOT EXISTS test.prediction --- -- ( --- -- predict1 Float64, --- -- predict2 Float64 --- -- ) ENGINE = Memory; --- --- --- -- insert into test.prediction values (20.0, 40.0); --- --- -- select multiply(param1, param2) from test.defaults; --- --- -- select evalLinReg(LinRegState(0.01)(target, param1, param2), 20.0, 40.0) from test.defaults; -select evalMLMethod(state, predict1, predict2) from test.model cross join test.defaults; --- -- select evalLinReg(state, predict1, predict2) from test.model inner join (select * from test.tests) using state; --- -- select evalLinReg(state1, predict1, predict2) from test.tests; --- --- -- select negate(target) from test.defaults; From 6a8542c8f6e524607b08e3ab00b02a0b3fb36d99 Mon Sep 17 00:00:00 2001 From: alexander kozhikhov Date: Wed, 13 Feb 2019 00:18:27 +0300 Subject: [PATCH 014/709] constructor changes change --- .../AggregateFunctions/AggregateFunctionMLMethod.cpp | 2 +- .../AggregateFunctions/AggregateFunctionMLMethod.h | 7 +++++-- ...0900_mytest.reference => 00950_ml_test.reference} | 0 .../{00900_stest.sql => 00950_ml_test.sql} | 12 +++++++----- 4 files changed, 13 insertions(+), 8 deletions(-) rename dbms/tests/queries/0_stateless/{00900_mytest.reference => 00950_ml_test.reference} (100%) rename dbms/tests/queries/0_stateless/{00900_stest.sql => 00950_ml_test.sql} (63%) diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp index 116a62b8408..04d31f918d0 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp @@ -73,7 +73,7 @@ AggregateFunctionPtr createAggregateFunctionMLMethod( if (argument_types.size() < 2) throw Exception("Aggregate function " + name + " requires at least two arguments", ErrorCodes::NUMBER_OF_ARGUMENTS_DOESNT_MATCH); - return std::make_shared(argument_types.size() - 1, gc, wu, learning_rate, batch_size); + return std::make_shared(argument_types.size() - 1, gc, wu, learning_rate, batch_size, argument_types, parameters); } } diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h index 9fde4174d4f..f9e12832f15 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h @@ -375,8 +375,11 @@ public: std::shared_ptr gradient_computer, std::shared_ptr weights_updater, Float64 learning_rate, - UInt32 batch_size) - : param_num(param_num), + UInt32 batch_size, + const DataTypes & argument_types, + const Array & params) + : IAggregateFunctionDataHelper>(argument_types, params), + param_num(param_num), learning_rate(learning_rate), batch_size(batch_size), gc(std::move(gradient_computer)), diff --git a/dbms/tests/queries/0_stateless/00900_mytest.reference b/dbms/tests/queries/0_stateless/00950_ml_test.reference similarity index 100% rename from dbms/tests/queries/0_stateless/00900_mytest.reference rename to dbms/tests/queries/0_stateless/00950_ml_test.reference diff --git a/dbms/tests/queries/0_stateless/00900_stest.sql b/dbms/tests/queries/0_stateless/00950_ml_test.sql similarity index 63% rename from dbms/tests/queries/0_stateless/00900_stest.sql rename to dbms/tests/queries/0_stateless/00950_ml_test.sql index 739de5aae35..4c1abb78bb6 100644 --- a/dbms/tests/queries/0_stateless/00900_stest.sql +++ b/dbms/tests/queries/0_stateless/00950_ml_test.sql @@ -1,6 +1,6 @@ CREATE DATABASE IF NOT EXISTS test; -DROP TABLE IF EXISTS test.defaults; -CREATE TABLE IF NOT EXISTS test.defaults +DROP TABLE IF EXISTS test.mldata; +CREATE TABLE IF NOT EXISTS test.mldata ( param1 Float64, param2 Float64, @@ -9,11 +9,13 @@ CREATE TABLE IF NOT EXISTS test.defaults predict2 Float64 ) ENGINE = Memory; -- -- insert into test.defaults values (2.533, 0.543, 3.181), (1.999, 1.765, 0.470), (0.631, 2.580, -1.845), (-1.164, 0.889, 0.640), (2.110, 0.768, 2.519), (1.251, 0.483, 2.659), (-3.958, 1.299, -1.576), (-2.152, -1.316, 4.556), (3.269, 1.441, 1.753), (4.206, -1.635, 8.373), (-3.479, -0.544, 2.349), (4.006, 0.167, 4.670), (-4.478, 2.400, -4.039), (1.856, 0.256, 3.417), (1.470, 1.685, 0.366), (-4.052, 2.326, -3.678), (-0.971, -0.969, 4.453), (0.881, -1.848, 7.137), (-1.551, -1.766, 5.756), (-0.988, -0.945, 4.395), (-4.636, 1.074, -1.466), (-4.074, -1.486, 3.934), (0.754, 2.627, -1.877), (1.035, 0.889, 1.738), (3.707, -1.281, 7.415), (-2.215, 1.110, -0.327), (-2.965, -1.316, 4.150), (-3.581, 1.063, -0.917), (0.548, 0.343, 2.588), (3.023, -0.870, 6.251), (4.053, -1.441, 7.909), (-0.750, 0.639, 1.348), (-4.411, 1.636, -2.477), (1.786, 0.398, 3.096), (-2.514, 0.033, 1.676), (4.935, -0.840, 7.148), (1.075, -0.921, 5.380), (-3.418, 2.177, -3.063), (3.122, 1.883, 0.795), (-2.254, -1.389, 4.650), (-4.603, 2.909, -5.119), (-1.886, -1.220, 4.497), (-0.509, -1.498, 5.741), (2.192, 1.882, 0.332), (4.056, -1.108, 7.244), (-1.918, 0.230, 1.581), (4.867, 1.516, 2.401), (-0.993, -0.011, 2.526), (-0.757, -1.192, 5.006), (-4.161, 2.059, -3.198), (2.258, 1.157, 1.814), (-3.878, -0.052, 1.165), (1.915, 2.998, -2.038), (-2.164, 2.379, -2.841), (-0.114, -1.914, 6.772), (3.812, 2.138, 0.630), (-1.863, 1.508, -0.947), (-2.964, 0.398, 0.722), (-2.046, -0.193, 2.363), (-1.525, -0.836, 3.910), (-4.557, -0.582, 1.886), (1.031, -0.461, 4.437), (-0.802, 0.699, 1.201), (3.982, 2.084, 0.824), (-2.243, 2.726, -3.573), (-3.989, -0.803, 2.611), (4.900, 0.253, 4.944), (-1.208, -1.587, 5.571), (0.370, 2.579, -1.972), (2.824, 0.964, 2.484), (-1.290, -0.128, 2.611), (0.190, 2.058, -1.021), (4.058, 2.122, 0.784), (4.879, 0.945, 3.549), (1.119, 1.992, -0.424), (4.050, 2.005, 1.015), (-0.064, 1.485, -0.002), (-2.496, 0.456, 0.840), (-1.835, 1.586, -1.090), (0.603, 1.856, -0.411), (-3.062, -0.966, 3.401), (-3.351, 0.430, 0.465), (-2.724, -1.331, 4.299), (3.291, -1.027, 6.699), (-4.263, 0.785, -0.701), (-3.289, -0.886, 3.128), (4.627, 1.331, 2.651), (-0.618, 0.602, 1.486), (0.056, 1.778, -0.528), (4.823, 1.154, 3.103), (-3.983, 0.509, -0.010), (-4.474, -1.400, 3.563), (-3.782, 2.996, -4.883), (4.515, -0.656, 6.569), (1.269, 2.592, -1.549), (-1.710, -0.241, 2.627), (2.171, 1.453, 1.180), (-1.931, -1.845, 5.726), (1.767, -1.798, 7.480), (4.352, 2.369, 0.438), (-4.498, 2.611, -4.472), (0.067, 0.517, 2.000), (4.151, 0.624, 3.827), (0.409, -0.969, 5.142), (0.193, -1.713, 6.522), (-2.487, 2.827, -3.898), (-4.363, 2.011, -3.203), (-2.383, 2.554, -3.299), (-4.457, -0.958, 2.687), (3.342, -0.360, 5.392), (0.902, 2.978, -2.505), (4.073, -1.524, 8.084), (3.036, 1.672, 1.173), (2.169, -0.564, 5.213), (-4.780, 0.962, -1.313), (-1.815, 2.096, -2.100), (-1.445, 0.458, 1.362), (1.891, -1.437, 6.820), (1.942, -1.761, 7.493), (-4.613, -1.551, 3.795), (-3.472, -1.110, 3.485), (-2.026, 1.961, -1.935), (0.091, -0.961, 4.967), (3.902, -1.336, 7.622), (-3.483, -0.769, 2.796), (-0.066, -1.233, 5.433), (2.597, 2.789, -1.280), (-1.657, -1.842, 5.856), (0.232, -1.420, 5.957), (-3.321, 1.609, -1.879), (2.673, 2.781, -1.226), (0.869, 0.072, 3.291), (1.444, -1.271, 6.264), (1.190, 1.460, 0.675), (3.497, 0.870, 3.008), (-2.884, -1.303, 4.163), (3.620, 0.381, 4.047), (2.594, 0.247, 3.803), (-3.902, -1.315, 3.678), (-4.753, -1.005, 2.634), (0.881, 0.675, 2.091), (0.414, 2.071, -0.935), (3.458, -0.920, 6.568), (-2.986, -0.411, 2.329), (3.076, -1.960, 8.458), (2.951, 2.988, -1.501), (2.408, 1.301, 1.603), (4.725, 0.366, 4.631), (4.924, -1.762, 8.985), (3.719, 0.970, 2.920), (-0.295, 0.257, 2.340), (-4.607, 2.548, -4.400), (0.288, 1.953, -0.761), (-3.311, 0.844, -0.344), (3.679, -0.642, 6.123), (-2.310, -0.838, 3.522), (-4.397, -0.226, 1.254), (-4.366, -0.024, 0.864), (2.405, 1.458, 1.286), (-4.296, -1.071, 2.994), (0.452, -1.901, 7.028), (-0.214, -0.467, 3.827), (2.559, 1.547, 1.185), (0.990, 1.539, 0.417), (0.478, -0.089, 3.417), (-2.734, -1.007, 3.646), (3.483, 0.247, 4.247), (3.507, 2.727, -0.701), (-4.399, 2.437, -4.073), (3.785, 0.036, 4.820), (-0.824, 2.417, -2.245), (-2.588, 0.369, 0.968), (-3.037, -1.639, 4.759), (4.531, -0.499, 6.264), (4.742, -1.161, 7.693), (-0.063, -0.595, 4.159), (0.697, 2.281, -1.212), (0.413, 0.607, 1.992), (-4.081, 0.383, 0.194), (0.712, 2.638, -1.920), (-1.620, 1.092, 0.006), (-3.425, -0.911, 3.109), (-0.124, 1.711, -0.484), (4.347, 1.387, 2.399), (-3.237, -0.900, 3.182), (-3.961, 0.358, 0.304), (4.326, -0.068, 5.298), (3.846, 1.725, 1.473), (-2.089, 0.953, 0.049), (-1.025, -1.470, 5.428), (2.061, -0.156, 4.343), (1.547, -1.827, 7.427), (2.786, 0.460, 3.473), (0.076, 0.659, 1.720), (3.597, 1.966, 0.866), (-0.933, -1.180, 4.894), (4.647, 1.190, 2.943), (-0.032, 0.544, 1.896), (4.461, -1.806, 8.843), (-0.586, 1.821, -0.934), (3.725, 1.715, 1.432), (-2.091, 2.714, -3.474), (4.494, -1.494, 8.236), (3.766, -0.209, 5.301), (-1.991, 1.776, -1.548), (-4.992, -0.742, 1.989), (-2.400, 1.828, -1.855), (-1.329, 0.143, 2.050), (1.954, 1.759, 0.459), (-4.422, 1.507, -2.224), (-2.243, -1.126, 4.131), (4.417, -1.080, 7.368), (1.737, -1.144, 6.157), (2.661, -1.084, 6.498), (-3.198, 0.443, 0.515), (4.191, -1.250, 7.596), (-2.419, -0.163, 2.116), (1.910, -1.173, 6.301), (-0.241, 1.902, -0.925), (-4.415, 2.479, -4.165), (3.307, -0.465, 5.583), (-2.382, 1.364, -0.920), (-3.154, 2.953, -4.483), (-2.562, 2.803, -3.888), (3.076, 0.195, 4.149), (-0.101, 0.896, 1.157), (-2.067, 1.120, -0.273), (-4.680, 2.756, -4.851), (-4.283, -0.607, 2.072), (4.013, -1.072, 7.150), (-4.401, -0.896, 2.591), (4.544, 2.498, 0.276), (4.075, -1.204, 7.445), (-3.463, 1.242, -1.216), (3.992, 2.782, -0.568), (-4.503, 0.239, 0.270), (-3.095, 1.161, -0.870), (0.768, -0.904, 5.192), (1.255, 2.870, -2.112), (-1.537, -0.049, 2.330), (2.851, -1.182, 6.789), (1.974, -0.922, 5.832), (4.447, 2.719, -0.214), (-3.413, 0.555, 0.184), (4.943, 2.120, 1.231), (3.645, -0.413, 5.648), (-4.776, 0.079, 0.453), (1.991, 1.565, 0.866), (2.413, 1.793, 0.620), (4.245, 2.663, -0.205), (-2.022, -1.180, 4.350), (-2.285, -1.246, 4.350), (2.276, 0.488, 3.162), (2.582, -0.037, 4.365), (-4.875, 1.468, -2.374), (-2.492, 2.730, -3.706), (2.696, -1.833, 8.013), (4.618, -1.127, 7.563), (-4.156, 0.987, -1.053), (1.873, -1.566, 7.068), (1.699, 0.794, 2.262), (-3.181, 1.640, -1.871), (-3.225, 1.526, -1.664), (-2.679, -1.811, 5.281), (3.717, 1.532, 1.794), (1.288, -0.999, 5.642), (-1.057, 0.044, 2.384), (-0.147, 1.108, 0.711), (-3.827, -1.139, 3.365), (0.872, -1.482, 6.399), (1.982, 0.286, 3.418), (-1.381, 2.374, -2.439), (-1.091, 2.010, -1.565), (-1.192, 2.751, -3.097), (1.468, -0.992, 5.718), (2.249, 0.949, 2.228), (3.064, 0.911, 2.711), (-1.576, -1.584, 5.380), (2.130, -1.489, 7.043), (4.386, -1.284, 7.761), (1.662, -1.645, 7.121), (-3.395, 1.784, -2.265), (4.618, 1.951, 1.406), (-0.299, 0.378, 2.095), (-2.911, 2.131, -2.717), (0.876, 2.869, -2.301), (-1.785, 0.961, 0.186), (-4.188, 2.442, -3.977), (-1.128, 0.127, 2.181), (1.755, -1.215, 6.307), (-2.276, 0.596, 0.669), (-4.630, 1.978, -3.272), (-0.454, 0.275, 2.224), (-1.950, -1.385, 4.794), (-0.889, 2.696, -2.837), (-4.832, -0.038, 0.661), (3.738, 0.604, 3.662), (-0.224, -0.465, 3.819); -insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0), (-1.099, 2.755, -3.060, 20.0, 40.0), (1.090, 2.945, -2.346, 20.0, 40.0), (0.305, 2.179, -1.205, 20.0, 40.0), (-0.925, 0.702, 1.134, 20.0, 40.0), (3.178, -1.316, 7.221, 20.0, 40.0), (-2.756, -0.473, 2.569, 20.0, 40.0), (3.665, 2.303, 0.226, 20.0, 40.0), (1.662, 1.951, -0.070, 20.0, 40.0), (2.869, 0.593, 3.249, 20.0, 40.0), (0.818, -0.593, 4.594, 20.0, 40.0), (-1.917, 0.916, 0.209, 20.0, 40.0), (2.706, 1.523, 1.307, 20.0, 40.0), (0.219, 2.162, -1.214, 20.0, 40.0), (-4.510, 1.376, -2.007, 20.0, 40.0), (4.284, -0.515, 6.173, 20.0, 40.0), (-1.101, 2.810, -3.170, 20.0, 40.0), (-1.810, -1.117, 4.329, 20.0, 40.0), (0.055, 1.115, 0.797, 20.0, 40.0), (-2.178, 2.904, -3.898, 20.0, 40.0), (-3.494, -1.814, 4.882, 20.0, 40.0), (3.027, 0.476, 3.562, 20.0, 40.0), (-1.434, 1.151, -0.018, 20.0, 40.0), (1.180, 0.992, 1.606, 20.0, 40.0), (0.015, 0.971, 1.067, 20.0, 40.0), (-0.511, -0.875, 4.495, 20.0, 40.0), (0.961, 2.348, -1.216, 20.0, 40.0), (-2.279, 0.038, 1.785, 20.0, 40.0), (-1.568, -0.248, 2.712, 20.0, 40.0), (-0.496, 0.366, 2.020, 20.0, 40.0), (1.177, -1.401, 6.390, 20.0, 40.0), (2.882, -1.442, 7.325, 20.0, 40.0), (-1.066, 1.817, -1.167, 20.0, 40.0), (-2.144, 2.791, -3.655, 20.0, 40.0), (-4.370, 2.228, -3.642, 20.0, 40.0), (3.996, 2.775, -0.553, 20.0, 40.0), (0.289, 2.055, -0.965, 20.0, 40.0), (-0.588, -1.601, 5.908, 20.0, 40.0), (-1.801, 0.417, 1.265, 20.0, 40.0), (4.375, -1.499, 8.186, 20.0, 40.0), (-2.618, 0.038, 1.615, 20.0, 40.0), (3.616, -0.833, 6.475, 20.0, 40.0), (-4.045, -1.558, 4.094, 20.0, 40.0), (-3.962, 0.636, -0.253, 20.0, 40.0), (3.505, 2.625, -0.497, 20.0, 40.0), (3.029, -0.523, 5.560, 20.0, 40.0), (-3.520, -0.474, 2.188, 20.0, 40.0), (2.430, -1.469, 7.154, 20.0, 40.0), (1.547, -1.654, 7.082, 20.0, 40.0), (-1.370, 0.575, 1.165, 20.0, 40.0), (-1.869, -1.555, 5.176, 20.0, 40.0), (3.536, 2.841, -0.913, 20.0, 40.0), (-3.810, 1.220, -1.344, 20.0, 40.0), (-1.971, 1.462, -0.910, 20.0, 40.0), (-0.243, 0.167, 2.545, 20.0, 40.0), (-1.403, 2.645, -2.991, 20.0, 40.0), (0.532, -0.114, 3.494, 20.0, 40.0), (-1.678, 0.975, 0.212, 20.0, 40.0), (-0.656, 2.140, -1.609, 20.0, 40.0), (1.743, 2.631, -1.390, 20.0, 40.0), (2.586, 2.943, -1.593, 20.0, 40.0), (-0.512, 2.969, -3.195, 20.0, 40.0), (2.283, -0.100, 4.342, 20.0, 40.0), (-4.293, 0.872, -0.890, 20.0, 40.0), (3.411, 1.300, 2.106, 20.0, 40.0), (-0.281, 2.951, -3.042, 20.0, 40.0), (-4.442, 0.384, 0.012, 20.0, 40.0), (1.194, 1.746, 0.104, 20.0, 40.0), (-1.152, 1.862, -1.300, 20.0, 40.0), (1.362, -1.341, 6.363, 20.0, 40.0), (-4.488, 2.618, -4.481, 20.0, 40.0), (3.419, -0.564, 5.837, 20.0, 40.0), (-3.392, 0.396, 0.512, 20.0, 40.0), (-1.629, -0.909, 4.003, 20.0, 40.0), (4.447, -1.088, 7.399, 20.0, 40.0), (-1.232, 1.699, -1.014, 20.0, 40.0), (-1.286, -0.609, 3.575, 20.0, 40.0), (2.437, 2.796, -1.374, 20.0, 40.0), (-4.864, 1.989, -3.410, 20.0, 40.0), (-1.716, -1.399, 4.940, 20.0, 40.0), (-3.084, 1.858, -2.259, 20.0, 40.0), (2.828, -0.319, 5.053, 20.0, 40.0), (-1.226, 2.586, -2.786, 20.0, 40.0), (2.456, 0.092, 4.044, 20.0, 40.0), (-0.989, 2.375, -2.245, 20.0, 40.0), (3.268, 0.935, 2.765, 20.0, 40.0), (-4.128, -1.995, 4.927, 20.0, 40.0), (-1.083, 2.197, -1.935, 20.0, 40.0), (-3.471, -1.198, 3.660, 20.0, 40.0), (4.617, -1.136, 7.579, 20.0, 40.0), (2.054, -1.675, 7.378, 20.0, 40.0), (4.106, 2.326, 0.402, 20.0, 40.0), (1.558, 0.310, 3.158, 20.0, 40.0), (0.792, 0.900, 1.596, 20.0, 40.0), (-3.229, 0.300, 0.785, 20.0, 40.0), (3.787, -0.793, 6.479, 20.0, 40.0), (1.786, 2.288, -0.684, 20.0, 40.0), (2.643, 0.223, 3.875, 20.0, 40.0), (-3.592, 2.122, -3.040, 20.0, 40.0), (4.519, -1.760, 8.779, 20.0, 40.0), (3.221, 2.255, 0.101, 20.0, 40.0), (4.151, 1.788, 1.500, 20.0, 40.0), (-1.033, -1.195, 4.874, 20.0, 40.0), (-1.636, -1.037, 4.257, 20.0, 40.0), (-3.548, 1.911, -2.596, 20.0, 40.0), (4.829, -0.293, 6.001, 20.0, 40.0), (-4.684, -1.664, 3.986, 20.0, 40.0), (4.531, -0.503, 6.271, 20.0, 40.0), (-3.503, -1.606, 4.460, 20.0, 40.0), (-2.036, -1.522, 5.027, 20.0, 40.0), (-0.473, -0.617, 3.997, 20.0, 40.0), (-1.554, -1.630, 5.483, 20.0, 40.0), (-3.567, -1.043, 3.302, 20.0, 40.0), (-2.038, 0.579, 0.823, 20.0, 40.0), (-3.040, 0.857, -0.233, 20.0, 40.0), (4.610, 0.562, 4.181, 20.0, 40.0), (-3.323, -1.938, 5.215, 20.0, 40.0), (4.314, 1.720, 1.717, 20.0, 40.0), (-1.220, 0.615, 1.161, 20.0, 40.0), (-2.556, 1.120, -0.519, 20.0, 40.0), (-3.717, -0.108, 1.358, 20.0, 40.0), (4.689, -1.826, 8.996, 20.0, 40.0), (3.452, 0.506, 3.713, 20.0, 40.0), (2.472, 0.612, 3.012, 20.0, 40.0), (3.452, 0.450, 3.826, 20.0, 40.0), (1.207, 2.585, -1.567, 20.0, 40.0), (-4.826, 1.090, -1.593, 20.0, 40.0), (3.116, -1.118, 6.794, 20.0, 40.0), (0.448, 2.732, -2.240, 20.0, 40.0), (-1.096, -0.525, 3.503, 20.0, 40.0), (-4.680, -0.238, 1.137, 20.0, 40.0), (2.552, -1.403, 7.082, 20.0, 40.0), (0.719, 2.997, -2.635, 20.0, 40.0), (0.347, -1.966, 7.105, 20.0, 40.0), (2.958, -0.404, 5.288, 20.0, 40.0), (0.722, -1.950, 7.261, 20.0, 40.0), (-2.851, -0.986, 3.546, 20.0, 40.0), (-4.316, -0.439, 1.721, 20.0, 40.0), (-1.685, -0.201, 2.560, 20.0, 40.0), (1.856, 0.190, 3.549, 20.0, 40.0), (-2.052, 0.206, 1.562, 20.0, 40.0), (-2.504, -0.646, 3.041, 20.0, 40.0), (3.235, 0.882, 2.854, 20.0, 40.0), (-1.366, -1.573, 5.463, 20.0, 40.0), (-3.447, 2.419, -3.562, 20.0, 40.0), (4.155, 2.092, 0.893, 20.0, 40.0), (-0.935, 0.209, 2.116, 20.0, 40.0), (3.117, -1.821, 8.201, 20.0, 40.0), (3.759, 0.577, 3.725, 20.0, 40.0), (-0.938, 2.992, -3.453, 20.0, 40.0), (-0.525, 2.341, -1.945, 20.0, 40.0), (4.540, 2.625, 0.019, 20.0, 40.0), (-2.097, 1.190, -0.429, 20.0, 40.0), (-2.672, 1.983, -2.302, 20.0, 40.0), (-3.038, -1.490, 4.460, 20.0, 40.0), (-0.943, 2.149, -1.770, 20.0, 40.0), (0.739, 1.598, 0.174, 20.0, 40.0), (1.828, 1.853, 0.208, 20.0, 40.0), (4.856, 0.137, 5.153, 20.0, 40.0), (-1.617, 0.468, 1.255, 20.0, 40.0), (-1.972, 2.053, -2.092, 20.0, 40.0), (-4.633, 1.389, -2.094, 20.0, 40.0), (-3.628, -1.156, 3.498, 20.0, 40.0), (3.597, 1.034, 2.731, 20.0, 40.0), (-1.488, -0.002, 2.261, 20.0, 40.0), (0.749, 1.921, -0.468, 20.0, 40.0), (1.304, -1.371, 6.394, 20.0, 40.0), (4.587, 2.936, -0.579, 20.0, 40.0), (-2.241, 1.791, -1.703, 20.0, 40.0), (-2.945, 1.372, -1.216, 20.0, 40.0), (1.375, 0.395, 2.898, 20.0, 40.0), (-1.281, -0.641, 3.642, 20.0, 40.0), (2.178, 0.895, 2.299, 20.0, 40.0), (3.031, -0.786, 6.087, 20.0, 40.0), (-1.385, -0.375, 3.058, 20.0, 40.0), (4.041, -0.431, 5.882, 20.0, 40.0), (0.480, -0.507, 4.254, 20.0, 40.0), (-3.797, 0.140, 0.822, 20.0, 40.0), (2.355, 2.502, -0.827, 20.0, 40.0), (1.376, -1.583, 6.854, 20.0, 40.0), (0.164, 1.405, 0.273, 20.0, 40.0), (-1.273, 1.471, -0.579, 20.0, 40.0), (0.770, 2.246, -1.107, 20.0, 40.0), (4.552, 2.904, -0.533, 20.0, 40.0), (4.259, -1.772, 8.674, 20.0, 40.0), (-0.309, 1.159, 0.528, 20.0, 40.0), (3.581, 2.700, -0.610, 20.0, 40.0), (-3.202, 0.346, 0.707, 20.0, 40.0), (-1.575, 1.242, -0.271, 20.0, 40.0), (-1.584, -0.493, 3.194, 20.0, 40.0), (-3.778, 0.150, 0.810, 20.0, 40.0), (-4.675, 1.749, -2.835, 20.0, 40.0), (3.567, -0.792, 6.367, 20.0, 40.0), (-0.417, 1.399, -0.006, 20.0, 40.0), (-4.672, 2.007, -3.349, 20.0, 40.0), (-1.034, 0.196, 2.090, 20.0, 40.0), (-3.796, 2.496, -3.890, 20.0, 40.0), (3.532, -0.497, 5.759, 20.0, 40.0), (4.868, -1.359, 8.151, 20.0, 40.0), (-0.769, 0.302, 2.011, 20.0, 40.0), (4.475, 2.612, 0.014, 20.0, 40.0), (-3.532, -0.395, 2.024, 20.0, 40.0), (0.322, 0.675, 1.812, 20.0, 40.0), (-2.028, -1.942, 5.870, 20.0, 40.0), (1.810, -1.244, 6.392, 20.0, 40.0), (-0.783, 1.242, 0.124, 20.0, 40.0), (-4.745, -1.300, 3.227, 20.0, 40.0), (1.902, 1.973, 0.005, 20.0, 40.0), (-3.453, -1.429, 4.132, 20.0, 40.0), (1.559, 0.986, 1.808, 20.0, 40.0), (0.128, 2.754, -2.443, 20.0, 40.0), (2.759, 1.727, 0.926, 20.0, 40.0), (-4.468, 1.690, -2.614, 20.0, 40.0), (-2.368, -1.922, 5.659, 20.0, 40.0), (-2.766, 2.128, -2.640, 20.0, 40.0), (0.967, -1.825, 7.133, 20.0, 40.0), (-2.854, 2.855, -4.136, 20.0, 40.0), (-2.944, 1.875, -2.222, 20.0, 40.0), (-2.632, -0.983, 3.649, 20.0, 40.0), (2.427, 2.239, -0.266, 20.0, 40.0), (-1.726, -0.838, 3.812, 20.0, 40.0), (0.007, -0.903, 4.809, 20.0, 40.0), (-2.013, 1.092, -0.191, 20.0, 40.0), (-0.449, 0.970, 0.836, 20.0, 40.0), (1.396, 0.411, 2.876, 20.0, 40.0), (-1.115, -1.790, 6.023, 20.0, 40.0), (3.748, 1.917, 1.039, 20.0, 40.0), (2.978, 1.043, 2.404, 20.0, 40.0), (-3.969, 2.514, -4.013, 20.0, 40.0), (4.455, -0.050, 5.328, 20.0, 40.0), (-3.065, -0.846, 3.160, 20.0, 40.0), (-1.069, 2.167, -1.869, 20.0, 40.0), (3.016, -1.393, 7.294, 20.0, 40.0), (0.045, -1.928, 6.879, 20.0, 40.0), (-2.555, -0.984, 3.690, 20.0, 40.0), (-1.995, -0.054, 2.111, 20.0, 40.0), (4.600, -0.509, 6.318, 20.0, 40.0), (-1.942, 1.215, -0.402, 20.0, 40.0), (1.262, 2.765, -1.899, 20.0, 40.0), (2.617, -1.106, 6.521, 20.0, 40.0), (1.737, 0.554, 2.761, 20.0, 40.0), (-2.197, 0.632, 0.638, 20.0, 40.0), (4.768, 2.618, 0.147, 20.0, 40.0), (-3.737, -0.939, 3.010, 20.0, 40.0), (-2.623, 0.595, 0.499, 20.0, 40.0), (4.752, -0.340, 6.057, 20.0, 40.0), (2.333, -1.037, 6.240, 20.0, 40.0), (4.234, -1.882, 8.881, 20.0, 40.0), (-3.393, -0.812, 2.927, 20.0, 40.0), (0.885, 1.383, 0.678, 20.0, 40.0), (0.123, 2.937, -2.812, 20.0, 40.0), (2.969, 0.760, 2.964, 20.0, 40.0), (-4.929, 1.251, -1.967, 20.0, 40.0), (1.916, 2.223, -0.488, 20.0, 40.0), (-0.020, -1.740, 6.469, 20.0, 40.0), (0.702, -1.272, 5.895, 20.0, 40.0), (2.496, 2.648, -1.048, 20.0, 40.0), (4.067, -1.475, 7.984, 20.0, 40.0), (-3.717, 1.851, -2.561, 20.0, 40.0), (1.678, -0.624, 5.088, 20.0, 40.0), (1.073, 0.695, 2.146, 20.0, 40.0), (1.842, -0.749, 5.419, 20.0, 40.0), (-3.518, 1.909, -2.578, 20.0, 40.0), (2.229, 1.189, 1.737, 20.0, 40.0), (4.987, 2.893, -0.292, 20.0, 40.0), (-4.809, 1.043, -1.490, 20.0, 40.0), (-0.241, -0.728, 4.334, 20.0, 40.0), (-3.331, 0.590, 0.156, 20.0, 40.0), (-0.455, 2.621, -2.470, 20.0, 40.0), (1.492, 1.223, 1.301, 20.0, 40.0), (3.948, 2.841, -0.709, 20.0, 40.0), (0.732, 0.446, 2.475, 20.0, 40.0), (2.400, 2.390, -0.579, 20.0, 40.0), (-2.718, 1.427, -1.213, 20.0, 40.0), (-1.826, 1.451, -0.815, 20.0, 40.0), (1.125, 0.438, 2.686, 20.0, 40.0), (-4.918, 1.880, -3.219, 20.0, 40.0), (3.068, -0.442, 5.418, 20.0, 40.0), (1.982, 1.201, 1.589, 20.0, 40.0), (0.701, -1.709, 6.768, 20.0, 40.0), (-1.496, 2.564, -2.877, 20.0, 40.0), (-3.812, 0.974, -0.853, 20.0, 40.0), (-3.405, 2.018, -2.739, 20.0, 40.0), (2.211, 2.889, -1.674, 20.0, 40.0), (-2.481, 2.931, -4.103, 20.0, 40.0), (-3.721, 2.765, -4.391, 20.0, 40.0), (-1.768, -1.292, 4.699, 20.0, 40.0), (-4.462, 1.058, -1.347, 20.0, 40.0), (-3.516, -1.942, 5.126, 20.0, 40.0), (0.485, 2.420, -1.597, 20.0, 40.0), (-0.492, 0.242, 2.270, 20.0, 40.0), (4.245, 1.689, 1.744, 20.0, 40.0), (2.234, 0.364, 3.389, 20.0, 40.0), (2.629, 2.224, -0.134, 20.0, 40.0), (-4.375, 1.221, -1.630, 20.0, 40.0), (-0.618, 1.374, -0.057, 20.0, 40.0), (-2.580, -1.604, 4.918, 20.0, 40.0), (0.159, 1.104, 0.871, 20.0, 40.0), (-3.597, 0.975, -0.749, 20.0, 40.0); +-- insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0), (-1.099, 2.755, -3.060, 20.0, 40.0), (1.090, 2.945, -2.346, 20.0, 40.0), (0.305, 2.179, -1.205, 20.0, 40.0), (-0.925, 0.702, 1.134, 20.0, 40.0), (3.178, -1.316, 7.221, 20.0, 40.0), (-2.756, -0.473, 2.569, 20.0, 40.0), (3.665, 2.303, 0.226, 20.0, 40.0), (1.662, 1.951, -0.070, 20.0, 40.0), (2.869, 0.593, 3.249, 20.0, 40.0), (0.818, -0.593, 4.594, 20.0, 40.0), (-1.917, 0.916, 0.209, 20.0, 40.0), (2.706, 1.523, 1.307, 20.0, 40.0), (0.219, 2.162, -1.214, 20.0, 40.0), (-4.510, 1.376, -2.007, 20.0, 40.0), (4.284, -0.515, 6.173, 20.0, 40.0), (-1.101, 2.810, -3.170, 20.0, 40.0), (-1.810, -1.117, 4.329, 20.0, 40.0), (0.055, 1.115, 0.797, 20.0, 40.0), (-2.178, 2.904, -3.898, 20.0, 40.0), (-3.494, -1.814, 4.882, 20.0, 40.0), (3.027, 0.476, 3.562, 20.0, 40.0), (-1.434, 1.151, -0.018, 20.0, 40.0), (1.180, 0.992, 1.606, 20.0, 40.0), (0.015, 0.971, 1.067, 20.0, 40.0), (-0.511, -0.875, 4.495, 20.0, 40.0), (0.961, 2.348, -1.216, 20.0, 40.0), (-2.279, 0.038, 1.785, 20.0, 40.0), (-1.568, -0.248, 2.712, 20.0, 40.0), (-0.496, 0.366, 2.020, 20.0, 40.0), (1.177, -1.401, 6.390, 20.0, 40.0), (2.882, -1.442, 7.325, 20.0, 40.0), (-1.066, 1.817, -1.167, 20.0, 40.0), (-2.144, 2.791, -3.655, 20.0, 40.0), (-4.370, 2.228, -3.642, 20.0, 40.0), (3.996, 2.775, -0.553, 20.0, 40.0), (0.289, 2.055, -0.965, 20.0, 40.0), (-0.588, -1.601, 5.908, 20.0, 40.0), (-1.801, 0.417, 1.265, 20.0, 40.0), (4.375, -1.499, 8.186, 20.0, 40.0), (-2.618, 0.038, 1.615, 20.0, 40.0), (3.616, -0.833, 6.475, 20.0, 40.0), (-4.045, -1.558, 4.094, 20.0, 40.0), (-3.962, 0.636, -0.253, 20.0, 40.0), (3.505, 2.625, -0.497, 20.0, 40.0), (3.029, -0.523, 5.560, 20.0, 40.0), (-3.520, -0.474, 2.188, 20.0, 40.0), (2.430, -1.469, 7.154, 20.0, 40.0), (1.547, -1.654, 7.082, 20.0, 40.0), (-1.370, 0.575, 1.165, 20.0, 40.0), (-1.869, -1.555, 5.176, 20.0, 40.0), (3.536, 2.841, -0.913, 20.0, 40.0), (-3.810, 1.220, -1.344, 20.0, 40.0), (-1.971, 1.462, -0.910, 20.0, 40.0), (-0.243, 0.167, 2.545, 20.0, 40.0), (-1.403, 2.645, -2.991, 20.0, 40.0), (0.532, -0.114, 3.494, 20.0, 40.0), (-1.678, 0.975, 0.212, 20.0, 40.0), (-0.656, 2.140, -1.609, 20.0, 40.0), (1.743, 2.631, -1.390, 20.0, 40.0), (2.586, 2.943, -1.593, 20.0, 40.0), (-0.512, 2.969, -3.195, 20.0, 40.0), (2.283, -0.100, 4.342, 20.0, 40.0), (-4.293, 0.872, -0.890, 20.0, 40.0), (3.411, 1.300, 2.106, 20.0, 40.0), (-0.281, 2.951, -3.042, 20.0, 40.0), (-4.442, 0.384, 0.012, 20.0, 40.0), (1.194, 1.746, 0.104, 20.0, 40.0), (-1.152, 1.862, -1.300, 20.0, 40.0), (1.362, -1.341, 6.363, 20.0, 40.0), (-4.488, 2.618, -4.481, 20.0, 40.0), (3.419, -0.564, 5.837, 20.0, 40.0), (-3.392, 0.396, 0.512, 20.0, 40.0), (-1.629, -0.909, 4.003, 20.0, 40.0), (4.447, -1.088, 7.399, 20.0, 40.0), (-1.232, 1.699, -1.014, 20.0, 40.0), (-1.286, -0.609, 3.575, 20.0, 40.0), (2.437, 2.796, -1.374, 20.0, 40.0), (-4.864, 1.989, -3.410, 20.0, 40.0), (-1.716, -1.399, 4.940, 20.0, 40.0), (-3.084, 1.858, -2.259, 20.0, 40.0), (2.828, -0.319, 5.053, 20.0, 40.0), (-1.226, 2.586, -2.786, 20.0, 40.0), (2.456, 0.092, 4.044, 20.0, 40.0), (-0.989, 2.375, -2.245, 20.0, 40.0), (3.268, 0.935, 2.765, 20.0, 40.0), (-4.128, -1.995, 4.927, 20.0, 40.0), (-1.083, 2.197, -1.935, 20.0, 40.0), (-3.471, -1.198, 3.660, 20.0, 40.0), (4.617, -1.136, 7.579, 20.0, 40.0), (2.054, -1.675, 7.378, 20.0, 40.0), (4.106, 2.326, 0.402, 20.0, 40.0), (1.558, 0.310, 3.158, 20.0, 40.0), (0.792, 0.900, 1.596, 20.0, 40.0), (-3.229, 0.300, 0.785, 20.0, 40.0), (3.787, -0.793, 6.479, 20.0, 40.0), (1.786, 2.288, -0.684, 20.0, 40.0), (2.643, 0.223, 3.875, 20.0, 40.0), (-3.592, 2.122, -3.040, 20.0, 40.0), (4.519, -1.760, 8.779, 20.0, 40.0), (3.221, 2.255, 0.101, 20.0, 40.0), (4.151, 1.788, 1.500, 20.0, 40.0), (-1.033, -1.195, 4.874, 20.0, 40.0), (-1.636, -1.037, 4.257, 20.0, 40.0), (-3.548, 1.911, -2.596, 20.0, 40.0), (4.829, -0.293, 6.001, 20.0, 40.0), (-4.684, -1.664, 3.986, 20.0, 40.0), (4.531, -0.503, 6.271, 20.0, 40.0), (-3.503, -1.606, 4.460, 20.0, 40.0), (-2.036, -1.522, 5.027, 20.0, 40.0), (-0.473, -0.617, 3.997, 20.0, 40.0), (-1.554, -1.630, 5.483, 20.0, 40.0), (-3.567, -1.043, 3.302, 20.0, 40.0), (-2.038, 0.579, 0.823, 20.0, 40.0), (-3.040, 0.857, -0.233, 20.0, 40.0), (4.610, 0.562, 4.181, 20.0, 40.0), (-3.323, -1.938, 5.215, 20.0, 40.0), (4.314, 1.720, 1.717, 20.0, 40.0), (-1.220, 0.615, 1.161, 20.0, 40.0), (-2.556, 1.120, -0.519, 20.0, 40.0), (-3.717, -0.108, 1.358, 20.0, 40.0), (4.689, -1.826, 8.996, 20.0, 40.0), (3.452, 0.506, 3.713, 20.0, 40.0), (2.472, 0.612, 3.012, 20.0, 40.0), (3.452, 0.450, 3.826, 20.0, 40.0), (1.207, 2.585, -1.567, 20.0, 40.0), (-4.826, 1.090, -1.593, 20.0, 40.0), (3.116, -1.118, 6.794, 20.0, 40.0), (0.448, 2.732, -2.240, 20.0, 40.0), (-1.096, -0.525, 3.503, 20.0, 40.0), (-4.680, -0.238, 1.137, 20.0, 40.0), (2.552, -1.403, 7.082, 20.0, 40.0), (0.719, 2.997, -2.635, 20.0, 40.0), (0.347, -1.966, 7.105, 20.0, 40.0), (2.958, -0.404, 5.288, 20.0, 40.0), (0.722, -1.950, 7.261, 20.0, 40.0), (-2.851, -0.986, 3.546, 20.0, 40.0), (-4.316, -0.439, 1.721, 20.0, 40.0), (-1.685, -0.201, 2.560, 20.0, 40.0), (1.856, 0.190, 3.549, 20.0, 40.0), (-2.052, 0.206, 1.562, 20.0, 40.0), (-2.504, -0.646, 3.041, 20.0, 40.0), (3.235, 0.882, 2.854, 20.0, 40.0), (-1.366, -1.573, 5.463, 20.0, 40.0), (-3.447, 2.419, -3.562, 20.0, 40.0), (4.155, 2.092, 0.893, 20.0, 40.0), (-0.935, 0.209, 2.116, 20.0, 40.0), (3.117, -1.821, 8.201, 20.0, 40.0), (3.759, 0.577, 3.725, 20.0, 40.0), (-0.938, 2.992, -3.453, 20.0, 40.0), (-0.525, 2.341, -1.945, 20.0, 40.0), (4.540, 2.625, 0.019, 20.0, 40.0), (-2.097, 1.190, -0.429, 20.0, 40.0), (-2.672, 1.983, -2.302, 20.0, 40.0), (-3.038, -1.490, 4.460, 20.0, 40.0), (-0.943, 2.149, -1.770, 20.0, 40.0), (0.739, 1.598, 0.174, 20.0, 40.0), (1.828, 1.853, 0.208, 20.0, 40.0), (4.856, 0.137, 5.153, 20.0, 40.0), (-1.617, 0.468, 1.255, 20.0, 40.0), (-1.972, 2.053, -2.092, 20.0, 40.0), (-4.633, 1.389, -2.094, 20.0, 40.0), (-3.628, -1.156, 3.498, 20.0, 40.0), (3.597, 1.034, 2.731, 20.0, 40.0), (-1.488, -0.002, 2.261, 20.0, 40.0), (0.749, 1.921, -0.468, 20.0, 40.0), (1.304, -1.371, 6.394, 20.0, 40.0), (4.587, 2.936, -0.579, 20.0, 40.0), (-2.241, 1.791, -1.703, 20.0, 40.0), (-2.945, 1.372, -1.216, 20.0, 40.0), (1.375, 0.395, 2.898, 20.0, 40.0), (-1.281, -0.641, 3.642, 20.0, 40.0), (2.178, 0.895, 2.299, 20.0, 40.0), (3.031, -0.786, 6.087, 20.0, 40.0), (-1.385, -0.375, 3.058, 20.0, 40.0), (4.041, -0.431, 5.882, 20.0, 40.0), (0.480, -0.507, 4.254, 20.0, 40.0), (-3.797, 0.140, 0.822, 20.0, 40.0), (2.355, 2.502, -0.827, 20.0, 40.0), (1.376, -1.583, 6.854, 20.0, 40.0), (0.164, 1.405, 0.273, 20.0, 40.0), (-1.273, 1.471, -0.579, 20.0, 40.0), (0.770, 2.246, -1.107, 20.0, 40.0), (4.552, 2.904, -0.533, 20.0, 40.0), (4.259, -1.772, 8.674, 20.0, 40.0), (-0.309, 1.159, 0.528, 20.0, 40.0), (3.581, 2.700, -0.610, 20.0, 40.0), (-3.202, 0.346, 0.707, 20.0, 40.0), (-1.575, 1.242, -0.271, 20.0, 40.0), (-1.584, -0.493, 3.194, 20.0, 40.0), (-3.778, 0.150, 0.810, 20.0, 40.0), (-4.675, 1.749, -2.835, 20.0, 40.0), (3.567, -0.792, 6.367, 20.0, 40.0), (-0.417, 1.399, -0.006, 20.0, 40.0), (-4.672, 2.007, -3.349, 20.0, 40.0), (-1.034, 0.196, 2.090, 20.0, 40.0), (-3.796, 2.496, -3.890, 20.0, 40.0), (3.532, -0.497, 5.759, 20.0, 40.0), (4.868, -1.359, 8.151, 20.0, 40.0), (-0.769, 0.302, 2.011, 20.0, 40.0), (4.475, 2.612, 0.014, 20.0, 40.0), (-3.532, -0.395, 2.024, 20.0, 40.0), (0.322, 0.675, 1.812, 20.0, 40.0), (-2.028, -1.942, 5.870, 20.0, 40.0), (1.810, -1.244, 6.392, 20.0, 40.0), (-0.783, 1.242, 0.124, 20.0, 40.0), (-4.745, -1.300, 3.227, 20.0, 40.0), (1.902, 1.973, 0.005, 20.0, 40.0), (-3.453, -1.429, 4.132, 20.0, 40.0), (1.559, 0.986, 1.808, 20.0, 40.0), (0.128, 2.754, -2.443, 20.0, 40.0), (2.759, 1.727, 0.926, 20.0, 40.0), (-4.468, 1.690, -2.614, 20.0, 40.0), (-2.368, -1.922, 5.659, 20.0, 40.0), (-2.766, 2.128, -2.640, 20.0, 40.0), (0.967, -1.825, 7.133, 20.0, 40.0), (-2.854, 2.855, -4.136, 20.0, 40.0), (-2.944, 1.875, -2.222, 20.0, 40.0), (-2.632, -0.983, 3.649, 20.0, 40.0), (2.427, 2.239, -0.266, 20.0, 40.0), (-1.726, -0.838, 3.812, 20.0, 40.0), (0.007, -0.903, 4.809, 20.0, 40.0), (-2.013, 1.092, -0.191, 20.0, 40.0), (-0.449, 0.970, 0.836, 20.0, 40.0), (1.396, 0.411, 2.876, 20.0, 40.0), (-1.115, -1.790, 6.023, 20.0, 40.0), (3.748, 1.917, 1.039, 20.0, 40.0), (2.978, 1.043, 2.404, 20.0, 40.0), (-3.969, 2.514, -4.013, 20.0, 40.0), (4.455, -0.050, 5.328, 20.0, 40.0), (-3.065, -0.846, 3.160, 20.0, 40.0), (-1.069, 2.167, -1.869, 20.0, 40.0), (3.016, -1.393, 7.294, 20.0, 40.0), (0.045, -1.928, 6.879, 20.0, 40.0), (-2.555, -0.984, 3.690, 20.0, 40.0), (-1.995, -0.054, 2.111, 20.0, 40.0), (4.600, -0.509, 6.318, 20.0, 40.0), (-1.942, 1.215, -0.402, 20.0, 40.0), (1.262, 2.765, -1.899, 20.0, 40.0), (2.617, -1.106, 6.521, 20.0, 40.0), (1.737, 0.554, 2.761, 20.0, 40.0), (-2.197, 0.632, 0.638, 20.0, 40.0), (4.768, 2.618, 0.147, 20.0, 40.0), (-3.737, -0.939, 3.010, 20.0, 40.0), (-2.623, 0.595, 0.499, 20.0, 40.0), (4.752, -0.340, 6.057, 20.0, 40.0), (2.333, -1.037, 6.240, 20.0, 40.0), (4.234, -1.882, 8.881, 20.0, 40.0), (-3.393, -0.812, 2.927, 20.0, 40.0), (0.885, 1.383, 0.678, 20.0, 40.0), (0.123, 2.937, -2.812, 20.0, 40.0), (2.969, 0.760, 2.964, 20.0, 40.0), (-4.929, 1.251, -1.967, 20.0, 40.0), (1.916, 2.223, -0.488, 20.0, 40.0), (-0.020, -1.740, 6.469, 20.0, 40.0), (0.702, -1.272, 5.895, 20.0, 40.0), (2.496, 2.648, -1.048, 20.0, 40.0), (4.067, -1.475, 7.984, 20.0, 40.0), (-3.717, 1.851, -2.561, 20.0, 40.0), (1.678, -0.624, 5.088, 20.0, 40.0), (1.073, 0.695, 2.146, 20.0, 40.0), (1.842, -0.749, 5.419, 20.0, 40.0), (-3.518, 1.909, -2.578, 20.0, 40.0), (2.229, 1.189, 1.737, 20.0, 40.0), (4.987, 2.893, -0.292, 20.0, 40.0), (-4.809, 1.043, -1.490, 20.0, 40.0), (-0.241, -0.728, 4.334, 20.0, 40.0), (-3.331, 0.590, 0.156, 20.0, 40.0), (-0.455, 2.621, -2.470, 20.0, 40.0), (1.492, 1.223, 1.301, 20.0, 40.0), (3.948, 2.841, -0.709, 20.0, 40.0), (0.732, 0.446, 2.475, 20.0, 40.0), (2.400, 2.390, -0.579, 20.0, 40.0), (-2.718, 1.427, -1.213, 20.0, 40.0), (-1.826, 1.451, -0.815, 20.0, 40.0), (1.125, 0.438, 2.686, 20.0, 40.0), (-4.918, 1.880, -3.219, 20.0, 40.0), (3.068, -0.442, 5.418, 20.0, 40.0), (1.982, 1.201, 1.589, 20.0, 40.0), (0.701, -1.709, 6.768, 20.0, 40.0), (-1.496, 2.564, -2.877, 20.0, 40.0), (-3.812, 0.974, -0.853, 20.0, 40.0), (-3.405, 2.018, -2.739, 20.0, 40.0), (2.211, 2.889, -1.674, 20.0, 40.0), (-2.481, 2.931, -4.103, 20.0, 40.0), (-3.721, 2.765, -4.391, 20.0, 40.0), (-1.768, -1.292, 4.699, 20.0, 40.0), (-4.462, 1.058, -1.347, 20.0, 40.0), (-3.516, -1.942, 5.126, 20.0, 40.0), (0.485, 2.420, -1.597, 20.0, 40.0), (-0.492, 0.242, 2.270, 20.0, 40.0), (4.245, 1.689, 1.744, 20.0, 40.0), (2.234, 0.364, 3.389, 20.0, 40.0), (2.629, 2.224, -0.134, 20.0, 40.0), (-4.375, 1.221, -1.630, 20.0, 40.0), (-0.618, 1.374, -0.057, 20.0, 40.0), (-2.580, -1.604, 4.918, 20.0, 40.0), (0.159, 1.104, 0.871, 20.0, 40.0), (-3.597, 0.975, -0.749, 20.0, 40.0); -- insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0), (-1.099, 2.755, -3.060, 20.0, 40.0), (1.090, 2.945, -2.346, 20.0, 40.0), (0.305, 2.179, -1.205, 20.0, 40.0), (-0.925, 0.702, 1.134, 20.0, 40.0), (3.178, -1.316, 7.221, 20.0, 40.0), (-2.756, -0.473, 2.569, 20.0, 40.0), (3.665, 2.303, 0.226, 20.0, 40.0), (1.662, 1.951, -0.070, 20.0, 40.0), (2.869, 0.593, 3.249, 20.0, 40.0), (0.818, -0.593, 4.594, 20.0, 40.0), (-1.917, 0.916, 0.209, 20.0, 40.0), (2.706, 1.523, 1.307, 20.0, 40.0), (0.219, 2.162, -1.214, 20.0, 40.0), (-4.510, 1.376, -2.007, 20.0, 40.0), (4.284, -0.515, 6.173, 20.0, 40.0), (-1.101, 2.810, -3.170, 20.0, 40.0), (-1.810, -1.117, 4.329, 20.0, 40.0), (0.055, 1.115, 0.797, 20.0, 40.0), (-2.178, 2.904, -3.898, 20.0, 40.0), (-3.494, -1.814, 4.882, 20.0, 40.0), (3.027, 0.476, 3.562, 20.0, 40.0), (-1.434, 1.151, -0.018, 20.0, 40.0), (1.180, 0.992, 1.606, 20.0, 40.0), (0.015, 0.971, 1.067, 20.0, 40.0), (-0.511, -0.875, 4.495, 20.0, 40.0), (0.961, 2.348, -1.216, 20.0, 40.0), (-2.279, 0.038, 1.785, 20.0, 40.0), (-1.568, -0.248, 2.712, 20.0, 40.0), (-0.496, 0.366, 2.020, 20.0, 40.0), (1.177, -1.401, 6.390, 20.0, 40.0), (2.882, -1.442, 7.325, 20.0, 40.0), (-1.066, 1.817, -1.167, 20.0, 40.0), (-2.144, 2.791, -3.655, 20.0, 40.0), (-4.370, 2.228, -3.642, 20.0, 40.0), (3.996, 2.775, -0.553, 20.0, 40.0), (0.289, 2.055, -0.965, 20.0, 40.0), (-0.588, -1.601, 5.908, 20.0, 40.0), (-1.801, 0.417, 1.265, 20.0, 40.0), (4.375, -1.499, 8.186, 20.0, 40.0), (-2.618, 0.038, 1.615, 20.0, 40.0), (3.616, -0.833, 6.475, 20.0, 40.0), (-4.045, -1.558, 4.094, 20.0, 40.0), (-3.962, 0.636, -0.253, 20.0, 40.0), (3.505, 2.625, -0.497, 20.0, 40.0), (3.029, -0.523, 5.560, 20.0, 40.0), (-3.520, -0.474, 2.188, 20.0, 40.0), (2.430, -1.469, 7.154, 20.0, 40.0), (1.547, -1.654, 7.082, 20.0, 40.0), (-1.370, 0.575, 1.165, 20.0, 40.0), (-1.869, -1.555, 5.176, 20.0, 40.0), (3.536, 2.841, -0.913, 20.0, 40.0), (-3.810, 1.220, -1.344, 20.0, 40.0), (-1.971, 1.462, -0.910, 20.0, 40.0), (-0.243, 0.167, 2.545, 20.0, 40.0), (-1.403, 2.645, -2.991, 20.0, 40.0), (0.532, -0.114, 3.494, 20.0, 40.0), (-1.678, 0.975, 0.212, 20.0, 40.0), (-0.656, 2.140, -1.609, 20.0, 40.0), (1.743, 2.631, -1.390, 20.0, 40.0), (2.586, 2.943, -1.593, 20.0, 40.0), (-0.512, 2.969, -3.195, 20.0, 40.0), (2.283, -0.100, 4.342, 20.0, 40.0), (-4.293, 0.872, -0.890, 20.0, 40.0), (3.411, 1.300, 2.106, 20.0, 40.0), (-0.281, 2.951, -3.042, 20.0, 40.0), (-4.442, 0.384, 0.012, 20.0, 40.0), (1.194, 1.746, 0.104, 20.0, 40.0), (-1.152, 1.862, -1.300, 20.0, 40.0), (1.362, -1.341, 6.363, 20.0, 40.0), (-4.488, 2.618, -4.481, 20.0, 40.0), (3.419, -0.564, 5.837, 20.0, 40.0), (-3.392, 0.396, 0.512, 20.0, 40.0), (-1.629, -0.909, 4.003, 20.0, 40.0), (4.447, -1.088, 7.399, 20.0, 40.0), (-1.232, 1.699, -1.014, 20.0, 40.0), (-1.286, -0.609, 3.575, 20.0, 40.0), (2.437, 2.796, -1.374, 20.0, 40.0), (-4.864, 1.989, -3.410, 20.0, 40.0), (-1.716, -1.399, 4.940, 20.0, 40.0), (-3.084, 1.858, -2.259, 20.0, 40.0), (2.828, -0.319, 5.053, 20.0, 40.0), (-1.226, 2.586, -2.786, 20.0, 40.0), (2.456, 0.092, 4.044, 20.0, 40.0), (-0.989, 2.375, -2.245, 20.0, 40.0), (3.268, 0.935, 2.765, 20.0, 40.0), (-4.128, -1.995, 4.927, 20.0, 40.0), (-1.083, 2.197, -1.935, 20.0, 40.0), (-3.471, -1.198, 3.660, 20.0, 40.0), (4.617, -1.136, 7.579, 20.0, 40.0), (2.054, -1.675, 7.378, 20.0, 40.0), (4.106, 2.326, 0.402, 20.0, 40.0), (1.558, 0.310, 3.158, 20.0, 40.0), (0.792, 0.900, 1.596, 20.0, 40.0), (-3.229, 0.300, 0.785, 20.0, 40.0), (3.787, -0.793, 6.479, 20.0, 40.0), (1.786, 2.288, -0.684, 20.0, 40.0), (2.643, 0.223, 3.875, 20.0, 40.0), (-3.592, 2.122, -3.040, 20.0, 40.0), (4.519, -1.760, 8.779, 20.0, 40.0), (3.221, 2.255, 0.101, 20.0, 40.0), (4.151, 1.788, 1.500, 20.0, 40.0), (-1.033, -1.195, 4.874, 20.0, 40.0), (-1.636, -1.037, 4.257, 20.0, 40.0), (-3.548, 1.911, -2.596, 20.0, 40.0), (4.829, -0.293, 6.001, 20.0, 40.0), (-4.684, -1.664, 3.986, 20.0, 40.0), (4.531, -0.503, 6.271, 20.0, 40.0), (-3.503, -1.606, 4.460, 20.0, 40.0), (-2.036, -1.522, 5.027, 20.0, 40.0), (-0.473, -0.617, 3.997, 20.0, 40.0), (-1.554, -1.630, 5.483, 20.0, 40.0), (-3.567, -1.043, 3.302, 20.0, 40.0), (-2.038, 0.579, 0.823, 20.0, 40.0), (-3.040, 0.857, -0.233, 20.0, 40.0), (4.610, 0.562, 4.181, 20.0, 40.0), (-3.323, -1.938, 5.215, 20.0, 40.0), (4.314, 1.720, 1.717, 20.0, 40.0), (-1.220, 0.615, 1.161, 20.0, 40.0), (-2.556, 1.120, -0.519, 20.0, 40.0), (-3.717, -0.108, 1.358, 20.0, 40.0), (4.689, -1.826, 8.996, 20.0, 40.0), (3.452, 0.506, 3.713, 20.0, 40.0), (2.472, 0.612, 3.012, 20.0, 40.0), (3.452, 0.450, 3.826, 20.0, 40.0), (1.207, 2.585, -1.567, 20.0, 40.0), (-4.826, 1.090, -1.593, 20.0, 40.0), (3.116, -1.118, 6.794, 20.0, 40.0), (0.448, 2.732, -2.240, 20.0, 40.0), (-1.096, -0.525, 3.503, 20.0, 40.0), (-4.680, -0.238, 1.137, 20.0, 40.0), (2.552, -1.403, 7.082, 20.0, 40.0), (0.719, 2.997, -2.635, 20.0, 40.0), (0.347, -1.966, 7.105, 20.0, 40.0), (2.958, -0.404, 5.288, 20.0, 40.0), (0.722, -1.950, 7.261, 20.0, 40.0), (-2.851, -0.986, 3.546, 20.0, 40.0), (-4.316, -0.439, 1.721, 20.0, 40.0), (-1.685, -0.201, 2.560, 20.0, 40.0), (1.856, 0.190, 3.549, 20.0, 40.0), (-2.052, 0.206, 1.562, 20.0, 40.0), (-2.504, -0.646, 3.041, 20.0, 40.0), (3.235, 0.882, 2.854, 20.0, 40.0), (-1.366, -1.573, 5.463, 20.0, 40.0), (-3.447, 2.419, -3.562, 20.0, 40.0), (4.155, 2.092, 0.893, 20.0, 40.0), (-0.935, 0.209, 2.116, 20.0, 40.0), (3.117, -1.821, 8.201, 20.0, 40.0), (3.759, 0.577, 3.725, 20.0, 40.0), (-0.938, 2.992, -3.453, 20.0, 40.0), (-0.525, 2.341, -1.945, 20.0, 40.0), (4.540, 2.625, 0.019, 20.0, 40.0), (-2.097, 1.190, -0.429, 20.0, 40.0), (-2.672, 1.983, -2.302, 20.0, 40.0), (-3.038, -1.490, 4.460, 20.0, 40.0), (-0.943, 2.149, -1.770, 20.0, 40.0), (0.739, 1.598, 0.174, 20.0, 40.0), (1.828, 1.853, 0.208, 20.0, 40.0), (4.856, 0.137, 5.153, 20.0, 40.0), (-1.617, 0.468, 1.255, 20.0, 40.0), (-1.972, 2.053, -2.092, 20.0, 40.0), (-4.633, 1.389, -2.094, 20.0, 40.0), (-3.628, -1.156, 3.498, 20.0, 40.0), (3.597, 1.034, 2.731, 20.0, 40.0), (-1.488, -0.002, 2.261, 20.0, 40.0), (0.749, 1.921, -0.468, 20.0, 40.0), (1.304, -1.371, 6.394, 20.0, 40.0), (4.587, 2.936, -0.579, 20.0, 40.0), (-2.241, 1.791, -1.703, 20.0, 40.0), (-2.945, 1.372, -1.216, 20.0, 40.0), (1.375, 0.395, 2.898, 20.0, 40.0), (-1.281, -0.641, 3.642, 20.0, 40.0), (2.178, 0.895, 2.299, 20.0, 40.0), (3.031, -0.786, 6.087, 20.0, 40.0), (-1.385, -0.375, 3.058, 20.0, 40.0), (4.041, -0.431, 5.882, 20.0, 40.0), (0.480, -0.507, 4.254, 20.0, 40.0), (-3.797, 0.140, 0.822, 20.0, 40.0), (2.355, 2.502, -0.827, 20.0, 40.0), (1.376, -1.583, 6.854, 20.0, 40.0), (0.164, 1.405, 0.273, 20.0, 40.0), (-1.273, 1.471, -0.579, 20.0, 40.0), (0.770, 2.246, -1.107, 20.0, 40.0), (4.552, 2.904, -0.533, 20.0, 40.0), (4.259, -1.772, 8.674, 20.0, 40.0), (-0.309, 1.159, 0.528, 20.0, 40.0), (3.581, 2.700, -0.610, 20.0, 40.0), (-3.202, 0.346, 0.707, 20.0, 40.0), (-1.575, 1.242, -0.271, 20.0, 40.0), (-1.584, -0.493, 3.194, 20.0, 40.0), (-3.778, 0.150, 0.810, 20.0, 40.0), (-4.675, 1.749, -2.835, 20.0, 40.0), (3.567, -0.792, 6.367, 20.0, 40.0), (-0.417, 1.399, -0.006, 20.0, 40.0), (-4.672, 2.007, -3.349, 20.0, 40.0), (-1.034, 0.196, 2.090, 20.0, 40.0), (-3.796, 2.496, -3.890, 20.0, 40.0), (3.532, -0.497, 5.759, 20.0, 40.0), (4.868, -1.359, 8.151, 20.0, 40.0), (-0.769, 0.302, 2.011, 20.0, 40.0), (4.475, 2.612, 0.014, 20.0, 40.0), (-3.532, -0.395, 2.024, 20.0, 40.0), (0.322, 0.675, 1.812, 20.0, 40.0), (-2.028, -1.942, 5.870, 20.0, 40.0), (1.810, -1.244, 6.392, 20.0, 40.0), (-0.783, 1.242, 0.124, 20.0, 40.0), (-4.745, -1.300, 3.227, 20.0, 40.0), (1.902, 1.973, 0.005, 20.0, 40.0), (-3.453, -1.429, 4.132, 20.0, 40.0), (1.559, 0.986, 1.808, 20.0, 40.0), (0.128, 2.754, -2.443, 20.0, 40.0), (2.759, 1.727, 0.926, 20.0, 40.0), (-4.468, 1.690, -2.614, 20.0, 40.0), (-2.368, -1.922, 5.659, 20.0, 40.0), (-2.766, 2.128, -2.640, 20.0, 40.0), (0.967, -1.825, 7.133, 20.0, 40.0), (-2.854, 2.855, -4.136, 20.0, 40.0), (-2.944, 1.875, -2.222, 20.0, 40.0), (-2.632, -0.983, 3.649, 20.0, 40.0), (2.427, 2.239, -0.266, 20.0, 40.0), (-1.726, -0.838, 3.812, 20.0, 40.0), (0.007, -0.903, 4.809, 20.0, 40.0), (-2.013, 1.092, -0.191, 20.0, 40.0), (-0.449, 0.970, 0.836, 20.0, 40.0), (1.396, 0.411, 2.876, 20.0, 40.0), (-1.115, -1.790, 6.023, 20.0, 40.0), (3.748, 1.917, 1.039, 20.0, 40.0), (2.978, 1.043, 2.404, 20.0, 40.0), (-3.969, 2.514, -4.013, 20.0, 40.0), (4.455, -0.050, 5.328, 20.0, 40.0), (-3.065, -0.846, 3.160, 20.0, 40.0), (-1.069, 2.167, -1.869, 20.0, 40.0), (3.016, -1.393, 7.294, 20.0, 40.0), (0.045, -1.928, 6.879, 20.0, 40.0), (-2.555, -0.984, 3.690, 20.0, 40.0), (-1.995, -0.054, 2.111, 20.0, 40.0), (4.600, -0.509, 6.318, 20.0, 40.0), (-1.942, 1.215, -0.402, 20.0, 40.0), (1.262, 2.765, -1.899, 20.0, 40.0), (2.617, -1.106, 6.521, 20.0, 40.0), (1.737, 0.554, 2.761, 20.0, 40.0), (-2.197, 0.632, 0.638, 20.0, 40.0), (4.768, 2.618, 0.147, 20.0, 40.0), (-3.737, -0.939, 3.010, 20.0, 40.0), (-2.623, 0.595, 0.499, 20.0, 40.0), (4.752, -0.340, 6.057, 20.0, 40.0), (2.333, -1.037, 6.240, 20.0, 40.0), (4.234, -1.882, 8.881, 20.0, 40.0), (-3.393, -0.812, 2.927, 20.0, 40.0), (0.885, 1.383, 0.678, 20.0, 40.0), (0.123, 2.937, -2.812, 20.0, 40.0), (2.969, 0.760, 2.964, 20.0, 40.0), (-4.929, 1.251, -1.967, 20.0, 40.0), (1.916, 2.223, -0.488, 20.0, 40.0), (-0.020, -1.740, 6.469, 20.0, 40.0), (0.702, -1.272, 5.895, 20.0, 40.0), (2.496, 2.648, -1.048, 20.0, 40.0), (4.067, -1.475, 7.984, 20.0, 40.0), (-3.717, 1.851, -2.561, 20.0, 40.0), (1.678, -0.624, 5.088, 20.0, 40.0), (1.073, 0.695, 2.146, 20.0, 40.0), (1.842, -0.749, 5.419, 20.0, 40.0), (-3.518, 1.909, -2.578, 20.0, 40.0), (2.229, 1.189, 1.737, 20.0, 40.0), (4.987, 2.893, -0.292, 20.0, 40.0), (-4.809, 1.043, -1.490, 20.0, 40.0), (-0.241, -0.728, 4.334, 20.0, 40.0), (-3.331, 0.590, 0.156, 20.0, 40.0), (-0.455, 2.621, -2.470, 20.0, 40.0), (1.492, 1.223, 1.301, 20.0, 40.0), (3.948, 2.841, -0.709, 20.0, 40.0), (0.732, 0.446, 2.475, 20.0, 40.0), (2.400, 2.390, -0.579, 20.0, 40.0), (-2.718, 1.427, -1.213, 20.0, 40.0), (-1.826, 1.451, -0.815, 20.0, 40.0), (1.125, 0.438, 2.686, 20.0, 40.0), (-4.918, 1.880, -3.219, 20.0, 40.0), (3.068, -0.442, 5.418, 20.0, 40.0), (1.982, 1.201, 1.589, 20.0, 40.0), (0.701, -1.709, 6.768, 20.0, 40.0), (-1.496, 2.564, -2.877, 20.0, 40.0), (-3.812, 0.974, -0.853, 20.0, 40.0), (-3.405, 2.018, -2.739, 20.0, 40.0), (2.211, 2.889, -1.674, 20.0, 40.0), (-2.481, 2.931, -4.103, 20.0, 40.0), (-3.721, 2.765, -4.391, 20.0, 40.0), (-1.768, -1.292, 4.699, 20.0, 40.0), (-4.462, 1.058, -1.347, 20.0, 40.0), (-3.516, -1.942, 5.126, 20.0, 40.0), (0.485, 2.420, -1.597, 20.0, 40.0), (-0.492, 0.242, 2.270, 20.0, 40.0), (4.245, 1.689, 1.744, 20.0, 40.0), (2.234, 0.364, 3.389, 20.0, 40.0), (2.629, 2.224, -0.134, 20.0, 40.0), (-4.375, 1.221, -1.630, 20.0, 40.0), (-0.618, 1.374, -0.057, 20.0, 40.0), (-2.580, -1.604, 4.918, 20.0, 40.0), (0.159, 1.104, 0.871, 20.0, 40.0), (-3.597, 0.975, -0.749, 20.0, 40.0); -- -DROP TABLE IF EXISTS test.model; -create table test.model engine = Memory as select LinearRegressionState(0.1, 5, 2.0)(target, param1, param2) as state from test.defaults; +insert into test.mldata values (-1.0, -2.0, -3.0, -4.0, -5.0); + +-- DROP TABLE IF EXISTS test.model; +-- create table test.model engine = Memory as select LinearRegressionState(0.1, 5, 2.0)(target, param1, param2) as state from test.defaults; -- -- select toTypeName(state) from test.model; -- -- -- -- DROP TABLE IF EXISTS test.tests; From a7f7c4a15704736df3c13540007e0a0b18f5f32f Mon Sep 17 00:00:00 2001 From: alexander kozhikhov Date: Wed, 13 Feb 2019 00:37:49 +0300 Subject: [PATCH 015/709] ml constructor changed --- dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp | 2 +- dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h | 7 +++++-- .../{00900_mytest.reference => 00950_mltest.reference} | 0 .../0_stateless/{00900_mytest.sql => 00950_mltest.sql} | 5 ++++- 4 files changed, 10 insertions(+), 4 deletions(-) rename dbms/tests/queries/0_stateless/{00900_mytest.reference => 00950_mltest.reference} (100%) rename dbms/tests/queries/0_stateless/{00900_mytest.sql => 00950_mltest.sql} (99%) diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp index 116a62b8408..04d31f918d0 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp @@ -73,7 +73,7 @@ AggregateFunctionPtr createAggregateFunctionMLMethod( if (argument_types.size() < 2) throw Exception("Aggregate function " + name + " requires at least two arguments", ErrorCodes::NUMBER_OF_ARGUMENTS_DOESNT_MATCH); - return std::make_shared(argument_types.size() - 1, gc, wu, learning_rate, batch_size); + return std::make_shared(argument_types.size() - 1, gc, wu, learning_rate, batch_size, argument_types, parameters); } } diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h index 545b278cce5..363f514c136 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h @@ -332,8 +332,11 @@ public: std::shared_ptr gradient_computer, std::shared_ptr weights_updater, Float64 learning_rate, - UInt32 batch_size) - : param_num(param_num), + UInt32 batch_size, + const DataTypes & argument_types, + const Array & params) + : IAggregateFunctionDataHelper>(argument_types, params), + param_num(param_num), learning_rate(learning_rate), batch_size(batch_size), gc(std::move(gradient_computer)), diff --git a/dbms/tests/queries/0_stateless/00900_mytest.reference b/dbms/tests/queries/0_stateless/00950_mltest.reference similarity index 100% rename from dbms/tests/queries/0_stateless/00900_mytest.reference rename to dbms/tests/queries/0_stateless/00950_mltest.reference diff --git a/dbms/tests/queries/0_stateless/00900_mytest.sql b/dbms/tests/queries/0_stateless/00950_mltest.sql similarity index 99% rename from dbms/tests/queries/0_stateless/00900_mytest.sql rename to dbms/tests/queries/0_stateless/00950_mltest.sql index ddb99c77d19..28e431b6814 100644 --- a/dbms/tests/queries/0_stateless/00900_mytest.sql +++ b/dbms/tests/queries/0_stateless/00950_mltest.sql @@ -36,12 +36,15 @@ create table test.model engine = Memory as select LinearRegressionState(0.1, 5, -- -- ) ENGINE = Memory; -- -- + +with (select state from test.model) as model select evalMLMethod(model, predict1, predict2) from test.defaults + -- -- insert into test.prediction values (20.0, 40.0); -- -- -- select multiply(param1, param2) from test.defaults; -- -- -- select evalLinReg(LinRegState(0.01)(target, param1, param2), 20.0, 40.0) from test.defaults; -select evalMLMethod(state, predict1, predict2) from test.model cross join test.defaults; +-- select evalMLMethod(state, predict1, predict2) from test.model cross join test.defaults; -- -- select evalLinReg(state, predict1, predict2) from test.model inner join (select * from test.tests) using state; -- -- select evalLinReg(state1, predict1, predict2) from test.tests; -- From b23cd21ce176701c1fa2d1af088476763f85dcc6 Mon Sep 17 00:00:00 2001 From: alexander kozhikhov Date: Wed, 13 Feb 2019 01:33:37 +0300 Subject: [PATCH 016/709] predict correctly using scalar aggr state --- .../AggregateFunctionMLMethod.h | 16 +- dbms/src/Columns/ColumnAggregateFunction.cpp | 19 +- dbms/src/Functions/evalMLMethod.cpp | 15 +- .../0_stateless/00950_ml_test.reference | 600 +++++++++--------- .../queries/0_stateless/00950_ml_test.sql | 55 +- 5 files changed, 321 insertions(+), 384 deletions(-) diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h index f9e12832f15..0dc0999da3f 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h @@ -110,22 +110,20 @@ public: void predict_for_all(ColumnVector::Container & container, Block & block, const ColumnNumbers & arguments, const std::vector & weights, Float64 bias) const override { size_t rows_num = block.rows(); - std::cout << "\n\nROWS NUM: " << rows_num << "\n\n"; std::vector results(rows_num, bias); - for (size_t i = 1; i < arguments.size(); ++i) { ColumnPtr cur_col = block.getByPosition(arguments[i]).column; for (size_t row_num = 0; row_num != rows_num; ++row_num) { + const auto &element = (*cur_col)[row_num]; if (element.getType() != Field::Types::Float64) throw Exception("Prediction arguments must be values of type Float", ErrorCodes::BAD_ARGUMENTS); - results[row_num] += weights[row_num] * element.get(); - // predict_features[i - 1] = element.get(); + results[row_num] += weights[i - 1] * element.get(); } } @@ -133,9 +131,6 @@ public: { container.emplace_back(results[row_num]); } -// column.getData().push_back(this->data(place).predict(predict_features)); -// column.getData().push_back(this->data(place).predict_for_all()); -// this->data(place).predict_for_all(column.getData(), block, arguments); } }; @@ -183,6 +178,7 @@ public: } void predict_for_all(ColumnVector::Container & container, Block & block, const ColumnNumbers & arguments, const std::vector & weights, Float64 bias) const override { + // TODO std::ignore = container; std::ignore = block; std::ignore = arguments; @@ -417,17 +413,15 @@ public: this->data(place).read(buf); } - void predictResultInto(ConstAggregateDataPtr place, IColumn & to, Block & block, size_t row_num, const ColumnNumbers & arguments) const + void predictResultInto(ConstAggregateDataPtr place, IColumn & to, Block & block, const ColumnNumbers & arguments) const { - std::ignore = row_num; - std::cout << "\n\n IM CALLED \n\n"; - if (arguments.size() != param_num + 1) throw Exception("Predict got incorrect number of arguments. Got: " + std::to_string(arguments.size()) + ". Required: " + std::to_string(param_num + 1), ErrorCodes::NUMBER_OF_ARGUMENTS_DOESNT_MATCH); auto &column = dynamic_cast &>(to); + /// Так делали с одним предиктом, пока пусть побудет тут // std::vector predict_features(arguments.size() - 1); // for (size_t i = 1; i < arguments.size(); ++i) // { diff --git a/dbms/src/Columns/ColumnAggregateFunction.cpp b/dbms/src/Columns/ColumnAggregateFunction.cpp index d5db26e3420..52f2f087b9e 100644 --- a/dbms/src/Columns/ColumnAggregateFunction.cpp +++ b/dbms/src/Columns/ColumnAggregateFunction.cpp @@ -108,28 +108,14 @@ MutableColumnPtr ColumnAggregateFunction::convertToValues() const MutableColumnPtr ColumnAggregateFunction::predictValues(Block & block, const ColumnNumbers & arguments) const { -// if (const AggregateFunctionState * function_state = typeid_cast(func.get())) -// { -// auto res = createView(); -// res->set(function_state->getNestedFunction()); -// res->data.assign(data.begin(), data.end()); -// return res; -// } -// -// MutableColumnPtr res = func->getReturnType()->createColumn(); -// res->reserve(data.size()); MutableColumnPtr res; if (convertion(&res)) { return res; } - std::cout << "\n\nHELLO: " << data.size() << "\n\n"; /// На моих тестах дважды в эту функцию приходит нечтно, имеющее data.size() == 0 однако оно по сути ничего не делает в следующих строках - if (1 != data.size()) - return res; -// auto ML_function = typeid_cast *>(func.get()); auto ML_function_Linear = typeid_cast *>(func.get()); auto ML_function_Logistic = typeid_cast *>(func.get()); if (ML_function_Linear) @@ -137,17 +123,16 @@ MutableColumnPtr ColumnAggregateFunction::predictValues(Block & block, const Col size_t row_num = 0; for (auto val : data) { - ML_function_Linear->predictResultInto(val, *res, block, row_num, arguments); + ML_function_Linear->predictResultInto(val, *res, block, arguments); ++row_num; } -// ML_function_Linear->predictResultInto(data[0], *res, block, row_num, arguments); } else if (ML_function_Logistic) { size_t row_num = 0; for (auto val : data) { - ML_function_Logistic->predictResultInto(val, *res, block, row_num, arguments); + ML_function_Logistic->predictResultInto(val, *res, block, arguments); ++row_num; } } else diff --git a/dbms/src/Functions/evalMLMethod.cpp b/dbms/src/Functions/evalMLMethod.cpp index 23e21b3605f..2585c2ae1c9 100644 --- a/dbms/src/Functions/evalMLMethod.cpp +++ b/dbms/src/Functions/evalMLMethod.cpp @@ -63,14 +63,14 @@ namespace DB // typeid_cast(static_cast(&*block.getByPosition(arguments.at(0)).column)); -// std::cout << "\n\n\nHELOOOOO\n\n\n"; // завести МЛ_аггр_функции как отдельный класс, чтобы тут сразу это проверять, а не делать это внутри predictValues() - const ColumnAggregateFunction * column_with_states - = typeid_cast(&*block.getByPosition(arguments.at(0)).column); -// std::cout << "\n\n\nHELOOOOO 2\n\n\n"; -// const ColumnConst * column_with_states -// = typeid_cast(&*block.getByPosition(arguments.at(0)).column); +// const ColumnAggregateFunction * column_with_states +// = typeid_cast(&*block.getByPosition(arguments.at(0)).column); + + + const ColumnConst * column_with_states + = typeid_cast(&*block.getByPosition(arguments.at(0)).column); if (!column_with_states) @@ -94,7 +94,8 @@ namespace DB } block.getByPosition(result).column = column_with_states->predictValues(predict_features); */ - block.getByPosition(result).column = column_with_states->predictValues(block, arguments); + block.getByPosition(result).column = + typeid_cast(&*column_with_states->getDataColumnPtr())->predictValues(block, arguments); } }; diff --git a/dbms/tests/queries/0_stateless/00950_ml_test.reference b/dbms/tests/queries/0_stateless/00950_ml_test.reference index 8a9f3c31da5..6326f98fcd1 100644 --- a/dbms/tests/queries/0_stateless/00950_ml_test.reference +++ b/dbms/tests/queries/0_stateless/00950_ml_test.reference @@ -1,300 +1,300 @@ --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 --66.99407003753556 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 +-67.00423606399804 diff --git a/dbms/tests/queries/0_stateless/00950_ml_test.sql b/dbms/tests/queries/0_stateless/00950_ml_test.sql index 4c1abb78bb6..0a009c29d29 100644 --- a/dbms/tests/queries/0_stateless/00950_ml_test.sql +++ b/dbms/tests/queries/0_stateless/00950_ml_test.sql @@ -1,6 +1,6 @@ CREATE DATABASE IF NOT EXISTS test; -DROP TABLE IF EXISTS test.mldata; -CREATE TABLE IF NOT EXISTS test.mldata +DROP TABLE IF EXISTS test.defaults; +CREATE TABLE IF NOT EXISTS test.defaults ( param1 Float64, param2 Float64, @@ -8,53 +8,10 @@ CREATE TABLE IF NOT EXISTS test.mldata predict1 Float64, predict2 Float64 ) ENGINE = Memory; --- -- insert into test.defaults values (2.533, 0.543, 3.181), (1.999, 1.765, 0.470), (0.631, 2.580, -1.845), (-1.164, 0.889, 0.640), (2.110, 0.768, 2.519), (1.251, 0.483, 2.659), (-3.958, 1.299, -1.576), (-2.152, -1.316, 4.556), (3.269, 1.441, 1.753), (4.206, -1.635, 8.373), (-3.479, -0.544, 2.349), (4.006, 0.167, 4.670), (-4.478, 2.400, -4.039), (1.856, 0.256, 3.417), (1.470, 1.685, 0.366), (-4.052, 2.326, -3.678), (-0.971, -0.969, 4.453), (0.881, -1.848, 7.137), (-1.551, -1.766, 5.756), (-0.988, -0.945, 4.395), (-4.636, 1.074, -1.466), (-4.074, -1.486, 3.934), (0.754, 2.627, -1.877), (1.035, 0.889, 1.738), (3.707, -1.281, 7.415), (-2.215, 1.110, -0.327), (-2.965, -1.316, 4.150), (-3.581, 1.063, -0.917), (0.548, 0.343, 2.588), (3.023, -0.870, 6.251), (4.053, -1.441, 7.909), (-0.750, 0.639, 1.348), (-4.411, 1.636, -2.477), (1.786, 0.398, 3.096), (-2.514, 0.033, 1.676), (4.935, -0.840, 7.148), (1.075, -0.921, 5.380), (-3.418, 2.177, -3.063), (3.122, 1.883, 0.795), (-2.254, -1.389, 4.650), (-4.603, 2.909, -5.119), (-1.886, -1.220, 4.497), (-0.509, -1.498, 5.741), (2.192, 1.882, 0.332), (4.056, -1.108, 7.244), (-1.918, 0.230, 1.581), (4.867, 1.516, 2.401), (-0.993, -0.011, 2.526), (-0.757, -1.192, 5.006), (-4.161, 2.059, -3.198), (2.258, 1.157, 1.814), (-3.878, -0.052, 1.165), (1.915, 2.998, -2.038), (-2.164, 2.379, -2.841), (-0.114, -1.914, 6.772), (3.812, 2.138, 0.630), (-1.863, 1.508, -0.947), (-2.964, 0.398, 0.722), (-2.046, -0.193, 2.363), (-1.525, -0.836, 3.910), (-4.557, -0.582, 1.886), (1.031, -0.461, 4.437), (-0.802, 0.699, 1.201), (3.982, 2.084, 0.824), (-2.243, 2.726, -3.573), (-3.989, -0.803, 2.611), (4.900, 0.253, 4.944), (-1.208, -1.587, 5.571), (0.370, 2.579, -1.972), (2.824, 0.964, 2.484), (-1.290, -0.128, 2.611), (0.190, 2.058, -1.021), (4.058, 2.122, 0.784), (4.879, 0.945, 3.549), (1.119, 1.992, -0.424), (4.050, 2.005, 1.015), (-0.064, 1.485, -0.002), (-2.496, 0.456, 0.840), (-1.835, 1.586, -1.090), (0.603, 1.856, -0.411), (-3.062, -0.966, 3.401), (-3.351, 0.430, 0.465), (-2.724, -1.331, 4.299), (3.291, -1.027, 6.699), (-4.263, 0.785, -0.701), (-3.289, -0.886, 3.128), (4.627, 1.331, 2.651), (-0.618, 0.602, 1.486), (0.056, 1.778, -0.528), (4.823, 1.154, 3.103), (-3.983, 0.509, -0.010), (-4.474, -1.400, 3.563), (-3.782, 2.996, -4.883), (4.515, -0.656, 6.569), (1.269, 2.592, -1.549), (-1.710, -0.241, 2.627), (2.171, 1.453, 1.180), (-1.931, -1.845, 5.726), (1.767, -1.798, 7.480), (4.352, 2.369, 0.438), (-4.498, 2.611, -4.472), (0.067, 0.517, 2.000), (4.151, 0.624, 3.827), (0.409, -0.969, 5.142), (0.193, -1.713, 6.522), (-2.487, 2.827, -3.898), (-4.363, 2.011, -3.203), (-2.383, 2.554, -3.299), (-4.457, -0.958, 2.687), (3.342, -0.360, 5.392), (0.902, 2.978, -2.505), (4.073, -1.524, 8.084), (3.036, 1.672, 1.173), (2.169, -0.564, 5.213), (-4.780, 0.962, -1.313), (-1.815, 2.096, -2.100), (-1.445, 0.458, 1.362), (1.891, -1.437, 6.820), (1.942, -1.761, 7.493), (-4.613, -1.551, 3.795), (-3.472, -1.110, 3.485), (-2.026, 1.961, -1.935), (0.091, -0.961, 4.967), (3.902, -1.336, 7.622), (-3.483, -0.769, 2.796), (-0.066, -1.233, 5.433), (2.597, 2.789, -1.280), (-1.657, -1.842, 5.856), (0.232, -1.420, 5.957), (-3.321, 1.609, -1.879), (2.673, 2.781, -1.226), (0.869, 0.072, 3.291), (1.444, -1.271, 6.264), (1.190, 1.460, 0.675), (3.497, 0.870, 3.008), (-2.884, -1.303, 4.163), (3.620, 0.381, 4.047), (2.594, 0.247, 3.803), (-3.902, -1.315, 3.678), (-4.753, -1.005, 2.634), (0.881, 0.675, 2.091), (0.414, 2.071, -0.935), (3.458, -0.920, 6.568), (-2.986, -0.411, 2.329), (3.076, -1.960, 8.458), (2.951, 2.988, -1.501), (2.408, 1.301, 1.603), (4.725, 0.366, 4.631), (4.924, -1.762, 8.985), (3.719, 0.970, 2.920), (-0.295, 0.257, 2.340), (-4.607, 2.548, -4.400), (0.288, 1.953, -0.761), (-3.311, 0.844, -0.344), (3.679, -0.642, 6.123), (-2.310, -0.838, 3.522), (-4.397, -0.226, 1.254), (-4.366, -0.024, 0.864), (2.405, 1.458, 1.286), (-4.296, -1.071, 2.994), (0.452, -1.901, 7.028), (-0.214, -0.467, 3.827), (2.559, 1.547, 1.185), (0.990, 1.539, 0.417), (0.478, -0.089, 3.417), (-2.734, -1.007, 3.646), (3.483, 0.247, 4.247), (3.507, 2.727, -0.701), (-4.399, 2.437, -4.073), (3.785, 0.036, 4.820), (-0.824, 2.417, -2.245), (-2.588, 0.369, 0.968), (-3.037, -1.639, 4.759), (4.531, -0.499, 6.264), (4.742, -1.161, 7.693), (-0.063, -0.595, 4.159), (0.697, 2.281, -1.212), (0.413, 0.607, 1.992), (-4.081, 0.383, 0.194), (0.712, 2.638, -1.920), (-1.620, 1.092, 0.006), (-3.425, -0.911, 3.109), (-0.124, 1.711, -0.484), (4.347, 1.387, 2.399), (-3.237, -0.900, 3.182), (-3.961, 0.358, 0.304), (4.326, -0.068, 5.298), (3.846, 1.725, 1.473), (-2.089, 0.953, 0.049), (-1.025, -1.470, 5.428), (2.061, -0.156, 4.343), (1.547, -1.827, 7.427), (2.786, 0.460, 3.473), (0.076, 0.659, 1.720), (3.597, 1.966, 0.866), (-0.933, -1.180, 4.894), (4.647, 1.190, 2.943), (-0.032, 0.544, 1.896), (4.461, -1.806, 8.843), (-0.586, 1.821, -0.934), (3.725, 1.715, 1.432), (-2.091, 2.714, -3.474), (4.494, -1.494, 8.236), (3.766, -0.209, 5.301), (-1.991, 1.776, -1.548), (-4.992, -0.742, 1.989), (-2.400, 1.828, -1.855), (-1.329, 0.143, 2.050), (1.954, 1.759, 0.459), (-4.422, 1.507, -2.224), (-2.243, -1.126, 4.131), (4.417, -1.080, 7.368), (1.737, -1.144, 6.157), (2.661, -1.084, 6.498), (-3.198, 0.443, 0.515), (4.191, -1.250, 7.596), (-2.419, -0.163, 2.116), (1.910, -1.173, 6.301), (-0.241, 1.902, -0.925), (-4.415, 2.479, -4.165), (3.307, -0.465, 5.583), (-2.382, 1.364, -0.920), (-3.154, 2.953, -4.483), (-2.562, 2.803, -3.888), (3.076, 0.195, 4.149), (-0.101, 0.896, 1.157), (-2.067, 1.120, -0.273), (-4.680, 2.756, -4.851), (-4.283, -0.607, 2.072), (4.013, -1.072, 7.150), (-4.401, -0.896, 2.591), (4.544, 2.498, 0.276), (4.075, -1.204, 7.445), (-3.463, 1.242, -1.216), (3.992, 2.782, -0.568), (-4.503, 0.239, 0.270), (-3.095, 1.161, -0.870), (0.768, -0.904, 5.192), (1.255, 2.870, -2.112), (-1.537, -0.049, 2.330), (2.851, -1.182, 6.789), (1.974, -0.922, 5.832), (4.447, 2.719, -0.214), (-3.413, 0.555, 0.184), (4.943, 2.120, 1.231), (3.645, -0.413, 5.648), (-4.776, 0.079, 0.453), (1.991, 1.565, 0.866), (2.413, 1.793, 0.620), (4.245, 2.663, -0.205), (-2.022, -1.180, 4.350), (-2.285, -1.246, 4.350), (2.276, 0.488, 3.162), (2.582, -0.037, 4.365), (-4.875, 1.468, -2.374), (-2.492, 2.730, -3.706), (2.696, -1.833, 8.013), (4.618, -1.127, 7.563), (-4.156, 0.987, -1.053), (1.873, -1.566, 7.068), (1.699, 0.794, 2.262), (-3.181, 1.640, -1.871), (-3.225, 1.526, -1.664), (-2.679, -1.811, 5.281), (3.717, 1.532, 1.794), (1.288, -0.999, 5.642), (-1.057, 0.044, 2.384), (-0.147, 1.108, 0.711), (-3.827, -1.139, 3.365), (0.872, -1.482, 6.399), (1.982, 0.286, 3.418), (-1.381, 2.374, -2.439), (-1.091, 2.010, -1.565), (-1.192, 2.751, -3.097), (1.468, -0.992, 5.718), (2.249, 0.949, 2.228), (3.064, 0.911, 2.711), (-1.576, -1.584, 5.380), (2.130, -1.489, 7.043), (4.386, -1.284, 7.761), (1.662, -1.645, 7.121), (-3.395, 1.784, -2.265), (4.618, 1.951, 1.406), (-0.299, 0.378, 2.095), (-2.911, 2.131, -2.717), (0.876, 2.869, -2.301), (-1.785, 0.961, 0.186), (-4.188, 2.442, -3.977), (-1.128, 0.127, 2.181), (1.755, -1.215, 6.307), (-2.276, 0.596, 0.669), (-4.630, 1.978, -3.272), (-0.454, 0.275, 2.224), (-1.950, -1.385, 4.794), (-0.889, 2.696, -2.837), (-4.832, -0.038, 0.661), (3.738, 0.604, 3.662), (-0.224, -0.465, 3.819); --- insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0), (-1.099, 2.755, -3.060, 20.0, 40.0), (1.090, 2.945, -2.346, 20.0, 40.0), (0.305, 2.179, -1.205, 20.0, 40.0), (-0.925, 0.702, 1.134, 20.0, 40.0), (3.178, -1.316, 7.221, 20.0, 40.0), (-2.756, -0.473, 2.569, 20.0, 40.0), (3.665, 2.303, 0.226, 20.0, 40.0), (1.662, 1.951, -0.070, 20.0, 40.0), (2.869, 0.593, 3.249, 20.0, 40.0), (0.818, -0.593, 4.594, 20.0, 40.0), (-1.917, 0.916, 0.209, 20.0, 40.0), (2.706, 1.523, 1.307, 20.0, 40.0), (0.219, 2.162, -1.214, 20.0, 40.0), (-4.510, 1.376, -2.007, 20.0, 40.0), (4.284, -0.515, 6.173, 20.0, 40.0), (-1.101, 2.810, -3.170, 20.0, 40.0), (-1.810, -1.117, 4.329, 20.0, 40.0), (0.055, 1.115, 0.797, 20.0, 40.0), (-2.178, 2.904, -3.898, 20.0, 40.0), (-3.494, -1.814, 4.882, 20.0, 40.0), (3.027, 0.476, 3.562, 20.0, 40.0), (-1.434, 1.151, -0.018, 20.0, 40.0), (1.180, 0.992, 1.606, 20.0, 40.0), (0.015, 0.971, 1.067, 20.0, 40.0), (-0.511, -0.875, 4.495, 20.0, 40.0), (0.961, 2.348, -1.216, 20.0, 40.0), (-2.279, 0.038, 1.785, 20.0, 40.0), (-1.568, -0.248, 2.712, 20.0, 40.0), (-0.496, 0.366, 2.020, 20.0, 40.0), (1.177, -1.401, 6.390, 20.0, 40.0), (2.882, -1.442, 7.325, 20.0, 40.0), (-1.066, 1.817, -1.167, 20.0, 40.0), (-2.144, 2.791, -3.655, 20.0, 40.0), (-4.370, 2.228, -3.642, 20.0, 40.0), (3.996, 2.775, -0.553, 20.0, 40.0), (0.289, 2.055, -0.965, 20.0, 40.0), (-0.588, -1.601, 5.908, 20.0, 40.0), (-1.801, 0.417, 1.265, 20.0, 40.0), (4.375, -1.499, 8.186, 20.0, 40.0), (-2.618, 0.038, 1.615, 20.0, 40.0), (3.616, -0.833, 6.475, 20.0, 40.0), (-4.045, -1.558, 4.094, 20.0, 40.0), (-3.962, 0.636, -0.253, 20.0, 40.0), (3.505, 2.625, -0.497, 20.0, 40.0), (3.029, -0.523, 5.560, 20.0, 40.0), (-3.520, -0.474, 2.188, 20.0, 40.0), (2.430, -1.469, 7.154, 20.0, 40.0), (1.547, -1.654, 7.082, 20.0, 40.0), (-1.370, 0.575, 1.165, 20.0, 40.0), (-1.869, -1.555, 5.176, 20.0, 40.0), (3.536, 2.841, -0.913, 20.0, 40.0), (-3.810, 1.220, -1.344, 20.0, 40.0), (-1.971, 1.462, -0.910, 20.0, 40.0), (-0.243, 0.167, 2.545, 20.0, 40.0), (-1.403, 2.645, -2.991, 20.0, 40.0), (0.532, -0.114, 3.494, 20.0, 40.0), (-1.678, 0.975, 0.212, 20.0, 40.0), (-0.656, 2.140, -1.609, 20.0, 40.0), (1.743, 2.631, -1.390, 20.0, 40.0), (2.586, 2.943, -1.593, 20.0, 40.0), (-0.512, 2.969, -3.195, 20.0, 40.0), (2.283, -0.100, 4.342, 20.0, 40.0), (-4.293, 0.872, -0.890, 20.0, 40.0), (3.411, 1.300, 2.106, 20.0, 40.0), (-0.281, 2.951, -3.042, 20.0, 40.0), (-4.442, 0.384, 0.012, 20.0, 40.0), (1.194, 1.746, 0.104, 20.0, 40.0), (-1.152, 1.862, -1.300, 20.0, 40.0), (1.362, -1.341, 6.363, 20.0, 40.0), (-4.488, 2.618, -4.481, 20.0, 40.0), (3.419, -0.564, 5.837, 20.0, 40.0), (-3.392, 0.396, 0.512, 20.0, 40.0), (-1.629, -0.909, 4.003, 20.0, 40.0), (4.447, -1.088, 7.399, 20.0, 40.0), (-1.232, 1.699, -1.014, 20.0, 40.0), (-1.286, -0.609, 3.575, 20.0, 40.0), (2.437, 2.796, -1.374, 20.0, 40.0), (-4.864, 1.989, -3.410, 20.0, 40.0), (-1.716, -1.399, 4.940, 20.0, 40.0), (-3.084, 1.858, -2.259, 20.0, 40.0), (2.828, -0.319, 5.053, 20.0, 40.0), (-1.226, 2.586, -2.786, 20.0, 40.0), (2.456, 0.092, 4.044, 20.0, 40.0), (-0.989, 2.375, -2.245, 20.0, 40.0), (3.268, 0.935, 2.765, 20.0, 40.0), (-4.128, -1.995, 4.927, 20.0, 40.0), (-1.083, 2.197, -1.935, 20.0, 40.0), (-3.471, -1.198, 3.660, 20.0, 40.0), (4.617, -1.136, 7.579, 20.0, 40.0), (2.054, -1.675, 7.378, 20.0, 40.0), (4.106, 2.326, 0.402, 20.0, 40.0), (1.558, 0.310, 3.158, 20.0, 40.0), (0.792, 0.900, 1.596, 20.0, 40.0), (-3.229, 0.300, 0.785, 20.0, 40.0), (3.787, -0.793, 6.479, 20.0, 40.0), (1.786, 2.288, -0.684, 20.0, 40.0), (2.643, 0.223, 3.875, 20.0, 40.0), (-3.592, 2.122, -3.040, 20.0, 40.0), (4.519, -1.760, 8.779, 20.0, 40.0), (3.221, 2.255, 0.101, 20.0, 40.0), (4.151, 1.788, 1.500, 20.0, 40.0), (-1.033, -1.195, 4.874, 20.0, 40.0), (-1.636, -1.037, 4.257, 20.0, 40.0), (-3.548, 1.911, -2.596, 20.0, 40.0), (4.829, -0.293, 6.001, 20.0, 40.0), (-4.684, -1.664, 3.986, 20.0, 40.0), (4.531, -0.503, 6.271, 20.0, 40.0), (-3.503, -1.606, 4.460, 20.0, 40.0), (-2.036, -1.522, 5.027, 20.0, 40.0), (-0.473, -0.617, 3.997, 20.0, 40.0), (-1.554, -1.630, 5.483, 20.0, 40.0), (-3.567, -1.043, 3.302, 20.0, 40.0), (-2.038, 0.579, 0.823, 20.0, 40.0), (-3.040, 0.857, -0.233, 20.0, 40.0), (4.610, 0.562, 4.181, 20.0, 40.0), (-3.323, -1.938, 5.215, 20.0, 40.0), (4.314, 1.720, 1.717, 20.0, 40.0), (-1.220, 0.615, 1.161, 20.0, 40.0), (-2.556, 1.120, -0.519, 20.0, 40.0), (-3.717, -0.108, 1.358, 20.0, 40.0), (4.689, -1.826, 8.996, 20.0, 40.0), (3.452, 0.506, 3.713, 20.0, 40.0), (2.472, 0.612, 3.012, 20.0, 40.0), (3.452, 0.450, 3.826, 20.0, 40.0), (1.207, 2.585, -1.567, 20.0, 40.0), (-4.826, 1.090, -1.593, 20.0, 40.0), (3.116, -1.118, 6.794, 20.0, 40.0), (0.448, 2.732, -2.240, 20.0, 40.0), (-1.096, -0.525, 3.503, 20.0, 40.0), (-4.680, -0.238, 1.137, 20.0, 40.0), (2.552, -1.403, 7.082, 20.0, 40.0), (0.719, 2.997, -2.635, 20.0, 40.0), (0.347, -1.966, 7.105, 20.0, 40.0), (2.958, -0.404, 5.288, 20.0, 40.0), (0.722, -1.950, 7.261, 20.0, 40.0), (-2.851, -0.986, 3.546, 20.0, 40.0), (-4.316, -0.439, 1.721, 20.0, 40.0), (-1.685, -0.201, 2.560, 20.0, 40.0), (1.856, 0.190, 3.549, 20.0, 40.0), (-2.052, 0.206, 1.562, 20.0, 40.0), (-2.504, -0.646, 3.041, 20.0, 40.0), (3.235, 0.882, 2.854, 20.0, 40.0), (-1.366, -1.573, 5.463, 20.0, 40.0), (-3.447, 2.419, -3.562, 20.0, 40.0), (4.155, 2.092, 0.893, 20.0, 40.0), (-0.935, 0.209, 2.116, 20.0, 40.0), (3.117, -1.821, 8.201, 20.0, 40.0), (3.759, 0.577, 3.725, 20.0, 40.0), (-0.938, 2.992, -3.453, 20.0, 40.0), (-0.525, 2.341, -1.945, 20.0, 40.0), (4.540, 2.625, 0.019, 20.0, 40.0), (-2.097, 1.190, -0.429, 20.0, 40.0), (-2.672, 1.983, -2.302, 20.0, 40.0), (-3.038, -1.490, 4.460, 20.0, 40.0), (-0.943, 2.149, -1.770, 20.0, 40.0), (0.739, 1.598, 0.174, 20.0, 40.0), (1.828, 1.853, 0.208, 20.0, 40.0), (4.856, 0.137, 5.153, 20.0, 40.0), (-1.617, 0.468, 1.255, 20.0, 40.0), (-1.972, 2.053, -2.092, 20.0, 40.0), (-4.633, 1.389, -2.094, 20.0, 40.0), (-3.628, -1.156, 3.498, 20.0, 40.0), (3.597, 1.034, 2.731, 20.0, 40.0), (-1.488, -0.002, 2.261, 20.0, 40.0), (0.749, 1.921, -0.468, 20.0, 40.0), (1.304, -1.371, 6.394, 20.0, 40.0), (4.587, 2.936, -0.579, 20.0, 40.0), (-2.241, 1.791, -1.703, 20.0, 40.0), (-2.945, 1.372, -1.216, 20.0, 40.0), (1.375, 0.395, 2.898, 20.0, 40.0), (-1.281, -0.641, 3.642, 20.0, 40.0), (2.178, 0.895, 2.299, 20.0, 40.0), (3.031, -0.786, 6.087, 20.0, 40.0), (-1.385, -0.375, 3.058, 20.0, 40.0), (4.041, -0.431, 5.882, 20.0, 40.0), (0.480, -0.507, 4.254, 20.0, 40.0), (-3.797, 0.140, 0.822, 20.0, 40.0), (2.355, 2.502, -0.827, 20.0, 40.0), (1.376, -1.583, 6.854, 20.0, 40.0), (0.164, 1.405, 0.273, 20.0, 40.0), (-1.273, 1.471, -0.579, 20.0, 40.0), (0.770, 2.246, -1.107, 20.0, 40.0), (4.552, 2.904, -0.533, 20.0, 40.0), (4.259, -1.772, 8.674, 20.0, 40.0), (-0.309, 1.159, 0.528, 20.0, 40.0), (3.581, 2.700, -0.610, 20.0, 40.0), (-3.202, 0.346, 0.707, 20.0, 40.0), (-1.575, 1.242, -0.271, 20.0, 40.0), (-1.584, -0.493, 3.194, 20.0, 40.0), (-3.778, 0.150, 0.810, 20.0, 40.0), (-4.675, 1.749, -2.835, 20.0, 40.0), (3.567, -0.792, 6.367, 20.0, 40.0), (-0.417, 1.399, -0.006, 20.0, 40.0), (-4.672, 2.007, -3.349, 20.0, 40.0), (-1.034, 0.196, 2.090, 20.0, 40.0), (-3.796, 2.496, -3.890, 20.0, 40.0), (3.532, -0.497, 5.759, 20.0, 40.0), (4.868, -1.359, 8.151, 20.0, 40.0), (-0.769, 0.302, 2.011, 20.0, 40.0), (4.475, 2.612, 0.014, 20.0, 40.0), (-3.532, -0.395, 2.024, 20.0, 40.0), (0.322, 0.675, 1.812, 20.0, 40.0), (-2.028, -1.942, 5.870, 20.0, 40.0), (1.810, -1.244, 6.392, 20.0, 40.0), (-0.783, 1.242, 0.124, 20.0, 40.0), (-4.745, -1.300, 3.227, 20.0, 40.0), (1.902, 1.973, 0.005, 20.0, 40.0), (-3.453, -1.429, 4.132, 20.0, 40.0), (1.559, 0.986, 1.808, 20.0, 40.0), (0.128, 2.754, -2.443, 20.0, 40.0), (2.759, 1.727, 0.926, 20.0, 40.0), (-4.468, 1.690, -2.614, 20.0, 40.0), (-2.368, -1.922, 5.659, 20.0, 40.0), (-2.766, 2.128, -2.640, 20.0, 40.0), (0.967, -1.825, 7.133, 20.0, 40.0), (-2.854, 2.855, -4.136, 20.0, 40.0), (-2.944, 1.875, -2.222, 20.0, 40.0), (-2.632, -0.983, 3.649, 20.0, 40.0), (2.427, 2.239, -0.266, 20.0, 40.0), (-1.726, -0.838, 3.812, 20.0, 40.0), (0.007, -0.903, 4.809, 20.0, 40.0), (-2.013, 1.092, -0.191, 20.0, 40.0), (-0.449, 0.970, 0.836, 20.0, 40.0), (1.396, 0.411, 2.876, 20.0, 40.0), (-1.115, -1.790, 6.023, 20.0, 40.0), (3.748, 1.917, 1.039, 20.0, 40.0), (2.978, 1.043, 2.404, 20.0, 40.0), (-3.969, 2.514, -4.013, 20.0, 40.0), (4.455, -0.050, 5.328, 20.0, 40.0), (-3.065, -0.846, 3.160, 20.0, 40.0), (-1.069, 2.167, -1.869, 20.0, 40.0), (3.016, -1.393, 7.294, 20.0, 40.0), (0.045, -1.928, 6.879, 20.0, 40.0), (-2.555, -0.984, 3.690, 20.0, 40.0), (-1.995, -0.054, 2.111, 20.0, 40.0), (4.600, -0.509, 6.318, 20.0, 40.0), (-1.942, 1.215, -0.402, 20.0, 40.0), (1.262, 2.765, -1.899, 20.0, 40.0), (2.617, -1.106, 6.521, 20.0, 40.0), (1.737, 0.554, 2.761, 20.0, 40.0), (-2.197, 0.632, 0.638, 20.0, 40.0), (4.768, 2.618, 0.147, 20.0, 40.0), (-3.737, -0.939, 3.010, 20.0, 40.0), (-2.623, 0.595, 0.499, 20.0, 40.0), (4.752, -0.340, 6.057, 20.0, 40.0), (2.333, -1.037, 6.240, 20.0, 40.0), (4.234, -1.882, 8.881, 20.0, 40.0), (-3.393, -0.812, 2.927, 20.0, 40.0), (0.885, 1.383, 0.678, 20.0, 40.0), (0.123, 2.937, -2.812, 20.0, 40.0), (2.969, 0.760, 2.964, 20.0, 40.0), (-4.929, 1.251, -1.967, 20.0, 40.0), (1.916, 2.223, -0.488, 20.0, 40.0), (-0.020, -1.740, 6.469, 20.0, 40.0), (0.702, -1.272, 5.895, 20.0, 40.0), (2.496, 2.648, -1.048, 20.0, 40.0), (4.067, -1.475, 7.984, 20.0, 40.0), (-3.717, 1.851, -2.561, 20.0, 40.0), (1.678, -0.624, 5.088, 20.0, 40.0), (1.073, 0.695, 2.146, 20.0, 40.0), (1.842, -0.749, 5.419, 20.0, 40.0), (-3.518, 1.909, -2.578, 20.0, 40.0), (2.229, 1.189, 1.737, 20.0, 40.0), (4.987, 2.893, -0.292, 20.0, 40.0), (-4.809, 1.043, -1.490, 20.0, 40.0), (-0.241, -0.728, 4.334, 20.0, 40.0), (-3.331, 0.590, 0.156, 20.0, 40.0), (-0.455, 2.621, -2.470, 20.0, 40.0), (1.492, 1.223, 1.301, 20.0, 40.0), (3.948, 2.841, -0.709, 20.0, 40.0), (0.732, 0.446, 2.475, 20.0, 40.0), (2.400, 2.390, -0.579, 20.0, 40.0), (-2.718, 1.427, -1.213, 20.0, 40.0), (-1.826, 1.451, -0.815, 20.0, 40.0), (1.125, 0.438, 2.686, 20.0, 40.0), (-4.918, 1.880, -3.219, 20.0, 40.0), (3.068, -0.442, 5.418, 20.0, 40.0), (1.982, 1.201, 1.589, 20.0, 40.0), (0.701, -1.709, 6.768, 20.0, 40.0), (-1.496, 2.564, -2.877, 20.0, 40.0), (-3.812, 0.974, -0.853, 20.0, 40.0), (-3.405, 2.018, -2.739, 20.0, 40.0), (2.211, 2.889, -1.674, 20.0, 40.0), (-2.481, 2.931, -4.103, 20.0, 40.0), (-3.721, 2.765, -4.391, 20.0, 40.0), (-1.768, -1.292, 4.699, 20.0, 40.0), (-4.462, 1.058, -1.347, 20.0, 40.0), (-3.516, -1.942, 5.126, 20.0, 40.0), (0.485, 2.420, -1.597, 20.0, 40.0), (-0.492, 0.242, 2.270, 20.0, 40.0), (4.245, 1.689, 1.744, 20.0, 40.0), (2.234, 0.364, 3.389, 20.0, 40.0), (2.629, 2.224, -0.134, 20.0, 40.0), (-4.375, 1.221, -1.630, 20.0, 40.0), (-0.618, 1.374, -0.057, 20.0, 40.0), (-2.580, -1.604, 4.918, 20.0, 40.0), (0.159, 1.104, 0.871, 20.0, 40.0), (-3.597, 0.975, -0.749, 20.0, 40.0); --- insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0), (-1.099, 2.755, -3.060, 20.0, 40.0), (1.090, 2.945, -2.346, 20.0, 40.0), (0.305, 2.179, -1.205, 20.0, 40.0), (-0.925, 0.702, 1.134, 20.0, 40.0), (3.178, -1.316, 7.221, 20.0, 40.0), (-2.756, -0.473, 2.569, 20.0, 40.0), (3.665, 2.303, 0.226, 20.0, 40.0), (1.662, 1.951, -0.070, 20.0, 40.0), (2.869, 0.593, 3.249, 20.0, 40.0), (0.818, -0.593, 4.594, 20.0, 40.0), (-1.917, 0.916, 0.209, 20.0, 40.0), (2.706, 1.523, 1.307, 20.0, 40.0), (0.219, 2.162, -1.214, 20.0, 40.0), (-4.510, 1.376, -2.007, 20.0, 40.0), (4.284, -0.515, 6.173, 20.0, 40.0), (-1.101, 2.810, -3.170, 20.0, 40.0), (-1.810, -1.117, 4.329, 20.0, 40.0), (0.055, 1.115, 0.797, 20.0, 40.0), (-2.178, 2.904, -3.898, 20.0, 40.0), (-3.494, -1.814, 4.882, 20.0, 40.0), (3.027, 0.476, 3.562, 20.0, 40.0), (-1.434, 1.151, -0.018, 20.0, 40.0), (1.180, 0.992, 1.606, 20.0, 40.0), (0.015, 0.971, 1.067, 20.0, 40.0), (-0.511, -0.875, 4.495, 20.0, 40.0), (0.961, 2.348, -1.216, 20.0, 40.0), (-2.279, 0.038, 1.785, 20.0, 40.0), (-1.568, -0.248, 2.712, 20.0, 40.0), (-0.496, 0.366, 2.020, 20.0, 40.0), (1.177, -1.401, 6.390, 20.0, 40.0), (2.882, -1.442, 7.325, 20.0, 40.0), (-1.066, 1.817, -1.167, 20.0, 40.0), (-2.144, 2.791, -3.655, 20.0, 40.0), (-4.370, 2.228, -3.642, 20.0, 40.0), (3.996, 2.775, -0.553, 20.0, 40.0), (0.289, 2.055, -0.965, 20.0, 40.0), (-0.588, -1.601, 5.908, 20.0, 40.0), (-1.801, 0.417, 1.265, 20.0, 40.0), (4.375, -1.499, 8.186, 20.0, 40.0), (-2.618, 0.038, 1.615, 20.0, 40.0), (3.616, -0.833, 6.475, 20.0, 40.0), (-4.045, -1.558, 4.094, 20.0, 40.0), (-3.962, 0.636, -0.253, 20.0, 40.0), (3.505, 2.625, -0.497, 20.0, 40.0), (3.029, -0.523, 5.560, 20.0, 40.0), (-3.520, -0.474, 2.188, 20.0, 40.0), (2.430, -1.469, 7.154, 20.0, 40.0), (1.547, -1.654, 7.082, 20.0, 40.0), (-1.370, 0.575, 1.165, 20.0, 40.0), (-1.869, -1.555, 5.176, 20.0, 40.0), (3.536, 2.841, -0.913, 20.0, 40.0), (-3.810, 1.220, -1.344, 20.0, 40.0), (-1.971, 1.462, -0.910, 20.0, 40.0), (-0.243, 0.167, 2.545, 20.0, 40.0), (-1.403, 2.645, -2.991, 20.0, 40.0), (0.532, -0.114, 3.494, 20.0, 40.0), (-1.678, 0.975, 0.212, 20.0, 40.0), (-0.656, 2.140, -1.609, 20.0, 40.0), (1.743, 2.631, -1.390, 20.0, 40.0), (2.586, 2.943, -1.593, 20.0, 40.0), (-0.512, 2.969, -3.195, 20.0, 40.0), (2.283, -0.100, 4.342, 20.0, 40.0), (-4.293, 0.872, -0.890, 20.0, 40.0), (3.411, 1.300, 2.106, 20.0, 40.0), (-0.281, 2.951, -3.042, 20.0, 40.0), (-4.442, 0.384, 0.012, 20.0, 40.0), (1.194, 1.746, 0.104, 20.0, 40.0), (-1.152, 1.862, -1.300, 20.0, 40.0), (1.362, -1.341, 6.363, 20.0, 40.0), (-4.488, 2.618, -4.481, 20.0, 40.0), (3.419, -0.564, 5.837, 20.0, 40.0), (-3.392, 0.396, 0.512, 20.0, 40.0), (-1.629, -0.909, 4.003, 20.0, 40.0), (4.447, -1.088, 7.399, 20.0, 40.0), (-1.232, 1.699, -1.014, 20.0, 40.0), (-1.286, -0.609, 3.575, 20.0, 40.0), (2.437, 2.796, -1.374, 20.0, 40.0), (-4.864, 1.989, -3.410, 20.0, 40.0), (-1.716, -1.399, 4.940, 20.0, 40.0), (-3.084, 1.858, -2.259, 20.0, 40.0), (2.828, -0.319, 5.053, 20.0, 40.0), (-1.226, 2.586, -2.786, 20.0, 40.0), (2.456, 0.092, 4.044, 20.0, 40.0), (-0.989, 2.375, -2.245, 20.0, 40.0), (3.268, 0.935, 2.765, 20.0, 40.0), (-4.128, -1.995, 4.927, 20.0, 40.0), (-1.083, 2.197, -1.935, 20.0, 40.0), (-3.471, -1.198, 3.660, 20.0, 40.0), (4.617, -1.136, 7.579, 20.0, 40.0), (2.054, -1.675, 7.378, 20.0, 40.0), (4.106, 2.326, 0.402, 20.0, 40.0), (1.558, 0.310, 3.158, 20.0, 40.0), (0.792, 0.900, 1.596, 20.0, 40.0), (-3.229, 0.300, 0.785, 20.0, 40.0), (3.787, -0.793, 6.479, 20.0, 40.0), (1.786, 2.288, -0.684, 20.0, 40.0), (2.643, 0.223, 3.875, 20.0, 40.0), (-3.592, 2.122, -3.040, 20.0, 40.0), (4.519, -1.760, 8.779, 20.0, 40.0), (3.221, 2.255, 0.101, 20.0, 40.0), (4.151, 1.788, 1.500, 20.0, 40.0), (-1.033, -1.195, 4.874, 20.0, 40.0), (-1.636, -1.037, 4.257, 20.0, 40.0), (-3.548, 1.911, -2.596, 20.0, 40.0), (4.829, -0.293, 6.001, 20.0, 40.0), (-4.684, -1.664, 3.986, 20.0, 40.0), (4.531, -0.503, 6.271, 20.0, 40.0), (-3.503, -1.606, 4.460, 20.0, 40.0), (-2.036, -1.522, 5.027, 20.0, 40.0), (-0.473, -0.617, 3.997, 20.0, 40.0), (-1.554, -1.630, 5.483, 20.0, 40.0), (-3.567, -1.043, 3.302, 20.0, 40.0), (-2.038, 0.579, 0.823, 20.0, 40.0), (-3.040, 0.857, -0.233, 20.0, 40.0), (4.610, 0.562, 4.181, 20.0, 40.0), (-3.323, -1.938, 5.215, 20.0, 40.0), (4.314, 1.720, 1.717, 20.0, 40.0), (-1.220, 0.615, 1.161, 20.0, 40.0), (-2.556, 1.120, -0.519, 20.0, 40.0), (-3.717, -0.108, 1.358, 20.0, 40.0), (4.689, -1.826, 8.996, 20.0, 40.0), (3.452, 0.506, 3.713, 20.0, 40.0), (2.472, 0.612, 3.012, 20.0, 40.0), (3.452, 0.450, 3.826, 20.0, 40.0), (1.207, 2.585, -1.567, 20.0, 40.0), (-4.826, 1.090, -1.593, 20.0, 40.0), (3.116, -1.118, 6.794, 20.0, 40.0), (0.448, 2.732, -2.240, 20.0, 40.0), (-1.096, -0.525, 3.503, 20.0, 40.0), (-4.680, -0.238, 1.137, 20.0, 40.0), (2.552, -1.403, 7.082, 20.0, 40.0), (0.719, 2.997, -2.635, 20.0, 40.0), (0.347, -1.966, 7.105, 20.0, 40.0), (2.958, -0.404, 5.288, 20.0, 40.0), (0.722, -1.950, 7.261, 20.0, 40.0), (-2.851, -0.986, 3.546, 20.0, 40.0), (-4.316, -0.439, 1.721, 20.0, 40.0), (-1.685, -0.201, 2.560, 20.0, 40.0), (1.856, 0.190, 3.549, 20.0, 40.0), (-2.052, 0.206, 1.562, 20.0, 40.0), (-2.504, -0.646, 3.041, 20.0, 40.0), (3.235, 0.882, 2.854, 20.0, 40.0), (-1.366, -1.573, 5.463, 20.0, 40.0), (-3.447, 2.419, -3.562, 20.0, 40.0), (4.155, 2.092, 0.893, 20.0, 40.0), (-0.935, 0.209, 2.116, 20.0, 40.0), (3.117, -1.821, 8.201, 20.0, 40.0), (3.759, 0.577, 3.725, 20.0, 40.0), (-0.938, 2.992, -3.453, 20.0, 40.0), (-0.525, 2.341, -1.945, 20.0, 40.0), (4.540, 2.625, 0.019, 20.0, 40.0), (-2.097, 1.190, -0.429, 20.0, 40.0), (-2.672, 1.983, -2.302, 20.0, 40.0), (-3.038, -1.490, 4.460, 20.0, 40.0), (-0.943, 2.149, -1.770, 20.0, 40.0), (0.739, 1.598, 0.174, 20.0, 40.0), (1.828, 1.853, 0.208, 20.0, 40.0), (4.856, 0.137, 5.153, 20.0, 40.0), (-1.617, 0.468, 1.255, 20.0, 40.0), (-1.972, 2.053, -2.092, 20.0, 40.0), (-4.633, 1.389, -2.094, 20.0, 40.0), (-3.628, -1.156, 3.498, 20.0, 40.0), (3.597, 1.034, 2.731, 20.0, 40.0), (-1.488, -0.002, 2.261, 20.0, 40.0), (0.749, 1.921, -0.468, 20.0, 40.0), (1.304, -1.371, 6.394, 20.0, 40.0), (4.587, 2.936, -0.579, 20.0, 40.0), (-2.241, 1.791, -1.703, 20.0, 40.0), (-2.945, 1.372, -1.216, 20.0, 40.0), (1.375, 0.395, 2.898, 20.0, 40.0), (-1.281, -0.641, 3.642, 20.0, 40.0), (2.178, 0.895, 2.299, 20.0, 40.0), (3.031, -0.786, 6.087, 20.0, 40.0), (-1.385, -0.375, 3.058, 20.0, 40.0), (4.041, -0.431, 5.882, 20.0, 40.0), (0.480, -0.507, 4.254, 20.0, 40.0), (-3.797, 0.140, 0.822, 20.0, 40.0), (2.355, 2.502, -0.827, 20.0, 40.0), (1.376, -1.583, 6.854, 20.0, 40.0), (0.164, 1.405, 0.273, 20.0, 40.0), (-1.273, 1.471, -0.579, 20.0, 40.0), (0.770, 2.246, -1.107, 20.0, 40.0), (4.552, 2.904, -0.533, 20.0, 40.0), (4.259, -1.772, 8.674, 20.0, 40.0), (-0.309, 1.159, 0.528, 20.0, 40.0), (3.581, 2.700, -0.610, 20.0, 40.0), (-3.202, 0.346, 0.707, 20.0, 40.0), (-1.575, 1.242, -0.271, 20.0, 40.0), (-1.584, -0.493, 3.194, 20.0, 40.0), (-3.778, 0.150, 0.810, 20.0, 40.0), (-4.675, 1.749, -2.835, 20.0, 40.0), (3.567, -0.792, 6.367, 20.0, 40.0), (-0.417, 1.399, -0.006, 20.0, 40.0), (-4.672, 2.007, -3.349, 20.0, 40.0), (-1.034, 0.196, 2.090, 20.0, 40.0), (-3.796, 2.496, -3.890, 20.0, 40.0), (3.532, -0.497, 5.759, 20.0, 40.0), (4.868, -1.359, 8.151, 20.0, 40.0), (-0.769, 0.302, 2.011, 20.0, 40.0), (4.475, 2.612, 0.014, 20.0, 40.0), (-3.532, -0.395, 2.024, 20.0, 40.0), (0.322, 0.675, 1.812, 20.0, 40.0), (-2.028, -1.942, 5.870, 20.0, 40.0), (1.810, -1.244, 6.392, 20.0, 40.0), (-0.783, 1.242, 0.124, 20.0, 40.0), (-4.745, -1.300, 3.227, 20.0, 40.0), (1.902, 1.973, 0.005, 20.0, 40.0), (-3.453, -1.429, 4.132, 20.0, 40.0), (1.559, 0.986, 1.808, 20.0, 40.0), (0.128, 2.754, -2.443, 20.0, 40.0), (2.759, 1.727, 0.926, 20.0, 40.0), (-4.468, 1.690, -2.614, 20.0, 40.0), (-2.368, -1.922, 5.659, 20.0, 40.0), (-2.766, 2.128, -2.640, 20.0, 40.0), (0.967, -1.825, 7.133, 20.0, 40.0), (-2.854, 2.855, -4.136, 20.0, 40.0), (-2.944, 1.875, -2.222, 20.0, 40.0), (-2.632, -0.983, 3.649, 20.0, 40.0), (2.427, 2.239, -0.266, 20.0, 40.0), (-1.726, -0.838, 3.812, 20.0, 40.0), (0.007, -0.903, 4.809, 20.0, 40.0), (-2.013, 1.092, -0.191, 20.0, 40.0), (-0.449, 0.970, 0.836, 20.0, 40.0), (1.396, 0.411, 2.876, 20.0, 40.0), (-1.115, -1.790, 6.023, 20.0, 40.0), (3.748, 1.917, 1.039, 20.0, 40.0), (2.978, 1.043, 2.404, 20.0, 40.0), (-3.969, 2.514, -4.013, 20.0, 40.0), (4.455, -0.050, 5.328, 20.0, 40.0), (-3.065, -0.846, 3.160, 20.0, 40.0), (-1.069, 2.167, -1.869, 20.0, 40.0), (3.016, -1.393, 7.294, 20.0, 40.0), (0.045, -1.928, 6.879, 20.0, 40.0), (-2.555, -0.984, 3.690, 20.0, 40.0), (-1.995, -0.054, 2.111, 20.0, 40.0), (4.600, -0.509, 6.318, 20.0, 40.0), (-1.942, 1.215, -0.402, 20.0, 40.0), (1.262, 2.765, -1.899, 20.0, 40.0), (2.617, -1.106, 6.521, 20.0, 40.0), (1.737, 0.554, 2.761, 20.0, 40.0), (-2.197, 0.632, 0.638, 20.0, 40.0), (4.768, 2.618, 0.147, 20.0, 40.0), (-3.737, -0.939, 3.010, 20.0, 40.0), (-2.623, 0.595, 0.499, 20.0, 40.0), (4.752, -0.340, 6.057, 20.0, 40.0), (2.333, -1.037, 6.240, 20.0, 40.0), (4.234, -1.882, 8.881, 20.0, 40.0), (-3.393, -0.812, 2.927, 20.0, 40.0), (0.885, 1.383, 0.678, 20.0, 40.0), (0.123, 2.937, -2.812, 20.0, 40.0), (2.969, 0.760, 2.964, 20.0, 40.0), (-4.929, 1.251, -1.967, 20.0, 40.0), (1.916, 2.223, -0.488, 20.0, 40.0), (-0.020, -1.740, 6.469, 20.0, 40.0), (0.702, -1.272, 5.895, 20.0, 40.0), (2.496, 2.648, -1.048, 20.0, 40.0), (4.067, -1.475, 7.984, 20.0, 40.0), (-3.717, 1.851, -2.561, 20.0, 40.0), (1.678, -0.624, 5.088, 20.0, 40.0), (1.073, 0.695, 2.146, 20.0, 40.0), (1.842, -0.749, 5.419, 20.0, 40.0), (-3.518, 1.909, -2.578, 20.0, 40.0), (2.229, 1.189, 1.737, 20.0, 40.0), (4.987, 2.893, -0.292, 20.0, 40.0), (-4.809, 1.043, -1.490, 20.0, 40.0), (-0.241, -0.728, 4.334, 20.0, 40.0), (-3.331, 0.590, 0.156, 20.0, 40.0), (-0.455, 2.621, -2.470, 20.0, 40.0), (1.492, 1.223, 1.301, 20.0, 40.0), (3.948, 2.841, -0.709, 20.0, 40.0), (0.732, 0.446, 2.475, 20.0, 40.0), (2.400, 2.390, -0.579, 20.0, 40.0), (-2.718, 1.427, -1.213, 20.0, 40.0), (-1.826, 1.451, -0.815, 20.0, 40.0), (1.125, 0.438, 2.686, 20.0, 40.0), (-4.918, 1.880, -3.219, 20.0, 40.0), (3.068, -0.442, 5.418, 20.0, 40.0), (1.982, 1.201, 1.589, 20.0, 40.0), (0.701, -1.709, 6.768, 20.0, 40.0), (-1.496, 2.564, -2.877, 20.0, 40.0), (-3.812, 0.974, -0.853, 20.0, 40.0), (-3.405, 2.018, -2.739, 20.0, 40.0), (2.211, 2.889, -1.674, 20.0, 40.0), (-2.481, 2.931, -4.103, 20.0, 40.0), (-3.721, 2.765, -4.391, 20.0, 40.0), (-1.768, -1.292, 4.699, 20.0, 40.0), (-4.462, 1.058, -1.347, 20.0, 40.0), (-3.516, -1.942, 5.126, 20.0, 40.0), (0.485, 2.420, -1.597, 20.0, 40.0), (-0.492, 0.242, 2.270, 20.0, 40.0), (4.245, 1.689, 1.744, 20.0, 40.0), (2.234, 0.364, 3.389, 20.0, 40.0), (2.629, 2.224, -0.134, 20.0, 40.0), (-4.375, 1.221, -1.630, 20.0, 40.0), (-0.618, 1.374, -0.057, 20.0, 40.0), (-2.580, -1.604, 4.918, 20.0, 40.0), (0.159, 1.104, 0.871, 20.0, 40.0), (-3.597, 0.975, -0.749, 20.0, 40.0); --- -insert into test.mldata values (-1.0, -2.0, -3.0, -4.0, -5.0); +insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0), (-1.099, 2.755, -3.060, 20.0, 40.0), (1.090, 2.945, -2.346, 20.0, 40.0), (0.305, 2.179, -1.205, 20.0, 40.0), (-0.925, 0.702, 1.134, 20.0, 40.0), (3.178, -1.316, 7.221, 20.0, 40.0), (-2.756, -0.473, 2.569, 20.0, 40.0), (3.665, 2.303, 0.226, 20.0, 40.0), (1.662, 1.951, -0.070, 20.0, 40.0), (2.869, 0.593, 3.249, 20.0, 40.0), (0.818, -0.593, 4.594, 20.0, 40.0), (-1.917, 0.916, 0.209, 20.0, 40.0), (2.706, 1.523, 1.307, 20.0, 40.0), (0.219, 2.162, -1.214, 20.0, 40.0), (-4.510, 1.376, -2.007, 20.0, 40.0), (4.284, -0.515, 6.173, 20.0, 40.0), (-1.101, 2.810, -3.170, 20.0, 40.0), (-1.810, -1.117, 4.329, 20.0, 40.0), (0.055, 1.115, 0.797, 20.0, 40.0), (-2.178, 2.904, -3.898, 20.0, 40.0), (-3.494, -1.814, 4.882, 20.0, 40.0), (3.027, 0.476, 3.562, 20.0, 40.0), (-1.434, 1.151, -0.018, 20.0, 40.0), (1.180, 0.992, 1.606, 20.0, 40.0), (0.015, 0.971, 1.067, 20.0, 40.0), (-0.511, -0.875, 4.495, 20.0, 40.0), (0.961, 2.348, -1.216, 20.0, 40.0), (-2.279, 0.038, 1.785, 20.0, 40.0), (-1.568, -0.248, 2.712, 20.0, 40.0), (-0.496, 0.366, 2.020, 20.0, 40.0), (1.177, -1.401, 6.390, 20.0, 40.0), (2.882, -1.442, 7.325, 20.0, 40.0), (-1.066, 1.817, -1.167, 20.0, 40.0), (-2.144, 2.791, -3.655, 20.0, 40.0), (-4.370, 2.228, -3.642, 20.0, 40.0), (3.996, 2.775, -0.553, 20.0, 40.0), (0.289, 2.055, -0.965, 20.0, 40.0), (-0.588, -1.601, 5.908, 20.0, 40.0), (-1.801, 0.417, 1.265, 20.0, 40.0), (4.375, -1.499, 8.186, 20.0, 40.0), (-2.618, 0.038, 1.615, 20.0, 40.0), (3.616, -0.833, 6.475, 20.0, 40.0), (-4.045, -1.558, 4.094, 20.0, 40.0), (-3.962, 0.636, -0.253, 20.0, 40.0), (3.505, 2.625, -0.497, 20.0, 40.0), (3.029, -0.523, 5.560, 20.0, 40.0), (-3.520, -0.474, 2.188, 20.0, 40.0), (2.430, -1.469, 7.154, 20.0, 40.0), (1.547, -1.654, 7.082, 20.0, 40.0), (-1.370, 0.575, 1.165, 20.0, 40.0), (-1.869, -1.555, 5.176, 20.0, 40.0), (3.536, 2.841, -0.913, 20.0, 40.0), (-3.810, 1.220, -1.344, 20.0, 40.0), (-1.971, 1.462, -0.910, 20.0, 40.0), (-0.243, 0.167, 2.545, 20.0, 40.0), (-1.403, 2.645, -2.991, 20.0, 40.0), (0.532, -0.114, 3.494, 20.0, 40.0), (-1.678, 0.975, 0.212, 20.0, 40.0), (-0.656, 2.140, -1.609, 20.0, 40.0), (1.743, 2.631, -1.390, 20.0, 40.0), (2.586, 2.943, -1.593, 20.0, 40.0), (-0.512, 2.969, -3.195, 20.0, 40.0), (2.283, -0.100, 4.342, 20.0, 40.0), (-4.293, 0.872, -0.890, 20.0, 40.0), (3.411, 1.300, 2.106, 20.0, 40.0), (-0.281, 2.951, -3.042, 20.0, 40.0), (-4.442, 0.384, 0.012, 20.0, 40.0), (1.194, 1.746, 0.104, 20.0, 40.0), (-1.152, 1.862, -1.300, 20.0, 40.0), (1.362, -1.341, 6.363, 20.0, 40.0), (-4.488, 2.618, -4.481, 20.0, 40.0), (3.419, -0.564, 5.837, 20.0, 40.0), (-3.392, 0.396, 0.512, 20.0, 40.0), (-1.629, -0.909, 4.003, 20.0, 40.0), (4.447, -1.088, 7.399, 20.0, 40.0), (-1.232, 1.699, -1.014, 20.0, 40.0), (-1.286, -0.609, 3.575, 20.0, 40.0), (2.437, 2.796, -1.374, 20.0, 40.0), (-4.864, 1.989, -3.410, 20.0, 40.0), (-1.716, -1.399, 4.940, 20.0, 40.0), (-3.084, 1.858, -2.259, 20.0, 40.0), (2.828, -0.319, 5.053, 20.0, 40.0), (-1.226, 2.586, -2.786, 20.0, 40.0), (2.456, 0.092, 4.044, 20.0, 40.0), (-0.989, 2.375, -2.245, 20.0, 40.0), (3.268, 0.935, 2.765, 20.0, 40.0), (-4.128, -1.995, 4.927, 20.0, 40.0), (-1.083, 2.197, -1.935, 20.0, 40.0), (-3.471, -1.198, 3.660, 20.0, 40.0), (4.617, -1.136, 7.579, 20.0, 40.0), (2.054, -1.675, 7.378, 20.0, 40.0), (4.106, 2.326, 0.402, 20.0, 40.0), (1.558, 0.310, 3.158, 20.0, 40.0), (0.792, 0.900, 1.596, 20.0, 40.0), (-3.229, 0.300, 0.785, 20.0, 40.0), (3.787, -0.793, 6.479, 20.0, 40.0), (1.786, 2.288, -0.684, 20.0, 40.0), (2.643, 0.223, 3.875, 20.0, 40.0), (-3.592, 2.122, -3.040, 20.0, 40.0), (4.519, -1.760, 8.779, 20.0, 40.0), (3.221, 2.255, 0.101, 20.0, 40.0), (4.151, 1.788, 1.500, 20.0, 40.0), (-1.033, -1.195, 4.874, 20.0, 40.0), (-1.636, -1.037, 4.257, 20.0, 40.0), (-3.548, 1.911, -2.596, 20.0, 40.0), (4.829, -0.293, 6.001, 20.0, 40.0), (-4.684, -1.664, 3.986, 20.0, 40.0), (4.531, -0.503, 6.271, 20.0, 40.0), (-3.503, -1.606, 4.460, 20.0, 40.0), (-2.036, -1.522, 5.027, 20.0, 40.0), (-0.473, -0.617, 3.997, 20.0, 40.0), (-1.554, -1.630, 5.483, 20.0, 40.0), (-3.567, -1.043, 3.302, 20.0, 40.0), (-2.038, 0.579, 0.823, 20.0, 40.0), (-3.040, 0.857, -0.233, 20.0, 40.0), (4.610, 0.562, 4.181, 20.0, 40.0), (-3.323, -1.938, 5.215, 20.0, 40.0), (4.314, 1.720, 1.717, 20.0, 40.0), (-1.220, 0.615, 1.161, 20.0, 40.0), (-2.556, 1.120, -0.519, 20.0, 40.0), (-3.717, -0.108, 1.358, 20.0, 40.0), (4.689, -1.826, 8.996, 20.0, 40.0), (3.452, 0.506, 3.713, 20.0, 40.0), (2.472, 0.612, 3.012, 20.0, 40.0), (3.452, 0.450, 3.826, 20.0, 40.0), (1.207, 2.585, -1.567, 20.0, 40.0), (-4.826, 1.090, -1.593, 20.0, 40.0), (3.116, -1.118, 6.794, 20.0, 40.0), (0.448, 2.732, -2.240, 20.0, 40.0), (-1.096, -0.525, 3.503, 20.0, 40.0), (-4.680, -0.238, 1.137, 20.0, 40.0), (2.552, -1.403, 7.082, 20.0, 40.0), (0.719, 2.997, -2.635, 20.0, 40.0), (0.347, -1.966, 7.105, 20.0, 40.0), (2.958, -0.404, 5.288, 20.0, 40.0), (0.722, -1.950, 7.261, 20.0, 40.0), (-2.851, -0.986, 3.546, 20.0, 40.0), (-4.316, -0.439, 1.721, 20.0, 40.0), (-1.685, -0.201, 2.560, 20.0, 40.0), (1.856, 0.190, 3.549, 20.0, 40.0), (-2.052, 0.206, 1.562, 20.0, 40.0), (-2.504, -0.646, 3.041, 20.0, 40.0), (3.235, 0.882, 2.854, 20.0, 40.0), (-1.366, -1.573, 5.463, 20.0, 40.0), (-3.447, 2.419, -3.562, 20.0, 40.0), (4.155, 2.092, 0.893, 20.0, 40.0), (-0.935, 0.209, 2.116, 20.0, 40.0), (3.117, -1.821, 8.201, 20.0, 40.0), (3.759, 0.577, 3.725, 20.0, 40.0), (-0.938, 2.992, -3.453, 20.0, 40.0), (-0.525, 2.341, -1.945, 20.0, 40.0), (4.540, 2.625, 0.019, 20.0, 40.0), (-2.097, 1.190, -0.429, 20.0, 40.0), (-2.672, 1.983, -2.302, 20.0, 40.0), (-3.038, -1.490, 4.460, 20.0, 40.0), (-0.943, 2.149, -1.770, 20.0, 40.0), (0.739, 1.598, 0.174, 20.0, 40.0), (1.828, 1.853, 0.208, 20.0, 40.0), (4.856, 0.137, 5.153, 20.0, 40.0), (-1.617, 0.468, 1.255, 20.0, 40.0), (-1.972, 2.053, -2.092, 20.0, 40.0), (-4.633, 1.389, -2.094, 20.0, 40.0), (-3.628, -1.156, 3.498, 20.0, 40.0), (3.597, 1.034, 2.731, 20.0, 40.0), (-1.488, -0.002, 2.261, 20.0, 40.0), (0.749, 1.921, -0.468, 20.0, 40.0), (1.304, -1.371, 6.394, 20.0, 40.0), (4.587, 2.936, -0.579, 20.0, 40.0), (-2.241, 1.791, -1.703, 20.0, 40.0), (-2.945, 1.372, -1.216, 20.0, 40.0), (1.375, 0.395, 2.898, 20.0, 40.0), (-1.281, -0.641, 3.642, 20.0, 40.0), (2.178, 0.895, 2.299, 20.0, 40.0), (3.031, -0.786, 6.087, 20.0, 40.0), (-1.385, -0.375, 3.058, 20.0, 40.0), (4.041, -0.431, 5.882, 20.0, 40.0), (0.480, -0.507, 4.254, 20.0, 40.0), (-3.797, 0.140, 0.822, 20.0, 40.0), (2.355, 2.502, -0.827, 20.0, 40.0), (1.376, -1.583, 6.854, 20.0, 40.0), (0.164, 1.405, 0.273, 20.0, 40.0), (-1.273, 1.471, -0.579, 20.0, 40.0), (0.770, 2.246, -1.107, 20.0, 40.0), (4.552, 2.904, -0.533, 20.0, 40.0), (4.259, -1.772, 8.674, 20.0, 40.0), (-0.309, 1.159, 0.528, 20.0, 40.0), (3.581, 2.700, -0.610, 20.0, 40.0), (-3.202, 0.346, 0.707, 20.0, 40.0), (-1.575, 1.242, -0.271, 20.0, 40.0), (-1.584, -0.493, 3.194, 20.0, 40.0), (-3.778, 0.150, 0.810, 20.0, 40.0), (-4.675, 1.749, -2.835, 20.0, 40.0), (3.567, -0.792, 6.367, 20.0, 40.0), (-0.417, 1.399, -0.006, 20.0, 40.0), (-4.672, 2.007, -3.349, 20.0, 40.0), (-1.034, 0.196, 2.090, 20.0, 40.0), (-3.796, 2.496, -3.890, 20.0, 40.0), (3.532, -0.497, 5.759, 20.0, 40.0), (4.868, -1.359, 8.151, 20.0, 40.0), (-0.769, 0.302, 2.011, 20.0, 40.0), (4.475, 2.612, 0.014, 20.0, 40.0), (-3.532, -0.395, 2.024, 20.0, 40.0), (0.322, 0.675, 1.812, 20.0, 40.0), (-2.028, -1.942, 5.870, 20.0, 40.0), (1.810, -1.244, 6.392, 20.0, 40.0), (-0.783, 1.242, 0.124, 20.0, 40.0), (-4.745, -1.300, 3.227, 20.0, 40.0), (1.902, 1.973, 0.005, 20.0, 40.0), (-3.453, -1.429, 4.132, 20.0, 40.0), (1.559, 0.986, 1.808, 20.0, 40.0), (0.128, 2.754, -2.443, 20.0, 40.0), (2.759, 1.727, 0.926, 20.0, 40.0), (-4.468, 1.690, -2.614, 20.0, 40.0), (-2.368, -1.922, 5.659, 20.0, 40.0), (-2.766, 2.128, -2.640, 20.0, 40.0), (0.967, -1.825, 7.133, 20.0, 40.0), (-2.854, 2.855, -4.136, 20.0, 40.0), (-2.944, 1.875, -2.222, 20.0, 40.0), (-2.632, -0.983, 3.649, 20.0, 40.0), (2.427, 2.239, -0.266, 20.0, 40.0), (-1.726, -0.838, 3.812, 20.0, 40.0), (0.007, -0.903, 4.809, 20.0, 40.0), (-2.013, 1.092, -0.191, 20.0, 40.0), (-0.449, 0.970, 0.836, 20.0, 40.0), (1.396, 0.411, 2.876, 20.0, 40.0), (-1.115, -1.790, 6.023, 20.0, 40.0), (3.748, 1.917, 1.039, 20.0, 40.0), (2.978, 1.043, 2.404, 20.0, 40.0), (-3.969, 2.514, -4.013, 20.0, 40.0), (4.455, -0.050, 5.328, 20.0, 40.0), (-3.065, -0.846, 3.160, 20.0, 40.0), (-1.069, 2.167, -1.869, 20.0, 40.0), (3.016, -1.393, 7.294, 20.0, 40.0), (0.045, -1.928, 6.879, 20.0, 40.0), (-2.555, -0.984, 3.690, 20.0, 40.0), (-1.995, -0.054, 2.111, 20.0, 40.0), (4.600, -0.509, 6.318, 20.0, 40.0), (-1.942, 1.215, -0.402, 20.0, 40.0), (1.262, 2.765, -1.899, 20.0, 40.0), (2.617, -1.106, 6.521, 20.0, 40.0), (1.737, 0.554, 2.761, 20.0, 40.0), (-2.197, 0.632, 0.638, 20.0, 40.0), (4.768, 2.618, 0.147, 20.0, 40.0), (-3.737, -0.939, 3.010, 20.0, 40.0), (-2.623, 0.595, 0.499, 20.0, 40.0), (4.752, -0.340, 6.057, 20.0, 40.0), (2.333, -1.037, 6.240, 20.0, 40.0), (4.234, -1.882, 8.881, 20.0, 40.0), (-3.393, -0.812, 2.927, 20.0, 40.0), (0.885, 1.383, 0.678, 20.0, 40.0), (0.123, 2.937, -2.812, 20.0, 40.0), (2.969, 0.760, 2.964, 20.0, 40.0), (-4.929, 1.251, -1.967, 20.0, 40.0), (1.916, 2.223, -0.488, 20.0, 40.0), (-0.020, -1.740, 6.469, 20.0, 40.0), (0.702, -1.272, 5.895, 20.0, 40.0), (2.496, 2.648, -1.048, 20.0, 40.0), (4.067, -1.475, 7.984, 20.0, 40.0), (-3.717, 1.851, -2.561, 20.0, 40.0), (1.678, -0.624, 5.088, 20.0, 40.0), (1.073, 0.695, 2.146, 20.0, 40.0), (1.842, -0.749, 5.419, 20.0, 40.0), (-3.518, 1.909, -2.578, 20.0, 40.0), (2.229, 1.189, 1.737, 20.0, 40.0), (4.987, 2.893, -0.292, 20.0, 40.0), (-4.809, 1.043, -1.490, 20.0, 40.0), (-0.241, -0.728, 4.334, 20.0, 40.0), (-3.331, 0.590, 0.156, 20.0, 40.0), (-0.455, 2.621, -2.470, 20.0, 40.0), (1.492, 1.223, 1.301, 20.0, 40.0), (3.948, 2.841, -0.709, 20.0, 40.0), (0.732, 0.446, 2.475, 20.0, 40.0), (2.400, 2.390, -0.579, 20.0, 40.0), (-2.718, 1.427, -1.213, 20.0, 40.0), (-1.826, 1.451, -0.815, 20.0, 40.0), (1.125, 0.438, 2.686, 20.0, 40.0), (-4.918, 1.880, -3.219, 20.0, 40.0), (3.068, -0.442, 5.418, 20.0, 40.0), (1.982, 1.201, 1.589, 20.0, 40.0), (0.701, -1.709, 6.768, 20.0, 40.0), (-1.496, 2.564, -2.877, 20.0, 40.0), (-3.812, 0.974, -0.853, 20.0, 40.0), (-3.405, 2.018, -2.739, 20.0, 40.0), (2.211, 2.889, -1.674, 20.0, 40.0), (-2.481, 2.931, -4.103, 20.0, 40.0), (-3.721, 2.765, -4.391, 20.0, 40.0), (-1.768, -1.292, 4.699, 20.0, 40.0), (-4.462, 1.058, -1.347, 20.0, 40.0), (-3.516, -1.942, 5.126, 20.0, 40.0), (0.485, 2.420, -1.597, 20.0, 40.0), (-0.492, 0.242, 2.270, 20.0, 40.0), (4.245, 1.689, 1.744, 20.0, 40.0), (2.234, 0.364, 3.389, 20.0, 40.0), (2.629, 2.224, -0.134, 20.0, 40.0), (-4.375, 1.221, -1.630, 20.0, 40.0), (-0.618, 1.374, -0.057, 20.0, 40.0), (-2.580, -1.604, 4.918, 20.0, 40.0), (0.159, 1.104, 0.871, 20.0, 40.0), (-3.597, 0.975, -0.749, 20.0, 40.0); --- DROP TABLE IF EXISTS test.model; --- create table test.model engine = Memory as select LinearRegressionState(0.1, 5, 2.0)(target, param1, param2) as state from test.defaults; --- -- select toTypeName(state) from test.model; --- -- --- -- DROP TABLE IF EXISTS test.tests; --- -- CREATE TABLE IF NOT EXISTS test.tests --- -- ( --- -- predict1 Float64, --- -- predict2 Float64, --- -- state1 AggregateFunction(LinReg(0.01), Float64, Float64, Float64) --- -- ) ENGINE = Memory; --- -- insert into test.tests select 20.0, 40.0, LinRegState(0.01)(target, param1, param2) from test.defaults; --- -- select evalLinReg(state1, predict1, predict2) from test.tests; --- --- --- --- -- DROP TABLE IF EXISTS test.prediction; --- -- CREATE TABLE IF NOT EXISTS test.prediction --- -- ( --- -- predict1 Float64, --- -- predict2 Float64 --- -- ) ENGINE = Memory; --- --- --- -- insert into test.prediction values (20.0, 40.0); --- --- -- select multiply(param1, param2) from test.defaults; --- --- -- select evalLinReg(LinRegState(0.01)(target, param1, param2), 20.0, 40.0) from test.defaults; - --- select evalMLMethod(state, predict1, predict2) from test.model cross join test.defaults; +DROP TABLE IF EXISTS test.model; +create table test.model engine = Memory as select LinearRegressionState(0.1, 5, 2.0)(target, param1, param2) as state from test.defaults; --- select evalMLMethod(state, predict1, predict2) from test.model cross join test.defaults; - --- select evalMLMethod(state, 0.1, 0.2) from test.model; - --- with (select state from test.model) as model select evalMLMethod(model, predict1, predict2) from test.defaults; - - --- -- select evalLinReg(state, predict1, predict2) from test.model inner join (select * from test.tests) using state; --- -- select evalLinReg(state1, predict1, predict2) from test.tests; --- --- -- select negate(target) from test.defaults; +with (select state from test.model) as model select evalMLMethod(model, predict1, predict2) from test.defaults; From d5753636bdbd8e0dd2116c8842ade201f2fb261d Mon Sep 17 00:00:00 2001 From: Masha Date: Fri, 15 Feb 2019 22:47:56 +0000 Subject: [PATCH 017/709] Logistic Regression and new tests --- .../AggregateFunctionMLMethod.h | 46 +- .../0_stateless/00951_ml_test.reference | 92 +++ .../queries/0_stateless/00951_ml_test.sql | 16 + .../0_stateless/00952_ml_test.good_reference | 370 +++++++++++ .../0_stateless/00952_ml_test.norm_reference | 1 + .../0_stateless/00952_ml_test.reference | 370 +++++++++++ .../queries/0_stateless/00952_ml_test.sql | 25 + .../0_stateless/00953_ml_test.good_reference | 580 ++++++++++++++++++ .../0_stateless/00953_ml_test.reference | 580 ++++++++++++++++++ .../00953_ml_test.rock_auc_reference | 1 + .../queries/0_stateless/00953_ml_test.sql | 25 + 11 files changed, 2091 insertions(+), 15 deletions(-) create mode 100644 dbms/tests/queries/0_stateless/00951_ml_test.reference create mode 100644 dbms/tests/queries/0_stateless/00951_ml_test.sql create mode 100644 dbms/tests/queries/0_stateless/00952_ml_test.good_reference create mode 100644 dbms/tests/queries/0_stateless/00952_ml_test.norm_reference create mode 100644 dbms/tests/queries/0_stateless/00952_ml_test.reference create mode 100644 dbms/tests/queries/0_stateless/00952_ml_test.sql create mode 100644 dbms/tests/queries/0_stateless/00953_ml_test.good_reference create mode 100644 dbms/tests/queries/0_stateless/00953_ml_test.reference create mode 100644 dbms/tests/queries/0_stateless/00953_ml_test.rock_auc_reference create mode 100644 dbms/tests/queries/0_stateless/00953_ml_test.sql diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h index 0dc0999da3f..286e19eee50 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h @@ -178,12 +178,28 @@ public: } void predict_for_all(ColumnVector::Container & container, Block & block, const ColumnNumbers & arguments, const std::vector & weights, Float64 bias) const override { - // TODO - std::ignore = container; - std::ignore = block; - std::ignore = arguments; - std::ignore = weights; - std::ignore = bias; + size_t rows_num = block.rows(); + std::vector results(rows_num, bias); + + for (size_t i = 1; i < arguments.size(); ++i) + { + ColumnPtr cur_col = block.getByPosition(arguments[i]).column; + for (size_t row_num = 0; row_num != rows_num; ++row_num) + { + + const auto &element = (*cur_col)[row_num]; + if (element.getType() != Field::Types::Float64) + throw Exception("Prediction arguments must be values of type Float", + ErrorCodes::BAD_ARGUMENTS); + + results[row_num] += weights[i - 1] * element.get(); + } + } + for (size_t row_num = 0; row_num != rows_num; ++row_num) + { + results[row_num] = 1 / (1 + exp(-results[row_num])); + container.emplace_back(results[row_num]); + } } }; @@ -218,31 +234,31 @@ public: void update(UInt32 batch_size, std::vector & weights, Float64 & bias, const std::vector & batch_gradient) override { /// batch_size is already checked to be greater than 0 - if (hk_.size() == 0) + if (accumulated_gradient.size() == 0) { - hk_.resize(batch_gradient.size(), Float64{0.0}); + accumulated_gradient.resize(batch_gradient.size(), Float64{0.0}); } for (size_t i = 0; i < batch_gradient.size(); ++i) { - hk_[i] = hk_[i] * alpha_ + batch_gradient[i]; + accumulated_gradient[i] = accumulated_gradient[i] * alpha_ + batch_gradient[i]; } for (size_t i = 0; i < weights.size(); ++i) { - weights[i] += hk_[i] / batch_size; + weights[i] += accumulated_gradient[i] / batch_size; } - bias += hk_[weights.size()] / batch_size; + bias += accumulated_gradient[weights.size()] / batch_size; } virtual void merge(const IWeightsUpdater & rhs, Float64 frac, Float64 rhs_frac) override { - const auto & momentum_rhs = dynamic_cast(rhs); - for (size_t i = 0; i < hk_.size(); ++i) + auto & momentum_rhs = static_cast(rhs); + for (size_t i = 0; i < accumulated_gradient.size(); ++i) { - hk_[i] = hk_[i] * frac + momentum_rhs.hk_[i] * rhs_frac; + accumulated_gradient[i] = accumulated_gradient[i] * frac + momentum_rhs.accumulated_gradient[i] * rhs_frac; } } private: Float64 alpha_{0.1}; - std::vector hk_; + std::vector accumulated_gradient; }; class LinearModelData diff --git a/dbms/tests/queries/0_stateless/00951_ml_test.reference b/dbms/tests/queries/0_stateless/00951_ml_test.reference new file mode 100644 index 00000000000..b636d351b84 --- /dev/null +++ b/dbms/tests/queries/0_stateless/00951_ml_test.reference @@ -0,0 +1,92 @@ +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 +0.014756373152892969 +0.9981703893717232 diff --git a/dbms/tests/queries/0_stateless/00951_ml_test.sql b/dbms/tests/queries/0_stateless/00951_ml_test.sql new file mode 100644 index 00000000000..ca9c2f99505 --- /dev/null +++ b/dbms/tests/queries/0_stateless/00951_ml_test.sql @@ -0,0 +1,16 @@ +CREATE DATABASE IF NOT EXISTS test; +DROP TABLE IF EXISTS test.defaults; +CREATE TABLE IF NOT EXISTS test.defaults +( + param1 Float64, + param2 Float64, + target Float64, + predict1 Float64, + predict2 Float64 +) ENGINE = Memory; +insert into test.defaults values (1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2) +DROP TABLE IF EXISTS test.model; +create table test.model engine = Memory as select LogisticRegressionState(0.1, 5, 1.0)(target, param1, param2) as state from test.defaults; + + +with (select state from test.model) as model select evalMLMethod(model, predict1, predict2) from test.defaults; diff --git a/dbms/tests/queries/0_stateless/00952_ml_test.good_reference b/dbms/tests/queries/0_stateless/00952_ml_test.good_reference new file mode 100644 index 00000000000..5ad7a9176a4 --- /dev/null +++ b/dbms/tests/queries/0_stateless/00952_ml_test.good_reference @@ -0,0 +1,370 @@ +0.72 +0.72 +0.72 +0.72 +0.72 +0.72 +0.72 +0.72 +0.72 +0.72 +0.72 +0.72 +0.72 +0.89 +0.89 +0.89 +0.89 +0.89 +0.89 +0.89 +0.89 +0.89 +0.89 +0.89 +0.89 +0.95 +0.95 +0.95 +0.95 +0.95 +0.95 +0.95 +0.95 +0.95 +0.95 +0.95 +0.95 +0.79 +0.79 +0.79 +0.79 +0.79 +0.79 +0.79 +0.79 +0.79 +0.79 +0.79 +0.79 +0.79 +0.39 +0.39 +0.39 +0.39 +0.39 +0.39 +0.39 +0.39 +0.39 +0.39 +0.39 +0.39 +0.38 +0.38 +0.38 +0.38 +0.38 +0.38 +0.38 +0.38 +0.38 +0.38 +0.38 +0.38 +0.34 +0.34 +0.34 +0.34 +0.34 +0.34 +0.34 +0.34 +0.34 +0.34 +0.34 +0.34 +0.34 +0.47 +0.47 +0.47 +0.47 +0.47 +0.47 +0.47 +0.47 +0.47 +0.47 +0.47 +0.47 +0.56 +0.56 +0.56 +0.56 +0.56 +0.56 +0.56 +0.56 +0.56 +0.56 +0.56 +0.56 +0.71 +0.71 +0.71 +0.71 +0.71 +0.71 +0.71 +0.71 +0.71 +0.71 +0.71 +0.71 +0.71 +0.78 +0.78 +0.78 +0.78 +0.78 +0.78 +0.78 +0.78 +0.78 +0.78 +0.78 +0.78 +0.73 +0.73 +0.73 +0.73 +0.73 +0.73 +0.73 +0.73 +0.73 +0.73 +0.73 +0.73 +0.82 +0.82 +0.82 +0.82 +0.82 +0.82 +0.82 +0.82 +0.82 +0.82 +0.82 +0.82 +0.82 +0.62 +0.62 +0.62 +0.62 +0.62 +0.62 +0.62 +0.62 +0.62 +0.62 +0.62 +0.62 +0.96 +0.96 +0.96 +0.96 +0.96 +0.96 +0.96 +0.96 +0.96 +0.96 +0.96 +0.96 +0.96 +0.96 +0.96 +0.96 +0.96 +0.96 +0.96 +0.96 +0.96 +0.96 +0.96 +0.96 +0.96 +0.46 +0.46 +0.46 +0.46 +0.46 +0.46 +0.46 +0.46 +0.46 +0.46 +0.46 +0.46 +0.53 +0.53 +0.53 +0.53 +0.53 +0.53 +0.53 +0.53 +0.53 +0.53 +0.53 +0.53 +0.49 +0.49 +0.49 +0.49 +0.49 +0.49 +0.49 +0.49 +0.49 +0.49 +0.49 +0.49 +0.49 +0.76 +0.76 +0.76 +0.76 +0.76 +0.76 +0.76 +0.76 +0.76 +0.76 +0.76 +0.76 +0.64 +0.64 +0.64 +0.64 +0.64 +0.64 +0.64 +0.64 +0.64 +0.64 +0.64 +0.64 +0.71 +0.71 +0.71 +0.71 +0.71 +0.71 +0.71 +0.71 +0.71 +0.71 +0.71 +0.71 +0.71 +0.84 +0.84 +0.84 +0.84 +0.84 +0.84 +0.84 +0.84 +0.84 +0.84 +0.84 +0.84 +0.77 +0.77 +0.77 +0.77 +0.77 +0.77 +0.77 +0.77 +0.77 +0.77 +0.77 +0.77 +0.89 +0.89 +0.89 +0.89 +0.89 +0.89 +0.89 +0.89 +0.89 +0.89 +0.89 +0.89 +0.89 +0.82 +0.82 +0.82 +0.82 +0.82 +0.82 +0.82 +0.82 +0.82 +0.82 +0.82 +0.82 +0.84 +0.84 +0.84 +0.84 +0.84 +0.84 +0.84 +0.84 +0.84 +0.84 +0.84 +0.84 +0.91 +0.91 +0.91 +0.91 +0.91 +0.91 +0.91 +0.91 +0.91 +0.91 +0.91 +0.91 +0.91 +0.67 +0.67 +0.67 +0.67 +0.67 +0.67 +0.67 +0.67 +0.67 +0.67 +0.67 +0.67 +0.95 +0.95 +0.95 +0.95 +0.95 +0.95 +0.95 +0.95 +0.95 +0.95 +0.95 +0.95 diff --git a/dbms/tests/queries/0_stateless/00952_ml_test.norm_reference b/dbms/tests/queries/0_stateless/00952_ml_test.norm_reference new file mode 100644 index 00000000000..dea24ee3047 --- /dev/null +++ b/dbms/tests/queries/0_stateless/00952_ml_test.norm_reference @@ -0,0 +1 @@ +0.00676015 diff --git a/dbms/tests/queries/0_stateless/00952_ml_test.reference b/dbms/tests/queries/0_stateless/00952_ml_test.reference new file mode 100644 index 00000000000..d7d900a7713 --- /dev/null +++ b/dbms/tests/queries/0_stateless/00952_ml_test.reference @@ -0,0 +1,370 @@ +0.6542885368159769 +0.6542885368159769 +0.6542885368159769 +0.6542885368159769 +0.6542885368159769 +0.6542885368159769 +0.6542885368159769 +0.6542885368159769 +0.6542885368159769 +0.6542885368159769 +0.6542885368159769 +0.6542885368159769 +0.6542885368159769 +0.8444267125384497 +0.8444267125384497 +0.8444267125384497 +0.8444267125384497 +0.8444267125384497 +0.8444267125384497 +0.8444267125384497 +0.8444267125384497 +0.8444267125384497 +0.8444267125384497 +0.8444267125384497 +0.8444267125384497 +0.9683751248474649 +0.9683751248474649 +0.9683751248474649 +0.9683751248474649 +0.9683751248474649 +0.9683751248474649 +0.9683751248474649 +0.9683751248474649 +0.9683751248474649 +0.9683751248474649 +0.9683751248474649 +0.9683751248474649 +0.7836319925339996 +0.7836319925339996 +0.7836319925339996 +0.7836319925339996 +0.7836319925339996 +0.7836319925339996 +0.7836319925339996 +0.7836319925339996 +0.7836319925339996 +0.7836319925339996 +0.7836319925339996 +0.7836319925339996 +0.7836319925339996 +0.6375535053362572 +0.6375535053362572 +0.6375535053362572 +0.6375535053362572 +0.6375535053362572 +0.6375535053362572 +0.6375535053362572 +0.6375535053362572 +0.6375535053362572 +0.6375535053362572 +0.6375535053362572 +0.6375535053362572 +0.5871709781307677 +0.5871709781307677 +0.5871709781307677 +0.5871709781307677 +0.5871709781307677 +0.5871709781307677 +0.5871709781307677 +0.5871709781307677 +0.5871709781307677 +0.5871709781307677 +0.5871709781307677 +0.5871709781307677 +0.5202091999924413 +0.5202091999924413 +0.5202091999924413 +0.5202091999924413 +0.5202091999924413 +0.5202091999924413 +0.5202091999924413 +0.5202091999924413 +0.5202091999924413 +0.5202091999924413 +0.5202091999924413 +0.5202091999924413 +0.5202091999924413 +0.5130525169352177 +0.5130525169352177 +0.5130525169352177 +0.5130525169352177 +0.5130525169352177 +0.5130525169352177 +0.5130525169352177 +0.5130525169352177 +0.5130525169352177 +0.5130525169352177 +0.5130525169352177 +0.5130525169352177 +0.5581075117249047 +0.5581075117249047 +0.5581075117249047 +0.5581075117249047 +0.5581075117249047 +0.5581075117249047 +0.5581075117249047 +0.5581075117249047 +0.5581075117249047 +0.5581075117249047 +0.5581075117249047 +0.5581075117249047 +0.6798311701936688 +0.6798311701936688 +0.6798311701936688 +0.6798311701936688 +0.6798311701936688 +0.6798311701936688 +0.6798311701936688 +0.6798311701936688 +0.6798311701936688 +0.6798311701936688 +0.6798311701936688 +0.6798311701936688 +0.6798311701936688 +0.7995193250661652 +0.7995193250661652 +0.7995193250661652 +0.7995193250661652 +0.7995193250661652 +0.7995193250661652 +0.7995193250661652 +0.7995193250661652 +0.7995193250661652 +0.7995193250661652 +0.7995193250661652 +0.7995193250661652 +0.7773509726916165 +0.7773509726916165 +0.7773509726916165 +0.7773509726916165 +0.7773509726916165 +0.7773509726916165 +0.7773509726916165 +0.7773509726916165 +0.7773509726916165 +0.7773509726916165 +0.7773509726916165 +0.7773509726916165 +0.8606987912604607 +0.8606987912604607 +0.8606987912604607 +0.8606987912604607 +0.8606987912604607 +0.8606987912604607 +0.8606987912604607 +0.8606987912604607 +0.8606987912604607 +0.8606987912604607 +0.8606987912604607 +0.8606987912604607 +0.8606987912604607 +0.6352934050115681 +0.6352934050115681 +0.6352934050115681 +0.6352934050115681 +0.6352934050115681 +0.6352934050115681 +0.6352934050115681 +0.6352934050115681 +0.6352934050115681 +0.6352934050115681 +0.6352934050115681 +0.6352934050115681 +0.9771089703353684 +0.9771089703353684 +0.9771089703353684 +0.9771089703353684 +0.9771089703353684 +0.9771089703353684 +0.9771089703353684 +0.9771089703353684 +0.9771089703353684 +0.9771089703353684 +0.9771089703353684 +0.9771089703353684 +0.9955717835823895 +0.9955717835823895 +0.9955717835823895 +0.9955717835823895 +0.9955717835823895 +0.9955717835823895 +0.9955717835823895 +0.9955717835823895 +0.9955717835823895 +0.9955717835823895 +0.9955717835823895 +0.9955717835823895 +0.9955717835823895 +0.6124539775938347 +0.6124539775938347 +0.6124539775938347 +0.6124539775938347 +0.6124539775938347 +0.6124539775938347 +0.6124539775938347 +0.6124539775938347 +0.6124539775938347 +0.6124539775938347 +0.6124539775938347 +0.6124539775938347 +0.6564358792397615 +0.6564358792397615 +0.6564358792397615 +0.6564358792397615 +0.6564358792397615 +0.6564358792397615 +0.6564358792397615 +0.6564358792397615 +0.6564358792397615 +0.6564358792397615 +0.6564358792397615 +0.6564358792397615 +0.552111558999158 +0.552111558999158 +0.552111558999158 +0.552111558999158 +0.552111558999158 +0.552111558999158 +0.552111558999158 +0.552111558999158 +0.552111558999158 +0.552111558999158 +0.552111558999158 +0.552111558999158 +0.552111558999158 +0.7792659923782862 +0.7792659923782862 +0.7792659923782862 +0.7792659923782862 +0.7792659923782862 +0.7792659923782862 +0.7792659923782862 +0.7792659923782862 +0.7792659923782862 +0.7792659923782862 +0.7792659923782862 +0.7792659923782862 +0.6656871036437929 +0.6656871036437929 +0.6656871036437929 +0.6656871036437929 +0.6656871036437929 +0.6656871036437929 +0.6656871036437929 +0.6656871036437929 +0.6656871036437929 +0.6656871036437929 +0.6656871036437929 +0.6656871036437929 +0.7435137743371989 +0.7435137743371989 +0.7435137743371989 +0.7435137743371989 +0.7435137743371989 +0.7435137743371989 +0.7435137743371989 +0.7435137743371989 +0.7435137743371989 +0.7435137743371989 +0.7435137743371989 +0.7435137743371989 +0.7435137743371989 +0.8688023472919777 +0.8688023472919777 +0.8688023472919777 +0.8688023472919777 +0.8688023472919777 +0.8688023472919777 +0.8688023472919777 +0.8688023472919777 +0.8688023472919777 +0.8688023472919777 +0.8688023472919777 +0.8688023472919777 +0.7225690042828818 +0.7225690042828818 +0.7225690042828818 +0.7225690042828818 +0.7225690042828818 +0.7225690042828818 +0.7225690042828818 +0.7225690042828818 +0.7225690042828818 +0.7225690042828818 +0.7225690042828818 +0.7225690042828818 +0.8866100282141612 +0.8866100282141612 +0.8866100282141612 +0.8866100282141612 +0.8866100282141612 +0.8866100282141612 +0.8866100282141612 +0.8866100282141612 +0.8866100282141612 +0.8866100282141612 +0.8866100282141612 +0.8866100282141612 +0.8866100282141612 +0.8374461350184257 +0.8374461350184257 +0.8374461350184257 +0.8374461350184257 +0.8374461350184257 +0.8374461350184257 +0.8374461350184257 +0.8374461350184257 +0.8374461350184257 +0.8374461350184257 +0.8374461350184257 +0.8374461350184257 +0.8365104788783658 +0.8365104788783658 +0.8365104788783658 +0.8365104788783658 +0.8365104788783658 +0.8365104788783658 +0.8365104788783658 +0.8365104788783658 +0.8365104788783658 +0.8365104788783658 +0.8365104788783658 +0.8365104788783658 +0.928892180915439 +0.928892180915439 +0.928892180915439 +0.928892180915439 +0.928892180915439 +0.928892180915439 +0.928892180915439 +0.928892180915439 +0.928892180915439 +0.928892180915439 +0.928892180915439 +0.928892180915439 +0.928892180915439 +0.7275019293899534 +0.7275019293899534 +0.7275019293899534 +0.7275019293899534 +0.7275019293899534 +0.7275019293899534 +0.7275019293899534 +0.7275019293899534 +0.7275019293899534 +0.7275019293899534 +0.7275019293899534 +0.7275019293899534 +0.9516437185963472 +0.9516437185963472 +0.9516437185963472 +0.9516437185963472 +0.9516437185963472 +0.9516437185963472 +0.9516437185963472 +0.9516437185963472 +0.9516437185963472 +0.9516437185963472 +0.9516437185963472 +0.9516437185963472 diff --git a/dbms/tests/queries/0_stateless/00952_ml_test.sql b/dbms/tests/queries/0_stateless/00952_ml_test.sql new file mode 100644 index 00000000000..813131cf78d --- /dev/null +++ b/dbms/tests/queries/0_stateless/00952_ml_test.sql @@ -0,0 +1,25 @@ +CREATE DATABASE IF NOT EXISTS test; +DROP TABLE IF EXISTS test.defaults; +CREATE TABLE IF NOT EXISTS test.defaults +( + param1 Float64, + param2 Float64, + param3 Float64, + param4 Float64, + param5 Float64, + param6 Float64, + param7 Float64, + target Float64, + predict1 Float64, + predict2 Float64, + predict3 Float64, + predict4 Float64, + predict5 Float64, + predict6 Float64, + predict7 Float64 + +) ENGINE = Memory; +insert into test.defaults values (1.76210664421617,1.7469706406568504,0.7988286239230257,1.0938642223599824,1.167321139201246,1.7648182796261376,0.909111664354187,0.92,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.6276564089897139,-0.06763531281107672,0.7988286239230257,0.5966532121963541,1.167321139201246,0.4551512643242912,0.909111664354187,0.76,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(-0.07046681268810527,-0.5625278455750569,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-1.0056311758200724,0.909111664354187,0.72,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.4531256035702591,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-1.0614543055744028,0.11933920911869125,0.909111664354187,0.8,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(-0.24499761810756004,-0.7274920231630502,-0.952028633990455,-1.3921908284581592,-0.5042604443804907,-0.6530285178541898,-1.0999748867047898,0.65,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(1.1512488252480781,1.2520781078928702,1.674257252879766,1.0938642223599824,-0.5042604443804907,1.244309594057455,0.909111664354187,0.9,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,0.6101272780073337,-0.6698191206144725,0.909111664354187,0.75,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(-0.7685900343659244,-1.057420378339037,-0.952028633990455,-0.3977688081309026,0.6101272780073337,-1.1735372034228724,-1.0999748867047898,0.68,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(-1.2921824506242887,-0.8924562007510436,-1.8274572629471952,-1.3921908284581592,-2.175842027962227,-1.0056311758200724,-1.0999748867047898,0.5,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.5403910062799865,0.09732886477691666,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,0.0018049897967303734,-1.0999748867047898,0.45,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.7149218116994412,-0.2325994903990701,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.3340070654088696,0.909111664354187,0.52,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.889452617118896,0.5922213975408968,0.7988286239230257,0.5966532121963541,1.167321139201246,0.6734291002079332,0.909111664354187,0.84,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.9767180198286235,0.7571855751288902,0.7988286239230257,0.5966532121963541,1.167321139201246,0.8413351278107333,0.909111664354187,0.78,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(-0.8558554370756518,0.26229304236491,-0.0766000050337147,0.5966532121963541,-0.5042604443804907,-1.0056311758200724,0.909111664354187,0.62,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(-0.5067938262367422,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,-1.618648166768315,-0.6698191206144725,0.909111664354187,0.61,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(-0.24499761810756004,-0.39756366798706344,-0.0766000050337147,0.09944220203272576,-1.0614543055744028,-0.5019130930116695,-1.0999748867047898,0.54,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(0.016798590021622126,-0.06763531281107672,-0.0766000050337147,0.5966532121963541,-0.5042604443804907,0.16971101739953035,-1.0999748867047898,0.66,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(0.1913293954410769,-0.2325994903990701,-0.0766000050337147,0.5966532121963541,-0.5042604443804907,-1.0056311758200724,0.909111664354187,0.65,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(0.10406399273134952,0.4272572199529034,-0.0766000050337147,0.5966532121963541,-0.5042604443804907,0.3376170450023333,-1.0999748867047898,0.63,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(-1.2049170479145614,-0.8924562007510436,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,-0.1661010378060696,-1.0999748867047898,0.62,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(-0.41952842352701486,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,-1.618648166768315,-1.1735372034228724,0.909111664354187,0.64,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(0.7149218116994412,1.087113930304877,0.7988286239230257,-0.3977688081309026,-1.618648166768315,-0.3340070654088696,-1.0999748867047898,0.7,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(0.9767180198286235,1.4170422854808635,1.674257252879766,1.5910752325236108,1.724515000395158,1.5129592382219361,0.909111664354187,0.94,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(1.5003104360869879,1.9119348182448437,1.674257252879766,1.5910752325236108,1.167321139201246,1.848771293427536,0.909111664354187,0.95,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(1.6748412415064426,1.9119348182448437,1.674257252879766,0.5966532121963541,0.052933416813421515,2.016677321030339,0.909111664354187,0.97,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(2.023902852345352,2.076898995832837,1.674257252879766,1.0938642223599824,1.167321139201246,1.680865265824736,0.909111664354187,0.94,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(0.4531256035702591,0.26229304236491,1.674257252879766,1.0938642223599824,0.052933416813421515,0.3376170450023333,-1.0999748867047898,0.76,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(-1.6412440614631982,-1.5523129111030172,-0.952028633990455,-1.8894018386217877,-1.0614543055744028,-1.8451613138340752,0.909111664354187,0.44,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(-1.9030402695923805,-2.377133799042984,-1.8274572629471952,-1.3921908284581592,-1.618648166768315,-2.348879396642477,-1.0999748867047898,0.46,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(-0.5940592289464697,-1.3873487335150236,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-2.180973369039677,-1.0999748867047898,0.54,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(-1.4667132560437435,-1.7172770886910105,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,-0.8377251482172725,0.909111664354187,0.65,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(0.889452617118896,-0.7274920231630502,-0.0766000050337147,0.5966532121963541,0.6101272780073337,-0.5019130930116695,0.909111664354187,0.74,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(1.8493720469258974,1.7469706406568504,0.7988286239230257,-0.3977688081309026,1.167321139201246,1.3450532106191362,0.909111664354187,0.91,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(2.023902852345352,1.087113930304877,1.674257252879766,0.5966532121963541,0.6101272780073337,1.680865265824736,0.909111664354187,0.9,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(1.2385142279578056,0.7571855751288902,1.674257252879766,0.5966532121963541,1.724515000395158,2.016677321030339,0.909111664354187,0.94,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(0.2785947981508043,0.4272572199529034,1.674257252879766,1.5910752325236108,1.724515000395158,1.0092411554135332,0.909111664354187,0.88,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(-1.553978658753471,-0.2325994903990701,-0.952028633990455,0.5966532121963541,0.6101272780073337,-0.3340070654088696,-1.0999748867047898,0.64,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(-1.4667132560437435,-0.39756366798706344,-1.8274572629471952,-2.386612848785416,-1.618648166768315,-1.3414432310256739,-1.0999748867047898,0.58,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(-1.117651645204834,-0.39756366798706344,-1.8274572629471952,-0.3977688081309026,-2.175842027962227,-1.8451613138340752,-1.0999748867047898,0.52,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(-0.8558554370756518,0.09732886477691666,-0.952028633990455,0.5966532121963541,0.052933416813421515,-1.5093492586284738,-1.0999748867047898,0.48,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(-0.7685900343659244,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,-1.0056311758200724,0.909111664354187,0.46,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(-0.07046681268810527,-0.39756366798706344,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6698191206144725,0.909111664354187,0.49,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(-0.3322630208172874,-0.06763531281107672,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-0.1661010378060696,0.909111664354187,0.53,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(1.3257796306675331,1.582006463068857,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.8413351278107333,-1.0999748867047898,0.87,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(0.8021872144091686,0.9221497527168835,1.674257252879766,1.0938642223599824,0.6101272780073337,1.3450532106191362,0.909111664354187,0.91,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(0.4531256035702591,0.4272572199529034,1.674257252879766,1.5910752325236108,0.6101272780073337,0.8413351278107333,0.909111664354187,0.88,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(1.0639834225383509,1.087113930304877,1.674257252879766,0.5966532121963541,1.724515000395158,1.1771471830163363,0.909111664354187,0.86,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(1.9366374496356247,1.9119348182448437,1.674257252879766,1.0938642223599824,0.6101272780073337,1.848771293427536,-1.0999748867047898,0.89,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(0.36586020086053167,0.4272572199529034,-0.0766000050337147,0.09944220203272576,1.724515000395158,0.42157005880373183,0.909111664354187,0.82,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(0.889452617118896,0.5922213975408968,0.7988286239230257,-0.3977688081309026,0.6101272780073337,-0.3340070654088696,0.909111664354187,0.78,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(-0.3322630208172874,-1.5523129111030172,-0.0766000050337147,-0.8949798182945309,1.167321139201246,-0.5019130930116695,0.909111664354187,0.76,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-0.41952842352701486,-1.2223845559270303,-0.952028633990455,-1.8894018386217877,0.052933416813421515,-1.1735372034228724,0.909111664354187,0.56,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(1.5003104360869879,1.4170422854808635,0.7988286239230257,0.5966532121963541,-0.5042604443804907,-1.0056311758200724,0.909111664354187,0.78,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(0.6276564089897139,0.7571855751288902,0.7988286239230257,0.5966532121963541,-1.0614543055744028,-0.8377251482172725,0.909111664354187,0.72,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(0.4531256035702591,0.4272572199529034,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-1.0056311758200724,-1.0999748867047898,0.7,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(0.2785947981508043,-0.7274920231630502,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-1.5093492586284738,-1.0999748867047898,0.64,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-0.07046681268810527,-0.8924562007510436,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,-2.013067341436875,-1.0999748867047898,0.64,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-1.6412440614631982,-1.3873487335150236,-0.952028633990455,0.5966532121963541,-1.618648166768315,-1.6772552862312753,-1.0999748867047898,0.46,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-1.4667132560437435,-1.3873487335150236,-1.8274572629471952,-0.3977688081309026,-1.618648166768315,-3.0205035070536796,0.909111664354187,0.36,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-0.5067938262367422,-0.5625278455750569,-0.952028633990455,-1.3921908284581592,-1.618648166768315,-0.5019130930116695,-1.0999748867047898,0.42,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-0.681324631656197,-1.2223845559270303,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,-0.8377251482172725,-1.0999748867047898,0.48,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-0.8558554370756518,-1.057420378339037,-0.0766000050337147,0.5966532121963541,-0.5042604443804907,-0.6698191206144725,-1.0999748867047898,0.47,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-1.117651645204834,-0.39756366798706344,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,-0.6698191206144725,0.909111664354187,0.54,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(-0.15773221539783266,-0.06763531281107672,-0.952028633990455,0.5966532121963541,-0.5042604443804907,-0.1661010378060696,0.909111664354187,0.56,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(0.7149218116994412,0.5922213975408968,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.16971101739953035,-1.0999748867047898,0.52,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(0.7149218116994412,0.7571855751288902,0.7988286239230257,0.09944220203272576,0.052933416813421515,0.5391042781256927,-1.0999748867047898,0.55,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(0.889452617118896,1.087113930304877,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,0.7070103057284927,-1.0999748867047898,0.61,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(-0.07046681268810527,-0.06763531281107672,-0.952028633990455,0.09944220203272576,0.052933416813421515,0.06896740083785215,0.909111664354187,0.57,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(0.10406399273134952,0.26229304236491,-0.0766000050337147,0.09944220203272576,0.6101272780073337,1.0428223609340956,0.909111664354187,0.68,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(0.9767180198286235,1.2520781078928702,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9420787443724145,0.909111664354187,0.78,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(1.3257796306675331,1.7469706406568504,1.674257252879766,1.5910752325236108,1.724515000395158,1.7480276768658578,0.909111664354187,0.94,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(1.6748412415064426,0.7571855751288902,1.674257252879766,1.5910752325236108,1.724515000395158,1.9495149099892173,0.909111664354187,0.96,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(0.36586020086053167,0.5922213975408968,1.674257252879766,1.5910752325236108,1.724515000395158,1.4290062244205346,0.909111664354187,0.93,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(-0.24499761810756004,0.09732886477691666,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.7405915112490521,0.909111664354187,0.84,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(-0.24499761810756004,-0.2325994903990701,-0.0766000050337147,-0.3977688081309026,1.724515000395158,0.5055230726051333,-1.0999748867047898,0.74,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(1.0639834225383509,1.087113930304877,-0.952028633990455,-1.3921908284581592,0.6101272780073337,-0.06535742124438843,0.909111664354187,0.72,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(0.889452617118896,0.7571855751288902,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,0.20329222292009272,0.909111664354187,0.74,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(-1.3794478533340162,-1.3873487335150236,-0.952028633990455,-0.3977688081309026,-1.618648166768315,-0.6362379150939101,-1.0999748867047898,0.64,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(-1.8157748668826532,-2.0472054438669973,-0.952028633990455,-0.3977688081309026,-1.618648166768315,-1.777998902792955,0.909111664354187,0.44,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(-1.990305672302108,-2.377133799042984,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-2.0802297524779956,-1.0999748867047898,0.46,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(-0.41952842352701486,-0.39756366798706344,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,-0.972049970299513,0.909111664354187,0.5,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(2.023902852345352,2.076898995832837,0.7988286239230257,1.5910752325236108,1.724515000395158,1.5129592382219361,0.909111664354187,0.96,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(0.2785947981508043,0.4272572199529034,1.674257252879766,1.5910752325236108,1.167321139201246,1.0428223609340956,0.909111664354187,0.92,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(0.4531256035702591,1.2520781078928702,1.674257252879766,0.5966532121963541,1.167321139201246,1.2778907995780144,0.909111664354187,0.92,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(2.023902852345352,1.2520781078928702,1.674257252879766,1.0938642223599824,1.167321139201246,1.4290062244205346,0.909111664354187,0.94,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(0.1913293954410769,-0.7274920231630502,0.7988286239230257,1.0938642223599824,0.052933416813421515,0.10254860635841155,-1.0999748867047898,0.76,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(-0.15773221539783266,-0.2325994903990701,-0.0766000050337147,1.0938642223599824,0.052933416813421515,-0.30042585988831016,-1.0999748867047898,0.72,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(0.016798590021622126,-0.06763531281107672,-0.952028633990455,0.09944220203272576,-0.5042604443804907,-0.535494298532232,-1.0999748867047898,0.66,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(-0.24499761810756004,0.09732886477691666,-0.0766000050337147,1.0938642223599824,0.052933416813421515,-0.7705627371761508,-1.0999748867047898,0.64,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(-0.07046681268810527,0.26229304236491,0.7988286239230257,1.0938642223599824,0.052933416813421515,0.27045463396121155,0.909111664354187,0.74,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(0.10406399273134952,-0.2325994903990701,-0.952028633990455,0.5966532121963541,0.6101272780073337,-1.139955997902313,0.909111664354187,0.64,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(-1.553978658753471,-1.7172770886910105,-0.0766000050337147,1.5910752325236108,0.052933416813421515,-1.5765116696695942,-1.0999748867047898,0.38,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(-1.6412440614631982,-1.5523129111030172,-0.952028633990455,0.5966532121963541,-0.5042604443804907,-0.9552593675392334,-1.0999748867047898,0.34,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(-1.3794478533340162,-1.7172770886910105,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,-1.2071184089434333,0.909111664354187,0.44,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(-1.2049170479145614,-1.3873487335150236,-0.0766000050337147,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898,0.36,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(-1.117651645204834,-1.2223845559270303,0.7988286239230257,-1.8894018386217877,-1.0614543055744028,-1.2742808199845537,-1.0999748867047898,0.42,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(-0.9431208397853792,-1.2223845559270303,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,-1.0056311758200724,-1.0999748867047898,0.48,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(1.2385142279578056,2.076898995832837,-0.0766000050337147,0.5966532121963541,0.6101272780073337,0.6062666891668145,0.909111664354187,0.86,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(1.3257796306675331,1.9119348182448437,0.7988286239230257,1.5910752325236108,1.167321139201246,1.076403566454655,0.909111664354187,0.9,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(0.5403910062799865,0.9221497527168835,-0.0766000050337147,0.5966532121963541,0.6101272780073337,0.47194186708457386,0.909111664354187,0.79,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(0.4531256035702591,-0.06763531281107672,-0.0766000050337147,0.09944220203272576,0.052933416813421515,-0.2332634488471884,0.909111664354187,0.71,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-0.41952842352701486,-0.39756366798706344,-0.952028633990455,-0.8949798182945309,-0.5042604443804907,-0.8041439426967131,-1.0999748867047898,0.64,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-0.24499761810756004,-0.2325994903990701,-0.952028633990455,0.5966532121963541,0.052933416813421515,-0.585866106813071,-1.0999748867047898,0.62,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(0.016798590021622126,-0.5625278455750569,-0.952028633990455,1.0938642223599824,0.6101272780073337,-0.2164728460869087,-1.0999748867047898,0.57,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(0.8021872144091686,0.7571855751288902,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,0.7573821140093348,0.909111664354187,0.74,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-0.07046681268810527,0.4272572199529034,-0.0766000050337147,0.5966532121963541,1.167321139201246,0.30403583948177093,0.909111664354187,0.69,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,1.167321139201246,0.9756599498929738,0.909111664354187,0.87,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(1.8493720469258974,1.582006463068857,0.7988286239230257,0.09944220203272576,1.167321139201246,1.4457968271808173,0.909111664354187,0.91,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(1.2385142279578056,1.4170422854808635,1.674257252879766,1.5910752325236108,1.724515000395158,1.3114720050985766,0.909111664354187,0.93,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-1.117651645204834,-0.7274920231630502,1.674257252879766,1.5910752325236108,0.6101272780073337,0.06896740083785215,-1.0999748867047898,0.68,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-1.0303862424951067,0.09732886477691666,1.674257252879766,-0.3977688081309026,-0.5042604443804907,-0.199682243326629,-1.0999748867047898,0.61,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(0.36586020086053167,0.26229304236491,0.7988286239230257,0.5966532121963541,0.6101272780073337,0.13612981187897094,0.909111664354187,0.69,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(-1.3794478533340162,-0.06763531281107672,-0.0766000050337147,0.09944220203272576,0.052933416813421515,-0.4347506819705508,0.909111664354187,0.62,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(0.2785947981508043,0.4272572199529034,-0.952028633990455,0.5966532121963541,0.052933416813421515,-0.06535742124438843,-1.0999748867047898,0.72,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(-0.5067938262367422,-0.39756366798706344,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,-0.2500540516074711,0.909111664354187,0.59,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(-0.5940592289464697,-0.2325994903990701,0.7988286239230257,1.0938642223599824,1.167321139201246,0.7405915112490521,0.909111664354187,0.66,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(-1.553978658753471,-0.8924562007510436,-0.0766000050337147,0.5966532121963541,0.052933416813421515,0.03538619531728977,-1.0999748867047898,0.56,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(-2.3393672831410175,-0.5625278455750569,0.7988286239230257,-1.3921908284581592,-1.0614543055744028,-1.9123237248751956,-1.0999748867047898,0.45,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(-1.8157748668826532,-1.3873487335150236,-0.952028633990455,-0.3977688081309026,0.052933416813421515,-2.214554574560236,-1.0999748867047898,0.47,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(0.889452617118896,-0.5625278455750569,1.674257252879766,-0.3977688081309026,0.052933416813421515,0.4047794560434521,0.909111664354187,0.71,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,1.6137028547836172,0.909111664354187,0.94,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(1.5003104360869879,1.9119348182448437,1.674257252879766,1.0938642223599824,1.167321139201246,1.4793780327013768,0.909111664354187,0.94,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(-0.5940592289464697,-0.2325994903990701,0.7988286239230257,-1.8894018386217877,-1.0614543055744028,-0.40116947644999135,-1.0999748867047898,0.57,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(-0.7685900343659244,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.052933416813421515,-0.6362379150939101,-1.0999748867047898,0.61,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(-1.3794478533340162,-0.2325994903990701,0.7988286239230257,-0.8949798182945309,-0.5042604443804907,-0.2164728460869087,-1.0999748867047898,0.57,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.10254860635841155,0.909111664354187,0.64,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(0.5403910062799865,0.9221497527168835,-0.0766000050337147,0.5966532121963541,-0.5042604443804907,1.2107283885368956,0.909111664354187,0.85,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(0.1913293954410769,0.7571855751288902,-0.0766000050337147,-0.8949798182945309,-1.618648166768315,0.18650162015981303,0.909111664354187,0.78,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(0.8021872144091686,0.7571855751288902,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,0.8413351278107333,0.909111664354187,0.84,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(1.4130450333772604,1.7469706406568504,1.674257252879766,1.5910752325236108,1.724515000395158,1.2611001968177347,0.909111664354187,0.92,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(1.9366374496356247,1.087113930304877,1.674257252879766,0.5966532121963541,1.167321139201246,1.9495149099892173,0.909111664354187,0.96,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(-1.2049170479145614,-0.39756366798706344,1.674257252879766,1.5910752325236108,1.167321139201246,0.08575800359813185,-1.0999748867047898,0.77,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(-0.681324631656197,-0.39756366798706344,1.674257252879766,0.09944220203272576,0.052933416813421515,-0.06535742124438843,-1.0999748867047898,0.71,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(0.5403910062799865,0.7571855751288902,1.674257252879766,0.5966532121963541,1.167321139201246,0.30403583948177093,-1.0999748867047898,0.79,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(1.4130450333772604,0.9221497527168835,1.674257252879766,0.5966532121963541,0.6101272780073337,1.1435659774957738,0.909111664354187,0.89,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(-0.24499761810756004,0.26229304236491,0.7988286239230257,0.09944220203272576,0.6101272780073337,0.2872452367214912,0.909111664354187,0.82,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,1.5910752325236108,0.6101272780073337,-0.2500540516074711,-1.0999748867047898,0.76,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(-0.07046681268810527,-1.2223845559270303,-0.952028633990455,-1.8894018386217877,-0.5042604443804907,-0.7369815316555913,0.909111664354187,0.71,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(0.8021872144091686,1.4170422854808635,-0.952028633990455,1.0938642223599824,-0.5042604443804907,0.8077539222901738,0.909111664354187,0.8,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(0.10406399273134952,0.26229304236491,-1.8274572629471952,0.09944220203272576,0.052933416813421515,0.8749163333312926,-1.0999748867047898,0.78,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(1.0639834225383509,0.4272572199529034,-0.952028633990455,0.5966532121963541,-0.5042604443804907,0.9252881416121347,0.909111664354187,0.84,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(1.3257796306675331,1.7469706406568504,-0.952028633990455,1.0938642223599824,0.052933416813421515,1.2778907995780144,0.909111664354187,0.9,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(1.2385142279578056,1.2520781078928702,1.674257252879766,0.5966532121963541,0.052933416813421515,1.412215621660255,0.909111664354187,0.92,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(2.023902852345352,2.076898995832837,0.7988286239230257,1.0938642223599824,0.6101272780073337,2.2181645541536983,0.909111664354187,0.97,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(0.7149218116994412,0.7571855751288902,-0.952028633990455,-0.3977688081309026,0.052933416813421515,0.6062666891668145,0.909111664354187,0.8,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(0.2785947981508043,0.9221497527168835,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,0.06896740083785215,0.909111664354187,0.81,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(-0.15773221539783266,-0.39756366798706344,-0.0766000050337147,-1.3921908284581592,-1.0614543055744028,-0.199682243326629,-1.0999748867047898,0.75,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(0.8021872144091686,1.087113930304877,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,0.8581257305710129,0.909111664354187,0.83,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(1.9366374496356247,1.4170422854808635,0.7988286239230257,0.5966532121963541,0.052933416813421515,2.016677321030339,0.909111664354187,0.96,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(-0.5067938262367422,-0.2325994903990701,-0.952028633990455,0.09944220203272576,-0.5042604443804907,-0.5690755040527913,0.909111664354187,0.79,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(1.5003104360869879,1.087113930304877,0.7988286239230257,0.5966532121963541,0.6101272780073337,1.3954250188999753,0.909111664354187,0.93,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(1.3257796306675331,1.4170422854808635,1.674257252879766,1.5910752325236108,1.724515000395158,1.1435659774957738,0.909111664354187,0.94,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(0.36586020086053167,0.7571855751288902,1.674257252879766,1.5910752325236108,1.724515000395158,0.7741727167696144,0.909111664354187,0.86,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(0.6276564089897139,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.6101272780073337,0.25366403120093184,-1.0999748867047898,0.79,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(0.8021872144091686,0.09732886477691666,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.4887324698448536,-1.0999748867047898,0.8,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(-0.41952842352701486,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,0.15292041463925066,-1.0999748867047898,0.77,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(-0.15773221539783266,-0.39756366798706344,-0.0766000050337147,-1.3921908284581592,-1.0614543055744028,-0.4347506819705508,-1.0999748867047898,0.7,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(-0.681324631656197,-0.5625278455750569,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.5690755040527913,-1.0999748867047898,0.65,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(-0.9431208397853792,-0.2325994903990701,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.7705627371761508,-1.0999748867047898,0.61,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(-1.7285094641729257,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.1735372034228724,-1.0999748867047898,0.52,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(-0.15773221539783266,-0.7274920231630502,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.2406996144639928,-1.0999748867047898,0.57,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(-1.6412440614631982,-1.3873487335150236,-1.8274572629471952,-1.8894018386217877,-0.5042604443804907,-1.9123237248751956,-1.0999748867047898,0.53,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(0.10406399273134952,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.1661010378060696,-1.0999748867047898,0.67,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(0.016798590021622126,-0.39756366798706344,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,-0.06535742124438843,-1.0999748867047898,0.68,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.690219702968213,0.909111664354187,0.81,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(0.4531256035702591,0.4272572199529034,1.674257252879766,1.0938642223599824,0.6101272780073337,0.6230572919270941,-1.0999748867047898,0.78,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(-1.2921824506242887,-0.8924562007510436,-0.0766000050337147,0.09944220203272576,1.724515000395158,-0.45154128473083044,-1.0999748867047898,0.65,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(-0.3322630208172874,-0.8924562007510436,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,-0.5522849012925116,-1.0999748867047898,0.64,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(-2.0775710750118352,-1.7172770886910105,-0.952028633990455,-1.3921908284581592,0.6101272780073337,-1.3414432310256739,0.909111664354187,0.64,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(-0.5067938262367422,-1.3873487335150236,-0.952028633990455,-0.8949798182945309,-0.5042604443804907,-1.0392123813406318,-1.0999748867047898,0.65,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(-0.41952842352701486,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-0.9384687647789537,0.909111664354187,0.68,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(1.5003104360869879,1.582006463068857,1.674257252879766,0.5966532121963541,1.167321139201246,0.7909633195298942,0.909111664354187,0.89,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(0.4531256035702591,0.4272572199529034,0.7988286239230257,0.5966532121963541,1.724515000395158,0.8917069360915754,0.909111664354187,0.86,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(0.5403910062799865,0.9221497527168835,0.7988286239230257,0.5966532121963541,1.167321139201246,1.0596129636943752,0.909111664354187,0.89,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(0.36586020086053167,0.5922213975408968,0.7988286239230257,0.5966532121963541,0.6101272780073337,0.6230572919270941,0.909111664354187,0.87,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(0.2785947981508043,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.052933416813421515,0.4551512643242912,0.909111664354187,0.85,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(1.0639834225383509,1.9119348182448437,0.7988286239230257,1.0938642223599824,1.167321139201246,0.9420787443724145,0.909111664354187,0.9,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(0.1913293954410769,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,-1.0999748867047898,0.82,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(-0.681324631656197,0.09732886477691666,-0.0766000050337147,-0.8949798182945309,-0.5042604443804907,-0.8041439426967131,-1.0999748867047898,0.72,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(-0.8558554370756518,-0.8924562007510436,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.5522849012925116,-1.0999748867047898,0.73,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(-1.4667132560437435,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,-0.7369815316555913,-1.0999748867047898,0.71,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(-1.0303862424951067,-0.06763531281107672,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.30042585988831016,-1.0999748867047898,0.71,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(-1.553978658753471,-1.2223845559270303,-0.952028633990455,-0.3977688081309026,0.052933416813421515,-1.2071184089434333,-1.0999748867047898,0.68,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(-0.24499761810756004,0.4272572199529034,-0.0766000050337147,0.5966532121963541,0.6101272780073337,0.3376170450023333,-1.0999748867047898,0.75,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(-0.07046681268810527,-0.2325994903990701,-0.952028633990455,-0.8949798182945309,0.6101272780073337,-0.46833188749111015,-1.0999748867047898,0.72,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(0.889452617118896,0.9221497527168835,0.7988286239230257,1.0938642223599824,1.167321139201246,0.8581257305710129,0.909111664354187,0.89,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(0.016798590021622126,-0.06763531281107672,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,0.13612981187897094,0.909111664354187,0.84,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(1.5875758387967152,1.7469706406568504,1.674257252879766,1.0938642223599824,0.052933416813421515,1.412215621660255,0.909111664354187,0.93,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(1.2385142279578056,1.2520781078928702,1.674257252879766,1.0938642223599824,0.052933416813421515,1.2778907995780144,0.909111664354187,0.93,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(0.6276564089897139,0.7571855751288902,1.674257252879766,1.5910752325236108,1.724515000395158,0.8077539222901738,0.909111664354187,0.88,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(0.6276564089897139,0.5922213975408968,1.674257252879766,1.0938642223599824,0.6101272780073337,0.9420787443724145,0.909111664354187,0.9,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(0.5403910062799865,0.4272572199529034,1.674257252879766,0.5966532121963541,1.724515000395158,0.6398478946873739,0.909111664354187,0.87,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(0.4531256035702591,1.087113930304877,1.674257252879766,1.0938642223599824,0.6101272780073337,0.572685483646252,0.909111664354187,0.86,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(1.6748412415064426,1.7469706406568504,1.674257252879766,1.0938642223599824,1.724515000395158,1.5633310465027752,0.909111664354187,0.94,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(-0.07046681268810527,0.26229304236491,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,0.27045463396121155,-1.0999748867047898,0.77,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(-0.8558554370756518,-0.06763531281107672,-0.952028633990455,-0.3977688081309026,0.052933416813421515,-0.1325198322855102,0.909111664354187,0.78,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(-0.9431208397853792,-0.39756366798706344,-0.952028633990455,-0.3977688081309026,-1.0614543055744028,-0.5690755040527913,-1.0999748867047898,0.73,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(-0.5940592289464697,-0.2325994903990701,-0.952028633990455,0.09944220203272576,-1.0614543055744028,-0.45154128473083044,-1.0999748867047898,0.73,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(-0.5067938262367422,-0.5625278455750569,-0.0766000050337147,1.0938642223599824,1.167321139201246,-0.2836352571280305,-1.0999748867047898,0.7,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(-0.3322630208172874,-0.06763531281107672,-0.0766000050337147,0.5966532121963541,1.167321139201246,0.15292041463925066,-1.0999748867047898,0.72,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(0.016798590021622126,-0.7274920231630502,-0.0766000050337147,-0.8949798182945309,-0.5042604443804907,-0.0989386267649508,0.909111664354187,0.73,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(-0.15773221539783266,0.4272572199529034,-0.952028633990455,0.09944220203272576,-0.5042604443804907,-0.2332634488471884,0.909111664354187,0.72,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(2.023902852345352,2.076898995832837,1.674257252879766,1.0938642223599824,1.167321139201246,2.2013739513934185,0.909111664354187,0.97,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(1.5003104360869879,2.076898995832837,1.674257252879766,0.5966532121963541,1.724515000395158,2.1342115403522968,0.909111664354187,0.97,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(-1.6412440614631982,-0.39756366798706344,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.0989386267649508,-1.0999748867047898,0.69,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(-1.9030402695923805,-1.3873487335150236,-0.952028633990455,-0.8949798182945309,-0.5042604443804907,-1.5933022724298738,-1.0999748867047898,0.57,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(-0.15773221539783266,-1.3873487335150236,-0.952028633990455,0.09944220203272576,-0.5042604443804907,-1.1903278061831537,-1.0999748867047898,0.63,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(-0.5940592289464697,-0.8924562007510436,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.972049970299513,0.909111664354187,0.66,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(-1.0303862424951067,-0.2325994903990701,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,-0.7369815316555913,-1.0999748867047898,0.64,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(-1.3794478533340162,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.8041439426967131,0.909111664354187,0.68,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(0.7149218116994412,0.09732886477691666,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.7741727167696144,0.909111664354187,0.79,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(0.9767180198286235,0.4272572199529034,0.7988286239230257,1.5910752325236108,0.6101272780073337,0.908497538851855,0.909111664354187,0.82,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(1.8493720469258974,2.076898995832837,0.7988286239230257,1.5910752325236108,1.724515000395158,1.7816088823864173,0.909111664354187,0.95,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(1.4130450333772604,1.9119348182448437,1.674257252879766,1.5910752325236108,1.167321139201246,1.9830961155097766,0.909111664354187,0.96,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(1.2385142279578056,1.582006463068857,0.7988286239230257,1.0938642223599824,1.724515000395158,1.3786344161396955,0.909111664354187,0.94,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(1.1512488252480781,1.4170422854808635,1.674257252879766,1.5910752325236108,1.167321139201246,1.2778907995780144,0.909111664354187,0.93,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(0.4531256035702591,0.7571855751288902,0.7988286239230257,1.0938642223599824,1.167321139201246,1.1099847719752143,0.909111664354187,0.91,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(0.36586020086053167,0.26229304236491,0.7988286239230257,0.5966532121963541,0.6101272780073337,0.8917069360915754,0.909111664354187,0.85,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(0.6276564089897139,0.4272572199529034,0.7988286239230257,-0.3977688081309026,0.052933416813421515,0.6230572919270941,0.909111664354187,0.84,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(-0.41952842352701486,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.052933416813421515,-0.30042585988831016,-1.0999748867047898,0.74,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(-0.3322630208172874,-0.7274920231630502,-0.0766000050337147,0.5966532121963541,0.6101272780073337,0.25366403120093184,-1.0999748867047898,0.76,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(-0.07046681268810527,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.06535742124438843,-1.0999748867047898,0.75,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(0.6276564089897139,0.9221497527168835,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.32082644224205065,-1.0999748867047898,0.76,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(-0.7685900343659244,0.26229304236491,-0.952028633990455,-0.3977688081309026,0.6101272780073337,-0.2500540516074711,-1.0999748867047898,0.71,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(-1.0303862424951067,-0.39756366798706344,-0.952028633990455,-0.3977688081309026,-1.618648166768315,-0.6194473123336305,-1.0999748867047898,0.67,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(-1.8157748668826532,-1.3873487335150236,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.9552593675392334,-1.0999748867047898,0.61,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(-0.9431208397853792,0.4272572199529034,-0.952028633990455,0.09944220203272576,0.6101272780073337,-0.2500540516074711,-1.0999748867047898,0.63,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(-0.41952842352701486,0.4272572199529034,-0.952028633990455,0.09944220203272576,-0.5042604443804907,-0.1157292295252305,-1.0999748867047898,0.64,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(0.10406399273134952,0.7571855751288902,-0.0766000050337147,0.5966532121963541,0.052933416813421515,0.11933920911869125,-1.0999748867047898,0.71,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(0.6276564089897139,0.5922213975408968,0.7988286239230257,-0.3977688081309026,-0.5042604443804907,0.690219702968213,0.909111664354187,0.82,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(-0.3322630208172874,-0.5625278455750569,-0.0766000050337147,0.5966532121963541,1.167321139201246,0.08575800359813185,-1.0999748867047898,0.73,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(0.1913293954410769,-0.2325994903990701,-0.0766000050337147,0.09944220203272576,-1.0614543055744028,-0.45154128473083044,0.909111664354187,0.74,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(-0.41952842352701486,-0.06763531281107672,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-0.5522849012925116,-1.0999748867047898,0.69,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(-1.117651645204834,-1.2223845559270303,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-0.8880969564981116,-1.0999748867047898,0.64,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(1.1512488252480781,0.9221497527168835,1.674257252879766,1.5910752325236108,0.6101272780073337,1.1939377857766158,0.909111664354187,0.91,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(0.8021872144091686,0.5922213975408968,1.674257252879766,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187,0.88,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(0.7149218116994412,0.7571855751288902,0.7988286239230257,0.5966532121963541,1.167321139201246,0.9588693471326941,0.909111664354187,0.85,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(1.0639834225383509,1.087113930304877,1.674257252879766,1.0938642223599824,1.724515000395158,0.9924505526532535,0.909111664354187,0.86,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(-0.5940592289464697,-0.5625278455750569,-0.0766000050337147,-1.3921908284581592,0.052933416813421515,-0.3843788736897117,-1.0999748867047898,0.7,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(-1.553978658753471,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.1903278061831537,-1.0999748867047898,0.59,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(-1.8157748668826532,-1.057420378339037,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-1.5429304641490347,-1.0999748867047898,0.6,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(0.016798590021622126,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-0.753772134415871,-1.0999748867047898,0.65,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(0.6276564089897139,1.2520781078928702,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,0.27045463396121155,0.909111664354187,0.7,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(0.7149218116994412,1.087113930304877,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,0.7405915112490521,0.909111664354187,0.76,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(-0.24499761810756004,-0.06763531281107672,-0.952028633990455,-0.8949798182945309,0.6101272780073337,-0.06535742124438843,-1.0999748867047898,0.63,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(0.9767180198286235,0.4272572199529034,0.7988286239230257,0.5966532121963541,-1.0614543055744028,0.7070103057284927,0.909111664354187,0.81,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(-0.07046681268810527,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.22008282568037243,-1.0999748867047898,0.72,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(-0.5067938262367422,-0.5625278455750569,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-0.199682243326629,-1.0999748867047898,0.71,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4551512643242912,0.909111664354187,0.8,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.36586020086053167,0.5922213975408968,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.3879888532831724,0.909111664354187,0.77,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.2785947981508043,-0.5625278455750569,-0.0766000050337147,-0.3977688081309026,-1.0614543055744028,-0.04856681848410872,0.909111664354187,0.74,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(-0.07046681268810527,-1.3873487335150236,-0.952028633990455,-0.8949798182945309,-0.5042604443804907,0.6734291002079332,-1.0999748867047898,0.7,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.10406399273134952,-1.2223845559270303,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-0.0989386267649508,0.909111664354187,0.71,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(1.5875758387967152,1.2520781078928702,0.7988286239230257,1.0938642223599824,1.167321139201246,1.8151900879069767,0.909111664354187,0.93,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.36586020086053167,1.087113930304877,0.7988286239230257,0.5966532121963541,1.724515000395158,0.8749163333312926,-1.0999748867047898,0.85,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(-0.8558554370756518,0.4272572199529034,0.7988286239230257,0.5966532121963541,1.167321139201246,-0.3843788736897117,-1.0999748867047898,0.79,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(-0.681324631656197,-1.3873487335150236,-0.0766000050337147,0.5966532121963541,0.6101272780073337,-0.06535742124438843,-1.0999748867047898,0.76,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.6276564089897139,-1.2223845559270303,-0.0766000050337147,0.5966532121963541,1.724515000395158,0.06896740083785215,0.909111664354187,0.78,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.8021872144091686,-0.8924562007510436,0.7988286239230257,1.5910752325236108,1.724515000395158,0.27045463396121155,0.909111664354187,0.77,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(1.2385142279578056,1.9119348182448437,0.7988286239230257,1.5910752325236108,1.167321139201246,1.244309594057455,0.909111664354187,0.9,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(0.889452617118896,0.09732886477691666,1.674257252879766,1.5910752325236108,0.052933416813421515,0.8917069360915754,0.909111664354187,0.87,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(-0.41952842352701486,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.8545157509775522,-1.0999748867047898,0.71,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(-0.7685900343659244,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,0.6101272780073337,-0.40116947644999135,0.909111664354187,0.7,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(0.6276564089897139,0.5922213975408968,-0.0766000050337147,-0.8949798182945309,-2.175842027962227,0.32082644224205065,0.909111664354187,0.7,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(0.7149218116994412,0.4272572199529034,-0.952028633990455,-0.3977688081309026,-1.0614543055744028,0.27045463396121155,0.909111664354187,0.75,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(-0.3322630208172874,-0.8924562007510436,-0.0766000050337147,-0.8949798182945309,-1.0614543055744028,0.13612981187897094,-1.0999748867047898,0.71,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(-0.41952842352701486,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.2500540516074711,-1.0999748867047898,0.72,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(-0.24499761810756004,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.7201909288953117,0.909111664354187,0.73,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(0.889452617118896,0.9221497527168835,0.7988286239230257,1.0938642223599824,1.724515000395158,0.908497538851855,-1.0999748867047898,0.83,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(-0.7685900343659244,0.09732886477691666,0.7988286239230257,1.0938642223599824,1.724515000395158,-0.4347506819705508,-1.0999748867047898,0.77,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(-0.9431208397853792,-0.39756366798706344,-0.952028633990455,-0.8949798182945309,-0.5042604443804907,-0.6362379150939101,0.909111664354187,0.72,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(-1.553978658753471,-1.8822412662790038,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.2406996144639928,-1.0999748867047898,0.54,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(-1.990305672302108,-2.0472054438669973,-1.8274572629471952,-1.8894018386217877,-2.175842027962227,-1.610092875190155,-1.0999748867047898,0.49,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(-0.41952842352701486,-1.3873487335150236,-1.8274572629471952,-2.386612848785416,-2.175842027962227,-0.9888405730597928,0.909111664354187,0.52,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(-0.15773221539783266,-1.2223845559270303,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.0895841896214724,-1.0999748867047898,0.58,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(0.4531256035702591,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,0.6062666891668145,0.909111664354187,0.78,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(1.0639834225383509,0.9221497527168835,1.674257252879766,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187,0.89,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(0.2785947981508043,-1.057420378339037,-0.952028633990455,-0.8949798182945309,-0.5042604443804907,0.03538619531728977,-1.0999748867047898,0.7,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(-0.7685900343659244,-0.7274920231630502,-0.952028633990455,-0.3977688081309026,0.052933416813421515,-0.1828916405663493,-1.0999748867047898,0.66,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(-1.117651645204834,-0.8924562007510436,-0.952028633990455,-0.3977688081309026,0.6101272780073337,0.22008282568037243,-1.0999748867047898,0.67,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(-0.5067938262367422,-0.8924562007510436,-0.0766000050337147,1.0938642223599824,0.6101272780073337,0.06896740083785215,0.909111664354187,0.68,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(0.016798590021622126,0.4272572199529034,-0.0766000050337147,0.5966532121963541,1.167321139201246,0.8581257305710129,0.909111664354187,0.8,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(-0.41952842352701486,-0.2325994903990701,-0.0766000050337147,0.5966532121963541,0.052933416813421515,0.32082644224205065,0.909111664354187,0.81,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(0.36586020086053167,0.5922213975408968,-0.0766000050337147,-0.8949798182945309,-0.5042604443804907,0.5055230726051333,0.909111664354187,0.8,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(2.023902852345352,0.7571855751288902,0.7988286239230257,1.5910752325236108,1.167321139201246,1.7816088823864173,0.909111664354187,0.94,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(1.2385142279578056,1.4170422854808635,1.674257252879766,0.5966532121963541,0.6101272780073337,1.1099847719752143,0.909111664354187,0.93,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(1.6748412415064426,1.7469706406568504,1.674257252879766,1.0938642223599824,0.6101272780073337,0.9924505526532535,0.909111664354187,0.92,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(0.6276564089897139,1.087113930304877,1.674257252879766,1.5910752325236108,1.167321139201246,0.8077539222901738,0.909111664354187,0.89,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(-0.24499761810756004,-0.5625278455750569,0.7988286239230257,1.5910752325236108,1.724515000395158,0.7070103057284927,-1.0999748867047898,0.82,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(-0.3322630208172874,0.26229304236491,-0.0766000050337147,0.5966532121963541,0.052933416813421515,0.6734291002079332,-1.0999748867047898,0.79,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-0.8949798182945309,-0.5042604443804907,-1.5933022724298738,-1.0999748867047898,0.58,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(-1.4667132560437435,-0.8924562007510436,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.223909011703713,-1.0999748867047898,0.56,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(-1.2921824506242887,-1.3873487335150236,-0.952028633990455,-2.386612848785416,-1.618648166768315,-1.056002984100913,-1.0999748867047898,0.56,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(-0.41952842352701486,-1.5523129111030172,-1.8274572629471952,0.09944220203272576,-0.5042604443804907,-0.7034003261350319,0.909111664354187,0.64,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(-0.07046681268810527,-1.057420378339037,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-0.46833188749111015,0.909111664354187,0.61,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(0.016798590021622126,-1.2223845559270303,-0.952028633990455,-0.3977688081309026,-1.0614543055744028,-0.04856681848410872,-1.0999748867047898,0.68,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(-0.5940592289464697,-0.06763531281107672,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.11933920911869125,-1.0999748867047898,0.76,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(0.2785947981508043,2.076898995832837,-0.0766000050337147,0.5966532121963541,1.167321139201246,0.8581257305710129,-1.0999748867047898,0.86,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(1.1512488252480781,1.087113930304877,-0.0766000050337147,1.0938642223599824,1.167321139201246,1.076403566454655,0.909111664354187,0.9,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(-1.0303862424951067,0.7571855751288902,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.08575800359813185,-1.0999748867047898,0.71,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(-0.681324631656197,-0.2325994903990701,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-1.0056311758200724,-1.0999748867047898,0.62,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(0.1913293954410769,0.09732886477691666,-0.952028633990455,-0.8949798182945309,-0.5042604443804907,0.27045463396121155,-1.0999748867047898,0.66,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(0.4531256035702591,-0.39756366798706344,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,-0.2500540516074711,0.909111664354187,0.65,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(0.5403910062799865,-0.06763531281107672,-0.0766000050337147,0.09944220203272576,0.052933416813421515,-0.08214802400466813,0.909111664354187,0.73,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(-0.3322630208172874,-0.2325994903990701,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-0.2836352571280305,-1.0999748867047898,0.62,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(0.36586020086053167,0.26229304236491,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.3376170450023333,0.909111664354187,0.74,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(0.5403910062799865,0.4272572199529034,-0.0766000050337147,0.5966532121963541,0.052933416813421515,0.8413351278107333,0.909111664354187,0.79,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(0.7149218116994412,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.6101272780073337,0.6734291002079332,0.909111664354187,0.8,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(-0.41952842352701486,0.09732886477691666,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,-0.1157292295252305,-1.0999748867047898,0.69,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(-0.7685900343659244,0.4272572199529034,0.7988286239230257,0.09944220203272576,-0.5042604443804907,0.0018049897967303734,-1.0999748867047898,0.7,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(0.2785947981508043,-0.5625278455750569,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.23687342844065212,0.909111664354187,0.76,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(0.9767180198286235,0.09732886477691666,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9756599498929738,0.909111664354187,0.84,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(-0.5067938262367422,-0.06763531281107672,0.7988286239230257,1.0938642223599824,1.167321139201246,0.6734291002079332,0.909111664354187,0.78,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(-1.3794478533340162,-1.2223845559270303,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,-0.9384687647789537,-1.0999748867047898,0.67,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(-1.0303862424951067,-0.39756366798706344,-0.952028633990455,-0.3977688081309026,0.6101272780073337,-0.7873533399364304,-1.0999748867047898,0.66,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(-0.7685900343659244,-0.5625278455750569,-0.952028633990455,-0.8949798182945309,-0.5042604443804907,-0.8880969564981116,-1.0999748867047898,0.65,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(-1.6412440614631982,-1.057420378339037,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.2406996144639928,-1.0999748867047898,0.54,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(-1.4667132560437435,-1.3873487335150236,-1.8274572629471952,-2.386612848785416,-1.0614543055744028,-0.9888405730597928,-1.0999748867047898,0.58,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(0.6276564089897139,0.5922213975408968,-0.0766000050337147,-0.8949798182945309,-1.618648166768315,0.3376170450023333,0.909111664354187,0.79,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(0.889452617118896,0.9221497527168835,0.7988286239230257,0.09944220203272576,-0.5042604443804907,0.15292041463925066,0.909111664354187,0.8,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(0.016798590021622126,-0.2325994903990701,-0.0766000050337147,0.5966532121963541,0.052933416813421515,-0.1661010378060696,0.909111664354187,0.75,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(0.5403910062799865,-0.5625278455750569,-0.0766000050337147,0.5966532121963541,0.6101272780073337,-0.2668446543677508,0.909111664354187,0.73,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(-0.24499761810756004,-0.06763531281107672,-0.952028633990455,-0.8949798182945309,0.6101272780073337,-0.5522849012925116,-1.0999748867047898,0.72,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(-1.0303862424951067,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.7034003261350319,-1.0999748867047898,0.62,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(-0.15773221539783266,-0.5625278455750569,-0.0766000050337147,-0.3977688081309026,-1.0614543055744028,-0.45154128473083044,-1.0999748867047898,0.67,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(0.8021872144091686,1.4170422854808635,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.908497538851855,0.909111664354187,0.81,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(-1.553978658753471,-1.2223845559270303,-0.0766000050337147,-1.3921908284581592,-1.618648166768315,-0.972049970299513,-1.0999748867047898,0.63,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(-1.9030402695923805,-1.057420378339037,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.2406996144639928,-1.0999748867047898,0.69,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(0.6276564089897139,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.2872452367214912,0.909111664354187,0.8,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-2.175842027962227,-1.1903278061831537,-1.0999748867047898,0.43,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(0.889452617118896,0.9221497527168835,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,0.10254860635841155,0.909111664354187,0.8,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(-0.5067938262367422,-0.39756366798706344,-0.952028633990455,-0.3977688081309026,-1.618648166768315,-0.8041439426967131,0.909111664354187,0.73,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(-0.7685900343659244,-0.2325994903990701,-0.0766000050337147,0.09944220203272576,-1.0614543055744028,-0.6530285178541898,0.909111664354187,0.75,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(0.1913293954410769,0.09732886477691666,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.0989386267649508,0.909111664354187,0.71,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(-0.41952842352701486,-0.06763531281107672,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.08575800359813185,0.909111664354187,0.73,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(0.7149218116994412,0.5922213975408968,0.7988286239230257,0.5966532121963541,1.167321139201246,0.8581257305710129,0.909111664354187,0.83,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(0.1913293954410769,0.4272572199529034,-0.0766000050337147,-0.3977688081309026,-1.0614543055744028,0.32082644224205065,-1.0999748867047898,0.72,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(1.3257796306675331,1.7469706406568504,1.674257252879766,1.5910752325236108,1.724515000395158,1.462587429941097,0.909111664354187,0.94,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(0.5403910062799865,0.09732886477691666,1.674257252879766,0.5966532121963541,0.6101272780073337,0.23687342844065212,0.909111664354187,0.81,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(0.6276564089897139,-0.06763531281107672,1.674257252879766,0.09944220203272576,0.6101272780073337,0.10254860635841155,0.909111664354187,0.81,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(-0.41952842352701486,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.2332634488471884,0.909111664354187,0.75,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(0.8021872144091686,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.27045463396121155,0.909111664354187,0.79,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(-0.7685900343659244,-0.2325994903990701,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.6026567095733507,-1.0999748867047898,0.58,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(-1.0303862424951067,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-0.7873533399364304,-1.0999748867047898,0.59,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(-1.9030402695923805,-1.8822412662790038,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-2.1138109579985565,-1.0999748867047898,0.47,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(-0.07046681268810527,-1.5523129111030172,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.9626955331560363,-1.0999748867047898,0.49,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(-1.117651645204834,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.610092875190155,-1.0999748867047898,0.47,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(-1.553978658753471,-2.2121696214549904,-1.8274572629471952,-2.386612848785416,-2.7330358891561395,-2.1138109579985565,-1.0999748867047898,0.42,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(-1.2921824506242887,-1.3873487335150236,-1.8274572629471952,-1.3921908284581592,-1.618648166768315,-2.2649263828410766,-1.0999748867047898,0.57,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(-0.3322630208172874,-1.057420378339037,-0.0766000050337147,-0.8949798182945309,-0.5042604443804907,-0.9384687647789537,-1.0999748867047898,0.62,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(0.10406399273134952,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5522849012925116,0.909111664354187,0.74,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(0.7149218116994412,0.4272572199529034,0.7988286239230257,0.09944220203272576,0.6101272780073337,0.11933920911869125,0.909111664354187,0.73,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(-1.2049170479145614,-1.2223845559270303,-0.952028633990455,-0.3977688081309026,0.052933416813421515,-0.9048875592583913,0.909111664354187,0.64,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(-1.4667132560437435,-0.8924562007510436,-0.0766000050337147,0.09944220203272576,-1.0614543055744028,-0.7201909288953117,-1.0999748867047898,0.63,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(-1.7285094641729257,-1.5523129111030172,-0.952028633990455,-0.8949798182945309,-0.5042604443804907,-1.5597210669093144,-1.0999748867047898,0.59,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(0.016798590021622126,-0.2325994903990701,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8041439426967131,-1.0999748867047898,0.73,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(0.889452617118896,0.26229304236491,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.2872452367214912,0.909111664354187,0.79,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(-1.3794478533340162,-0.5625278455750569,-0.952028633990455,0.09944220203272576,0.052933416813421515,-1.1903278061831537,0.909111664354187,0.68,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(-0.24499761810756004,-0.39756366798706344,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.610092875190155,-1.0999748867047898,0.7,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187),(0.36586020086053167,-0.06763531281107672,-0.952028633990455,-1.3921908284581592,-2.175842027962227,-0.2668446543677508,-1.0999748867047898,0.81,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187),(0.4531256035702591,0.4272572199529034,-0.0766000050337147,0.5966532121963541,1.724515000395158,0.06896740083785215,0.909111664354187,0.85,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187),(1.5003104360869879,1.4170422854808635,0.7988286239230257,0.5966532121963541,0.052933416813421515,1.580121649263055,0.909111664354187,0.93,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187),(1.8493720469258974,1.2520781078928702,1.674257252879766,1.0938642223599824,1.724515000395158,1.0596129636943752,0.909111664354187,0.91,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187),(-0.9431208397853792,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-0.5042604443804907,-0.40116947644999135,-1.0999748867047898,0.69,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187),(-0.3322630208172874,-0.8924562007510436,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.5055230726051333,0.909111664354187,0.77,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187),(1.1512488252480781,1.087113930304877,0.7988286239230257,1.0938642223599824,-0.5042604443804907,0.9588693471326941,0.909111664354187,0.86,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187),(0.2785947981508043,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,1.167321139201246,-0.4347506819705508,0.909111664354187,0.74,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187),(-0.5067938262367422,-1.5523129111030172,-1.8274572629471952,-2.386612848785416,-1.0614543055744028,-1.9123237248751956,-1.0999748867047898,0.57,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187),(-1.6412440614631982,-2.5420979766309775,-1.8274572629471952,-1.3921908284581592,-1.618648166768315,-1.2071184089434333,-1.0999748867047898,0.51,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187),(-1.3794478533340162,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-0.5042604443804907,-0.9552593675392334,0.909111664354187,0.67,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187) +DROP TABLE IF EXISTS test.model; +create table test.model engine = Memory as select LinearRegressionState(0.1, 5, 1.0)(target, param1, param2, param3, param4, param5, param6, param7) as state from test.defaults; +with (select state from test.model) as model select evalMLMethod(model, predict1, predict2, predict3, predict4, predict5, predict6, predict7) from test.defaults; diff --git a/dbms/tests/queries/0_stateless/00953_ml_test.good_reference b/dbms/tests/queries/0_stateless/00953_ml_test.good_reference new file mode 100644 index 00000000000..ff9c61e403b --- /dev/null +++ b/dbms/tests/queries/0_stateless/00953_ml_test.good_reference @@ -0,0 +1,580 @@ +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +0.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 +1.0 diff --git a/dbms/tests/queries/0_stateless/00953_ml_test.reference b/dbms/tests/queries/0_stateless/00953_ml_test.reference new file mode 100644 index 00000000000..e50cbdd6732 --- /dev/null +++ b/dbms/tests/queries/0_stateless/00953_ml_test.reference @@ -0,0 +1,580 @@ +0.645206721297782 +0.645206721297782 +0.645206721297782 +0.645206721297782 +0.645206721297782 +0.645206721297782 +0.645206721297782 +0.645206721297782 +0.645206721297782 +0.645206721297782 +0.645206721297782 +0.645206721297782 +0.645206721297782 +0.645206721297782 +0.645206721297782 +0.645206721297782 +0.645206721297782 +0.645206721297782 +0.645206721297782 +0.645206721297782 +0.645206721297782 +0.645206721297782 +0.645206721297782 +0.645206721297782 +0.645206721297782 +0.645206721297782 +0.645206721297782 +0.645206721297782 +0.645206721297782 +0.6694443959224505 +0.6694443959224505 +0.6694443959224505 +0.6694443959224505 +0.6694443959224505 +0.6694443959224505 +0.6694443959224505 +0.6694443959224505 +0.6694443959224505 +0.6694443959224505 +0.6694443959224505 +0.6694443959224505 +0.6694443959224505 +0.6694443959224505 +0.6694443959224505 +0.6694443959224505 +0.6694443959224505 +0.6694443959224505 +0.6694443959224505 +0.6694443959224505 +0.6694443959224505 +0.6694443959224505 +0.6694443959224505 +0.6694443959224505 +0.6694443959224505 +0.6694443959224505 +0.6694443959224505 +0.6694443959224505 +0.6694443959224505 +0.4493293816391796 +0.4493293816391796 +0.4493293816391796 +0.4493293816391796 +0.4493293816391796 +0.4493293816391796 +0.4493293816391796 +0.4493293816391796 +0.4493293816391796 +0.4493293816391796 +0.4493293816391796 +0.4493293816391796 +0.4493293816391796 +0.4493293816391796 +0.4493293816391796 +0.4493293816391796 +0.4493293816391796 +0.4493293816391796 +0.4493293816391796 +0.4493293816391796 +0.4493293816391796 +0.4493293816391796 +0.4493293816391796 +0.4493293816391796 +0.4493293816391796 +0.4493293816391796 +0.4493293816391796 +0.4493293816391796 +0.4493293816391796 +0.600720195229028 +0.600720195229028 +0.600720195229028 +0.600720195229028 +0.600720195229028 +0.600720195229028 +0.600720195229028 +0.600720195229028 +0.600720195229028 +0.600720195229028 +0.600720195229028 +0.600720195229028 +0.600720195229028 +0.600720195229028 +0.600720195229028 +0.600720195229028 +0.600720195229028 +0.600720195229028 +0.600720195229028 +0.600720195229028 +0.600720195229028 +0.600720195229028 +0.600720195229028 +0.600720195229028 +0.600720195229028 +0.600720195229028 +0.600720195229028 +0.600720195229028 +0.600720195229028 +0.6762784661885577 +0.6762784661885577 +0.6762784661885577 +0.6762784661885577 +0.6762784661885577 +0.6762784661885577 +0.6762784661885577 +0.6762784661885577 +0.6762784661885577 +0.6762784661885577 +0.6762784661885577 +0.6762784661885577 +0.6762784661885577 +0.6762784661885577 +0.6762784661885577 +0.6762784661885577 +0.6762784661885577 +0.6762784661885577 +0.6762784661885577 +0.6762784661885577 +0.6762784661885577 +0.6762784661885577 +0.6762784661885577 +0.6762784661885577 +0.6762784661885577 +0.6762784661885577 +0.6762784661885577 +0.6762784661885577 +0.6762784661885577 +0.559635760952823 +0.559635760952823 +0.559635760952823 +0.559635760952823 +0.559635760952823 +0.559635760952823 +0.559635760952823 +0.559635760952823 +0.559635760952823 +0.559635760952823 +0.559635760952823 +0.559635760952823 +0.559635760952823 +0.559635760952823 +0.559635760952823 +0.559635760952823 +0.559635760952823 +0.559635760952823 +0.559635760952823 +0.559635760952823 +0.559635760952823 +0.559635760952823 +0.559635760952823 +0.559635760952823 +0.559635760952823 +0.559635760952823 +0.559635760952823 +0.559635760952823 +0.559635760952823 +0.6353300559297663 +0.6353300559297663 +0.6353300559297663 +0.6353300559297663 +0.6353300559297663 +0.6353300559297663 +0.6353300559297663 +0.6353300559297663 +0.6353300559297663 +0.6353300559297663 +0.6353300559297663 +0.6353300559297663 +0.6353300559297663 +0.6353300559297663 +0.6353300559297663 +0.6353300559297663 +0.6353300559297663 +0.6353300559297663 +0.6353300559297663 +0.6353300559297663 +0.6353300559297663 +0.6353300559297663 +0.6353300559297663 +0.6353300559297663 +0.6353300559297663 +0.6353300559297663 +0.6353300559297663 +0.6353300559297663 +0.6353300559297663 +0.6635807616996307 +0.6635807616996307 +0.6635807616996307 +0.6635807616996307 +0.6635807616996307 +0.6635807616996307 +0.6635807616996307 +0.6635807616996307 +0.6635807616996307 +0.6635807616996307 +0.6635807616996307 +0.6635807616996307 +0.6635807616996307 +0.6635807616996307 +0.6635807616996307 +0.6635807616996307 +0.6635807616996307 +0.6635807616996307 +0.6635807616996307 +0.6635807616996307 +0.6635807616996307 +0.6635807616996307 +0.6635807616996307 +0.6635807616996307 +0.6635807616996307 +0.6635807616996307 +0.6635807616996307 +0.6635807616996307 +0.6635807616996307 +0.4615908676549731 +0.4615908676549731 +0.4615908676549731 +0.4615908676549731 +0.4615908676549731 +0.4615908676549731 +0.4615908676549731 +0.4615908676549731 +0.4615908676549731 +0.4615908676549731 +0.4615908676549731 +0.4615908676549731 +0.4615908676549731 +0.4615908676549731 +0.4615908676549731 +0.4615908676549731 +0.4615908676549731 +0.4615908676549731 +0.4615908676549731 +0.4615908676549731 +0.4615908676549731 +0.4615908676549731 +0.4615908676549731 +0.4615908676549731 +0.4615908676549731 +0.4615908676549731 +0.4615908676549731 +0.4615908676549731 +0.4615908676549731 +0.6148954951112843 +0.6148954951112843 +0.6148954951112843 +0.6148954951112843 +0.6148954951112843 +0.6148954951112843 +0.6148954951112843 +0.6148954951112843 +0.6148954951112843 +0.6148954951112843 +0.6148954951112843 +0.6148954951112843 +0.6148954951112843 +0.6148954951112843 +0.6148954951112843 +0.6148954951112843 +0.6148954951112843 +0.6148954951112843 +0.6148954951112843 +0.6148954951112843 +0.6148954951112843 +0.6148954951112843 +0.6148954951112843 +0.6148954951112843 +0.6148954951112843 +0.6148954951112843 +0.6148954951112843 +0.6148954951112843 +0.6148954951112843 +0.724525500316245 +0.724525500316245 +0.724525500316245 +0.724525500316245 +0.724525500316245 +0.724525500316245 +0.724525500316245 +0.724525500316245 +0.724525500316245 +0.724525500316245 +0.724525500316245 +0.724525500316245 +0.724525500316245 +0.724525500316245 +0.724525500316245 +0.724525500316245 +0.724525500316245 +0.724525500316245 +0.724525500316245 +0.724525500316245 +0.724525500316245 +0.724525500316245 +0.724525500316245 +0.724525500316245 +0.724525500316245 +0.724525500316245 +0.724525500316245 +0.724525500316245 +0.724525500316245 +0.6814712987389229 +0.6814712987389229 +0.6814712987389229 +0.6814712987389229 +0.6814712987389229 +0.6814712987389229 +0.6814712987389229 +0.6814712987389229 +0.6814712987389229 +0.6814712987389229 +0.6814712987389229 +0.6814712987389229 +0.6814712987389229 +0.6814712987389229 +0.6814712987389229 +0.6814712987389229 +0.6814712987389229 +0.6814712987389229 +0.6814712987389229 +0.6814712987389229 +0.6814712987389229 +0.6814712987389229 +0.6814712987389229 +0.6814712987389229 +0.6814712987389229 +0.6814712987389229 +0.6814712987389229 +0.6814712987389229 +0.6814712987389229 +0.39027824250652915 +0.39027824250652915 +0.39027824250652915 +0.39027824250652915 +0.39027824250652915 +0.39027824250652915 +0.39027824250652915 +0.39027824250652915 +0.39027824250652915 +0.39027824250652915 +0.39027824250652915 +0.39027824250652915 +0.39027824250652915 +0.39027824250652915 +0.39027824250652915 +0.39027824250652915 +0.39027824250652915 +0.39027824250652915 +0.39027824250652915 +0.39027824250652915 +0.39027824250652915 +0.39027824250652915 +0.39027824250652915 +0.39027824250652915 +0.39027824250652915 +0.39027824250652915 +0.39027824250652915 +0.39027824250652915 +0.39027824250652915 +0.5406362537321668 +0.5406362537321668 +0.5406362537321668 +0.5406362537321668 +0.5406362537321668 +0.5406362537321668 +0.5406362537321668 +0.5406362537321668 +0.5406362537321668 +0.5406362537321668 +0.5406362537321668 +0.5406362537321668 +0.5406362537321668 +0.5406362537321668 +0.5406362537321668 +0.5406362537321668 +0.5406362537321668 +0.5406362537321668 +0.5406362537321668 +0.5406362537321668 +0.5406362537321668 +0.5406362537321668 +0.5406362537321668 +0.5406362537321668 +0.5406362537321668 +0.5406362537321668 +0.5406362537321668 +0.5406362537321668 +0.5406362537321668 +0.6581480265671044 +0.6581480265671044 +0.6581480265671044 +0.6581480265671044 +0.6581480265671044 +0.6581480265671044 +0.6581480265671044 +0.6581480265671044 +0.6581480265671044 +0.6581480265671044 +0.6581480265671044 +0.6581480265671044 +0.6581480265671044 +0.6581480265671044 +0.6581480265671044 +0.6581480265671044 +0.6581480265671044 +0.6581480265671044 +0.6581480265671044 +0.6581480265671044 +0.6581480265671044 +0.6581480265671044 +0.6581480265671044 +0.6581480265671044 +0.6581480265671044 +0.6581480265671044 +0.6581480265671044 +0.6581480265671044 +0.6581480265671044 +0.604770630344337 +0.604770630344337 +0.604770630344337 +0.604770630344337 +0.604770630344337 +0.604770630344337 +0.604770630344337 +0.604770630344337 +0.604770630344337 +0.604770630344337 +0.604770630344337 +0.604770630344337 +0.604770630344337 +0.604770630344337 +0.604770630344337 +0.604770630344337 +0.604770630344337 +0.604770630344337 +0.604770630344337 +0.604770630344337 +0.604770630344337 +0.604770630344337 +0.604770630344337 +0.604770630344337 +0.604770630344337 +0.604770630344337 +0.604770630344337 +0.604770630344337 +0.604770630344337 +0.6124292530568871 +0.6124292530568871 +0.6124292530568871 +0.6124292530568871 +0.6124292530568871 +0.6124292530568871 +0.6124292530568871 +0.6124292530568871 +0.6124292530568871 +0.6124292530568871 +0.6124292530568871 +0.6124292530568871 +0.6124292530568871 +0.6124292530568871 +0.6124292530568871 +0.6124292530568871 +0.6124292530568871 +0.6124292530568871 +0.6124292530568871 +0.6124292530568871 +0.6124292530568871 +0.6124292530568871 +0.6124292530568871 +0.6124292530568871 +0.6124292530568871 +0.6124292530568871 +0.6124292530568871 +0.6124292530568871 +0.6124292530568871 +0.5652923919041697 +0.5652923919041697 +0.5652923919041697 +0.5652923919041697 +0.5652923919041697 +0.5652923919041697 +0.5652923919041697 +0.5652923919041697 +0.5652923919041697 +0.5652923919041697 +0.5652923919041697 +0.5652923919041697 +0.5652923919041697 +0.5652923919041697 +0.5652923919041697 +0.5652923919041697 +0.5652923919041697 +0.5652923919041697 +0.5652923919041697 +0.5652923919041697 +0.5652923919041697 +0.5652923919041697 +0.5652923919041697 +0.5652923919041697 +0.5652923919041697 +0.5652923919041697 +0.5652923919041697 +0.5652923919041697 +0.5652923919041697 +0.5347192073584655 +0.5347192073584655 +0.5347192073584655 +0.5347192073584655 +0.5347192073584655 +0.5347192073584655 +0.5347192073584655 +0.5347192073584655 +0.5347192073584655 +0.5347192073584655 +0.5347192073584655 +0.5347192073584655 +0.5347192073584655 +0.5347192073584655 +0.5347192073584655 +0.5347192073584655 +0.5347192073584655 +0.5347192073584655 +0.5347192073584655 +0.5347192073584655 +0.5347192073584655 +0.5347192073584655 +0.5347192073584655 +0.5347192073584655 +0.5347192073584655 +0.5347192073584655 +0.5347192073584655 +0.5347192073584655 +0.5347192073584655 +0.6777439840889651 +0.6777439840889651 +0.6777439840889651 +0.6777439840889651 +0.6777439840889651 +0.6777439840889651 +0.6777439840889651 +0.6777439840889651 +0.6777439840889651 +0.6777439840889651 +0.6777439840889651 +0.6777439840889651 +0.6777439840889651 +0.6777439840889651 +0.6777439840889651 +0.6777439840889651 +0.6777439840889651 +0.6777439840889651 +0.6777439840889651 +0.6777439840889651 +0.6777439840889651 +0.6777439840889651 +0.6777439840889651 +0.6777439840889651 +0.6777439840889651 +0.6777439840889651 +0.6777439840889651 +0.6777439840889651 +0.6777439840889651 diff --git a/dbms/tests/queries/0_stateless/00953_ml_test.rock_auc_reference b/dbms/tests/queries/0_stateless/00953_ml_test.rock_auc_reference new file mode 100644 index 00000000000..a760c5b44b6 --- /dev/null +++ b/dbms/tests/queries/0_stateless/00953_ml_test.rock_auc_reference @@ -0,0 +1 @@ +0.7692307692307693 diff --git a/dbms/tests/queries/0_stateless/00953_ml_test.sql b/dbms/tests/queries/0_stateless/00953_ml_test.sql new file mode 100644 index 00000000000..d807bd0a043 --- /dev/null +++ b/dbms/tests/queries/0_stateless/00953_ml_test.sql @@ -0,0 +1,25 @@ +CREATE DATABASE IF NOT EXISTS test; +DROP TABLE IF EXISTS test.defaults; +CREATE TABLE IF NOT EXISTS test.defaults +( + param1 Float64, + param2 Float64, + param3 Float64, + param4 Float64, + param5 Float64, + param6 Float64, + param7 Float64, + target Float64, + predict1 Float64, + predict2 Float64, + predict3 Float64, + predict4 Float64, + predict5 Float64, + predict6 Float64, + predict7 Float64 + +) ENGINE = Memory; +insert into test.defaults values (2.096042154435875,-1.430135166863733,0.552002055283785,5.530269265662427,-2.724119998880863,-2.727060497877947,-2.6521663150493935,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(2.156034808051058,-0.4519877395933891,0.34558837162895817,2.2798791370166707,-1.2600139205601857,-2.314726182739184,-0.9176776519268379,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(2.0227012823747095,0.7073993763424218,-2.526579837235766,2.8884210818462503,-0.04921172682949959,-0.9351603686160936,-0.5773308731642317,1.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(1.461704796035435,1.2400054513675245,1.3110456913590716,-1.22465515713176,-0.7935030458046264,-1.103533329941002,0.5919719712269023,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(2.3957050452186377,-1.9316918657725441,0.9190142057288935,7.155955775162267,-2.8869703029890026,-3.0234929608286194,-4.304748904849194,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(1.392556430407127,-1.7794168780763924,2.1181012869348086,-0.6814309766916051,2.00404915245683,-1.7928635680687615,-2.425109137822439,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(1.9685507597915972,0.8408759652866196,-1.2607782469598254,-1.5515619975922614,2.3915793036512913,-0.8003752729444923,0.3318055683772181,1.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.365215205131582,1.6421911754887804,-0.470904627839269,-2.195888125979813,0.9714278325597505,0.5976321868124256,1.1540464822511913,1.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.3351152167766934,0.9498577915117139,-0.879126536282473,-2.971335010973352,2.468544204807239,0.5553774318661323,1.093198284507689,1.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.03912510876000452,-1.3322341365102917,1.6434865408453003,2.7281117051531183,-2.719490284062717,-1.2856678156526198,-1.087994719221058,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.8110134301050786,0.10305735724313725,-0.019183566058287527,1.478933303100145,-0.8948542269544303,-0.7185915708657821,-0.5378349211144934,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.013571717295999042,-2.1401875522838942,1.5751388914372026,2.869365994906071,-2.263892397950471,-1.5905392928904198,-1.317250564711623,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(-1.3815235147212976,-0.9616053368120304,2.8150588272277965,0.14759793530998425,-1.620992799677878,0.20786388505596268,-0.9816032789320823,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(-0.11407654661743705,0.768404354463356,-0.3930175233254567,2.3015784648119375,-1.7211987426998967,0.45519975382978,-0.6156907430410832,1.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(1.8478239086918133,1.5409911767774376,1.6994582902088935,-0.941221552716078,-0.5161849474607861,-1.0836831033224825,-0.4295520072868204,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.05455524769902653,-0.44441732196125217,2.708301849219744,-4.119367835878758,1.145934474605499,-0.7195943706636994,0.790664128197853,1.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(2.1969604043817803,-0.32118839886233386,0.23529133982375638,2.0406253994414003,-0.9957550724767615,-2.2235912952793635,-0.8800043260355785,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(1.8220150519058342,-0.09416361439372012,-3.047770316012948,5.034883266354364,-2.0143105832194625,-1.5733009655638288,-0.0222530409439472,1.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.0161176246725091,2.6217682547175736,0.9626736958220774,-7.396443060155276,3.4854283180461727,1.4376798844052319,2.2403875697818205,1.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(1.5082554497694574,1.8467142393208946,1.6327843990728441,-3.2881109608057573,-0.4321005482505421,-1.0603588475156511,1.8575619836721444,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.42260650162006874,0.41155861800999316,0.7982889881884394,-0.7237985064171936,-0.8285415729659753,-0.5825003405465955,0.7630457046521066,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(2.4984953879098306,-1.1006932402217684,-0.4488170035755814,5.409789404959963,-2.734678167398622,-2.9680022720016557,-1.6313962465437406,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.9436912987053148,-1.9262688389287774,1.314850116820961,6.396062133529162,-2.842471758246596,-1.7716503301033386,-4.152218598373375,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(-0.16349909844947885,-2.1701452208414933,2.568526586668546,3.397671556920363,-0.8976577440476563,-0.7471631706579982,-4.256758308439956,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.43511790495037683,0.5111546228572755,1.5168239103908907,1.604718301244254,-2.095124808747114,-0.4602828633136912,-1.1177938053615741,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.5413156314344527,0.09335263935887883,0.5612958143676673,-3.7986008152463135,1.8342221950246018,-0.5809729319600001,1.6392301667689284,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(-1.4504814727811615,1.3493103008673883,-0.04616646907891209,1.3117933064479026,-0.7702114172619944,2.2759289480635956,-1.3306427086061552,1.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(-0.5130854076349335,0.6888754268554591,-0.24046616537106735,1.5838074220098308,-1.6445748079667983,0.6567869990109363,-0.10911343377083105,1.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(-0.24277413251186197,0.8473320183553533,0.13183067757383438,-1.285681114811781,0.8555624158828621,0.8394005656843551,-0.03496602415650052,1.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.8369385120882685,-1.341251823971342,0.9554668074045201,1.4270151216516322,1.3962946241553666,-0.7795883140931273,-3.1902671851058684,0.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(1.1583479751809334,0.517409603059198,-0.6999515579272186,2.051960782143681,-1.715430664432116,-0.9939038452652763,0.23845436310251533,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(-0.8595203894117056,1.586295759104766,3.24464432451852,1.7792981720712642,-3.5599729812558625,1.0339349200010899,-2.0761447233122485,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(0.2187879306043835,0.785516320747686,-0.2648586496544352,-2.8228486010789404,1.128464932373549,0.09723332542813223,1.7886949807027714,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(0.5027908312527922,1.299795068598311,-2.247265548686248,0.3568369726515874,0.3094133364610945,0.4849256444073516,0.9882861752504595,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(-2.323680245156419,1.74815453644885,1.3056727348077939,0.19720821301977268,-1.3307294071180997,2.961691552540972,-1.1567709696086979,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(-3.4660709804341914,3.0020058328582584,1.5532651665598032,1.5583662913164948,-1.817494404470051,5.014323195426371,-3.0261871799657434,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(-0.07263506966702105,-0.9786215483869296,1.9521065048378694,-0.5412416965904013,-0.7526123488568063,-0.9097656582671574,-0.11616596119861677,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(-1.1101210747955936,0.45690435659743034,1.0024061194024203,3.151090618784407,-3.1293373639055435,0.9063184859725469,-1.4156004860432896,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(3.126163478788228,-1.3873077921754309,-1.6696389941434133,2.6802469210649256,-0.681228435146825,-3.632607072537458,0.5151315701276392,0.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(0.35121315158298516,3.269898801839016,-0.3139240954702248,-3.3982176643392235,1.5943902174769407,1.665406096965063,0.9632634643458649,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(0.7468935350733565,2.1854201988656303,-1.5921771449650985,-1.9866930130946439,2.2487176483490816,1.088338402207399,0.5136328198882177,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(-0.8336689441755065,1.9918308776801352,2.2772332104920645,-4.087683288038629,-1.0325983001724792,0.8849166354769218,2.286910253692919,0.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(1.977801713559557,2.047290687529743,-1.892163531069095,0.023277725464046682,1.5086179535693676,-0.02241979904892156,-0.3153319898124409,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(0.0518424311627248,1.8501419588702324,0.8505610339256306,-6.405529783623052,2.0897521277071087,0.570135066692417,3.065661906503785,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(-3.467126967504096,3.5784474447980568,-1.593527155162049,6.595207715742785,-3.872578649012629,5.606447409075812,-3.4752544483201677,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(-0.49490773800501286,1.595739466407145,0.28740296306486357,-3.824557248992501,-0.005517967878073571,0.6713599863888331,3.0557952294935538,0.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(0.544193867668699,2.3262231384923844,2.750917624599606,-3.510182442015632,-1.2164244818530026,-0.12870618351275448,1.4921405703258661,0.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(1.51316443936564,-1.2270576118491379,-0.1511873771860477,5.077623200702221,-2.47128253159166,-2.071110370778194,-1.938581109844371,0.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(0.6113192323231587,1.6659128724858379,-0.26101192082957914,-4.320443128005412,1.661337251012963,0.17282617602319883,2.521205470842835,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(1.8198275616708954,1.3675138581932453,2.4905089781034886,-4.065703441137424,-0.7766613572278701,-1.9487231810266057,2.467596447852433,0.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(-1.9560716071750701,1.8563089934671257,-1.089371283526789,0.45302651466747346,0.5754832357256494,3.377112037476161,-1.1078516930515567,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(1.5014679676763512,1.46456490318075,3.74940663345368,-0.5180207050201467,-0.9701148885455172,-0.7947236401223874,-2.385191842660675,0.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(1.316853101423458,1.2491089344703392,2.3725759643289566,-2.9342129359065137,-0.4183076327718859,-1.155701368032073,0.9779293936805153,0.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(1.1849117352329739,1.3925299588445736,1.5695966090587818,-2.1311823024234813,-0.9067969456142655,-0.9769402104776256,1.3185069398877736,0.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(2.373297959341027,2.775778233617674,-3.987898143897202,4.1703153450619785,0.47977169869012415,0.5341339903160455,-1.8868105390404768,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(2.3482349418405724,-3.1159637626200545,1.322069359815815,2.229373710192031,0.1833587373393235,-3.6718200269675574,-2.167407144040195,0.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(0.8243075201573921,1.3348585688363546,-2.0351861522550223,0.44274131356886665,0.7582729504076067,0.4043388560881777,0.26562738440084566,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(0.9481666208581829,0.22905400262922648,-1.2625401200379784,0.01891167448317009,-0.23629041979461762,-0.8959552087654045,1.483311569076668,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(-0.06585868557878616,1.4576378617673251,0.7399321196221702,-5.557327993134892,2.0615711774643364,0.59937804443105,2.443312546568034,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(-0.5617223747915407,-0.536515447514492,-0.9957168928986968,4.77783798052823,-3.0250516363531137,0.04763704320310812,-0.8503674789558922,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(-3.34324723959496,4.3926424059948035,-0.0495291336313155,2.6333253919636106,-1.8973423593226126,5.962186949574377,-3.1074374428513205,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.49887278027307114,2.4772176483573447,0.8766144403424073,-4.412341348998718,-0.06544816902397033,0.17540887369438027,2.973618255958296,0.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(-0.7781653022461528,1.6160279900558963,2.9043194289987406,-1.6138303698874787,-0.3568046596220451,1.4348863906315135,-1.472812006839362,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(1.0193028644873694,1.6299059681175168,0.7720871381731178,-6.526365022144807,3.602358868389331,0.05735615709042067,1.942603137953855,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(1.126058179631438,-0.08021399823747422,0.1845945629753224,0.17818816509562224,-0.738333890554967,-1.3667460232410276,0.6101098938191294,0.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.696410860620625,-0.6276802386587743,2.4836900187897752,-2.0850016187629534,0.24626466623836807,-1.3510098287109322,-0.044478444238072345,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(-2.2180272120355253,2.4305553228334267,-1.5801744943687832,4.862275527923406,-2.2752200612907183,3.8805912201348205,-2.6384927064003305,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(1.7567743245952139,-0.34730069944053166,-0.8948025108160138,3.0380121675012406,-1.1828054695478198,-1.7157828402064659,-0.7250035618486275,0.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.8454701528107351,-1.4667747625694347,1.3994753234952881,0.14108982726971897,-1.4662061418653511,-2.2561833089066807,0.7712682192410636,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.9311255806838445,0.30138652549697587,0.38513967479058675,1.3739433638375038,-1.148015783327944,-0.8064976661502308,-0.6120628161659272,0.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(3.364212163278218,-0.5777774492998544,-2.0960237073085235,2.7292130504797565,0.3929841930243696,-2.9133895273811254,-0.5391544963326877,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(1.0464711573814256,0.6301410336103881,0.6168596799831255,-1.032929924340855,-1.2787522510385279,-1.28640822590547,1.7388375253169488,0.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(-1.422247332703442,1.3099920188712886,2.4073061721409297,2.1870630187898,-2.906653106438294,1.6982591159934275,-2.362573454685344,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(3.1695741682612937,-0.18516594373997697,-0.7713888778777602,3.1151308383183576,-3.0028825960507337,-3.641700075824226,1.1176723514330833,0.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(-1.0201468439854502,2.0949741514552933,0.6385052523919061,1.8831849732743258,-2.2046121941585293,1.961396504470046,-1.341031552473416,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.9381164870495406,0.7569235185409051,-0.04079716532568112,-1.0646216144008618,-2.1229314622801283,-1.4627720410887246,3.205645865534935,0.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.9437251365046566,0.2476269059695898,0.04785469653893282,-3.162644357415593,1.5437021067561914,-0.853674727031123,1.7551166151989124,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.7011087711254909,1.2035331930765993,-1.4398091375364501,-0.22767686518825167,0.8665559020317706,0.35056665369985957,0.3315069768001421,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.7691595700548932,0.23226979363339084,-0.7524159985119943,-2.273159847018095,1.2051808874023429,-0.6613989835734112,1.904431917138825,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(-0.9901267648253292,0.8314035869824183,0.9623028761759912,3.0463733919904152,-2.623962359372865,1.2107802811322752,-1.9252298613127752,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.5670331443146553,1.8504800423581038,-0.644940607788113,-2.7678230888952498,1.5881287762026992,0.6450884188501608,1.2333970014028715,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.7215290147887311,-0.8847639920373926,0.4904341287870997,1.0732294179644357,-0.08407257982238703,-1.0427528377077504,-1.0423316359603254,0.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(-3.0571866679643755,3.3801167219727093,0.7666061453475292,-1.4047601244502173,1.2542122493912302,5.360634400210411,-2.408846721295774,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(-1.14458899707407,0.806558148488993,0.9258314968497899,1.6039908714694096,-1.8099931519413055,1.3287669410436236,-1.2183570331221776,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.0029511283094880714,0.7392527584182871,2.271615106839793,-0.4594423088240106,-1.302932906147438,-0.024854290186172693,-0.6305929459060517,0.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(-1.0262556462492007,3.106727638660441,1.552666143363748,-3.579169866499337,-1.4623529808205205,1.7247030376250396,2.395785937012022,0.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.9439810230045693,-0.03450351562051179,-1.8489916117037675,1.627016506901843,-0.2551150847440704,-0.7340241866844871,0.46366450521689084,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(-0.8995507828338771,2.637194803741764,0.5281828736349332,-5.263580235229065,0.7097535677602926,1.7093409623873352,3.1199605290151666,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(2.2331543227352126,0.576960304218676,-0.676727171313593,1.0171538582152717,-2.82527488357647,-2.6461049785824264,2.6088913588467775,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(-1.884286499274555,1.7159327959050787,3.786765950812899,-6.121056390326268,2.333369727673255,2.6168319013890295,-0.5366786842960347,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(-1.1382122858746933,-0.14299633489223185,0.8327531435987057,1.298580815498469,-0.8627965605758569,0.988030584240615,-1.3967521076705827,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(-0.6303393796237344,4.358235812284331,2.280888586413079,-8.838648817770522,2.239906490938857,2.4513045936352977,2.990325780977093,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(2.4442835629793667,-1.5595422106625365,-0.14785351526730506,2.4592541040486275,-0.0735148069297793,-2.8435659780281113,-1.3676274520194718,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(1.4143700456566066,0.8204418264435885,0.967997405875176,0.42646086353492046,-1.564532879987763,-1.275739590687965,0.1318313864473809,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(1.993790451964731,1.3774074310286606,3.280200674941446,-1.341646747143973,-0.7045036833894341,-1.426903501445604,-1.2265179636048882,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(-0.25515995427833005,-0.4671088714062114,2.2153588526087598,2.313329282416284,-3.5569628024009674,-0.8261756134416534,-0.7263653091644615,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(1.6355961932522634,-1.0282770582100191,-3.2173580488490123,4.559935052970455,-1.1214958228117986,-1.7827022934914223,0.07193385989494827,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(0.3283277042612722,3.4105121001777348,3.2195651165101515,-5.324711721749864,-0.9682526335929017,0.5004787785615196,2.2337122442476227,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(0.754679079237366,1.2099552379791747,-0.4385913525503159,-3.1077997316498673,1.9318023043436465,0.10670563866580032,1.3334679355779948,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(2.0317090865947613,0.8572264240668982,2.4095086017705816,-4.663118509638804,0.16709538369449373,-2.261736697516116,2.4428573077545996,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(2.1693473062725674,0.28205162253200255,-1.9303762140352645,0.9887844009255294,0.9897729061853578,-1.3590499520050627,-0.010177228789967074,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(1.0801920463321826,-0.4298481415473505,-0.33436737741767897,0.8097326513818011,-1.310248231723286,-1.6559624358526785,1.164300884735815,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(-0.04021181298242671,0.22389963328779605,1.9968767300385086,-0.019382197954940554,-1.4497486951865157,-0.29417522140873087,-0.47838412801942587,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(1.1239921256001624,-0.8638540030084805,-1.0178241055718993,-2.2937149162466777,2.565762757868864,-1.2141062999841048,1.274422252538015,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(-0.7413970807889825,1.5875817859558181,0.8403835779082484,-0.06969468265303144,-2.0112826998053173,0.9991342650707755,0.5897487899339218,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(0.21012246579494498,0.7349291140125731,1.1564215797263593,3.067109745050948,-3.8072019508231905,-0.4458351151041659,-0.6775773369205058,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(-0.2786193776514114,0.8391330674680333,-0.4026891923466751,-1.3731305159290677,-0.8305074905865648,0.169874931175302,2.3132805058219574,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(-1.2328709703392624,2.7597725867233383,0.5684016239686696,-2.9566618506267175,-1.5157478752904878,1.7699608909022329,2.8392511093116637,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(0.6871398306249665,-1.4103987067510992,1.0274161223406697,-0.5072792317407046,0.16697719764934948,-1.5964973105562557,0.07247594534487489,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(0.988330670186111,-0.5258004908649867,0.857816493019688,2.905878095316476,-0.3238823556705246,-0.7203927872533037,-3.1935613280291166,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(2.4322721114721757,0.30561297616901784,-1.5190220731160726,1.3743262473426763,-0.37180525132367603,-2.018098080706224,0.6319351503875634,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(1.4632563423687737,0.5381126931941951,0.9013515836533991,-0.4868930388692965,-0.8036249563776104,-1.424272458154115,0.4989428610329456,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(0.9759142028783296,0.0963990665555634,1.080300923613975,-3.059378549550568,1.7637552314639664,-0.8307617709909302,0.5002521536297346,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(0.8451444217468322,2.675124983592143,1.8034394339920048,-6.24356070906137,-0.1404077934628427,-0.4290049368154296,4.083301092855288,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(1.7832957038087498,0.46583490546204087,-2.8377296298346213,1.7314321239250723,1.4637196588786066,-0.5551666584209051,-0.560342527910989,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(2.0305985048097615,-0.8136835491751737,-1.5375629006726204,0.23344540733313246,-0.38312070583511015,-2.6407899536879547,2.2682169302221693,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(-4.450198579702571,3.8044895601982978,1.340371422770127,3.236568823054465,-2.7997133244581374,6.476201660322862,-4.069014914211333,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(1.4825506606818901,1.8932394950918274,-1.6402434007292597,-0.6438070488741744,1.5377697938617518,0.2190653369274579,0.10746474982298349,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(-0.12865647469516983,-0.03277446362082159,0.3789672161429233,0.13234961251820676,0.10865846661989931,0.1899002744334014,-0.6210816810053859,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(-0.7483525163782037,1.911632146474509,1.0237857931937804,-5.939983118898138,0.18095426014013039,0.7464913363725915,4.2349290686151395,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(1.4639789336512659,-1.487762211307613,1.2333792712082898,-0.5819847984553231,1.367105196681563,-1.9311626412059815,-1.1352946822318226,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(-2.716437954263598,3.2172228184755456,2.486899575348391,-0.27826500422738343,-1.496858928573759,4.189036022930514,-2.271237075436395,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(2.0984679507408304,-0.39222671785000096,-0.00929742777138598,2.4355790415042984,-1.2773465142555198,-2.2069415614400536,-0.7601011284502681,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(-2.3851061122725956,1.2652524519794195,1.2056559497342312,0.2301402557556724,-0.13853039522345567,3.166739303466531,-2.143757701306856,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(-0.912501321700246,1.0668955351482894,0.031154669474161678,-0.2922639794504092,0.1586320914087691,1.5749108653175503,-0.4654455435433783,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(1.6897500753524755,-1.5877093887419145,-1.7611534048954183,2.033285149958932,-0.45562387935528914,-2.4572133028294783,0.9117001207364435,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(0.03279016425268144,-0.553487415980487,1.5178285275445653,-1.756383753660862,-1.6424327750282592,-1.3694706413196136,2.3514036487381236,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(0.58004120787043,-0.1972292963993476,-0.13424999439900343,0.0644658482737472,-0.5669375045425562,-0.8960436704764648,0.8194123344316495,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(0.3142690816498883,1.9522135610917537,1.3104586637571347,-3.120340694946515,-0.7990786213674381,0.031103936415356134,2.1367311835504337,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(1.2711769727288555,1.0981021590638618,-1.7957098361193409,0.11763102112672769,0.8889146120013874,-0.1919397644256007,0.4140737388483293,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(-0.2753034616688934,0.5396168159983519,-0.25856295996037804,-0.8784121825809064,0.6222845940416049,0.6514517789151233,0.268334498274877,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(-0.054143446852892296,-1.6609882776935554,1.6234667989235132,3.3387697001507917,-0.9389121245324956,-0.5846606129339186,-3.4424309279299794,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(0.26621832805226675,-0.18078638381031364,2.933879140489032,-0.46282747535339114,-1.7199780636897413,-1.01998740911614,-0.406866592293917,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(0.04897174356182843,-0.3676084862290635,0.9387028981245669,0.8918277660343057,-0.7366479777100163,-0.33317336104618817,-0.9185779389595495,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(-0.21696194123607038,0.21555874139491749,-0.005133162761840726,4.209335205163436,-2.985056254482762,0.1462920409430946,-1.4879483835912106,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(1.1919697926532478,-0.06899302259156948,1.011479220945279,-2.6782330940108325,1.4957262168280048,-1.167204400077594,0.5412644793623882,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(0.797384096830145,-2.8858544823493006,1.4613598752639518,4.082334904310998,-0.48025789276661146,-1.8693084187642843,-3.9155728821524383,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(0.8513327899828025,0.7458930410858058,-0.7732225705417501,-1.4870005874864665,0.6145060572057287,-0.45127579686900166,1.5047009176226747,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(1.2510116832256535,0.2754714151780169,-2.265757658761317,1.229877962757745,0.7099703142373317,-0.5550915813556282,0.20254867074113803,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(1.02808083853107,-0.040629553520089345,0.8900206816703727,-1.3480875179776237,1.3442347323117394,-0.7538223926536042,-0.6342339871101205,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(2.695776681946838,-0.8864088092399576,-0.0789578748776445,2.0458434092506015,-0.970225560557315,-3.0770089140411643,-0.3020299079680173,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(1.1631434432249037,0.2854532336635398,-2.390500707033707,1.7344940763151517,0.6923406830495642,-0.36218796498051203,-0.21341989806423345,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(-1.6503048195027281,0.5243299697796613,0.2251840345614935,3.781488078646145,-2.8118176812215054,1.6996229508611647,-1.7849702798837712,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(1.7841357579086083,1.4436543212940578,-4.6726465448085035,6.434459937635292,-0.5846417872195009,0.2849453543668835,-2.0775372719522043,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(1.0822211355799545,0.9994266546847871,1.0465138567217758,2.0558098640968043,-2.639498177967953,-0.8840583888113261,-0.6825001012379466,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(0.848338734345929,-1.4745072026687287,0.37318698837288045,6.0929889409953235,-2.860229206267653,-1.4979288865033067,-3.1150236297626157,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(-1.2995339588833392,1.2407288550263273,2.640609187687466,-5.723460643589443,2.7512517947788786,1.946472506752308,-0.012081582228990029,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.9946726154312155,1.5401885333052683,3.32058260159335,-2.7680757902230586,-1.5330279328773837,-1.0093823869079046,0.8835422971914466,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(-1.1653969392564758,1.8477252075676,1.5154492658344962,-1.5050500138182235,-0.4399475400838969,1.8901940665945647,-0.3337717224590103,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(2.3410474945205646,0.9406941157522144,-0.31346932922698456,-0.5250458393014832,-0.5348245647633945,-1.952646624466109,1.3913067179555951,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(2.4376595283129783,0.12884481167739992,-0.7153536782631447,2.2980804863380264,-4.310130247410337,-3.425970247693062,3.0425484210457308,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(1.4242822094686205,-0.6739175649059916,-1.6207631956139514,0.9215275442056382,-0.2255601728743668,-1.7552758751749484,1.3017469600205345,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.5634426551277789,-1.5471077082024784,2.4165088824982957,-0.07551896335863666,0.7259879191915617,-1.19324872205996,-2.252728223170336,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.4438980206249631,3.2154267346236893,4.344033519574632,-7.789482359991429,0.27392642950548796,0.2323729828915657,2.58660101167189,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(-1.8266978944375327,2.764653149219914,0.44269893736952115,-1.448029334618218,-0.14573666828341858,3.209923834413559,-0.1568551995293309,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.49796742294949103,0.38611648047359515,0.947852631250811,1.921055938334201,-1.6442237026351973,-0.3807946252730803,-1.3171989797300596,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.2825028600006064,2.4079617426078688,1.3943677343584104,-5.068702752063692,0.3262485206507727,0.361686441352446,2.7646386524149182,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.22492901625026118,2.487212601897629,0.26524983577107275,-3.2366605539208284,-0.6423312073077014,0.4599935245385812,2.860371878492055,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(-0.04824496005648782,-0.41434421911898167,3.2271022590248886,-1.7830389885935827,-1.0845055278057123,-0.9148118678714859,0.10175737670186669,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(1.2494445038361341,-1.2605077919460772,-0.5919596470609547,2.65848661076861,-1.137208814184975,-1.89192004138945,-0.36297989181266965,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(1.9368152698009182,1.4026143232862036,2.654968484232417,-0.48052468015489747,-1.4353801796778478,-1.471326764204455,-0.8054078742203845,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(1.1144180116920606,1.9104663145213592,2.66246604484307,-5.074755087317627,-0.19811341338412658,-0.9123477120908239,2.440556004826056,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(-0.39453752442584944,-0.07366743472831994,1.9655786401195567,0.030511897442377315,-1.4873612106122647,-0.15769770005697964,-0.39586406801516416,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(-0.13705225566650903,-1.066340745793812,2.247663742284547,-2.2163700069902466,1.650571100968139,-0.34030614914782426,-1.086715918625918,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(1.257058965850754,-0.4841613444620174,0.11928070954945669,5.903325224092789,-3.2500639441872186,-1.4374965938334754,-2.6101536572472206,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(2.3338018044957725,-0.25783497499040453,-1.912097518989901,1.7897855693470501,0.6967346574866409,-1.8049321045768083,-0.3259566366550859,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(1.1597881133675316,0.18269125188689506,0.8486870733972146,0.9187771036928764,-1.3457464656817628,-1.263601970316707,-0.28154047796298953,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.3007389767680182,0.46484767063945054,-0.4886824605041771,-2.4201895447056203,1.3963201084273231,-0.007673513374869891,1.4417809458190534,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.24963563676970935,2.146378372977968,0.7902446346235774,-5.6573637067026645,1.9861496459522696,0.7047213943168629,2.3463141909563427,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.5836918839436678,1.3008666070056107,0.598629993661711,-0.10362396303302328,-1.5961048239125133,-0.3129853796094125,0.7514037918744904,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(-0.5229752172383009,0.24565782730994223,0.6095967557050924,0.688197893976115,-1.2881263450703708,0.3444699274985082,-0.15860735569730788,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.713159371718102,0.590874479989717,1.8556281124000433,-1.0879792739972094,-0.885690863908573,-0.8000805235607321,0.1725076813209897,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(2.8728203729298416,-0.8175386138217031,0.21256366729230014,1.4640205139258353,-1.175325702074738,-3.3996480522044146,0.24937101097686643,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.26386100804843426,-0.681937012093828,0.8719546263837685,0.6595807560020865,-1.0334232838287962,-0.9176670256552146,-0.13807803400017815,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.551767614016228,0.7109567026227261,-2.4802658442092,4.901977885732814,-3.066882464644468,-0.2414288804598717,0.13906877696470232,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(-0.9756434098282215,1.5177936333128244,1.0475803709656935,1.4474573922263465,-1.7751753583320031,1.6220531518629306,-1.4700570193599187,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.47763046455062,0.7743296610978223,-2.5287652392342297,0.7391934469677471,2.226326518880974,0.02544798983127873,-0.7676730030660792,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(-0.610702152006014,0.42910678217008225,3.0903157899137983,-5.390224952610268,1.3934337695947003,0.31851454704530224,1.054856662581439,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(3.0958554477794293,-1.4621148020869976,-0.5551243999064688,4.452619430630248,-1.379337013287443,-3.473330945653575,-1.677775172150648,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(3.362080810136683,-1.1400452123643188,0.6638526272830326,4.3778813924145785,-2.415943199028577,-3.8808958633487163,-1.7763856761782737,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(0.9515114782428997,2.5786148051977067,-1.4363545275647995,-0.6681291822406065,1.442317050314664,1.1465667088200706,-0.3269300577214689,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(-2.847938296751167,2.712497525564083,1.1348510423230198,-2.2420055180148903,1.4487652612218769,4.619765374911169,-1.766502892457076,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(-0.8552096265177644,-0.12433378867180744,0.06127441497123598,0.13124974598382613,0.21864608825429177,0.8516308714702762,-0.507455045151372,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(0.9413220120743674,-0.6671836871322345,1.1048795184969697,-0.251817589817712,-0.10041503067356516,-1.389149792100333,-0.26046842750699295,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.8515854524357955,-1.7456600581314028,-0.03925421048801203,1.5179974737998816,0.921332613668205,-2.223550296257367,-1.5207136810245006,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.8801336233511907,-0.4540198439328891,-0.07161754150108735,2.585913277189122,-2.060344360858858,-2.3122434286920814,-0.05721742141110542,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.1565930942796394,2.450186149747695,-0.36499519602591257,-2.6865164333840843,1.7817709621251276,0.5854922377125512,0.5256974003979489,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(2.285833909861166,0.28691651999098333,-1.099897735586095,0.9901853501724588,-0.6044670039367862,-2.050143304937507,0.8657679727222412,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(2.445814401245838,0.617451576980906,-3.6857076155185244,5.807368947766343,-0.7232837434835624,-1.0478351431241741,-1.7664121491248945,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.5724051967604904,1.043672733945267,-2.0466438205717346,1.4988175635419767,-0.022443970841448557,-0.5668460356271273,0.202681936318985,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.767326428923734,1.3282660371650246,0.6148708858259404,-5.476743033106995,0.10974913440714529,-1.9823302577814652,4.841465646867359,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.267326496231199,1.617557661552171,-0.15134447708394183,-3.488157628617435,0.05177221139688082,-0.9171772512777149,3.3253618318584692,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.0726650800289255,1.8463940170697746,-0.8554291334165234,0.2971150824858356,-0.9787305516015852,-0.15059128685897505,0.9251737194989748,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(0.6000678810964989,0.009464861555371407,0.32537504910087334,0.8785831725401735,-1.7720188770580114,-1.041503294055527,0.6853035439619124,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(-0.31903474892623174,-1.9161472026304565,3.249115661818257,-2.064008784693295,2.2511539463109678,-0.4181721655528234,-2.50536511723279,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(-0.27724311948888514,2.269876913502752,-1.0362588939415787,-0.4240851576553433,1.2557043908056547,2.115539216914462,-0.8397651617945024,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.6204471977858825,-0.7472757671052046,-0.44286591935948816,4.984083392550257,-3.765441418069141,-2.3924356302645933,-0.39967559303850064,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(2.4553901093631776,-1.401190635652457,-2.3384856201428965,2.7925686994223646,0.5230823350598678,-2.536900987998952,-0.31452413492174003,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(0.9908721193084293,0.33504947512645533,-0.15004041559882886,1.9914202896753672,-2.15972930497663,-1.1173470973110544,0.2876627916908172,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(-0.4268729371404919,0.0476100000649724,0.7234066075866292,0.9640920579044465,-0.8390128813007733,0.36362579291343516,-0.9290133023411948,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.7223130581227628,-1.5033618740143198,-1.0063691155313,3.7129996091186506,-0.18424839092347522,-1.9124490582287537,-1.9006188557753505,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.3863018949780674,-0.8118812038086545,-0.06824465995756457,2.3605677632827864,-1.9190940321241714,-2.074049594905443,0.10164582500649044,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.122137640295668,-0.7053791921624009,0.5001218626585733,2.202098650241533,-2.13406560335504,-1.846073420077453,-0.13442355611826817,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(-2.612008274681875,2.9273962705582894,-0.6255802858328701,4.821435572962468,-3.6682637014042756,4.076926276736118,-2.3267975850725797,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(0.14722476209464985,0.7169962280383986,1.30877628107509,0.2902560870390723,-0.5278822077282794,0.2523150652935394,-1.279708896388758,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(-0.7291366403013744,-0.5270029128179039,1.3646324243209347,0.22878411183186387,-0.6994553559333184,0.18645848628858827,-0.7164866293982425,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(2.3179603782898544,-1.8426294837876296,-2.0930634395627186,2.2618833621656558,0.4353521009755007,-2.8422362994637034,0.2651206458970319,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(0.16403922504683877,4.218117350808432,-1.464621892755238,0.4525429538867001,-1.1098371609469235,2.24664042651435,0.36048324675723487,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(-0.3213609724022466,-0.025854561408853893,2.639880414243348,-2.0411613386965612,-0.2566331978960029,-0.15905221997635197,-0.12531363631323988,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(-0.5267173926293351,-1.2061059553159688,1.0942381290703467,5.103189751648365,-3.4155924589635265,-0.4164954791259518,-2.502649328522689,0.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(-0.4855645347515395,0.23735171533067967,-0.5003708194846357,1.7804232308433463,-0.7957779583467628,0.6944973953194824,-0.7601873835159783,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(-2.3971333169627815,2.1868183332652453,3.3450712958825215,-4.719603701036977,1.4718198666990285,3.3830233233505638,-0.9827919370657879,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(2.11857678473749,-0.2366895620149072,1.2347293251374487,2.4546831756152896,-1.8039261811587064,-2.269262710480983,-1.4811644132395334,0.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(0.9259627347147839,-1.2059713052048235,1.6474462871354079,0.788474193584277,0.4987767692224161,-1.2387227304804325,-2.2836695458167746,0.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(-3.000029275289839,2.924265303236554,1.5287904697666397,1.8091750655228505,-2.173785091949717,4.4352889084307785,-2.7944599158598593,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(0.509417258150962,0.9345200865941814,-1.2065038607091274,-0.7231863787024786,0.529992343413479,0.12208026281018039,1.064059623279838,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(0.843381208944096,-0.7839641420793553,1.1047338725131475,3.200498581509832,-3.6879624786217464,-1.9826767010553936,-0.17031233402775825,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(0.6996453363330898,1.834603462699156,-1.9563488472181594,-0.8078842985019533,1.603757579443418,0.9023581741197092,0.4157203160510998,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(1.8780698333418597,1.5711743895099697,-1.1532301645027747,-0.1279147199475934,0.3940852348745265,-0.6780554823489231,0.47599660994228743,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(4.074460008738832,-0.7586132247609974,-0.40680550183518793,2.80044141991812,-1.3520950083731564,-4.299897567538348,-0.23018611363621466,0.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(2.537343474263246,-2.346504411277027,1.0696587867609815,-0.09139515915291577,2.6976348801496677,-2.9037343661704513,-2.358064375853471,0.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(0.13810538048698184,0.4972293743727757,0.5170017632088637,3.8074275771962216,-3.441529620481504,-0.2520767485969924,-1.1460977221077522,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(-0.3716927651804762,1.5264964546073356,1.4116615829468997,-3.2696400437607975,-0.44330241396466785,0.5126776429602927,1.8969558924443808,0.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(-3.914146075904356,2.642868730715806,0.756953442096455,4.602054020453453,-3.1534100284140263,5.342012379341791,-4.033424004180775,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(0.6610025539601961,0.47098027882213267,0.09948302448982482,-3.936612690667609,2.4394531934109507,-0.2612419251520717,1.4621079847055367,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(-0.7686849946406735,2.704509185058657,1.3450572364169955,-7.822928994397781,2.9044544260546163,1.9358105418972935,2.7734907448226678,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(1.080539638439189,-2.1322877957031263,1.6986178322913714,0.36371624049923845,1.429812500230177,-1.7326917232712606,-2.4425242014940247,0.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(-1.167900481192102,0.1355097193610142,2.9097040430835177,-3.6404520903908724,0.9713474861844931,0.8816977448790321,-0.15831403216669404,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(-0.45514503610371104,-1.9645298836180913,2.3714681761255285,2.487263886450227,-1.4334710076423254,-0.7560866446214036,-2.677795087997294,0.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(2.205533638434593,0.1522422005591213,-1.2695825588015412,2.5717611851063906,-2.15564597325238,-2.3135028542159386,1.0008109723209975,0.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(1.1514247059211036,-1.0644545346285557,0.889971896861668,-0.8027781017855179,0.612875597105246,-1.7103926464884456,-0.014562305063810954,0.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(0.9177035463916016,1.3689702950747875,-1.3645490052164024,0.12947308667161297,0.383804924036368,0.15022529478155294,0.3474568882561838,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(1.0510311481075103,1.6986541281639824,1.4298397013825055,-2.24828571804734,-0.6193865199766544,-0.5672340485010048,1.131261958671076,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(-0.10475037404319854,1.9826630391809927,-0.4359458701822585,-1.9789206321994306,-0.5553707561694275,0.7295103208665263,2.2600055064016873,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(-0.43499110833343724,1.5870101815511446,0.9402541543282176,-2.933159361296762,-0.5955365826478517,0.6100236545656817,2.1125115594475554,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(2.4357050136448253,-0.5731495595770033,0.16933618049977095,-1.7352638099045383,2.4501836994395925,-2.140306061138697,-0.24355599298923802,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(1.9152646709544332,-1.1044398743526131,0.7264309168930094,2.751047949593423,-1.2155360000324171,-2.376314205559085,-1.5965277293217528,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(1.563555126365538,1.5905399716363626,-2.054401768001512,0.12558226223380958,1.579243827915478,0.11405592777658333,-0.21982342334862204,1.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(-0.730455784283673,0.6917046084758414,-0.7228104495687078,3.170055958828353,-1.447442840589877,1.2822906006373609,-1.5715790666666658,1.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(0.5567147832410433,-0.38074277886588925,-0.7250043310190759,2.9890681820702665,-1.7854730460169494,-0.8300350245815701,-0.38466093931103296,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(1.160113601533908,-2.0739287822796264,0.8656089350937013,2.5598075614900306,-0.4549159561400836,-2.039598659196028,-2.035308932344324,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(1.7301212300757651,1.7905058319133835,2.4785558633754987,-3.285854075731725,-0.2969054302783658,-1.2196278928218516,0.9665388396475895,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(0.15809910063242794,2.086280383850715,0.4267158940755982,-5.777388598503115,2.932621582965904,1.0770137767265244,1.8492278105417443,1.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(0.4346732485474898,0.6310734941541358,-1.404853676310947,-1.1002807120165736,1.4475439430359827,0.2545978186733911,0.8147445978455613,1.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(0.7111994909007124,-1.2485377736456615,0.00888551426993378,-2.6270035371594207,1.5232308527755958,-1.511116569724326,1.8232379971332986,1.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(1.7009681274533355,-2.098511498004252,0.49402451683802484,0.28198081101179506,1.092044026606271,-2.5049127881573976,-0.7737045360739153,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(1.350857441471699,-0.9080776890873943,0.4192135312704207,1.0335209980632558,0.5496545069678738,-1.424954540304835,-1.4810527974238206,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(0.6110098767879673,-0.19648138768779044,0.6976256713944607,0.7330099435441839,-0.4509443081740856,-0.6919587079193924,-0.7985836940346585,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(-0.7120668607049034,1.9568572093714138,1.0113558871394959,1.03831694531311,-1.3192489094050812,1.7439853418610345,-1.6131748737045164,1.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(0.025810229759270387,-1.1821577183920273,1.3502904597295187,3.316741043641779,-2.023622604735853,-0.7820762681282083,-2.2180784244243403,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(0.4823313839367841,0.9550640446662372,0.7796517614669789,-6.113481580673545,3.141750466778539,0.037999576976416934,2.1678622639783702,1.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(0.3198057040263189,1.067353282335374,-0.03774758522041055,-4.276016524189581,2.3619524359005077,0.3465583522342412,1.734889684984254,1.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(1.3206279075878253,2.9104551041192077,2.29210751642639,-5.248625098223054,-0.558629284361523,-0.6422444653370927,2.973566459413637,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(0.2335520332662372,-1.3483862701781133,1.6523781388128378,2.032580021967608,-1.9769743403072197,-1.351134129026289,-1.0913704298839408,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(-0.006197780146330656,1.5659161747636117,0.47428711078179253,-4.163105473654435,0.7532395776393404,0.41101356739081774,2.5389845366598145,1.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(-1.653872981072018,2.150652366216212,-0.682391413932038,1.0683573143849745,0.1041132013079018,3.2579744909035644,-1.7333419946625157,1.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(1.1929822852229999,0.6893229432312034,3.666180819002058,-0.8739189672652259,-1.4699333333739455,-1.292656078547559,-1.1401278912126873,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(1.155136793407768,1.556608797804812,2.6765890234500116,-6.068904790037338,0.06903301027490838,-1.3072077729905347,3.3564000590548333,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(0.21045240367371898,2.426324089796932,2.0395576967297147,-5.872734043014707,-0.09982516278127862,0.12243072729230661,3.4253409716774006,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(3.17277330610435,-0.4559861433811748,-1.4534816279072529,5.475931755644249,-2.7552146063412866,-3.221196770695242,-0.8814034920122698,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(1.6588973963601246,0.8461887027217563,0.18477915861912242,-3.5310792828384088,0.25782571964298096,-1.7173208517757454,3.2150078520616185,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(0.17118349950674683,1.118995662564974,1.4568293787618913,-0.5051347078771523,-1.7022847156761762,-0.1348235263823884,0.47918217936316587,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(-0.22222924383517895,0.11857662096295907,0.07650096299472098,2.0379158249219897,-1.471446181869702,0.1853732522038508,-0.7926848379983182,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(1.3949446302922746,1.370416982034507,-0.3726578951573005,-1.507865895566473,-0.619512343610795,-1.0233127750108155,2.253197907579775,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(1.1892991131649973,0.2446002905843807,1.5298718807562723,-2.099232339908538,-0.5056025526011423,-1.5804405058815307,1.378631760774571,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(1.9397609220772734,0.14612060976419405,0.003327490192374327,1.4823264748097986,-2.108057107017595,-2.2375080799048814,0.8543685258649079,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(-1.9375716302148769,1.8574155817438662,2.006982221925343,-2.0459560007405906,0.6658052443469802,2.9620627786230567,-1.5001878399436688,1.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(-0.2402192482549249,0.8729678849935101,2.1191043260999765,-1.8209285767011751,0.0702401507261432,0.5135562190468611,-0.5577240325203157,1.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(2.797645624903333,-1.5347261778272303,-1.4584107801210373,6.541970409599133,-2.25967473302527,-3.1433214379816197,-2.1371760232834607,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(1.2101207627001906,0.8178658070050348,1.345409305335169,-1.9521840925844323,-0.8292096750094382,-1.3207710619636854,1.5018732200296,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(1.6843456669089063,0.48885992756272634,-2.6849559269116936,4.369671523773933,-1.4771168062402,-0.9821022416444716,-0.4805026737266491,1.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(-0.23784839921057732,1.3535111387210395,0.05320924751207967,-1.9541402009569646,-0.3500510709804364,0.5463348385111396,1.7919768604357116,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(0.13128543053550334,0.6798074445687711,-1.6368443198221256,4.528049001062067,-3.362666984877701,-0.02382357706983641,-0.014886019488387747,1.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(0.4538532345705868,-1.726862620300886,1.7759464630443889,0.9705528654666244,-0.49477289232990296,-1.4722744644269066,-1.4293619756392357,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(1.4801653855390309,-0.47453344733200986,-0.09260586995290043,2.687518390442803,-3.092103825000628,-2.3227047457368974,0.8704218574790192,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(0.5218708026806307,-0.06967317420230557,0.7596210580022738,1.4711668879037785,-2.2608212537809083,-1.0556984545567896,0.1697181766634217,1.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(1.4686426053930823,-0.6876980688572898,-2.318133723758386,4.0906358440061625,-2.2111071372497046,-1.888548462638197,0.6761113150287794,1.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(-0.4655020791006943,-0.18262886630424446,1.9618533997695677,0.8126903231715692,-1.989649844992524,-0.17976489249510838,-0.6676474866827617,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(2.6720786039475946,0.30664618627008156,-1.7819670224326658,3.342376634237586,-2.127744178113725,-2.492973506799871,0.6527115800200574,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(0.7709544863051466,2.089208572308133,1.43733785954422,-3.1347865929904026,-0.7427482316186719,-0.29003767369798433,1.9880762501233427,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(2.004914193301878,0.8836225844754194,-2.8167544354447296,3.730548925991903,-0.14698284122574812,-0.6606442717965159,-1.1677908246516493,1.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(2.178670695122552,-0.37343176507494813,1.6102782889058491,-0.289668173735893,-0.5685426730499268,-2.544466773299166,-0.14330590112211938,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(2.450240693081766,-1.7077791947369563,-0.29053907727783956,3.1577977578818204,-1.574125943917932,-3.3781022323795638,-0.35494151519927786,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(0.7949700874472329,-0.6895749747428475,0.5374981044761692,3.165455372090398,-1.3991901354081273,-1.017110351525864,-2.011720496675317,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(0.9997776221443948,2.602928645773437,-0.6342952955734563,-2.148426258044219,1.4364180609082342,0.8128055918648491,0.4823811597366997,1.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(-0.5142831732503337,0.39128528101053817,0.9008320554174565,2.720050611707023,-3.1508830104429366,0.18317686511736905,-0.7187511553625723,1.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(-0.24024843070289092,-1.3426586516159533,1.698263715427241,4.97158422740088,-3.607946860074412,-0.8589087656970434,-2.6384582242582013,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(2.0649229275070042,-0.8691362909724218,0.06127110963748894,-2.4577692790862034,1.3553513321670838,-2.5767544706205916,1.8244096384210655,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(0.0388578224017484,1.569409049304232,1.55168058988638,-2.7338899094060074,-0.4317685880775276,0.28142214179950714,1.2299760646928444,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(1.083150208364903,1.0544201332588858,0.4849275584677891,0.030545098979075733,-0.9479940248019967,-0.675804210647968,0.2250820171268385,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(1.321939824236789,-1.7325735166420875,-0.1953762072802312,5.922742281805113,-3.438389085025568,-2.409237434210855,-1.6126418088678278,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(0.08186040177412857,-2.5585139391025904,3.3632598057046548,-0.37100416034089057,1.3575022880583072,-1.1842671469006207,-3.156866442574128,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(0.6532751173456468,-0.1563829566175261,0.38904035718586505,-2.0827142213294705,-0.505080151941329,-1.3800157395745356,2.528797835185646,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(2.315159218931961,-0.09574244146296951,-2.870390868688257,5.331430959491889,-1.6278329123179232,-1.819930686484162,-0.8286246222285059,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(2.235231767737936,0.7854330832954342,-2.148601058467422,1.895492977094104,0.5666083244157072,-1.056258020890489,-0.5215948847904226,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(4.241292917178763,-0.9860709778639231,-2.0009845087092635,0.962148112338849,1.76426913823527,-3.885947965014016,0.1282356911817848,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(-1.1263292028928795,-2.4050273682272323,2.9554910083536323,1.7828090923807403,0.9076886004084566,0.3679450599509102,-4.839058422078569,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(-1.7101470672682688,2.847398191594129,-0.5856330427022973,2.8707227771069346,-2.014245686136327,3.3640164995655213,-1.8361445565243186,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(0.38581091755503416,0.5780440904400403,-0.5071088914742421,-0.6090146252730738,0.060807864136913636,-0.12211047185114299,0.8896074381060197,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(1.5231754402233766,1.9421603486454766,-1.7729788908428823,2.3753911110055963,-1.5997916313255445,-0.3262735124330241,0.2706188768556723,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(2.820843966643821,-0.10692047584327335,0.9321887238014344,1.719981242218561,-1.5089437086452422,-2.919276123151345,-0.6623159052278418,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(-0.6180585065606545,-1.7250090425434537,3.183283866457158,0.6566647784968032,-1.9066003341979854,-1.0063287837463553,-1.1432711661139228,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(0.8520873302590414,0.9591953810947647,0.12676127726500885,0.5343659255630722,-1.8092748172332644,-0.7540690279448913,0.9279444910129341,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(-0.31530621506647705,0.12176928364261552,-1.2806898307327894,7.142595241207153,-3.5977212186784424,0.5510238558258297,-2.725111194146174,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(0.3886220250322657,1.8576914505484492,-0.43244838707799194,-4.044760393601628,2.2839267628076234,0.8096845168000543,1.6330072957261046,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(0.6675726022935767,0.20087089318493057,0.6845200898058594,3.6937800329175112,-5.330865424937081,-1.706760651701588,0.9784018600546389,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(-0.6116081865842736,0.6341537797659369,2.8798713181168587,1.1828301568793216,-2.9571969765156374,0.24906758002449095,-1.2907026715079555,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(0.6989473726151247,1.2498504500564895,0.2060774042696093,1.1690938756831124,-1.5014992194769494,-0.14794637691692877,-0.2834799610847376,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(-1.5273671236385944,0.9999544767906874,2.7703496758203627,1.207722028899153,-2.501911705844986,1.5436946481674476,-1.9786310839177188,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(1.702511351487795,-0.34203109814603394,0.7835851548168504,-1.5405081514894055,0.2849694967382024,-2.0575090526779283,0.9992013412095553,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(0.9665214110949041,-0.19155552919216534,0.7199622529149727,2.9073996081407234,-1.9527120616051468,-1.1166708078512677,-1.5156463719764512,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(0.1972926334458771,0.28276647040138503,-0.5192444905278686,-2.5476955695233556,1.8593101847023514,0.12004744459504944,1.1846881329737942,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(1.0321665520706136,1.9966732155667404,-1.4686236794986778,2.3902186300815456,-4.092727086591983,-0.7734708607085561,2.4499981678087295,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(1.2698946255416441,-1.1605905587383079,0.4187489725358793,2.835484738320932,-0.68793046490086,-1.5864754446600542,-2.017976019601487,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(0.4416798285809602,0.24811827480851545,1.0654898348977437,-0.4024036574325009,-1.0692237349365254,-0.7179061516427682,0.48702102541566117,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(1.6907373915312665,0.5782488154633239,0.599945149500958,-0.2547283719058139,-1.1602651261549966,-1.7138182985715615,0.9289975810399699,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(-0.21388172717674148,0.3670796032199588,1.8010065450197448,-1.5292034217343784,-0.10056573944930569,0.13923292684787758,-0.17493465232059124,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(-0.8249165562810634,0.8118811935227044,2.3634010952575495,-8.883011395212582,2.455323134835944,0.3640943002357488,4.16121831002304,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(-1.6123614832674,1.0270743358787555,2.4191824925784884,2.264244528945494,-2.9165944742592664,1.7064826406612614,-2.3591040913743972,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(-0.6856967207299276,1.7525897024574661,-1.1579023328670028,2.2589448355407176,-1.2312457357134239,1.8006792346334546,-0.8430752755923367,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(-1.8165914912002683,0.8803866404425429,2.316672635369382,-1.1810808635080954,-0.7924349556466443,1.8423790039564922,-0.7807611895668487,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(-1.5010244046779506,0.34523810497714713,1.3435520505455572,2.1639508161221426,-1.970858397807827,1.4462679112274643,-1.9102916382971258,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(0.5635922598273722,1.4033442818530633,1.683062562422878,1.0596983259384716,-2.158976282461896,-0.1331177596503839,-0.9781682769599302,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(0.28304003232809394,0.7811221245610349,-1.3923039114076419,3.99712372860234,-3.032968329036988,-0.08346940774160802,-0.044461198603807706,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(2.173115613211947,-0.45623120871027734,2.175888858443627,2.470563591949725,-1.8629450889871788,-2.445235352837583,-2.2353945966210875,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(-2.202431357080454,1.7546984246056434,1.1591425658354584,3.296837897884164,-2.99390938476279,2.901907693620618,-2.5643861199437623,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(1.2507060234279137,2.247796821591938,1.6608145081255743,-4.7160328360136115,-0.29001991756211454,-0.8166791671531242,2.9931321130155855,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(0.15573258355460207,2.172215007412987,1.8398328672983983,-9.111886152079743,3.1988497003563268,0.5434197773241329,3.727484292533844,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(-0.8328725961197609,-0.6837726198347411,2.9609894373395536,0.8541802329628736,-3.0704598054272783,-0.5282371583328125,-0.3954644151370479,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(-0.2305590281166081,2.1714878997598683,1.7808987263571887,-9.091214440959869,4.142077261397787,1.2804508330843913,2.7234893852433366,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(0.8464950859920972,1.8457460443518234,-0.7052530209199774,-0.8099187003486551,-0.49123726501052833,0.00934840017523153,1.4156707278241676,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(-0.7264984103515051,1.58762223148286,1.2543531688970304,-4.576041107988799,2.0471164338092316,1.556043827297222,0.7698900485966396,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(0.6310968833126964,-1.1557887631194408,1.8551643762629424,-1.3835655412181143,1.9814966914722598,-0.8322607453940875,-1.7817987572702223,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(2.1199173655735954,1.0316065570986357,-0.7388254953223654,-1.5610525631124597,1.5291161750630256,-1.1331188201036435,0.6838798263486152,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(0.5793958654817044,1.1370197985890995,-0.42699818741119544,0.451226751321184,-1.1762866346999212,-0.17284061128496353,0.7719883664743177,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(2.8052991708512645,-1.1543441822283065,-0.3079753774879235,0.7547558056367234,-0.39720293791911077,-3.439804665164511,0.8189837917408398,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(1.4024940524681682,0.7830543837865398,-0.11283237135740953,-1.5985039318124916,-0.026048812102019037,-1.1984529193448816,1.7287177333060695,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(3.0147217767070127,-1.0200781629431939,-0.7724586754852318,-1.6645919990450377,1.9943933870089592,-3.191360642502209,1.3263216762617858,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(-0.13531722708660943,1.9535028451727992,-0.04964794910170134,-4.546755747571752,1.8947915970446751,1.1248070457112436,2.0824716923788533,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(0.5780057561867775,2.4389883284494083,-0.06177856070697829,-2.748621215287728,0.45812115038086476,0.6152223729044103,1.5886901010362529,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(1.0546518884657923,0.18234244286557466,0.11030325399538321,3.2191661811958934,-2.36593743964414,-1.0692768734441718,-0.976407733545978,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(1.2933529177327734,-0.30513242091723924,-0.5615862663372806,1.3659303219726464,-1.362414397386018,-1.6806085153310848,0.8272333759272421,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(1.2391823930807615,0.4859918391655791,-0.4928502195038118,3.3616731079156708,-4.091655429873027,-1.7086947303342366,1.1409546244149862,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(-1.5054439327223408,-1.8924109686046506,2.5786138973436095,3.887056714146377,-1.6860332497357198,0.5234956471939621,-4.2927091788856995,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(-1.3147049070042374,2.9550742125471636,2.0805292078567885,-9.458984787991394,2.8909817970255327,2.2781958951820305,3.6332132074095567,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(0.1283229732783333,-1.5808489621836723,0.8581958490255427,5.390836449848271,-2.2509658655011426,-0.782618186639205,-3.5335726851924387,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(1.3314464140423534,0.8129182143050286,-0.8520617594080788,-1.0575404326246254,0.7809407543778316,-0.7064459840496876,0.9995381008322716,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(2.880225665985992,-1.0411359815296204,0.0510449350726625,-0.3878704148669313,1.401121588230164,-2.981523988078325,-0.2104726020045955,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(1.1046212143302618,0.987236550938289,-0.42669185582239033,-4.241325872971698,3.3415739009279566,-0.08424468577629528,1.2092562055909368,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(-1.973789947376512,0.8223402130701964,1.304490015055944,-0.8651390659470903,0.41682754650717646,2.4517085988221443,-1.4055044396931808,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(0.06981536179516334,-1.2065227695226142,2.2774676130672953,-1.1447098015872619,-0.7121456855990037,-1.304068586802913,0.28777483307132834,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(1.9795069078477965,-1.4473444569218747,0.8422773780928017,0.6313697742033327,1.7025648211172815,-2.0075492615530264,-2.333059370251311,0.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(-2.0600652063829266,-0.6333837621853073,3.468536748603692,-0.8913322423271115,-1.757462156010717,0.812572213213716,-0.6022907633519164,0.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(-1.98791867951561,3.031826514239644,-0.7924161436687038,0.12654610966629276,0.7081579465881396,4.176833422654864,-1.6699406256082212,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(0.8426115606298852,1.521152762657554,-0.1337230146189129,-1.4434995314881074,-0.2896581375563225,-0.2428413848621396,1.4665671078648115,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(-0.7284609427171894,-0.0633581959686611,1.1837577791819778,1.4350302630784448,-1.685312280726362,0.3762055904421248,-0.9917669857292509,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(0.13284448420444384,0.48989059418620295,0.649707339140327,3.1534094899577343,-3.2386106987041243,-0.31590614582047116,-0.7870427657819528,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(1.2813990054292852,1.8372801264131764,-2.379643406798959,1.3652576471003457,0.8512744869758768,0.5316461788691897,-0.6156053305262073,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(2.2891125617289863,-1.034466590177339,-0.8528073168005216,0.25565750615528443,0.9498395616806752,-2.48113303573229,0.3410176709625573,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(1.1906881283588873,-1.056056540973113,1.3574824118581417,0.6476728621753428,-0.1322934876060734,-1.6819740111315091,-1.2235936957518294,0.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(-1.3905684814071666,1.2466198898609266,2.259663679830063,-4.14763740755883,1.900848972347196,2.0483451909922756,-0.4555035477919126,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(0.007915404964254469,0.9420317471279528,0.294832519263326,2.582719495108136,-2.3945080639778853,0.28592816588339703,-0.9237809797403697,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(0.583521877945629,0.5331277730352217,-0.48721239763332447,-0.9498752906318381,0.346744013775807,-0.30613068397450366,0.9852227565956533,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(0.3038572775603694,1.8199226286216352,1.7209044780887788,-5.871244361704007,0.03082808989632535,-0.3313693128329034,3.8557824350560352,0.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(-1.4668677560682444,0.615864357805121,1.7525182699336228,-0.8210346671163282,-0.06020757379664965,1.6749795990476146,-1.2205165325854055,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(0.6437634561464207,0.46869838369521777,0.2512633646181748,-4.172634394188566,1.8972887815402877,-0.5040107496571128,2.1281248265853847,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(-2.566685802269739,1.3703937592515176,0.5522319795313368,4.714571322966261,-3.304529843224266,3.1700807408713936,-3.0669517754857556,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(1.4321320759545988,-0.5852717998212875,0.9344530828549473,2.2230574005646426,-3.0763883080523486,-2.405005631784908,0.40557678200484926,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(0.9641855971738517,1.5212499636636303,0.6152159628327369,-0.6607640817743697,-1.6102751585503117,-0.6616239847898601,1.3104820483943997,0.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(1.7048725942936547,1.6561110071176048,-1.6410777840461575,-0.021542409537615766,0.8497272700517364,-0.27637230275554314,0.29379908986403824,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(2.3877637394253206,-1.260106166916444,0.24240366155067983,3.254511285225256,-0.3359126390530982,-2.495451370201776,-2.4430734577527575,0.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(-1.7159795394991253,2.058479403961047,-1.0298338285959132,3.8830429726396325,-1.9236847469944287,3.092667652752938,-2.2573319930263267,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(2.61157813457322,-2.4629468072718197,0.5947853311127764,2.611227042557338,1.956298392040809,-2.746393521796805,-3.94414512547543,0.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(2.100378156997694,-1.0254193606740454,-0.3383292598098695,3.2522179469555192,-0.9092591620666294,-2.3140923190362463,-1.4339917844306427,0.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(-1.5793051540109753,1.6188751709051976,1.3848844184755469,1.166034226400195,-1.1259010183836429,2.4684572651406573,-2.3025016844857564,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(-0.16989054765279876,3.48842017914546,1.9300555017851737,-4.960543036879973,-0.584002148725781,1.2038222628858277,2.568256118525951,0.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(1.3846175270079646,2.145798875875564,0.1748386720212266,-4.796962390806608,0.5073503830831803,-0.7852786914681317,3.731869923790979,0.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(2.463498091505543,-1.641948347672444,0.014419220996607973,1.2485427665891868,-0.4093101695125,-3.315069785949253,0.14698377443441846,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.3015458148717531,2.4084218001678828,-1.9377479084764957,0.1461762550285925,1.181541855937334,0.7614544555573661,-0.3175290393124959,1.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.1995047619542676,-0.5685997445105482,-0.7780001688368265,-0.4208529275293881,0.5408090529552546,-1.441434337645698,1.0491529750596622,1.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.2789267591912103,-0.24431600650961838,-1.7008831850097177,-0.3956028703382682,2.2778328150392717,-0.6617441978281935,-0.01943996576935536,1.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.4426854749839935,-0.4544872588795166,-1.5961072511292693,0.12966802768765306,1.393550473376669,-1.1771061322845136,0.352301270605195,1.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(0.3811254347865457,1.3090655871933126,-0.27688380534200907,-3.0070886914719375,1.064692283384284,0.222022515151732,1.8721838900322956,1.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.1193434289666437,-0.6252656232912621,0.23118248743666925,2.685581337005184,-2.153833997930418,-1.6998262419123031,-0.4037349176707249,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(0.929529577814512,-1.7024107022914883,1.2488247870677989,1.2738796125012244,-0.5345104518047759,-1.8796928677805893,-1.1427878473451383,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(0.8362075518180005,1.1085707711145794,0.9854067590709947,-1.314041820148795,-0.7016240360391046,-0.5921632413160102,0.8578333456580334,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(3.5781343752139643,-1.756334316490143,-1.8913637043295912,3.8207236620641587,0.5041362860876586,-3.5985748597254386,-1.4898228334981138,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(0.3438720049323608,-0.24833525627533626,-0.8346231392283516,-1.5319164096905173,0.7676105738102315,-0.5790077722354865,1.78082722778547,1.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(3.0647342782436895,-1.0260134932323655,-1.2844635442292494,4.455520074360008,-0.33555784108704956,-2.780046271993584,-2.251683378416552,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(0.1706511098490927,1.427297039001016,0.16198610469672814,-4.678308717576381,1.9758795045738022,0.4947574282507664,2.2002784569922085,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(-1.562622677878104,1.7307650405142323,0.30622820821123853,-2.7159606100756912,2.3010271547514884,2.9293712371855865,-0.7525506989141675,1.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.3230332705184404,0.43074369107629307,-1.012178677869002,0.3764842669438245,-0.08467152822680513,-0.9691680411489616,0.6840966010729281,1.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(-0.6935320192169789,0.7446618818491898,0.09665333347742111,2.668069679850536,-1.4079283621598315,1.2190489986881268,-1.877269359035067,1.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.6615988715176795,1.4283536020765286,1.1939007488960722,-0.8584576982487286,-0.9666534542260612,-1.1587443010384395,0.44873555048520886,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.3850989235975144,-1.321996217461353,0.6533355400578518,3.765014097672636,-1.0657673636987341,-1.7288501469488284,-2.7515588732367537,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.679404226498682,0.4488111266798771,-0.09194107232644777,-0.1276070545791313,-0.6321422212401715,-1.5847461579670379,0.9576005483141299,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(2.04659758707243,-0.09637025410588262,-0.5301580315997092,2.3882076811218886,-1.1488798805266265,-1.9448358030407187,-0.4760994417763218,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(0.9502778204515043,1.560900513420219,2.6139226644509987,-0.17703081525604314,-1.3385353345210982,-0.31964658388963124,-1.4084087880151692,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(-1.7064636980022851,0.7232269304349839,2.122895762364635,-0.16484613782968235,-0.5171650348762113,1.962539190063468,-1.877610385342741,1.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(-0.27650843111684753,0.8824040605554635,-0.30196780207451157,-2.686121134883907,-0.17986243753961562,0.1554027845787418,2.9180254329681845,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(0.4055828873228918,-1.686704469180161,2.267279261928881,1.4120459259316966,0.32553090572843124,-0.9591177085579479,-3.2406871412917724,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(2.7528205900707885,-0.7838213498913917,0.42720475600569097,2.4810550424721343,-2.2722544267653983,-3.448555825513464,0.07050855537470957,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.1680246800757323,-0.40872210452552404,-0.4508203946039193,1.8115932970624247,-1.3903370815714982,-1.5343584504031225,0.30070498273072843,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.641411139391031,0.13066169098555191,0.013403427494233067,1.5312226380139464,-1.797441178406297,-1.830627427150842,0.4303846195173422,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.955478907567246,-1.719506740185793,0.762082256889067,0.1866756780988265,-0.9744041434997593,-3.309776136185275,1.0986283866533104,1.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(2.029214776852436,-0.2878096697019167,0.4084705542378164,1.7382336286765805,-0.6833067762076729,-1.9810690593038442,-1.0883122722276921,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(-1.560341449711872,1.5663634023069921,1.0471848595431368,0.1098488111202763,-0.7390036919795584,2.3112166370786724,-1.236752105743788,1.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.2089307327631884,1.9964256833116285,1.226378416624192,-2.4725235681126247,-0.8107018052923085,0.30001515631040365,1.5070634835647967,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.9128041176239442,1.8895100577112083,2.2886808335130913,-3.820954170467079,-0.6052835544037938,-0.623305490142599,1.866033800845503,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(2.993453919875277,-0.901133069473183,-0.0373521979721787,4.2922014798199974,-1.4822374048552227,-3.057711957842002,-2.1409987015165632,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.6766898453496916,-0.5261764912138024,0.7312972156077737,3.9581515737988227,-3.6502190772987513,-1.4820841451981968,-0.7891414274310181,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.14295833912761002,1.6231233113707968,0.18467857172572733,-5.3244744678874545,2.795954007446923,0.8238138676166966,1.929063833460194,1.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(1.7984907565135961,-0.08748991514172744,-1.908421605424304,1.0997506504768602,0.0193869641026021,-1.6007691098789487,0.9508597268855666,1.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(1.4795447177170868,1.558265108527901,2.9519444855092285,-1.7082112440267474,-1.5242435982351923,-1.2321506790399888,0.17024643186890942,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(1.1397560857395845,0.9929628562316919,0.5750597254679413,-5.175405133250185,1.9970886299361146,-0.8051594629268625,2.6421930794939943,1.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(1.2740780719977765,1.1197184976428955,0.651490056121677,-4.4266113109917935,0.15736308604688132,-1.390854468713751,3.651477122782289,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(-1.0402991953119143,-2.06533833303297,3.758708846819417,3.6643483716116036,-1.9836502961873896,-0.15018640286882878,-4.728987719679379,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(1.388042546834122,0.6351311476333177,0.3087393130542635,-0.9747105355778285,-1.2058573277731863,-1.5810825745871568,1.9467994460089018,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(1.6408026773429794,1.4879283180814786,1.547058272073475,-1.3451802114196914,-1.1447992224936614,-1.2638772850029756,0.7853236881637284,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(2.0708542922701993,1.2711484350719897,1.4339591134115544,-0.16035643681145156,-1.184129814417774,-1.5691360483142587,-0.16642233400730944,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.8610958818630077,-1.8798623440397844,0.017309940244927047,1.5547116910354313,-1.2884818488253607,-2.214675539259715,0.5772827870563995,1.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.31017681214048487,-0.5669909849550294,1.9488706008510093,0.8765489312330507,-1.1971421401945954,-0.8532090545239664,-1.265147944962231,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.18497775560572882,0.4850151901864863,-0.6551824564727529,4.63982714028508,-3.2551402962092797,-0.09431469092158731,-1.0924304335485553,1.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(2.4669444008351666,1.859760910530527,-0.10218608993775513,-2.7065907109099916,-1.0087009804989429,-2.1344551850779685,3.6376693906822846,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.8238485766287365,-0.3526798936194202,1.5512566546145274,-0.783457568001856,-0.609118220503116,-1.3676361438381344,0.25775920670818486,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.4279886506498394,-1.318933410675522,1.786893864552341,2.319001466307592,-1.3636960802506595,-1.2080158126691145,-2.140891357760963,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(2.3245577743791705,-1.655861652943644,-0.5357071043474062,3.763999930078965,-0.8970789230750165,-2.833502507806386,-1.5072610448030646,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(1.285195766833195,1.6783115876604113,1.513434891521249,-2.2682980117838745,-0.45638868017239276,-0.7418730885738332,0.9488865767818059,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(1.3481586273438384,0.5174277441556074,0.8785338801961253,2.8147248395427154,-1.9625677135620347,-1.0292085195161238,-1.7895813340376878,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.6954065675726984,-1.3664621081516608,1.5476108546333234,2.180283590956567,-1.293895789561963,-1.5096513815855221,-1.7765071005868003,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.38827399019045394,-0.49792022753587073,1.0198058264078862,-1.5037569154998438,0.6543768219469193,-0.7437803404718291,0.2098285257737864,1.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(-0.3404731340559216,1.2427923266757308,-0.16300461061876503,0.2831612899496902,-0.34457609890571084,1.0720599628234369,-0.3514992450509097,1.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.3161748863138345,0.997351948912386,-1.0801295751777644,0.7571521026186296,0.0016508799060777068,0.48479285742246886,-0.13508160168753358,1.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.12681720829445697,0.11855714969664732,-0.9104184710851837,-1.085292209788002,-0.36232862899070417,-0.46951670408525054,2.366122573967455,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.7054632977954634,1.2572176853681154,0.860029635692299,-2.674401827682585,-0.6939897336698935,-0.6804162818791725,2.3309482151237217,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(1.07976657146411,-1.4207183531564556,2.0010660824353304,-3.194648928592429,3.2399872347286767,-1.3523756841739691,-1.1253482654531937,0.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(0.23610519315312728,-1.7449703241490164,1.6819741303788158,-0.10873160707117276,0.05416324589686572,-1.3123804509649377,-0.7907457427267194,0.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(3.0428333674190866,-1.0841060957114639,0.17243967022211515,-2.377637313997145,4.364469885879871,-2.4605659936454316,-1.2447560474503905,0.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(1.6701855712395437,0.2928301757559636,-1.5428673307968002,1.287330415870048,0.2727252075767579,-1.0692518489650513,-0.035616454995755165,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(-3.4800819804037824,2.977389692948332,1.8517753132543673,-0.19008504775532553,-0.7707879065175474,5.033813816903953,-2.5333706554638304,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(1.140202012142074,2.378634968895875,2.7556348176530534,-5.2834702463746215,-0.3652107320195507,-0.7350150171567257,2.5581641229084484,0.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(1.0981169615204438,-1.0119127261725325,2.2820770387227434,-1.9614013769844154,-0.5644666042090782,-2.284934214852611,1.078012639576424,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(0.8517786531323737,3.6302113892867838,-2.0029871207282746,0.2619852928861331,0.17390567848052974,1.6325105715744603,0.09423329683760107,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(1.4165800771742705,1.1149308340527142,-2.271387795418956,0.24518100275596663,1.6930308923123703,0.0011584811148082907,-0.08553747108993615,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(-2.0053022769813875,1.9109759825293087,2.773376480448724,-4.517202660362165,1.395196983263658,2.817448384076263,-0.39825181111140695,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(-0.5355188940690749,0.6018680914829695,0.7541924354853773,1.0775908586661713,-1.0907319838063005,0.7639886786882052,-1.0624390472003777,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(0.6595797552374167,-0.294809475541403,-0.9630206945978195,-1.5012079340321822,1.0098225390572804,-0.8157334681048121,1.6881542023624867,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(-1.720237261284876,0.11277874103206109,1.844572508290903,3.1533623636012984,-3.9104997386815334,0.9943897606151588,-1.3654061835218285,0.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(0.6922463463083346,-0.35073899252145635,1.9626145160108819,0.08179158347355334,-0.9530812260330679,-1.159859309462594,-0.7170911906049338,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(0.6413378935676259,0.1773899280357525,2.490383604140318,-3.8237997263323082,0.3863233217240887,-1.1052859279962846,1.309165949800489,0.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(-0.918763813284105,1.203162397621166,2.561321396321196,-0.3779626409007189,-2.283467449993765,0.8127359401206152,-0.31172201669053634,0.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(-0.41808616994891934,0.6297437830552794,-0.43519990266235187,0.8152590429422543,-0.4861773114380574,0.7939395653553468,-0.2700384949502228,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(0.0589503046935691,1.1096474018520084,0.8430477162065145,1.017463543138896,-1.8449195206430737,0.23001103979814566,-0.41668386521379497,0.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(0.7035305093965771,1.852386714172002,-0.8581310953858379,-2.7047073013316734,1.7544323773483619,0.5857189112040242,1.2179049628159166,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(-2.404521999474064,1.956856261585237,2.743662957828813,-3.763120660309916,1.2341598733468144,3.336518429323325,-1.0843551531070281,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(-1.5787514548491495,0.9043297397824689,0.3647966016141414,1.5615325941265177,-1.2949689138659002,1.9742065688305668,-1.2806827013749367,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(-1.0235078222978835,3.0475095656963602,1.4758089211909295,-8.183689162345186,2.311408931029436,2.0996841788530536,3.4655603211752783,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(1.4171153313833007,1.5601837547522388,-1.788047063738159,0.6536070698420184,0.03991294542935109,-0.23285562477977859,0.5515980511199634,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(2.5943012663247385,0.768939524488533,-4.7102725616072085,6.878524574598383,-0.5433735742893244,-0.8204559726610645,-2.151320262569758,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(2.095928691139254,-1.5364598955767699,-3.539396767334079,9.353427912472746,-5.3917492321240745,-3.143207068564544,0.002434375177712278,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(1.1733973608839687,-0.4779398907232715,-0.8222573364108066,0.5741388087269558,-0.8233349828146013,-1.6623616225589888,1.4089015715206914,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(2.5968720217016728,-1.561183647496414,-0.5368548320897575,4.563481344641381,-1.1935320996872132,-2.9643545782562257,-2.0430397264366764,0.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(2.714041736048137,0.026319558085377337,2.358390982988962,1.3832961478997392,-1.1938325736946396,-2.6210410239146587,-2.0630733441327145,0.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(1.0224268255603193,-0.3251567068096688,-0.3890143766789398,4.248774781294234,-1.7156272804262211,-0.9098747934249555,-2.0634504893495587,0.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(2.2466469802152655,-0.6104373122047839,0.013869093684521272,1.4174148121004353,-0.9299675669968678,-2.588397575094862,0.05056310478616921,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(-3.734598766339932,4.357711910775082,1.8063222011726097,0.5647484734204162,-1.2668904831697467,6.168350149687059,-3.383175902767071,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(-0.5075416946835463,2.826260938878084,1.6757291381825439,-7.312162195113464,0.5879313407461273,0.9973913776640214,4.309180001467237,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(1.46423411343145,-0.6005198090658379,0.9652261368365875,2.779552976547825,-2.60911189484479,-2.1363879310601983,-0.68726399922343,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(-2.1740091482509643,1.7158438812483352,1.207751628708825,2.1653318489129973,-1.9385559871567524,3.0041298293453407,-2.4842256171560244,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(-0.7576001841832798,-0.007594954223985706,1.0139997501431828,3.0324645799871592,-2.8287853572848425,0.352236350020044,-1.3663697410958096,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(0.22682005310878983,0.17882393778738837,0.6852239252823532,0.6996858648832547,-1.1005329373372745,-0.33694671576753815,-0.2923121947217511,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(1.6420808677485317,-1.567375548263394,1.3596455396410332,-3.18643779804509,2.6618463434153123,-2.2371667201597454,0.22533544015338114,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(-2.4762355913130216,2.18020271868241,1.3238107587214825,3.0782376854873186,-3.2670188241062785,3.2966864834016447,-2.424026089867702,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(0.4681164581671533,2.7802016066061546,2.4377514573974084,-3.504681185661089,-0.33038317365035264,0.576740491675048,0.6678482697206392,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(0.5911030428508862,-0.16060250554086664,-0.01306065642624099,3.934006680488941,-2.120769002361267,-0.6016009232082299,-1.8031712223115948,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(1.174745604954626,-0.4965423351198456,0.5943755851379704,-1.1052321260476299,0.2661649679666236,-1.5726083173913104,0.718004049467069,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(-0.7412751177208392,2.1327090440707304,1.194964453595523,-8.044195522762877,2.831742609518064,1.4456391207259371,3.4658128935875947,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(2.4728274623052195,-1.4446871431555646,-1.473077006061342,4.962183982602092,-0.877344961449386,-2.5959492339011856,-1.96852347020304,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(1.4964109038216507,0.20917901186206578,0.033859363997187364,-0.5696525703041693,-1.37076844681051,-1.950833571036897,2.1420942100235636,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(0.45583852223057186,0.9139217880820522,-0.503312639124806,0.5499114765531566,-1.2222692214056665,-0.20147776675726137,0.8599714517914723,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(-0.2737373806536043,1.27270826072556,0.4760375405877796,-1.801901825509861,-0.692130105318383,0.44709954001227903,1.6095875372621724,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(-1.347794187900541,0.2524553675565264,2.1003710485812177,-2.9225590783504978,1.4128230662455974,1.4304610174764638,-0.6822127662589081,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(0.5871361479153822,-0.8417339321943338,1.1995718501271524,0.8202523967506464,-2.301137318093607,-1.774115856891251,0.8098563835220876,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(-0.21508659002268615,1.569888963274912,0.03986115298828641,-3.9601982606129926,0.9380243205292723,0.7121236564430702,2.5119291735464375,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(2.7941481129839723,-1.0798806957539784,0.025240123668783254,2.633977218875101,1.0284753931360715,-2.3842856430416517,-3.002641820170753,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(0.21207162097481735,0.4647940297522595,0.46295798512172415,0.3232524421339397,-1.6159135710807149,-0.42882666161264194,0.7335086616487765,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(1.4929756391749678,-1.155157311134643,-3.4806846906158686,4.0693214517288965,0.35597074350303237,-1.2793994744342176,-0.6586972623541594,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(1.6854581171681562,0.1834002919426212,2.0365519468046482,3.858832265773903,-2.607252553631471,-1.5355541412174958,-3.1426914316979495,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(2.8327800893646486,-1.7343614197962078,-0.38324008318772385,4.214850202134405,-0.7612512185075357,-3.2089289677127355,-2.1597330449132066,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(0.07122882463582014,-0.6138287383249159,2.384026551347024,-1.7146604393110776,0.6628743724080095,-0.5031775744589227,-0.8780321112073121,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(0.5714623898190813,1.8499637809618559,-1.6528766898390757,0.7922648746756872,0.009123352945717644,0.7920546495067624,0.05588645257506697,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(-3.2633273539187027,1.911289368256512,2.065182047264482,1.922313389116063,-1.9358969584812344,4.156853974629493,-3.297822591979971,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(-1.0527594231003512,0.11046706857150712,-0.17034216295607751,2.002056902252602,-1.3909207669150798,0.9854200330466844,-0.729769914147927,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(1.9857432393597216,-0.797559664346102,-1.8628229075290526,0.7912416658605166,1.1189706285668513,-1.890957287869455,0.41557152949411214,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-2.504762737846811,2.1769977714122506,2.57992693306698,-1.8747939851770445,0.46865410489106774,3.7026137438952347,-2.2438143549852185,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-0.41886628561756134,1.997961493652824,0.45098865921149955,-3.9240951571422404,0.6720821012238447,1.1131211300973887,2.1496317763658626,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-1.269058850471455,0.9113128779485802,-0.987609614890711,5.17453944944951,-2.792635641455655,1.8633254768112497,-2.225434601190937,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(1.60221516530219,0.8573873954567277,-1.2532323321502234,1.4586670560212756,-1.2872866648841212,-1.184906097673008,0.88142213963169,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(0.664945717778535,1.7074410216455105,-0.9164942360480002,-1.7328352122931063,1.042439944629323,0.4681254075262177,1.034268339879112,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-1.0229129860675013,-2.780448032379326,3.2847626195180495,2.509568320419263,-0.8239377084416294,-0.47304522543584926,-3.9581559499963603,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(1.357349140742531,-2.30529006767782,0.09791220462993844,5.626021471718858,-1.5946347715827764,-2.1607839211751037,-3.248371527799422,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(0.19008566471204968,0.9075514438212983,-1.8650607875027787,-0.8680513536341087,0.7997443732584267,0.45238678503301627,1.526885288707088,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-2.9254711696053395,2.1750597750267042,2.1933277965486973,-2.4693963476817404,0.3973459599348179,3.9233999600808573,-1.2357640687177518,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(1.233619763358607,0.9913146965561134,2.3973693810536236,-0.8070564887140679,-1.45741017327986,-1.1664320360973062,-0.13201085846744465,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(0.3161303390254758,0.3276995534451512,-0.02889035651373595,-0.8230808482804979,-0.5319352491047409,-0.47967360079060634,1.36719581140463,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(0.5317287425894308,1.208735839267825,0.08407141955287045,-2.4813609730490715,-0.8888470073318796,-0.6122551141011588,3.060645109675252,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-0.07298769165290997,0.819808188036161,2.0384919882650516,-7.748399227191985,2.2435939891188377,-0.18719747936307643,3.6016374001334093,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-0.7901852621466418,0.5145825360308702,4.637957908386738,-6.150836801745065,1.3912229090534307,0.440132724867259,0.3252310211529108,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(1.831671718235779,0.5977438753380795,-2.321886357828979,2.9104235559256404,-1.017343884238508,-1.1877468146597532,0.22300620292739104,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-2.1539924701669846,1.883675370067507,-1.7680881855073274,5.807546701204832,-2.7646119804927913,3.473472133586789,-2.7200321903160463,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(1.756348176804372,1.7615764405819676,-1.5388289669836195,0.07080621692501461,0.6426698929723338,-0.3106612170666746,0.277797622658288,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-0.2487545187544351,2.609229589371483,1.8882144277890807,-6.154774232631951,-0.5638199006934052,0.43112941318589476,4.2027303973580565,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(0.10955533675333518,0.9087196837335013,0.1136664013383859,-4.1472494266956055,2.014924031822069,0.3431702042196298,1.8459002928252932,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-0.6652930532149404,1.197530864301426,0.9169919325624285,-5.961473613444594,1.8351066038331625,0.8272159997488158,2.950791256392912,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(2.9316838982943185,-0.6964392952831678,-1.1502529215081365,1.4921077726597665,-0.5780146627368032,-3.196356469849491,0.85907655235715,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(2.600077692763368,-1.2623740481307253,-0.8962595005959539,1.9679383389242255,1.2790953056015506,-2.4139441686510956,-1.6329167452667077,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(1.452791564760785,0.41146795445009166,0.14392806279219328,0.17108543131200796,-1.029600784845083,-1.469443131098191,0.8077470058618661,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(0.727098084005239,-2.5546937777149403,1.5105485872014457,-0.29443260630992396,1.1439390403078158,-1.9439707234539425,-1.1506513582879956,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(0.7021391905991415,2.4414499286754787,0.8074093066989305,-6.070712605446909,3.5191034192402006,0.9707334993431298,1.1288619039998729,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-0.9308026588402101,2.57928079368376,1.0748311675888704,-8.529095009719802,3.699706292413457,2.1444358957249268,2.9816820943899875,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(1.2360219692964298,-0.8921138259532037,1.324707218340896,-0.13529792443717042,0.03483533664127236,-1.7310071987282634,-0.5952741360978552,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(0.9580721326511403,1.515267173693862,0.9547831554732867,-3.792366629532976,0.14805240219415627,-0.6733000064089022,2.4871576141650023,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-0.11224442995910122,1.6882722404753472,1.7161782543665778,-2.9486619700579975,-0.6165883797519401,0.3909989063485372,1.4200766219929295,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.4004498564816448,-0.5483306586274586,0.6884992629346187,1.6860799533920177,-2.4028921057076675,-2.221265193101131,0.4912576499341499,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.239942383240145,-1.5480563981269437,1.8577874744757454,0.7272933808052509,-0.9344450764118416,-2.3269279460451013,-0.7435854860482998,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.4542570156828636,-0.27176912816457977,-0.3618604064197557,-1.502224358768631,0.9678737333818738,-1.5496348751441344,1.2748010290281975,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.1468076270806558,1.2322052468347184,-1.7602650358096363,0.7212280541208039,0.024643216826090497,-0.1814752483470614,0.561492706792226,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.5077003347535025,1.088513118264028,1.7551210104319521,-0.736441038595527,-1.3056362875092131,-1.3166156974158438,0.2511173359195177,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(0.288389962747996,0.36332653636764256,1.6656089747619136,-0.571105661353323,-1.1612868506911342,-0.5432082064452731,0.11792111797788773,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.9995296056005114,1.3529339664784819,-2.3981864910916855,2.9849134331502665,-0.7407438786500962,-0.7264517691858112,-0.3538463287395124,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(-0.08579858389687023,1.7161890418770884,-0.06656951353461293,-4.105281638118306,1.5285630478172285,0.8775192894752291,2.1152291309916,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(0.9661724849567914,-0.40445855460769375,-0.8984041426116092,-0.036985924898836356,-0.8750620577241204,-1.5780799558007883,2.1207161932972505,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(0.8699336332979304,0.6851162561092408,-0.9012433467548683,-1.8635864465365037,1.9301898676639888,-0.0891783038473156,0.689996751808305,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(-3.390371025284407,4.3362614916709905,1.1553623702701241,-0.5402753273558951,-0.7164467112290367,5.759960343500196,-2.098251841172708,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(2.3121549519106877,-0.49079106810872064,1.0874868101059274,1.8775100736563255,-1.832698844916588,-2.771227001345358,-0.5639729980991646,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(0.5317909834339799,-0.31402050735813103,1.5222379228128546,1.1028560181554226,-2.2574716049926096,-1.2763341078397625,-0.0682234152133977,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(2.3489372887473756,-1.902965890195,-1.1058115737668315,6.444396538850495,-1.3013307250524164,-2.59335014865392,-3.2826286389085126,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(0.10352282484992748,1.7763521706893264,-0.98957323888984,-3.092145229794725,2.3159326671997436,1.2326770331559804,1.1091309782040397,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(-0.6781201591090096,-1.2017056619726723,3.1386436103718722,-1.4826197651366986,0.7413994646513105,-0.061222556588136814,-1.8011807696190751,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.3088071867454587,-0.9058060170486686,-1.533795865471077,4.443254383671029,-2.2143075168348214,-1.767491483116837,-0.3779098725243084,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(0.42758387794542607,1.3840546035724883,-0.10889830402413547,-3.1754775666120802,1.2232929860961135,0.25803202005775294,1.7027079999027905,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(0.1914622420587,1.6808636178618053,0.5565573242166482,-1.954492290078305,-0.9510650933441838,0.14161140375081846,1.868522343287696,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(2.327521800555288,1.707072587638922,-0.3408892551572401,-0.7841366540150495,-0.30706125962166064,-1.403400095559777,1.139293148033613,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(-1.6870712174917015,1.691651631532742,-2.288473035077086,4.52043452758501,-1.8935449916089768,2.9237857364797977,-1.609566360393679,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(-1.733708401198054,1.3041639797022042,1.400544122440466,-1.9741481668869392,0.4617729940086308,2.3114245726840337,-0.5274602470044196,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.7575715367081157,0.3753135909060661,-1.2693308636208644,0.5371878918731451,0.5384575757585188,-1.153326220541941,0.20366235231148166,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.4883842771922242,1.7515504950397989,1.038220064787369,-1.3034051909539248,-1.3740421429605687,-1.0453541069418544,1.3316370102880164,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.816707826258376,0.9334850907564992,-2.7235167200741737,2.561614634752468,0.5749390983559122,-0.42892177674740073,-0.8151907044116287,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.922399180978037,-0.47398744746047616,-1.086455344591692,0.5421631590354696,-0.17489100087797138,-2.141675253309839,1.1382797565150389,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(-0.4370945240496815,0.7406706373308528,2.3817851052918986,-1.5970867983837052,-0.5383146950358882,0.43966344292078025,-0.39121212011259565,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.5227791882404937,0.032628064555142666,-2.7346852692959223,3.6243268586724393,-0.4338687119554254,-0.8963076772737661,-0.5620760681630759,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(0.6925555904243851,2.2660402104433004,0.571879255854077,-5.136520159556465,0.23388977994347782,-0.21095746484974373,3.839104184046647,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(-0.6170807446057736,1.1618050798356736,-0.3318054593493467,6.307458106404423,-4.152242368795466,1.164412152487124,-2.6433851880918566,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.09933841297654922,-1.3009113230097453,2.3763024813118814,4.843663490637228,-2.7335802864430874,-0.8152959702787319,-4.019613642468096,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(-0.29723257606972664,1.534048303390355,-0.9278630836202846,4.548220911132926,-2.2312916467625055,1.4265140750671224,-2.3032786031118535,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(-1.8723473627536515,0.9717287860436329,2.3847715433643724,0.7344463319711535,-1.8629044282929315,1.9783943683566731,-1.8140411081153947,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.3005647919287311,0.3806355736171525,-0.27869848922330487,-0.8799959881301632,0.3995051923334578,-0.09156717805815423,0.6758278798998893,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(-0.5955050165131914,1.450567042185088,-0.9897943065169226,2.737681953113439,-0.7663788673735875,1.811148094805718,-1.854983423784701,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(2.9669296357978334,-1.3324159367684048,-3.104836225416732,5.208190995197741,-0.8202049866634673,-2.9861699841871703,-0.7016133155919906,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(-1.228016828510732,1.1216551175944176,-0.8558209427875334,4.258437071067928,-2.7976936142573496,1.759131670682027,-1.4539872453038518,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(1.2339963699690584,-0.2804755708218589,1.4715087228456836,-2.9261144609808616,0.355595728180802,-1.8268629783014674,1.6411674193628243,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.9659087122503214,-0.2548687699578174,2.104950827672197,-6.076161419668977,2.9878426404779534,-1.2192738796045464,1.5970699410759703,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.22061418917082676,1.7175054727901158,-0.5033501522353456,-3.8353548758394256,2.331439472843757,0.9401634108615404,1.4604187484921587,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(1.309907365358922,-0.12990852843173584,1.0737239270579344,0.7337127225434502,-1.246715098799017,-1.6078875928365746,-0.25052374133607436,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(-0.36721164916342697,-1.7079119599701718,3.0068461711549523,0.14826986026046768,-0.8186880144087275,-0.9349454628893296,-1.5313812357768914,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(1.6398796287916704,-0.2454439388782933,-0.3454790010819664,2.792239227481451,0.15344573827886987,-1.0493634503221692,-2.4336157756640855,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.7847363960073463,0.7363916664271204,-1.0119432855225785,-1.9544812667283535,1.277543003992446,-0.2529346594821023,1.5342034566540081,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(1.2232936134800012,-1.163429305152226,1.8203348565681234,-1.2313360448785429,1.1074565407265085,-1.7093423514569264,-0.9078154994566392,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.7585110515783027,1.565377477710182,2.027749458360845,-5.369019478696252,-0.3380358319830341,-0.9500514254177758,3.588791253857626,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.7362390304804842,-1.2017843711210685,0.8926545968864157,1.2399265238688837,-0.050827310016290705,-1.198605392602416,-1.5046056364379843,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.6451221517395296,-2.0484424552178737,0.6171428263446541,6.422100778753815,-2.577636468051222,-1.4890401115179508,-3.785907231054817,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(-1.765086441069906,0.3886895405231462,2.731661900411207,-1.3069068417000809,-0.19766973479399452,1.6879242979289697,-1.449585901495793,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.18985291006333638,-1.0740273879437814,1.2843531782256652,2.9867201516109323,-2.853724333474166,-1.267483825267256,-0.9631441174041762,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.9871628788591412,1.8534178483912092,-1.2805384917990295,-1.092147064487189,1.0822665318842248,0.4024378429492361,0.6510218029229897,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.3717600489367091,0.7167856864650772,-0.7499821639105004,-2.1169534465406232,-0.870825637391141,-0.7319917041438911,3.6275089929559368,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.34781014325513526,-0.42631045215441477,2.276403265265107,-1.7872802807090558,0.6460091472975253,-0.6707279710261537,-0.7145197261034959,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.6978341324237667,0.44583514954616277,2.5487409237553997,-3.883754805256149,-0.5331862190361614,-1.3497349443383184,2.16910621644326,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(-0.42196177110466704,2.16561337972615,1.3262059312894516,-5.6286300261936,-0.08711234527451972,0.5828901807272211,3.841164934415239,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(-1.16389008844843,1.2429168032114994,1.1288227844364782,-0.8914746299219967,-0.12326393212364906,1.7336169885979524,-0.6957687675851021,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(-0.97426704102067,-0.06480324801411252,1.2488895732194991,1.6784228029603945,-2.2987446544566623,0.42970828101052566,-0.7140097535913854,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706) +DROP TABLE IF EXISTS test.model; +create table test.model engine = Memory as select LogisticRegressionState(400, 2, 2.0)(target, param1, param2, param3, param4, param5, param6, param7) as state from test.defaults; +with (select state from test.model) as model select evalMLMethod(model, predict1, predict2, predict3, predict4, predict5, predict6, predict7) from test.defaults; From e708983e9bed0efe260fe0ace365e1e9fbe64d73 Mon Sep 17 00:00:00 2001 From: Masha Date: Fri, 15 Feb 2019 23:38:13 +0000 Subject: [PATCH 018/709] Changed Linear Regression and test --- .../AggregateFunctionMLMethod.h | 6 +- .../0_stateless/00953_ml_test.reference | 1160 ++++++++--------- .../00953_ml_test.rock_auc_reference | 2 +- .../queries/0_stateless/00953_ml_test.sql | 2 +- 4 files changed, 585 insertions(+), 585 deletions(-) diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h index 286e19eee50..4394d508846 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h @@ -150,12 +150,12 @@ public: derivative += weights[i] * static_cast &>(*columns[i]).getData()[row_num];; } derivative *= target; - derivative = learning_rate * exp(derivative); + derivative = exp(derivative); - batch_gradient[weights.size()] += target / (derivative + 1);; + batch_gradient[weights.size()] += learning_rate * target / (derivative + 1);; for (size_t i = 0; i < weights.size(); ++i) { - batch_gradient[i] += target / (derivative + 1) * static_cast &>(*columns[i]).getData()[row_num]; + batch_gradient[i] += learning_rate * target / (derivative + 1) * static_cast &>(*columns[i]).getData()[row_num]; } } Float64 predict(const std::vector & predict_feature, const std::vector & weights, Float64 bias) const override diff --git a/dbms/tests/queries/0_stateless/00953_ml_test.reference b/dbms/tests/queries/0_stateless/00953_ml_test.reference index e50cbdd6732..993fa484869 100644 --- a/dbms/tests/queries/0_stateless/00953_ml_test.reference +++ b/dbms/tests/queries/0_stateless/00953_ml_test.reference @@ -1,580 +1,580 @@ -0.645206721297782 -0.645206721297782 -0.645206721297782 -0.645206721297782 -0.645206721297782 -0.645206721297782 -0.645206721297782 -0.645206721297782 -0.645206721297782 -0.645206721297782 -0.645206721297782 -0.645206721297782 -0.645206721297782 -0.645206721297782 -0.645206721297782 -0.645206721297782 -0.645206721297782 -0.645206721297782 -0.645206721297782 -0.645206721297782 -0.645206721297782 -0.645206721297782 -0.645206721297782 -0.645206721297782 -0.645206721297782 -0.645206721297782 -0.645206721297782 -0.645206721297782 -0.645206721297782 -0.6694443959224505 -0.6694443959224505 -0.6694443959224505 -0.6694443959224505 -0.6694443959224505 -0.6694443959224505 -0.6694443959224505 -0.6694443959224505 -0.6694443959224505 -0.6694443959224505 -0.6694443959224505 -0.6694443959224505 -0.6694443959224505 -0.6694443959224505 -0.6694443959224505 -0.6694443959224505 -0.6694443959224505 -0.6694443959224505 -0.6694443959224505 -0.6694443959224505 -0.6694443959224505 -0.6694443959224505 -0.6694443959224505 -0.6694443959224505 -0.6694443959224505 -0.6694443959224505 -0.6694443959224505 -0.6694443959224505 -0.6694443959224505 -0.4493293816391796 -0.4493293816391796 -0.4493293816391796 -0.4493293816391796 -0.4493293816391796 -0.4493293816391796 -0.4493293816391796 -0.4493293816391796 -0.4493293816391796 -0.4493293816391796 -0.4493293816391796 -0.4493293816391796 -0.4493293816391796 -0.4493293816391796 -0.4493293816391796 -0.4493293816391796 -0.4493293816391796 -0.4493293816391796 -0.4493293816391796 -0.4493293816391796 -0.4493293816391796 -0.4493293816391796 -0.4493293816391796 -0.4493293816391796 -0.4493293816391796 -0.4493293816391796 -0.4493293816391796 -0.4493293816391796 -0.4493293816391796 -0.600720195229028 -0.600720195229028 -0.600720195229028 -0.600720195229028 -0.600720195229028 -0.600720195229028 -0.600720195229028 -0.600720195229028 -0.600720195229028 -0.600720195229028 -0.600720195229028 -0.600720195229028 -0.600720195229028 -0.600720195229028 -0.600720195229028 -0.600720195229028 -0.600720195229028 -0.600720195229028 -0.600720195229028 -0.600720195229028 -0.600720195229028 -0.600720195229028 -0.600720195229028 -0.600720195229028 -0.600720195229028 -0.600720195229028 -0.600720195229028 -0.600720195229028 -0.600720195229028 -0.6762784661885577 -0.6762784661885577 -0.6762784661885577 -0.6762784661885577 -0.6762784661885577 -0.6762784661885577 -0.6762784661885577 -0.6762784661885577 -0.6762784661885577 -0.6762784661885577 -0.6762784661885577 -0.6762784661885577 -0.6762784661885577 -0.6762784661885577 -0.6762784661885577 -0.6762784661885577 -0.6762784661885577 -0.6762784661885577 -0.6762784661885577 -0.6762784661885577 -0.6762784661885577 -0.6762784661885577 -0.6762784661885577 -0.6762784661885577 -0.6762784661885577 -0.6762784661885577 -0.6762784661885577 -0.6762784661885577 -0.6762784661885577 -0.559635760952823 -0.559635760952823 -0.559635760952823 -0.559635760952823 -0.559635760952823 -0.559635760952823 -0.559635760952823 -0.559635760952823 -0.559635760952823 -0.559635760952823 -0.559635760952823 -0.559635760952823 -0.559635760952823 -0.559635760952823 -0.559635760952823 -0.559635760952823 -0.559635760952823 -0.559635760952823 -0.559635760952823 -0.559635760952823 -0.559635760952823 -0.559635760952823 -0.559635760952823 -0.559635760952823 -0.559635760952823 -0.559635760952823 -0.559635760952823 -0.559635760952823 -0.559635760952823 -0.6353300559297663 -0.6353300559297663 -0.6353300559297663 -0.6353300559297663 -0.6353300559297663 -0.6353300559297663 -0.6353300559297663 -0.6353300559297663 -0.6353300559297663 -0.6353300559297663 -0.6353300559297663 -0.6353300559297663 -0.6353300559297663 -0.6353300559297663 -0.6353300559297663 -0.6353300559297663 -0.6353300559297663 -0.6353300559297663 -0.6353300559297663 -0.6353300559297663 -0.6353300559297663 -0.6353300559297663 -0.6353300559297663 -0.6353300559297663 -0.6353300559297663 -0.6353300559297663 -0.6353300559297663 -0.6353300559297663 -0.6353300559297663 -0.6635807616996307 -0.6635807616996307 -0.6635807616996307 -0.6635807616996307 -0.6635807616996307 -0.6635807616996307 -0.6635807616996307 -0.6635807616996307 -0.6635807616996307 -0.6635807616996307 -0.6635807616996307 -0.6635807616996307 -0.6635807616996307 -0.6635807616996307 -0.6635807616996307 -0.6635807616996307 -0.6635807616996307 -0.6635807616996307 -0.6635807616996307 -0.6635807616996307 -0.6635807616996307 -0.6635807616996307 -0.6635807616996307 -0.6635807616996307 -0.6635807616996307 -0.6635807616996307 -0.6635807616996307 -0.6635807616996307 -0.6635807616996307 -0.4615908676549731 -0.4615908676549731 -0.4615908676549731 -0.4615908676549731 -0.4615908676549731 -0.4615908676549731 -0.4615908676549731 -0.4615908676549731 -0.4615908676549731 -0.4615908676549731 -0.4615908676549731 -0.4615908676549731 -0.4615908676549731 -0.4615908676549731 -0.4615908676549731 -0.4615908676549731 -0.4615908676549731 -0.4615908676549731 -0.4615908676549731 -0.4615908676549731 -0.4615908676549731 -0.4615908676549731 -0.4615908676549731 -0.4615908676549731 -0.4615908676549731 -0.4615908676549731 -0.4615908676549731 -0.4615908676549731 -0.4615908676549731 -0.6148954951112843 -0.6148954951112843 -0.6148954951112843 -0.6148954951112843 -0.6148954951112843 -0.6148954951112843 -0.6148954951112843 -0.6148954951112843 -0.6148954951112843 -0.6148954951112843 -0.6148954951112843 -0.6148954951112843 -0.6148954951112843 -0.6148954951112843 -0.6148954951112843 -0.6148954951112843 -0.6148954951112843 -0.6148954951112843 -0.6148954951112843 -0.6148954951112843 -0.6148954951112843 -0.6148954951112843 -0.6148954951112843 -0.6148954951112843 -0.6148954951112843 -0.6148954951112843 -0.6148954951112843 -0.6148954951112843 -0.6148954951112843 -0.724525500316245 -0.724525500316245 -0.724525500316245 -0.724525500316245 -0.724525500316245 -0.724525500316245 -0.724525500316245 -0.724525500316245 -0.724525500316245 -0.724525500316245 -0.724525500316245 -0.724525500316245 -0.724525500316245 -0.724525500316245 -0.724525500316245 -0.724525500316245 -0.724525500316245 -0.724525500316245 -0.724525500316245 -0.724525500316245 -0.724525500316245 -0.724525500316245 -0.724525500316245 -0.724525500316245 -0.724525500316245 -0.724525500316245 -0.724525500316245 -0.724525500316245 -0.724525500316245 -0.6814712987389229 -0.6814712987389229 -0.6814712987389229 -0.6814712987389229 -0.6814712987389229 -0.6814712987389229 -0.6814712987389229 -0.6814712987389229 -0.6814712987389229 -0.6814712987389229 -0.6814712987389229 -0.6814712987389229 -0.6814712987389229 -0.6814712987389229 -0.6814712987389229 -0.6814712987389229 -0.6814712987389229 -0.6814712987389229 -0.6814712987389229 -0.6814712987389229 -0.6814712987389229 -0.6814712987389229 -0.6814712987389229 -0.6814712987389229 -0.6814712987389229 -0.6814712987389229 -0.6814712987389229 -0.6814712987389229 -0.6814712987389229 -0.39027824250652915 -0.39027824250652915 -0.39027824250652915 -0.39027824250652915 -0.39027824250652915 -0.39027824250652915 -0.39027824250652915 -0.39027824250652915 -0.39027824250652915 -0.39027824250652915 -0.39027824250652915 -0.39027824250652915 -0.39027824250652915 -0.39027824250652915 -0.39027824250652915 -0.39027824250652915 -0.39027824250652915 -0.39027824250652915 -0.39027824250652915 -0.39027824250652915 -0.39027824250652915 -0.39027824250652915 -0.39027824250652915 -0.39027824250652915 -0.39027824250652915 -0.39027824250652915 -0.39027824250652915 -0.39027824250652915 -0.39027824250652915 -0.5406362537321668 -0.5406362537321668 -0.5406362537321668 -0.5406362537321668 -0.5406362537321668 -0.5406362537321668 -0.5406362537321668 -0.5406362537321668 -0.5406362537321668 -0.5406362537321668 -0.5406362537321668 -0.5406362537321668 -0.5406362537321668 -0.5406362537321668 -0.5406362537321668 -0.5406362537321668 -0.5406362537321668 -0.5406362537321668 -0.5406362537321668 -0.5406362537321668 -0.5406362537321668 -0.5406362537321668 -0.5406362537321668 -0.5406362537321668 -0.5406362537321668 -0.5406362537321668 -0.5406362537321668 -0.5406362537321668 -0.5406362537321668 -0.6581480265671044 -0.6581480265671044 -0.6581480265671044 -0.6581480265671044 -0.6581480265671044 -0.6581480265671044 -0.6581480265671044 -0.6581480265671044 -0.6581480265671044 -0.6581480265671044 -0.6581480265671044 -0.6581480265671044 -0.6581480265671044 -0.6581480265671044 -0.6581480265671044 -0.6581480265671044 -0.6581480265671044 -0.6581480265671044 -0.6581480265671044 -0.6581480265671044 -0.6581480265671044 -0.6581480265671044 -0.6581480265671044 -0.6581480265671044 -0.6581480265671044 -0.6581480265671044 -0.6581480265671044 -0.6581480265671044 -0.6581480265671044 -0.604770630344337 -0.604770630344337 -0.604770630344337 -0.604770630344337 -0.604770630344337 -0.604770630344337 -0.604770630344337 -0.604770630344337 -0.604770630344337 -0.604770630344337 -0.604770630344337 -0.604770630344337 -0.604770630344337 -0.604770630344337 -0.604770630344337 -0.604770630344337 -0.604770630344337 -0.604770630344337 -0.604770630344337 -0.604770630344337 -0.604770630344337 -0.604770630344337 -0.604770630344337 -0.604770630344337 -0.604770630344337 -0.604770630344337 -0.604770630344337 -0.604770630344337 -0.604770630344337 -0.6124292530568871 -0.6124292530568871 -0.6124292530568871 -0.6124292530568871 -0.6124292530568871 -0.6124292530568871 -0.6124292530568871 -0.6124292530568871 -0.6124292530568871 -0.6124292530568871 -0.6124292530568871 -0.6124292530568871 -0.6124292530568871 -0.6124292530568871 -0.6124292530568871 -0.6124292530568871 -0.6124292530568871 -0.6124292530568871 -0.6124292530568871 -0.6124292530568871 -0.6124292530568871 -0.6124292530568871 -0.6124292530568871 -0.6124292530568871 -0.6124292530568871 -0.6124292530568871 -0.6124292530568871 -0.6124292530568871 -0.6124292530568871 -0.5652923919041697 -0.5652923919041697 -0.5652923919041697 -0.5652923919041697 -0.5652923919041697 -0.5652923919041697 -0.5652923919041697 -0.5652923919041697 -0.5652923919041697 -0.5652923919041697 -0.5652923919041697 -0.5652923919041697 -0.5652923919041697 -0.5652923919041697 -0.5652923919041697 -0.5652923919041697 -0.5652923919041697 -0.5652923919041697 -0.5652923919041697 -0.5652923919041697 -0.5652923919041697 -0.5652923919041697 -0.5652923919041697 -0.5652923919041697 -0.5652923919041697 -0.5652923919041697 -0.5652923919041697 -0.5652923919041697 -0.5652923919041697 -0.5347192073584655 -0.5347192073584655 -0.5347192073584655 -0.5347192073584655 -0.5347192073584655 -0.5347192073584655 -0.5347192073584655 -0.5347192073584655 -0.5347192073584655 -0.5347192073584655 -0.5347192073584655 -0.5347192073584655 -0.5347192073584655 -0.5347192073584655 -0.5347192073584655 -0.5347192073584655 -0.5347192073584655 -0.5347192073584655 -0.5347192073584655 -0.5347192073584655 -0.5347192073584655 -0.5347192073584655 -0.5347192073584655 -0.5347192073584655 -0.5347192073584655 -0.5347192073584655 -0.5347192073584655 -0.5347192073584655 -0.5347192073584655 -0.6777439840889651 -0.6777439840889651 -0.6777439840889651 -0.6777439840889651 -0.6777439840889651 -0.6777439840889651 -0.6777439840889651 -0.6777439840889651 -0.6777439840889651 -0.6777439840889651 -0.6777439840889651 -0.6777439840889651 -0.6777439840889651 -0.6777439840889651 -0.6777439840889651 -0.6777439840889651 -0.6777439840889651 -0.6777439840889651 -0.6777439840889651 -0.6777439840889651 -0.6777439840889651 -0.6777439840889651 -0.6777439840889651 -0.6777439840889651 -0.6777439840889651 -0.6777439840889651 -0.6777439840889651 -0.6777439840889651 -0.6777439840889651 +0.6411012851604063 +0.6411012851604063 +0.6411012851604063 +0.6411012851604063 +0.6411012851604063 +0.6411012851604063 +0.6411012851604063 +0.6411012851604063 +0.6411012851604063 +0.6411012851604063 +0.6411012851604063 +0.6411012851604063 +0.6411012851604063 +0.6411012851604063 +0.6411012851604063 +0.6411012851604063 +0.6411012851604063 +0.6411012851604063 +0.6411012851604063 +0.6411012851604063 +0.6411012851604063 +0.6411012851604063 +0.6411012851604063 +0.6411012851604063 +0.6411012851604063 +0.6411012851604063 +0.6411012851604063 +0.6411012851604063 +0.6411012851604063 +0.6882314202562039 +0.6882314202562039 +0.6882314202562039 +0.6882314202562039 +0.6882314202562039 +0.6882314202562039 +0.6882314202562039 +0.6882314202562039 +0.6882314202562039 +0.6882314202562039 +0.6882314202562039 +0.6882314202562039 +0.6882314202562039 +0.6882314202562039 +0.6882314202562039 +0.6882314202562039 +0.6882314202562039 +0.6882314202562039 +0.6882314202562039 +0.6882314202562039 +0.6882314202562039 +0.6882314202562039 +0.6882314202562039 +0.6882314202562039 +0.6882314202562039 +0.6882314202562039 +0.6882314202562039 +0.6882314202562039 +0.6882314202562039 +0.4364572659523192 +0.4364572659523192 +0.4364572659523192 +0.4364572659523192 +0.4364572659523192 +0.4364572659523192 +0.4364572659523192 +0.4364572659523192 +0.4364572659523192 +0.4364572659523192 +0.4364572659523192 +0.4364572659523192 +0.4364572659523192 +0.4364572659523192 +0.4364572659523192 +0.4364572659523192 +0.4364572659523192 +0.4364572659523192 +0.4364572659523192 +0.4364572659523192 +0.4364572659523192 +0.4364572659523192 +0.4364572659523192 +0.4364572659523192 +0.4364572659523192 +0.4364572659523192 +0.4364572659523192 +0.4364572659523192 +0.4364572659523192 +0.6093243100848463 +0.6093243100848463 +0.6093243100848463 +0.6093243100848463 +0.6093243100848463 +0.6093243100848463 +0.6093243100848463 +0.6093243100848463 +0.6093243100848463 +0.6093243100848463 +0.6093243100848463 +0.6093243100848463 +0.6093243100848463 +0.6093243100848463 +0.6093243100848463 +0.6093243100848463 +0.6093243100848463 +0.6093243100848463 +0.6093243100848463 +0.6093243100848463 +0.6093243100848463 +0.6093243100848463 +0.6093243100848463 +0.6093243100848463 +0.6093243100848463 +0.6093243100848463 +0.6093243100848463 +0.6093243100848463 +0.6093243100848463 +0.6997646999628921 +0.6997646999628921 +0.6997646999628921 +0.6997646999628921 +0.6997646999628921 +0.6997646999628921 +0.6997646999628921 +0.6997646999628921 +0.6997646999628921 +0.6997646999628921 +0.6997646999628921 +0.6997646999628921 +0.6997646999628921 +0.6997646999628921 +0.6997646999628921 +0.6997646999628921 +0.6997646999628921 +0.6997646999628921 +0.6997646999628921 +0.6997646999628921 +0.6997646999628921 +0.6997646999628921 +0.6997646999628921 +0.6997646999628921 +0.6997646999628921 +0.6997646999628921 +0.6997646999628921 +0.6997646999628921 +0.6997646999628921 +0.5422581250564131 +0.5422581250564131 +0.5422581250564131 +0.5422581250564131 +0.5422581250564131 +0.5422581250564131 +0.5422581250564131 +0.5422581250564131 +0.5422581250564131 +0.5422581250564131 +0.5422581250564131 +0.5422581250564131 +0.5422581250564131 +0.5422581250564131 +0.5422581250564131 +0.5422581250564131 +0.5422581250564131 +0.5422581250564131 +0.5422581250564131 +0.5422581250564131 +0.5422581250564131 +0.5422581250564131 +0.5422581250564131 +0.5422581250564131 +0.5422581250564131 +0.5422581250564131 +0.5422581250564131 +0.5422581250564131 +0.5422581250564131 +0.6508734063103988 +0.6508734063103988 +0.6508734063103988 +0.6508734063103988 +0.6508734063103988 +0.6508734063103988 +0.6508734063103988 +0.6508734063103988 +0.6508734063103988 +0.6508734063103988 +0.6508734063103988 +0.6508734063103988 +0.6508734063103988 +0.6508734063103988 +0.6508734063103988 +0.6508734063103988 +0.6508734063103988 +0.6508734063103988 +0.6508734063103988 +0.6508734063103988 +0.6508734063103988 +0.6508734063103988 +0.6508734063103988 +0.6508734063103988 +0.6508734063103988 +0.6508734063103988 +0.6508734063103988 +0.6508734063103988 +0.6508734063103988 +0.6985513111559237 +0.6985513111559237 +0.6985513111559237 +0.6985513111559237 +0.6985513111559237 +0.6985513111559237 +0.6985513111559237 +0.6985513111559237 +0.6985513111559237 +0.6985513111559237 +0.6985513111559237 +0.6985513111559237 +0.6985513111559237 +0.6985513111559237 +0.6985513111559237 +0.6985513111559237 +0.6985513111559237 +0.6985513111559237 +0.6985513111559237 +0.6985513111559237 +0.6985513111559237 +0.6985513111559237 +0.6985513111559237 +0.6985513111559237 +0.6985513111559237 +0.6985513111559237 +0.6985513111559237 +0.6985513111559237 +0.6985513111559237 +0.45244725477787 +0.45244725477787 +0.45244725477787 +0.45244725477787 +0.45244725477787 +0.45244725477787 +0.45244725477787 +0.45244725477787 +0.45244725477787 +0.45244725477787 +0.45244725477787 +0.45244725477787 +0.45244725477787 +0.45244725477787 +0.45244725477787 +0.45244725477787 +0.45244725477787 +0.45244725477787 +0.45244725477787 +0.45244725477787 +0.45244725477787 +0.45244725477787 +0.45244725477787 +0.45244725477787 +0.45244725477787 +0.45244725477787 +0.45244725477787 +0.45244725477787 +0.45244725477787 +0.6261675112820656 +0.6261675112820656 +0.6261675112820656 +0.6261675112820656 +0.6261675112820656 +0.6261675112820656 +0.6261675112820656 +0.6261675112820656 +0.6261675112820656 +0.6261675112820656 +0.6261675112820656 +0.6261675112820656 +0.6261675112820656 +0.6261675112820656 +0.6261675112820656 +0.6261675112820656 +0.6261675112820656 +0.6261675112820656 +0.6261675112820656 +0.6261675112820656 +0.6261675112820656 +0.6261675112820656 +0.6261675112820656 +0.6261675112820656 +0.6261675112820656 +0.6261675112820656 +0.6261675112820656 +0.6261675112820656 +0.6261675112820656 +0.7461838992404664 +0.7461838992404664 +0.7461838992404664 +0.7461838992404664 +0.7461838992404664 +0.7461838992404664 +0.7461838992404664 +0.7461838992404664 +0.7461838992404664 +0.7461838992404664 +0.7461838992404664 +0.7461838992404664 +0.7461838992404664 +0.7461838992404664 +0.7461838992404664 +0.7461838992404664 +0.7461838992404664 +0.7461838992404664 +0.7461838992404664 +0.7461838992404664 +0.7461838992404664 +0.7461838992404664 +0.7461838992404664 +0.7461838992404664 +0.7461838992404664 +0.7461838992404664 +0.7461838992404664 +0.7461838992404664 +0.7461838992404664 +0.7018563514656831 +0.7018563514656831 +0.7018563514656831 +0.7018563514656831 +0.7018563514656831 +0.7018563514656831 +0.7018563514656831 +0.7018563514656831 +0.7018563514656831 +0.7018563514656831 +0.7018563514656831 +0.7018563514656831 +0.7018563514656831 +0.7018563514656831 +0.7018563514656831 +0.7018563514656831 +0.7018563514656831 +0.7018563514656831 +0.7018563514656831 +0.7018563514656831 +0.7018563514656831 +0.7018563514656831 +0.7018563514656831 +0.7018563514656831 +0.7018563514656831 +0.7018563514656831 +0.7018563514656831 +0.7018563514656831 +0.7018563514656831 +0.36013871027066185 +0.36013871027066185 +0.36013871027066185 +0.36013871027066185 +0.36013871027066185 +0.36013871027066185 +0.36013871027066185 +0.36013871027066185 +0.36013871027066185 +0.36013871027066185 +0.36013871027066185 +0.36013871027066185 +0.36013871027066185 +0.36013871027066185 +0.36013871027066185 +0.36013871027066185 +0.36013871027066185 +0.36013871027066185 +0.36013871027066185 +0.36013871027066185 +0.36013871027066185 +0.36013871027066185 +0.36013871027066185 +0.36013871027066185 +0.36013871027066185 +0.36013871027066185 +0.36013871027066185 +0.36013871027066185 +0.36013871027066185 +0.5238855727602139 +0.5238855727602139 +0.5238855727602139 +0.5238855727602139 +0.5238855727602139 +0.5238855727602139 +0.5238855727602139 +0.5238855727602139 +0.5238855727602139 +0.5238855727602139 +0.5238855727602139 +0.5238855727602139 +0.5238855727602139 +0.5238855727602139 +0.5238855727602139 +0.5238855727602139 +0.5238855727602139 +0.5238855727602139 +0.5238855727602139 +0.5238855727602139 +0.5238855727602139 +0.5238855727602139 +0.5238855727602139 +0.5238855727602139 +0.5238855727602139 +0.5238855727602139 +0.5238855727602139 +0.5238855727602139 +0.5238855727602139 +0.6804249705341022 +0.6804249705341022 +0.6804249705341022 +0.6804249705341022 +0.6804249705341022 +0.6804249705341022 +0.6804249705341022 +0.6804249705341022 +0.6804249705341022 +0.6804249705341022 +0.6804249705341022 +0.6804249705341022 +0.6804249705341022 +0.6804249705341022 +0.6804249705341022 +0.6804249705341022 +0.6804249705341022 +0.6804249705341022 +0.6804249705341022 +0.6804249705341022 +0.6804249705341022 +0.6804249705341022 +0.6804249705341022 +0.6804249705341022 +0.6804249705341022 +0.6804249705341022 +0.6804249705341022 +0.6804249705341022 +0.6804249705341022 +0.6050764770369429 +0.6050764770369429 +0.6050764770369429 +0.6050764770369429 +0.6050764770369429 +0.6050764770369429 +0.6050764770369429 +0.6050764770369429 +0.6050764770369429 +0.6050764770369429 +0.6050764770369429 +0.6050764770369429 +0.6050764770369429 +0.6050764770369429 +0.6050764770369429 +0.6050764770369429 +0.6050764770369429 +0.6050764770369429 +0.6050764770369429 +0.6050764770369429 +0.6050764770369429 +0.6050764770369429 +0.6050764770369429 +0.6050764770369429 +0.6050764770369429 +0.6050764770369429 +0.6050764770369429 +0.6050764770369429 +0.6050764770369429 +0.6440334745784803 +0.6440334745784803 +0.6440334745784803 +0.6440334745784803 +0.6440334745784803 +0.6440334745784803 +0.6440334745784803 +0.6440334745784803 +0.6440334745784803 +0.6440334745784803 +0.6440334745784803 +0.6440334745784803 +0.6440334745784803 +0.6440334745784803 +0.6440334745784803 +0.6440334745784803 +0.6440334745784803 +0.6440334745784803 +0.6440334745784803 +0.6440334745784803 +0.6440334745784803 +0.6440334745784803 +0.6440334745784803 +0.6440334745784803 +0.6440334745784803 +0.6440334745784803 +0.6440334745784803 +0.6440334745784803 +0.6440334745784803 +0.5716205957425191 +0.5716205957425191 +0.5716205957425191 +0.5716205957425191 +0.5716205957425191 +0.5716205957425191 +0.5716205957425191 +0.5716205957425191 +0.5716205957425191 +0.5716205957425191 +0.5716205957425191 +0.5716205957425191 +0.5716205957425191 +0.5716205957425191 +0.5716205957425191 +0.5716205957425191 +0.5716205957425191 +0.5716205957425191 +0.5716205957425191 +0.5716205957425191 +0.5716205957425191 +0.5716205957425191 +0.5716205957425191 +0.5716205957425191 +0.5716205957425191 +0.5716205957425191 +0.5716205957425191 +0.5716205957425191 +0.5716205957425191 +0.5311888217657855 +0.5311888217657855 +0.5311888217657855 +0.5311888217657855 +0.5311888217657855 +0.5311888217657855 +0.5311888217657855 +0.5311888217657855 +0.5311888217657855 +0.5311888217657855 +0.5311888217657855 +0.5311888217657855 +0.5311888217657855 +0.5311888217657855 +0.5311888217657855 +0.5311888217657855 +0.5311888217657855 +0.5311888217657855 +0.5311888217657855 +0.5311888217657855 +0.5311888217657855 +0.5311888217657855 +0.5311888217657855 +0.5311888217657855 +0.5311888217657855 +0.5311888217657855 +0.5311888217657855 +0.5311888217657855 +0.5311888217657855 +0.6986271931040996 +0.6986271931040996 +0.6986271931040996 +0.6986271931040996 +0.6986271931040996 +0.6986271931040996 +0.6986271931040996 +0.6986271931040996 +0.6986271931040996 +0.6986271931040996 +0.6986271931040996 +0.6986271931040996 +0.6986271931040996 +0.6986271931040996 +0.6986271931040996 +0.6986271931040996 +0.6986271931040996 +0.6986271931040996 +0.6986271931040996 +0.6986271931040996 +0.6986271931040996 +0.6986271931040996 +0.6986271931040996 +0.6986271931040996 +0.6986271931040996 +0.6986271931040996 +0.6986271931040996 +0.6986271931040996 +0.6986271931040996 diff --git a/dbms/tests/queries/0_stateless/00953_ml_test.rock_auc_reference b/dbms/tests/queries/0_stateless/00953_ml_test.rock_auc_reference index a760c5b44b6..edd49736ac8 100644 --- a/dbms/tests/queries/0_stateless/00953_ml_test.rock_auc_reference +++ b/dbms/tests/queries/0_stateless/00953_ml_test.rock_auc_reference @@ -1 +1 @@ -0.7692307692307693 +0.6703296703296704 diff --git a/dbms/tests/queries/0_stateless/00953_ml_test.sql b/dbms/tests/queries/0_stateless/00953_ml_test.sql index d807bd0a043..8da2a81fb5c 100644 --- a/dbms/tests/queries/0_stateless/00953_ml_test.sql +++ b/dbms/tests/queries/0_stateless/00953_ml_test.sql @@ -21,5 +21,5 @@ CREATE TABLE IF NOT EXISTS test.defaults ) ENGINE = Memory; insert into test.defaults values (2.096042154435875,-1.430135166863733,0.552002055283785,5.530269265662427,-2.724119998880863,-2.727060497877947,-2.6521663150493935,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(2.156034808051058,-0.4519877395933891,0.34558837162895817,2.2798791370166707,-1.2600139205601857,-2.314726182739184,-0.9176776519268379,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(2.0227012823747095,0.7073993763424218,-2.526579837235766,2.8884210818462503,-0.04921172682949959,-0.9351603686160936,-0.5773308731642317,1.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(1.461704796035435,1.2400054513675245,1.3110456913590716,-1.22465515713176,-0.7935030458046264,-1.103533329941002,0.5919719712269023,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(2.3957050452186377,-1.9316918657725441,0.9190142057288935,7.155955775162267,-2.8869703029890026,-3.0234929608286194,-4.304748904849194,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(1.392556430407127,-1.7794168780763924,2.1181012869348086,-0.6814309766916051,2.00404915245683,-1.7928635680687615,-2.425109137822439,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(1.9685507597915972,0.8408759652866196,-1.2607782469598254,-1.5515619975922614,2.3915793036512913,-0.8003752729444923,0.3318055683772181,1.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.365215205131582,1.6421911754887804,-0.470904627839269,-2.195888125979813,0.9714278325597505,0.5976321868124256,1.1540464822511913,1.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.3351152167766934,0.9498577915117139,-0.879126536282473,-2.971335010973352,2.468544204807239,0.5553774318661323,1.093198284507689,1.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.03912510876000452,-1.3322341365102917,1.6434865408453003,2.7281117051531183,-2.719490284062717,-1.2856678156526198,-1.087994719221058,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.8110134301050786,0.10305735724313725,-0.019183566058287527,1.478933303100145,-0.8948542269544303,-0.7185915708657821,-0.5378349211144934,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.013571717295999042,-2.1401875522838942,1.5751388914372026,2.869365994906071,-2.263892397950471,-1.5905392928904198,-1.317250564711623,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(-1.3815235147212976,-0.9616053368120304,2.8150588272277965,0.14759793530998425,-1.620992799677878,0.20786388505596268,-0.9816032789320823,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(-0.11407654661743705,0.768404354463356,-0.3930175233254567,2.3015784648119375,-1.7211987426998967,0.45519975382978,-0.6156907430410832,1.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(1.8478239086918133,1.5409911767774376,1.6994582902088935,-0.941221552716078,-0.5161849474607861,-1.0836831033224825,-0.4295520072868204,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.05455524769902653,-0.44441732196125217,2.708301849219744,-4.119367835878758,1.145934474605499,-0.7195943706636994,0.790664128197853,1.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(2.1969604043817803,-0.32118839886233386,0.23529133982375638,2.0406253994414003,-0.9957550724767615,-2.2235912952793635,-0.8800043260355785,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(1.8220150519058342,-0.09416361439372012,-3.047770316012948,5.034883266354364,-2.0143105832194625,-1.5733009655638288,-0.0222530409439472,1.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.0161176246725091,2.6217682547175736,0.9626736958220774,-7.396443060155276,3.4854283180461727,1.4376798844052319,2.2403875697818205,1.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(1.5082554497694574,1.8467142393208946,1.6327843990728441,-3.2881109608057573,-0.4321005482505421,-1.0603588475156511,1.8575619836721444,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.42260650162006874,0.41155861800999316,0.7982889881884394,-0.7237985064171936,-0.8285415729659753,-0.5825003405465955,0.7630457046521066,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(2.4984953879098306,-1.1006932402217684,-0.4488170035755814,5.409789404959963,-2.734678167398622,-2.9680022720016557,-1.6313962465437406,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.9436912987053148,-1.9262688389287774,1.314850116820961,6.396062133529162,-2.842471758246596,-1.7716503301033386,-4.152218598373375,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(-0.16349909844947885,-2.1701452208414933,2.568526586668546,3.397671556920363,-0.8976577440476563,-0.7471631706579982,-4.256758308439956,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.43511790495037683,0.5111546228572755,1.5168239103908907,1.604718301244254,-2.095124808747114,-0.4602828633136912,-1.1177938053615741,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.5413156314344527,0.09335263935887883,0.5612958143676673,-3.7986008152463135,1.8342221950246018,-0.5809729319600001,1.6392301667689284,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(-1.4504814727811615,1.3493103008673883,-0.04616646907891209,1.3117933064479026,-0.7702114172619944,2.2759289480635956,-1.3306427086061552,1.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(-0.5130854076349335,0.6888754268554591,-0.24046616537106735,1.5838074220098308,-1.6445748079667983,0.6567869990109363,-0.10911343377083105,1.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(-0.24277413251186197,0.8473320183553533,0.13183067757383438,-1.285681114811781,0.8555624158828621,0.8394005656843551,-0.03496602415650052,1.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.8369385120882685,-1.341251823971342,0.9554668074045201,1.4270151216516322,1.3962946241553666,-0.7795883140931273,-3.1902671851058684,0.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(1.1583479751809334,0.517409603059198,-0.6999515579272186,2.051960782143681,-1.715430664432116,-0.9939038452652763,0.23845436310251533,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(-0.8595203894117056,1.586295759104766,3.24464432451852,1.7792981720712642,-3.5599729812558625,1.0339349200010899,-2.0761447233122485,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(0.2187879306043835,0.785516320747686,-0.2648586496544352,-2.8228486010789404,1.128464932373549,0.09723332542813223,1.7886949807027714,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(0.5027908312527922,1.299795068598311,-2.247265548686248,0.3568369726515874,0.3094133364610945,0.4849256444073516,0.9882861752504595,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(-2.323680245156419,1.74815453644885,1.3056727348077939,0.19720821301977268,-1.3307294071180997,2.961691552540972,-1.1567709696086979,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(-3.4660709804341914,3.0020058328582584,1.5532651665598032,1.5583662913164948,-1.817494404470051,5.014323195426371,-3.0261871799657434,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(-0.07263506966702105,-0.9786215483869296,1.9521065048378694,-0.5412416965904013,-0.7526123488568063,-0.9097656582671574,-0.11616596119861677,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(-1.1101210747955936,0.45690435659743034,1.0024061194024203,3.151090618784407,-3.1293373639055435,0.9063184859725469,-1.4156004860432896,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(3.126163478788228,-1.3873077921754309,-1.6696389941434133,2.6802469210649256,-0.681228435146825,-3.632607072537458,0.5151315701276392,0.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(0.35121315158298516,3.269898801839016,-0.3139240954702248,-3.3982176643392235,1.5943902174769407,1.665406096965063,0.9632634643458649,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(0.7468935350733565,2.1854201988656303,-1.5921771449650985,-1.9866930130946439,2.2487176483490816,1.088338402207399,0.5136328198882177,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(-0.8336689441755065,1.9918308776801352,2.2772332104920645,-4.087683288038629,-1.0325983001724792,0.8849166354769218,2.286910253692919,0.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(1.977801713559557,2.047290687529743,-1.892163531069095,0.023277725464046682,1.5086179535693676,-0.02241979904892156,-0.3153319898124409,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(0.0518424311627248,1.8501419588702324,0.8505610339256306,-6.405529783623052,2.0897521277071087,0.570135066692417,3.065661906503785,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(-3.467126967504096,3.5784474447980568,-1.593527155162049,6.595207715742785,-3.872578649012629,5.606447409075812,-3.4752544483201677,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(-0.49490773800501286,1.595739466407145,0.28740296306486357,-3.824557248992501,-0.005517967878073571,0.6713599863888331,3.0557952294935538,0.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(0.544193867668699,2.3262231384923844,2.750917624599606,-3.510182442015632,-1.2164244818530026,-0.12870618351275448,1.4921405703258661,0.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(1.51316443936564,-1.2270576118491379,-0.1511873771860477,5.077623200702221,-2.47128253159166,-2.071110370778194,-1.938581109844371,0.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(0.6113192323231587,1.6659128724858379,-0.26101192082957914,-4.320443128005412,1.661337251012963,0.17282617602319883,2.521205470842835,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(1.8198275616708954,1.3675138581932453,2.4905089781034886,-4.065703441137424,-0.7766613572278701,-1.9487231810266057,2.467596447852433,0.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(-1.9560716071750701,1.8563089934671257,-1.089371283526789,0.45302651466747346,0.5754832357256494,3.377112037476161,-1.1078516930515567,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(1.5014679676763512,1.46456490318075,3.74940663345368,-0.5180207050201467,-0.9701148885455172,-0.7947236401223874,-2.385191842660675,0.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(1.316853101423458,1.2491089344703392,2.3725759643289566,-2.9342129359065137,-0.4183076327718859,-1.155701368032073,0.9779293936805153,0.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(1.1849117352329739,1.3925299588445736,1.5695966090587818,-2.1311823024234813,-0.9067969456142655,-0.9769402104776256,1.3185069398877736,0.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(2.373297959341027,2.775778233617674,-3.987898143897202,4.1703153450619785,0.47977169869012415,0.5341339903160455,-1.8868105390404768,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(2.3482349418405724,-3.1159637626200545,1.322069359815815,2.229373710192031,0.1833587373393235,-3.6718200269675574,-2.167407144040195,0.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(0.8243075201573921,1.3348585688363546,-2.0351861522550223,0.44274131356886665,0.7582729504076067,0.4043388560881777,0.26562738440084566,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(0.9481666208581829,0.22905400262922648,-1.2625401200379784,0.01891167448317009,-0.23629041979461762,-0.8959552087654045,1.483311569076668,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(-0.06585868557878616,1.4576378617673251,0.7399321196221702,-5.557327993134892,2.0615711774643364,0.59937804443105,2.443312546568034,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(-0.5617223747915407,-0.536515447514492,-0.9957168928986968,4.77783798052823,-3.0250516363531137,0.04763704320310812,-0.8503674789558922,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(-3.34324723959496,4.3926424059948035,-0.0495291336313155,2.6333253919636106,-1.8973423593226126,5.962186949574377,-3.1074374428513205,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.49887278027307114,2.4772176483573447,0.8766144403424073,-4.412341348998718,-0.06544816902397033,0.17540887369438027,2.973618255958296,0.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(-0.7781653022461528,1.6160279900558963,2.9043194289987406,-1.6138303698874787,-0.3568046596220451,1.4348863906315135,-1.472812006839362,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(1.0193028644873694,1.6299059681175168,0.7720871381731178,-6.526365022144807,3.602358868389331,0.05735615709042067,1.942603137953855,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(1.126058179631438,-0.08021399823747422,0.1845945629753224,0.17818816509562224,-0.738333890554967,-1.3667460232410276,0.6101098938191294,0.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.696410860620625,-0.6276802386587743,2.4836900187897752,-2.0850016187629534,0.24626466623836807,-1.3510098287109322,-0.044478444238072345,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(-2.2180272120355253,2.4305553228334267,-1.5801744943687832,4.862275527923406,-2.2752200612907183,3.8805912201348205,-2.6384927064003305,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(1.7567743245952139,-0.34730069944053166,-0.8948025108160138,3.0380121675012406,-1.1828054695478198,-1.7157828402064659,-0.7250035618486275,0.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.8454701528107351,-1.4667747625694347,1.3994753234952881,0.14108982726971897,-1.4662061418653511,-2.2561833089066807,0.7712682192410636,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.9311255806838445,0.30138652549697587,0.38513967479058675,1.3739433638375038,-1.148015783327944,-0.8064976661502308,-0.6120628161659272,0.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(3.364212163278218,-0.5777774492998544,-2.0960237073085235,2.7292130504797565,0.3929841930243696,-2.9133895273811254,-0.5391544963326877,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(1.0464711573814256,0.6301410336103881,0.6168596799831255,-1.032929924340855,-1.2787522510385279,-1.28640822590547,1.7388375253169488,0.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(-1.422247332703442,1.3099920188712886,2.4073061721409297,2.1870630187898,-2.906653106438294,1.6982591159934275,-2.362573454685344,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(3.1695741682612937,-0.18516594373997697,-0.7713888778777602,3.1151308383183576,-3.0028825960507337,-3.641700075824226,1.1176723514330833,0.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(-1.0201468439854502,2.0949741514552933,0.6385052523919061,1.8831849732743258,-2.2046121941585293,1.961396504470046,-1.341031552473416,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.9381164870495406,0.7569235185409051,-0.04079716532568112,-1.0646216144008618,-2.1229314622801283,-1.4627720410887246,3.205645865534935,0.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.9437251365046566,0.2476269059695898,0.04785469653893282,-3.162644357415593,1.5437021067561914,-0.853674727031123,1.7551166151989124,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.7011087711254909,1.2035331930765993,-1.4398091375364501,-0.22767686518825167,0.8665559020317706,0.35056665369985957,0.3315069768001421,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.7691595700548932,0.23226979363339084,-0.7524159985119943,-2.273159847018095,1.2051808874023429,-0.6613989835734112,1.904431917138825,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(-0.9901267648253292,0.8314035869824183,0.9623028761759912,3.0463733919904152,-2.623962359372865,1.2107802811322752,-1.9252298613127752,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.5670331443146553,1.8504800423581038,-0.644940607788113,-2.7678230888952498,1.5881287762026992,0.6450884188501608,1.2333970014028715,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.7215290147887311,-0.8847639920373926,0.4904341287870997,1.0732294179644357,-0.08407257982238703,-1.0427528377077504,-1.0423316359603254,0.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(-3.0571866679643755,3.3801167219727093,0.7666061453475292,-1.4047601244502173,1.2542122493912302,5.360634400210411,-2.408846721295774,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(-1.14458899707407,0.806558148488993,0.9258314968497899,1.6039908714694096,-1.8099931519413055,1.3287669410436236,-1.2183570331221776,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.0029511283094880714,0.7392527584182871,2.271615106839793,-0.4594423088240106,-1.302932906147438,-0.024854290186172693,-0.6305929459060517,0.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(-1.0262556462492007,3.106727638660441,1.552666143363748,-3.579169866499337,-1.4623529808205205,1.7247030376250396,2.395785937012022,0.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.9439810230045693,-0.03450351562051179,-1.8489916117037675,1.627016506901843,-0.2551150847440704,-0.7340241866844871,0.46366450521689084,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(-0.8995507828338771,2.637194803741764,0.5281828736349332,-5.263580235229065,0.7097535677602926,1.7093409623873352,3.1199605290151666,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(2.2331543227352126,0.576960304218676,-0.676727171313593,1.0171538582152717,-2.82527488357647,-2.6461049785824264,2.6088913588467775,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(-1.884286499274555,1.7159327959050787,3.786765950812899,-6.121056390326268,2.333369727673255,2.6168319013890295,-0.5366786842960347,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(-1.1382122858746933,-0.14299633489223185,0.8327531435987057,1.298580815498469,-0.8627965605758569,0.988030584240615,-1.3967521076705827,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(-0.6303393796237344,4.358235812284331,2.280888586413079,-8.838648817770522,2.239906490938857,2.4513045936352977,2.990325780977093,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(2.4442835629793667,-1.5595422106625365,-0.14785351526730506,2.4592541040486275,-0.0735148069297793,-2.8435659780281113,-1.3676274520194718,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(1.4143700456566066,0.8204418264435885,0.967997405875176,0.42646086353492046,-1.564532879987763,-1.275739590687965,0.1318313864473809,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(1.993790451964731,1.3774074310286606,3.280200674941446,-1.341646747143973,-0.7045036833894341,-1.426903501445604,-1.2265179636048882,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(-0.25515995427833005,-0.4671088714062114,2.2153588526087598,2.313329282416284,-3.5569628024009674,-0.8261756134416534,-0.7263653091644615,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(1.6355961932522634,-1.0282770582100191,-3.2173580488490123,4.559935052970455,-1.1214958228117986,-1.7827022934914223,0.07193385989494827,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(0.3283277042612722,3.4105121001777348,3.2195651165101515,-5.324711721749864,-0.9682526335929017,0.5004787785615196,2.2337122442476227,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(0.754679079237366,1.2099552379791747,-0.4385913525503159,-3.1077997316498673,1.9318023043436465,0.10670563866580032,1.3334679355779948,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(2.0317090865947613,0.8572264240668982,2.4095086017705816,-4.663118509638804,0.16709538369449373,-2.261736697516116,2.4428573077545996,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(2.1693473062725674,0.28205162253200255,-1.9303762140352645,0.9887844009255294,0.9897729061853578,-1.3590499520050627,-0.010177228789967074,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(1.0801920463321826,-0.4298481415473505,-0.33436737741767897,0.8097326513818011,-1.310248231723286,-1.6559624358526785,1.164300884735815,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(-0.04021181298242671,0.22389963328779605,1.9968767300385086,-0.019382197954940554,-1.4497486951865157,-0.29417522140873087,-0.47838412801942587,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(1.1239921256001624,-0.8638540030084805,-1.0178241055718993,-2.2937149162466777,2.565762757868864,-1.2141062999841048,1.274422252538015,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(-0.7413970807889825,1.5875817859558181,0.8403835779082484,-0.06969468265303144,-2.0112826998053173,0.9991342650707755,0.5897487899339218,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(0.21012246579494498,0.7349291140125731,1.1564215797263593,3.067109745050948,-3.8072019508231905,-0.4458351151041659,-0.6775773369205058,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(-0.2786193776514114,0.8391330674680333,-0.4026891923466751,-1.3731305159290677,-0.8305074905865648,0.169874931175302,2.3132805058219574,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(-1.2328709703392624,2.7597725867233383,0.5684016239686696,-2.9566618506267175,-1.5157478752904878,1.7699608909022329,2.8392511093116637,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(0.6871398306249665,-1.4103987067510992,1.0274161223406697,-0.5072792317407046,0.16697719764934948,-1.5964973105562557,0.07247594534487489,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(0.988330670186111,-0.5258004908649867,0.857816493019688,2.905878095316476,-0.3238823556705246,-0.7203927872533037,-3.1935613280291166,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(2.4322721114721757,0.30561297616901784,-1.5190220731160726,1.3743262473426763,-0.37180525132367603,-2.018098080706224,0.6319351503875634,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(1.4632563423687737,0.5381126931941951,0.9013515836533991,-0.4868930388692965,-0.8036249563776104,-1.424272458154115,0.4989428610329456,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(0.9759142028783296,0.0963990665555634,1.080300923613975,-3.059378549550568,1.7637552314639664,-0.8307617709909302,0.5002521536297346,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(0.8451444217468322,2.675124983592143,1.8034394339920048,-6.24356070906137,-0.1404077934628427,-0.4290049368154296,4.083301092855288,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(1.7832957038087498,0.46583490546204087,-2.8377296298346213,1.7314321239250723,1.4637196588786066,-0.5551666584209051,-0.560342527910989,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(2.0305985048097615,-0.8136835491751737,-1.5375629006726204,0.23344540733313246,-0.38312070583511015,-2.6407899536879547,2.2682169302221693,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(-4.450198579702571,3.8044895601982978,1.340371422770127,3.236568823054465,-2.7997133244581374,6.476201660322862,-4.069014914211333,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(1.4825506606818901,1.8932394950918274,-1.6402434007292597,-0.6438070488741744,1.5377697938617518,0.2190653369274579,0.10746474982298349,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(-0.12865647469516983,-0.03277446362082159,0.3789672161429233,0.13234961251820676,0.10865846661989931,0.1899002744334014,-0.6210816810053859,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(-0.7483525163782037,1.911632146474509,1.0237857931937804,-5.939983118898138,0.18095426014013039,0.7464913363725915,4.2349290686151395,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(1.4639789336512659,-1.487762211307613,1.2333792712082898,-0.5819847984553231,1.367105196681563,-1.9311626412059815,-1.1352946822318226,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(-2.716437954263598,3.2172228184755456,2.486899575348391,-0.27826500422738343,-1.496858928573759,4.189036022930514,-2.271237075436395,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(2.0984679507408304,-0.39222671785000096,-0.00929742777138598,2.4355790415042984,-1.2773465142555198,-2.2069415614400536,-0.7601011284502681,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(-2.3851061122725956,1.2652524519794195,1.2056559497342312,0.2301402557556724,-0.13853039522345567,3.166739303466531,-2.143757701306856,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(-0.912501321700246,1.0668955351482894,0.031154669474161678,-0.2922639794504092,0.1586320914087691,1.5749108653175503,-0.4654455435433783,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(1.6897500753524755,-1.5877093887419145,-1.7611534048954183,2.033285149958932,-0.45562387935528914,-2.4572133028294783,0.9117001207364435,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(0.03279016425268144,-0.553487415980487,1.5178285275445653,-1.756383753660862,-1.6424327750282592,-1.3694706413196136,2.3514036487381236,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(0.58004120787043,-0.1972292963993476,-0.13424999439900343,0.0644658482737472,-0.5669375045425562,-0.8960436704764648,0.8194123344316495,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(0.3142690816498883,1.9522135610917537,1.3104586637571347,-3.120340694946515,-0.7990786213674381,0.031103936415356134,2.1367311835504337,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(1.2711769727288555,1.0981021590638618,-1.7957098361193409,0.11763102112672769,0.8889146120013874,-0.1919397644256007,0.4140737388483293,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(-0.2753034616688934,0.5396168159983519,-0.25856295996037804,-0.8784121825809064,0.6222845940416049,0.6514517789151233,0.268334498274877,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(-0.054143446852892296,-1.6609882776935554,1.6234667989235132,3.3387697001507917,-0.9389121245324956,-0.5846606129339186,-3.4424309279299794,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(0.26621832805226675,-0.18078638381031364,2.933879140489032,-0.46282747535339114,-1.7199780636897413,-1.01998740911614,-0.406866592293917,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(0.04897174356182843,-0.3676084862290635,0.9387028981245669,0.8918277660343057,-0.7366479777100163,-0.33317336104618817,-0.9185779389595495,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(-0.21696194123607038,0.21555874139491749,-0.005133162761840726,4.209335205163436,-2.985056254482762,0.1462920409430946,-1.4879483835912106,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(1.1919697926532478,-0.06899302259156948,1.011479220945279,-2.6782330940108325,1.4957262168280048,-1.167204400077594,0.5412644793623882,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(0.797384096830145,-2.8858544823493006,1.4613598752639518,4.082334904310998,-0.48025789276661146,-1.8693084187642843,-3.9155728821524383,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(0.8513327899828025,0.7458930410858058,-0.7732225705417501,-1.4870005874864665,0.6145060572057287,-0.45127579686900166,1.5047009176226747,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(1.2510116832256535,0.2754714151780169,-2.265757658761317,1.229877962757745,0.7099703142373317,-0.5550915813556282,0.20254867074113803,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(1.02808083853107,-0.040629553520089345,0.8900206816703727,-1.3480875179776237,1.3442347323117394,-0.7538223926536042,-0.6342339871101205,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(2.695776681946838,-0.8864088092399576,-0.0789578748776445,2.0458434092506015,-0.970225560557315,-3.0770089140411643,-0.3020299079680173,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(1.1631434432249037,0.2854532336635398,-2.390500707033707,1.7344940763151517,0.6923406830495642,-0.36218796498051203,-0.21341989806423345,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(-1.6503048195027281,0.5243299697796613,0.2251840345614935,3.781488078646145,-2.8118176812215054,1.6996229508611647,-1.7849702798837712,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(1.7841357579086083,1.4436543212940578,-4.6726465448085035,6.434459937635292,-0.5846417872195009,0.2849453543668835,-2.0775372719522043,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(1.0822211355799545,0.9994266546847871,1.0465138567217758,2.0558098640968043,-2.639498177967953,-0.8840583888113261,-0.6825001012379466,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(0.848338734345929,-1.4745072026687287,0.37318698837288045,6.0929889409953235,-2.860229206267653,-1.4979288865033067,-3.1150236297626157,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(-1.2995339588833392,1.2407288550263273,2.640609187687466,-5.723460643589443,2.7512517947788786,1.946472506752308,-0.012081582228990029,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.9946726154312155,1.5401885333052683,3.32058260159335,-2.7680757902230586,-1.5330279328773837,-1.0093823869079046,0.8835422971914466,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(-1.1653969392564758,1.8477252075676,1.5154492658344962,-1.5050500138182235,-0.4399475400838969,1.8901940665945647,-0.3337717224590103,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(2.3410474945205646,0.9406941157522144,-0.31346932922698456,-0.5250458393014832,-0.5348245647633945,-1.952646624466109,1.3913067179555951,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(2.4376595283129783,0.12884481167739992,-0.7153536782631447,2.2980804863380264,-4.310130247410337,-3.425970247693062,3.0425484210457308,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(1.4242822094686205,-0.6739175649059916,-1.6207631956139514,0.9215275442056382,-0.2255601728743668,-1.7552758751749484,1.3017469600205345,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.5634426551277789,-1.5471077082024784,2.4165088824982957,-0.07551896335863666,0.7259879191915617,-1.19324872205996,-2.252728223170336,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.4438980206249631,3.2154267346236893,4.344033519574632,-7.789482359991429,0.27392642950548796,0.2323729828915657,2.58660101167189,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(-1.8266978944375327,2.764653149219914,0.44269893736952115,-1.448029334618218,-0.14573666828341858,3.209923834413559,-0.1568551995293309,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.49796742294949103,0.38611648047359515,0.947852631250811,1.921055938334201,-1.6442237026351973,-0.3807946252730803,-1.3171989797300596,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.2825028600006064,2.4079617426078688,1.3943677343584104,-5.068702752063692,0.3262485206507727,0.361686441352446,2.7646386524149182,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.22492901625026118,2.487212601897629,0.26524983577107275,-3.2366605539208284,-0.6423312073077014,0.4599935245385812,2.860371878492055,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(-0.04824496005648782,-0.41434421911898167,3.2271022590248886,-1.7830389885935827,-1.0845055278057123,-0.9148118678714859,0.10175737670186669,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(1.2494445038361341,-1.2605077919460772,-0.5919596470609547,2.65848661076861,-1.137208814184975,-1.89192004138945,-0.36297989181266965,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(1.9368152698009182,1.4026143232862036,2.654968484232417,-0.48052468015489747,-1.4353801796778478,-1.471326764204455,-0.8054078742203845,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(1.1144180116920606,1.9104663145213592,2.66246604484307,-5.074755087317627,-0.19811341338412658,-0.9123477120908239,2.440556004826056,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(-0.39453752442584944,-0.07366743472831994,1.9655786401195567,0.030511897442377315,-1.4873612106122647,-0.15769770005697964,-0.39586406801516416,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(-0.13705225566650903,-1.066340745793812,2.247663742284547,-2.2163700069902466,1.650571100968139,-0.34030614914782426,-1.086715918625918,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(1.257058965850754,-0.4841613444620174,0.11928070954945669,5.903325224092789,-3.2500639441872186,-1.4374965938334754,-2.6101536572472206,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(2.3338018044957725,-0.25783497499040453,-1.912097518989901,1.7897855693470501,0.6967346574866409,-1.8049321045768083,-0.3259566366550859,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(1.1597881133675316,0.18269125188689506,0.8486870733972146,0.9187771036928764,-1.3457464656817628,-1.263601970316707,-0.28154047796298953,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.3007389767680182,0.46484767063945054,-0.4886824605041771,-2.4201895447056203,1.3963201084273231,-0.007673513374869891,1.4417809458190534,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.24963563676970935,2.146378372977968,0.7902446346235774,-5.6573637067026645,1.9861496459522696,0.7047213943168629,2.3463141909563427,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.5836918839436678,1.3008666070056107,0.598629993661711,-0.10362396303302328,-1.5961048239125133,-0.3129853796094125,0.7514037918744904,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(-0.5229752172383009,0.24565782730994223,0.6095967557050924,0.688197893976115,-1.2881263450703708,0.3444699274985082,-0.15860735569730788,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.713159371718102,0.590874479989717,1.8556281124000433,-1.0879792739972094,-0.885690863908573,-0.8000805235607321,0.1725076813209897,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(2.8728203729298416,-0.8175386138217031,0.21256366729230014,1.4640205139258353,-1.175325702074738,-3.3996480522044146,0.24937101097686643,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.26386100804843426,-0.681937012093828,0.8719546263837685,0.6595807560020865,-1.0334232838287962,-0.9176670256552146,-0.13807803400017815,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.551767614016228,0.7109567026227261,-2.4802658442092,4.901977885732814,-3.066882464644468,-0.2414288804598717,0.13906877696470232,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(-0.9756434098282215,1.5177936333128244,1.0475803709656935,1.4474573922263465,-1.7751753583320031,1.6220531518629306,-1.4700570193599187,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.47763046455062,0.7743296610978223,-2.5287652392342297,0.7391934469677471,2.226326518880974,0.02544798983127873,-0.7676730030660792,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(-0.610702152006014,0.42910678217008225,3.0903157899137983,-5.390224952610268,1.3934337695947003,0.31851454704530224,1.054856662581439,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(3.0958554477794293,-1.4621148020869976,-0.5551243999064688,4.452619430630248,-1.379337013287443,-3.473330945653575,-1.677775172150648,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(3.362080810136683,-1.1400452123643188,0.6638526272830326,4.3778813924145785,-2.415943199028577,-3.8808958633487163,-1.7763856761782737,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(0.9515114782428997,2.5786148051977067,-1.4363545275647995,-0.6681291822406065,1.442317050314664,1.1465667088200706,-0.3269300577214689,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(-2.847938296751167,2.712497525564083,1.1348510423230198,-2.2420055180148903,1.4487652612218769,4.619765374911169,-1.766502892457076,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(-0.8552096265177644,-0.12433378867180744,0.06127441497123598,0.13124974598382613,0.21864608825429177,0.8516308714702762,-0.507455045151372,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(0.9413220120743674,-0.6671836871322345,1.1048795184969697,-0.251817589817712,-0.10041503067356516,-1.389149792100333,-0.26046842750699295,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.8515854524357955,-1.7456600581314028,-0.03925421048801203,1.5179974737998816,0.921332613668205,-2.223550296257367,-1.5207136810245006,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.8801336233511907,-0.4540198439328891,-0.07161754150108735,2.585913277189122,-2.060344360858858,-2.3122434286920814,-0.05721742141110542,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.1565930942796394,2.450186149747695,-0.36499519602591257,-2.6865164333840843,1.7817709621251276,0.5854922377125512,0.5256974003979489,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(2.285833909861166,0.28691651999098333,-1.099897735586095,0.9901853501724588,-0.6044670039367862,-2.050143304937507,0.8657679727222412,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(2.445814401245838,0.617451576980906,-3.6857076155185244,5.807368947766343,-0.7232837434835624,-1.0478351431241741,-1.7664121491248945,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.5724051967604904,1.043672733945267,-2.0466438205717346,1.4988175635419767,-0.022443970841448557,-0.5668460356271273,0.202681936318985,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.767326428923734,1.3282660371650246,0.6148708858259404,-5.476743033106995,0.10974913440714529,-1.9823302577814652,4.841465646867359,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.267326496231199,1.617557661552171,-0.15134447708394183,-3.488157628617435,0.05177221139688082,-0.9171772512777149,3.3253618318584692,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.0726650800289255,1.8463940170697746,-0.8554291334165234,0.2971150824858356,-0.9787305516015852,-0.15059128685897505,0.9251737194989748,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(0.6000678810964989,0.009464861555371407,0.32537504910087334,0.8785831725401735,-1.7720188770580114,-1.041503294055527,0.6853035439619124,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(-0.31903474892623174,-1.9161472026304565,3.249115661818257,-2.064008784693295,2.2511539463109678,-0.4181721655528234,-2.50536511723279,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(-0.27724311948888514,2.269876913502752,-1.0362588939415787,-0.4240851576553433,1.2557043908056547,2.115539216914462,-0.8397651617945024,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.6204471977858825,-0.7472757671052046,-0.44286591935948816,4.984083392550257,-3.765441418069141,-2.3924356302645933,-0.39967559303850064,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(2.4553901093631776,-1.401190635652457,-2.3384856201428965,2.7925686994223646,0.5230823350598678,-2.536900987998952,-0.31452413492174003,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(0.9908721193084293,0.33504947512645533,-0.15004041559882886,1.9914202896753672,-2.15972930497663,-1.1173470973110544,0.2876627916908172,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(-0.4268729371404919,0.0476100000649724,0.7234066075866292,0.9640920579044465,-0.8390128813007733,0.36362579291343516,-0.9290133023411948,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.7223130581227628,-1.5033618740143198,-1.0063691155313,3.7129996091186506,-0.18424839092347522,-1.9124490582287537,-1.9006188557753505,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.3863018949780674,-0.8118812038086545,-0.06824465995756457,2.3605677632827864,-1.9190940321241714,-2.074049594905443,0.10164582500649044,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.122137640295668,-0.7053791921624009,0.5001218626585733,2.202098650241533,-2.13406560335504,-1.846073420077453,-0.13442355611826817,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(-2.612008274681875,2.9273962705582894,-0.6255802858328701,4.821435572962468,-3.6682637014042756,4.076926276736118,-2.3267975850725797,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(0.14722476209464985,0.7169962280383986,1.30877628107509,0.2902560870390723,-0.5278822077282794,0.2523150652935394,-1.279708896388758,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(-0.7291366403013744,-0.5270029128179039,1.3646324243209347,0.22878411183186387,-0.6994553559333184,0.18645848628858827,-0.7164866293982425,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(2.3179603782898544,-1.8426294837876296,-2.0930634395627186,2.2618833621656558,0.4353521009755007,-2.8422362994637034,0.2651206458970319,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(0.16403922504683877,4.218117350808432,-1.464621892755238,0.4525429538867001,-1.1098371609469235,2.24664042651435,0.36048324675723487,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(-0.3213609724022466,-0.025854561408853893,2.639880414243348,-2.0411613386965612,-0.2566331978960029,-0.15905221997635197,-0.12531363631323988,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(-0.5267173926293351,-1.2061059553159688,1.0942381290703467,5.103189751648365,-3.4155924589635265,-0.4164954791259518,-2.502649328522689,0.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(-0.4855645347515395,0.23735171533067967,-0.5003708194846357,1.7804232308433463,-0.7957779583467628,0.6944973953194824,-0.7601873835159783,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(-2.3971333169627815,2.1868183332652453,3.3450712958825215,-4.719603701036977,1.4718198666990285,3.3830233233505638,-0.9827919370657879,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(2.11857678473749,-0.2366895620149072,1.2347293251374487,2.4546831756152896,-1.8039261811587064,-2.269262710480983,-1.4811644132395334,0.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(0.9259627347147839,-1.2059713052048235,1.6474462871354079,0.788474193584277,0.4987767692224161,-1.2387227304804325,-2.2836695458167746,0.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(-3.000029275289839,2.924265303236554,1.5287904697666397,1.8091750655228505,-2.173785091949717,4.4352889084307785,-2.7944599158598593,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(0.509417258150962,0.9345200865941814,-1.2065038607091274,-0.7231863787024786,0.529992343413479,0.12208026281018039,1.064059623279838,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(0.843381208944096,-0.7839641420793553,1.1047338725131475,3.200498581509832,-3.6879624786217464,-1.9826767010553936,-0.17031233402775825,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(0.6996453363330898,1.834603462699156,-1.9563488472181594,-0.8078842985019533,1.603757579443418,0.9023581741197092,0.4157203160510998,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(1.8780698333418597,1.5711743895099697,-1.1532301645027747,-0.1279147199475934,0.3940852348745265,-0.6780554823489231,0.47599660994228743,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(4.074460008738832,-0.7586132247609974,-0.40680550183518793,2.80044141991812,-1.3520950083731564,-4.299897567538348,-0.23018611363621466,0.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(2.537343474263246,-2.346504411277027,1.0696587867609815,-0.09139515915291577,2.6976348801496677,-2.9037343661704513,-2.358064375853471,0.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(0.13810538048698184,0.4972293743727757,0.5170017632088637,3.8074275771962216,-3.441529620481504,-0.2520767485969924,-1.1460977221077522,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(-0.3716927651804762,1.5264964546073356,1.4116615829468997,-3.2696400437607975,-0.44330241396466785,0.5126776429602927,1.8969558924443808,0.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(-3.914146075904356,2.642868730715806,0.756953442096455,4.602054020453453,-3.1534100284140263,5.342012379341791,-4.033424004180775,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(0.6610025539601961,0.47098027882213267,0.09948302448982482,-3.936612690667609,2.4394531934109507,-0.2612419251520717,1.4621079847055367,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(-0.7686849946406735,2.704509185058657,1.3450572364169955,-7.822928994397781,2.9044544260546163,1.9358105418972935,2.7734907448226678,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(1.080539638439189,-2.1322877957031263,1.6986178322913714,0.36371624049923845,1.429812500230177,-1.7326917232712606,-2.4425242014940247,0.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(-1.167900481192102,0.1355097193610142,2.9097040430835177,-3.6404520903908724,0.9713474861844931,0.8816977448790321,-0.15831403216669404,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(-0.45514503610371104,-1.9645298836180913,2.3714681761255285,2.487263886450227,-1.4334710076423254,-0.7560866446214036,-2.677795087997294,0.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(2.205533638434593,0.1522422005591213,-1.2695825588015412,2.5717611851063906,-2.15564597325238,-2.3135028542159386,1.0008109723209975,0.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(1.1514247059211036,-1.0644545346285557,0.889971896861668,-0.8027781017855179,0.612875597105246,-1.7103926464884456,-0.014562305063810954,0.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(0.9177035463916016,1.3689702950747875,-1.3645490052164024,0.12947308667161297,0.383804924036368,0.15022529478155294,0.3474568882561838,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(1.0510311481075103,1.6986541281639824,1.4298397013825055,-2.24828571804734,-0.6193865199766544,-0.5672340485010048,1.131261958671076,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(-0.10475037404319854,1.9826630391809927,-0.4359458701822585,-1.9789206321994306,-0.5553707561694275,0.7295103208665263,2.2600055064016873,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(-0.43499110833343724,1.5870101815511446,0.9402541543282176,-2.933159361296762,-0.5955365826478517,0.6100236545656817,2.1125115594475554,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(2.4357050136448253,-0.5731495595770033,0.16933618049977095,-1.7352638099045383,2.4501836994395925,-2.140306061138697,-0.24355599298923802,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(1.9152646709544332,-1.1044398743526131,0.7264309168930094,2.751047949593423,-1.2155360000324171,-2.376314205559085,-1.5965277293217528,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(1.563555126365538,1.5905399716363626,-2.054401768001512,0.12558226223380958,1.579243827915478,0.11405592777658333,-0.21982342334862204,1.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(-0.730455784283673,0.6917046084758414,-0.7228104495687078,3.170055958828353,-1.447442840589877,1.2822906006373609,-1.5715790666666658,1.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(0.5567147832410433,-0.38074277886588925,-0.7250043310190759,2.9890681820702665,-1.7854730460169494,-0.8300350245815701,-0.38466093931103296,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(1.160113601533908,-2.0739287822796264,0.8656089350937013,2.5598075614900306,-0.4549159561400836,-2.039598659196028,-2.035308932344324,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(1.7301212300757651,1.7905058319133835,2.4785558633754987,-3.285854075731725,-0.2969054302783658,-1.2196278928218516,0.9665388396475895,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(0.15809910063242794,2.086280383850715,0.4267158940755982,-5.777388598503115,2.932621582965904,1.0770137767265244,1.8492278105417443,1.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(0.4346732485474898,0.6310734941541358,-1.404853676310947,-1.1002807120165736,1.4475439430359827,0.2545978186733911,0.8147445978455613,1.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(0.7111994909007124,-1.2485377736456615,0.00888551426993378,-2.6270035371594207,1.5232308527755958,-1.511116569724326,1.8232379971332986,1.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(1.7009681274533355,-2.098511498004252,0.49402451683802484,0.28198081101179506,1.092044026606271,-2.5049127881573976,-0.7737045360739153,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(1.350857441471699,-0.9080776890873943,0.4192135312704207,1.0335209980632558,0.5496545069678738,-1.424954540304835,-1.4810527974238206,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(0.6110098767879673,-0.19648138768779044,0.6976256713944607,0.7330099435441839,-0.4509443081740856,-0.6919587079193924,-0.7985836940346585,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(-0.7120668607049034,1.9568572093714138,1.0113558871394959,1.03831694531311,-1.3192489094050812,1.7439853418610345,-1.6131748737045164,1.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(0.025810229759270387,-1.1821577183920273,1.3502904597295187,3.316741043641779,-2.023622604735853,-0.7820762681282083,-2.2180784244243403,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(0.4823313839367841,0.9550640446662372,0.7796517614669789,-6.113481580673545,3.141750466778539,0.037999576976416934,2.1678622639783702,1.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(0.3198057040263189,1.067353282335374,-0.03774758522041055,-4.276016524189581,2.3619524359005077,0.3465583522342412,1.734889684984254,1.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(1.3206279075878253,2.9104551041192077,2.29210751642639,-5.248625098223054,-0.558629284361523,-0.6422444653370927,2.973566459413637,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(0.2335520332662372,-1.3483862701781133,1.6523781388128378,2.032580021967608,-1.9769743403072197,-1.351134129026289,-1.0913704298839408,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(-0.006197780146330656,1.5659161747636117,0.47428711078179253,-4.163105473654435,0.7532395776393404,0.41101356739081774,2.5389845366598145,1.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(-1.653872981072018,2.150652366216212,-0.682391413932038,1.0683573143849745,0.1041132013079018,3.2579744909035644,-1.7333419946625157,1.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(1.1929822852229999,0.6893229432312034,3.666180819002058,-0.8739189672652259,-1.4699333333739455,-1.292656078547559,-1.1401278912126873,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(1.155136793407768,1.556608797804812,2.6765890234500116,-6.068904790037338,0.06903301027490838,-1.3072077729905347,3.3564000590548333,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(0.21045240367371898,2.426324089796932,2.0395576967297147,-5.872734043014707,-0.09982516278127862,0.12243072729230661,3.4253409716774006,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(3.17277330610435,-0.4559861433811748,-1.4534816279072529,5.475931755644249,-2.7552146063412866,-3.221196770695242,-0.8814034920122698,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(1.6588973963601246,0.8461887027217563,0.18477915861912242,-3.5310792828384088,0.25782571964298096,-1.7173208517757454,3.2150078520616185,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(0.17118349950674683,1.118995662564974,1.4568293787618913,-0.5051347078771523,-1.7022847156761762,-0.1348235263823884,0.47918217936316587,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(-0.22222924383517895,0.11857662096295907,0.07650096299472098,2.0379158249219897,-1.471446181869702,0.1853732522038508,-0.7926848379983182,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(1.3949446302922746,1.370416982034507,-0.3726578951573005,-1.507865895566473,-0.619512343610795,-1.0233127750108155,2.253197907579775,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(1.1892991131649973,0.2446002905843807,1.5298718807562723,-2.099232339908538,-0.5056025526011423,-1.5804405058815307,1.378631760774571,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(1.9397609220772734,0.14612060976419405,0.003327490192374327,1.4823264748097986,-2.108057107017595,-2.2375080799048814,0.8543685258649079,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(-1.9375716302148769,1.8574155817438662,2.006982221925343,-2.0459560007405906,0.6658052443469802,2.9620627786230567,-1.5001878399436688,1.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(-0.2402192482549249,0.8729678849935101,2.1191043260999765,-1.8209285767011751,0.0702401507261432,0.5135562190468611,-0.5577240325203157,1.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(2.797645624903333,-1.5347261778272303,-1.4584107801210373,6.541970409599133,-2.25967473302527,-3.1433214379816197,-2.1371760232834607,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(1.2101207627001906,0.8178658070050348,1.345409305335169,-1.9521840925844323,-0.8292096750094382,-1.3207710619636854,1.5018732200296,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(1.6843456669089063,0.48885992756272634,-2.6849559269116936,4.369671523773933,-1.4771168062402,-0.9821022416444716,-0.4805026737266491,1.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(-0.23784839921057732,1.3535111387210395,0.05320924751207967,-1.9541402009569646,-0.3500510709804364,0.5463348385111396,1.7919768604357116,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(0.13128543053550334,0.6798074445687711,-1.6368443198221256,4.528049001062067,-3.362666984877701,-0.02382357706983641,-0.014886019488387747,1.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(0.4538532345705868,-1.726862620300886,1.7759464630443889,0.9705528654666244,-0.49477289232990296,-1.4722744644269066,-1.4293619756392357,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(1.4801653855390309,-0.47453344733200986,-0.09260586995290043,2.687518390442803,-3.092103825000628,-2.3227047457368974,0.8704218574790192,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(0.5218708026806307,-0.06967317420230557,0.7596210580022738,1.4711668879037785,-2.2608212537809083,-1.0556984545567896,0.1697181766634217,1.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(1.4686426053930823,-0.6876980688572898,-2.318133723758386,4.0906358440061625,-2.2111071372497046,-1.888548462638197,0.6761113150287794,1.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(-0.4655020791006943,-0.18262886630424446,1.9618533997695677,0.8126903231715692,-1.989649844992524,-0.17976489249510838,-0.6676474866827617,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(2.6720786039475946,0.30664618627008156,-1.7819670224326658,3.342376634237586,-2.127744178113725,-2.492973506799871,0.6527115800200574,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(0.7709544863051466,2.089208572308133,1.43733785954422,-3.1347865929904026,-0.7427482316186719,-0.29003767369798433,1.9880762501233427,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(2.004914193301878,0.8836225844754194,-2.8167544354447296,3.730548925991903,-0.14698284122574812,-0.6606442717965159,-1.1677908246516493,1.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(2.178670695122552,-0.37343176507494813,1.6102782889058491,-0.289668173735893,-0.5685426730499268,-2.544466773299166,-0.14330590112211938,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(2.450240693081766,-1.7077791947369563,-0.29053907727783956,3.1577977578818204,-1.574125943917932,-3.3781022323795638,-0.35494151519927786,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(0.7949700874472329,-0.6895749747428475,0.5374981044761692,3.165455372090398,-1.3991901354081273,-1.017110351525864,-2.011720496675317,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(0.9997776221443948,2.602928645773437,-0.6342952955734563,-2.148426258044219,1.4364180609082342,0.8128055918648491,0.4823811597366997,1.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(-0.5142831732503337,0.39128528101053817,0.9008320554174565,2.720050611707023,-3.1508830104429366,0.18317686511736905,-0.7187511553625723,1.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(-0.24024843070289092,-1.3426586516159533,1.698263715427241,4.97158422740088,-3.607946860074412,-0.8589087656970434,-2.6384582242582013,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(2.0649229275070042,-0.8691362909724218,0.06127110963748894,-2.4577692790862034,1.3553513321670838,-2.5767544706205916,1.8244096384210655,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(0.0388578224017484,1.569409049304232,1.55168058988638,-2.7338899094060074,-0.4317685880775276,0.28142214179950714,1.2299760646928444,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(1.083150208364903,1.0544201332588858,0.4849275584677891,0.030545098979075733,-0.9479940248019967,-0.675804210647968,0.2250820171268385,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(1.321939824236789,-1.7325735166420875,-0.1953762072802312,5.922742281805113,-3.438389085025568,-2.409237434210855,-1.6126418088678278,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(0.08186040177412857,-2.5585139391025904,3.3632598057046548,-0.37100416034089057,1.3575022880583072,-1.1842671469006207,-3.156866442574128,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(0.6532751173456468,-0.1563829566175261,0.38904035718586505,-2.0827142213294705,-0.505080151941329,-1.3800157395745356,2.528797835185646,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(2.315159218931961,-0.09574244146296951,-2.870390868688257,5.331430959491889,-1.6278329123179232,-1.819930686484162,-0.8286246222285059,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(2.235231767737936,0.7854330832954342,-2.148601058467422,1.895492977094104,0.5666083244157072,-1.056258020890489,-0.5215948847904226,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(4.241292917178763,-0.9860709778639231,-2.0009845087092635,0.962148112338849,1.76426913823527,-3.885947965014016,0.1282356911817848,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(-1.1263292028928795,-2.4050273682272323,2.9554910083536323,1.7828090923807403,0.9076886004084566,0.3679450599509102,-4.839058422078569,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(-1.7101470672682688,2.847398191594129,-0.5856330427022973,2.8707227771069346,-2.014245686136327,3.3640164995655213,-1.8361445565243186,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(0.38581091755503416,0.5780440904400403,-0.5071088914742421,-0.6090146252730738,0.060807864136913636,-0.12211047185114299,0.8896074381060197,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(1.5231754402233766,1.9421603486454766,-1.7729788908428823,2.3753911110055963,-1.5997916313255445,-0.3262735124330241,0.2706188768556723,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(2.820843966643821,-0.10692047584327335,0.9321887238014344,1.719981242218561,-1.5089437086452422,-2.919276123151345,-0.6623159052278418,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(-0.6180585065606545,-1.7250090425434537,3.183283866457158,0.6566647784968032,-1.9066003341979854,-1.0063287837463553,-1.1432711661139228,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(0.8520873302590414,0.9591953810947647,0.12676127726500885,0.5343659255630722,-1.8092748172332644,-0.7540690279448913,0.9279444910129341,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(-0.31530621506647705,0.12176928364261552,-1.2806898307327894,7.142595241207153,-3.5977212186784424,0.5510238558258297,-2.725111194146174,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(0.3886220250322657,1.8576914505484492,-0.43244838707799194,-4.044760393601628,2.2839267628076234,0.8096845168000543,1.6330072957261046,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(0.6675726022935767,0.20087089318493057,0.6845200898058594,3.6937800329175112,-5.330865424937081,-1.706760651701588,0.9784018600546389,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(-0.6116081865842736,0.6341537797659369,2.8798713181168587,1.1828301568793216,-2.9571969765156374,0.24906758002449095,-1.2907026715079555,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(0.6989473726151247,1.2498504500564895,0.2060774042696093,1.1690938756831124,-1.5014992194769494,-0.14794637691692877,-0.2834799610847376,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(-1.5273671236385944,0.9999544767906874,2.7703496758203627,1.207722028899153,-2.501911705844986,1.5436946481674476,-1.9786310839177188,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(1.702511351487795,-0.34203109814603394,0.7835851548168504,-1.5405081514894055,0.2849694967382024,-2.0575090526779283,0.9992013412095553,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(0.9665214110949041,-0.19155552919216534,0.7199622529149727,2.9073996081407234,-1.9527120616051468,-1.1166708078512677,-1.5156463719764512,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(0.1972926334458771,0.28276647040138503,-0.5192444905278686,-2.5476955695233556,1.8593101847023514,0.12004744459504944,1.1846881329737942,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(1.0321665520706136,1.9966732155667404,-1.4686236794986778,2.3902186300815456,-4.092727086591983,-0.7734708607085561,2.4499981678087295,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(1.2698946255416441,-1.1605905587383079,0.4187489725358793,2.835484738320932,-0.68793046490086,-1.5864754446600542,-2.017976019601487,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(0.4416798285809602,0.24811827480851545,1.0654898348977437,-0.4024036574325009,-1.0692237349365254,-0.7179061516427682,0.48702102541566117,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(1.6907373915312665,0.5782488154633239,0.599945149500958,-0.2547283719058139,-1.1602651261549966,-1.7138182985715615,0.9289975810399699,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(-0.21388172717674148,0.3670796032199588,1.8010065450197448,-1.5292034217343784,-0.10056573944930569,0.13923292684787758,-0.17493465232059124,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(-0.8249165562810634,0.8118811935227044,2.3634010952575495,-8.883011395212582,2.455323134835944,0.3640943002357488,4.16121831002304,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(-1.6123614832674,1.0270743358787555,2.4191824925784884,2.264244528945494,-2.9165944742592664,1.7064826406612614,-2.3591040913743972,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(-0.6856967207299276,1.7525897024574661,-1.1579023328670028,2.2589448355407176,-1.2312457357134239,1.8006792346334546,-0.8430752755923367,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(-1.8165914912002683,0.8803866404425429,2.316672635369382,-1.1810808635080954,-0.7924349556466443,1.8423790039564922,-0.7807611895668487,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(-1.5010244046779506,0.34523810497714713,1.3435520505455572,2.1639508161221426,-1.970858397807827,1.4462679112274643,-1.9102916382971258,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(0.5635922598273722,1.4033442818530633,1.683062562422878,1.0596983259384716,-2.158976282461896,-0.1331177596503839,-0.9781682769599302,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(0.28304003232809394,0.7811221245610349,-1.3923039114076419,3.99712372860234,-3.032968329036988,-0.08346940774160802,-0.044461198603807706,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(2.173115613211947,-0.45623120871027734,2.175888858443627,2.470563591949725,-1.8629450889871788,-2.445235352837583,-2.2353945966210875,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(-2.202431357080454,1.7546984246056434,1.1591425658354584,3.296837897884164,-2.99390938476279,2.901907693620618,-2.5643861199437623,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(1.2507060234279137,2.247796821591938,1.6608145081255743,-4.7160328360136115,-0.29001991756211454,-0.8166791671531242,2.9931321130155855,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(0.15573258355460207,2.172215007412987,1.8398328672983983,-9.111886152079743,3.1988497003563268,0.5434197773241329,3.727484292533844,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(-0.8328725961197609,-0.6837726198347411,2.9609894373395536,0.8541802329628736,-3.0704598054272783,-0.5282371583328125,-0.3954644151370479,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(-0.2305590281166081,2.1714878997598683,1.7808987263571887,-9.091214440959869,4.142077261397787,1.2804508330843913,2.7234893852433366,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(0.8464950859920972,1.8457460443518234,-0.7052530209199774,-0.8099187003486551,-0.49123726501052833,0.00934840017523153,1.4156707278241676,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(-0.7264984103515051,1.58762223148286,1.2543531688970304,-4.576041107988799,2.0471164338092316,1.556043827297222,0.7698900485966396,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(0.6310968833126964,-1.1557887631194408,1.8551643762629424,-1.3835655412181143,1.9814966914722598,-0.8322607453940875,-1.7817987572702223,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(2.1199173655735954,1.0316065570986357,-0.7388254953223654,-1.5610525631124597,1.5291161750630256,-1.1331188201036435,0.6838798263486152,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(0.5793958654817044,1.1370197985890995,-0.42699818741119544,0.451226751321184,-1.1762866346999212,-0.17284061128496353,0.7719883664743177,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(2.8052991708512645,-1.1543441822283065,-0.3079753774879235,0.7547558056367234,-0.39720293791911077,-3.439804665164511,0.8189837917408398,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(1.4024940524681682,0.7830543837865398,-0.11283237135740953,-1.5985039318124916,-0.026048812102019037,-1.1984529193448816,1.7287177333060695,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(3.0147217767070127,-1.0200781629431939,-0.7724586754852318,-1.6645919990450377,1.9943933870089592,-3.191360642502209,1.3263216762617858,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(-0.13531722708660943,1.9535028451727992,-0.04964794910170134,-4.546755747571752,1.8947915970446751,1.1248070457112436,2.0824716923788533,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(0.5780057561867775,2.4389883284494083,-0.06177856070697829,-2.748621215287728,0.45812115038086476,0.6152223729044103,1.5886901010362529,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(1.0546518884657923,0.18234244286557466,0.11030325399538321,3.2191661811958934,-2.36593743964414,-1.0692768734441718,-0.976407733545978,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(1.2933529177327734,-0.30513242091723924,-0.5615862663372806,1.3659303219726464,-1.362414397386018,-1.6806085153310848,0.8272333759272421,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(1.2391823930807615,0.4859918391655791,-0.4928502195038118,3.3616731079156708,-4.091655429873027,-1.7086947303342366,1.1409546244149862,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(-1.5054439327223408,-1.8924109686046506,2.5786138973436095,3.887056714146377,-1.6860332497357198,0.5234956471939621,-4.2927091788856995,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(-1.3147049070042374,2.9550742125471636,2.0805292078567885,-9.458984787991394,2.8909817970255327,2.2781958951820305,3.6332132074095567,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(0.1283229732783333,-1.5808489621836723,0.8581958490255427,5.390836449848271,-2.2509658655011426,-0.782618186639205,-3.5335726851924387,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(1.3314464140423534,0.8129182143050286,-0.8520617594080788,-1.0575404326246254,0.7809407543778316,-0.7064459840496876,0.9995381008322716,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(2.880225665985992,-1.0411359815296204,0.0510449350726625,-0.3878704148669313,1.401121588230164,-2.981523988078325,-0.2104726020045955,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(1.1046212143302618,0.987236550938289,-0.42669185582239033,-4.241325872971698,3.3415739009279566,-0.08424468577629528,1.2092562055909368,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(-1.973789947376512,0.8223402130701964,1.304490015055944,-0.8651390659470903,0.41682754650717646,2.4517085988221443,-1.4055044396931808,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(0.06981536179516334,-1.2065227695226142,2.2774676130672953,-1.1447098015872619,-0.7121456855990037,-1.304068586802913,0.28777483307132834,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(1.9795069078477965,-1.4473444569218747,0.8422773780928017,0.6313697742033327,1.7025648211172815,-2.0075492615530264,-2.333059370251311,0.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(-2.0600652063829266,-0.6333837621853073,3.468536748603692,-0.8913322423271115,-1.757462156010717,0.812572213213716,-0.6022907633519164,0.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(-1.98791867951561,3.031826514239644,-0.7924161436687038,0.12654610966629276,0.7081579465881396,4.176833422654864,-1.6699406256082212,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(0.8426115606298852,1.521152762657554,-0.1337230146189129,-1.4434995314881074,-0.2896581375563225,-0.2428413848621396,1.4665671078648115,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(-0.7284609427171894,-0.0633581959686611,1.1837577791819778,1.4350302630784448,-1.685312280726362,0.3762055904421248,-0.9917669857292509,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(0.13284448420444384,0.48989059418620295,0.649707339140327,3.1534094899577343,-3.2386106987041243,-0.31590614582047116,-0.7870427657819528,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(1.2813990054292852,1.8372801264131764,-2.379643406798959,1.3652576471003457,0.8512744869758768,0.5316461788691897,-0.6156053305262073,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(2.2891125617289863,-1.034466590177339,-0.8528073168005216,0.25565750615528443,0.9498395616806752,-2.48113303573229,0.3410176709625573,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(1.1906881283588873,-1.056056540973113,1.3574824118581417,0.6476728621753428,-0.1322934876060734,-1.6819740111315091,-1.2235936957518294,0.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(-1.3905684814071666,1.2466198898609266,2.259663679830063,-4.14763740755883,1.900848972347196,2.0483451909922756,-0.4555035477919126,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(0.007915404964254469,0.9420317471279528,0.294832519263326,2.582719495108136,-2.3945080639778853,0.28592816588339703,-0.9237809797403697,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(0.583521877945629,0.5331277730352217,-0.48721239763332447,-0.9498752906318381,0.346744013775807,-0.30613068397450366,0.9852227565956533,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(0.3038572775603694,1.8199226286216352,1.7209044780887788,-5.871244361704007,0.03082808989632535,-0.3313693128329034,3.8557824350560352,0.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(-1.4668677560682444,0.615864357805121,1.7525182699336228,-0.8210346671163282,-0.06020757379664965,1.6749795990476146,-1.2205165325854055,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(0.6437634561464207,0.46869838369521777,0.2512633646181748,-4.172634394188566,1.8972887815402877,-0.5040107496571128,2.1281248265853847,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(-2.566685802269739,1.3703937592515176,0.5522319795313368,4.714571322966261,-3.304529843224266,3.1700807408713936,-3.0669517754857556,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(1.4321320759545988,-0.5852717998212875,0.9344530828549473,2.2230574005646426,-3.0763883080523486,-2.405005631784908,0.40557678200484926,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(0.9641855971738517,1.5212499636636303,0.6152159628327369,-0.6607640817743697,-1.6102751585503117,-0.6616239847898601,1.3104820483943997,0.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(1.7048725942936547,1.6561110071176048,-1.6410777840461575,-0.021542409537615766,0.8497272700517364,-0.27637230275554314,0.29379908986403824,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(2.3877637394253206,-1.260106166916444,0.24240366155067983,3.254511285225256,-0.3359126390530982,-2.495451370201776,-2.4430734577527575,0.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(-1.7159795394991253,2.058479403961047,-1.0298338285959132,3.8830429726396325,-1.9236847469944287,3.092667652752938,-2.2573319930263267,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(2.61157813457322,-2.4629468072718197,0.5947853311127764,2.611227042557338,1.956298392040809,-2.746393521796805,-3.94414512547543,0.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(2.100378156997694,-1.0254193606740454,-0.3383292598098695,3.2522179469555192,-0.9092591620666294,-2.3140923190362463,-1.4339917844306427,0.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(-1.5793051540109753,1.6188751709051976,1.3848844184755469,1.166034226400195,-1.1259010183836429,2.4684572651406573,-2.3025016844857564,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(-0.16989054765279876,3.48842017914546,1.9300555017851737,-4.960543036879973,-0.584002148725781,1.2038222628858277,2.568256118525951,0.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(1.3846175270079646,2.145798875875564,0.1748386720212266,-4.796962390806608,0.5073503830831803,-0.7852786914681317,3.731869923790979,0.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(2.463498091505543,-1.641948347672444,0.014419220996607973,1.2485427665891868,-0.4093101695125,-3.315069785949253,0.14698377443441846,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.3015458148717531,2.4084218001678828,-1.9377479084764957,0.1461762550285925,1.181541855937334,0.7614544555573661,-0.3175290393124959,1.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.1995047619542676,-0.5685997445105482,-0.7780001688368265,-0.4208529275293881,0.5408090529552546,-1.441434337645698,1.0491529750596622,1.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.2789267591912103,-0.24431600650961838,-1.7008831850097177,-0.3956028703382682,2.2778328150392717,-0.6617441978281935,-0.01943996576935536,1.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.4426854749839935,-0.4544872588795166,-1.5961072511292693,0.12966802768765306,1.393550473376669,-1.1771061322845136,0.352301270605195,1.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(0.3811254347865457,1.3090655871933126,-0.27688380534200907,-3.0070886914719375,1.064692283384284,0.222022515151732,1.8721838900322956,1.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.1193434289666437,-0.6252656232912621,0.23118248743666925,2.685581337005184,-2.153833997930418,-1.6998262419123031,-0.4037349176707249,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(0.929529577814512,-1.7024107022914883,1.2488247870677989,1.2738796125012244,-0.5345104518047759,-1.8796928677805893,-1.1427878473451383,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(0.8362075518180005,1.1085707711145794,0.9854067590709947,-1.314041820148795,-0.7016240360391046,-0.5921632413160102,0.8578333456580334,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(3.5781343752139643,-1.756334316490143,-1.8913637043295912,3.8207236620641587,0.5041362860876586,-3.5985748597254386,-1.4898228334981138,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(0.3438720049323608,-0.24833525627533626,-0.8346231392283516,-1.5319164096905173,0.7676105738102315,-0.5790077722354865,1.78082722778547,1.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(3.0647342782436895,-1.0260134932323655,-1.2844635442292494,4.455520074360008,-0.33555784108704956,-2.780046271993584,-2.251683378416552,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(0.1706511098490927,1.427297039001016,0.16198610469672814,-4.678308717576381,1.9758795045738022,0.4947574282507664,2.2002784569922085,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(-1.562622677878104,1.7307650405142323,0.30622820821123853,-2.7159606100756912,2.3010271547514884,2.9293712371855865,-0.7525506989141675,1.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.3230332705184404,0.43074369107629307,-1.012178677869002,0.3764842669438245,-0.08467152822680513,-0.9691680411489616,0.6840966010729281,1.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(-0.6935320192169789,0.7446618818491898,0.09665333347742111,2.668069679850536,-1.4079283621598315,1.2190489986881268,-1.877269359035067,1.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.6615988715176795,1.4283536020765286,1.1939007488960722,-0.8584576982487286,-0.9666534542260612,-1.1587443010384395,0.44873555048520886,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.3850989235975144,-1.321996217461353,0.6533355400578518,3.765014097672636,-1.0657673636987341,-1.7288501469488284,-2.7515588732367537,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.679404226498682,0.4488111266798771,-0.09194107232644777,-0.1276070545791313,-0.6321422212401715,-1.5847461579670379,0.9576005483141299,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(2.04659758707243,-0.09637025410588262,-0.5301580315997092,2.3882076811218886,-1.1488798805266265,-1.9448358030407187,-0.4760994417763218,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(0.9502778204515043,1.560900513420219,2.6139226644509987,-0.17703081525604314,-1.3385353345210982,-0.31964658388963124,-1.4084087880151692,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(-1.7064636980022851,0.7232269304349839,2.122895762364635,-0.16484613782968235,-0.5171650348762113,1.962539190063468,-1.877610385342741,1.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(-0.27650843111684753,0.8824040605554635,-0.30196780207451157,-2.686121134883907,-0.17986243753961562,0.1554027845787418,2.9180254329681845,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(0.4055828873228918,-1.686704469180161,2.267279261928881,1.4120459259316966,0.32553090572843124,-0.9591177085579479,-3.2406871412917724,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(2.7528205900707885,-0.7838213498913917,0.42720475600569097,2.4810550424721343,-2.2722544267653983,-3.448555825513464,0.07050855537470957,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.1680246800757323,-0.40872210452552404,-0.4508203946039193,1.8115932970624247,-1.3903370815714982,-1.5343584504031225,0.30070498273072843,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.641411139391031,0.13066169098555191,0.013403427494233067,1.5312226380139464,-1.797441178406297,-1.830627427150842,0.4303846195173422,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.955478907567246,-1.719506740185793,0.762082256889067,0.1866756780988265,-0.9744041434997593,-3.309776136185275,1.0986283866533104,1.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(2.029214776852436,-0.2878096697019167,0.4084705542378164,1.7382336286765805,-0.6833067762076729,-1.9810690593038442,-1.0883122722276921,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(-1.560341449711872,1.5663634023069921,1.0471848595431368,0.1098488111202763,-0.7390036919795584,2.3112166370786724,-1.236752105743788,1.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.2089307327631884,1.9964256833116285,1.226378416624192,-2.4725235681126247,-0.8107018052923085,0.30001515631040365,1.5070634835647967,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.9128041176239442,1.8895100577112083,2.2886808335130913,-3.820954170467079,-0.6052835544037938,-0.623305490142599,1.866033800845503,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(2.993453919875277,-0.901133069473183,-0.0373521979721787,4.2922014798199974,-1.4822374048552227,-3.057711957842002,-2.1409987015165632,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.6766898453496916,-0.5261764912138024,0.7312972156077737,3.9581515737988227,-3.6502190772987513,-1.4820841451981968,-0.7891414274310181,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.14295833912761002,1.6231233113707968,0.18467857172572733,-5.3244744678874545,2.795954007446923,0.8238138676166966,1.929063833460194,1.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(1.7984907565135961,-0.08748991514172744,-1.908421605424304,1.0997506504768602,0.0193869641026021,-1.6007691098789487,0.9508597268855666,1.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(1.4795447177170868,1.558265108527901,2.9519444855092285,-1.7082112440267474,-1.5242435982351923,-1.2321506790399888,0.17024643186890942,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(1.1397560857395845,0.9929628562316919,0.5750597254679413,-5.175405133250185,1.9970886299361146,-0.8051594629268625,2.6421930794939943,1.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(1.2740780719977765,1.1197184976428955,0.651490056121677,-4.4266113109917935,0.15736308604688132,-1.390854468713751,3.651477122782289,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(-1.0402991953119143,-2.06533833303297,3.758708846819417,3.6643483716116036,-1.9836502961873896,-0.15018640286882878,-4.728987719679379,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(1.388042546834122,0.6351311476333177,0.3087393130542635,-0.9747105355778285,-1.2058573277731863,-1.5810825745871568,1.9467994460089018,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(1.6408026773429794,1.4879283180814786,1.547058272073475,-1.3451802114196914,-1.1447992224936614,-1.2638772850029756,0.7853236881637284,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(2.0708542922701993,1.2711484350719897,1.4339591134115544,-0.16035643681145156,-1.184129814417774,-1.5691360483142587,-0.16642233400730944,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.8610958818630077,-1.8798623440397844,0.017309940244927047,1.5547116910354313,-1.2884818488253607,-2.214675539259715,0.5772827870563995,1.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.31017681214048487,-0.5669909849550294,1.9488706008510093,0.8765489312330507,-1.1971421401945954,-0.8532090545239664,-1.265147944962231,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.18497775560572882,0.4850151901864863,-0.6551824564727529,4.63982714028508,-3.2551402962092797,-0.09431469092158731,-1.0924304335485553,1.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(2.4669444008351666,1.859760910530527,-0.10218608993775513,-2.7065907109099916,-1.0087009804989429,-2.1344551850779685,3.6376693906822846,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.8238485766287365,-0.3526798936194202,1.5512566546145274,-0.783457568001856,-0.609118220503116,-1.3676361438381344,0.25775920670818486,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.4279886506498394,-1.318933410675522,1.786893864552341,2.319001466307592,-1.3636960802506595,-1.2080158126691145,-2.140891357760963,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(2.3245577743791705,-1.655861652943644,-0.5357071043474062,3.763999930078965,-0.8970789230750165,-2.833502507806386,-1.5072610448030646,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(1.285195766833195,1.6783115876604113,1.513434891521249,-2.2682980117838745,-0.45638868017239276,-0.7418730885738332,0.9488865767818059,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(1.3481586273438384,0.5174277441556074,0.8785338801961253,2.8147248395427154,-1.9625677135620347,-1.0292085195161238,-1.7895813340376878,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.6954065675726984,-1.3664621081516608,1.5476108546333234,2.180283590956567,-1.293895789561963,-1.5096513815855221,-1.7765071005868003,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.38827399019045394,-0.49792022753587073,1.0198058264078862,-1.5037569154998438,0.6543768219469193,-0.7437803404718291,0.2098285257737864,1.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(-0.3404731340559216,1.2427923266757308,-0.16300461061876503,0.2831612899496902,-0.34457609890571084,1.0720599628234369,-0.3514992450509097,1.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.3161748863138345,0.997351948912386,-1.0801295751777644,0.7571521026186296,0.0016508799060777068,0.48479285742246886,-0.13508160168753358,1.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.12681720829445697,0.11855714969664732,-0.9104184710851837,-1.085292209788002,-0.36232862899070417,-0.46951670408525054,2.366122573967455,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.7054632977954634,1.2572176853681154,0.860029635692299,-2.674401827682585,-0.6939897336698935,-0.6804162818791725,2.3309482151237217,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(1.07976657146411,-1.4207183531564556,2.0010660824353304,-3.194648928592429,3.2399872347286767,-1.3523756841739691,-1.1253482654531937,0.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(0.23610519315312728,-1.7449703241490164,1.6819741303788158,-0.10873160707117276,0.05416324589686572,-1.3123804509649377,-0.7907457427267194,0.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(3.0428333674190866,-1.0841060957114639,0.17243967022211515,-2.377637313997145,4.364469885879871,-2.4605659936454316,-1.2447560474503905,0.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(1.6701855712395437,0.2928301757559636,-1.5428673307968002,1.287330415870048,0.2727252075767579,-1.0692518489650513,-0.035616454995755165,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(-3.4800819804037824,2.977389692948332,1.8517753132543673,-0.19008504775532553,-0.7707879065175474,5.033813816903953,-2.5333706554638304,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(1.140202012142074,2.378634968895875,2.7556348176530534,-5.2834702463746215,-0.3652107320195507,-0.7350150171567257,2.5581641229084484,0.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(1.0981169615204438,-1.0119127261725325,2.2820770387227434,-1.9614013769844154,-0.5644666042090782,-2.284934214852611,1.078012639576424,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(0.8517786531323737,3.6302113892867838,-2.0029871207282746,0.2619852928861331,0.17390567848052974,1.6325105715744603,0.09423329683760107,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(1.4165800771742705,1.1149308340527142,-2.271387795418956,0.24518100275596663,1.6930308923123703,0.0011584811148082907,-0.08553747108993615,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(-2.0053022769813875,1.9109759825293087,2.773376480448724,-4.517202660362165,1.395196983263658,2.817448384076263,-0.39825181111140695,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(-0.5355188940690749,0.6018680914829695,0.7541924354853773,1.0775908586661713,-1.0907319838063005,0.7639886786882052,-1.0624390472003777,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(0.6595797552374167,-0.294809475541403,-0.9630206945978195,-1.5012079340321822,1.0098225390572804,-0.8157334681048121,1.6881542023624867,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(-1.720237261284876,0.11277874103206109,1.844572508290903,3.1533623636012984,-3.9104997386815334,0.9943897606151588,-1.3654061835218285,0.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(0.6922463463083346,-0.35073899252145635,1.9626145160108819,0.08179158347355334,-0.9530812260330679,-1.159859309462594,-0.7170911906049338,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(0.6413378935676259,0.1773899280357525,2.490383604140318,-3.8237997263323082,0.3863233217240887,-1.1052859279962846,1.309165949800489,0.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(-0.918763813284105,1.203162397621166,2.561321396321196,-0.3779626409007189,-2.283467449993765,0.8127359401206152,-0.31172201669053634,0.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(-0.41808616994891934,0.6297437830552794,-0.43519990266235187,0.8152590429422543,-0.4861773114380574,0.7939395653553468,-0.2700384949502228,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(0.0589503046935691,1.1096474018520084,0.8430477162065145,1.017463543138896,-1.8449195206430737,0.23001103979814566,-0.41668386521379497,0.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(0.7035305093965771,1.852386714172002,-0.8581310953858379,-2.7047073013316734,1.7544323773483619,0.5857189112040242,1.2179049628159166,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(-2.404521999474064,1.956856261585237,2.743662957828813,-3.763120660309916,1.2341598733468144,3.336518429323325,-1.0843551531070281,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(-1.5787514548491495,0.9043297397824689,0.3647966016141414,1.5615325941265177,-1.2949689138659002,1.9742065688305668,-1.2806827013749367,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(-1.0235078222978835,3.0475095656963602,1.4758089211909295,-8.183689162345186,2.311408931029436,2.0996841788530536,3.4655603211752783,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(1.4171153313833007,1.5601837547522388,-1.788047063738159,0.6536070698420184,0.03991294542935109,-0.23285562477977859,0.5515980511199634,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(2.5943012663247385,0.768939524488533,-4.7102725616072085,6.878524574598383,-0.5433735742893244,-0.8204559726610645,-2.151320262569758,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(2.095928691139254,-1.5364598955767699,-3.539396767334079,9.353427912472746,-5.3917492321240745,-3.143207068564544,0.002434375177712278,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(1.1733973608839687,-0.4779398907232715,-0.8222573364108066,0.5741388087269558,-0.8233349828146013,-1.6623616225589888,1.4089015715206914,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(2.5968720217016728,-1.561183647496414,-0.5368548320897575,4.563481344641381,-1.1935320996872132,-2.9643545782562257,-2.0430397264366764,0.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(2.714041736048137,0.026319558085377337,2.358390982988962,1.3832961478997392,-1.1938325736946396,-2.6210410239146587,-2.0630733441327145,0.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(1.0224268255603193,-0.3251567068096688,-0.3890143766789398,4.248774781294234,-1.7156272804262211,-0.9098747934249555,-2.0634504893495587,0.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(2.2466469802152655,-0.6104373122047839,0.013869093684521272,1.4174148121004353,-0.9299675669968678,-2.588397575094862,0.05056310478616921,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(-3.734598766339932,4.357711910775082,1.8063222011726097,0.5647484734204162,-1.2668904831697467,6.168350149687059,-3.383175902767071,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(-0.5075416946835463,2.826260938878084,1.6757291381825439,-7.312162195113464,0.5879313407461273,0.9973913776640214,4.309180001467237,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(1.46423411343145,-0.6005198090658379,0.9652261368365875,2.779552976547825,-2.60911189484479,-2.1363879310601983,-0.68726399922343,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(-2.1740091482509643,1.7158438812483352,1.207751628708825,2.1653318489129973,-1.9385559871567524,3.0041298293453407,-2.4842256171560244,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(-0.7576001841832798,-0.007594954223985706,1.0139997501431828,3.0324645799871592,-2.8287853572848425,0.352236350020044,-1.3663697410958096,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(0.22682005310878983,0.17882393778738837,0.6852239252823532,0.6996858648832547,-1.1005329373372745,-0.33694671576753815,-0.2923121947217511,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(1.6420808677485317,-1.567375548263394,1.3596455396410332,-3.18643779804509,2.6618463434153123,-2.2371667201597454,0.22533544015338114,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(-2.4762355913130216,2.18020271868241,1.3238107587214825,3.0782376854873186,-3.2670188241062785,3.2966864834016447,-2.424026089867702,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(0.4681164581671533,2.7802016066061546,2.4377514573974084,-3.504681185661089,-0.33038317365035264,0.576740491675048,0.6678482697206392,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(0.5911030428508862,-0.16060250554086664,-0.01306065642624099,3.934006680488941,-2.120769002361267,-0.6016009232082299,-1.8031712223115948,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(1.174745604954626,-0.4965423351198456,0.5943755851379704,-1.1052321260476299,0.2661649679666236,-1.5726083173913104,0.718004049467069,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(-0.7412751177208392,2.1327090440707304,1.194964453595523,-8.044195522762877,2.831742609518064,1.4456391207259371,3.4658128935875947,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(2.4728274623052195,-1.4446871431555646,-1.473077006061342,4.962183982602092,-0.877344961449386,-2.5959492339011856,-1.96852347020304,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(1.4964109038216507,0.20917901186206578,0.033859363997187364,-0.5696525703041693,-1.37076844681051,-1.950833571036897,2.1420942100235636,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(0.45583852223057186,0.9139217880820522,-0.503312639124806,0.5499114765531566,-1.2222692214056665,-0.20147776675726137,0.8599714517914723,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(-0.2737373806536043,1.27270826072556,0.4760375405877796,-1.801901825509861,-0.692130105318383,0.44709954001227903,1.6095875372621724,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(-1.347794187900541,0.2524553675565264,2.1003710485812177,-2.9225590783504978,1.4128230662455974,1.4304610174764638,-0.6822127662589081,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(0.5871361479153822,-0.8417339321943338,1.1995718501271524,0.8202523967506464,-2.301137318093607,-1.774115856891251,0.8098563835220876,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(-0.21508659002268615,1.569888963274912,0.03986115298828641,-3.9601982606129926,0.9380243205292723,0.7121236564430702,2.5119291735464375,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(2.7941481129839723,-1.0798806957539784,0.025240123668783254,2.633977218875101,1.0284753931360715,-2.3842856430416517,-3.002641820170753,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(0.21207162097481735,0.4647940297522595,0.46295798512172415,0.3232524421339397,-1.6159135710807149,-0.42882666161264194,0.7335086616487765,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(1.4929756391749678,-1.155157311134643,-3.4806846906158686,4.0693214517288965,0.35597074350303237,-1.2793994744342176,-0.6586972623541594,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(1.6854581171681562,0.1834002919426212,2.0365519468046482,3.858832265773903,-2.607252553631471,-1.5355541412174958,-3.1426914316979495,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(2.8327800893646486,-1.7343614197962078,-0.38324008318772385,4.214850202134405,-0.7612512185075357,-3.2089289677127355,-2.1597330449132066,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(0.07122882463582014,-0.6138287383249159,2.384026551347024,-1.7146604393110776,0.6628743724080095,-0.5031775744589227,-0.8780321112073121,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(0.5714623898190813,1.8499637809618559,-1.6528766898390757,0.7922648746756872,0.009123352945717644,0.7920546495067624,0.05588645257506697,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(-3.2633273539187027,1.911289368256512,2.065182047264482,1.922313389116063,-1.9358969584812344,4.156853974629493,-3.297822591979971,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(-1.0527594231003512,0.11046706857150712,-0.17034216295607751,2.002056902252602,-1.3909207669150798,0.9854200330466844,-0.729769914147927,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(1.9857432393597216,-0.797559664346102,-1.8628229075290526,0.7912416658605166,1.1189706285668513,-1.890957287869455,0.41557152949411214,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-2.504762737846811,2.1769977714122506,2.57992693306698,-1.8747939851770445,0.46865410489106774,3.7026137438952347,-2.2438143549852185,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-0.41886628561756134,1.997961493652824,0.45098865921149955,-3.9240951571422404,0.6720821012238447,1.1131211300973887,2.1496317763658626,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-1.269058850471455,0.9113128779485802,-0.987609614890711,5.17453944944951,-2.792635641455655,1.8633254768112497,-2.225434601190937,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(1.60221516530219,0.8573873954567277,-1.2532323321502234,1.4586670560212756,-1.2872866648841212,-1.184906097673008,0.88142213963169,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(0.664945717778535,1.7074410216455105,-0.9164942360480002,-1.7328352122931063,1.042439944629323,0.4681254075262177,1.034268339879112,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-1.0229129860675013,-2.780448032379326,3.2847626195180495,2.509568320419263,-0.8239377084416294,-0.47304522543584926,-3.9581559499963603,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(1.357349140742531,-2.30529006767782,0.09791220462993844,5.626021471718858,-1.5946347715827764,-2.1607839211751037,-3.248371527799422,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(0.19008566471204968,0.9075514438212983,-1.8650607875027787,-0.8680513536341087,0.7997443732584267,0.45238678503301627,1.526885288707088,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-2.9254711696053395,2.1750597750267042,2.1933277965486973,-2.4693963476817404,0.3973459599348179,3.9233999600808573,-1.2357640687177518,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(1.233619763358607,0.9913146965561134,2.3973693810536236,-0.8070564887140679,-1.45741017327986,-1.1664320360973062,-0.13201085846744465,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(0.3161303390254758,0.3276995534451512,-0.02889035651373595,-0.8230808482804979,-0.5319352491047409,-0.47967360079060634,1.36719581140463,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(0.5317287425894308,1.208735839267825,0.08407141955287045,-2.4813609730490715,-0.8888470073318796,-0.6122551141011588,3.060645109675252,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-0.07298769165290997,0.819808188036161,2.0384919882650516,-7.748399227191985,2.2435939891188377,-0.18719747936307643,3.6016374001334093,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-0.7901852621466418,0.5145825360308702,4.637957908386738,-6.150836801745065,1.3912229090534307,0.440132724867259,0.3252310211529108,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(1.831671718235779,0.5977438753380795,-2.321886357828979,2.9104235559256404,-1.017343884238508,-1.1877468146597532,0.22300620292739104,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-2.1539924701669846,1.883675370067507,-1.7680881855073274,5.807546701204832,-2.7646119804927913,3.473472133586789,-2.7200321903160463,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(1.756348176804372,1.7615764405819676,-1.5388289669836195,0.07080621692501461,0.6426698929723338,-0.3106612170666746,0.277797622658288,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-0.2487545187544351,2.609229589371483,1.8882144277890807,-6.154774232631951,-0.5638199006934052,0.43112941318589476,4.2027303973580565,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(0.10955533675333518,0.9087196837335013,0.1136664013383859,-4.1472494266956055,2.014924031822069,0.3431702042196298,1.8459002928252932,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-0.6652930532149404,1.197530864301426,0.9169919325624285,-5.961473613444594,1.8351066038331625,0.8272159997488158,2.950791256392912,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(2.9316838982943185,-0.6964392952831678,-1.1502529215081365,1.4921077726597665,-0.5780146627368032,-3.196356469849491,0.85907655235715,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(2.600077692763368,-1.2623740481307253,-0.8962595005959539,1.9679383389242255,1.2790953056015506,-2.4139441686510956,-1.6329167452667077,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(1.452791564760785,0.41146795445009166,0.14392806279219328,0.17108543131200796,-1.029600784845083,-1.469443131098191,0.8077470058618661,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(0.727098084005239,-2.5546937777149403,1.5105485872014457,-0.29443260630992396,1.1439390403078158,-1.9439707234539425,-1.1506513582879956,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(0.7021391905991415,2.4414499286754787,0.8074093066989305,-6.070712605446909,3.5191034192402006,0.9707334993431298,1.1288619039998729,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-0.9308026588402101,2.57928079368376,1.0748311675888704,-8.529095009719802,3.699706292413457,2.1444358957249268,2.9816820943899875,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(1.2360219692964298,-0.8921138259532037,1.324707218340896,-0.13529792443717042,0.03483533664127236,-1.7310071987282634,-0.5952741360978552,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(0.9580721326511403,1.515267173693862,0.9547831554732867,-3.792366629532976,0.14805240219415627,-0.6733000064089022,2.4871576141650023,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-0.11224442995910122,1.6882722404753472,1.7161782543665778,-2.9486619700579975,-0.6165883797519401,0.3909989063485372,1.4200766219929295,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.4004498564816448,-0.5483306586274586,0.6884992629346187,1.6860799533920177,-2.4028921057076675,-2.221265193101131,0.4912576499341499,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.239942383240145,-1.5480563981269437,1.8577874744757454,0.7272933808052509,-0.9344450764118416,-2.3269279460451013,-0.7435854860482998,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.4542570156828636,-0.27176912816457977,-0.3618604064197557,-1.502224358768631,0.9678737333818738,-1.5496348751441344,1.2748010290281975,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.1468076270806558,1.2322052468347184,-1.7602650358096363,0.7212280541208039,0.024643216826090497,-0.1814752483470614,0.561492706792226,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.5077003347535025,1.088513118264028,1.7551210104319521,-0.736441038595527,-1.3056362875092131,-1.3166156974158438,0.2511173359195177,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(0.288389962747996,0.36332653636764256,1.6656089747619136,-0.571105661353323,-1.1612868506911342,-0.5432082064452731,0.11792111797788773,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.9995296056005114,1.3529339664784819,-2.3981864910916855,2.9849134331502665,-0.7407438786500962,-0.7264517691858112,-0.3538463287395124,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(-0.08579858389687023,1.7161890418770884,-0.06656951353461293,-4.105281638118306,1.5285630478172285,0.8775192894752291,2.1152291309916,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(0.9661724849567914,-0.40445855460769375,-0.8984041426116092,-0.036985924898836356,-0.8750620577241204,-1.5780799558007883,2.1207161932972505,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(0.8699336332979304,0.6851162561092408,-0.9012433467548683,-1.8635864465365037,1.9301898676639888,-0.0891783038473156,0.689996751808305,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(-3.390371025284407,4.3362614916709905,1.1553623702701241,-0.5402753273558951,-0.7164467112290367,5.759960343500196,-2.098251841172708,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(2.3121549519106877,-0.49079106810872064,1.0874868101059274,1.8775100736563255,-1.832698844916588,-2.771227001345358,-0.5639729980991646,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(0.5317909834339799,-0.31402050735813103,1.5222379228128546,1.1028560181554226,-2.2574716049926096,-1.2763341078397625,-0.0682234152133977,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(2.3489372887473756,-1.902965890195,-1.1058115737668315,6.444396538850495,-1.3013307250524164,-2.59335014865392,-3.2826286389085126,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(0.10352282484992748,1.7763521706893264,-0.98957323888984,-3.092145229794725,2.3159326671997436,1.2326770331559804,1.1091309782040397,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(-0.6781201591090096,-1.2017056619726723,3.1386436103718722,-1.4826197651366986,0.7413994646513105,-0.061222556588136814,-1.8011807696190751,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.3088071867454587,-0.9058060170486686,-1.533795865471077,4.443254383671029,-2.2143075168348214,-1.767491483116837,-0.3779098725243084,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(0.42758387794542607,1.3840546035724883,-0.10889830402413547,-3.1754775666120802,1.2232929860961135,0.25803202005775294,1.7027079999027905,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(0.1914622420587,1.6808636178618053,0.5565573242166482,-1.954492290078305,-0.9510650933441838,0.14161140375081846,1.868522343287696,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(2.327521800555288,1.707072587638922,-0.3408892551572401,-0.7841366540150495,-0.30706125962166064,-1.403400095559777,1.139293148033613,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(-1.6870712174917015,1.691651631532742,-2.288473035077086,4.52043452758501,-1.8935449916089768,2.9237857364797977,-1.609566360393679,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(-1.733708401198054,1.3041639797022042,1.400544122440466,-1.9741481668869392,0.4617729940086308,2.3114245726840337,-0.5274602470044196,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.7575715367081157,0.3753135909060661,-1.2693308636208644,0.5371878918731451,0.5384575757585188,-1.153326220541941,0.20366235231148166,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.4883842771922242,1.7515504950397989,1.038220064787369,-1.3034051909539248,-1.3740421429605687,-1.0453541069418544,1.3316370102880164,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.816707826258376,0.9334850907564992,-2.7235167200741737,2.561614634752468,0.5749390983559122,-0.42892177674740073,-0.8151907044116287,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.922399180978037,-0.47398744746047616,-1.086455344591692,0.5421631590354696,-0.17489100087797138,-2.141675253309839,1.1382797565150389,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(-0.4370945240496815,0.7406706373308528,2.3817851052918986,-1.5970867983837052,-0.5383146950358882,0.43966344292078025,-0.39121212011259565,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.5227791882404937,0.032628064555142666,-2.7346852692959223,3.6243268586724393,-0.4338687119554254,-0.8963076772737661,-0.5620760681630759,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(0.6925555904243851,2.2660402104433004,0.571879255854077,-5.136520159556465,0.23388977994347782,-0.21095746484974373,3.839104184046647,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(-0.6170807446057736,1.1618050798356736,-0.3318054593493467,6.307458106404423,-4.152242368795466,1.164412152487124,-2.6433851880918566,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.09933841297654922,-1.3009113230097453,2.3763024813118814,4.843663490637228,-2.7335802864430874,-0.8152959702787319,-4.019613642468096,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(-0.29723257606972664,1.534048303390355,-0.9278630836202846,4.548220911132926,-2.2312916467625055,1.4265140750671224,-2.3032786031118535,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(-1.8723473627536515,0.9717287860436329,2.3847715433643724,0.7344463319711535,-1.8629044282929315,1.9783943683566731,-1.8140411081153947,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.3005647919287311,0.3806355736171525,-0.27869848922330487,-0.8799959881301632,0.3995051923334578,-0.09156717805815423,0.6758278798998893,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(-0.5955050165131914,1.450567042185088,-0.9897943065169226,2.737681953113439,-0.7663788673735875,1.811148094805718,-1.854983423784701,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(2.9669296357978334,-1.3324159367684048,-3.104836225416732,5.208190995197741,-0.8202049866634673,-2.9861699841871703,-0.7016133155919906,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(-1.228016828510732,1.1216551175944176,-0.8558209427875334,4.258437071067928,-2.7976936142573496,1.759131670682027,-1.4539872453038518,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(1.2339963699690584,-0.2804755708218589,1.4715087228456836,-2.9261144609808616,0.355595728180802,-1.8268629783014674,1.6411674193628243,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.9659087122503214,-0.2548687699578174,2.104950827672197,-6.076161419668977,2.9878426404779534,-1.2192738796045464,1.5970699410759703,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.22061418917082676,1.7175054727901158,-0.5033501522353456,-3.8353548758394256,2.331439472843757,0.9401634108615404,1.4604187484921587,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(1.309907365358922,-0.12990852843173584,1.0737239270579344,0.7337127225434502,-1.246715098799017,-1.6078875928365746,-0.25052374133607436,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(-0.36721164916342697,-1.7079119599701718,3.0068461711549523,0.14826986026046768,-0.8186880144087275,-0.9349454628893296,-1.5313812357768914,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(1.6398796287916704,-0.2454439388782933,-0.3454790010819664,2.792239227481451,0.15344573827886987,-1.0493634503221692,-2.4336157756640855,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.7847363960073463,0.7363916664271204,-1.0119432855225785,-1.9544812667283535,1.277543003992446,-0.2529346594821023,1.5342034566540081,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(1.2232936134800012,-1.163429305152226,1.8203348565681234,-1.2313360448785429,1.1074565407265085,-1.7093423514569264,-0.9078154994566392,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.7585110515783027,1.565377477710182,2.027749458360845,-5.369019478696252,-0.3380358319830341,-0.9500514254177758,3.588791253857626,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.7362390304804842,-1.2017843711210685,0.8926545968864157,1.2399265238688837,-0.050827310016290705,-1.198605392602416,-1.5046056364379843,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.6451221517395296,-2.0484424552178737,0.6171428263446541,6.422100778753815,-2.577636468051222,-1.4890401115179508,-3.785907231054817,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(-1.765086441069906,0.3886895405231462,2.731661900411207,-1.3069068417000809,-0.19766973479399452,1.6879242979289697,-1.449585901495793,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.18985291006333638,-1.0740273879437814,1.2843531782256652,2.9867201516109323,-2.853724333474166,-1.267483825267256,-0.9631441174041762,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.9871628788591412,1.8534178483912092,-1.2805384917990295,-1.092147064487189,1.0822665318842248,0.4024378429492361,0.6510218029229897,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.3717600489367091,0.7167856864650772,-0.7499821639105004,-2.1169534465406232,-0.870825637391141,-0.7319917041438911,3.6275089929559368,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.34781014325513526,-0.42631045215441477,2.276403265265107,-1.7872802807090558,0.6460091472975253,-0.6707279710261537,-0.7145197261034959,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.6978341324237667,0.44583514954616277,2.5487409237553997,-3.883754805256149,-0.5331862190361614,-1.3497349443383184,2.16910621644326,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(-0.42196177110466704,2.16561337972615,1.3262059312894516,-5.6286300261936,-0.08711234527451972,0.5828901807272211,3.841164934415239,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(-1.16389008844843,1.2429168032114994,1.1288227844364782,-0.8914746299219967,-0.12326393212364906,1.7336169885979524,-0.6957687675851021,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(-0.97426704102067,-0.06480324801411252,1.2488895732194991,1.6784228029603945,-2.2987446544566623,0.42970828101052566,-0.7140097535913854,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706) DROP TABLE IF EXISTS test.model; -create table test.model engine = Memory as select LogisticRegressionState(400, 2, 2.0)(target, param1, param2, param3, param4, param5, param6, param7) as state from test.defaults; +create table test.model engine = Memory as select LogisticRegressionState(0.005, 2, 2.0)(target, param1, param2, param3, param4, param5, param6, param7) as state from test.defaults; with (select state from test.model) as model select evalMLMethod(model, predict1, predict2, predict3, predict4, predict5, predict6, predict7) from test.defaults; From f89d0264fc7882c79dd66120fdb200b6fb41abb7 Mon Sep 17 00:00:00 2001 From: Masha Date: Fri, 15 Feb 2019 23:41:50 +0000 Subject: [PATCH 019/709] message with description --- dbms/tests/queries/0_stateless/00953_ml_test.rock_auc_reference | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/dbms/tests/queries/0_stateless/00953_ml_test.rock_auc_reference b/dbms/tests/queries/0_stateless/00953_ml_test.rock_auc_reference index edd49736ac8..a760c5b44b6 100644 --- a/dbms/tests/queries/0_stateless/00953_ml_test.rock_auc_reference +++ b/dbms/tests/queries/0_stateless/00953_ml_test.rock_auc_reference @@ -1 +1 @@ -0.6703296703296704 +0.7692307692307693 From 67b28c224053c2867c25cd1d7582d3776d9bb511 Mon Sep 17 00:00:00 2001 From: Masha Date: Tue, 26 Feb 2019 08:12:16 +0000 Subject: [PATCH 020/709] Nesterov and Adam + tests --- .../AggregateFunctionMLMethod.cpp | 6 + .../AggregateFunctionMLMethod.h | 110 +++++++++++++++++- .../0_stateless/00954_ml_test.reference | 1 + .../queries/0_stateless/00954_ml_test.sql | 17 +++ .../0_stateless/00955_ml_test.reference | 1 + .../queries/0_stateless/00955_ml_test.sql | 17 +++ 6 files changed, 150 insertions(+), 2 deletions(-) create mode 100644 dbms/tests/queries/0_stateless/00954_ml_test.reference create mode 100644 dbms/tests/queries/0_stateless/00954_ml_test.sql create mode 100644 dbms/tests/queries/0_stateless/00955_ml_test.reference create mode 100644 dbms/tests/queries/0_stateless/00955_ml_test.sql diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp index 04d31f918d0..814f60f544c 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp @@ -61,6 +61,12 @@ AggregateFunctionPtr createAggregateFunctionMLMethod( } else if (applyVisitor(FieldVisitorConvertToNumber(), parameters[2]) == Float64{2.0}) { wu = std::make_shared(); + } else if (applyVisitor(FieldVisitorConvertToNumber(), parameters[2]) == Float64{3.0}) + { + wu = std::make_shared(); + } else if (applyVisitor(FieldVisitorConvertToNumber(), parameters[2]) == Float64{4.0}) + { + wu = std::make_shared(); } else { throw Exception("Such weights updater is not implemented yet", ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT); diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h index 4394d508846..d815313a67c 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h @@ -210,6 +210,9 @@ public: virtual void update(UInt32 batch_size, std::vector & weights, Float64 & bias, const std::vector & gradient) = 0; virtual void merge(const IWeightsUpdater &, Float64, Float64) {} + virtual std::vector get_update(UInt32 sz, UInt32) { + return std::vector(sz, 0.0); + } }; class StochasticGradientDescent : public IWeightsUpdater @@ -260,6 +263,100 @@ private: Float64 alpha_{0.1}; std::vector accumulated_gradient; }; +class Nesterov : public IWeightsUpdater +{ +public: + Nesterov() {} + Nesterov (Float64 alpha) : alpha_(alpha) {} + void update(UInt32 batch_size, std::vector & weights, Float64 & bias, const std::vector & batch_gradient) override { + if (accumulated_gradient.size() == 0) + { + accumulated_gradient.resize(batch_gradient.size(), Float64{0.0}); + } + for (size_t i = 0; i < batch_gradient.size(); ++i) + { + accumulated_gradient[i] = accumulated_gradient[i] * alpha_ + batch_gradient[i]; + } + for (size_t i = 0; i < weights.size(); ++i) + { + weights[i] += accumulated_gradient[i] / batch_size; + } + bias += accumulated_gradient[weights.size()] / batch_size; + std::cout<<"BIAS " << bias<<'\n'; + } + virtual void merge(const IWeightsUpdater & rhs, Float64 frac, Float64 rhs_frac) override { + auto & nesterov_rhs = static_cast(rhs); + for (size_t i = 0; i < accumulated_gradient.size(); ++i) + { + accumulated_gradient[i] = accumulated_gradient[i] * frac + nesterov_rhs.accumulated_gradient[i] * rhs_frac; + } + } + virtual std::vector get_update(UInt32 sz, UInt32 batch_size) override { + if (accumulated_gradient.size() == 0) + { + accumulated_gradient.resize(sz, Float64{0.0}); + return accumulated_gradient; + } + std::vector delta(accumulated_gradient.size()); + // std::cout<<"\n\nHK\n\n"; + for (size_t i = 0; i < delta.size(); ++i) + { + delta[i] = accumulated_gradient[i] * alpha_ / batch_size; + } + return delta; + } + +Float64 alpha_{0.1}; +std::vector accumulated_gradient; +}; +class Adam : public IWeightsUpdater +{ +public: + Adam() {} + Adam (Float64 betta1, Float64 betta2) : betta1_(betta1), betta2_(betta2), betta1t_(betta1), betta2t_(betta2) {} + void update(UInt32 cur_batch, std::vector & weights, Float64 & bias, const std::vector & batch_gradient) override { + if (mt_.size() == 0) + { + mt_.resize(batch_gradient.size(), Float64{0.0}); + vt_.resize(batch_gradient.size(), Float64{0.0}); + } + Float64 eps = 0.01; + for (size_t i = 0; i < batch_gradient.size(); ++i) + { + mt_[i] = mt_[i] * betta1_ + (1 - betta1_) * batch_gradient[i]; + vt_[i] = vt_[i] * betta2_ + (1 - betta2_) * batch_gradient[i] * batch_gradient[i]; + if (t < 8) { + mt_[i] = mt_[i] / (1 - betta1t_); + betta1t_ *= betta1_; + } + if (t < 850) { + vt_[i] = vt_[i] / (1 - betta2t_); + betta2t_ *= betta2_; + } + } + for (size_t i = 0; i < weights.size(); ++i) + { + weights[i] += (mt_[i] / (sqrt(vt_[i] + eps))) / cur_batch; + } + bias += (mt_[weights.size()] / (sqrt(vt_[weights.size()] + eps))) / cur_batch; + t += 1; + } + virtual void merge(const IWeightsUpdater & rhs, Float64 frac, Float64 rhs_frac) override { + auto & adam_rhs = static_cast(rhs); + for (size_t i = 0; i < mt_.size(); ++i) + { + mt_[i] = mt_[i] * frac + adam_rhs.mt_[i] * rhs_frac; + vt_[i] = vt_[i] * frac + adam_rhs.vt_[i] * rhs_frac; + } + } +Float64 betta1_{0.2}; +Float64 betta2_{0.3}; +Float64 betta1t_{0.3}; +Float64 betta2t_{0.3}; +UInt32 t = 0; +std::vector mt_; +std::vector vt_; +}; class LinearModelData { @@ -285,8 +382,16 @@ public: { /// first column stores target; features start from (columns + 1) const auto & target = static_cast &>(*columns[0]).getData()[row_num]; - - gradient_computer->compute(weights, bias, learning_rate, target, columns + 1, row_num); + + auto delta = weights_updater->get_update(weights.size() + 1, batch_capacity); + Float64 delta_bias = bias + delta[weights.size()]; + delta.resize(weights.size()); + for (size_t i = 0; i < weights.size(); ++i) { + delta[i] += weights[i]; + } + + gradient_computer->compute(delta, delta_bias, learning_rate, target, columns + 1, row_num); + // gradient_computer->compute(weights, bias, learning_rate, target, columns + 1, row_num); ++batch_size; if (batch_size == batch_capacity) { @@ -369,6 +474,7 @@ private: batch_size = 0; ++iter_num; gradient_computer->reset(); + //TODO ask: для нестерова и адама не очень. Нужно добавить другую функцию } }; diff --git a/dbms/tests/queries/0_stateless/00954_ml_test.reference b/dbms/tests/queries/0_stateless/00954_ml_test.reference new file mode 100644 index 00000000000..8575e00f538 --- /dev/null +++ b/dbms/tests/queries/0_stateless/00954_ml_test.reference @@ -0,0 +1 @@ +-66.98005053600168 diff --git a/dbms/tests/queries/0_stateless/00954_ml_test.sql b/dbms/tests/queries/0_stateless/00954_ml_test.sql new file mode 100644 index 00000000000..b1bce54036f --- /dev/null +++ b/dbms/tests/queries/0_stateless/00954_ml_test.sql @@ -0,0 +1,17 @@ +CREATE DATABASE IF NOT EXISTS test; +DROP TABLE IF EXISTS test.defaults; +CREATE TABLE IF NOT EXISTS test.defaults +( + param1 Float64, + param2 Float64, + target Float64, + predict1 Float64, + predict2 Float64 +) ENGINE = Memory; +insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0), (-1.099, 2.755, -3.060, 20.0, 40.0), (1.090, 2.945, -2.346, 20.0, 40.0), (0.305, 2.179, -1.205, 20.0, 40.0), (-0.925, 0.702, 1.134, 20.0, 40.0), (3.178, -1.316, 7.221, 20.0, 40.0), (-2.756, -0.473, 2.569, 20.0, 40.0), (3.665, 2.303, 0.226, 20.0, 40.0), (1.662, 1.951, -0.070, 20.0, 40.0), (2.869, 0.593, 3.249, 20.0, 40.0), (0.818, -0.593, 4.594, 20.0, 40.0), (-1.917, 0.916, 0.209, 20.0, 40.0), (2.706, 1.523, 1.307, 20.0, 40.0), (0.219, 2.162, -1.214, 20.0, 40.0), (-4.510, 1.376, -2.007, 20.0, 40.0), (4.284, -0.515, 6.173, 20.0, 40.0), (-1.101, 2.810, -3.170, 20.0, 40.0), (-1.810, -1.117, 4.329, 20.0, 40.0), (0.055, 1.115, 0.797, 20.0, 40.0), (-2.178, 2.904, -3.898, 20.0, 40.0), (-3.494, -1.814, 4.882, 20.0, 40.0), (3.027, 0.476, 3.562, 20.0, 40.0), (-1.434, 1.151, -0.018, 20.0, 40.0), (1.180, 0.992, 1.606, 20.0, 40.0), (0.015, 0.971, 1.067, 20.0, 40.0), (-0.511, -0.875, 4.495, 20.0, 40.0), (0.961, 2.348, -1.216, 20.0, 40.0), (-2.279, 0.038, 1.785, 20.0, 40.0), (-1.568, -0.248, 2.712, 20.0, 40.0), (-0.496, 0.366, 2.020, 20.0, 40.0), (1.177, -1.401, 6.390, 20.0, 40.0), (2.882, -1.442, 7.325, 20.0, 40.0), (-1.066, 1.817, -1.167, 20.0, 40.0), (-2.144, 2.791, -3.655, 20.0, 40.0), (-4.370, 2.228, -3.642, 20.0, 40.0), (3.996, 2.775, -0.553, 20.0, 40.0), (0.289, 2.055, -0.965, 20.0, 40.0), (-0.588, -1.601, 5.908, 20.0, 40.0), (-1.801, 0.417, 1.265, 20.0, 40.0), (4.375, -1.499, 8.186, 20.0, 40.0), (-2.618, 0.038, 1.615, 20.0, 40.0), (3.616, -0.833, 6.475, 20.0, 40.0), (-4.045, -1.558, 4.094, 20.0, 40.0), (-3.962, 0.636, -0.253, 20.0, 40.0), (3.505, 2.625, -0.497, 20.0, 40.0), (3.029, -0.523, 5.560, 20.0, 40.0), (-3.520, -0.474, 2.188, 20.0, 40.0), (2.430, -1.469, 7.154, 20.0, 40.0), (1.547, -1.654, 7.082, 20.0, 40.0), (-1.370, 0.575, 1.165, 20.0, 40.0), (-1.869, -1.555, 5.176, 20.0, 40.0), (3.536, 2.841, -0.913, 20.0, 40.0), (-3.810, 1.220, -1.344, 20.0, 40.0), (-1.971, 1.462, -0.910, 20.0, 40.0), (-0.243, 0.167, 2.545, 20.0, 40.0), (-1.403, 2.645, -2.991, 20.0, 40.0), (0.532, -0.114, 3.494, 20.0, 40.0), (-1.678, 0.975, 0.212, 20.0, 40.0), (-0.656, 2.140, -1.609, 20.0, 40.0), (1.743, 2.631, -1.390, 20.0, 40.0), (2.586, 2.943, -1.593, 20.0, 40.0), (-0.512, 2.969, -3.195, 20.0, 40.0), (2.283, -0.100, 4.342, 20.0, 40.0), (-4.293, 0.872, -0.890, 20.0, 40.0), (3.411, 1.300, 2.106, 20.0, 40.0), (-0.281, 2.951, -3.042, 20.0, 40.0), (-4.442, 0.384, 0.012, 20.0, 40.0), (1.194, 1.746, 0.104, 20.0, 40.0), (-1.152, 1.862, -1.300, 20.0, 40.0), (1.362, -1.341, 6.363, 20.0, 40.0), (-4.488, 2.618, -4.481, 20.0, 40.0), (3.419, -0.564, 5.837, 20.0, 40.0), (-3.392, 0.396, 0.512, 20.0, 40.0), (-1.629, -0.909, 4.003, 20.0, 40.0), (4.447, -1.088, 7.399, 20.0, 40.0), (-1.232, 1.699, -1.014, 20.0, 40.0), (-1.286, -0.609, 3.575, 20.0, 40.0), (2.437, 2.796, -1.374, 20.0, 40.0), (-4.864, 1.989, -3.410, 20.0, 40.0), (-1.716, -1.399, 4.940, 20.0, 40.0), (-3.084, 1.858, -2.259, 20.0, 40.0), (2.828, -0.319, 5.053, 20.0, 40.0), (-1.226, 2.586, -2.786, 20.0, 40.0), (2.456, 0.092, 4.044, 20.0, 40.0), (-0.989, 2.375, -2.245, 20.0, 40.0), (3.268, 0.935, 2.765, 20.0, 40.0), (-4.128, -1.995, 4.927, 20.0, 40.0), (-1.083, 2.197, -1.935, 20.0, 40.0), (-3.471, -1.198, 3.660, 20.0, 40.0), (4.617, -1.136, 7.579, 20.0, 40.0), (2.054, -1.675, 7.378, 20.0, 40.0), (4.106, 2.326, 0.402, 20.0, 40.0), (1.558, 0.310, 3.158, 20.0, 40.0), (0.792, 0.900, 1.596, 20.0, 40.0), (-3.229, 0.300, 0.785, 20.0, 40.0), (3.787, -0.793, 6.479, 20.0, 40.0), (1.786, 2.288, -0.684, 20.0, 40.0), (2.643, 0.223, 3.875, 20.0, 40.0), (-3.592, 2.122, -3.040, 20.0, 40.0), (4.519, -1.760, 8.779, 20.0, 40.0), (3.221, 2.255, 0.101, 20.0, 40.0), (4.151, 1.788, 1.500, 20.0, 40.0), (-1.033, -1.195, 4.874, 20.0, 40.0), (-1.636, -1.037, 4.257, 20.0, 40.0), (-3.548, 1.911, -2.596, 20.0, 40.0), (4.829, -0.293, 6.001, 20.0, 40.0), (-4.684, -1.664, 3.986, 20.0, 40.0), (4.531, -0.503, 6.271, 20.0, 40.0), (-3.503, -1.606, 4.460, 20.0, 40.0), (-2.036, -1.522, 5.027, 20.0, 40.0), (-0.473, -0.617, 3.997, 20.0, 40.0), (-1.554, -1.630, 5.483, 20.0, 40.0), (-3.567, -1.043, 3.302, 20.0, 40.0), (-2.038, 0.579, 0.823, 20.0, 40.0), (-3.040, 0.857, -0.233, 20.0, 40.0), (4.610, 0.562, 4.181, 20.0, 40.0), (-3.323, -1.938, 5.215, 20.0, 40.0), (4.314, 1.720, 1.717, 20.0, 40.0), (-1.220, 0.615, 1.161, 20.0, 40.0), (-2.556, 1.120, -0.519, 20.0, 40.0), (-3.717, -0.108, 1.358, 20.0, 40.0), (4.689, -1.826, 8.996, 20.0, 40.0), (3.452, 0.506, 3.713, 20.0, 40.0), (2.472, 0.612, 3.012, 20.0, 40.0), (3.452, 0.450, 3.826, 20.0, 40.0), (1.207, 2.585, -1.567, 20.0, 40.0), (-4.826, 1.090, -1.593, 20.0, 40.0), (3.116, -1.118, 6.794, 20.0, 40.0), (0.448, 2.732, -2.240, 20.0, 40.0), (-1.096, -0.525, 3.503, 20.0, 40.0), (-4.680, -0.238, 1.137, 20.0, 40.0), (2.552, -1.403, 7.082, 20.0, 40.0), (0.719, 2.997, -2.635, 20.0, 40.0), (0.347, -1.966, 7.105, 20.0, 40.0), (2.958, -0.404, 5.288, 20.0, 40.0), (0.722, -1.950, 7.261, 20.0, 40.0), (-2.851, -0.986, 3.546, 20.0, 40.0), (-4.316, -0.439, 1.721, 20.0, 40.0), (-1.685, -0.201, 2.560, 20.0, 40.0), (1.856, 0.190, 3.549, 20.0, 40.0), (-2.052, 0.206, 1.562, 20.0, 40.0), (-2.504, -0.646, 3.041, 20.0, 40.0), (3.235, 0.882, 2.854, 20.0, 40.0), (-1.366, -1.573, 5.463, 20.0, 40.0), (-3.447, 2.419, -3.562, 20.0, 40.0), (4.155, 2.092, 0.893, 20.0, 40.0), (-0.935, 0.209, 2.116, 20.0, 40.0), (3.117, -1.821, 8.201, 20.0, 40.0), (3.759, 0.577, 3.725, 20.0, 40.0), (-0.938, 2.992, -3.453, 20.0, 40.0), (-0.525, 2.341, -1.945, 20.0, 40.0), (4.540, 2.625, 0.019, 20.0, 40.0), (-2.097, 1.190, -0.429, 20.0, 40.0), (-2.672, 1.983, -2.302, 20.0, 40.0), (-3.038, -1.490, 4.460, 20.0, 40.0), (-0.943, 2.149, -1.770, 20.0, 40.0), (0.739, 1.598, 0.174, 20.0, 40.0), (1.828, 1.853, 0.208, 20.0, 40.0), (4.856, 0.137, 5.153, 20.0, 40.0), (-1.617, 0.468, 1.255, 20.0, 40.0), (-1.972, 2.053, -2.092, 20.0, 40.0), (-4.633, 1.389, -2.094, 20.0, 40.0), (-3.628, -1.156, 3.498, 20.0, 40.0), (3.597, 1.034, 2.731, 20.0, 40.0), (-1.488, -0.002, 2.261, 20.0, 40.0), (0.749, 1.921, -0.468, 20.0, 40.0), (1.304, -1.371, 6.394, 20.0, 40.0), (4.587, 2.936, -0.579, 20.0, 40.0), (-2.241, 1.791, -1.703, 20.0, 40.0), (-2.945, 1.372, -1.216, 20.0, 40.0), (1.375, 0.395, 2.898, 20.0, 40.0), (-1.281, -0.641, 3.642, 20.0, 40.0), (2.178, 0.895, 2.299, 20.0, 40.0), (3.031, -0.786, 6.087, 20.0, 40.0), (-1.385, -0.375, 3.058, 20.0, 40.0), (4.041, -0.431, 5.882, 20.0, 40.0), (0.480, -0.507, 4.254, 20.0, 40.0), (-3.797, 0.140, 0.822, 20.0, 40.0), (2.355, 2.502, -0.827, 20.0, 40.0), (1.376, -1.583, 6.854, 20.0, 40.0), (0.164, 1.405, 0.273, 20.0, 40.0), (-1.273, 1.471, -0.579, 20.0, 40.0), (0.770, 2.246, -1.107, 20.0, 40.0), (4.552, 2.904, -0.533, 20.0, 40.0), (4.259, -1.772, 8.674, 20.0, 40.0), (-0.309, 1.159, 0.528, 20.0, 40.0), (3.581, 2.700, -0.610, 20.0, 40.0), (-3.202, 0.346, 0.707, 20.0, 40.0), (-1.575, 1.242, -0.271, 20.0, 40.0), (-1.584, -0.493, 3.194, 20.0, 40.0), (-3.778, 0.150, 0.810, 20.0, 40.0), (-4.675, 1.749, -2.835, 20.0, 40.0), (3.567, -0.792, 6.367, 20.0, 40.0), (-0.417, 1.399, -0.006, 20.0, 40.0), (-4.672, 2.007, -3.349, 20.0, 40.0), (-1.034, 0.196, 2.090, 20.0, 40.0), (-3.796, 2.496, -3.890, 20.0, 40.0), (3.532, -0.497, 5.759, 20.0, 40.0), (4.868, -1.359, 8.151, 20.0, 40.0), (-0.769, 0.302, 2.011, 20.0, 40.0), (4.475, 2.612, 0.014, 20.0, 40.0), (-3.532, -0.395, 2.024, 20.0, 40.0), (0.322, 0.675, 1.812, 20.0, 40.0), (-2.028, -1.942, 5.870, 20.0, 40.0), (1.810, -1.244, 6.392, 20.0, 40.0), (-0.783, 1.242, 0.124, 20.0, 40.0), (-4.745, -1.300, 3.227, 20.0, 40.0), (1.902, 1.973, 0.005, 20.0, 40.0), (-3.453, -1.429, 4.132, 20.0, 40.0), (1.559, 0.986, 1.808, 20.0, 40.0), (0.128, 2.754, -2.443, 20.0, 40.0), (2.759, 1.727, 0.926, 20.0, 40.0), (-4.468, 1.690, -2.614, 20.0, 40.0), (-2.368, -1.922, 5.659, 20.0, 40.0), (-2.766, 2.128, -2.640, 20.0, 40.0), (0.967, -1.825, 7.133, 20.0, 40.0), (-2.854, 2.855, -4.136, 20.0, 40.0), (-2.944, 1.875, -2.222, 20.0, 40.0), (-2.632, -0.983, 3.649, 20.0, 40.0), (2.427, 2.239, -0.266, 20.0, 40.0), (-1.726, -0.838, 3.812, 20.0, 40.0), (0.007, -0.903, 4.809, 20.0, 40.0), (-2.013, 1.092, -0.191, 20.0, 40.0), (-0.449, 0.970, 0.836, 20.0, 40.0), (1.396, 0.411, 2.876, 20.0, 40.0), (-1.115, -1.790, 6.023, 20.0, 40.0), (3.748, 1.917, 1.039, 20.0, 40.0), (2.978, 1.043, 2.404, 20.0, 40.0), (-3.969, 2.514, -4.013, 20.0, 40.0), (4.455, -0.050, 5.328, 20.0, 40.0), (-3.065, -0.846, 3.160, 20.0, 40.0), (-1.069, 2.167, -1.869, 20.0, 40.0), (3.016, -1.393, 7.294, 20.0, 40.0), (0.045, -1.928, 6.879, 20.0, 40.0), (-2.555, -0.984, 3.690, 20.0, 40.0), (-1.995, -0.054, 2.111, 20.0, 40.0), (4.600, -0.509, 6.318, 20.0, 40.0), (-1.942, 1.215, -0.402, 20.0, 40.0), (1.262, 2.765, -1.899, 20.0, 40.0), (2.617, -1.106, 6.521, 20.0, 40.0), (1.737, 0.554, 2.761, 20.0, 40.0), (-2.197, 0.632, 0.638, 20.0, 40.0), (4.768, 2.618, 0.147, 20.0, 40.0), (-3.737, -0.939, 3.010, 20.0, 40.0), (-2.623, 0.595, 0.499, 20.0, 40.0), (4.752, -0.340, 6.057, 20.0, 40.0), (2.333, -1.037, 6.240, 20.0, 40.0), (4.234, -1.882, 8.881, 20.0, 40.0), (-3.393, -0.812, 2.927, 20.0, 40.0), (0.885, 1.383, 0.678, 20.0, 40.0), (0.123, 2.937, -2.812, 20.0, 40.0), (2.969, 0.760, 2.964, 20.0, 40.0), (-4.929, 1.251, -1.967, 20.0, 40.0), (1.916, 2.223, -0.488, 20.0, 40.0), (-0.020, -1.740, 6.469, 20.0, 40.0), (0.702, -1.272, 5.895, 20.0, 40.0), (2.496, 2.648, -1.048, 20.0, 40.0), (4.067, -1.475, 7.984, 20.0, 40.0), (-3.717, 1.851, -2.561, 20.0, 40.0), (1.678, -0.624, 5.088, 20.0, 40.0), (1.073, 0.695, 2.146, 20.0, 40.0), (1.842, -0.749, 5.419, 20.0, 40.0), (-3.518, 1.909, -2.578, 20.0, 40.0), (2.229, 1.189, 1.737, 20.0, 40.0), (4.987, 2.893, -0.292, 20.0, 40.0), (-4.809, 1.043, -1.490, 20.0, 40.0), (-0.241, -0.728, 4.334, 20.0, 40.0), (-3.331, 0.590, 0.156, 20.0, 40.0), (-0.455, 2.621, -2.470, 20.0, 40.0), (1.492, 1.223, 1.301, 20.0, 40.0), (3.948, 2.841, -0.709, 20.0, 40.0), (0.732, 0.446, 2.475, 20.0, 40.0), (2.400, 2.390, -0.579, 20.0, 40.0), (-2.718, 1.427, -1.213, 20.0, 40.0), (-1.826, 1.451, -0.815, 20.0, 40.0), (1.125, 0.438, 2.686, 20.0, 40.0), (-4.918, 1.880, -3.219, 20.0, 40.0), (3.068, -0.442, 5.418, 20.0, 40.0), (1.982, 1.201, 1.589, 20.0, 40.0), (0.701, -1.709, 6.768, 20.0, 40.0), (-1.496, 2.564, -2.877, 20.0, 40.0), (-3.812, 0.974, -0.853, 20.0, 40.0), (-3.405, 2.018, -2.739, 20.0, 40.0), (2.211, 2.889, -1.674, 20.0, 40.0), (-2.481, 2.931, -4.103, 20.0, 40.0), (-3.721, 2.765, -4.391, 20.0, 40.0), (-1.768, -1.292, 4.699, 20.0, 40.0), (-4.462, 1.058, -1.347, 20.0, 40.0), (-3.516, -1.942, 5.126, 20.0, 40.0), (0.485, 2.420, -1.597, 20.0, 40.0), (-0.492, 0.242, 2.270, 20.0, 40.0), (4.245, 1.689, 1.744, 20.0, 40.0), (2.234, 0.364, 3.389, 20.0, 40.0), (2.629, 2.224, -0.134, 20.0, 40.0), (-4.375, 1.221, -1.630, 20.0, 40.0), (-0.618, 1.374, -0.057, 20.0, 40.0), (-2.580, -1.604, 4.918, 20.0, 40.0), (0.159, 1.104, 0.871, 20.0, 40.0), (-3.597, 0.975, -0.749, 20.0, 40.0); + +DROP TABLE IF EXISTS test.model; +create table test.model engine = Memory as select LinearRegressionState(0.1, 5, 3.0)(target, param1, param2) as state from test.defaults; + + +with (select state from test.model) as model select evalMLMethod(model, predict1, predict2) from test.defaults; diff --git a/dbms/tests/queries/0_stateless/00955_ml_test.reference b/dbms/tests/queries/0_stateless/00955_ml_test.reference new file mode 100644 index 00000000000..8d19c2c21f6 --- /dev/null +++ b/dbms/tests/queries/0_stateless/00955_ml_test.reference @@ -0,0 +1 @@ +-70.73127165094067 diff --git a/dbms/tests/queries/0_stateless/00955_ml_test.sql b/dbms/tests/queries/0_stateless/00955_ml_test.sql new file mode 100644 index 00000000000..fb919e5aa57 --- /dev/null +++ b/dbms/tests/queries/0_stateless/00955_ml_test.sql @@ -0,0 +1,17 @@ +CREATE DATABASE IF NOT EXISTS test; +DROP TABLE IF EXISTS test.defaults; +CREATE TABLE IF NOT EXISTS test.defaults +( + param1 Float64, + param2 Float64, + target Float64, + predict1 Float64, + predict2 Float64 +) ENGINE = Memory; +insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0), (-1.099, 2.755, -3.060, 20.0, 40.0), (1.090, 2.945, -2.346, 20.0, 40.0), (0.305, 2.179, -1.205, 20.0, 40.0), (-0.925, 0.702, 1.134, 20.0, 40.0), (3.178, -1.316, 7.221, 20.0, 40.0), (-2.756, -0.473, 2.569, 20.0, 40.0), (3.665, 2.303, 0.226, 20.0, 40.0), (1.662, 1.951, -0.070, 20.0, 40.0), (2.869, 0.593, 3.249, 20.0, 40.0), (0.818, -0.593, 4.594, 20.0, 40.0), (-1.917, 0.916, 0.209, 20.0, 40.0), (2.706, 1.523, 1.307, 20.0, 40.0), (0.219, 2.162, -1.214, 20.0, 40.0), (-4.510, 1.376, -2.007, 20.0, 40.0), (4.284, -0.515, 6.173, 20.0, 40.0), (-1.101, 2.810, -3.170, 20.0, 40.0), (-1.810, -1.117, 4.329, 20.0, 40.0), (0.055, 1.115, 0.797, 20.0, 40.0), (-2.178, 2.904, -3.898, 20.0, 40.0), (-3.494, -1.814, 4.882, 20.0, 40.0), (3.027, 0.476, 3.562, 20.0, 40.0), (-1.434, 1.151, -0.018, 20.0, 40.0), (1.180, 0.992, 1.606, 20.0, 40.0), (0.015, 0.971, 1.067, 20.0, 40.0), (-0.511, -0.875, 4.495, 20.0, 40.0), (0.961, 2.348, -1.216, 20.0, 40.0), (-2.279, 0.038, 1.785, 20.0, 40.0), (-1.568, -0.248, 2.712, 20.0, 40.0), (-0.496, 0.366, 2.020, 20.0, 40.0), (1.177, -1.401, 6.390, 20.0, 40.0), (2.882, -1.442, 7.325, 20.0, 40.0), (-1.066, 1.817, -1.167, 20.0, 40.0), (-2.144, 2.791, -3.655, 20.0, 40.0), (-4.370, 2.228, -3.642, 20.0, 40.0), (3.996, 2.775, -0.553, 20.0, 40.0), (0.289, 2.055, -0.965, 20.0, 40.0), (-0.588, -1.601, 5.908, 20.0, 40.0), (-1.801, 0.417, 1.265, 20.0, 40.0), (4.375, -1.499, 8.186, 20.0, 40.0), (-2.618, 0.038, 1.615, 20.0, 40.0), (3.616, -0.833, 6.475, 20.0, 40.0), (-4.045, -1.558, 4.094, 20.0, 40.0), (-3.962, 0.636, -0.253, 20.0, 40.0), (3.505, 2.625, -0.497, 20.0, 40.0), (3.029, -0.523, 5.560, 20.0, 40.0), (-3.520, -0.474, 2.188, 20.0, 40.0), (2.430, -1.469, 7.154, 20.0, 40.0), (1.547, -1.654, 7.082, 20.0, 40.0), (-1.370, 0.575, 1.165, 20.0, 40.0), (-1.869, -1.555, 5.176, 20.0, 40.0), (3.536, 2.841, -0.913, 20.0, 40.0), (-3.810, 1.220, -1.344, 20.0, 40.0), (-1.971, 1.462, -0.910, 20.0, 40.0), (-0.243, 0.167, 2.545, 20.0, 40.0), (-1.403, 2.645, -2.991, 20.0, 40.0), (0.532, -0.114, 3.494, 20.0, 40.0), (-1.678, 0.975, 0.212, 20.0, 40.0), (-0.656, 2.140, -1.609, 20.0, 40.0), (1.743, 2.631, -1.390, 20.0, 40.0), (2.586, 2.943, -1.593, 20.0, 40.0), (-0.512, 2.969, -3.195, 20.0, 40.0), (2.283, -0.100, 4.342, 20.0, 40.0), (-4.293, 0.872, -0.890, 20.0, 40.0), (3.411, 1.300, 2.106, 20.0, 40.0), (-0.281, 2.951, -3.042, 20.0, 40.0), (-4.442, 0.384, 0.012, 20.0, 40.0), (1.194, 1.746, 0.104, 20.0, 40.0), (-1.152, 1.862, -1.300, 20.0, 40.0), (1.362, -1.341, 6.363, 20.0, 40.0), (-4.488, 2.618, -4.481, 20.0, 40.0), (3.419, -0.564, 5.837, 20.0, 40.0), (-3.392, 0.396, 0.512, 20.0, 40.0), (-1.629, -0.909, 4.003, 20.0, 40.0), (4.447, -1.088, 7.399, 20.0, 40.0), (-1.232, 1.699, -1.014, 20.0, 40.0), (-1.286, -0.609, 3.575, 20.0, 40.0), (2.437, 2.796, -1.374, 20.0, 40.0), (-4.864, 1.989, -3.410, 20.0, 40.0), (-1.716, -1.399, 4.940, 20.0, 40.0), (-3.084, 1.858, -2.259, 20.0, 40.0), (2.828, -0.319, 5.053, 20.0, 40.0), (-1.226, 2.586, -2.786, 20.0, 40.0), (2.456, 0.092, 4.044, 20.0, 40.0), (-0.989, 2.375, -2.245, 20.0, 40.0), (3.268, 0.935, 2.765, 20.0, 40.0), (-4.128, -1.995, 4.927, 20.0, 40.0), (-1.083, 2.197, -1.935, 20.0, 40.0), (-3.471, -1.198, 3.660, 20.0, 40.0), (4.617, -1.136, 7.579, 20.0, 40.0), (2.054, -1.675, 7.378, 20.0, 40.0), (4.106, 2.326, 0.402, 20.0, 40.0), (1.558, 0.310, 3.158, 20.0, 40.0), (0.792, 0.900, 1.596, 20.0, 40.0), (-3.229, 0.300, 0.785, 20.0, 40.0), (3.787, -0.793, 6.479, 20.0, 40.0), (1.786, 2.288, -0.684, 20.0, 40.0), (2.643, 0.223, 3.875, 20.0, 40.0), (-3.592, 2.122, -3.040, 20.0, 40.0), (4.519, -1.760, 8.779, 20.0, 40.0), (3.221, 2.255, 0.101, 20.0, 40.0), (4.151, 1.788, 1.500, 20.0, 40.0), (-1.033, -1.195, 4.874, 20.0, 40.0), (-1.636, -1.037, 4.257, 20.0, 40.0), (-3.548, 1.911, -2.596, 20.0, 40.0), (4.829, -0.293, 6.001, 20.0, 40.0), (-4.684, -1.664, 3.986, 20.0, 40.0), (4.531, -0.503, 6.271, 20.0, 40.0), (-3.503, -1.606, 4.460, 20.0, 40.0), (-2.036, -1.522, 5.027, 20.0, 40.0), (-0.473, -0.617, 3.997, 20.0, 40.0), (-1.554, -1.630, 5.483, 20.0, 40.0), (-3.567, -1.043, 3.302, 20.0, 40.0), (-2.038, 0.579, 0.823, 20.0, 40.0), (-3.040, 0.857, -0.233, 20.0, 40.0), (4.610, 0.562, 4.181, 20.0, 40.0), (-3.323, -1.938, 5.215, 20.0, 40.0), (4.314, 1.720, 1.717, 20.0, 40.0), (-1.220, 0.615, 1.161, 20.0, 40.0), (-2.556, 1.120, -0.519, 20.0, 40.0), (-3.717, -0.108, 1.358, 20.0, 40.0), (4.689, -1.826, 8.996, 20.0, 40.0), (3.452, 0.506, 3.713, 20.0, 40.0), (2.472, 0.612, 3.012, 20.0, 40.0), (3.452, 0.450, 3.826, 20.0, 40.0), (1.207, 2.585, -1.567, 20.0, 40.0), (-4.826, 1.090, -1.593, 20.0, 40.0), (3.116, -1.118, 6.794, 20.0, 40.0), (0.448, 2.732, -2.240, 20.0, 40.0), (-1.096, -0.525, 3.503, 20.0, 40.0), (-4.680, -0.238, 1.137, 20.0, 40.0), (2.552, -1.403, 7.082, 20.0, 40.0), (0.719, 2.997, -2.635, 20.0, 40.0), (0.347, -1.966, 7.105, 20.0, 40.0), (2.958, -0.404, 5.288, 20.0, 40.0), (0.722, -1.950, 7.261, 20.0, 40.0), (-2.851, -0.986, 3.546, 20.0, 40.0), (-4.316, -0.439, 1.721, 20.0, 40.0), (-1.685, -0.201, 2.560, 20.0, 40.0), (1.856, 0.190, 3.549, 20.0, 40.0), (-2.052, 0.206, 1.562, 20.0, 40.0), (-2.504, -0.646, 3.041, 20.0, 40.0), (3.235, 0.882, 2.854, 20.0, 40.0), (-1.366, -1.573, 5.463, 20.0, 40.0), (-3.447, 2.419, -3.562, 20.0, 40.0), (4.155, 2.092, 0.893, 20.0, 40.0), (-0.935, 0.209, 2.116, 20.0, 40.0), (3.117, -1.821, 8.201, 20.0, 40.0), (3.759, 0.577, 3.725, 20.0, 40.0), (-0.938, 2.992, -3.453, 20.0, 40.0), (-0.525, 2.341, -1.945, 20.0, 40.0), (4.540, 2.625, 0.019, 20.0, 40.0), (-2.097, 1.190, -0.429, 20.0, 40.0), (-2.672, 1.983, -2.302, 20.0, 40.0), (-3.038, -1.490, 4.460, 20.0, 40.0), (-0.943, 2.149, -1.770, 20.0, 40.0), (0.739, 1.598, 0.174, 20.0, 40.0), (1.828, 1.853, 0.208, 20.0, 40.0), (4.856, 0.137, 5.153, 20.0, 40.0), (-1.617, 0.468, 1.255, 20.0, 40.0), (-1.972, 2.053, -2.092, 20.0, 40.0), (-4.633, 1.389, -2.094, 20.0, 40.0), (-3.628, -1.156, 3.498, 20.0, 40.0), (3.597, 1.034, 2.731, 20.0, 40.0), (-1.488, -0.002, 2.261, 20.0, 40.0), (0.749, 1.921, -0.468, 20.0, 40.0), (1.304, -1.371, 6.394, 20.0, 40.0), (4.587, 2.936, -0.579, 20.0, 40.0), (-2.241, 1.791, -1.703, 20.0, 40.0), (-2.945, 1.372, -1.216, 20.0, 40.0), (1.375, 0.395, 2.898, 20.0, 40.0), (-1.281, -0.641, 3.642, 20.0, 40.0), (2.178, 0.895, 2.299, 20.0, 40.0), (3.031, -0.786, 6.087, 20.0, 40.0), (-1.385, -0.375, 3.058, 20.0, 40.0), (4.041, -0.431, 5.882, 20.0, 40.0), (0.480, -0.507, 4.254, 20.0, 40.0), (-3.797, 0.140, 0.822, 20.0, 40.0), (2.355, 2.502, -0.827, 20.0, 40.0), (1.376, -1.583, 6.854, 20.0, 40.0), (0.164, 1.405, 0.273, 20.0, 40.0), (-1.273, 1.471, -0.579, 20.0, 40.0), (0.770, 2.246, -1.107, 20.0, 40.0), (4.552, 2.904, -0.533, 20.0, 40.0), (4.259, -1.772, 8.674, 20.0, 40.0), (-0.309, 1.159, 0.528, 20.0, 40.0), (3.581, 2.700, -0.610, 20.0, 40.0), (-3.202, 0.346, 0.707, 20.0, 40.0), (-1.575, 1.242, -0.271, 20.0, 40.0), (-1.584, -0.493, 3.194, 20.0, 40.0), (-3.778, 0.150, 0.810, 20.0, 40.0), (-4.675, 1.749, -2.835, 20.0, 40.0), (3.567, -0.792, 6.367, 20.0, 40.0), (-0.417, 1.399, -0.006, 20.0, 40.0), (-4.672, 2.007, -3.349, 20.0, 40.0), (-1.034, 0.196, 2.090, 20.0, 40.0), (-3.796, 2.496, -3.890, 20.0, 40.0), (3.532, -0.497, 5.759, 20.0, 40.0), (4.868, -1.359, 8.151, 20.0, 40.0), (-0.769, 0.302, 2.011, 20.0, 40.0), (4.475, 2.612, 0.014, 20.0, 40.0), (-3.532, -0.395, 2.024, 20.0, 40.0), (0.322, 0.675, 1.812, 20.0, 40.0), (-2.028, -1.942, 5.870, 20.0, 40.0), (1.810, -1.244, 6.392, 20.0, 40.0), (-0.783, 1.242, 0.124, 20.0, 40.0), (-4.745, -1.300, 3.227, 20.0, 40.0), (1.902, 1.973, 0.005, 20.0, 40.0), (-3.453, -1.429, 4.132, 20.0, 40.0), (1.559, 0.986, 1.808, 20.0, 40.0), (0.128, 2.754, -2.443, 20.0, 40.0), (2.759, 1.727, 0.926, 20.0, 40.0), (-4.468, 1.690, -2.614, 20.0, 40.0), (-2.368, -1.922, 5.659, 20.0, 40.0), (-2.766, 2.128, -2.640, 20.0, 40.0), (0.967, -1.825, 7.133, 20.0, 40.0), (-2.854, 2.855, -4.136, 20.0, 40.0), (-2.944, 1.875, -2.222, 20.0, 40.0), (-2.632, -0.983, 3.649, 20.0, 40.0), (2.427, 2.239, -0.266, 20.0, 40.0), (-1.726, -0.838, 3.812, 20.0, 40.0), (0.007, -0.903, 4.809, 20.0, 40.0), (-2.013, 1.092, -0.191, 20.0, 40.0), (-0.449, 0.970, 0.836, 20.0, 40.0), (1.396, 0.411, 2.876, 20.0, 40.0), (-1.115, -1.790, 6.023, 20.0, 40.0), (3.748, 1.917, 1.039, 20.0, 40.0), (2.978, 1.043, 2.404, 20.0, 40.0), (-3.969, 2.514, -4.013, 20.0, 40.0), (4.455, -0.050, 5.328, 20.0, 40.0), (-3.065, -0.846, 3.160, 20.0, 40.0), (-1.069, 2.167, -1.869, 20.0, 40.0), (3.016, -1.393, 7.294, 20.0, 40.0), (0.045, -1.928, 6.879, 20.0, 40.0), (-2.555, -0.984, 3.690, 20.0, 40.0), (-1.995, -0.054, 2.111, 20.0, 40.0), (4.600, -0.509, 6.318, 20.0, 40.0), (-1.942, 1.215, -0.402, 20.0, 40.0), (1.262, 2.765, -1.899, 20.0, 40.0), (2.617, -1.106, 6.521, 20.0, 40.0), (1.737, 0.554, 2.761, 20.0, 40.0), (-2.197, 0.632, 0.638, 20.0, 40.0), (4.768, 2.618, 0.147, 20.0, 40.0), (-3.737, -0.939, 3.010, 20.0, 40.0), (-2.623, 0.595, 0.499, 20.0, 40.0), (4.752, -0.340, 6.057, 20.0, 40.0), (2.333, -1.037, 6.240, 20.0, 40.0), (4.234, -1.882, 8.881, 20.0, 40.0), (-3.393, -0.812, 2.927, 20.0, 40.0), (0.885, 1.383, 0.678, 20.0, 40.0), (0.123, 2.937, -2.812, 20.0, 40.0), (2.969, 0.760, 2.964, 20.0, 40.0), (-4.929, 1.251, -1.967, 20.0, 40.0), (1.916, 2.223, -0.488, 20.0, 40.0), (-0.020, -1.740, 6.469, 20.0, 40.0), (0.702, -1.272, 5.895, 20.0, 40.0), (2.496, 2.648, -1.048, 20.0, 40.0), (4.067, -1.475, 7.984, 20.0, 40.0), (-3.717, 1.851, -2.561, 20.0, 40.0), (1.678, -0.624, 5.088, 20.0, 40.0), (1.073, 0.695, 2.146, 20.0, 40.0), (1.842, -0.749, 5.419, 20.0, 40.0), (-3.518, 1.909, -2.578, 20.0, 40.0), (2.229, 1.189, 1.737, 20.0, 40.0), (4.987, 2.893, -0.292, 20.0, 40.0), (-4.809, 1.043, -1.490, 20.0, 40.0), (-0.241, -0.728, 4.334, 20.0, 40.0), (-3.331, 0.590, 0.156, 20.0, 40.0), (-0.455, 2.621, -2.470, 20.0, 40.0), (1.492, 1.223, 1.301, 20.0, 40.0), (3.948, 2.841, -0.709, 20.0, 40.0), (0.732, 0.446, 2.475, 20.0, 40.0), (2.400, 2.390, -0.579, 20.0, 40.0), (-2.718, 1.427, -1.213, 20.0, 40.0), (-1.826, 1.451, -0.815, 20.0, 40.0), (1.125, 0.438, 2.686, 20.0, 40.0), (-4.918, 1.880, -3.219, 20.0, 40.0), (3.068, -0.442, 5.418, 20.0, 40.0), (1.982, 1.201, 1.589, 20.0, 40.0), (0.701, -1.709, 6.768, 20.0, 40.0), (-1.496, 2.564, -2.877, 20.0, 40.0), (-3.812, 0.974, -0.853, 20.0, 40.0), (-3.405, 2.018, -2.739, 20.0, 40.0), (2.211, 2.889, -1.674, 20.0, 40.0), (-2.481, 2.931, -4.103, 20.0, 40.0), (-3.721, 2.765, -4.391, 20.0, 40.0), (-1.768, -1.292, 4.699, 20.0, 40.0), (-4.462, 1.058, -1.347, 20.0, 40.0), (-3.516, -1.942, 5.126, 20.0, 40.0), (0.485, 2.420, -1.597, 20.0, 40.0), (-0.492, 0.242, 2.270, 20.0, 40.0), (4.245, 1.689, 1.744, 20.0, 40.0), (2.234, 0.364, 3.389, 20.0, 40.0), (2.629, 2.224, -0.134, 20.0, 40.0), (-4.375, 1.221, -1.630, 20.0, 40.0), (-0.618, 1.374, -0.057, 20.0, 40.0), (-2.580, -1.604, 4.918, 20.0, 40.0), (0.159, 1.104, 0.871, 20.0, 40.0), (-3.597, 0.975, -0.749, 20.0, 40.0); + +DROP TABLE IF EXISTS test.model; +create table test.model engine = Memory as select LinearRegressionState(0.1, 5, 4.0)(target, param1, param2) as state from test.defaults; + + +with (select state from test.model) as model select evalMLMethod(model, predict1, predict2) from test.defaults; From 3fa972e6b676373acd397eb57823cbc482c88ef8 Mon Sep 17 00:00:00 2001 From: quid Date: Sun, 3 Mar 2019 11:46:36 +0300 Subject: [PATCH 021/709] changes in weights updater --- .../AggregateFunctionMLMethod.cpp | 8 +- .../AggregateFunctionMLMethod.h | 488 ++++++++++++------ .../queries/0_stateless/00950_ml_test.sql | 2 +- .../queries/0_stateless/00954_ml_test.sql | 2 +- .../queries/0_stateless/00955_ml_test.sql | 2 +- 5 files changed, 343 insertions(+), 159 deletions(-) diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp index 814f60f544c..4a8d7a43172 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp @@ -42,7 +42,6 @@ AggregateFunctionPtr createAggregateFunctionMLMethod( } - /// Gradient_Computer for LinearRegression has LinearRegression gradient computer if (std::is_same::value) { gc = std::make_shared(argument_types.size()); @@ -64,11 +63,12 @@ AggregateFunctionPtr createAggregateFunctionMLMethod( } else if (applyVisitor(FieldVisitorConvertToNumber(), parameters[2]) == Float64{3.0}) { wu = std::make_shared(); + } else if (applyVisitor(FieldVisitorConvertToNumber(), parameters[2]) == Float64{4.0}) { - wu = std::make_shared(); - } else - { + /// Adam should be here + wu = std::make_shared(); + } else { throw Exception("Such weights updater is not implemented yet", ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT); } } else diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h index d815313a67c..c295679fab4 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h @@ -29,52 +29,66 @@ namespace ErrorCodes extern const int BAD_ARGUMENTS; } +/** +IGradientComputer class computes gradient according to its loss function +and stores mini-batch +*/ class IGradientComputer { public: - IGradientComputer(UInt32 sz) - : batch_gradient(sz, 0) - {} + IGradientComputer(UInt32 sz) { std::ignore = sz;// : batch_gradient(sz, 0) { + } + virtual ~IGradientComputer() = default; - virtual void compute(const std::vector & weights, Float64 bias, Float64 learning_rate, - Float64 target, const IColumn ** columns, size_t row_num) = 0; + /// Adds to batch_gradient computed gradient in point (weigts, bias) using corresponding loss function + virtual void compute(std::vector * batch_gradient, const std::vector &weights, Float64 bias, + Float64 learning_rate, Float64 target, const IColumn **columns, size_t row_num) = 0; - void reset() - { - batch_gradient.assign(batch_gradient.size(), 0); - } +// void reset() +// { +// batch_gradient.assign(batch_gradient.size(), 0); +// } - void write(WriteBuffer & buf) const - { - writeBinary(batch_gradient, buf); - } +// void write(WriteBuffer &buf) const +// { +// writeBinary(batch_gradient, buf); +// } +// +// void read(ReadBuffer &buf) +// { +// readBinary(batch_gradient, buf); +// } - void read(ReadBuffer & buf) - { - readBinary(batch_gradient, buf); - } +// const std::vector &get() const +// { +// return batch_gradient; +// } - const std::vector & get() const - { - return batch_gradient; - } - virtual Float64 predict(const std::vector & predict_feature, const std::vector & weights, Float64 bias) const = 0; - virtual void predict_for_all(ColumnVector::Container & container, Block & block, const ColumnNumbers & arguments, const std::vector & weights, Float64 bias) const = 0; + virtual Float64 predict(const std::vector &predict_feature, + const std::vector &weights, + Float64 bias) const = 0; -protected: - std::vector batch_gradient; // gradient for bias lies in batch_gradient[batch_gradient.size() - 1] + /// Now we should use predict_for_all function instead of predict + virtual void predict_for_all(ColumnVector::Container &container, + Block &block, const ColumnNumbers &arguments, + const std::vector &weights, + Float64 bias) const = 0; + +//protected: +// std::vector batch_gradient; // gradient for bias lies in batch_gradient[batch_gradient.size() - 1] }; + class LinearRegression : public IGradientComputer { public: LinearRegression(UInt32 sz) - : IGradientComputer(sz) - {} + : IGradientComputer(sz) { + } - void compute(const std::vector & weights, Float64 bias, Float64 learning_rate, - Float64 target, const IColumn ** columns, size_t row_num) override + void compute(std::vector * batch_gradient, const std::vector &weights, Float64 bias, + Float64 learning_rate, Float64 target, const IColumn **columns, size_t row_num) override { Float64 derivative = (target - bias); for (size_t i = 0; i < weights.size(); ++i) @@ -83,20 +97,19 @@ public: } derivative *= (2 * learning_rate); - batch_gradient[weights.size()] += derivative; + (*batch_gradient)[weights.size()] += derivative; for (size_t i = 0; i < weights.size(); ++i) { - batch_gradient[i] += derivative * static_cast &>(*columns[i]).getData()[row_num];; + (*batch_gradient)[i] += + derivative * static_cast &>(*columns[i]).getData()[row_num]; } } - Float64 predict(const std::vector & predict_feature, const std::vector & weights, Float64 bias) const override + + Float64 predict(const std::vector &predict_feature, + const std::vector &weights, Float64 bias) const override { /// не обновляем веса при предикте, т.к. это может замедлить предсказание /// однако можно например обновлять их при каждом мердже не зависимо от того, сколько элементнов в батче -// if (cur_batch) -// { -// update_weights(); -// } Float64 res{0.0}; for (size_t i = 0; i < predict_feature.size(); ++i) @@ -107,7 +120,11 @@ public: return res; } - void predict_for_all(ColumnVector::Container & container, Block & block, const ColumnNumbers & arguments, const std::vector & weights, Float64 bias) const override + + void predict_for_all(ColumnVector::Container &container, + Block &block, + const ColumnNumbers &arguments, + const std::vector &weights, Float64 bias) const override { size_t rows_num = block.rows(); std::vector results(rows_num, bias); @@ -134,6 +151,7 @@ public: } }; + class LogisticRegression : public IGradientComputer { public: @@ -141,31 +159,32 @@ public: : IGradientComputer(sz) {} - void compute(const std::vector & weights, Float64 bias, Float64 learning_rate, - Float64 target, const IColumn ** columns, size_t row_num) override + void compute(std::vector * batch_gradient, const std::vector &weights, Float64 bias, + Float64 learning_rate, Float64 target, const IColumn **columns, size_t row_num) override { Float64 derivative = bias; for (size_t i = 0; i < weights.size(); ++i) { - derivative += weights[i] * static_cast &>(*columns[i]).getData()[row_num];; + derivative += weights[i] * static_cast &>(*columns[i]).getData()[row_num]; } derivative *= target; - derivative = exp(derivative); + derivative = exp(derivative); - batch_gradient[weights.size()] += learning_rate * target / (derivative + 1);; + (*batch_gradient)[weights.size()] += learning_rate * target / (derivative + 1);; for (size_t i = 0; i < weights.size(); ++i) { - batch_gradient[i] += learning_rate * target / (derivative + 1) * static_cast &>(*columns[i]).getData()[row_num]; + (*batch_gradient)[i] += + learning_rate * target * + static_cast &>(*columns[i]).getData()[row_num] + / (derivative + 1); } } - Float64 predict(const std::vector & predict_feature, const std::vector & weights, Float64 bias) const override + + Float64 predict(const std::vector &predict_feature, + const std::vector &weights, Float64 bias) const override { /// не обновляем веса при предикте, т.к. это может замедлить предсказание /// однако можно например обновлять их при каждом мердже не зависимо от того, сколько элементнов в батче -// if (cur_batch) -// { -// update_weights(); -// } Float64 res{0.0}; for (size_t i = 0; i < predict_feature.size(); ++i) @@ -176,7 +195,11 @@ public: res = 1 / (1 + exp(-res)); return res; } - void predict_for_all(ColumnVector::Container & container, Block & block, const ColumnNumbers & arguments, const std::vector & weights, Float64 bias) const override + + void predict_for_all(ColumnVector::Container & container, + Block & block, + const ColumnNumbers & arguments, + const std::vector & weights, Float64 bias) const override { size_t rows_num = block.rows(); std::vector results(rows_num, bias); @@ -186,7 +209,6 @@ public: ColumnPtr cur_col = block.getByPosition(arguments[i]).column; for (size_t row_num = 0; row_num != rows_num; ++row_num) { - const auto &element = (*cur_col)[row_num]; if (element.getType() != Field::Types::Float64) throw Exception("Prediction arguments must be values of type Float", @@ -197,124 +219,226 @@ public: } for (size_t row_num = 0; row_num != rows_num; ++row_num) { - results[row_num] = 1 / (1 + exp(-results[row_num])); - container.emplace_back(results[row_num]); + container.emplace_back(1 / (1 + exp(-results[row_num]))); } } }; + +/** +* IWeightsUpdater class defines the way to update current state +* and uses GradientComputer on each iteration +*/ class IWeightsUpdater { public: virtual ~IWeightsUpdater() = default; - virtual void update(UInt32 batch_size, std::vector & weights, Float64 & bias, const std::vector & gradient) = 0; - virtual void merge(const IWeightsUpdater &, Float64, Float64) {} - virtual std::vector get_update(UInt32 sz, UInt32) { - return std::vector(sz, 0.0); + virtual void add_to_batch(std::vector * batch_gradient, std::shared_ptr gc, + const std::vector & weights, Float64 bias, + Float64 learning_rate, Float64 target, const IColumn **columns, size_t row_num) + { + gc->compute(batch_gradient, weights, bias, learning_rate, target, columns, row_num); } + + virtual void update(UInt32 batch_size, + std::vector & weights, Float64 & bias, + const std::vector & gradient) = 0; + + virtual void merge(const IWeightsUpdater &, Float64, Float64) + {} + + virtual void write(WriteBuffer &) const + {} + + virtual void read(ReadBuffer &) + {} +// virtual std::vector get_update(UInt32 sz, UInt32) +// { +// return std::vector(sz, 0.0); +// } }; + class StochasticGradientDescent : public IWeightsUpdater { public: - void update(UInt32 batch_size, std::vector & weights, Float64 & bias, const std::vector & batch_gradient) override { + void update(UInt32 batch_size, + std::vector & weights, Float64 & bias, + const std::vector & batch_gradient) override + { /// batch_size is already checked to be greater than 0 - for (size_t i = 0; i < weights.size(); ++i) { weights[i] += batch_gradient[i] / batch_size; } bias += batch_gradient[weights.size()] / batch_size; + +// batch_gradient->assign(batch_gradient->size(), Float64{0.0}); } }; + class Momentum : public IWeightsUpdater { public: - Momentum() {} - Momentum (Float64 alpha) : alpha_(alpha) {} - void update(UInt32 batch_size, std::vector & weights, Float64 & bias, const std::vector & batch_gradient) override { - /// batch_size is already checked to be greater than 0 + Momentum() + {} - if (accumulated_gradient.size() == 0) + Momentum(Float64 alpha) : alpha_(alpha) + {} + + void update(UInt32 batch_size, + std::vector & weights, Float64 & bias, + const std::vector & batch_gradient) override + { + /// batch_size is already checked to be greater than 0 + if (accumulated_gradient.empty()) { accumulated_gradient.resize(batch_gradient.size(), Float64{0.0}); } + for (size_t i = 0; i < batch_gradient.size(); ++i) { - accumulated_gradient[i] = accumulated_gradient[i] * alpha_ + batch_gradient[i]; + accumulated_gradient[i] = accumulated_gradient[i] * alpha_ + batch_gradient[i] / batch_size; } for (size_t i = 0; i < weights.size(); ++i) { - weights[i] += accumulated_gradient[i] / batch_size; + weights[i] += accumulated_gradient[i]; } - bias += accumulated_gradient[weights.size()] / batch_size; + bias += accumulated_gradient[weights.size()]; } - virtual void merge(const IWeightsUpdater & rhs, Float64 frac, Float64 rhs_frac) override { - auto & momentum_rhs = static_cast(rhs); + + virtual void merge(const IWeightsUpdater & rhs, Float64 frac, Float64 rhs_frac) override + { + auto &momentum_rhs = static_cast(rhs); for (size_t i = 0; i < accumulated_gradient.size(); ++i) { - accumulated_gradient[i] = accumulated_gradient[i] * frac + momentum_rhs.accumulated_gradient[i] * rhs_frac; + accumulated_gradient[i] = accumulated_gradient[i] * frac + + momentum_rhs.accumulated_gradient[i] * rhs_frac; } } + void write(WriteBuffer &buf) const override + { + writeBinary(accumulated_gradient, buf); + } + + void read(ReadBuffer &buf) override + { + readBinary(accumulated_gradient, buf); + } + private: Float64 alpha_{0.1}; std::vector accumulated_gradient; }; + + class Nesterov : public IWeightsUpdater { public: - Nesterov() {} - Nesterov (Float64 alpha) : alpha_(alpha) {} - void update(UInt32 batch_size, std::vector & weights, Float64 & bias, const std::vector & batch_gradient) override { - if (accumulated_gradient.size() == 0) + Nesterov() + {} + + Nesterov(Float64 alpha) : alpha_(alpha) + {} + + void add_to_batch(std::vector * batch_gradient, std::shared_ptr gc, + const std::vector & weights, Float64 bias, + Float64 learning_rate, Float64 target, const IColumn ** columns, size_t row_num) override + { + if (accumulated_gradient.empty()) + { + accumulated_gradient.resize(batch_gradient->size(), Float64{0.0}); + } + + std::vector shifted_weights(weights.size()); + for (size_t i = 0; i != shifted_weights.size(); ++i) + { + shifted_weights[i] = weights[i] + accumulated_gradient[i] * alpha_; + } + auto shifted_bias = bias + accumulated_gradient[weights.size()] * alpha_; + + gc->compute(batch_gradient, shifted_weights, shifted_bias, learning_rate, target, columns, row_num); + } + + void update(UInt32 batch_size, + std::vector & weights, Float64 & bias, + const std::vector & batch_gradient) override + { + if (accumulated_gradient.empty()) { accumulated_gradient.resize(batch_gradient.size(), Float64{0.0}); } + for (size_t i = 0; i < batch_gradient.size(); ++i) { - accumulated_gradient[i] = accumulated_gradient[i] * alpha_ + batch_gradient[i]; + accumulated_gradient[i] = accumulated_gradient[i] * alpha_ + batch_gradient[i] / batch_size; } for (size_t i = 0; i < weights.size(); ++i) { - weights[i] += accumulated_gradient[i] / batch_size; + weights[i] += accumulated_gradient[i]; } - bias += accumulated_gradient[weights.size()] / batch_size; - std::cout<<"BIAS " << bias<<'\n'; + bias += accumulated_gradient[weights.size()]; } - virtual void merge(const IWeightsUpdater & rhs, Float64 frac, Float64 rhs_frac) override { + + virtual void merge(const IWeightsUpdater & rhs, Float64 frac, Float64 rhs_frac) override + { auto & nesterov_rhs = static_cast(rhs); for (size_t i = 0; i < accumulated_gradient.size(); ++i) { - accumulated_gradient[i] = accumulated_gradient[i] * frac + nesterov_rhs.accumulated_gradient[i] * rhs_frac; + accumulated_gradient[i] = + accumulated_gradient[i] * frac + nesterov_rhs.accumulated_gradient[i] * rhs_frac; } } - virtual std::vector get_update(UInt32 sz, UInt32 batch_size) override { - if (accumulated_gradient.size() == 0) - { - accumulated_gradient.resize(sz, Float64{0.0}); - return accumulated_gradient; - } - std::vector delta(accumulated_gradient.size()); - // std::cout<<"\n\nHK\n\n"; - for (size_t i = 0; i < delta.size(); ++i) - { - delta[i] = accumulated_gradient[i] * alpha_ / batch_size; - } - return delta; - } -Float64 alpha_{0.1}; -std::vector accumulated_gradient; + void write(WriteBuffer &buf) const override + { + writeBinary(accumulated_gradient, buf); + } + + void read(ReadBuffer &buf) override + { + readBinary(accumulated_gradient, buf); + } +// virtual std::vector get_update(UInt32 sz, UInt32 batch_size) override +// { +// if (accumulated_gradient.size() == 0) +// { +// accumulated_gradient.resize(sz, Float64{0.0}); +// return accumulated_gradient; +// } +// std::vector delta(accumulated_gradient.size()); +// // std::cout<<"\n\nHK\n\n"; +// for (size_t i = 0; i < delta.size(); ++i) +// { +// delta[i] = accumulated_gradient[i] * alpha_ / batch_size; +// } +// return delta; +// } + +private: + Float64 alpha_{0.1}; + std::vector accumulated_gradient; }; + + +// TODO: проверить после изменения логики моментума +/* class Adam : public IWeightsUpdater { public: - Adam() {} - Adam (Float64 betta1, Float64 betta2) : betta1_(betta1), betta2_(betta2), betta1t_(betta1), betta2t_(betta2) {} - void update(UInt32 cur_batch, std::vector & weights, Float64 & bias, const std::vector & batch_gradient) override { + Adam() + {} + + Adam(Float64 betta1, Float64 betta2) : betta1_(betta1), betta2_(betta2), betta1t_(betta1), betta2t_(betta2) + {} + + void update(UInt32 cur_batch, + std::vector & weights, Float64 & bias, + std::vector * batch_gradient) override + { if (mt_.size() == 0) { mt_.resize(batch_gradient.size(), Float64{0.0}); @@ -325,11 +449,13 @@ public: { mt_[i] = mt_[i] * betta1_ + (1 - betta1_) * batch_gradient[i]; vt_[i] = vt_[i] * betta2_ + (1 - betta2_) * batch_gradient[i] * batch_gradient[i]; - if (t < 8) { + if (t < 8) + { mt_[i] = mt_[i] / (1 - betta1t_); betta1t_ *= betta1_; } - if (t < 850) { + if (t < 850) + { vt_[i] = vt_[i] / (1 - betta2t_); betta2t_ *= betta2_; } @@ -341,23 +467,33 @@ public: bias += (mt_[weights.size()] / (sqrt(vt_[weights.size()] + eps))) / cur_batch; t += 1; } - virtual void merge(const IWeightsUpdater & rhs, Float64 frac, Float64 rhs_frac) override { - auto & adam_rhs = static_cast(rhs); + + virtual void merge(const IWeightsUpdater &rhs, Float64 frac, Float64 rhs_frac) override + { + auto &adam_rhs = static_cast(rhs); for (size_t i = 0; i < mt_.size(); ++i) { mt_[i] = mt_[i] * frac + adam_rhs.mt_[i] * rhs_frac; vt_[i] = vt_[i] * frac + adam_rhs.vt_[i] * rhs_frac; } } -Float64 betta1_{0.2}; -Float64 betta2_{0.3}; -Float64 betta1t_{0.3}; -Float64 betta2t_{0.3}; -UInt32 t = 0; -std::vector mt_; -std::vector vt_; -}; +private: + Float64 betta1_{0.2}; + Float64 betta2_{0.3}; + Float64 betta1t_{0.3}; + Float64 betta2t_{0.3}; + UInt32 t = 0; + std::vector mt_; + std::vector vt_; +}; + */ + + +/** +* LinearModelData is a class which manages current state of learning +* and is stored as AggregateFunctionState +*/ class LinearModelData { public: @@ -365,33 +501,53 @@ public: {} LinearModelData(Float64 learning_rate, - UInt32 param_num, - UInt32 batch_capacity, - std::shared_ptr gc, - std::shared_ptr wu) - : learning_rate(learning_rate), - batch_capacity(batch_capacity), - gradient_computer(std::move(gc)), - weights_updater(std::move(wu)) + UInt32 param_num, + UInt32 batch_capacity, + std::shared_ptr gc, + std::shared_ptr wu) + : learning_rate(learning_rate), + batch_capacity(batch_capacity), + batch_size(0), + gradient_computer(std::move(gc)), + weights_updater(std::move(wu)) { weights.resize(param_num, Float64{0.0}); - batch_size = 0; + gradient_batch.resize(param_num + 1, Float64{0.0}); } - void add(const IColumn ** columns, size_t row_num) + void add(const IColumn **columns, size_t row_num) { /// first column stores target; features start from (columns + 1) - const auto & target = static_cast &>(*columns[0]).getData()[row_num]; - - auto delta = weights_updater->get_update(weights.size() + 1, batch_capacity); - Float64 delta_bias = bias + delta[weights.size()]; - delta.resize(weights.size()); - for (size_t i = 0; i < weights.size(); ++i) { - delta[i] += weights[i]; - } - - gradient_computer->compute(delta, delta_bias, learning_rate, target, columns + 1, row_num); - // gradient_computer->compute(weights, bias, learning_rate, target, columns + 1, row_num); + const auto &target = static_cast &>(*columns[0]).getData()[row_num]; + +// auto delta = weights_updater->get_update(weights.size() + 1, batch_capacity); +// Float64 delta_bias = bias + delta[weights.size()]; +// delta.resize(weights.size()); +// for (size_t i = 0; i < weights.size(); ++i) +// { +// delta[i] += weights[i]; +// } + +// gradient_computer->compute(delta, delta_bias, learning_rate, target, columns + 1, row_num); +// gradient_computer->compute(weights, bias, learning_rate, target, columns + 1, row_num); + std::cout << "\nBATCH BEFORE\n"; + for (auto i : gradient_batch) + std::cout << i << " "; + std::cout << "\nhello\n"; + + + weights_updater->add_to_batch(&gradient_batch, gradient_computer, + weights, bias, learning_rate, target, columns, row_num); + + + std::cout << "BATCH AFTER\n"; + for (auto i : gradient_batch) + std::cout << i << " "; + std::cout << "\nhello\n\n"; + + if (iter_num == 10) + exit(1); + ++batch_size; if (batch_size == batch_capacity) { @@ -399,7 +555,7 @@ public: } } - void merge(const LinearModelData & rhs) + void merge(const LinearModelData &rhs) { if (iter_num == 0 && rhs.iter_num == 0) return; @@ -421,63 +577,90 @@ public: weights_updater->merge(*rhs.weights_updater, frac, rhs_frac); } - void write(WriteBuffer & buf) const + void write(WriteBuffer &buf) const { writeBinary(bias, buf); writeBinary(weights, buf); writeBinary(iter_num, buf); + writeBinary(gradient_batch, buf); writeBinary(batch_size, buf); - gradient_computer->write(buf); + weights_updater->write(buf); +// gradient_computer->write(buf); } - void read(ReadBuffer & buf) + void read(ReadBuffer &buf) { readBinary(bias, buf); readBinary(weights, buf); readBinary(iter_num, buf); + readBinary(gradient_batch, buf); readBinary(batch_size, buf); - gradient_computer->read(buf); + weights_updater->read(buf); +// gradient_computer->read(buf); } - Float64 predict(const std::vector & predict_feature) const + Float64 predict(const std::vector &predict_feature) const { /// не обновляем веса при предикте, т.к. это может замедлить предсказание - /// однако можно например обновлять их при каждом мердже не зависимо от того, сколько элементнов в батче + /// однако можно например обновлять их при каждом мердже независимо от того, сколько элементнов в батче // if (cur_batch) // { // update_weights(); // } + std::cout << "\n\nWEIGHTS: "; + for (size_t i = 0; i != weights.size(); ++i) { + std::cout << weights[i] << " "; + } + std::cout << "\n\n"; + return gradient_computer->predict(predict_feature, weights, bias); } - void predict_for_all(ColumnVector::Container & container, Block & block, const ColumnNumbers & arguments) const + + void predict_for_all(ColumnVector::Container &container, Block &block, const ColumnNumbers &arguments) const { + std::cout << "\n\nWEIGHTS: "; + for (size_t i = 0; i != weights.size(); ++i) { + std::cout << weights[i] << " "; + } + std::cout << "\n\n"; + gradient_computer->predict_for_all(container, block, arguments, weights, bias); } private: std::vector weights; + Float64 bias{0.0}; + Float64 learning_rate; UInt32 batch_capacity; - Float64 bias{0.0}; + UInt32 iter_num = 0; + std::vector gradient_batch; UInt32 batch_size; + std::shared_ptr gradient_computer; std::shared_ptr weights_updater; + /** + * The function is called when we want to flush current batch and make a step with it + */ void update_state() { if (batch_size == 0) return; - weights_updater->update(batch_size, weights, bias, gradient_computer->get()); +// weights_updater->update(batch_size, weights, bias, gradient_batch); + + // /// use pointer to gradient_batch, because some methods (e.g. simple stochastic descent) require to reset it + weights_updater->update(batch_size, weights, bias, gradient_batch); batch_size = 0; ++iter_num; - gradient_computer->reset(); - //TODO ask: для нестерова и адама не очень. Нужно добавить другую функцию + gradient_batch.assign(gradient_batch.size(), Float64{0.0}); } }; + template < /// Implemented Machine Learning method typename Data, @@ -490,19 +673,19 @@ public: String getName() const override { return Name::name; } explicit AggregateFunctionMLMethod(UInt32 param_num, - std::shared_ptr gradient_computer, - std::shared_ptr weights_updater, - Float64 learning_rate, - UInt32 batch_size, - const DataTypes & argument_types, - const Array & params) + std::shared_ptr gradient_computer, + std::shared_ptr weights_updater, + Float64 learning_rate, + UInt32 batch_size, + const DataTypes & argument_types, + const Array & params) : IAggregateFunctionDataHelper>(argument_types, params), param_num(param_num), learning_rate(learning_rate), batch_size(batch_size), gc(std::move(gradient_computer)), - wu(std::move(weights_updater)) - {} + wu(std::move(weights_updater)) { + } DataTypePtr getReturnType() const override { @@ -538,7 +721,8 @@ public: void predictResultInto(ConstAggregateDataPtr place, IColumn & to, Block & block, const ColumnNumbers & arguments) const { if (arguments.size() != param_num + 1) - throw Exception("Predict got incorrect number of arguments. Got: " + std::to_string(arguments.size()) + ". Required: " + std::to_string(param_num + 1), + throw Exception("Predict got incorrect number of arguments. Got: " + + std::to_string(arguments.size()) + ". Required: " + std::to_string(param_num + 1), ErrorCodes::NUMBER_OF_ARGUMENTS_DOESNT_MATCH); auto &column = dynamic_cast &>(to); diff --git a/dbms/tests/queries/0_stateless/00950_ml_test.sql b/dbms/tests/queries/0_stateless/00950_ml_test.sql index 0a009c29d29..46f64a1f1dd 100644 --- a/dbms/tests/queries/0_stateless/00950_ml_test.sql +++ b/dbms/tests/queries/0_stateless/00950_ml_test.sql @@ -11,7 +11,7 @@ CREATE TABLE IF NOT EXISTS test.defaults insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0), (-1.099, 2.755, -3.060, 20.0, 40.0), (1.090, 2.945, -2.346, 20.0, 40.0), (0.305, 2.179, -1.205, 20.0, 40.0), (-0.925, 0.702, 1.134, 20.0, 40.0), (3.178, -1.316, 7.221, 20.0, 40.0), (-2.756, -0.473, 2.569, 20.0, 40.0), (3.665, 2.303, 0.226, 20.0, 40.0), (1.662, 1.951, -0.070, 20.0, 40.0), (2.869, 0.593, 3.249, 20.0, 40.0), (0.818, -0.593, 4.594, 20.0, 40.0), (-1.917, 0.916, 0.209, 20.0, 40.0), (2.706, 1.523, 1.307, 20.0, 40.0), (0.219, 2.162, -1.214, 20.0, 40.0), (-4.510, 1.376, -2.007, 20.0, 40.0), (4.284, -0.515, 6.173, 20.0, 40.0), (-1.101, 2.810, -3.170, 20.0, 40.0), (-1.810, -1.117, 4.329, 20.0, 40.0), (0.055, 1.115, 0.797, 20.0, 40.0), (-2.178, 2.904, -3.898, 20.0, 40.0), (-3.494, -1.814, 4.882, 20.0, 40.0), (3.027, 0.476, 3.562, 20.0, 40.0), (-1.434, 1.151, -0.018, 20.0, 40.0), (1.180, 0.992, 1.606, 20.0, 40.0), (0.015, 0.971, 1.067, 20.0, 40.0), (-0.511, -0.875, 4.495, 20.0, 40.0), (0.961, 2.348, -1.216, 20.0, 40.0), (-2.279, 0.038, 1.785, 20.0, 40.0), (-1.568, -0.248, 2.712, 20.0, 40.0), (-0.496, 0.366, 2.020, 20.0, 40.0), (1.177, -1.401, 6.390, 20.0, 40.0), (2.882, -1.442, 7.325, 20.0, 40.0), (-1.066, 1.817, -1.167, 20.0, 40.0), (-2.144, 2.791, -3.655, 20.0, 40.0), (-4.370, 2.228, -3.642, 20.0, 40.0), (3.996, 2.775, -0.553, 20.0, 40.0), (0.289, 2.055, -0.965, 20.0, 40.0), (-0.588, -1.601, 5.908, 20.0, 40.0), (-1.801, 0.417, 1.265, 20.0, 40.0), (4.375, -1.499, 8.186, 20.0, 40.0), (-2.618, 0.038, 1.615, 20.0, 40.0), (3.616, -0.833, 6.475, 20.0, 40.0), (-4.045, -1.558, 4.094, 20.0, 40.0), (-3.962, 0.636, -0.253, 20.0, 40.0), (3.505, 2.625, -0.497, 20.0, 40.0), (3.029, -0.523, 5.560, 20.0, 40.0), (-3.520, -0.474, 2.188, 20.0, 40.0), (2.430, -1.469, 7.154, 20.0, 40.0), (1.547, -1.654, 7.082, 20.0, 40.0), (-1.370, 0.575, 1.165, 20.0, 40.0), (-1.869, -1.555, 5.176, 20.0, 40.0), (3.536, 2.841, -0.913, 20.0, 40.0), (-3.810, 1.220, -1.344, 20.0, 40.0), (-1.971, 1.462, -0.910, 20.0, 40.0), (-0.243, 0.167, 2.545, 20.0, 40.0), (-1.403, 2.645, -2.991, 20.0, 40.0), (0.532, -0.114, 3.494, 20.0, 40.0), (-1.678, 0.975, 0.212, 20.0, 40.0), (-0.656, 2.140, -1.609, 20.0, 40.0), (1.743, 2.631, -1.390, 20.0, 40.0), (2.586, 2.943, -1.593, 20.0, 40.0), (-0.512, 2.969, -3.195, 20.0, 40.0), (2.283, -0.100, 4.342, 20.0, 40.0), (-4.293, 0.872, -0.890, 20.0, 40.0), (3.411, 1.300, 2.106, 20.0, 40.0), (-0.281, 2.951, -3.042, 20.0, 40.0), (-4.442, 0.384, 0.012, 20.0, 40.0), (1.194, 1.746, 0.104, 20.0, 40.0), (-1.152, 1.862, -1.300, 20.0, 40.0), (1.362, -1.341, 6.363, 20.0, 40.0), (-4.488, 2.618, -4.481, 20.0, 40.0), (3.419, -0.564, 5.837, 20.0, 40.0), (-3.392, 0.396, 0.512, 20.0, 40.0), (-1.629, -0.909, 4.003, 20.0, 40.0), (4.447, -1.088, 7.399, 20.0, 40.0), (-1.232, 1.699, -1.014, 20.0, 40.0), (-1.286, -0.609, 3.575, 20.0, 40.0), (2.437, 2.796, -1.374, 20.0, 40.0), (-4.864, 1.989, -3.410, 20.0, 40.0), (-1.716, -1.399, 4.940, 20.0, 40.0), (-3.084, 1.858, -2.259, 20.0, 40.0), (2.828, -0.319, 5.053, 20.0, 40.0), (-1.226, 2.586, -2.786, 20.0, 40.0), (2.456, 0.092, 4.044, 20.0, 40.0), (-0.989, 2.375, -2.245, 20.0, 40.0), (3.268, 0.935, 2.765, 20.0, 40.0), (-4.128, -1.995, 4.927, 20.0, 40.0), (-1.083, 2.197, -1.935, 20.0, 40.0), (-3.471, -1.198, 3.660, 20.0, 40.0), (4.617, -1.136, 7.579, 20.0, 40.0), (2.054, -1.675, 7.378, 20.0, 40.0), (4.106, 2.326, 0.402, 20.0, 40.0), (1.558, 0.310, 3.158, 20.0, 40.0), (0.792, 0.900, 1.596, 20.0, 40.0), (-3.229, 0.300, 0.785, 20.0, 40.0), (3.787, -0.793, 6.479, 20.0, 40.0), (1.786, 2.288, -0.684, 20.0, 40.0), (2.643, 0.223, 3.875, 20.0, 40.0), (-3.592, 2.122, -3.040, 20.0, 40.0), (4.519, -1.760, 8.779, 20.0, 40.0), (3.221, 2.255, 0.101, 20.0, 40.0), (4.151, 1.788, 1.500, 20.0, 40.0), (-1.033, -1.195, 4.874, 20.0, 40.0), (-1.636, -1.037, 4.257, 20.0, 40.0), (-3.548, 1.911, -2.596, 20.0, 40.0), (4.829, -0.293, 6.001, 20.0, 40.0), (-4.684, -1.664, 3.986, 20.0, 40.0), (4.531, -0.503, 6.271, 20.0, 40.0), (-3.503, -1.606, 4.460, 20.0, 40.0), (-2.036, -1.522, 5.027, 20.0, 40.0), (-0.473, -0.617, 3.997, 20.0, 40.0), (-1.554, -1.630, 5.483, 20.0, 40.0), (-3.567, -1.043, 3.302, 20.0, 40.0), (-2.038, 0.579, 0.823, 20.0, 40.0), (-3.040, 0.857, -0.233, 20.0, 40.0), (4.610, 0.562, 4.181, 20.0, 40.0), (-3.323, -1.938, 5.215, 20.0, 40.0), (4.314, 1.720, 1.717, 20.0, 40.0), (-1.220, 0.615, 1.161, 20.0, 40.0), (-2.556, 1.120, -0.519, 20.0, 40.0), (-3.717, -0.108, 1.358, 20.0, 40.0), (4.689, -1.826, 8.996, 20.0, 40.0), (3.452, 0.506, 3.713, 20.0, 40.0), (2.472, 0.612, 3.012, 20.0, 40.0), (3.452, 0.450, 3.826, 20.0, 40.0), (1.207, 2.585, -1.567, 20.0, 40.0), (-4.826, 1.090, -1.593, 20.0, 40.0), (3.116, -1.118, 6.794, 20.0, 40.0), (0.448, 2.732, -2.240, 20.0, 40.0), (-1.096, -0.525, 3.503, 20.0, 40.0), (-4.680, -0.238, 1.137, 20.0, 40.0), (2.552, -1.403, 7.082, 20.0, 40.0), (0.719, 2.997, -2.635, 20.0, 40.0), (0.347, -1.966, 7.105, 20.0, 40.0), (2.958, -0.404, 5.288, 20.0, 40.0), (0.722, -1.950, 7.261, 20.0, 40.0), (-2.851, -0.986, 3.546, 20.0, 40.0), (-4.316, -0.439, 1.721, 20.0, 40.0), (-1.685, -0.201, 2.560, 20.0, 40.0), (1.856, 0.190, 3.549, 20.0, 40.0), (-2.052, 0.206, 1.562, 20.0, 40.0), (-2.504, -0.646, 3.041, 20.0, 40.0), (3.235, 0.882, 2.854, 20.0, 40.0), (-1.366, -1.573, 5.463, 20.0, 40.0), (-3.447, 2.419, -3.562, 20.0, 40.0), (4.155, 2.092, 0.893, 20.0, 40.0), (-0.935, 0.209, 2.116, 20.0, 40.0), (3.117, -1.821, 8.201, 20.0, 40.0), (3.759, 0.577, 3.725, 20.0, 40.0), (-0.938, 2.992, -3.453, 20.0, 40.0), (-0.525, 2.341, -1.945, 20.0, 40.0), (4.540, 2.625, 0.019, 20.0, 40.0), (-2.097, 1.190, -0.429, 20.0, 40.0), (-2.672, 1.983, -2.302, 20.0, 40.0), (-3.038, -1.490, 4.460, 20.0, 40.0), (-0.943, 2.149, -1.770, 20.0, 40.0), (0.739, 1.598, 0.174, 20.0, 40.0), (1.828, 1.853, 0.208, 20.0, 40.0), (4.856, 0.137, 5.153, 20.0, 40.0), (-1.617, 0.468, 1.255, 20.0, 40.0), (-1.972, 2.053, -2.092, 20.0, 40.0), (-4.633, 1.389, -2.094, 20.0, 40.0), (-3.628, -1.156, 3.498, 20.0, 40.0), (3.597, 1.034, 2.731, 20.0, 40.0), (-1.488, -0.002, 2.261, 20.0, 40.0), (0.749, 1.921, -0.468, 20.0, 40.0), (1.304, -1.371, 6.394, 20.0, 40.0), (4.587, 2.936, -0.579, 20.0, 40.0), (-2.241, 1.791, -1.703, 20.0, 40.0), (-2.945, 1.372, -1.216, 20.0, 40.0), (1.375, 0.395, 2.898, 20.0, 40.0), (-1.281, -0.641, 3.642, 20.0, 40.0), (2.178, 0.895, 2.299, 20.0, 40.0), (3.031, -0.786, 6.087, 20.0, 40.0), (-1.385, -0.375, 3.058, 20.0, 40.0), (4.041, -0.431, 5.882, 20.0, 40.0), (0.480, -0.507, 4.254, 20.0, 40.0), (-3.797, 0.140, 0.822, 20.0, 40.0), (2.355, 2.502, -0.827, 20.0, 40.0), (1.376, -1.583, 6.854, 20.0, 40.0), (0.164, 1.405, 0.273, 20.0, 40.0), (-1.273, 1.471, -0.579, 20.0, 40.0), (0.770, 2.246, -1.107, 20.0, 40.0), (4.552, 2.904, -0.533, 20.0, 40.0), (4.259, -1.772, 8.674, 20.0, 40.0), (-0.309, 1.159, 0.528, 20.0, 40.0), (3.581, 2.700, -0.610, 20.0, 40.0), (-3.202, 0.346, 0.707, 20.0, 40.0), (-1.575, 1.242, -0.271, 20.0, 40.0), (-1.584, -0.493, 3.194, 20.0, 40.0), (-3.778, 0.150, 0.810, 20.0, 40.0), (-4.675, 1.749, -2.835, 20.0, 40.0), (3.567, -0.792, 6.367, 20.0, 40.0), (-0.417, 1.399, -0.006, 20.0, 40.0), (-4.672, 2.007, -3.349, 20.0, 40.0), (-1.034, 0.196, 2.090, 20.0, 40.0), (-3.796, 2.496, -3.890, 20.0, 40.0), (3.532, -0.497, 5.759, 20.0, 40.0), (4.868, -1.359, 8.151, 20.0, 40.0), (-0.769, 0.302, 2.011, 20.0, 40.0), (4.475, 2.612, 0.014, 20.0, 40.0), (-3.532, -0.395, 2.024, 20.0, 40.0), (0.322, 0.675, 1.812, 20.0, 40.0), (-2.028, -1.942, 5.870, 20.0, 40.0), (1.810, -1.244, 6.392, 20.0, 40.0), (-0.783, 1.242, 0.124, 20.0, 40.0), (-4.745, -1.300, 3.227, 20.0, 40.0), (1.902, 1.973, 0.005, 20.0, 40.0), (-3.453, -1.429, 4.132, 20.0, 40.0), (1.559, 0.986, 1.808, 20.0, 40.0), (0.128, 2.754, -2.443, 20.0, 40.0), (2.759, 1.727, 0.926, 20.0, 40.0), (-4.468, 1.690, -2.614, 20.0, 40.0), (-2.368, -1.922, 5.659, 20.0, 40.0), (-2.766, 2.128, -2.640, 20.0, 40.0), (0.967, -1.825, 7.133, 20.0, 40.0), (-2.854, 2.855, -4.136, 20.0, 40.0), (-2.944, 1.875, -2.222, 20.0, 40.0), (-2.632, -0.983, 3.649, 20.0, 40.0), (2.427, 2.239, -0.266, 20.0, 40.0), (-1.726, -0.838, 3.812, 20.0, 40.0), (0.007, -0.903, 4.809, 20.0, 40.0), (-2.013, 1.092, -0.191, 20.0, 40.0), (-0.449, 0.970, 0.836, 20.0, 40.0), (1.396, 0.411, 2.876, 20.0, 40.0), (-1.115, -1.790, 6.023, 20.0, 40.0), (3.748, 1.917, 1.039, 20.0, 40.0), (2.978, 1.043, 2.404, 20.0, 40.0), (-3.969, 2.514, -4.013, 20.0, 40.0), (4.455, -0.050, 5.328, 20.0, 40.0), (-3.065, -0.846, 3.160, 20.0, 40.0), (-1.069, 2.167, -1.869, 20.0, 40.0), (3.016, -1.393, 7.294, 20.0, 40.0), (0.045, -1.928, 6.879, 20.0, 40.0), (-2.555, -0.984, 3.690, 20.0, 40.0), (-1.995, -0.054, 2.111, 20.0, 40.0), (4.600, -0.509, 6.318, 20.0, 40.0), (-1.942, 1.215, -0.402, 20.0, 40.0), (1.262, 2.765, -1.899, 20.0, 40.0), (2.617, -1.106, 6.521, 20.0, 40.0), (1.737, 0.554, 2.761, 20.0, 40.0), (-2.197, 0.632, 0.638, 20.0, 40.0), (4.768, 2.618, 0.147, 20.0, 40.0), (-3.737, -0.939, 3.010, 20.0, 40.0), (-2.623, 0.595, 0.499, 20.0, 40.0), (4.752, -0.340, 6.057, 20.0, 40.0), (2.333, -1.037, 6.240, 20.0, 40.0), (4.234, -1.882, 8.881, 20.0, 40.0), (-3.393, -0.812, 2.927, 20.0, 40.0), (0.885, 1.383, 0.678, 20.0, 40.0), (0.123, 2.937, -2.812, 20.0, 40.0), (2.969, 0.760, 2.964, 20.0, 40.0), (-4.929, 1.251, -1.967, 20.0, 40.0), (1.916, 2.223, -0.488, 20.0, 40.0), (-0.020, -1.740, 6.469, 20.0, 40.0), (0.702, -1.272, 5.895, 20.0, 40.0), (2.496, 2.648, -1.048, 20.0, 40.0), (4.067, -1.475, 7.984, 20.0, 40.0), (-3.717, 1.851, -2.561, 20.0, 40.0), (1.678, -0.624, 5.088, 20.0, 40.0), (1.073, 0.695, 2.146, 20.0, 40.0), (1.842, -0.749, 5.419, 20.0, 40.0), (-3.518, 1.909, -2.578, 20.0, 40.0), (2.229, 1.189, 1.737, 20.0, 40.0), (4.987, 2.893, -0.292, 20.0, 40.0), (-4.809, 1.043, -1.490, 20.0, 40.0), (-0.241, -0.728, 4.334, 20.0, 40.0), (-3.331, 0.590, 0.156, 20.0, 40.0), (-0.455, 2.621, -2.470, 20.0, 40.0), (1.492, 1.223, 1.301, 20.0, 40.0), (3.948, 2.841, -0.709, 20.0, 40.0), (0.732, 0.446, 2.475, 20.0, 40.0), (2.400, 2.390, -0.579, 20.0, 40.0), (-2.718, 1.427, -1.213, 20.0, 40.0), (-1.826, 1.451, -0.815, 20.0, 40.0), (1.125, 0.438, 2.686, 20.0, 40.0), (-4.918, 1.880, -3.219, 20.0, 40.0), (3.068, -0.442, 5.418, 20.0, 40.0), (1.982, 1.201, 1.589, 20.0, 40.0), (0.701, -1.709, 6.768, 20.0, 40.0), (-1.496, 2.564, -2.877, 20.0, 40.0), (-3.812, 0.974, -0.853, 20.0, 40.0), (-3.405, 2.018, -2.739, 20.0, 40.0), (2.211, 2.889, -1.674, 20.0, 40.0), (-2.481, 2.931, -4.103, 20.0, 40.0), (-3.721, 2.765, -4.391, 20.0, 40.0), (-1.768, -1.292, 4.699, 20.0, 40.0), (-4.462, 1.058, -1.347, 20.0, 40.0), (-3.516, -1.942, 5.126, 20.0, 40.0), (0.485, 2.420, -1.597, 20.0, 40.0), (-0.492, 0.242, 2.270, 20.0, 40.0), (4.245, 1.689, 1.744, 20.0, 40.0), (2.234, 0.364, 3.389, 20.0, 40.0), (2.629, 2.224, -0.134, 20.0, 40.0), (-4.375, 1.221, -1.630, 20.0, 40.0), (-0.618, 1.374, -0.057, 20.0, 40.0), (-2.580, -1.604, 4.918, 20.0, 40.0), (0.159, 1.104, 0.871, 20.0, 40.0), (-3.597, 0.975, -0.749, 20.0, 40.0); DROP TABLE IF EXISTS test.model; -create table test.model engine = Memory as select LinearRegressionState(0.1, 5, 2.0)(target, param1, param2) as state from test.defaults; +create table test.model engine = Memory as select LinearRegressionState(0.01, 5, 1.0)(target, param1, param2) as state from test.defaults; with (select state from test.model) as model select evalMLMethod(model, predict1, predict2) from test.defaults; diff --git a/dbms/tests/queries/0_stateless/00954_ml_test.sql b/dbms/tests/queries/0_stateless/00954_ml_test.sql index b1bce54036f..2df84c00d3f 100644 --- a/dbms/tests/queries/0_stateless/00954_ml_test.sql +++ b/dbms/tests/queries/0_stateless/00954_ml_test.sql @@ -11,7 +11,7 @@ CREATE TABLE IF NOT EXISTS test.defaults insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0), (-1.099, 2.755, -3.060, 20.0, 40.0), (1.090, 2.945, -2.346, 20.0, 40.0), (0.305, 2.179, -1.205, 20.0, 40.0), (-0.925, 0.702, 1.134, 20.0, 40.0), (3.178, -1.316, 7.221, 20.0, 40.0), (-2.756, -0.473, 2.569, 20.0, 40.0), (3.665, 2.303, 0.226, 20.0, 40.0), (1.662, 1.951, -0.070, 20.0, 40.0), (2.869, 0.593, 3.249, 20.0, 40.0), (0.818, -0.593, 4.594, 20.0, 40.0), (-1.917, 0.916, 0.209, 20.0, 40.0), (2.706, 1.523, 1.307, 20.0, 40.0), (0.219, 2.162, -1.214, 20.0, 40.0), (-4.510, 1.376, -2.007, 20.0, 40.0), (4.284, -0.515, 6.173, 20.0, 40.0), (-1.101, 2.810, -3.170, 20.0, 40.0), (-1.810, -1.117, 4.329, 20.0, 40.0), (0.055, 1.115, 0.797, 20.0, 40.0), (-2.178, 2.904, -3.898, 20.0, 40.0), (-3.494, -1.814, 4.882, 20.0, 40.0), (3.027, 0.476, 3.562, 20.0, 40.0), (-1.434, 1.151, -0.018, 20.0, 40.0), (1.180, 0.992, 1.606, 20.0, 40.0), (0.015, 0.971, 1.067, 20.0, 40.0), (-0.511, -0.875, 4.495, 20.0, 40.0), (0.961, 2.348, -1.216, 20.0, 40.0), (-2.279, 0.038, 1.785, 20.0, 40.0), (-1.568, -0.248, 2.712, 20.0, 40.0), (-0.496, 0.366, 2.020, 20.0, 40.0), (1.177, -1.401, 6.390, 20.0, 40.0), (2.882, -1.442, 7.325, 20.0, 40.0), (-1.066, 1.817, -1.167, 20.0, 40.0), (-2.144, 2.791, -3.655, 20.0, 40.0), (-4.370, 2.228, -3.642, 20.0, 40.0), (3.996, 2.775, -0.553, 20.0, 40.0), (0.289, 2.055, -0.965, 20.0, 40.0), (-0.588, -1.601, 5.908, 20.0, 40.0), (-1.801, 0.417, 1.265, 20.0, 40.0), (4.375, -1.499, 8.186, 20.0, 40.0), (-2.618, 0.038, 1.615, 20.0, 40.0), (3.616, -0.833, 6.475, 20.0, 40.0), (-4.045, -1.558, 4.094, 20.0, 40.0), (-3.962, 0.636, -0.253, 20.0, 40.0), (3.505, 2.625, -0.497, 20.0, 40.0), (3.029, -0.523, 5.560, 20.0, 40.0), (-3.520, -0.474, 2.188, 20.0, 40.0), (2.430, -1.469, 7.154, 20.0, 40.0), (1.547, -1.654, 7.082, 20.0, 40.0), (-1.370, 0.575, 1.165, 20.0, 40.0), (-1.869, -1.555, 5.176, 20.0, 40.0), (3.536, 2.841, -0.913, 20.0, 40.0), (-3.810, 1.220, -1.344, 20.0, 40.0), (-1.971, 1.462, -0.910, 20.0, 40.0), (-0.243, 0.167, 2.545, 20.0, 40.0), (-1.403, 2.645, -2.991, 20.0, 40.0), (0.532, -0.114, 3.494, 20.0, 40.0), (-1.678, 0.975, 0.212, 20.0, 40.0), (-0.656, 2.140, -1.609, 20.0, 40.0), (1.743, 2.631, -1.390, 20.0, 40.0), (2.586, 2.943, -1.593, 20.0, 40.0), (-0.512, 2.969, -3.195, 20.0, 40.0), (2.283, -0.100, 4.342, 20.0, 40.0), (-4.293, 0.872, -0.890, 20.0, 40.0), (3.411, 1.300, 2.106, 20.0, 40.0), (-0.281, 2.951, -3.042, 20.0, 40.0), (-4.442, 0.384, 0.012, 20.0, 40.0), (1.194, 1.746, 0.104, 20.0, 40.0), (-1.152, 1.862, -1.300, 20.0, 40.0), (1.362, -1.341, 6.363, 20.0, 40.0), (-4.488, 2.618, -4.481, 20.0, 40.0), (3.419, -0.564, 5.837, 20.0, 40.0), (-3.392, 0.396, 0.512, 20.0, 40.0), (-1.629, -0.909, 4.003, 20.0, 40.0), (4.447, -1.088, 7.399, 20.0, 40.0), (-1.232, 1.699, -1.014, 20.0, 40.0), (-1.286, -0.609, 3.575, 20.0, 40.0), (2.437, 2.796, -1.374, 20.0, 40.0), (-4.864, 1.989, -3.410, 20.0, 40.0), (-1.716, -1.399, 4.940, 20.0, 40.0), (-3.084, 1.858, -2.259, 20.0, 40.0), (2.828, -0.319, 5.053, 20.0, 40.0), (-1.226, 2.586, -2.786, 20.0, 40.0), (2.456, 0.092, 4.044, 20.0, 40.0), (-0.989, 2.375, -2.245, 20.0, 40.0), (3.268, 0.935, 2.765, 20.0, 40.0), (-4.128, -1.995, 4.927, 20.0, 40.0), (-1.083, 2.197, -1.935, 20.0, 40.0), (-3.471, -1.198, 3.660, 20.0, 40.0), (4.617, -1.136, 7.579, 20.0, 40.0), (2.054, -1.675, 7.378, 20.0, 40.0), (4.106, 2.326, 0.402, 20.0, 40.0), (1.558, 0.310, 3.158, 20.0, 40.0), (0.792, 0.900, 1.596, 20.0, 40.0), (-3.229, 0.300, 0.785, 20.0, 40.0), (3.787, -0.793, 6.479, 20.0, 40.0), (1.786, 2.288, -0.684, 20.0, 40.0), (2.643, 0.223, 3.875, 20.0, 40.0), (-3.592, 2.122, -3.040, 20.0, 40.0), (4.519, -1.760, 8.779, 20.0, 40.0), (3.221, 2.255, 0.101, 20.0, 40.0), (4.151, 1.788, 1.500, 20.0, 40.0), (-1.033, -1.195, 4.874, 20.0, 40.0), (-1.636, -1.037, 4.257, 20.0, 40.0), (-3.548, 1.911, -2.596, 20.0, 40.0), (4.829, -0.293, 6.001, 20.0, 40.0), (-4.684, -1.664, 3.986, 20.0, 40.0), (4.531, -0.503, 6.271, 20.0, 40.0), (-3.503, -1.606, 4.460, 20.0, 40.0), (-2.036, -1.522, 5.027, 20.0, 40.0), (-0.473, -0.617, 3.997, 20.0, 40.0), (-1.554, -1.630, 5.483, 20.0, 40.0), (-3.567, -1.043, 3.302, 20.0, 40.0), (-2.038, 0.579, 0.823, 20.0, 40.0), (-3.040, 0.857, -0.233, 20.0, 40.0), (4.610, 0.562, 4.181, 20.0, 40.0), (-3.323, -1.938, 5.215, 20.0, 40.0), (4.314, 1.720, 1.717, 20.0, 40.0), (-1.220, 0.615, 1.161, 20.0, 40.0), (-2.556, 1.120, -0.519, 20.0, 40.0), (-3.717, -0.108, 1.358, 20.0, 40.0), (4.689, -1.826, 8.996, 20.0, 40.0), (3.452, 0.506, 3.713, 20.0, 40.0), (2.472, 0.612, 3.012, 20.0, 40.0), (3.452, 0.450, 3.826, 20.0, 40.0), (1.207, 2.585, -1.567, 20.0, 40.0), (-4.826, 1.090, -1.593, 20.0, 40.0), (3.116, -1.118, 6.794, 20.0, 40.0), (0.448, 2.732, -2.240, 20.0, 40.0), (-1.096, -0.525, 3.503, 20.0, 40.0), (-4.680, -0.238, 1.137, 20.0, 40.0), (2.552, -1.403, 7.082, 20.0, 40.0), (0.719, 2.997, -2.635, 20.0, 40.0), (0.347, -1.966, 7.105, 20.0, 40.0), (2.958, -0.404, 5.288, 20.0, 40.0), (0.722, -1.950, 7.261, 20.0, 40.0), (-2.851, -0.986, 3.546, 20.0, 40.0), (-4.316, -0.439, 1.721, 20.0, 40.0), (-1.685, -0.201, 2.560, 20.0, 40.0), (1.856, 0.190, 3.549, 20.0, 40.0), (-2.052, 0.206, 1.562, 20.0, 40.0), (-2.504, -0.646, 3.041, 20.0, 40.0), (3.235, 0.882, 2.854, 20.0, 40.0), (-1.366, -1.573, 5.463, 20.0, 40.0), (-3.447, 2.419, -3.562, 20.0, 40.0), (4.155, 2.092, 0.893, 20.0, 40.0), (-0.935, 0.209, 2.116, 20.0, 40.0), (3.117, -1.821, 8.201, 20.0, 40.0), (3.759, 0.577, 3.725, 20.0, 40.0), (-0.938, 2.992, -3.453, 20.0, 40.0), (-0.525, 2.341, -1.945, 20.0, 40.0), (4.540, 2.625, 0.019, 20.0, 40.0), (-2.097, 1.190, -0.429, 20.0, 40.0), (-2.672, 1.983, -2.302, 20.0, 40.0), (-3.038, -1.490, 4.460, 20.0, 40.0), (-0.943, 2.149, -1.770, 20.0, 40.0), (0.739, 1.598, 0.174, 20.0, 40.0), (1.828, 1.853, 0.208, 20.0, 40.0), (4.856, 0.137, 5.153, 20.0, 40.0), (-1.617, 0.468, 1.255, 20.0, 40.0), (-1.972, 2.053, -2.092, 20.0, 40.0), (-4.633, 1.389, -2.094, 20.0, 40.0), (-3.628, -1.156, 3.498, 20.0, 40.0), (3.597, 1.034, 2.731, 20.0, 40.0), (-1.488, -0.002, 2.261, 20.0, 40.0), (0.749, 1.921, -0.468, 20.0, 40.0), (1.304, -1.371, 6.394, 20.0, 40.0), (4.587, 2.936, -0.579, 20.0, 40.0), (-2.241, 1.791, -1.703, 20.0, 40.0), (-2.945, 1.372, -1.216, 20.0, 40.0), (1.375, 0.395, 2.898, 20.0, 40.0), (-1.281, -0.641, 3.642, 20.0, 40.0), (2.178, 0.895, 2.299, 20.0, 40.0), (3.031, -0.786, 6.087, 20.0, 40.0), (-1.385, -0.375, 3.058, 20.0, 40.0), (4.041, -0.431, 5.882, 20.0, 40.0), (0.480, -0.507, 4.254, 20.0, 40.0), (-3.797, 0.140, 0.822, 20.0, 40.0), (2.355, 2.502, -0.827, 20.0, 40.0), (1.376, -1.583, 6.854, 20.0, 40.0), (0.164, 1.405, 0.273, 20.0, 40.0), (-1.273, 1.471, -0.579, 20.0, 40.0), (0.770, 2.246, -1.107, 20.0, 40.0), (4.552, 2.904, -0.533, 20.0, 40.0), (4.259, -1.772, 8.674, 20.0, 40.0), (-0.309, 1.159, 0.528, 20.0, 40.0), (3.581, 2.700, -0.610, 20.0, 40.0), (-3.202, 0.346, 0.707, 20.0, 40.0), (-1.575, 1.242, -0.271, 20.0, 40.0), (-1.584, -0.493, 3.194, 20.0, 40.0), (-3.778, 0.150, 0.810, 20.0, 40.0), (-4.675, 1.749, -2.835, 20.0, 40.0), (3.567, -0.792, 6.367, 20.0, 40.0), (-0.417, 1.399, -0.006, 20.0, 40.0), (-4.672, 2.007, -3.349, 20.0, 40.0), (-1.034, 0.196, 2.090, 20.0, 40.0), (-3.796, 2.496, -3.890, 20.0, 40.0), (3.532, -0.497, 5.759, 20.0, 40.0), (4.868, -1.359, 8.151, 20.0, 40.0), (-0.769, 0.302, 2.011, 20.0, 40.0), (4.475, 2.612, 0.014, 20.0, 40.0), (-3.532, -0.395, 2.024, 20.0, 40.0), (0.322, 0.675, 1.812, 20.0, 40.0), (-2.028, -1.942, 5.870, 20.0, 40.0), (1.810, -1.244, 6.392, 20.0, 40.0), (-0.783, 1.242, 0.124, 20.0, 40.0), (-4.745, -1.300, 3.227, 20.0, 40.0), (1.902, 1.973, 0.005, 20.0, 40.0), (-3.453, -1.429, 4.132, 20.0, 40.0), (1.559, 0.986, 1.808, 20.0, 40.0), (0.128, 2.754, -2.443, 20.0, 40.0), (2.759, 1.727, 0.926, 20.0, 40.0), (-4.468, 1.690, -2.614, 20.0, 40.0), (-2.368, -1.922, 5.659, 20.0, 40.0), (-2.766, 2.128, -2.640, 20.0, 40.0), (0.967, -1.825, 7.133, 20.0, 40.0), (-2.854, 2.855, -4.136, 20.0, 40.0), (-2.944, 1.875, -2.222, 20.0, 40.0), (-2.632, -0.983, 3.649, 20.0, 40.0), (2.427, 2.239, -0.266, 20.0, 40.0), (-1.726, -0.838, 3.812, 20.0, 40.0), (0.007, -0.903, 4.809, 20.0, 40.0), (-2.013, 1.092, -0.191, 20.0, 40.0), (-0.449, 0.970, 0.836, 20.0, 40.0), (1.396, 0.411, 2.876, 20.0, 40.0), (-1.115, -1.790, 6.023, 20.0, 40.0), (3.748, 1.917, 1.039, 20.0, 40.0), (2.978, 1.043, 2.404, 20.0, 40.0), (-3.969, 2.514, -4.013, 20.0, 40.0), (4.455, -0.050, 5.328, 20.0, 40.0), (-3.065, -0.846, 3.160, 20.0, 40.0), (-1.069, 2.167, -1.869, 20.0, 40.0), (3.016, -1.393, 7.294, 20.0, 40.0), (0.045, -1.928, 6.879, 20.0, 40.0), (-2.555, -0.984, 3.690, 20.0, 40.0), (-1.995, -0.054, 2.111, 20.0, 40.0), (4.600, -0.509, 6.318, 20.0, 40.0), (-1.942, 1.215, -0.402, 20.0, 40.0), (1.262, 2.765, -1.899, 20.0, 40.0), (2.617, -1.106, 6.521, 20.0, 40.0), (1.737, 0.554, 2.761, 20.0, 40.0), (-2.197, 0.632, 0.638, 20.0, 40.0), (4.768, 2.618, 0.147, 20.0, 40.0), (-3.737, -0.939, 3.010, 20.0, 40.0), (-2.623, 0.595, 0.499, 20.0, 40.0), (4.752, -0.340, 6.057, 20.0, 40.0), (2.333, -1.037, 6.240, 20.0, 40.0), (4.234, -1.882, 8.881, 20.0, 40.0), (-3.393, -0.812, 2.927, 20.0, 40.0), (0.885, 1.383, 0.678, 20.0, 40.0), (0.123, 2.937, -2.812, 20.0, 40.0), (2.969, 0.760, 2.964, 20.0, 40.0), (-4.929, 1.251, -1.967, 20.0, 40.0), (1.916, 2.223, -0.488, 20.0, 40.0), (-0.020, -1.740, 6.469, 20.0, 40.0), (0.702, -1.272, 5.895, 20.0, 40.0), (2.496, 2.648, -1.048, 20.0, 40.0), (4.067, -1.475, 7.984, 20.0, 40.0), (-3.717, 1.851, -2.561, 20.0, 40.0), (1.678, -0.624, 5.088, 20.0, 40.0), (1.073, 0.695, 2.146, 20.0, 40.0), (1.842, -0.749, 5.419, 20.0, 40.0), (-3.518, 1.909, -2.578, 20.0, 40.0), (2.229, 1.189, 1.737, 20.0, 40.0), (4.987, 2.893, -0.292, 20.0, 40.0), (-4.809, 1.043, -1.490, 20.0, 40.0), (-0.241, -0.728, 4.334, 20.0, 40.0), (-3.331, 0.590, 0.156, 20.0, 40.0), (-0.455, 2.621, -2.470, 20.0, 40.0), (1.492, 1.223, 1.301, 20.0, 40.0), (3.948, 2.841, -0.709, 20.0, 40.0), (0.732, 0.446, 2.475, 20.0, 40.0), (2.400, 2.390, -0.579, 20.0, 40.0), (-2.718, 1.427, -1.213, 20.0, 40.0), (-1.826, 1.451, -0.815, 20.0, 40.0), (1.125, 0.438, 2.686, 20.0, 40.0), (-4.918, 1.880, -3.219, 20.0, 40.0), (3.068, -0.442, 5.418, 20.0, 40.0), (1.982, 1.201, 1.589, 20.0, 40.0), (0.701, -1.709, 6.768, 20.0, 40.0), (-1.496, 2.564, -2.877, 20.0, 40.0), (-3.812, 0.974, -0.853, 20.0, 40.0), (-3.405, 2.018, -2.739, 20.0, 40.0), (2.211, 2.889, -1.674, 20.0, 40.0), (-2.481, 2.931, -4.103, 20.0, 40.0), (-3.721, 2.765, -4.391, 20.0, 40.0), (-1.768, -1.292, 4.699, 20.0, 40.0), (-4.462, 1.058, -1.347, 20.0, 40.0), (-3.516, -1.942, 5.126, 20.0, 40.0), (0.485, 2.420, -1.597, 20.0, 40.0), (-0.492, 0.242, 2.270, 20.0, 40.0), (4.245, 1.689, 1.744, 20.0, 40.0), (2.234, 0.364, 3.389, 20.0, 40.0), (2.629, 2.224, -0.134, 20.0, 40.0), (-4.375, 1.221, -1.630, 20.0, 40.0), (-0.618, 1.374, -0.057, 20.0, 40.0), (-2.580, -1.604, 4.918, 20.0, 40.0), (0.159, 1.104, 0.871, 20.0, 40.0), (-3.597, 0.975, -0.749, 20.0, 40.0); DROP TABLE IF EXISTS test.model; -create table test.model engine = Memory as select LinearRegressionState(0.1, 5, 3.0)(target, param1, param2) as state from test.defaults; +create table test.model engine = Memory as select LinearRegressionState(0.1, 5, 1.0)(target, param1, param2) as state from test.defaults; with (select state from test.model) as model select evalMLMethod(model, predict1, predict2) from test.defaults; diff --git a/dbms/tests/queries/0_stateless/00955_ml_test.sql b/dbms/tests/queries/0_stateless/00955_ml_test.sql index fb919e5aa57..2df84c00d3f 100644 --- a/dbms/tests/queries/0_stateless/00955_ml_test.sql +++ b/dbms/tests/queries/0_stateless/00955_ml_test.sql @@ -11,7 +11,7 @@ CREATE TABLE IF NOT EXISTS test.defaults insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0), (-1.099, 2.755, -3.060, 20.0, 40.0), (1.090, 2.945, -2.346, 20.0, 40.0), (0.305, 2.179, -1.205, 20.0, 40.0), (-0.925, 0.702, 1.134, 20.0, 40.0), (3.178, -1.316, 7.221, 20.0, 40.0), (-2.756, -0.473, 2.569, 20.0, 40.0), (3.665, 2.303, 0.226, 20.0, 40.0), (1.662, 1.951, -0.070, 20.0, 40.0), (2.869, 0.593, 3.249, 20.0, 40.0), (0.818, -0.593, 4.594, 20.0, 40.0), (-1.917, 0.916, 0.209, 20.0, 40.0), (2.706, 1.523, 1.307, 20.0, 40.0), (0.219, 2.162, -1.214, 20.0, 40.0), (-4.510, 1.376, -2.007, 20.0, 40.0), (4.284, -0.515, 6.173, 20.0, 40.0), (-1.101, 2.810, -3.170, 20.0, 40.0), (-1.810, -1.117, 4.329, 20.0, 40.0), (0.055, 1.115, 0.797, 20.0, 40.0), (-2.178, 2.904, -3.898, 20.0, 40.0), (-3.494, -1.814, 4.882, 20.0, 40.0), (3.027, 0.476, 3.562, 20.0, 40.0), (-1.434, 1.151, -0.018, 20.0, 40.0), (1.180, 0.992, 1.606, 20.0, 40.0), (0.015, 0.971, 1.067, 20.0, 40.0), (-0.511, -0.875, 4.495, 20.0, 40.0), (0.961, 2.348, -1.216, 20.0, 40.0), (-2.279, 0.038, 1.785, 20.0, 40.0), (-1.568, -0.248, 2.712, 20.0, 40.0), (-0.496, 0.366, 2.020, 20.0, 40.0), (1.177, -1.401, 6.390, 20.0, 40.0), (2.882, -1.442, 7.325, 20.0, 40.0), (-1.066, 1.817, -1.167, 20.0, 40.0), (-2.144, 2.791, -3.655, 20.0, 40.0), (-4.370, 2.228, -3.642, 20.0, 40.0), (3.996, 2.775, -0.553, 20.0, 40.0), (0.289, 2.055, -0.965, 20.0, 40.0), (-0.588, -1.601, 5.908, 20.0, 40.0), (-1.801, 0.417, 1.265, 20.0, 40.0), (4.375, -1.499, 8.186, 20.0, 40.0), (-2.618, 0.038, 1.615, 20.0, 40.0), (3.616, -0.833, 6.475, 20.0, 40.0), (-4.045, -1.558, 4.094, 20.0, 40.0), (-3.962, 0.636, -0.253, 20.0, 40.0), (3.505, 2.625, -0.497, 20.0, 40.0), (3.029, -0.523, 5.560, 20.0, 40.0), (-3.520, -0.474, 2.188, 20.0, 40.0), (2.430, -1.469, 7.154, 20.0, 40.0), (1.547, -1.654, 7.082, 20.0, 40.0), (-1.370, 0.575, 1.165, 20.0, 40.0), (-1.869, -1.555, 5.176, 20.0, 40.0), (3.536, 2.841, -0.913, 20.0, 40.0), (-3.810, 1.220, -1.344, 20.0, 40.0), (-1.971, 1.462, -0.910, 20.0, 40.0), (-0.243, 0.167, 2.545, 20.0, 40.0), (-1.403, 2.645, -2.991, 20.0, 40.0), (0.532, -0.114, 3.494, 20.0, 40.0), (-1.678, 0.975, 0.212, 20.0, 40.0), (-0.656, 2.140, -1.609, 20.0, 40.0), (1.743, 2.631, -1.390, 20.0, 40.0), (2.586, 2.943, -1.593, 20.0, 40.0), (-0.512, 2.969, -3.195, 20.0, 40.0), (2.283, -0.100, 4.342, 20.0, 40.0), (-4.293, 0.872, -0.890, 20.0, 40.0), (3.411, 1.300, 2.106, 20.0, 40.0), (-0.281, 2.951, -3.042, 20.0, 40.0), (-4.442, 0.384, 0.012, 20.0, 40.0), (1.194, 1.746, 0.104, 20.0, 40.0), (-1.152, 1.862, -1.300, 20.0, 40.0), (1.362, -1.341, 6.363, 20.0, 40.0), (-4.488, 2.618, -4.481, 20.0, 40.0), (3.419, -0.564, 5.837, 20.0, 40.0), (-3.392, 0.396, 0.512, 20.0, 40.0), (-1.629, -0.909, 4.003, 20.0, 40.0), (4.447, -1.088, 7.399, 20.0, 40.0), (-1.232, 1.699, -1.014, 20.0, 40.0), (-1.286, -0.609, 3.575, 20.0, 40.0), (2.437, 2.796, -1.374, 20.0, 40.0), (-4.864, 1.989, -3.410, 20.0, 40.0), (-1.716, -1.399, 4.940, 20.0, 40.0), (-3.084, 1.858, -2.259, 20.0, 40.0), (2.828, -0.319, 5.053, 20.0, 40.0), (-1.226, 2.586, -2.786, 20.0, 40.0), (2.456, 0.092, 4.044, 20.0, 40.0), (-0.989, 2.375, -2.245, 20.0, 40.0), (3.268, 0.935, 2.765, 20.0, 40.0), (-4.128, -1.995, 4.927, 20.0, 40.0), (-1.083, 2.197, -1.935, 20.0, 40.0), (-3.471, -1.198, 3.660, 20.0, 40.0), (4.617, -1.136, 7.579, 20.0, 40.0), (2.054, -1.675, 7.378, 20.0, 40.0), (4.106, 2.326, 0.402, 20.0, 40.0), (1.558, 0.310, 3.158, 20.0, 40.0), (0.792, 0.900, 1.596, 20.0, 40.0), (-3.229, 0.300, 0.785, 20.0, 40.0), (3.787, -0.793, 6.479, 20.0, 40.0), (1.786, 2.288, -0.684, 20.0, 40.0), (2.643, 0.223, 3.875, 20.0, 40.0), (-3.592, 2.122, -3.040, 20.0, 40.0), (4.519, -1.760, 8.779, 20.0, 40.0), (3.221, 2.255, 0.101, 20.0, 40.0), (4.151, 1.788, 1.500, 20.0, 40.0), (-1.033, -1.195, 4.874, 20.0, 40.0), (-1.636, -1.037, 4.257, 20.0, 40.0), (-3.548, 1.911, -2.596, 20.0, 40.0), (4.829, -0.293, 6.001, 20.0, 40.0), (-4.684, -1.664, 3.986, 20.0, 40.0), (4.531, -0.503, 6.271, 20.0, 40.0), (-3.503, -1.606, 4.460, 20.0, 40.0), (-2.036, -1.522, 5.027, 20.0, 40.0), (-0.473, -0.617, 3.997, 20.0, 40.0), (-1.554, -1.630, 5.483, 20.0, 40.0), (-3.567, -1.043, 3.302, 20.0, 40.0), (-2.038, 0.579, 0.823, 20.0, 40.0), (-3.040, 0.857, -0.233, 20.0, 40.0), (4.610, 0.562, 4.181, 20.0, 40.0), (-3.323, -1.938, 5.215, 20.0, 40.0), (4.314, 1.720, 1.717, 20.0, 40.0), (-1.220, 0.615, 1.161, 20.0, 40.0), (-2.556, 1.120, -0.519, 20.0, 40.0), (-3.717, -0.108, 1.358, 20.0, 40.0), (4.689, -1.826, 8.996, 20.0, 40.0), (3.452, 0.506, 3.713, 20.0, 40.0), (2.472, 0.612, 3.012, 20.0, 40.0), (3.452, 0.450, 3.826, 20.0, 40.0), (1.207, 2.585, -1.567, 20.0, 40.0), (-4.826, 1.090, -1.593, 20.0, 40.0), (3.116, -1.118, 6.794, 20.0, 40.0), (0.448, 2.732, -2.240, 20.0, 40.0), (-1.096, -0.525, 3.503, 20.0, 40.0), (-4.680, -0.238, 1.137, 20.0, 40.0), (2.552, -1.403, 7.082, 20.0, 40.0), (0.719, 2.997, -2.635, 20.0, 40.0), (0.347, -1.966, 7.105, 20.0, 40.0), (2.958, -0.404, 5.288, 20.0, 40.0), (0.722, -1.950, 7.261, 20.0, 40.0), (-2.851, -0.986, 3.546, 20.0, 40.0), (-4.316, -0.439, 1.721, 20.0, 40.0), (-1.685, -0.201, 2.560, 20.0, 40.0), (1.856, 0.190, 3.549, 20.0, 40.0), (-2.052, 0.206, 1.562, 20.0, 40.0), (-2.504, -0.646, 3.041, 20.0, 40.0), (3.235, 0.882, 2.854, 20.0, 40.0), (-1.366, -1.573, 5.463, 20.0, 40.0), (-3.447, 2.419, -3.562, 20.0, 40.0), (4.155, 2.092, 0.893, 20.0, 40.0), (-0.935, 0.209, 2.116, 20.0, 40.0), (3.117, -1.821, 8.201, 20.0, 40.0), (3.759, 0.577, 3.725, 20.0, 40.0), (-0.938, 2.992, -3.453, 20.0, 40.0), (-0.525, 2.341, -1.945, 20.0, 40.0), (4.540, 2.625, 0.019, 20.0, 40.0), (-2.097, 1.190, -0.429, 20.0, 40.0), (-2.672, 1.983, -2.302, 20.0, 40.0), (-3.038, -1.490, 4.460, 20.0, 40.0), (-0.943, 2.149, -1.770, 20.0, 40.0), (0.739, 1.598, 0.174, 20.0, 40.0), (1.828, 1.853, 0.208, 20.0, 40.0), (4.856, 0.137, 5.153, 20.0, 40.0), (-1.617, 0.468, 1.255, 20.0, 40.0), (-1.972, 2.053, -2.092, 20.0, 40.0), (-4.633, 1.389, -2.094, 20.0, 40.0), (-3.628, -1.156, 3.498, 20.0, 40.0), (3.597, 1.034, 2.731, 20.0, 40.0), (-1.488, -0.002, 2.261, 20.0, 40.0), (0.749, 1.921, -0.468, 20.0, 40.0), (1.304, -1.371, 6.394, 20.0, 40.0), (4.587, 2.936, -0.579, 20.0, 40.0), (-2.241, 1.791, -1.703, 20.0, 40.0), (-2.945, 1.372, -1.216, 20.0, 40.0), (1.375, 0.395, 2.898, 20.0, 40.0), (-1.281, -0.641, 3.642, 20.0, 40.0), (2.178, 0.895, 2.299, 20.0, 40.0), (3.031, -0.786, 6.087, 20.0, 40.0), (-1.385, -0.375, 3.058, 20.0, 40.0), (4.041, -0.431, 5.882, 20.0, 40.0), (0.480, -0.507, 4.254, 20.0, 40.0), (-3.797, 0.140, 0.822, 20.0, 40.0), (2.355, 2.502, -0.827, 20.0, 40.0), (1.376, -1.583, 6.854, 20.0, 40.0), (0.164, 1.405, 0.273, 20.0, 40.0), (-1.273, 1.471, -0.579, 20.0, 40.0), (0.770, 2.246, -1.107, 20.0, 40.0), (4.552, 2.904, -0.533, 20.0, 40.0), (4.259, -1.772, 8.674, 20.0, 40.0), (-0.309, 1.159, 0.528, 20.0, 40.0), (3.581, 2.700, -0.610, 20.0, 40.0), (-3.202, 0.346, 0.707, 20.0, 40.0), (-1.575, 1.242, -0.271, 20.0, 40.0), (-1.584, -0.493, 3.194, 20.0, 40.0), (-3.778, 0.150, 0.810, 20.0, 40.0), (-4.675, 1.749, -2.835, 20.0, 40.0), (3.567, -0.792, 6.367, 20.0, 40.0), (-0.417, 1.399, -0.006, 20.0, 40.0), (-4.672, 2.007, -3.349, 20.0, 40.0), (-1.034, 0.196, 2.090, 20.0, 40.0), (-3.796, 2.496, -3.890, 20.0, 40.0), (3.532, -0.497, 5.759, 20.0, 40.0), (4.868, -1.359, 8.151, 20.0, 40.0), (-0.769, 0.302, 2.011, 20.0, 40.0), (4.475, 2.612, 0.014, 20.0, 40.0), (-3.532, -0.395, 2.024, 20.0, 40.0), (0.322, 0.675, 1.812, 20.0, 40.0), (-2.028, -1.942, 5.870, 20.0, 40.0), (1.810, -1.244, 6.392, 20.0, 40.0), (-0.783, 1.242, 0.124, 20.0, 40.0), (-4.745, -1.300, 3.227, 20.0, 40.0), (1.902, 1.973, 0.005, 20.0, 40.0), (-3.453, -1.429, 4.132, 20.0, 40.0), (1.559, 0.986, 1.808, 20.0, 40.0), (0.128, 2.754, -2.443, 20.0, 40.0), (2.759, 1.727, 0.926, 20.0, 40.0), (-4.468, 1.690, -2.614, 20.0, 40.0), (-2.368, -1.922, 5.659, 20.0, 40.0), (-2.766, 2.128, -2.640, 20.0, 40.0), (0.967, -1.825, 7.133, 20.0, 40.0), (-2.854, 2.855, -4.136, 20.0, 40.0), (-2.944, 1.875, -2.222, 20.0, 40.0), (-2.632, -0.983, 3.649, 20.0, 40.0), (2.427, 2.239, -0.266, 20.0, 40.0), (-1.726, -0.838, 3.812, 20.0, 40.0), (0.007, -0.903, 4.809, 20.0, 40.0), (-2.013, 1.092, -0.191, 20.0, 40.0), (-0.449, 0.970, 0.836, 20.0, 40.0), (1.396, 0.411, 2.876, 20.0, 40.0), (-1.115, -1.790, 6.023, 20.0, 40.0), (3.748, 1.917, 1.039, 20.0, 40.0), (2.978, 1.043, 2.404, 20.0, 40.0), (-3.969, 2.514, -4.013, 20.0, 40.0), (4.455, -0.050, 5.328, 20.0, 40.0), (-3.065, -0.846, 3.160, 20.0, 40.0), (-1.069, 2.167, -1.869, 20.0, 40.0), (3.016, -1.393, 7.294, 20.0, 40.0), (0.045, -1.928, 6.879, 20.0, 40.0), (-2.555, -0.984, 3.690, 20.0, 40.0), (-1.995, -0.054, 2.111, 20.0, 40.0), (4.600, -0.509, 6.318, 20.0, 40.0), (-1.942, 1.215, -0.402, 20.0, 40.0), (1.262, 2.765, -1.899, 20.0, 40.0), (2.617, -1.106, 6.521, 20.0, 40.0), (1.737, 0.554, 2.761, 20.0, 40.0), (-2.197, 0.632, 0.638, 20.0, 40.0), (4.768, 2.618, 0.147, 20.0, 40.0), (-3.737, -0.939, 3.010, 20.0, 40.0), (-2.623, 0.595, 0.499, 20.0, 40.0), (4.752, -0.340, 6.057, 20.0, 40.0), (2.333, -1.037, 6.240, 20.0, 40.0), (4.234, -1.882, 8.881, 20.0, 40.0), (-3.393, -0.812, 2.927, 20.0, 40.0), (0.885, 1.383, 0.678, 20.0, 40.0), (0.123, 2.937, -2.812, 20.0, 40.0), (2.969, 0.760, 2.964, 20.0, 40.0), (-4.929, 1.251, -1.967, 20.0, 40.0), (1.916, 2.223, -0.488, 20.0, 40.0), (-0.020, -1.740, 6.469, 20.0, 40.0), (0.702, -1.272, 5.895, 20.0, 40.0), (2.496, 2.648, -1.048, 20.0, 40.0), (4.067, -1.475, 7.984, 20.0, 40.0), (-3.717, 1.851, -2.561, 20.0, 40.0), (1.678, -0.624, 5.088, 20.0, 40.0), (1.073, 0.695, 2.146, 20.0, 40.0), (1.842, -0.749, 5.419, 20.0, 40.0), (-3.518, 1.909, -2.578, 20.0, 40.0), (2.229, 1.189, 1.737, 20.0, 40.0), (4.987, 2.893, -0.292, 20.0, 40.0), (-4.809, 1.043, -1.490, 20.0, 40.0), (-0.241, -0.728, 4.334, 20.0, 40.0), (-3.331, 0.590, 0.156, 20.0, 40.0), (-0.455, 2.621, -2.470, 20.0, 40.0), (1.492, 1.223, 1.301, 20.0, 40.0), (3.948, 2.841, -0.709, 20.0, 40.0), (0.732, 0.446, 2.475, 20.0, 40.0), (2.400, 2.390, -0.579, 20.0, 40.0), (-2.718, 1.427, -1.213, 20.0, 40.0), (-1.826, 1.451, -0.815, 20.0, 40.0), (1.125, 0.438, 2.686, 20.0, 40.0), (-4.918, 1.880, -3.219, 20.0, 40.0), (3.068, -0.442, 5.418, 20.0, 40.0), (1.982, 1.201, 1.589, 20.0, 40.0), (0.701, -1.709, 6.768, 20.0, 40.0), (-1.496, 2.564, -2.877, 20.0, 40.0), (-3.812, 0.974, -0.853, 20.0, 40.0), (-3.405, 2.018, -2.739, 20.0, 40.0), (2.211, 2.889, -1.674, 20.0, 40.0), (-2.481, 2.931, -4.103, 20.0, 40.0), (-3.721, 2.765, -4.391, 20.0, 40.0), (-1.768, -1.292, 4.699, 20.0, 40.0), (-4.462, 1.058, -1.347, 20.0, 40.0), (-3.516, -1.942, 5.126, 20.0, 40.0), (0.485, 2.420, -1.597, 20.0, 40.0), (-0.492, 0.242, 2.270, 20.0, 40.0), (4.245, 1.689, 1.744, 20.0, 40.0), (2.234, 0.364, 3.389, 20.0, 40.0), (2.629, 2.224, -0.134, 20.0, 40.0), (-4.375, 1.221, -1.630, 20.0, 40.0), (-0.618, 1.374, -0.057, 20.0, 40.0), (-2.580, -1.604, 4.918, 20.0, 40.0), (0.159, 1.104, 0.871, 20.0, 40.0), (-3.597, 0.975, -0.749, 20.0, 40.0); DROP TABLE IF EXISTS test.model; -create table test.model engine = Memory as select LinearRegressionState(0.1, 5, 4.0)(target, param1, param2) as state from test.defaults; +create table test.model engine = Memory as select LinearRegressionState(0.1, 5, 1.0)(target, param1, param2) as state from test.defaults; with (select state from test.model) as model select evalMLMethod(model, predict1, predict2) from test.defaults; From 6371b4021dadd2f5940356fa5e21b449f56c3848 Mon Sep 17 00:00:00 2001 From: Alexander Kozhikhov Date: Sun, 3 Mar 2019 13:21:12 +0300 Subject: [PATCH 022/709] changes in gradient_computer class --- .../AggregateFunctionMLMethod.cpp | 4 +- .../AggregateFunctionMLMethod.h | 111 ++---------------- .../queries/0_stateless/00950_ml_test.sql | 2 +- .../queries/0_stateless/00951_ml_test.sql | 2 +- .../queries/0_stateless/00954_ml_test.sql | 2 +- 5 files changed, 17 insertions(+), 104 deletions(-) diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp index 4a8d7a43172..bd3aa51c2e2 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp @@ -44,10 +44,10 @@ AggregateFunctionPtr createAggregateFunctionMLMethod( if (std::is_same::value) { - gc = std::make_shared(argument_types.size()); + gc = std::make_shared(); } else if (std::is_same::value) { - gc = std::make_shared(argument_types.size()); + gc = std::make_shared(); } else { throw Exception("Such gradient computer is not implemented yet", ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT); diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h index c295679fab4..2fd4c7cc3f2 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h @@ -36,8 +36,8 @@ and stores mini-batch class IGradientComputer { public: - IGradientComputer(UInt32 sz) { std::ignore = sz;// : batch_gradient(sz, 0) { - } + IGradientComputer() + {} virtual ~IGradientComputer() = default; @@ -45,26 +45,6 @@ public: virtual void compute(std::vector * batch_gradient, const std::vector &weights, Float64 bias, Float64 learning_rate, Float64 target, const IColumn **columns, size_t row_num) = 0; -// void reset() -// { -// batch_gradient.assign(batch_gradient.size(), 0); -// } - -// void write(WriteBuffer &buf) const -// { -// writeBinary(batch_gradient, buf); -// } -// -// void read(ReadBuffer &buf) -// { -// readBinary(batch_gradient, buf); -// } - -// const std::vector &get() const -// { -// return batch_gradient; -// } - virtual Float64 predict(const std::vector &predict_feature, const std::vector &weights, Float64 bias) const = 0; @@ -74,18 +54,14 @@ public: Block &block, const ColumnNumbers &arguments, const std::vector &weights, Float64 bias) const = 0; - -//protected: -// std::vector batch_gradient; // gradient for bias lies in batch_gradient[batch_gradient.size() - 1] }; class LinearRegression : public IGradientComputer { public: - LinearRegression(UInt32 sz) - : IGradientComputer(sz) { - } + LinearRegression() + {} void compute(std::vector * batch_gradient, const std::vector &weights, Float64 bias, Float64 learning_rate, Float64 target, const IColumn **columns, size_t row_num) override @@ -155,8 +131,7 @@ public: class LogisticRegression : public IGradientComputer { public: - LogisticRegression(UInt32 sz) - : IGradientComputer(sz) + LogisticRegression() {} void compute(std::vector * batch_gradient, const std::vector &weights, Float64 bias, @@ -253,10 +228,6 @@ public: virtual void read(ReadBuffer &) {} -// virtual std::vector get_update(UInt32 sz, UInt32) -// { -// return std::vector(sz, 0.0); -// } }; @@ -273,8 +244,6 @@ public: weights[i] += batch_gradient[i] / batch_size; } bias += batch_gradient[weights.size()] / batch_size; - -// batch_gradient->assign(batch_gradient->size(), Float64{0.0}); } }; @@ -402,21 +371,6 @@ public: { readBinary(accumulated_gradient, buf); } -// virtual std::vector get_update(UInt32 sz, UInt32 batch_size) override -// { -// if (accumulated_gradient.size() == 0) -// { -// accumulated_gradient.resize(sz, Float64{0.0}); -// return accumulated_gradient; -// } -// std::vector delta(accumulated_gradient.size()); -// // std::cout<<"\n\nHK\n\n"; -// for (size_t i = 0; i < delta.size(); ++i) -// { -// delta[i] = accumulated_gradient[i] * alpha_ / batch_size; -// } -// return delta; -// } private: Float64 alpha_{0.1}; @@ -505,11 +459,11 @@ public: UInt32 batch_capacity, std::shared_ptr gc, std::shared_ptr wu) - : learning_rate(learning_rate), - batch_capacity(batch_capacity), - batch_size(0), - gradient_computer(std::move(gc)), - weights_updater(std::move(wu)) + : learning_rate(learning_rate), + batch_capacity(batch_capacity), + batch_size(0), + gradient_computer(std::move(gc)), + weights_updater(std::move(wu)) { weights.resize(param_num, Float64{0.0}); gradient_batch.resize(param_num + 1, Float64{0.0}); @@ -520,33 +474,9 @@ public: /// first column stores target; features start from (columns + 1) const auto &target = static_cast &>(*columns[0]).getData()[row_num]; -// auto delta = weights_updater->get_update(weights.size() + 1, batch_capacity); -// Float64 delta_bias = bias + delta[weights.size()]; -// delta.resize(weights.size()); -// for (size_t i = 0; i < weights.size(); ++i) -// { -// delta[i] += weights[i]; -// } - -// gradient_computer->compute(delta, delta_bias, learning_rate, target, columns + 1, row_num); -// gradient_computer->compute(weights, bias, learning_rate, target, columns + 1, row_num); - std::cout << "\nBATCH BEFORE\n"; - for (auto i : gradient_batch) - std::cout << i << " "; - std::cout << "\nhello\n"; - - + /// Here we have columns + 1 as first column corresponds to target value, and others - to features weights_updater->add_to_batch(&gradient_batch, gradient_computer, - weights, bias, learning_rate, target, columns, row_num); - - - std::cout << "BATCH AFTER\n"; - for (auto i : gradient_batch) - std::cout << i << " "; - std::cout << "\nhello\n\n"; - - if (iter_num == 10) - exit(1); + weights, bias, learning_rate, target, columns + 1, row_num); ++batch_size; if (batch_size == batch_capacity) @@ -585,7 +515,6 @@ public: writeBinary(gradient_batch, buf); writeBinary(batch_size, buf); weights_updater->write(buf); -// gradient_computer->write(buf); } void read(ReadBuffer &buf) @@ -596,7 +525,6 @@ public: readBinary(gradient_batch, buf); readBinary(batch_size, buf); weights_updater->read(buf); -// gradient_computer->read(buf); } Float64 predict(const std::vector &predict_feature) const @@ -608,23 +536,11 @@ public: // update_weights(); // } - std::cout << "\n\nWEIGHTS: "; - for (size_t i = 0; i != weights.size(); ++i) { - std::cout << weights[i] << " "; - } - std::cout << "\n\n"; - return gradient_computer->predict(predict_feature, weights, bias); } void predict_for_all(ColumnVector::Container &container, Block &block, const ColumnNumbers &arguments) const { - std::cout << "\n\nWEIGHTS: "; - for (size_t i = 0; i != weights.size(); ++i) { - std::cout << weights[i] << " "; - } - std::cout << "\n\n"; - gradient_computer->predict_for_all(container, block, arguments, weights, bias); } @@ -650,9 +566,6 @@ private: if (batch_size == 0) return; -// weights_updater->update(batch_size, weights, bias, gradient_batch); - - // /// use pointer to gradient_batch, because some methods (e.g. simple stochastic descent) require to reset it weights_updater->update(batch_size, weights, bias, gradient_batch); batch_size = 0; ++iter_num; diff --git a/dbms/tests/queries/0_stateless/00950_ml_test.sql b/dbms/tests/queries/0_stateless/00950_ml_test.sql index 46f64a1f1dd..0a009c29d29 100644 --- a/dbms/tests/queries/0_stateless/00950_ml_test.sql +++ b/dbms/tests/queries/0_stateless/00950_ml_test.sql @@ -11,7 +11,7 @@ CREATE TABLE IF NOT EXISTS test.defaults insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0), (-1.099, 2.755, -3.060, 20.0, 40.0), (1.090, 2.945, -2.346, 20.0, 40.0), (0.305, 2.179, -1.205, 20.0, 40.0), (-0.925, 0.702, 1.134, 20.0, 40.0), (3.178, -1.316, 7.221, 20.0, 40.0), (-2.756, -0.473, 2.569, 20.0, 40.0), (3.665, 2.303, 0.226, 20.0, 40.0), (1.662, 1.951, -0.070, 20.0, 40.0), (2.869, 0.593, 3.249, 20.0, 40.0), (0.818, -0.593, 4.594, 20.0, 40.0), (-1.917, 0.916, 0.209, 20.0, 40.0), (2.706, 1.523, 1.307, 20.0, 40.0), (0.219, 2.162, -1.214, 20.0, 40.0), (-4.510, 1.376, -2.007, 20.0, 40.0), (4.284, -0.515, 6.173, 20.0, 40.0), (-1.101, 2.810, -3.170, 20.0, 40.0), (-1.810, -1.117, 4.329, 20.0, 40.0), (0.055, 1.115, 0.797, 20.0, 40.0), (-2.178, 2.904, -3.898, 20.0, 40.0), (-3.494, -1.814, 4.882, 20.0, 40.0), (3.027, 0.476, 3.562, 20.0, 40.0), (-1.434, 1.151, -0.018, 20.0, 40.0), (1.180, 0.992, 1.606, 20.0, 40.0), (0.015, 0.971, 1.067, 20.0, 40.0), (-0.511, -0.875, 4.495, 20.0, 40.0), (0.961, 2.348, -1.216, 20.0, 40.0), (-2.279, 0.038, 1.785, 20.0, 40.0), (-1.568, -0.248, 2.712, 20.0, 40.0), (-0.496, 0.366, 2.020, 20.0, 40.0), (1.177, -1.401, 6.390, 20.0, 40.0), (2.882, -1.442, 7.325, 20.0, 40.0), (-1.066, 1.817, -1.167, 20.0, 40.0), (-2.144, 2.791, -3.655, 20.0, 40.0), (-4.370, 2.228, -3.642, 20.0, 40.0), (3.996, 2.775, -0.553, 20.0, 40.0), (0.289, 2.055, -0.965, 20.0, 40.0), (-0.588, -1.601, 5.908, 20.0, 40.0), (-1.801, 0.417, 1.265, 20.0, 40.0), (4.375, -1.499, 8.186, 20.0, 40.0), (-2.618, 0.038, 1.615, 20.0, 40.0), (3.616, -0.833, 6.475, 20.0, 40.0), (-4.045, -1.558, 4.094, 20.0, 40.0), (-3.962, 0.636, -0.253, 20.0, 40.0), (3.505, 2.625, -0.497, 20.0, 40.0), (3.029, -0.523, 5.560, 20.0, 40.0), (-3.520, -0.474, 2.188, 20.0, 40.0), (2.430, -1.469, 7.154, 20.0, 40.0), (1.547, -1.654, 7.082, 20.0, 40.0), (-1.370, 0.575, 1.165, 20.0, 40.0), (-1.869, -1.555, 5.176, 20.0, 40.0), (3.536, 2.841, -0.913, 20.0, 40.0), (-3.810, 1.220, -1.344, 20.0, 40.0), (-1.971, 1.462, -0.910, 20.0, 40.0), (-0.243, 0.167, 2.545, 20.0, 40.0), (-1.403, 2.645, -2.991, 20.0, 40.0), (0.532, -0.114, 3.494, 20.0, 40.0), (-1.678, 0.975, 0.212, 20.0, 40.0), (-0.656, 2.140, -1.609, 20.0, 40.0), (1.743, 2.631, -1.390, 20.0, 40.0), (2.586, 2.943, -1.593, 20.0, 40.0), (-0.512, 2.969, -3.195, 20.0, 40.0), (2.283, -0.100, 4.342, 20.0, 40.0), (-4.293, 0.872, -0.890, 20.0, 40.0), (3.411, 1.300, 2.106, 20.0, 40.0), (-0.281, 2.951, -3.042, 20.0, 40.0), (-4.442, 0.384, 0.012, 20.0, 40.0), (1.194, 1.746, 0.104, 20.0, 40.0), (-1.152, 1.862, -1.300, 20.0, 40.0), (1.362, -1.341, 6.363, 20.0, 40.0), (-4.488, 2.618, -4.481, 20.0, 40.0), (3.419, -0.564, 5.837, 20.0, 40.0), (-3.392, 0.396, 0.512, 20.0, 40.0), (-1.629, -0.909, 4.003, 20.0, 40.0), (4.447, -1.088, 7.399, 20.0, 40.0), (-1.232, 1.699, -1.014, 20.0, 40.0), (-1.286, -0.609, 3.575, 20.0, 40.0), (2.437, 2.796, -1.374, 20.0, 40.0), (-4.864, 1.989, -3.410, 20.0, 40.0), (-1.716, -1.399, 4.940, 20.0, 40.0), (-3.084, 1.858, -2.259, 20.0, 40.0), (2.828, -0.319, 5.053, 20.0, 40.0), (-1.226, 2.586, -2.786, 20.0, 40.0), (2.456, 0.092, 4.044, 20.0, 40.0), (-0.989, 2.375, -2.245, 20.0, 40.0), (3.268, 0.935, 2.765, 20.0, 40.0), (-4.128, -1.995, 4.927, 20.0, 40.0), (-1.083, 2.197, -1.935, 20.0, 40.0), (-3.471, -1.198, 3.660, 20.0, 40.0), (4.617, -1.136, 7.579, 20.0, 40.0), (2.054, -1.675, 7.378, 20.0, 40.0), (4.106, 2.326, 0.402, 20.0, 40.0), (1.558, 0.310, 3.158, 20.0, 40.0), (0.792, 0.900, 1.596, 20.0, 40.0), (-3.229, 0.300, 0.785, 20.0, 40.0), (3.787, -0.793, 6.479, 20.0, 40.0), (1.786, 2.288, -0.684, 20.0, 40.0), (2.643, 0.223, 3.875, 20.0, 40.0), (-3.592, 2.122, -3.040, 20.0, 40.0), (4.519, -1.760, 8.779, 20.0, 40.0), (3.221, 2.255, 0.101, 20.0, 40.0), (4.151, 1.788, 1.500, 20.0, 40.0), (-1.033, -1.195, 4.874, 20.0, 40.0), (-1.636, -1.037, 4.257, 20.0, 40.0), (-3.548, 1.911, -2.596, 20.0, 40.0), (4.829, -0.293, 6.001, 20.0, 40.0), (-4.684, -1.664, 3.986, 20.0, 40.0), (4.531, -0.503, 6.271, 20.0, 40.0), (-3.503, -1.606, 4.460, 20.0, 40.0), (-2.036, -1.522, 5.027, 20.0, 40.0), (-0.473, -0.617, 3.997, 20.0, 40.0), (-1.554, -1.630, 5.483, 20.0, 40.0), (-3.567, -1.043, 3.302, 20.0, 40.0), (-2.038, 0.579, 0.823, 20.0, 40.0), (-3.040, 0.857, -0.233, 20.0, 40.0), (4.610, 0.562, 4.181, 20.0, 40.0), (-3.323, -1.938, 5.215, 20.0, 40.0), (4.314, 1.720, 1.717, 20.0, 40.0), (-1.220, 0.615, 1.161, 20.0, 40.0), (-2.556, 1.120, -0.519, 20.0, 40.0), (-3.717, -0.108, 1.358, 20.0, 40.0), (4.689, -1.826, 8.996, 20.0, 40.0), (3.452, 0.506, 3.713, 20.0, 40.0), (2.472, 0.612, 3.012, 20.0, 40.0), (3.452, 0.450, 3.826, 20.0, 40.0), (1.207, 2.585, -1.567, 20.0, 40.0), (-4.826, 1.090, -1.593, 20.0, 40.0), (3.116, -1.118, 6.794, 20.0, 40.0), (0.448, 2.732, -2.240, 20.0, 40.0), (-1.096, -0.525, 3.503, 20.0, 40.0), (-4.680, -0.238, 1.137, 20.0, 40.0), (2.552, -1.403, 7.082, 20.0, 40.0), (0.719, 2.997, -2.635, 20.0, 40.0), (0.347, -1.966, 7.105, 20.0, 40.0), (2.958, -0.404, 5.288, 20.0, 40.0), (0.722, -1.950, 7.261, 20.0, 40.0), (-2.851, -0.986, 3.546, 20.0, 40.0), (-4.316, -0.439, 1.721, 20.0, 40.0), (-1.685, -0.201, 2.560, 20.0, 40.0), (1.856, 0.190, 3.549, 20.0, 40.0), (-2.052, 0.206, 1.562, 20.0, 40.0), (-2.504, -0.646, 3.041, 20.0, 40.0), (3.235, 0.882, 2.854, 20.0, 40.0), (-1.366, -1.573, 5.463, 20.0, 40.0), (-3.447, 2.419, -3.562, 20.0, 40.0), (4.155, 2.092, 0.893, 20.0, 40.0), (-0.935, 0.209, 2.116, 20.0, 40.0), (3.117, -1.821, 8.201, 20.0, 40.0), (3.759, 0.577, 3.725, 20.0, 40.0), (-0.938, 2.992, -3.453, 20.0, 40.0), (-0.525, 2.341, -1.945, 20.0, 40.0), (4.540, 2.625, 0.019, 20.0, 40.0), (-2.097, 1.190, -0.429, 20.0, 40.0), (-2.672, 1.983, -2.302, 20.0, 40.0), (-3.038, -1.490, 4.460, 20.0, 40.0), (-0.943, 2.149, -1.770, 20.0, 40.0), (0.739, 1.598, 0.174, 20.0, 40.0), (1.828, 1.853, 0.208, 20.0, 40.0), (4.856, 0.137, 5.153, 20.0, 40.0), (-1.617, 0.468, 1.255, 20.0, 40.0), (-1.972, 2.053, -2.092, 20.0, 40.0), (-4.633, 1.389, -2.094, 20.0, 40.0), (-3.628, -1.156, 3.498, 20.0, 40.0), (3.597, 1.034, 2.731, 20.0, 40.0), (-1.488, -0.002, 2.261, 20.0, 40.0), (0.749, 1.921, -0.468, 20.0, 40.0), (1.304, -1.371, 6.394, 20.0, 40.0), (4.587, 2.936, -0.579, 20.0, 40.0), (-2.241, 1.791, -1.703, 20.0, 40.0), (-2.945, 1.372, -1.216, 20.0, 40.0), (1.375, 0.395, 2.898, 20.0, 40.0), (-1.281, -0.641, 3.642, 20.0, 40.0), (2.178, 0.895, 2.299, 20.0, 40.0), (3.031, -0.786, 6.087, 20.0, 40.0), (-1.385, -0.375, 3.058, 20.0, 40.0), (4.041, -0.431, 5.882, 20.0, 40.0), (0.480, -0.507, 4.254, 20.0, 40.0), (-3.797, 0.140, 0.822, 20.0, 40.0), (2.355, 2.502, -0.827, 20.0, 40.0), (1.376, -1.583, 6.854, 20.0, 40.0), (0.164, 1.405, 0.273, 20.0, 40.0), (-1.273, 1.471, -0.579, 20.0, 40.0), (0.770, 2.246, -1.107, 20.0, 40.0), (4.552, 2.904, -0.533, 20.0, 40.0), (4.259, -1.772, 8.674, 20.0, 40.0), (-0.309, 1.159, 0.528, 20.0, 40.0), (3.581, 2.700, -0.610, 20.0, 40.0), (-3.202, 0.346, 0.707, 20.0, 40.0), (-1.575, 1.242, -0.271, 20.0, 40.0), (-1.584, -0.493, 3.194, 20.0, 40.0), (-3.778, 0.150, 0.810, 20.0, 40.0), (-4.675, 1.749, -2.835, 20.0, 40.0), (3.567, -0.792, 6.367, 20.0, 40.0), (-0.417, 1.399, -0.006, 20.0, 40.0), (-4.672, 2.007, -3.349, 20.0, 40.0), (-1.034, 0.196, 2.090, 20.0, 40.0), (-3.796, 2.496, -3.890, 20.0, 40.0), (3.532, -0.497, 5.759, 20.0, 40.0), (4.868, -1.359, 8.151, 20.0, 40.0), (-0.769, 0.302, 2.011, 20.0, 40.0), (4.475, 2.612, 0.014, 20.0, 40.0), (-3.532, -0.395, 2.024, 20.0, 40.0), (0.322, 0.675, 1.812, 20.0, 40.0), (-2.028, -1.942, 5.870, 20.0, 40.0), (1.810, -1.244, 6.392, 20.0, 40.0), (-0.783, 1.242, 0.124, 20.0, 40.0), (-4.745, -1.300, 3.227, 20.0, 40.0), (1.902, 1.973, 0.005, 20.0, 40.0), (-3.453, -1.429, 4.132, 20.0, 40.0), (1.559, 0.986, 1.808, 20.0, 40.0), (0.128, 2.754, -2.443, 20.0, 40.0), (2.759, 1.727, 0.926, 20.0, 40.0), (-4.468, 1.690, -2.614, 20.0, 40.0), (-2.368, -1.922, 5.659, 20.0, 40.0), (-2.766, 2.128, -2.640, 20.0, 40.0), (0.967, -1.825, 7.133, 20.0, 40.0), (-2.854, 2.855, -4.136, 20.0, 40.0), (-2.944, 1.875, -2.222, 20.0, 40.0), (-2.632, -0.983, 3.649, 20.0, 40.0), (2.427, 2.239, -0.266, 20.0, 40.0), (-1.726, -0.838, 3.812, 20.0, 40.0), (0.007, -0.903, 4.809, 20.0, 40.0), (-2.013, 1.092, -0.191, 20.0, 40.0), (-0.449, 0.970, 0.836, 20.0, 40.0), (1.396, 0.411, 2.876, 20.0, 40.0), (-1.115, -1.790, 6.023, 20.0, 40.0), (3.748, 1.917, 1.039, 20.0, 40.0), (2.978, 1.043, 2.404, 20.0, 40.0), (-3.969, 2.514, -4.013, 20.0, 40.0), (4.455, -0.050, 5.328, 20.0, 40.0), (-3.065, -0.846, 3.160, 20.0, 40.0), (-1.069, 2.167, -1.869, 20.0, 40.0), (3.016, -1.393, 7.294, 20.0, 40.0), (0.045, -1.928, 6.879, 20.0, 40.0), (-2.555, -0.984, 3.690, 20.0, 40.0), (-1.995, -0.054, 2.111, 20.0, 40.0), (4.600, -0.509, 6.318, 20.0, 40.0), (-1.942, 1.215, -0.402, 20.0, 40.0), (1.262, 2.765, -1.899, 20.0, 40.0), (2.617, -1.106, 6.521, 20.0, 40.0), (1.737, 0.554, 2.761, 20.0, 40.0), (-2.197, 0.632, 0.638, 20.0, 40.0), (4.768, 2.618, 0.147, 20.0, 40.0), (-3.737, -0.939, 3.010, 20.0, 40.0), (-2.623, 0.595, 0.499, 20.0, 40.0), (4.752, -0.340, 6.057, 20.0, 40.0), (2.333, -1.037, 6.240, 20.0, 40.0), (4.234, -1.882, 8.881, 20.0, 40.0), (-3.393, -0.812, 2.927, 20.0, 40.0), (0.885, 1.383, 0.678, 20.0, 40.0), (0.123, 2.937, -2.812, 20.0, 40.0), (2.969, 0.760, 2.964, 20.0, 40.0), (-4.929, 1.251, -1.967, 20.0, 40.0), (1.916, 2.223, -0.488, 20.0, 40.0), (-0.020, -1.740, 6.469, 20.0, 40.0), (0.702, -1.272, 5.895, 20.0, 40.0), (2.496, 2.648, -1.048, 20.0, 40.0), (4.067, -1.475, 7.984, 20.0, 40.0), (-3.717, 1.851, -2.561, 20.0, 40.0), (1.678, -0.624, 5.088, 20.0, 40.0), (1.073, 0.695, 2.146, 20.0, 40.0), (1.842, -0.749, 5.419, 20.0, 40.0), (-3.518, 1.909, -2.578, 20.0, 40.0), (2.229, 1.189, 1.737, 20.0, 40.0), (4.987, 2.893, -0.292, 20.0, 40.0), (-4.809, 1.043, -1.490, 20.0, 40.0), (-0.241, -0.728, 4.334, 20.0, 40.0), (-3.331, 0.590, 0.156, 20.0, 40.0), (-0.455, 2.621, -2.470, 20.0, 40.0), (1.492, 1.223, 1.301, 20.0, 40.0), (3.948, 2.841, -0.709, 20.0, 40.0), (0.732, 0.446, 2.475, 20.0, 40.0), (2.400, 2.390, -0.579, 20.0, 40.0), (-2.718, 1.427, -1.213, 20.0, 40.0), (-1.826, 1.451, -0.815, 20.0, 40.0), (1.125, 0.438, 2.686, 20.0, 40.0), (-4.918, 1.880, -3.219, 20.0, 40.0), (3.068, -0.442, 5.418, 20.0, 40.0), (1.982, 1.201, 1.589, 20.0, 40.0), (0.701, -1.709, 6.768, 20.0, 40.0), (-1.496, 2.564, -2.877, 20.0, 40.0), (-3.812, 0.974, -0.853, 20.0, 40.0), (-3.405, 2.018, -2.739, 20.0, 40.0), (2.211, 2.889, -1.674, 20.0, 40.0), (-2.481, 2.931, -4.103, 20.0, 40.0), (-3.721, 2.765, -4.391, 20.0, 40.0), (-1.768, -1.292, 4.699, 20.0, 40.0), (-4.462, 1.058, -1.347, 20.0, 40.0), (-3.516, -1.942, 5.126, 20.0, 40.0), (0.485, 2.420, -1.597, 20.0, 40.0), (-0.492, 0.242, 2.270, 20.0, 40.0), (4.245, 1.689, 1.744, 20.0, 40.0), (2.234, 0.364, 3.389, 20.0, 40.0), (2.629, 2.224, -0.134, 20.0, 40.0), (-4.375, 1.221, -1.630, 20.0, 40.0), (-0.618, 1.374, -0.057, 20.0, 40.0), (-2.580, -1.604, 4.918, 20.0, 40.0), (0.159, 1.104, 0.871, 20.0, 40.0), (-3.597, 0.975, -0.749, 20.0, 40.0); DROP TABLE IF EXISTS test.model; -create table test.model engine = Memory as select LinearRegressionState(0.01, 5, 1.0)(target, param1, param2) as state from test.defaults; +create table test.model engine = Memory as select LinearRegressionState(0.1, 5, 2.0)(target, param1, param2) as state from test.defaults; with (select state from test.model) as model select evalMLMethod(model, predict1, predict2) from test.defaults; diff --git a/dbms/tests/queries/0_stateless/00951_ml_test.sql b/dbms/tests/queries/0_stateless/00951_ml_test.sql index ca9c2f99505..3bce8cc3085 100644 --- a/dbms/tests/queries/0_stateless/00951_ml_test.sql +++ b/dbms/tests/queries/0_stateless/00951_ml_test.sql @@ -8,7 +8,7 @@ CREATE TABLE IF NOT EXISTS test.defaults predict1 Float64, predict2 Float64 ) ENGINE = Memory; -insert into test.defaults values (1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2),(1,2,1,-1,-2),(-1,-2,0,1,2) +insert into test.defaults values (1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2) DROP TABLE IF EXISTS test.model; create table test.model engine = Memory as select LogisticRegressionState(0.1, 5, 1.0)(target, param1, param2) as state from test.defaults; diff --git a/dbms/tests/queries/0_stateless/00954_ml_test.sql b/dbms/tests/queries/0_stateless/00954_ml_test.sql index 2df84c00d3f..932924672d6 100644 --- a/dbms/tests/queries/0_stateless/00954_ml_test.sql +++ b/dbms/tests/queries/0_stateless/00954_ml_test.sql @@ -11,7 +11,7 @@ CREATE TABLE IF NOT EXISTS test.defaults insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0), (-1.099, 2.755, -3.060, 20.0, 40.0), (1.090, 2.945, -2.346, 20.0, 40.0), (0.305, 2.179, -1.205, 20.0, 40.0), (-0.925, 0.702, 1.134, 20.0, 40.0), (3.178, -1.316, 7.221, 20.0, 40.0), (-2.756, -0.473, 2.569, 20.0, 40.0), (3.665, 2.303, 0.226, 20.0, 40.0), (1.662, 1.951, -0.070, 20.0, 40.0), (2.869, 0.593, 3.249, 20.0, 40.0), (0.818, -0.593, 4.594, 20.0, 40.0), (-1.917, 0.916, 0.209, 20.0, 40.0), (2.706, 1.523, 1.307, 20.0, 40.0), (0.219, 2.162, -1.214, 20.0, 40.0), (-4.510, 1.376, -2.007, 20.0, 40.0), (4.284, -0.515, 6.173, 20.0, 40.0), (-1.101, 2.810, -3.170, 20.0, 40.0), (-1.810, -1.117, 4.329, 20.0, 40.0), (0.055, 1.115, 0.797, 20.0, 40.0), (-2.178, 2.904, -3.898, 20.0, 40.0), (-3.494, -1.814, 4.882, 20.0, 40.0), (3.027, 0.476, 3.562, 20.0, 40.0), (-1.434, 1.151, -0.018, 20.0, 40.0), (1.180, 0.992, 1.606, 20.0, 40.0), (0.015, 0.971, 1.067, 20.0, 40.0), (-0.511, -0.875, 4.495, 20.0, 40.0), (0.961, 2.348, -1.216, 20.0, 40.0), (-2.279, 0.038, 1.785, 20.0, 40.0), (-1.568, -0.248, 2.712, 20.0, 40.0), (-0.496, 0.366, 2.020, 20.0, 40.0), (1.177, -1.401, 6.390, 20.0, 40.0), (2.882, -1.442, 7.325, 20.0, 40.0), (-1.066, 1.817, -1.167, 20.0, 40.0), (-2.144, 2.791, -3.655, 20.0, 40.0), (-4.370, 2.228, -3.642, 20.0, 40.0), (3.996, 2.775, -0.553, 20.0, 40.0), (0.289, 2.055, -0.965, 20.0, 40.0), (-0.588, -1.601, 5.908, 20.0, 40.0), (-1.801, 0.417, 1.265, 20.0, 40.0), (4.375, -1.499, 8.186, 20.0, 40.0), (-2.618, 0.038, 1.615, 20.0, 40.0), (3.616, -0.833, 6.475, 20.0, 40.0), (-4.045, -1.558, 4.094, 20.0, 40.0), (-3.962, 0.636, -0.253, 20.0, 40.0), (3.505, 2.625, -0.497, 20.0, 40.0), (3.029, -0.523, 5.560, 20.0, 40.0), (-3.520, -0.474, 2.188, 20.0, 40.0), (2.430, -1.469, 7.154, 20.0, 40.0), (1.547, -1.654, 7.082, 20.0, 40.0), (-1.370, 0.575, 1.165, 20.0, 40.0), (-1.869, -1.555, 5.176, 20.0, 40.0), (3.536, 2.841, -0.913, 20.0, 40.0), (-3.810, 1.220, -1.344, 20.0, 40.0), (-1.971, 1.462, -0.910, 20.0, 40.0), (-0.243, 0.167, 2.545, 20.0, 40.0), (-1.403, 2.645, -2.991, 20.0, 40.0), (0.532, -0.114, 3.494, 20.0, 40.0), (-1.678, 0.975, 0.212, 20.0, 40.0), (-0.656, 2.140, -1.609, 20.0, 40.0), (1.743, 2.631, -1.390, 20.0, 40.0), (2.586, 2.943, -1.593, 20.0, 40.0), (-0.512, 2.969, -3.195, 20.0, 40.0), (2.283, -0.100, 4.342, 20.0, 40.0), (-4.293, 0.872, -0.890, 20.0, 40.0), (3.411, 1.300, 2.106, 20.0, 40.0), (-0.281, 2.951, -3.042, 20.0, 40.0), (-4.442, 0.384, 0.012, 20.0, 40.0), (1.194, 1.746, 0.104, 20.0, 40.0), (-1.152, 1.862, -1.300, 20.0, 40.0), (1.362, -1.341, 6.363, 20.0, 40.0), (-4.488, 2.618, -4.481, 20.0, 40.0), (3.419, -0.564, 5.837, 20.0, 40.0), (-3.392, 0.396, 0.512, 20.0, 40.0), (-1.629, -0.909, 4.003, 20.0, 40.0), (4.447, -1.088, 7.399, 20.0, 40.0), (-1.232, 1.699, -1.014, 20.0, 40.0), (-1.286, -0.609, 3.575, 20.0, 40.0), (2.437, 2.796, -1.374, 20.0, 40.0), (-4.864, 1.989, -3.410, 20.0, 40.0), (-1.716, -1.399, 4.940, 20.0, 40.0), (-3.084, 1.858, -2.259, 20.0, 40.0), (2.828, -0.319, 5.053, 20.0, 40.0), (-1.226, 2.586, -2.786, 20.0, 40.0), (2.456, 0.092, 4.044, 20.0, 40.0), (-0.989, 2.375, -2.245, 20.0, 40.0), (3.268, 0.935, 2.765, 20.0, 40.0), (-4.128, -1.995, 4.927, 20.0, 40.0), (-1.083, 2.197, -1.935, 20.0, 40.0), (-3.471, -1.198, 3.660, 20.0, 40.0), (4.617, -1.136, 7.579, 20.0, 40.0), (2.054, -1.675, 7.378, 20.0, 40.0), (4.106, 2.326, 0.402, 20.0, 40.0), (1.558, 0.310, 3.158, 20.0, 40.0), (0.792, 0.900, 1.596, 20.0, 40.0), (-3.229, 0.300, 0.785, 20.0, 40.0), (3.787, -0.793, 6.479, 20.0, 40.0), (1.786, 2.288, -0.684, 20.0, 40.0), (2.643, 0.223, 3.875, 20.0, 40.0), (-3.592, 2.122, -3.040, 20.0, 40.0), (4.519, -1.760, 8.779, 20.0, 40.0), (3.221, 2.255, 0.101, 20.0, 40.0), (4.151, 1.788, 1.500, 20.0, 40.0), (-1.033, -1.195, 4.874, 20.0, 40.0), (-1.636, -1.037, 4.257, 20.0, 40.0), (-3.548, 1.911, -2.596, 20.0, 40.0), (4.829, -0.293, 6.001, 20.0, 40.0), (-4.684, -1.664, 3.986, 20.0, 40.0), (4.531, -0.503, 6.271, 20.0, 40.0), (-3.503, -1.606, 4.460, 20.0, 40.0), (-2.036, -1.522, 5.027, 20.0, 40.0), (-0.473, -0.617, 3.997, 20.0, 40.0), (-1.554, -1.630, 5.483, 20.0, 40.0), (-3.567, -1.043, 3.302, 20.0, 40.0), (-2.038, 0.579, 0.823, 20.0, 40.0), (-3.040, 0.857, -0.233, 20.0, 40.0), (4.610, 0.562, 4.181, 20.0, 40.0), (-3.323, -1.938, 5.215, 20.0, 40.0), (4.314, 1.720, 1.717, 20.0, 40.0), (-1.220, 0.615, 1.161, 20.0, 40.0), (-2.556, 1.120, -0.519, 20.0, 40.0), (-3.717, -0.108, 1.358, 20.0, 40.0), (4.689, -1.826, 8.996, 20.0, 40.0), (3.452, 0.506, 3.713, 20.0, 40.0), (2.472, 0.612, 3.012, 20.0, 40.0), (3.452, 0.450, 3.826, 20.0, 40.0), (1.207, 2.585, -1.567, 20.0, 40.0), (-4.826, 1.090, -1.593, 20.0, 40.0), (3.116, -1.118, 6.794, 20.0, 40.0), (0.448, 2.732, -2.240, 20.0, 40.0), (-1.096, -0.525, 3.503, 20.0, 40.0), (-4.680, -0.238, 1.137, 20.0, 40.0), (2.552, -1.403, 7.082, 20.0, 40.0), (0.719, 2.997, -2.635, 20.0, 40.0), (0.347, -1.966, 7.105, 20.0, 40.0), (2.958, -0.404, 5.288, 20.0, 40.0), (0.722, -1.950, 7.261, 20.0, 40.0), (-2.851, -0.986, 3.546, 20.0, 40.0), (-4.316, -0.439, 1.721, 20.0, 40.0), (-1.685, -0.201, 2.560, 20.0, 40.0), (1.856, 0.190, 3.549, 20.0, 40.0), (-2.052, 0.206, 1.562, 20.0, 40.0), (-2.504, -0.646, 3.041, 20.0, 40.0), (3.235, 0.882, 2.854, 20.0, 40.0), (-1.366, -1.573, 5.463, 20.0, 40.0), (-3.447, 2.419, -3.562, 20.0, 40.0), (4.155, 2.092, 0.893, 20.0, 40.0), (-0.935, 0.209, 2.116, 20.0, 40.0), (3.117, -1.821, 8.201, 20.0, 40.0), (3.759, 0.577, 3.725, 20.0, 40.0), (-0.938, 2.992, -3.453, 20.0, 40.0), (-0.525, 2.341, -1.945, 20.0, 40.0), (4.540, 2.625, 0.019, 20.0, 40.0), (-2.097, 1.190, -0.429, 20.0, 40.0), (-2.672, 1.983, -2.302, 20.0, 40.0), (-3.038, -1.490, 4.460, 20.0, 40.0), (-0.943, 2.149, -1.770, 20.0, 40.0), (0.739, 1.598, 0.174, 20.0, 40.0), (1.828, 1.853, 0.208, 20.0, 40.0), (4.856, 0.137, 5.153, 20.0, 40.0), (-1.617, 0.468, 1.255, 20.0, 40.0), (-1.972, 2.053, -2.092, 20.0, 40.0), (-4.633, 1.389, -2.094, 20.0, 40.0), (-3.628, -1.156, 3.498, 20.0, 40.0), (3.597, 1.034, 2.731, 20.0, 40.0), (-1.488, -0.002, 2.261, 20.0, 40.0), (0.749, 1.921, -0.468, 20.0, 40.0), (1.304, -1.371, 6.394, 20.0, 40.0), (4.587, 2.936, -0.579, 20.0, 40.0), (-2.241, 1.791, -1.703, 20.0, 40.0), (-2.945, 1.372, -1.216, 20.0, 40.0), (1.375, 0.395, 2.898, 20.0, 40.0), (-1.281, -0.641, 3.642, 20.0, 40.0), (2.178, 0.895, 2.299, 20.0, 40.0), (3.031, -0.786, 6.087, 20.0, 40.0), (-1.385, -0.375, 3.058, 20.0, 40.0), (4.041, -0.431, 5.882, 20.0, 40.0), (0.480, -0.507, 4.254, 20.0, 40.0), (-3.797, 0.140, 0.822, 20.0, 40.0), (2.355, 2.502, -0.827, 20.0, 40.0), (1.376, -1.583, 6.854, 20.0, 40.0), (0.164, 1.405, 0.273, 20.0, 40.0), (-1.273, 1.471, -0.579, 20.0, 40.0), (0.770, 2.246, -1.107, 20.0, 40.0), (4.552, 2.904, -0.533, 20.0, 40.0), (4.259, -1.772, 8.674, 20.0, 40.0), (-0.309, 1.159, 0.528, 20.0, 40.0), (3.581, 2.700, -0.610, 20.0, 40.0), (-3.202, 0.346, 0.707, 20.0, 40.0), (-1.575, 1.242, -0.271, 20.0, 40.0), (-1.584, -0.493, 3.194, 20.0, 40.0), (-3.778, 0.150, 0.810, 20.0, 40.0), (-4.675, 1.749, -2.835, 20.0, 40.0), (3.567, -0.792, 6.367, 20.0, 40.0), (-0.417, 1.399, -0.006, 20.0, 40.0), (-4.672, 2.007, -3.349, 20.0, 40.0), (-1.034, 0.196, 2.090, 20.0, 40.0), (-3.796, 2.496, -3.890, 20.0, 40.0), (3.532, -0.497, 5.759, 20.0, 40.0), (4.868, -1.359, 8.151, 20.0, 40.0), (-0.769, 0.302, 2.011, 20.0, 40.0), (4.475, 2.612, 0.014, 20.0, 40.0), (-3.532, -0.395, 2.024, 20.0, 40.0), (0.322, 0.675, 1.812, 20.0, 40.0), (-2.028, -1.942, 5.870, 20.0, 40.0), (1.810, -1.244, 6.392, 20.0, 40.0), (-0.783, 1.242, 0.124, 20.0, 40.0), (-4.745, -1.300, 3.227, 20.0, 40.0), (1.902, 1.973, 0.005, 20.0, 40.0), (-3.453, -1.429, 4.132, 20.0, 40.0), (1.559, 0.986, 1.808, 20.0, 40.0), (0.128, 2.754, -2.443, 20.0, 40.0), (2.759, 1.727, 0.926, 20.0, 40.0), (-4.468, 1.690, -2.614, 20.0, 40.0), (-2.368, -1.922, 5.659, 20.0, 40.0), (-2.766, 2.128, -2.640, 20.0, 40.0), (0.967, -1.825, 7.133, 20.0, 40.0), (-2.854, 2.855, -4.136, 20.0, 40.0), (-2.944, 1.875, -2.222, 20.0, 40.0), (-2.632, -0.983, 3.649, 20.0, 40.0), (2.427, 2.239, -0.266, 20.0, 40.0), (-1.726, -0.838, 3.812, 20.0, 40.0), (0.007, -0.903, 4.809, 20.0, 40.0), (-2.013, 1.092, -0.191, 20.0, 40.0), (-0.449, 0.970, 0.836, 20.0, 40.0), (1.396, 0.411, 2.876, 20.0, 40.0), (-1.115, -1.790, 6.023, 20.0, 40.0), (3.748, 1.917, 1.039, 20.0, 40.0), (2.978, 1.043, 2.404, 20.0, 40.0), (-3.969, 2.514, -4.013, 20.0, 40.0), (4.455, -0.050, 5.328, 20.0, 40.0), (-3.065, -0.846, 3.160, 20.0, 40.0), (-1.069, 2.167, -1.869, 20.0, 40.0), (3.016, -1.393, 7.294, 20.0, 40.0), (0.045, -1.928, 6.879, 20.0, 40.0), (-2.555, -0.984, 3.690, 20.0, 40.0), (-1.995, -0.054, 2.111, 20.0, 40.0), (4.600, -0.509, 6.318, 20.0, 40.0), (-1.942, 1.215, -0.402, 20.0, 40.0), (1.262, 2.765, -1.899, 20.0, 40.0), (2.617, -1.106, 6.521, 20.0, 40.0), (1.737, 0.554, 2.761, 20.0, 40.0), (-2.197, 0.632, 0.638, 20.0, 40.0), (4.768, 2.618, 0.147, 20.0, 40.0), (-3.737, -0.939, 3.010, 20.0, 40.0), (-2.623, 0.595, 0.499, 20.0, 40.0), (4.752, -0.340, 6.057, 20.0, 40.0), (2.333, -1.037, 6.240, 20.0, 40.0), (4.234, -1.882, 8.881, 20.0, 40.0), (-3.393, -0.812, 2.927, 20.0, 40.0), (0.885, 1.383, 0.678, 20.0, 40.0), (0.123, 2.937, -2.812, 20.0, 40.0), (2.969, 0.760, 2.964, 20.0, 40.0), (-4.929, 1.251, -1.967, 20.0, 40.0), (1.916, 2.223, -0.488, 20.0, 40.0), (-0.020, -1.740, 6.469, 20.0, 40.0), (0.702, -1.272, 5.895, 20.0, 40.0), (2.496, 2.648, -1.048, 20.0, 40.0), (4.067, -1.475, 7.984, 20.0, 40.0), (-3.717, 1.851, -2.561, 20.0, 40.0), (1.678, -0.624, 5.088, 20.0, 40.0), (1.073, 0.695, 2.146, 20.0, 40.0), (1.842, -0.749, 5.419, 20.0, 40.0), (-3.518, 1.909, -2.578, 20.0, 40.0), (2.229, 1.189, 1.737, 20.0, 40.0), (4.987, 2.893, -0.292, 20.0, 40.0), (-4.809, 1.043, -1.490, 20.0, 40.0), (-0.241, -0.728, 4.334, 20.0, 40.0), (-3.331, 0.590, 0.156, 20.0, 40.0), (-0.455, 2.621, -2.470, 20.0, 40.0), (1.492, 1.223, 1.301, 20.0, 40.0), (3.948, 2.841, -0.709, 20.0, 40.0), (0.732, 0.446, 2.475, 20.0, 40.0), (2.400, 2.390, -0.579, 20.0, 40.0), (-2.718, 1.427, -1.213, 20.0, 40.0), (-1.826, 1.451, -0.815, 20.0, 40.0), (1.125, 0.438, 2.686, 20.0, 40.0), (-4.918, 1.880, -3.219, 20.0, 40.0), (3.068, -0.442, 5.418, 20.0, 40.0), (1.982, 1.201, 1.589, 20.0, 40.0), (0.701, -1.709, 6.768, 20.0, 40.0), (-1.496, 2.564, -2.877, 20.0, 40.0), (-3.812, 0.974, -0.853, 20.0, 40.0), (-3.405, 2.018, -2.739, 20.0, 40.0), (2.211, 2.889, -1.674, 20.0, 40.0), (-2.481, 2.931, -4.103, 20.0, 40.0), (-3.721, 2.765, -4.391, 20.0, 40.0), (-1.768, -1.292, 4.699, 20.0, 40.0), (-4.462, 1.058, -1.347, 20.0, 40.0), (-3.516, -1.942, 5.126, 20.0, 40.0), (0.485, 2.420, -1.597, 20.0, 40.0), (-0.492, 0.242, 2.270, 20.0, 40.0), (4.245, 1.689, 1.744, 20.0, 40.0), (2.234, 0.364, 3.389, 20.0, 40.0), (2.629, 2.224, -0.134, 20.0, 40.0), (-4.375, 1.221, -1.630, 20.0, 40.0), (-0.618, 1.374, -0.057, 20.0, 40.0), (-2.580, -1.604, 4.918, 20.0, 40.0), (0.159, 1.104, 0.871, 20.0, 40.0), (-3.597, 0.975, -0.749, 20.0, 40.0); DROP TABLE IF EXISTS test.model; -create table test.model engine = Memory as select LinearRegressionState(0.1, 5, 1.0)(target, param1, param2) as state from test.defaults; +create table test.model engine = Memory as select LinearRegressionState(0.01, 1, 2.0)(target, param1, param2) as state from test.defaults; with (select state from test.model) as model select evalMLMethod(model, predict1, predict2) from test.defaults; From 521e897a92bff165c0f2a79e3517dff107fd10cc Mon Sep 17 00:00:00 2001 From: ivan-kush Date: Sat, 9 Mar 2019 21:24:11 +0300 Subject: [PATCH 023/709] init --- dbms/src/Storages/StorageMergeTree.cpp | 26 +++++++++++++++++++++++--- 1 file changed, 23 insertions(+), 3 deletions(-) diff --git a/dbms/src/Storages/StorageMergeTree.cpp b/dbms/src/Storages/StorageMergeTree.cpp index ba3fe04dd89..10b9b9d51b6 100644 --- a/dbms/src/Storages/StorageMergeTree.cpp +++ b/dbms/src/Storages/StorageMergeTree.cpp @@ -3,6 +3,8 @@ #include #include #include +#include +#include #include #include @@ -224,11 +226,29 @@ void StorageMergeTree::alter( auto parts = data.getDataParts({MergeTreeDataPartState::PreCommitted, MergeTreeDataPartState::Committed, MergeTreeDataPartState::Outdated}); auto columns_for_parts = new_columns.getAllPhysical(); std::vector transactions; - for (const MergeTreeData::DataPartPtr & part : parts) + + ThreadPool thread_pool(2 * getNumberOfPhysicalCPUCores()); + size_t i = 0; + transactions.resize(parts.size()); + for (const auto & part : parts) { - if (auto transaction = data.alterDataPart(part, columns_for_parts, new_indices.indices, false)) - transactions.push_back(std::move(transaction)); + thread_pool.schedule( + [this, i, &transactions, &part, columns_for_parts, new_indices = new_indices.indices] { + if (auto transaction = this->data.alterDataPart(part, columns_for_parts, new_indices, false)) + transactions[i] = (std::move(transaction)); + } + ); + + ++i; } + thread_pool.wait(); + transactions.erase( + std::remove_if(transactions.begin(), transactions.end(), + [](const MergeTreeData::AlterDataPartTransactionPtr& transaction) { + return transaction == nullptr; + } + ) + ); auto table_hard_lock = lockStructureForAlter(context.getCurrentQueryId()); From c3182d4ae690e5f51e3a1e6de3f6c14cea3f0bd4 Mon Sep 17 00:00:00 2001 From: ivan-kush Date: Sun, 10 Mar 2019 22:47:26 +0300 Subject: [PATCH 024/709] fix erase --- dbms/src/Storages/StorageMergeTree.cpp | 62 +++++++++++++++----------- dbms/src/Storages/StorageMergeTree.h | 3 ++ 2 files changed, 38 insertions(+), 27 deletions(-) diff --git a/dbms/src/Storages/StorageMergeTree.cpp b/dbms/src/Storages/StorageMergeTree.cpp index 10b9b9d51b6..a1fa2426249 100644 --- a/dbms/src/Storages/StorageMergeTree.cpp +++ b/dbms/src/Storages/StorageMergeTree.cpp @@ -193,6 +193,38 @@ void StorageMergeTree::rename(const String & new_path_to_db, const String & /*ne } +std::vector StorageMergeTree::prepare_alter_transactions( + const ColumnsDescription& new_columns, const IndicesDescription& new_indices, const size_t thread_pool_size) +{ + ThreadPool thread_pool(thread_pool_size); + + auto parts = data.getDataParts({MergeTreeDataPartState::PreCommitted, MergeTreeDataPartState::Committed, MergeTreeDataPartState::Outdated}); + std::vector transactions(parts.size()); + const auto& columns_for_parts = new_columns.getAllPhysical(); + size_t i = 0; + for (const auto & part : parts) + { + thread_pool.schedule( + [this, i, &transactions, &part, columns_for_parts, new_indices = new_indices.indices] + { + if (auto transaction = this->data.alterDataPart(part, columns_for_parts, new_indices, false)) + transactions[i] = (std::move(transaction)); + } + ); + + ++i; + } + thread_pool.wait(); + auto erase_pos = std::remove_if(transactions.begin(), transactions.end(), + [](const MergeTreeData::AlterDataPartTransactionPtr& transaction) { + return transaction == nullptr; + } + ); + transactions.erase(erase_pos, transactions.end()); + + return transactions; +} + void StorageMergeTree::alter( const AlterCommands & params, const String & current_database_name, @@ -223,32 +255,8 @@ void StorageMergeTree::alter( ASTPtr new_primary_key_ast = data.primary_key_ast; params.apply(new_columns, new_indices, new_order_by_ast, new_primary_key_ast); - auto parts = data.getDataParts({MergeTreeDataPartState::PreCommitted, MergeTreeDataPartState::Committed, MergeTreeDataPartState::Outdated}); - auto columns_for_parts = new_columns.getAllPhysical(); - std::vector transactions; - - ThreadPool thread_pool(2 * getNumberOfPhysicalCPUCores()); - size_t i = 0; - transactions.resize(parts.size()); - for (const auto & part : parts) - { - thread_pool.schedule( - [this, i, &transactions, &part, columns_for_parts, new_indices = new_indices.indices] { - if (auto transaction = this->data.alterDataPart(part, columns_for_parts, new_indices, false)) - transactions[i] = (std::move(transaction)); - } - ); - - ++i; - } - thread_pool.wait(); - transactions.erase( - std::remove_if(transactions.begin(), transactions.end(), - [](const MergeTreeData::AlterDataPartTransactionPtr& transaction) { - return transaction == nullptr; - } - ) - ); + std::vector transactions = prepare_alter_transactions(new_columns, new_indices, + 2 * getNumberOfPhysicalCPUCores()); auto table_hard_lock = lockStructureForAlter(context.getCurrentQueryId()); @@ -269,7 +277,7 @@ void StorageMergeTree::alter( data.setPrimaryKeyIndicesAndColumns(new_order_by_ast, new_primary_key_ast, new_columns, new_indices); for (auto & transaction : transactions) - transaction->commit(); + transaction->commit(); /// Columns sizes could be changed data.recalculateColumnSizes(); diff --git a/dbms/src/Storages/StorageMergeTree.h b/dbms/src/Storages/StorageMergeTree.h index d17b496bd97..36b6cb9fc36 100644 --- a/dbms/src/Storages/StorageMergeTree.h +++ b/dbms/src/Storages/StorageMergeTree.h @@ -132,6 +132,9 @@ private: BackgroundProcessingPool::TaskHandle background_task_handle; + std::vector prepare_alter_transactions( + const ColumnsDescription& new_columns, const IndicesDescription& new_indices, const size_t thread_pool_size); + void loadMutations(); /** Determines what parts should be merged and merges it. From 6acb39032ff072bc3771f0d7293456964fcbe5ca Mon Sep 17 00:00:00 2001 From: ivan-kush Date: Mon, 11 Mar 2019 23:17:50 +0300 Subject: [PATCH 025/709] format --- dbms/src/Storages/StorageMergeTree.cpp | 6 ++++-- 1 file changed, 4 insertions(+), 2 deletions(-) diff --git a/dbms/src/Storages/StorageMergeTree.cpp b/dbms/src/Storages/StorageMergeTree.cpp index a1fa2426249..363718badf0 100644 --- a/dbms/src/Storages/StorageMergeTree.cpp +++ b/dbms/src/Storages/StorageMergeTree.cpp @@ -200,7 +200,9 @@ std::vector StorageMergeTree::prepar auto parts = data.getDataParts({MergeTreeDataPartState::PreCommitted, MergeTreeDataPartState::Committed, MergeTreeDataPartState::Outdated}); std::vector transactions(parts.size()); + const auto& columns_for_parts = new_columns.getAllPhysical(); + size_t i = 0; for (const auto & part : parts) { @@ -215,6 +217,7 @@ std::vector StorageMergeTree::prepar ++i; } thread_pool.wait(); + auto erase_pos = std::remove_if(transactions.begin(), transactions.end(), [](const MergeTreeData::AlterDataPartTransactionPtr& transaction) { return transaction == nullptr; @@ -255,8 +258,7 @@ void StorageMergeTree::alter( ASTPtr new_primary_key_ast = data.primary_key_ast; params.apply(new_columns, new_indices, new_order_by_ast, new_primary_key_ast); - std::vector transactions = prepare_alter_transactions(new_columns, new_indices, - 2 * getNumberOfPhysicalCPUCores()); + auto transactions = prepare_alter_transactions(new_columns, new_indices, 2 * getNumberOfPhysicalCPUCores()); auto table_hard_lock = lockStructureForAlter(context.getCurrentQueryId()); From 3f01882310f0755abd61d8d459eac942fe136ab5 Mon Sep 17 00:00:00 2001 From: ivan-kush Date: Tue, 12 Mar 2019 08:56:02 +0300 Subject: [PATCH 026/709] format2 --- dbms/src/Storages/StorageMergeTree.cpp | 3 ++- 1 file changed, 2 insertions(+), 1 deletion(-) diff --git a/dbms/src/Storages/StorageMergeTree.cpp b/dbms/src/Storages/StorageMergeTree.cpp index 363718badf0..a7a618873a8 100644 --- a/dbms/src/Storages/StorageMergeTree.cpp +++ b/dbms/src/Storages/StorageMergeTree.cpp @@ -219,7 +219,8 @@ std::vector StorageMergeTree::prepar thread_pool.wait(); auto erase_pos = std::remove_if(transactions.begin(), transactions.end(), - [](const MergeTreeData::AlterDataPartTransactionPtr& transaction) { + [](const MergeTreeData::AlterDataPartTransactionPtr& transaction) + { return transaction == nullptr; } ); From 6daee801fafd2f45360408a735233818aa4594b2 Mon Sep 17 00:00:00 2001 From: alexey-milovidov Date: Tue, 12 Mar 2019 16:24:03 +0300 Subject: [PATCH 027/709] Update StorageMergeTree.cpp --- dbms/src/Storages/StorageMergeTree.cpp | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/dbms/src/Storages/StorageMergeTree.cpp b/dbms/src/Storages/StorageMergeTree.cpp index a7a618873a8..ab176cae64d 100644 --- a/dbms/src/Storages/StorageMergeTree.cpp +++ b/dbms/src/Storages/StorageMergeTree.cpp @@ -280,7 +280,7 @@ void StorageMergeTree::alter( data.setPrimaryKeyIndicesAndColumns(new_order_by_ast, new_primary_key_ast, new_columns, new_indices); for (auto & transaction : transactions) - transaction->commit(); + transaction->commit(); /// Columns sizes could be changed data.recalculateColumnSizes(); From 72f785bd1db0788b3ae4e1e4b272c54db66665fc Mon Sep 17 00:00:00 2001 From: alexey-milovidov Date: Tue, 12 Mar 2019 16:24:56 +0300 Subject: [PATCH 028/709] Update StorageMergeTree.cpp --- dbms/src/Storages/StorageMergeTree.cpp | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/dbms/src/Storages/StorageMergeTree.cpp b/dbms/src/Storages/StorageMergeTree.cpp index ab176cae64d..dbfa02b2869 100644 --- a/dbms/src/Storages/StorageMergeTree.cpp +++ b/dbms/src/Storages/StorageMergeTree.cpp @@ -194,7 +194,7 @@ void StorageMergeTree::rename(const String & new_path_to_db, const String & /*ne std::vector StorageMergeTree::prepare_alter_transactions( - const ColumnsDescription& new_columns, const IndicesDescription& new_indices, const size_t thread_pool_size) + const ColumnsDescription & new_columns, const IndicesDescription & new_indices, const size_t thread_pool_size) { ThreadPool thread_pool(thread_pool_size); From fc3cb57881e85cbc96643ab71237bbd6d9591fad Mon Sep 17 00:00:00 2001 From: alexey-milovidov Date: Tue, 12 Mar 2019 16:26:26 +0300 Subject: [PATCH 029/709] Update StorageMergeTree.cpp --- dbms/src/Storages/StorageMergeTree.cpp | 10 +++++----- 1 file changed, 5 insertions(+), 5 deletions(-) diff --git a/dbms/src/Storages/StorageMergeTree.cpp b/dbms/src/Storages/StorageMergeTree.cpp index dbfa02b2869..90a50ce80f8 100644 --- a/dbms/src/Storages/StorageMergeTree.cpp +++ b/dbms/src/Storages/StorageMergeTree.cpp @@ -193,7 +193,7 @@ void StorageMergeTree::rename(const String & new_path_to_db, const String & /*ne } -std::vector StorageMergeTree::prepare_alter_transactions( +std::vector StorageMergeTree::prepareAlterTransactions( const ColumnsDescription & new_columns, const IndicesDescription & new_indices, const size_t thread_pool_size) { ThreadPool thread_pool(thread_pool_size); @@ -201,7 +201,7 @@ std::vector StorageMergeTree::prepar auto parts = data.getDataParts({MergeTreeDataPartState::PreCommitted, MergeTreeDataPartState::Committed, MergeTreeDataPartState::Outdated}); std::vector transactions(parts.size()); - const auto& columns_for_parts = new_columns.getAllPhysical(); + const auto & columns_for_parts = new_columns.getAllPhysical(); size_t i = 0; for (const auto & part : parts) @@ -210,7 +210,7 @@ std::vector StorageMergeTree::prepar [this, i, &transactions, &part, columns_for_parts, new_indices = new_indices.indices] { if (auto transaction = this->data.alterDataPart(part, columns_for_parts, new_indices, false)) - transactions[i] = (std::move(transaction)); + transactions[i] = std::move(transaction); } ); @@ -219,7 +219,7 @@ std::vector StorageMergeTree::prepar thread_pool.wait(); auto erase_pos = std::remove_if(transactions.begin(), transactions.end(), - [](const MergeTreeData::AlterDataPartTransactionPtr& transaction) + [](const MergeTreeData::AlterDataPartTransactionPtr & transaction) { return transaction == nullptr; } @@ -259,7 +259,7 @@ void StorageMergeTree::alter( ASTPtr new_primary_key_ast = data.primary_key_ast; params.apply(new_columns, new_indices, new_order_by_ast, new_primary_key_ast); - auto transactions = prepare_alter_transactions(new_columns, new_indices, 2 * getNumberOfPhysicalCPUCores()); + auto transactions = prepareAlterTransactions(new_columns, new_indices, 2 * getNumberOfPhysicalCPUCores()); auto table_hard_lock = lockStructureForAlter(context.getCurrentQueryId()); From 24d0315f1e7cbf7218c612e338b2acc2ab8c9426 Mon Sep 17 00:00:00 2001 From: alexey-milovidov Date: Tue, 12 Mar 2019 16:26:48 +0300 Subject: [PATCH 030/709] Update StorageMergeTree.h --- dbms/src/Storages/StorageMergeTree.h | 4 ++-- 1 file changed, 2 insertions(+), 2 deletions(-) diff --git a/dbms/src/Storages/StorageMergeTree.h b/dbms/src/Storages/StorageMergeTree.h index 36b6cb9fc36..7e0da497465 100644 --- a/dbms/src/Storages/StorageMergeTree.h +++ b/dbms/src/Storages/StorageMergeTree.h @@ -132,8 +132,8 @@ private: BackgroundProcessingPool::TaskHandle background_task_handle; - std::vector prepare_alter_transactions( - const ColumnsDescription& new_columns, const IndicesDescription& new_indices, const size_t thread_pool_size); + std::vector prepareAlterTransactions( + const ColumnsDescription & new_columns, const IndicesDescription & new_indices, const size_t thread_pool_size); void loadMutations(); From bfd53e3cccb0f8ebfce9b66e09c3860f2c574d30 Mon Sep 17 00:00:00 2001 From: Yuriy Date: Sat, 16 Mar 2019 05:08:21 +0300 Subject: [PATCH 031/709] draft --- dbms/programs/server/CMakeLists.txt | 1 + dbms/programs/server/MySQLHandler.cpp | 279 ++++++++++++++++ dbms/programs/server/MySQLHandler.h | 58 ++++ dbms/programs/server/MySQLHandlerFactory.h | 33 ++ dbms/programs/server/Server.cpp | 16 + dbms/src/Core/MySQLProtocol.cpp | 50 +++ dbms/src/Core/MySQLProtocol.h | 366 +++++++++++++++++++++ 7 files changed, 803 insertions(+) create mode 100644 dbms/programs/server/MySQLHandler.cpp create mode 100644 dbms/programs/server/MySQLHandler.h create mode 100644 dbms/programs/server/MySQLHandlerFactory.h create mode 100644 dbms/src/Core/MySQLProtocol.cpp create mode 100644 dbms/src/Core/MySQLProtocol.h diff --git a/dbms/programs/server/CMakeLists.txt b/dbms/programs/server/CMakeLists.txt index 5cb08018065..5b00f5574c8 100644 --- a/dbms/programs/server/CMakeLists.txt +++ b/dbms/programs/server/CMakeLists.txt @@ -8,6 +8,7 @@ set(CLICKHOUSE_SERVER_SOURCES ${CMAKE_CURRENT_SOURCE_DIR}/RootRequestHandler.cpp ${CMAKE_CURRENT_SOURCE_DIR}/Server.cpp ${CMAKE_CURRENT_SOURCE_DIR}/TCPHandler.cpp + ${CMAKE_CURRENT_SOURCE_DIR}/MySQLHandler.cpp ) set(CLICKHOUSE_SERVER_LINK PRIVATE clickhouse_dictionaries clickhouse_common_io PUBLIC daemon PRIVATE clickhouse_storages_system clickhouse_functions clickhouse_aggregate_functions clickhouse_table_functions ${Poco_Net_LIBRARY}) diff --git a/dbms/programs/server/MySQLHandler.cpp b/dbms/programs/server/MySQLHandler.cpp new file mode 100644 index 00000000000..ad250c8ce7e --- /dev/null +++ b/dbms/programs/server/MySQLHandler.cpp @@ -0,0 +1,279 @@ +#include +#include +#include +#include +#include +#include +#include +#include +#include +#include +#include +#include +#include +#include "MySQLHandler.h" +#include + + +namespace DB +{ +using namespace MySQLProtocol; + +uint32_t MySQLHandler::last_connection_id = 0; + +String MySQLHandler::readPayload() +{ + WriteBufferFromOwnString buf; + + size_t payload_length = 0; + uint8_t packet_sequence_id; + + // packets which are larger than or equal to 16MB are splitted + do { + LOG_TRACE(log, "Reading from buffer"); + + in->readStrict(reinterpret_cast(&payload_length), 3); + + if (payload_length > MAX_PACKET_LENGTH) { + throw ProtocolError(Poco::format("Received packet with payload length greater than 2^24 - 1: %z.", payload_length), 0); + } + + in->readStrict(reinterpret_cast(&packet_sequence_id), 1); + + if (packet_sequence_id != sequence_id) { + throw ProtocolError(Poco::format("Received packet with wrong sequence-id: %d. Expected: %d.", packet_sequence_id, sequence_id), 0); + } + sequence_id++; + + LOG_TRACE(log, "Received packet. Sequence-id: " << static_cast(packet_sequence_id) << ", payload length: " << payload_length); + + copyData(*in, static_cast(buf), payload_length); + } + while (payload_length == MAX_PACKET_LENGTH); + + return buf.str(); +} + +/// Converts packet to text. Useful for debugging, since packets often consist of non-printing characters. +static String packetToText(std::string_view payload) { + String result; + for (auto c : payload) { + result += ' '; + result += std::to_string(static_cast(c)); + } + return result; +} + +void MySQLHandler::writePayload(std::string_view payload) +{ + size_t pos = 0; + do + { + size_t payload_length = std::min(payload.length() - pos, MAX_PACKET_LENGTH); + + LOG_TRACE(log, "Writing packet of size " << payload_length << " with sequence-id " << static_cast(sequence_id)); + LOG_TRACE(log, packetToText(payload)); + + out->write(reinterpret_cast(&payload_length), 3); + out->write(reinterpret_cast(&sequence_id), 1); + out->write(payload.data() + pos, payload_length); + + pos += payload_length; + sequence_id++; + } + while (pos < payload.length()); + out->next(); + + LOG_TRACE(log, "Packet was sent."); +} + +void MySQLHandler::run() { + sequence_id = 0; + connection_context = server.context(); + + in = std::make_shared(socket()); + out = std::make_shared(socket()); + + try + { + Handshake handshake(connection_id, VERSION_FULL); + auto payload = handshake.getPayload(); + writePayload(payload); + + LOG_TRACE(log, "sent handshake"); + + HandshakeResponse handshake_response; + payload = readPayload(); + handshake_response.readPayload(payload); + + LOG_DEBUG(log, "capability_flags: " << handshake_response.capability_flags + << "max_packet_size: %s" + << handshake_response.max_packet_size + << "character_set: %s" + << handshake_response.character_set + << "user: %s" + << handshake_response.username + << "auth_response length: %s" + << handshake_response.auth_response.length() + << "auth_response: %s" + << handshake_response.auth_response + << "database: %s" + << handshake_response.database + << "auth_plugin_name: %s" + << handshake_response.auth_plugin_name); + + capabilities = handshake_response.capability_flags; + if (!(capabilities & CLIENT_PROTOCOL_41)) { + LOG_ERROR(log, "Clients without CLIENT_PROTOCOL_41 capability are not supported."); + return; + } + + try { + connection_context.setUser(handshake_response.username, "", socket().address(), ""); + connection_context.setCurrentDatabase(handshake_response.database); + connection_context.setCurrentQueryId(""); + } + catch (const Exception & exc) { + log->log(exc); + writePayload(ERR_Packet(exc.code(), "00000", exc.message()).getPayload()); + return; // TODO Authentication method change + } + OK_Packet ok_packet(0, handshake_response.capability_flags, 0, 0, 0, 0, ""); + payload = ok_packet.getPayload(); + writePayload(payload); + LOG_INFO(log, "sent OK_Packet"); + + while (true) { + sequence_id = 0; + payload = readPayload(); + int command = payload[0]; + LOG_DEBUG(log, "Received command: " << std::to_string(command) << ". Connection id: " << connection_id << "."); + try { + switch (command) { + case COM_QUIT: + return; + case COM_INIT_DB: + comInitDB(payload); + break; + case COM_QUERY: + comQuery(payload); + break; + case COM_FIELD_LIST: + comFieldList(payload); + break; + case COM_PING: + comPing(); + break; + default: + throw Exception(Poco::format("Command %d is not implemented.", command), ErrorCodes::NOT_IMPLEMENTED); + } + } + catch (const NetException & exc) { + log->log(exc); + throw; + } + catch (const Exception & exc) { + log->log(exc); + writePayload(ERR_Packet(exc.code(), "00000", exc.message()).getPayload()); + } + } + } + catch (Poco::Exception& exc) + { + log->log(exc); + } + +} + +void MySQLHandler::comInitDB(const String & payload) +{ + String database = payload.substr(1); + LOG_DEBUG(log, "Setting current database to " << database); + connection_context.setCurrentDatabase(database); + writePayload(OK_Packet(0, capabilities, 0, 0, 0, 1, "").getPayload()); +} + +void MySQLHandler::comFieldList(const String & payload) { + ComFieldList packet; + packet.readPayload(payload); + StoragePtr tablePtr = connection_context.getTable(connection_context.getCurrentDatabase(), packet.table); + for (const NameAndTypePair & column: tablePtr->getColumns().getAll()) + { + ColumnDefinition column_definition( + "schema", packet.table, packet.table, column.name, column.name, CharacterSet::UTF8, 100, ColumnType::MYSQL_TYPE_STRING, 0, 0 + ); + writePayload(column_definition.getPayload()); + } + writePayload(OK_Packet(0xfe, capabilities, 0, 0, 0, 0, "").getPayload()); +} + +void MySQLHandler::comPing() { + writePayload(OK_Packet(0x0, capabilities, 0, 0, 0, 0, "").getPayload()); +} + +void MySQLHandler::comQuery(const String & payload) { + BlockIO res = executeQuery(payload.substr(1), connection_context); + FormatSettings format_settings; + if (res.in) { + LOG_TRACE(log, "Executing query with output."); + + Block header = res.in->getHeader(); + writePayload(writeLenenc(header.columns())); + + for (const ColumnWithTypeAndName & column : header.getColumnsWithTypeAndName()) + { + writePayload(ColumnDefinition( + "", /// database. Apparently, addition of these fields to ColumnWithTypeAndName and changes in interpreters are needed. + "", /// table name. + "", /// physical table name + column.name, /// virtual column name + "", /// physical column name + CharacterSet::UTF8, + /// maximum column length which can be used for text outputting. Since query execution hasn't started, it is unknown. + std::numeric_limits::max(), + ColumnType::MYSQL_TYPE_STRING, /// TODO + 0, + 0 + ).getPayload()); + + LOG_TRACE(log, "sent " << column.name << " column definition"); + } + + LOG_TRACE(log, "Sent columns definitions."); + + while (Block block = res.in->read()) + { + size_t rows = block.rows(); + size_t columns = block.columns(); + + for (size_t i = 0; i < rows; i++) { + String row_payload; + for (size_t j = 0; j < columns; j++) { + ColumnWithTypeAndName & column = block.getByPosition(j); + column.column = column.column->convertToFullColumnIfConst(); + + String column_value; + WriteBufferFromString ostr(column_value); + + LOG_TRACE(log, "sending value of type " << column.type->getName() << " of column " << column.column->getName()); + + column.type->serializeAsText(*column.column.get(), i, ostr, format_settings); + ostr.finish(); + + writeLenencStr(row_payload, column_value); + } + writePayload(row_payload); + } + } + + LOG_TRACE(log, "Sent rows."); + } + + if (capabilities & CLIENT_DEPRECATE_EOF) { + writePayload(OK_Packet(0xfe, capabilities, 0, 0, 0, 0, "").getPayload()); + } else { + writePayload(EOF_Packet(0, 0).getPayload()); + } +} + +} diff --git a/dbms/programs/server/MySQLHandler.h b/dbms/programs/server/MySQLHandler.h new file mode 100644 index 00000000000..85b6ed78e81 --- /dev/null +++ b/dbms/programs/server/MySQLHandler.h @@ -0,0 +1,58 @@ +#pragma once + +#include +#include +#include "IServer.h" + + +namespace DB +{ + +/// Handler for MySQL wire protocol connections. Allows to connect to ClickHouse using MySQL client. +class MySQLHandler : public Poco::Net::TCPServerConnection { +public: + MySQLHandler(IServer &server_, const Poco::Net::StreamSocket &socket_) + : Poco::Net::TCPServerConnection(socket_) + , server(server_) + , log(&Poco::Logger::get("MySQLHandler")) + , connection_context(server.context()) + , connection_id(last_connection_id++) + { + } + + void run() final; + + /** Reads one packet, incrementing sequence-id, and returns its payload. + * Currently, whole payload is loaded into memory. + */ + String readPayload(); + + /// Writes packet payload, incrementing sequence-id. + void writePayload(std::string_view payload); + + void comQuery(const String & payload); + + void comFieldList(const String & payload); + + void comPing(); + + void comInitDB(const String & payload); +private: + IServer & server; + Poco::Logger * log; + Context connection_context; + + std::shared_ptr in; + std::shared_ptr out; + + /// Packet sequence id + unsigned char sequence_id = 0; + + uint32_t connection_id = 0; + + uint32_t capabilities; + + static uint32_t last_connection_id; +}; + +} diff --git a/dbms/programs/server/MySQLHandlerFactory.h b/dbms/programs/server/MySQLHandlerFactory.h new file mode 100644 index 00000000000..5f081915778 --- /dev/null +++ b/dbms/programs/server/MySQLHandlerFactory.h @@ -0,0 +1,33 @@ +#pragma once + +#include +#include +#include "IServer.h" +#include "MySQLHandler.h" + +namespace Poco { class Logger; } + +namespace DB +{ + + class MySQLHandlerFactory : public Poco::Net::TCPServerConnectionFactory + { + private: + IServer & server; + Poco::Logger * log; + + public: + explicit MySQLHandlerFactory(IServer & server_) + : server(server_) + , log(&Logger::get("MySQLHandlerFactory")) + { + } + + Poco::Net::TCPServerConnection * createConnection(const Poco::Net::StreamSocket & socket) override + { + LOG_TRACE(log, "MySQL connection. Address: " << socket.peerAddress().toString()); + return new MySQLHandler(server, socket); + } + }; + +} diff --git a/dbms/programs/server/Server.cpp b/dbms/programs/server/Server.cpp index 2b10c9e3c98..5c7959f3092 100644 --- a/dbms/programs/server/Server.cpp +++ b/dbms/programs/server/Server.cpp @@ -49,6 +49,7 @@ #include #include "TCPHandlerFactory.h" #include "Common/config_version.h" +#include "MySQLHandlerFactory.h" #if defined(__linux__) #include @@ -725,6 +726,21 @@ int Server::main(const std::vector & /*args*/) ErrorCodes::SUPPORT_IS_DISABLED}; #endif } + + if (config().has("mysql_port")) + { + Poco::Net::ServerSocket socket; + auto address = socket_bind_listen(socket, listen_host, config().getInt("mysql_port"), /* secure = */ true); + socket.setReceiveTimeout(Poco::Timespan()); + socket.setSendTimeout(settings.send_timeout); + servers.emplace_back(std::make_unique( + new MySQLHandlerFactory(*this), + server_pool, + socket, + new Poco::Net::TCPServerParams)); + + LOG_INFO(log, "Listening mysql: " + address.toString()); + } } catch (const Poco::Net::NetException & e) { diff --git a/dbms/src/Core/MySQLProtocol.cpp b/dbms/src/Core/MySQLProtocol.cpp new file mode 100644 index 00000000000..baa6784fd64 --- /dev/null +++ b/dbms/src/Core/MySQLProtocol.cpp @@ -0,0 +1,50 @@ +#include +#include +#include + +/// Implementation of MySQL wire protocol + +namespace DB { +namespace MySQLProtocol { + +uint64_t readLenenc(std::istringstream &ss) { + char c; + uint64_t buf = 0; + ss.get(c); + auto cc = static_cast(c); + if (cc < 0xfc) { + return cc; + } else if (cc < 0xfd) { + ss.read(reinterpret_cast(&buf), 2); + } else if (cc < 0xfe) { + ss.read(reinterpret_cast(&buf), 3); + } else { + ss.read(reinterpret_cast(&buf), 8); + } + return buf; +} + +std::string writeLenenc(uint64_t x) { + std::string result; + if (x < 251) { + result.append(1, static_cast(x)); + } else if (x < (1 << 16)) { + result.append(1, 0xfc); + result.append(reinterpret_cast(&x), 2); + } else if (x < (1 << 24)) { + result.append(1, 0xfd); + result.append(reinterpret_cast(&x), 3); + } else { + result.append(1, 0xfe); + result.append(reinterpret_cast(&x), 8); + } + return result; +} + +void writeLenencStr(std::string &payload, const std::string &s) { + payload.append(writeLenenc(s.length())); + payload.append(s); +} + +} +} diff --git a/dbms/src/Core/MySQLProtocol.h b/dbms/src/Core/MySQLProtocol.h new file mode 100644 index 00000000000..9157a32e96d --- /dev/null +++ b/dbms/src/Core/MySQLProtocol.h @@ -0,0 +1,366 @@ +#pragma once + +#include +#include +#include + +/// Implementation of MySQL wire protocol + +namespace DB { +namespace MySQLProtocol { + +const size_t MAX_PACKET_LENGTH = (1 << 24) - 1; // 16 mb +const size_t SCRAMBLE_LENGTH = 20; +const size_t AUTH_PLUGIN_DATA_PART_1_LENGTH = 8; +const size_t MYSQL_ERRMSG_SIZE = 512; + +namespace Authentication { + const std::string Native41 = "mysql_native_password"; +} + +enum CharacterSet { + UTF8 = 33 +}; + +enum StatusFlags { + SERVER_SESSION_STATE_CHANGED = 0x4000 +}; + +enum Capability { + CLIENT_CONNECT_WITH_DB = 0x00000008, + CLIENT_PROTOCOL_41 = 0x00000200, + CLIENT_TRANSACTIONS = 0x00002000, // TODO + CLIENT_SESSION_TRACK = 0x00800000, // TODO + CLIENT_SECURE_CONNECTION = 0x00008000, + CLIENT_PLUGIN_AUTH_LENENC_CLIENT_DATA = 0x00200000, + CLIENT_PLUGIN_AUTH = 0x00080000, + CLIENT_DEPRECATE_EOF = 0x01000000, +}; + +enum Command { + COM_SLEEP = 0x0, + COM_QUIT = 0x1, + COM_INIT_DB = 0x2, + COM_QUERY = 0x3, + COM_FIELD_LIST = 0x4, + COM_CREATE_DB = 0x5, + COM_DROP_DB = 0x6, + COM_REFRESH = 0x7, + COM_SHUTDOWN = 0x8, + COM_STATISTICS = 0x9, + COM_PROCESS_INFO = 0xa, + COM_CONNECT = 0xb, + COM_PROCESS_KILL = 0xc, + COM_DEBUG = 0xd, + COM_PING = 0xe, + COM_TIME = 0xf, + COM_DELAYED_INSERT = 0x10, + COM_CHANGE_USER = 0x11, + COM_RESET_CONNECTION = 0x1f, + COM_DAEMON = 0x1d +}; + +enum ColumnType { + MYSQL_TYPE_DECIMAL = 0x00, + MYSQL_TYPE_TINY = 0x01, + MYSQL_TYPE_SHORT = 0x02, + MYSQL_TYPE_LONG = 0x03, + MYSQL_TYPE_FLOAT = 0x04, + MYSQL_TYPE_DOUBLE = 0x05, + MYSQL_TYPE_NULL = 0x06, + MYSQL_TYPE_TIMESTAMP = 0x07, + MYSQL_TYPE_LONGLONG = 0x08, + MYSQL_TYPE_INT24 = 0x09, + MYSQL_TYPE_DATE = 0x0a, + MYSQL_TYPE_TIME = 0x0b, + MYSQL_TYPE_DATETIME = 0x0c, + MYSQL_TYPE_YEAR = 0x0d, + MYSQL_TYPE_VARCHAR = 0x0f, + MYSQL_TYPE_BIT = 0x10, + MYSQL_TYPE_NEWDECIMAL = 0xf6, + MYSQL_TYPE_ENUM = 0xf7, + MYSQL_TYPE_SET = 0xf8, + MYSQL_TYPE_TINY_BLOB = 0xf9, + MYSQL_TYPE_MEDIUM_BLOB = 0xfa, + MYSQL_TYPE_LONG_BLOB = 0xfb, + MYSQL_TYPE_BLOB = 0xfc, + MYSQL_TYPE_VAR_STRING = 0xfd, + MYSQL_TYPE_STRING = 0xfe, + MYSQL_TYPE_GEOMETRY = 0xff +}; + +uint64_t readLenenc(std::istringstream &ss); + +std::string writeLenenc(uint64_t x); + +void writeLenencStr(std::string &payload, const std::string &s); + + +class ProtocolError : public DB::Exception { +public: + using Exception::Exception; +}; + + +/// https://dev.mysql.com/doc/internals/en/connection-phase-packets.html + + +class Handshake { + int protocol_version = 0xa; + std::string server_version; + uint32_t connection_id; + uint32_t capability_flags; + uint8_t character_set; + uint32_t status_flags; + std::string auth_plugin_data; +public: + explicit Handshake(uint32_t connection_id, std::string server_version) + : protocol_version(0xa) + , server_version(std::move(server_version)) + , connection_id(connection_id) + , capability_flags( + CLIENT_PROTOCOL_41 + | CLIENT_SECURE_CONNECTION + | CLIENT_PLUGIN_AUTH + | CLIENT_PLUGIN_AUTH_LENENC_CLIENT_DATA + | CLIENT_CONNECT_WITH_DB + | CLIENT_DEPRECATE_EOF) + , character_set(63) + , status_flags(0) { + auth_plugin_data.resize(SCRAMBLE_LENGTH); + + auto seed = std::chrono::system_clock::now().time_since_epoch().count(); + std::default_random_engine generator (static_cast(seed)); + + std::uniform_int_distribution distribution(0); + for (size_t i = 0; i < SCRAMBLE_LENGTH; i++) { + auth_plugin_data[i] = distribution(generator); + } + } + + std::string getPayload() { + std::string result; + result.append(1, protocol_version); + result.append(server_version); + result.append(1, 0x0); + result.append(reinterpret_cast(&connection_id), 4); + result.append(auth_plugin_data.substr(0, AUTH_PLUGIN_DATA_PART_1_LENGTH)); + result.append(1, 0x0); + result.append(reinterpret_cast(&capability_flags), 2); + result.append(reinterpret_cast(&character_set), 1); + result.append(reinterpret_cast(&status_flags), 2); + result.append((reinterpret_cast(&capability_flags)) + 2, 2); + result.append(1, SCRAMBLE_LENGTH + 1); + result.append(1, 0x0); + result.append(10, 0x0); + result.append(auth_plugin_data.substr(AUTH_PLUGIN_DATA_PART_1_LENGTH, SCRAMBLE_LENGTH - AUTH_PLUGIN_DATA_PART_1_LENGTH)); + result.append(Authentication::Native41); + result.append(1, 0x0); + return result; + } +}; + +class HandshakeResponse { +public: + uint32_t capability_flags; + uint32_t max_packet_size; + uint8_t character_set; + std::string username; + std::string auth_response; + std::string database; + std::string auth_plugin_name; + + void readPayload(const std::string & s) { + std::istringstream ss(s); + + ss.readsome(reinterpret_cast(&capability_flags), 4); + ss.readsome(reinterpret_cast(&max_packet_size), 4); + ss.readsome(reinterpret_cast(&character_set), 1); + ss.ignore(23); + + std::getline(ss, username, static_cast(0x0)); + + if (capability_flags & CLIENT_PLUGIN_AUTH_LENENC_CLIENT_DATA) { + auto len = readLenenc(ss); + auth_response.resize(len); + ss.read(auth_response.data(), static_cast(len)); + } else if (capability_flags & CLIENT_SECURE_CONNECTION) { + uint8_t len; + ss.read(reinterpret_cast(&len), 1); + auth_response.resize(len); + ss.read(auth_response.data(), len); + } else { + std::getline(ss, auth_response, static_cast(0x0)); + } + + if (capability_flags & CLIENT_CONNECT_WITH_DB) { + std::getline(ss, database, static_cast(0x0)); + } + + if (capability_flags & CLIENT_PLUGIN_AUTH) { + std::getline(ss, auth_plugin_name, static_cast(0x0)); + } + } +}; + +class OK_Packet { + uint8_t header; + uint32_t capabilities; + uint64_t affected_rows; + uint64_t last_insert_id; + int16_t warnings = 0; + uint32_t status_flags; + std::string info; + std::string session_state_changes; +public: + OK_Packet(uint8_t header, uint32_t capabilities, uint64_t affected_rows, uint64_t last_insert_id, uint32_t status_flags, + int16_t warnings, std::string session_state_changes) + : header(header) + , capabilities(capabilities) + , affected_rows(affected_rows) + , last_insert_id(last_insert_id) + , warnings(warnings) + , status_flags(status_flags) + , session_state_changes(std::move(session_state_changes)) + { + } + + std::string getPayload() { + std::string result; + result.append(1, header); + result.append(writeLenenc(affected_rows)); + result.append(writeLenenc(last_insert_id)); + + if (capabilities & CLIENT_PROTOCOL_41) { + result.append(reinterpret_cast(&status_flags), 2); + result.append(reinterpret_cast(&warnings), 2); + } else if (capabilities & CLIENT_TRANSACTIONS) { + result.append(reinterpret_cast(&status_flags), 2); + } + + if (capabilities & CLIENT_SESSION_TRACK) { + result.append(writeLenenc(info.length())); + result.append(info); + if (status_flags & SERVER_SESSION_STATE_CHANGED) { + result.append(writeLenenc(session_state_changes.length())); + result.append(session_state_changes); + } + } else { + result.append(info); + } + return result; + } +}; + +class EOF_Packet { + int warnings; + int status_flags; +public: + EOF_Packet(int warnings, int status_flags): warnings(warnings), status_flags(status_flags) {} + + std::string getPayload() { + std::string result; + result.append(1, 0xfe); // EOF header + result.append(reinterpret_cast(&warnings), 2); + result.append(reinterpret_cast(&status_flags), 2); + return result; + } +}; + +class ERR_Packet { + int error_code; + std::string sql_state; + std::string error_message; +public: + ERR_Packet(int error_code, std::string sql_state, std::string error_message) + : error_code(error_code) + , sql_state(std::move(sql_state)) + , error_message(std::move(error_message)) + { + } + + std::string getPayload() + { + std::string result; + result.append(1, 0xff); + result.append(reinterpret_cast(&error_code), 2); + result.append("#", 1); + result.append(sql_state.data(), sql_state.length()); + result.append(error_message.data(), std::min(error_message.length(), MYSQL_ERRMSG_SIZE)); + return result; + } +}; + +class ColumnDefinition { + std::string schema; + std::string table; + std::string org_table; + std::string name; + std::string org_name; + size_t next_length = 0x0c; + uint16_t character_set; + uint32_t column_length; + ColumnType column_type; + uint16_t flags; + uint8_t decimals = 0x00; +public: + explicit ColumnDefinition( + std::string schema, + std::string table, + std::string org_table, + std::string name, + std::string org_name, + uint16_t character_set, + uint32_t column_length, + ColumnType column_type, + uint16_t flags, + uint8_t decimals) + + : schema(std::move(schema)) + , table(std::move(table)) + , org_table(std::move(org_table)) + , name(std::move(name)) + , org_name(std::move(org_name)) + , character_set(character_set) + , column_length(column_length) + , column_type(column_type) + , flags(flags) + , decimals(decimals) + { + } + + std::string getPayload() { + std::string result; + writeLenencStr(result, "def"); // always "def" + writeLenencStr(result, schema); + writeLenencStr(result, table); + writeLenencStr(result, org_table); + writeLenencStr(result, name); + writeLenencStr(result, org_name); + result.append(writeLenenc(next_length)); + result.append(reinterpret_cast(&character_set), 2); + result.append(reinterpret_cast(&column_length), 4); + result.append(reinterpret_cast(&column_type), 1); + result.append(reinterpret_cast(&flags), 2); + result.append(reinterpret_cast(&decimals), 2); + result.append(2, 0x0); + return result; + } +}; + +class ComFieldList { +public: + std::string table, field_wildcard; + + void readPayload(const std::string & payload) + { + std::istringstream ss(payload); + ss.ignore(1); // command byte + std::getline(ss, table, static_cast(0x0)); + field_wildcard = payload.substr(table.length() + 2); // rest of the packet + } +}; + + +} +} From 107f33e888b6cca2a725d14c8b633b9f7fe5d2be Mon Sep 17 00:00:00 2001 From: Yuriy Date: Tue, 26 Mar 2019 21:30:41 +0300 Subject: [PATCH 032/709] added password check and changed packets serialization --- dbms/programs/server/MySQLHandler.cpp | 259 ++++++-------- dbms/programs/server/MySQLHandler.h | 18 +- dbms/src/Common/ErrorCodes.cpp | 1 + dbms/src/Core/MySQLProtocol.cpp | 74 +++- dbms/src/Core/MySQLProtocol.h | 484 +++++++++++++++++++------- 5 files changed, 529 insertions(+), 307 deletions(-) diff --git a/dbms/programs/server/MySQLHandler.cpp b/dbms/programs/server/MySQLHandler.cpp index ad250c8ce7e..9a4d8cf4a35 100644 --- a/dbms/programs/server/MySQLHandler.cpp +++ b/dbms/programs/server/MySQLHandler.cpp @@ -1,9 +1,6 @@ #include #include -#include #include -#include -#include #include #include #include @@ -19,137 +16,90 @@ namespace DB { using namespace MySQLProtocol; +namespace ErrorCodes +{ + extern const int MYSQL_CLIENT_INSUFFICIENT_CAPABILITIES; +} + uint32_t MySQLHandler::last_connection_id = 0; -String MySQLHandler::readPayload() + +void MySQLHandler::run() { - WriteBufferFromOwnString buf; - - size_t payload_length = 0; - uint8_t packet_sequence_id; - - // packets which are larger than or equal to 16MB are splitted - do { - LOG_TRACE(log, "Reading from buffer"); - - in->readStrict(reinterpret_cast(&payload_length), 3); - - if (payload_length > MAX_PACKET_LENGTH) { - throw ProtocolError(Poco::format("Received packet with payload length greater than 2^24 - 1: %z.", payload_length), 0); - } - - in->readStrict(reinterpret_cast(&packet_sequence_id), 1); - - if (packet_sequence_id != sequence_id) { - throw ProtocolError(Poco::format("Received packet with wrong sequence-id: %d. Expected: %d.", packet_sequence_id, sequence_id), 0); - } - sequence_id++; - - LOG_TRACE(log, "Received packet. Sequence-id: " << static_cast(packet_sequence_id) << ", payload length: " << payload_length); - - copyData(*in, static_cast(buf), payload_length); - } - while (payload_length == MAX_PACKET_LENGTH); - - return buf.str(); -} - -/// Converts packet to text. Useful for debugging, since packets often consist of non-printing characters. -static String packetToText(std::string_view payload) { - String result; - for (auto c : payload) { - result += ' '; - result += std::to_string(static_cast(c)); - } - return result; -} - -void MySQLHandler::writePayload(std::string_view payload) -{ - size_t pos = 0; - do - { - size_t payload_length = std::min(payload.length() - pos, MAX_PACKET_LENGTH); - - LOG_TRACE(log, "Writing packet of size " << payload_length << " with sequence-id " << static_cast(sequence_id)); - LOG_TRACE(log, packetToText(payload)); - - out->write(reinterpret_cast(&payload_length), 3); - out->write(reinterpret_cast(&sequence_id), 1); - out->write(payload.data() + pos, payload_length); - - pos += payload_length; - sequence_id++; - } - while (pos < payload.length()); - out->next(); - - LOG_TRACE(log, "Packet was sent."); -} - -void MySQLHandler::run() { - sequence_id = 0; connection_context = server.context(); - in = std::make_shared(socket()); - out = std::make_shared(socket()); + { + auto in = std::make_shared(socket()); + auto out = std::make_shared(socket()); + packet_sender = PacketSender(in, out); + } try { Handshake handshake(connection_id, VERSION_FULL); - auto payload = handshake.getPayload(); - writePayload(payload); + packet_sender.sendPacket(handshake, true); - LOG_TRACE(log, "sent handshake"); + LOG_TRACE(log, "Sent handshake"); - HandshakeResponse handshake_response; - payload = readPayload(); - handshake_response.readPayload(payload); + auto handshake_response = packet_sender.receivePacket(); - LOG_DEBUG(log, "capability_flags: " << handshake_response.capability_flags - << "max_packet_size: %s" - << handshake_response.max_packet_size - << "character_set: %s" - << handshake_response.character_set - << "user: %s" - << handshake_response.username - << "auth_response length: %s" - << handshake_response.auth_response.length() - << "auth_response: %s" - << handshake_response.auth_response - << "database: %s" - << handshake_response.database - << "auth_plugin_name: %s" - << handshake_response.auth_plugin_name); + LOG_DEBUG(log, "Capabilities: " << handshake_response.capability_flags + << "\nmax_packet_size: " + << handshake_response.max_packet_size + << "\ncharacter_set: " + << handshake_response.character_set + << "\nuser: " + << handshake_response.username + << "\nauth_response length: " + << handshake_response.auth_response.length() + << "\nauth_response: " + << handshake_response.auth_response + << "\ndatabase: " + << handshake_response.database + << "\nauth_plugin_name: " + << handshake_response.auth_plugin_name); capabilities = handshake_response.capability_flags; - if (!(capabilities & CLIENT_PROTOCOL_41)) { - LOG_ERROR(log, "Clients without CLIENT_PROTOCOL_41 capability are not supported."); - return; + if (!(capabilities & CLIENT_PROTOCOL_41)) + { + throw Exception("Required capability: CLIENT_PROTOCOL_41.", ErrorCodes::MYSQL_CLIENT_INSUFFICIENT_CAPABILITIES); + } + if (!(capabilities & CLIENT_PLUGIN_AUTH)) + { + throw Exception("Required capability: CLIENT_PLUGIN_AUTH.", ErrorCodes::MYSQL_CLIENT_INSUFFICIENT_CAPABILITIES); } - try { - connection_context.setUser(handshake_response.username, "", socket().address(), ""); - connection_context.setCurrentDatabase(handshake_response.database); - connection_context.setCurrentQueryId(""); + String password; + if (handshake_response.auth_plugin_name != Authentication::ClearText) + { + + packet_sender.sendPacket(AuthSwitchRequest(Authentication::ClearText, ""), true); + password = packet_sender.receivePacket().value; } - catch (const Exception & exc) { - log->log(exc); - writePayload(ERR_Packet(exc.code(), "00000", exc.message()).getPayload()); - return; // TODO Authentication method change + else + { + NullTerminatedString packet; + packet.readPayload(std::move(handshake_response.auth_response)); + password = packet.value; } + connection_context.setUser(handshake_response.username, password, socket().address(), ""); + connection_context.setCurrentDatabase(handshake_response.database); + connection_context.setCurrentQueryId(""); + LOG_ERROR(log, "Authentication for user " << handshake_response.username << " succeeded."); + OK_Packet ok_packet(0, handshake_response.capability_flags, 0, 0, 0, 0, ""); - payload = ok_packet.getPayload(); - writePayload(payload); - LOG_INFO(log, "sent OK_Packet"); + packet_sender.sendPacket(ok_packet, true); - while (true) { - sequence_id = 0; - payload = readPayload(); + while (true) + { + packet_sender.resetSequenceId(); + String payload = packet_sender.receivePacketPayload(); int command = payload[0]; LOG_DEBUG(log, "Received command: " << std::to_string(command) << ". Connection id: " << connection_id << "."); - try { - switch (command) { + try + { + switch (command) + { case COM_QUIT: return; case COM_INIT_DB: @@ -168,75 +118,71 @@ void MySQLHandler::run() { throw Exception(Poco::format("Command %d is not implemented.", command), ErrorCodes::NOT_IMPLEMENTED); } } - catch (const NetException & exc) { + catch (const NetException & exc) + { log->log(exc); throw; } - catch (const Exception & exc) { + catch (const Exception & exc) + { log->log(exc); - writePayload(ERR_Packet(exc.code(), "00000", exc.message()).getPayload()); + packet_sender.sendPacket(ERR_Packet(exc.code(), "00000", exc.message()), true); } } } - catch (Poco::Exception& exc) + catch (Poco::Exception & exc) { log->log(exc); } - } -void MySQLHandler::comInitDB(const String & payload) +void MySQLHandler::comInitDB(String payload) { String database = payload.substr(1); LOG_DEBUG(log, "Setting current database to " << database); connection_context.setCurrentDatabase(database); - writePayload(OK_Packet(0, capabilities, 0, 0, 0, 1, "").getPayload()); + packet_sender.sendPacket(OK_Packet(0, capabilities, 0, 0, 0, 1, ""), true); } -void MySQLHandler::comFieldList(const String & payload) { +void MySQLHandler::comFieldList(String payload) +{ ComFieldList packet; packet.readPayload(payload); - StoragePtr tablePtr = connection_context.getTable(connection_context.getCurrentDatabase(), packet.table); + String database = connection_context.getCurrentDatabase(); + StoragePtr tablePtr = connection_context.getTable(database, packet.table); for (const NameAndTypePair & column: tablePtr->getColumns().getAll()) { ColumnDefinition column_definition( - "schema", packet.table, packet.table, column.name, column.name, CharacterSet::UTF8, 100, ColumnType::MYSQL_TYPE_STRING, 0, 0 + database, packet.table, packet.table, column.name, column.name, CharacterSet::binary, 100, ColumnType::MYSQL_TYPE_STRING, 0, 0 ); - writePayload(column_definition.getPayload()); + packet_sender.sendPacket(column_definition); } - writePayload(OK_Packet(0xfe, capabilities, 0, 0, 0, 0, "").getPayload()); + packet_sender.sendPacket(OK_Packet(0xfe, capabilities, 0, 0, 0, 0, ""), true); } -void MySQLHandler::comPing() { - writePayload(OK_Packet(0x0, capabilities, 0, 0, 0, 0, "").getPayload()); +void MySQLHandler::comPing() +{ + packet_sender.sendPacket(OK_Packet(0x0, capabilities, 0, 0, 0, 0, ""), true); } -void MySQLHandler::comQuery(const String & payload) { +void MySQLHandler::comQuery(String payload) +{ BlockIO res = executeQuery(payload.substr(1), connection_context); FormatSettings format_settings; - if (res.in) { + if (res.in) + { LOG_TRACE(log, "Executing query with output."); Block header = res.in->getHeader(); - writePayload(writeLenenc(header.columns())); + packet_sender.sendPacket(LengthEncodedNumber(header.columns())); for (const ColumnWithTypeAndName & column : header.getColumnsWithTypeAndName()) { - writePayload(ColumnDefinition( - "", /// database. Apparently, addition of these fields to ColumnWithTypeAndName and changes in interpreters are needed. - "", /// table name. - "", /// physical table name - column.name, /// virtual column name - "", /// physical column name - CharacterSet::UTF8, - /// maximum column length which can be used for text outputting. Since query execution hasn't started, it is unknown. - std::numeric_limits::max(), - ColumnType::MYSQL_TYPE_STRING, /// TODO - 0, - 0 - ).getPayload()); + ColumnDefinition column_definition(column.name, CharacterSet::binary, std::numeric_limits::max(), + ColumnType::MYSQL_TYPE_STRING, 0, 0); + packet_sender.sendPacket(column_definition); - LOG_TRACE(log, "sent " << column.name << " column definition"); + LOG_TRACE(log, "Sent " << column.name << " column definition"); } LOG_TRACE(log, "Sent columns definitions."); @@ -244,35 +190,38 @@ void MySQLHandler::comQuery(const String & payload) { while (Block block = res.in->read()) { size_t rows = block.rows(); - size_t columns = block.columns(); - for (size_t i = 0; i < rows; i++) { - String row_payload; - for (size_t j = 0; j < columns; j++) { - ColumnWithTypeAndName & column = block.getByPosition(j); + for (size_t i = 0; i < rows; i++) + { + ResultsetRow row_packet; + for (ColumnWithTypeAndName & column : block) + { column.column = column.column->convertToFullColumnIfConst(); String column_value; WriteBufferFromString ostr(column_value); - LOG_TRACE(log, "sending value of type " << column.type->getName() << " of column " << column.column->getName()); + LOG_TRACE(log, "Sending value of type " << column.type->getName() << " of column " << column.column->getName()); column.type->serializeAsText(*column.column.get(), i, ostr, format_settings); ostr.finish(); - writeLenencStr(row_payload, column_value); + row_packet.appendColumn(std::move(column_value)); } - writePayload(row_payload); + packet_sender.sendPacket(row_packet); } } LOG_TRACE(log, "Sent rows."); } - if (capabilities & CLIENT_DEPRECATE_EOF) { - writePayload(OK_Packet(0xfe, capabilities, 0, 0, 0, 0, "").getPayload()); - } else { - writePayload(EOF_Packet(0, 0).getPayload()); + if (capabilities & CLIENT_DEPRECATE_EOF) + { + packet_sender.sendPacket(OK_Packet(0xfe, capabilities, 0, 0, 0, 0, ""), true); + } + else + { + packet_sender.sendPacket(EOF_Packet(0, 0), true); } } diff --git a/dbms/programs/server/MySQLHandler.h b/dbms/programs/server/MySQLHandler.h index 85b6ed78e81..6ca2419ad1f 100644 --- a/dbms/programs/server/MySQLHandler.h +++ b/dbms/programs/server/MySQLHandler.h @@ -2,6 +2,7 @@ #include #include +#include #include "IServer.h" @@ -22,21 +23,13 @@ public: void run() final; - /** Reads one packet, incrementing sequence-id, and returns its payload. - * Currently, whole payload is loaded into memory. - */ - String readPayload(); + void comQuery(String payload); - /// Writes packet payload, incrementing sequence-id. - void writePayload(std::string_view payload); - - void comQuery(const String & payload); - - void comFieldList(const String & payload); + void comFieldList(String payload); void comPing(); - void comInitDB(const String & payload); + void comInitDB(String payload); private: IServer & server; Poco::Logger * log; @@ -45,8 +38,7 @@ private: std::shared_ptr in; std::shared_ptr out; - /// Packet sequence id - unsigned char sequence_id = 0; + MySQLProtocol::PacketSender packet_sender; uint32_t connection_id = 0; diff --git a/dbms/src/Common/ErrorCodes.cpp b/dbms/src/Common/ErrorCodes.cpp index f974b2bdaf6..e6c6ee8a4a7 100644 --- a/dbms/src/Common/ErrorCodes.cpp +++ b/dbms/src/Common/ErrorCodes.cpp @@ -420,6 +420,7 @@ namespace ErrorCodes extern const int NO_COMMON_COLUMNS_WITH_PROTOBUF_SCHEMA = 443; extern const int UNKNOWN_PROTOBUF_FORMAT = 444; extern const int CANNOT_MPROTECT = 445; + extern const int MYSQL_CLIENT_INSUFFICIENT_CAPABILITIES = 446; extern const int KEEPER_EXCEPTION = 999; extern const int POCO_EXCEPTION = 1000; diff --git a/dbms/src/Core/MySQLProtocol.cpp b/dbms/src/Core/MySQLProtocol.cpp index baa6784fd64..f727ae3df54 100644 --- a/dbms/src/Core/MySQLProtocol.cpp +++ b/dbms/src/Core/MySQLProtocol.cpp @@ -1,50 +1,94 @@ #include +#include +#include +#include #include #include +#include "MySQLProtocol.h" -/// Implementation of MySQL wire protocol -namespace DB { -namespace MySQLProtocol { +namespace DB +{ +namespace MySQLProtocol +{ -uint64_t readLenenc(std::istringstream &ss) { +void PacketSender::resetSequenceId() +{ + sequence_id = 0; +} + +String PacketSender::packetToText(String payload) +{ + String result; + for (auto c : payload) + { + result += ' '; + result += std::to_string(static_cast(c)); + } + return result; +} + +uint64_t readLengthEncodedNumber(std::istringstream & ss) +{ char c; uint64_t buf = 0; ss.get(c); auto cc = static_cast(c); - if (cc < 0xfc) { + if (cc < 0xfc) + { return cc; - } else if (cc < 0xfd) { + } + else if (cc < 0xfd) + { ss.read(reinterpret_cast(&buf), 2); - } else if (cc < 0xfe) { + } + else if (cc < 0xfe) + { ss.read(reinterpret_cast(&buf), 3); - } else { + } + else + { ss.read(reinterpret_cast(&buf), 8); } return buf; } -std::string writeLenenc(uint64_t x) { +std::string writeLengthEncodedNumber(uint64_t x) +{ std::string result; - if (x < 251) { + if (x < 251) + { result.append(1, static_cast(x)); - } else if (x < (1 << 16)) { + } + else if (x < (1 << 16)) + { result.append(1, 0xfc); result.append(reinterpret_cast(&x), 2); - } else if (x < (1 << 24)) { + } + else if (x < (1 << 24)) + { result.append(1, 0xfd); result.append(reinterpret_cast(&x), 3); - } else { + } + else + { result.append(1, 0xfe); result.append(reinterpret_cast(&x), 8); } return result; } -void writeLenencStr(std::string &payload, const std::string &s) { - payload.append(writeLenenc(s.length())); +void writeLengthEncodedString(std::string & payload, const std::string & s) +{ + payload.append(writeLengthEncodedNumber(s.length())); payload.append(s); } +void writeNulTerminatedString(std::string & payload, const std::string & s) +{ + payload.append(s); + payload.append(1, 0); +} + } } diff --git a/dbms/src/Core/MySQLProtocol.h b/dbms/src/Core/MySQLProtocol.h index 9157a32e96d..bbead941e6b 100644 --- a/dbms/src/Core/MySQLProtocol.h +++ b/dbms/src/Core/MySQLProtocol.h @@ -1,32 +1,48 @@ #pragma once +#include #include +#include +#include #include #include /// Implementation of MySQL wire protocol -namespace DB { -namespace MySQLProtocol { +namespace DB +{ + +namespace ErrorCodes +{ + extern const int UNKNOWN_PACKET_FROM_CLIENT; +} + +namespace MySQLProtocol +{ const size_t MAX_PACKET_LENGTH = (1 << 24) - 1; // 16 mb const size_t SCRAMBLE_LENGTH = 20; const size_t AUTH_PLUGIN_DATA_PART_1_LENGTH = 8; const size_t MYSQL_ERRMSG_SIZE = 512; -namespace Authentication { - const std::string Native41 = "mysql_native_password"; +namespace Authentication +{ + const String ClearText = "mysql_clear_password"; } -enum CharacterSet { - UTF8 = 33 +enum CharacterSet +{ + utf8_general_ci = 33, + binary = 63 }; -enum StatusFlags { +enum StatusFlags +{ SERVER_SESSION_STATE_CHANGED = 0x4000 }; -enum Capability { +enum Capability +{ CLIENT_CONNECT_WITH_DB = 0x00000008, CLIENT_PROTOCOL_41 = 0x00000200, CLIENT_TRANSACTIONS = 0x00002000, // TODO @@ -37,7 +53,8 @@ enum Capability { CLIENT_DEPRECATE_EOF = 0x01000000, }; -enum Command { +enum Command +{ COM_SLEEP = 0x0, COM_QUIT = 0x1, COM_INIT_DB = 0x2, @@ -60,7 +77,8 @@ enum Command { COM_DAEMON = 0x1d }; -enum ColumnType { +enum ColumnType +{ MYSQL_TYPE_DECIMAL = 0x00, MYSQL_TYPE_TINY = 0x01, MYSQL_TYPE_SHORT = 0x02, @@ -89,63 +107,184 @@ enum ColumnType { MYSQL_TYPE_GEOMETRY = 0xff }; -uint64_t readLenenc(std::istringstream &ss); -std::string writeLenenc(uint64_t x); - -void writeLenencStr(std::string &payload, const std::string &s); - - -class ProtocolError : public DB::Exception { +class ProtocolError : public DB::Exception +{ public: using Exception::Exception; }; -/// https://dev.mysql.com/doc/internals/en/connection-phase-packets.html +class WritePacket +{ +public: + virtual String getPayload() const = 0; + + virtual ~WritePacket() = default; +}; -class Handshake { +class ReadPacket +{ +public: + virtual void readPayload(String payload) = 0; + + virtual ~ReadPacket() = default; +}; + + +/* Writes and reads packets, keeping sequence-id. + * Throws ProtocolError, if packet with incorrect sequence-id was received. + */ +class PacketSender +{ +public: + PacketSender() + {} + + PacketSender(std::shared_ptr in, std::shared_ptr out) + : in(std::move(in)), out(std::move(out)), sequence_id(0), log(&Poco::Logger::get("MySQLHandler")) + { + } + + String receivePacketPayload() + { + WriteBufferFromOwnString buf; + + size_t payload_length = 0; + size_t packet_sequence_id = 0; + + // packets which are larger than or equal to 16MB are splitted + do + { + LOG_TRACE(log, "Reading from buffer"); + + in->readStrict(reinterpret_cast(&payload_length), 3); + + if (payload_length > MAX_PACKET_LENGTH) + { + std::ostringstream tmp; + tmp << "Received packet with payload larger than MAX_PACKET_LENGTH: " << payload_length; + throw ProtocolError(tmp.str(), ErrorCodes::UNKNOWN_PACKET_FROM_CLIENT); + } + + in->readStrict(reinterpret_cast(&packet_sequence_id), 1); + + if (packet_sequence_id != sequence_id) + { + std::ostringstream tmp; + tmp << "Received packet with wrong sequence-id: " << packet_sequence_id << ". Expected: " << sequence_id << '.'; + throw ProtocolError(tmp.str(), ErrorCodes::UNKNOWN_PACKET_FROM_CLIENT); + } + sequence_id++; + + LOG_TRACE(log, "Received packet. Sequence-id: " << packet_sequence_id << ", payload length: " << payload_length); + + copyData(*in, static_cast(buf), payload_length); + } while (payload_length == MAX_PACKET_LENGTH); + + return std::move(buf.str()); + } + + template + T receivePacket() + { + static_assert(std::is_base_of()); + T packet; + packet.readPayload(std::move(receivePacketPayload())); + return packet; + } + + template + void sendPacket(const T & packet, bool flush = false) + { + static_assert(std::is_base_of()); + String payload = packet.getPayload(); + size_t pos = 0; + do + { + size_t payload_length = std::min(payload.length() - pos, MAX_PACKET_LENGTH); + + LOG_TRACE(log, "Writing packet of size " << payload_length << " with sequence-id " << static_cast(sequence_id)); + LOG_TRACE(log, packetToText(payload)); + + out->write(reinterpret_cast(&payload_length), 3); + out->write(reinterpret_cast(&sequence_id), 1); + out->write(payload.data() + pos, payload_length); + + pos += payload_length; + sequence_id++; + } while (pos < payload.length()); + + LOG_TRACE(log, "Packet was sent."); + + if (flush) + { + out->next(); + } + } + + /// Sets sequence-id to 0. Must be called before each command phase. + void resetSequenceId(); + +private: + /// Converts packet to text. Is used for debug output. + static String packetToText(String payload); + + std::shared_ptr in; + std::shared_ptr out; + size_t sequence_id; + Poco::Logger * log; +}; + + +uint64_t readLengthEncodedNumber(std::istringstream & ss); + +String writeLengthEncodedNumber(uint64_t x); + +void writeLengthEncodedString(String & payload, const String & s); + +void writeNulTerminatedString(String & payload, const String & s); + + +class Handshake : public WritePacket +{ int protocol_version = 0xa; - std::string server_version; + String server_version; uint32_t connection_id; uint32_t capability_flags; uint8_t character_set; uint32_t status_flags; - std::string auth_plugin_data; + String auth_plugin_data; public: - explicit Handshake(uint32_t connection_id, std::string server_version) - : protocol_version(0xa) - , server_version(std::move(server_version)) - , connection_id(connection_id) - , capability_flags( - CLIENT_PROTOCOL_41 - | CLIENT_SECURE_CONNECTION - | CLIENT_PLUGIN_AUTH - | CLIENT_PLUGIN_AUTH_LENENC_CLIENT_DATA - | CLIENT_CONNECT_WITH_DB - | CLIENT_DEPRECATE_EOF) - , character_set(63) - , status_flags(0) { + explicit Handshake(uint32_t connection_id, String server_version) + : protocol_version(0xa), server_version(std::move(server_version)), connection_id(connection_id), capability_flags( + CLIENT_PROTOCOL_41 + | CLIENT_SECURE_CONNECTION + | CLIENT_PLUGIN_AUTH + | CLIENT_PLUGIN_AUTH_LENENC_CLIENT_DATA + | CLIENT_CONNECT_WITH_DB + | CLIENT_DEPRECATE_EOF), character_set(63), status_flags(0) + { auth_plugin_data.resize(SCRAMBLE_LENGTH); auto seed = std::chrono::system_clock::now().time_since_epoch().count(); - std::default_random_engine generator (static_cast(seed)); + std::default_random_engine generator(static_cast(seed)); std::uniform_int_distribution distribution(0); - for (size_t i = 0; i < SCRAMBLE_LENGTH; i++) { + for (size_t i = 0; i < SCRAMBLE_LENGTH; i++) + { auth_plugin_data[i] = distribution(generator); } } - std::string getPayload() { - std::string result; + String getPayload() const override + { + String result; result.append(1, protocol_version); - result.append(server_version); - result.append(1, 0x0); + writeNulTerminatedString(result, server_version); result.append(reinterpret_cast(&connection_id), 4); - result.append(auth_plugin_data.substr(0, AUTH_PLUGIN_DATA_PART_1_LENGTH)); - result.append(1, 0x0); + writeNulTerminatedString(result, auth_plugin_data.substr(0, AUTH_PLUGIN_DATA_PART_1_LENGTH)); result.append(reinterpret_cast(&capability_flags), 2); result.append(reinterpret_cast(&character_set), 1); result.append(reinterpret_cast(&status_flags), 2); @@ -154,23 +293,25 @@ public: result.append(1, 0x0); result.append(10, 0x0); result.append(auth_plugin_data.substr(AUTH_PLUGIN_DATA_PART_1_LENGTH, SCRAMBLE_LENGTH - AUTH_PLUGIN_DATA_PART_1_LENGTH)); - result.append(Authentication::Native41); + result.append(Authentication::ClearText); result.append(1, 0x0); return result; } }; -class HandshakeResponse { +class HandshakeResponse : public ReadPacket +{ public: uint32_t capability_flags; uint32_t max_packet_size; uint8_t character_set; - std::string username; - std::string auth_response; - std::string database; - std::string auth_plugin_name; + String username; + String auth_response; + String database; + String auth_plugin_name; - void readPayload(const std::string & s) { + void readPayload(String s) override + { std::istringstream ss(s); ss.readsome(reinterpret_cast(&capability_flags), 4); @@ -180,86 +321,137 @@ public: std::getline(ss, username, static_cast(0x0)); - if (capability_flags & CLIENT_PLUGIN_AUTH_LENENC_CLIENT_DATA) { - auto len = readLenenc(ss); + if (capability_flags & CLIENT_PLUGIN_AUTH_LENENC_CLIENT_DATA) + { + auto len = readLengthEncodedNumber(ss); auth_response.resize(len); ss.read(auth_response.data(), static_cast(len)); - } else if (capability_flags & CLIENT_SECURE_CONNECTION) { + } + else if (capability_flags & CLIENT_SECURE_CONNECTION) + { uint8_t len; ss.read(reinterpret_cast(&len), 1); auth_response.resize(len); ss.read(auth_response.data(), len); - } else { + } + else + { std::getline(ss, auth_response, static_cast(0x0)); } - if (capability_flags & CLIENT_CONNECT_WITH_DB) { + if (capability_flags & CLIENT_CONNECT_WITH_DB) + { std::getline(ss, database, static_cast(0x0)); } - if (capability_flags & CLIENT_PLUGIN_AUTH) { + if (capability_flags & CLIENT_PLUGIN_AUTH) + { std::getline(ss, auth_plugin_name, static_cast(0x0)); } } }; -class OK_Packet { +class AuthSwitchRequest : public WritePacket +{ + String plugin_name; + String auth_plugin_data; +public: + AuthSwitchRequest(String plugin_name, String auth_plugin_data) + : plugin_name(std::move(plugin_name)), auth_plugin_data(std::move(auth_plugin_data)) + { + } + + String getPayload() const override + { + String result; + result.append(1, 0xfe); + result.append(plugin_name); + result.append(auth_plugin_data); + return result; + } +}; + +/// Packet with a single null-terminated string. Is used for clear text authentication. +class NullTerminatedString : public ReadPacket +{ +public: + String value; + + void readPayload(String s) override + { + if (s.length() == 0 || s.back() != 0) + { + throw ProtocolError("String is not null terminated.", ErrorCodes::UNKNOWN_PACKET_FROM_CLIENT); + } + value = s; + value.pop_back(); + } +}; + +class OK_Packet : public WritePacket +{ uint8_t header; uint32_t capabilities; uint64_t affected_rows; uint64_t last_insert_id; int16_t warnings = 0; uint32_t status_flags; - std::string info; - std::string session_state_changes; + String info; + String session_state_changes; public: OK_Packet(uint8_t header, uint32_t capabilities, uint64_t affected_rows, uint64_t last_insert_id, uint32_t status_flags, - int16_t warnings, std::string session_state_changes) - : header(header) - , capabilities(capabilities) - , affected_rows(affected_rows) - , last_insert_id(last_insert_id) - , warnings(warnings) - , status_flags(status_flags) - , session_state_changes(std::move(session_state_changes)) + int16_t warnings, String session_state_changes) + : header(header), capabilities(capabilities), affected_rows(affected_rows), last_insert_id(last_insert_id), warnings(warnings), + status_flags(status_flags), session_state_changes(std::move(session_state_changes)) { } - std::string getPayload() { - std::string result; + String getPayload() const override + { + String result; result.append(1, header); - result.append(writeLenenc(affected_rows)); - result.append(writeLenenc(last_insert_id)); + result.append(writeLengthEncodedNumber(affected_rows)); + result.append(writeLengthEncodedNumber(last_insert_id)); - if (capabilities & CLIENT_PROTOCOL_41) { + if (capabilities & CLIENT_PROTOCOL_41) + { result.append(reinterpret_cast(&status_flags), 2); result.append(reinterpret_cast(&warnings), 2); - } else if (capabilities & CLIENT_TRANSACTIONS) { + } + else if (capabilities & CLIENT_TRANSACTIONS) + { result.append(reinterpret_cast(&status_flags), 2); } - if (capabilities & CLIENT_SESSION_TRACK) { - result.append(writeLenenc(info.length())); + if (capabilities & CLIENT_SESSION_TRACK) + { + result.append(writeLengthEncodedNumber(info.length())); result.append(info); - if (status_flags & SERVER_SESSION_STATE_CHANGED) { - result.append(writeLenenc(session_state_changes.length())); + if (status_flags & SERVER_SESSION_STATE_CHANGED) + { + result.append(writeLengthEncodedNumber(session_state_changes.length())); result.append(session_state_changes); } - } else { + } + else + { result.append(info); } return result; } }; -class EOF_Packet { +class EOF_Packet : public WritePacket +{ int warnings; int status_flags; public: - EOF_Packet(int warnings, int status_flags): warnings(warnings), status_flags(status_flags) {} + EOF_Packet(int warnings, int status_flags) : warnings(warnings), status_flags(status_flags) + {} - std::string getPayload() { - std::string result; + String getPayload() const override + { + String result; result.append(1, 0xfe); // EOF header result.append(reinterpret_cast(&warnings), 2); result.append(reinterpret_cast(&status_flags), 2); @@ -267,21 +459,20 @@ public: } }; -class ERR_Packet { +class ERR_Packet : public WritePacket +{ int error_code; - std::string sql_state; - std::string error_message; + String sql_state; + String error_message; public: - ERR_Packet(int error_code, std::string sql_state, std::string error_message) - : error_code(error_code) - , sql_state(std::move(sql_state)) - , error_message(std::move(error_message)) + ERR_Packet(int error_code, String sql_state, String error_message) + : error_code(error_code), sql_state(std::move(sql_state)), error_message(std::move(error_message)) { } - std::string getPayload() + String getPayload() const override { - std::string result; + String result; result.append(1, 0xff); result.append(reinterpret_cast(&error_code), 2); result.append("#", 1); @@ -291,12 +482,13 @@ public: } }; -class ColumnDefinition { - std::string schema; - std::string table; - std::string org_table; - std::string name; - std::string org_name; +class ColumnDefinition : public WritePacket +{ + String schema; + String table; + String org_table; + String name; + String org_name; size_t next_length = 0x0c; uint16_t character_set; uint32_t column_length; @@ -304,40 +496,46 @@ class ColumnDefinition { uint16_t flags; uint8_t decimals = 0x00; public: - explicit ColumnDefinition( - std::string schema, - std::string table, - std::string org_table, - std::string name, - std::string org_name, + ColumnDefinition( + String schema, + String table, + String org_table, + String name, + String org_name, uint16_t character_set, uint32_t column_length, ColumnType column_type, uint16_t flags, uint8_t decimals) - : schema(std::move(schema)) - , table(std::move(table)) - , org_table(std::move(org_table)) - , name(std::move(name)) - , org_name(std::move(org_name)) - , character_set(character_set) - , column_length(column_length) - , column_type(column_type) - , flags(flags) - , decimals(decimals) + : schema(std::move(schema)), table(std::move(table)), org_table(std::move(org_table)), name(std::move(name)), + org_name(std::move(org_name)), character_set(character_set), column_length(column_length), column_type(column_type), flags(flags), + decimals(decimals) { } - std::string getPayload() { - std::string result; - writeLenencStr(result, "def"); // always "def" - writeLenencStr(result, schema); - writeLenencStr(result, table); - writeLenencStr(result, org_table); - writeLenencStr(result, name); - writeLenencStr(result, org_name); - result.append(writeLenenc(next_length)); + /// Should be used when column metadata (original name, table, original table, database) is unknown. + ColumnDefinition( + String name, + uint16_t character_set, + uint32_t column_length, + ColumnType column_type, + uint16_t flags, + uint8_t decimals) + : ColumnDefinition("", "", "", std::move(name), "", character_set, column_length, column_type, flags, decimals) + { + } + + String getPayload() const override + { + String result; + writeLengthEncodedString(result, "def"); /// always "def" + writeLengthEncodedString(result, ""); /// schema + writeLengthEncodedString(result, ""); /// table + writeLengthEncodedString(result, ""); /// org_table + writeLengthEncodedString(result, name); + writeLengthEncodedString(result, ""); /// org_name + result.append(writeLengthEncodedNumber(next_length)); result.append(reinterpret_cast(&character_set), 2); result.append(reinterpret_cast(&column_length), 4); result.append(reinterpret_cast(&column_type), 1); @@ -348,11 +546,12 @@ public: } }; -class ComFieldList { +class ComFieldList : public ReadPacket +{ public: - std::string table, field_wildcard; + String table, field_wildcard; - void readPayload(const std::string & payload) + void readPayload(String payload) { std::istringstream ss(payload); ss.ignore(1); // command byte @@ -361,6 +560,43 @@ public: } }; +class LengthEncodedNumber : public WritePacket +{ + uint64_t value; +public: + LengthEncodedNumber(uint64_t value): value(value) + { + } + + String getPayload() const override + { + return writeLengthEncodedNumber(value); + } +}; + +class ResultsetRow : public WritePacket +{ + std::vector columns; +public: + ResultsetRow() + { + } + + void appendColumn(String value) + { + columns.emplace_back(std::move(value)); + } + + String getPayload() const override + { + String result; + for (const String & column : columns) + { + writeLengthEncodedString(result, column); + } + return result; + } +}; } } From e91fd22b82fb3105970021180a9f756f4f6b8527 Mon Sep 17 00:00:00 2001 From: Yuriy Date: Mon, 1 Apr 2019 12:59:49 +0300 Subject: [PATCH 033/709] fixed style check --- dbms/programs/server/MySQLHandler.h | 13 ++++++------- 1 file changed, 6 insertions(+), 7 deletions(-) diff --git a/dbms/programs/server/MySQLHandler.h b/dbms/programs/server/MySQLHandler.h index 6ca2419ad1f..710a8cd3afc 100644 --- a/dbms/programs/server/MySQLHandler.h +++ b/dbms/programs/server/MySQLHandler.h @@ -10,14 +10,12 @@ namespace DB { /// Handler for MySQL wire protocol connections. Allows to connect to ClickHouse using MySQL client. -class MySQLHandler : public Poco::Net::TCPServerConnection { +class MySQLHandler : public Poco::Net::TCPServerConnection +{ public: - MySQLHandler(IServer &server_, const Poco::Net::StreamSocket &socket_) - : Poco::Net::TCPServerConnection(socket_) - , server(server_) - , log(&Poco::Logger::get("MySQLHandler")) - , connection_context(server.context()) - , connection_id(last_connection_id++) + MySQLHandler(IServer & server_, const Poco::Net::StreamSocket & socket_) + : Poco::Net::TCPServerConnection(socket_), server(server_), log(&Poco::Logger::get("MySQLHandler")), + connection_context(server.context()), connection_id(last_connection_id++) { } @@ -30,6 +28,7 @@ public: void comPing(); void comInitDB(String payload); + private: IServer & server; Poco::Logger * log; From 0f3ec94ebdbe1cda979f86f15743bbe12642f30b Mon Sep 17 00:00:00 2001 From: Yuriy Date: Wed, 3 Apr 2019 01:21:44 +0300 Subject: [PATCH 034/709] added mysql protocol test --- dbms/programs/server/MySQLHandler.cpp | 28 ++++- dbms/programs/server/MySQLHandler.h | 3 - dbms/src/Core/MySQLProtocol.h | 2 +- dbms/tests/integration/helpers/cluster.py | 2 +- .../test_mysql_protocol/__init__.py | 0 .../test_mysql_protocol/configs/config.xml | 20 ++++ .../test_mysql_protocol/configs/users.xml | 23 ++++ .../integration/test_mysql_protocol/test.py | 100 ++++++++++++++++++ 8 files changed, 168 insertions(+), 10 deletions(-) create mode 100644 dbms/tests/integration/test_mysql_protocol/__init__.py create mode 100644 dbms/tests/integration/test_mysql_protocol/configs/config.xml create mode 100644 dbms/tests/integration/test_mysql_protocol/configs/users.xml create mode 100644 dbms/tests/integration/test_mysql_protocol/test.py diff --git a/dbms/programs/server/MySQLHandler.cpp b/dbms/programs/server/MySQLHandler.cpp index 9a4d8cf4a35..09a88c65e0f 100644 --- a/dbms/programs/server/MySQLHandler.cpp +++ b/dbms/programs/server/MySQLHandler.cpp @@ -36,7 +36,7 @@ void MySQLHandler::run() try { - Handshake handshake(connection_id, VERSION_FULL); + Handshake handshake(connection_id, VERSION_STRING); packet_sender.sendPacket(handshake, true); LOG_TRACE(log, "Sent handshake"); @@ -82,10 +82,24 @@ void MySQLHandler::run() packet.readPayload(std::move(handshake_response.auth_response)); password = packet.value; } - connection_context.setUser(handshake_response.username, password, socket().address(), ""); - connection_context.setCurrentDatabase(handshake_response.database); - connection_context.setCurrentQueryId(""); - LOG_ERROR(log, "Authentication for user " << handshake_response.username << " succeeded."); + LOG_TRACE(log, "password: " << password); + try + { + connection_context.setUser(handshake_response.username, password, socket().address(), ""); + connection_context.setCurrentDatabase(handshake_response.database); + connection_context.setCurrentQueryId(""); + LOG_ERROR(log, "Authentication for user " << handshake_response.username << " succeeded."); + } + catch (const NetException &) + { + throw; + } + catch (const Exception & exc) + { + LOG_ERROR(log, "Authentication for user " << handshake_response.username << " failed."); + packet_sender.sendPacket(ERR_Packet(exc.code(), "00000", exc.message()), true); + throw; + } OK_Packet ok_packet(0, handshake_response.capability_flags, 0, 0, 0, 0, ""); packet_sender.sendPacket(ok_packet, true); @@ -187,6 +201,10 @@ void MySQLHandler::comQuery(String payload) LOG_TRACE(log, "Sent columns definitions."); + if (!(capabilities & Capability::CLIENT_DEPRECATE_EOF)) { + packet_sender.sendPacket(EOF_Packet(0, 0)); + } + while (Block block = res.in->read()) { size_t rows = block.rows(); diff --git a/dbms/programs/server/MySQLHandler.h b/dbms/programs/server/MySQLHandler.h index 710a8cd3afc..0e1a73f0f24 100644 --- a/dbms/programs/server/MySQLHandler.h +++ b/dbms/programs/server/MySQLHandler.h @@ -34,9 +34,6 @@ private: Poco::Logger * log; Context connection_context; - std::shared_ptr in; - std::shared_ptr out; - MySQLProtocol::PacketSender packet_sender; uint32_t connection_id = 0; diff --git a/dbms/src/Core/MySQLProtocol.h b/dbms/src/Core/MySQLProtocol.h index bbead941e6b..e55ea86fbf5 100644 --- a/dbms/src/Core/MySQLProtocol.h +++ b/dbms/src/Core/MySQLProtocol.h @@ -365,7 +365,7 @@ public: { String result; result.append(1, 0xfe); - result.append(plugin_name); + writeNulTerminatedString(result, plugin_name); result.append(auth_plugin_data); return result; } diff --git a/dbms/tests/integration/helpers/cluster.py b/dbms/tests/integration/helpers/cluster.py index 240cc2c8695..1bd7404bdac 100644 --- a/dbms/tests/integration/helpers/cluster.py +++ b/dbms/tests/integration/helpers/cluster.py @@ -102,7 +102,7 @@ class ClickHouseCluster: self.with_hdfs = False self.with_mongo = False - self.docker_client = None + self.docker_client = None # type: docker.DockerClient self.is_up = False diff --git a/dbms/tests/integration/test_mysql_protocol/__init__.py b/dbms/tests/integration/test_mysql_protocol/__init__.py new file mode 100644 index 00000000000..e69de29bb2d diff --git a/dbms/tests/integration/test_mysql_protocol/configs/config.xml b/dbms/tests/integration/test_mysql_protocol/configs/config.xml new file mode 100644 index 00000000000..7c73809100b --- /dev/null +++ b/dbms/tests/integration/test_mysql_protocol/configs/config.xml @@ -0,0 +1,20 @@ + + + + trace + /var/log/clickhouse-server/clickhouse-server.log + /var/log/clickhouse-server/clickhouse-server.err.log + 1000M + 10 + + + 9000 + 9001 + 127.0.0.1 + + 500 + 5368709120 + ./clickhouse/ + users.xml + + diff --git a/dbms/tests/integration/test_mysql_protocol/configs/users.xml b/dbms/tests/integration/test_mysql_protocol/configs/users.xml new file mode 100644 index 00000000000..2be13dca499 --- /dev/null +++ b/dbms/tests/integration/test_mysql_protocol/configs/users.xml @@ -0,0 +1,23 @@ + + + + + + + + + + 123 + + ::/0 + + default + default + + + + + + + + diff --git a/dbms/tests/integration/test_mysql_protocol/test.py b/dbms/tests/integration/test_mysql_protocol/test.py new file mode 100644 index 00000000000..587d36d3a1c --- /dev/null +++ b/dbms/tests/integration/test_mysql_protocol/test.py @@ -0,0 +1,100 @@ +# coding: utf-8 + +import os +import pytest +import pymysql.connections + +from docker.models.containers import Container + +from helpers.cluster import ClickHouseCluster + + +SCRIPT_DIR = os.path.dirname(os.path.realpath(__file__)) + +cluster = ClickHouseCluster(__file__, base_configs_dir=os.path.join(SCRIPT_DIR, './configs')) + +node = cluster.add_instance('node', with_mysql=True) + +server_port = 9001 + + +@pytest.fixture(scope="module") +def started_cluster(): + cluster.start() + try: + yield cluster + finally: + cluster.shutdown() + + +@pytest.fixture(scope='module') +def mysql_container(started_cluster): + # type: (ClickHouseCluster) -> Container + yield started_cluster.docker_client.containers.get(started_cluster.get_instance_docker_id('mysql1')) + + +@pytest.fixture(scope='module') +def server_address(started_cluster): + yield started_cluster.get_instance_ip('node') + + +def test_select(mysql_container, server_address): + # type: (Container, str) -> None + code, (stdout, stderr) = mysql_container.exec_run(''' + mysql --protocol tcp -h {host} -P {port} default -u default --enable-cleartext-plugin --password=123 + -e "select 1 as a;" + -e "select 'тест' as b;" + '''.format(host=server_address, port=server_port), demux=True) + + assert stdout == 'a\n1\nb\nтест\n' + + +def test_authentication(mysql_container, server_address): + # type: (Container, str) -> None + + code, (stdout, stderr) = mysql_container.exec_run(''' + mysql --protocol tcp -h {host} -P {port} default -u default --enable-cleartext-plugin --password=abc -e "select 1 as a;" + '''.format(host=server_address, port=server_port), demux=True) + + assert stderr == 'mysql: [Warning] Using a password on the command line interface can be insecure.\n' \ + 'ERROR 193 (00000): Wrong password for user default\n' + + +def test_change_database(mysql_container, server_address): + # type: (Container, str) -> None + + code, (stdout, stderr) = mysql_container.exec_run(''' + mysql --protocol tcp -h {host} -P {port} default -u default --enable-cleartext-plugin --password=123 + -e "use system;" + -e "select count(*) from (select name from tables limit 1);" + -e "use system2;" + '''.format(host=server_address, port=server_port), demux=True) + + assert stdout == 'count()\n1\n' + assert stderr == "mysql: [Warning] Using a password on the command line interface can be insecure.\n" \ + "ERROR 81 (00000) at line 1: Database system2 doesn't exist\n" + + +def test_py_client(server_address): + with pytest.raises(pymysql.InternalError) as exc_info: + pymysql.connections.Connection(host=server_address, user='default', password='abacab', database='default', port=server_port) + + assert exc_info.value.args == (193, 'Wrong password for user default') + + client = pymysql.connections.Connection(host=server_address, user='default', password='123', database='default', port=server_port) + + with pytest.raises(pymysql.InternalError) as exc_info: + client.query('select name from tables') + + assert exc_info.value.args == (60, "Table default.tables doesn't exist.") + + cursor = client.cursor(pymysql.cursors.DictCursor) + cursor.execute("select 1 as a, 'тест' as b") + assert cursor.fetchall() == [{'a': '1', 'b': 'тест'}] + + client.select_db('system') + + with pytest.raises(pymysql.InternalError) as exc_info: + client.select_db('system2') + + assert exc_info.value.args == (81, "Database system2 doesn't exist") From 3ea33600a050647211a7db70c2b9723e85234f52 Mon Sep 17 00:00:00 2001 From: Yuriy Date: Wed, 3 Apr 2019 01:56:49 +0300 Subject: [PATCH 035/709] fixed style check --- dbms/programs/server/MySQLHandler.cpp | 3 ++- 1 file changed, 2 insertions(+), 1 deletion(-) diff --git a/dbms/programs/server/MySQLHandler.cpp b/dbms/programs/server/MySQLHandler.cpp index 09a88c65e0f..4f760c0c67f 100644 --- a/dbms/programs/server/MySQLHandler.cpp +++ b/dbms/programs/server/MySQLHandler.cpp @@ -201,7 +201,8 @@ void MySQLHandler::comQuery(String payload) LOG_TRACE(log, "Sent columns definitions."); - if (!(capabilities & Capability::CLIENT_DEPRECATE_EOF)) { + if (!(capabilities & Capability::CLIENT_DEPRECATE_EOF)) + { packet_sender.sendPacket(EOF_Packet(0, 0)); } From b5f0414200d98843fadd9d7002bdbfe93342b289 Mon Sep 17 00:00:00 2001 From: Alexander Kozhikhov Date: Thu, 4 Apr 2019 03:17:27 +0300 Subject: [PATCH 036/709] new test --- .../AggregateFunctionMLMethod.h | 17 +++++++------- .../0_stateless/00960_dataset_test.sql | 22 +++++++++++++++++++ 2 files changed, 31 insertions(+), 8 deletions(-) create mode 100644 dbms/tests/queries/0_stateless/00960_dataset_test.sql diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h index 2fd4c7cc3f2..6bceb2ee8a8 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h @@ -7,19 +7,17 @@ #include #include -#include +#include +#include +#include +#include #include +#include #include #include -#include -#include -#include -#include - - namespace DB { @@ -618,6 +616,7 @@ public: /// хочется не константный rhs void merge(AggregateDataPtr place, ConstAggregateDataPtr rhs, Arena *) const override { + std::cout << "\nMERGING!!\n\n"; this->data(place).merge(this->data(rhs)); } @@ -633,6 +632,8 @@ public: void predictResultInto(ConstAggregateDataPtr place, IColumn & to, Block & block, const ColumnNumbers & arguments) const { + std::cout << "\nPREDICTING!!\n\n"; + if (arguments.size() != param_num + 1) throw Exception("Predict got incorrect number of arguments. Got: " + std::to_string(arguments.size()) + ". Required: " + std::to_string(param_num + 1), @@ -660,7 +661,7 @@ public: { std::ignore = place; std::ignore = to; - return; + throw std::runtime_error("not implemented"); } const char * getHeaderFilePath() const override { return __FILE__; } diff --git a/dbms/tests/queries/0_stateless/00960_dataset_test.sql b/dbms/tests/queries/0_stateless/00960_dataset_test.sql new file mode 100644 index 00000000000..1b065afdecb --- /dev/null +++ b/dbms/tests/queries/0_stateless/00960_dataset_test.sql @@ -0,0 +1,22 @@ +-- CREATE DATABASE IF NOT EXISTS test; +-- DROP TABLE IF EXISTS test.trainset; +-- CREATE TABLE IF NOT EXISTS test.trainset +-- ( +-- param1 Float64, param2 Float64, param3 Float64, param4 Float64, param5 Float64, param6 Float64, param7 Float64, param8 Float64, param9 Float64, param10 Float64, param11 Float64, param12 Float64, param13 Float64, param14 Float64, param15 Float64, param16 Float64, param17 Float64, param18 Float64, param19 Float64, param20 Float64, param21 Float64, param22 Float64, param23 Float64, param24 Float64, param25 Float64, param26 Float64, param27 Float64, param28 Float64, param29 Float64, param30 Float64, param31 Float64, param32 Float64, param33 Float64, param34 Float64, param35 Float64, param36 Float64, param37 Float64, param38 Float64, param39 Float64, param40 Float64, param41 Float64, param42 Float64, param43 Float64, param44 Float64, param45 Float64, param46 Float64, param47 Float64, param48 Float64, param49 Float64, param50 Float64, param51 Float64, param52 Float64, param53 Float64, param54 Float64, param55 Float64, param56 Float64, param57 Float64, param58 Float64, param59 Float64, param60 Float64, param61 Float64, param62 Float64, param63 Float64, param64 Float64, param65 Float64, param66 Float64, param67 Float64, param68 Float64, param69 Float64, param70 Float64, param71 Float64, param72 Float64, param73 Float64, param74 Float64, param75 Float64, param76 Float64, param77 Float64, param78 Float64, param79 Float64, param80 Float64, param81 Float64, param82 Float64, param83 Float64, param84 Float64, param85 Float64, param86 Float64, param87 Float64, param88 Float64, param89 Float64, param90 Float64, param91 Float64, param92 Float64, param93 Float64, param94 Float64, param95 Float64, param96 Float64, param97 Float64, param98 Float64, param99 Float64, param100 Float64, param101 Float64, param102 Float64, param103 Float64, param104 Float64, param105 Float64, param106 Float64, param107 Float64, param108 Float64, param109 Float64, param110 Float64, param111 Float64, param112 Float64, param113 Float64, param114 Float64, param115 Float64, param116 Float64, param117 Float64, param118 Float64, param119 Float64, param120 Float64, param121 Float64, param122 Float64, param123 Float64, param124 Float64, param125 Float64, param126 Float64, param127 Float64, param128 Float64, param129 Float64, param130 Float64, param131 Float64, param132 Float64, param133 Float64, param134 Float64, param135 Float64, param136 Float64, param137 Float64, param138 Float64, param139 Float64, param140 Float64, param141 Float64, param142 Float64, param143 Float64, param144 Float64, param145 Float64, param146 Float64, param147 Float64, param148 Float64, param149 Float64, param150 Float64, param151 Float64, param152 Float64, param153 Float64, param154 Float64, param155 Float64, param156 Float64, param157 Float64, param158 Float64, param159 Float64, param160 Float64, param161 Float64, param162 Float64, param163 Float64, param164 Float64, param165 Float64, param166 Float64, param167 Float64, param168 Float64, param169 Float64, param170 Float64, param171 Float64, param172 Float64, param173 Float64, param174 Float64, param175 Float64, param176 Float64, param177 Float64, param178 Float64, param179 Float64, param180 Float64, param181 Float64, param182 Float64, param183 Float64, target Float64 +-- ) ENGINE = Memory; +-- DROP TABLE IF EXISTS test.testset; +-- CREATE TABLE IF NOT EXISTS test.testset +-- ( +-- param1 Float64, param2 Float64, param3 Float64, param4 Float64, param5 Float64, param6 Float64, param7 Float64, param8 Float64, param9 Float64, param10 Float64, param11 Float64, param12 Float64, param13 Float64, param14 Float64, param15 Float64, param16 Float64, param17 Float64, param18 Float64, param19 Float64, param20 Float64, param21 Float64, param22 Float64, param23 Float64, param24 Float64, param25 Float64, param26 Float64, param27 Float64, param28 Float64, param29 Float64, param30 Float64, param31 Float64, param32 Float64, param33 Float64, param34 Float64, param35 Float64, param36 Float64, param37 Float64, param38 Float64, param39 Float64, param40 Float64, param41 Float64, param42 Float64, param43 Float64, param44 Float64, param45 Float64, param46 Float64, param47 Float64, param48 Float64, param49 Float64, param50 Float64, param51 Float64, param52 Float64, param53 Float64, param54 Float64, param55 Float64, param56 Float64, param57 Float64, param58 Float64, param59 Float64, param60 Float64, param61 Float64, param62 Float64, param63 Float64, param64 Float64, param65 Float64, param66 Float64, param67 Float64, param68 Float64, param69 Float64, param70 Float64, param71 Float64, param72 Float64, param73 Float64, param74 Float64, param75 Float64, param76 Float64, param77 Float64, param78 Float64, param79 Float64, param80 Float64, param81 Float64, param82 Float64, param83 Float64, param84 Float64, param85 Float64, param86 Float64, param87 Float64, param88 Float64, param89 Float64, param90 Float64, param91 Float64, param92 Float64, param93 Float64, param94 Float64, param95 Float64, param96 Float64, param97 Float64, param98 Float64, param99 Float64, param100 Float64, param101 Float64, param102 Float64, param103 Float64, param104 Float64, param105 Float64, param106 Float64, param107 Float64, param108 Float64, param109 Float64, param110 Float64, param111 Float64, param112 Float64, param113 Float64, param114 Float64, param115 Float64, param116 Float64, param117 Float64, param118 Float64, param119 Float64, param120 Float64, param121 Float64, param122 Float64, param123 Float64, param124 Float64, param125 Float64, param126 Float64, param127 Float64, param128 Float64, param129 Float64, param130 Float64, param131 Float64, param132 Float64, param133 Float64, param134 Float64, param135 Float64, param136 Float64, param137 Float64, param138 Float64, param139 Float64, param140 Float64, param141 Float64, param142 Float64, param143 Float64, param144 Float64, param145 Float64, param146 Float64, param147 Float64, param148 Float64, param149 Float64, param150 Float64, param151 Float64, param152 Float64, param153 Float64, param154 Float64, param155 Float64, param156 Float64, param157 Float64, param158 Float64, param159 Float64, param160 Float64, param161 Float64, param162 Float64, param163 Float64, param164 Float64, param165 Float64, param166 Float64, param167 Float64, param168 Float64, param169 Float64, param170 Float64, param171 Float64, param172 Float64, param173 Float64, param174 Float64, param175 Float64, param176 Float64, param177 Float64, param178 Float64, param179 Float64, param180 Float64, param181 Float64, param182 Float64, param183 Float64 +-- ) ENGINE = Memory; + +SET send_logs_level = 'trace'; +-- SET log_queries = 1; +-- SET max_threads = 4; + +-- drop table if exists test.model; +-- create table if not exists test.model engine = Memory as select LinearRegressionState(0.0000001, 4, 2.0)(target, param1, param2, param3, param4, param5, param6, param7, param8, param9, param10, param11, param12, param13, param14, param15, param16, param17, param18, param19, param20, param21, param22, param23, param24, param25, param26, param27, param28, param29, param30, param31, param32, param33, param34, param35, param36, param37, param38, param39, param40, param41, param42, param43, param44, param45, param46, param47, param48, param49, param50, param51, param52, param53, param54, param55, param56, param57, param58, param59, param60, param61, param62, param63, param64, param65, param66, param67, param68, param69, param70, param71, param72, param73, param74, param75, param76, param77, param78, param79, param80, param81, param82, param83, param84, param85, param86, param87, param88, param89, param90, param91, param92, param93, param94, param95, param96, param97, param98, param99, param100, param101, param102, param103, param104, param105, param106, param107, param108, param109, param110, param111, param112, param113, param114, param115, param116, param117, param118, param119, param120, param121, param122, param123, param124, param125, param126, param127, param128, param129, param130, param131, param132, param133, param134, param135, param136, param137, param138, param139, param140, param141, param142, param143, param144, param145, param146, param147, param148, param149, param150, param151, param152, param153, param154, param155, param156, param157, param158, param159, param160, param161, param162, param163, param164, param165, param166, param167, param168, param169, param170, param171, param172, param173, param174, param175, param176, param177, param178, param179, param180, param181, param182, param183) as state from test.trainset; + +select LinearRegressionState(0.0000001, 4, 2.0)(target, param1, param2, param3, param4, param5, param6, param7, param8, param9, param10, param11, param12, param13, param14, param15, param16, param17, param18, param19, param20, param21, param22, param23, param24, param25, param26, param27, param28, param29, param30, param31, param32, param33, param34, param35, param36, param37, param38, param39, param40, param41, param42, param43, param44, param45, param46, param47, param48, param49, param50, param51, param52, param53, param54, param55, param56, param57, param58, param59, param60, param61, param62, param63, param64, param65, param66, param67, param68, param69, param70, param71, param72, param73, param74, param75, param76, param77, param78, param79, param80, param81, param82, param83, param84, param85, param86, param87, param88, param89, param90, param91, param92, param93, param94, param95, param96, param97, param98, param99, param100, param101, param102, param103, param104, param105, param106, param107, param108, param109, param110, param111, param112, param113, param114, param115, param116, param117, param118, param119, param120, param121, param122, param123, param124, param125, param126, param127, param128, param129, param130, param131, param132, param133, param134, param135, param136, param137, param138, param139, param140, param141, param142, param143, param144, param145, param146, param147, param148, param149, param150, param151, param152, param153, param154, param155, param156, param157, param158, param159, param160, param161, param162, param163, param164, param165, param166, param167, param168, param169, param170, param171, param172, param173, param174, param175, param176, param177, param178, param179, param180, param181, param182, param183) from test.trainset; + +-- with (select state from test.model) as model select evalMLMethod(model, param1, param2, param3, param4, param5, param6, param7, param8, param9, param10, param11, param12, param13, param14, param15, param16, param17, param18, param19, param20, param21, param22, param23, param24, param25, param26, param27, param28, param29, param30, param31, param32, param33, param34, param35, param36, param37, param38, param39, param40, param41, param42, param43, param44, param45, param46, param47, param48, param49, param50, param51, param52, param53, param54, param55, param56, param57, param58, param59, param60, param61, param62, param63, param64, param65, param66, param67, param68, param69, param70, param71, param72, param73, param74, param75, param76, param77, param78, param79, param80, param81, param82, param83, param84, param85, param86, param87, param88, param89, param90, param91, param92, param93, param94, param95, param96, param97, param98, param99, param100, param101, param102, param103, param104, param105, param106, param107, param108, param109, param110, param111, param112, param113, param114, param115, param116, param117, param118, param119, param120, param121, param122, param123, param124, param125, param126, param127, param128, param129, param130, param131, param132, param133, param134, param135, param136, param137, param138, param139, param140, param141, param142, param143, param144, param145, param146, param147, param148, param149, param150, param151, param152, param153, param154, param155, param156, param157, param158, param159, param160, param161, param162, param163, param164, param165, param166, param167, param168, param169, param170, param171, param172, param173, param174, param175, param176, param177, param178, param179, param180, param181, param182, param183) from test.testset; \ No newline at end of file From b792568bdce09b990d97187901084a10f8b4d734 Mon Sep 17 00:00:00 2001 From: Yuriy Date: Sun, 7 Apr 2019 13:29:30 +0300 Subject: [PATCH 037/709] added golang mysql client test --- dbms/src/Core/MySQLProtocol.h | 9 -- dbms/tests/integration/helpers/cluster.py | 2 +- .../clients/golang/0.reference | 24 +++++ .../clients/golang/Dockerfile | 7 ++ .../clients/golang/docker_compose.yml | 8 ++ .../clients/golang/main.go | 93 +++++++++++++++++++ .../clients/mysql/docker_compose.yml | 6 ++ .../integration/test_mysql_protocol/test.py | 58 +++++++----- 8 files changed, 175 insertions(+), 32 deletions(-) create mode 100644 dbms/tests/integration/test_mysql_protocol/clients/golang/0.reference create mode 100644 dbms/tests/integration/test_mysql_protocol/clients/golang/Dockerfile create mode 100644 dbms/tests/integration/test_mysql_protocol/clients/golang/docker_compose.yml create mode 100644 dbms/tests/integration/test_mysql_protocol/clients/golang/main.go create mode 100644 dbms/tests/integration/test_mysql_protocol/clients/mysql/docker_compose.yml diff --git a/dbms/src/Core/MySQLProtocol.h b/dbms/src/Core/MySQLProtocol.h index e55ea86fbf5..488bf1f7e7a 100644 --- a/dbms/src/Core/MySQLProtocol.h +++ b/dbms/src/Core/MySQLProtocol.h @@ -267,15 +267,6 @@ public: | CLIENT_DEPRECATE_EOF), character_set(63), status_flags(0) { auth_plugin_data.resize(SCRAMBLE_LENGTH); - - auto seed = std::chrono::system_clock::now().time_since_epoch().count(); - std::default_random_engine generator(static_cast(seed)); - - std::uniform_int_distribution distribution(0); - for (size_t i = 0; i < SCRAMBLE_LENGTH; i++) - { - auth_plugin_data[i] = distribution(generator); - } } String getPayload() const override diff --git a/dbms/tests/integration/helpers/cluster.py b/dbms/tests/integration/helpers/cluster.py index 1bd7404bdac..240cc2c8695 100644 --- a/dbms/tests/integration/helpers/cluster.py +++ b/dbms/tests/integration/helpers/cluster.py @@ -102,7 +102,7 @@ class ClickHouseCluster: self.with_hdfs = False self.with_mongo = False - self.docker_client = None # type: docker.DockerClient + self.docker_client = None self.is_up = False diff --git a/dbms/tests/integration/test_mysql_protocol/clients/golang/0.reference b/dbms/tests/integration/test_mysql_protocol/clients/golang/0.reference new file mode 100644 index 00000000000..d1414bf6562 --- /dev/null +++ b/dbms/tests/integration/test_mysql_protocol/clients/golang/0.reference @@ -0,0 +1,24 @@ +Columns: +a +Column types: +a BINARY +Result: +0 +1 +Columns: +name +a +Column types: +name BINARY +a BINARY +Result: +aggregate_function_combinators 1 +asynchronous_metrics 1 +Columns: +a +b +Column types: +a BINARY +b BINARY +Result: +тест 1 diff --git a/dbms/tests/integration/test_mysql_protocol/clients/golang/Dockerfile b/dbms/tests/integration/test_mysql_protocol/clients/golang/Dockerfile new file mode 100644 index 00000000000..d169c274a8b --- /dev/null +++ b/dbms/tests/integration/test_mysql_protocol/clients/golang/Dockerfile @@ -0,0 +1,7 @@ +FROM golang:1.12.2 + +RUN go get "github.com/go-sql-driver/mysql" + +COPY ./main.go main.go + +RUN go build main.go diff --git a/dbms/tests/integration/test_mysql_protocol/clients/golang/docker_compose.yml b/dbms/tests/integration/test_mysql_protocol/clients/golang/docker_compose.yml new file mode 100644 index 00000000000..7850298dd7c --- /dev/null +++ b/dbms/tests/integration/test_mysql_protocol/clients/golang/docker_compose.yml @@ -0,0 +1,8 @@ +version: '2.2' +services: + golang1: + build: + context: ./ + network: host + # to keep container running + command: sleep infinity diff --git a/dbms/tests/integration/test_mysql_protocol/clients/golang/main.go b/dbms/tests/integration/test_mysql_protocol/clients/golang/main.go new file mode 100644 index 00000000000..93eab9d8568 --- /dev/null +++ b/dbms/tests/integration/test_mysql_protocol/clients/golang/main.go @@ -0,0 +1,93 @@ +package main + +import ( + "database/sql" + "flag" + "fmt" + _ "github.com/go-sql-driver/mysql" + "log" + "os" +) + + +func main() { + host := flag.String("host", "localhost", "mysql server address") + port := flag.Uint("port", 3306, "mysql server port") + user := flag.String("user", "", "username") + password := flag.String("password", "", "password") + database := flag.String("database", "", "database to authenticate against") + flag.Parse() + + logger := log.New(os.Stderr, "", 0) + dataSource := fmt.Sprintf("%s:%s@tcp(%s:%d)/%s?allowCleartextPasswords=1", *user, *password, *host, *port, *database) + db, err := sql.Open("mysql", dataSource) + + if err != nil { + logger.Fatal(err) + } + defer db.Close() + + runQuery := func (query string, processRows func (*sql.Rows)) { + rows, err := db.Query(query) + if err != nil { + logger.Fatal(err) + } + + columns, err := rows.Columns() + fmt.Println("Columns:") + for _, name := range columns { + fmt.Println(name) + } + + columnsTypes, err := rows.ColumnTypes() + fmt.Println("Column types:") + for _, column := range columnsTypes { + fmt.Printf("%s %s\n", column.Name(), column.DatabaseTypeName()) + } + + fmt.Println("Result:") + processRows(rows) + + err = rows.Err() + if err != nil { + logger.Fatal(err) + } + + err = rows.Close() + if err != nil { + logger.Fatal(err) + } + err = rows.Close() + if err != nil { + logger.Fatal(err) + } + } + + processRows := func (rows *sql.Rows) { + var x int + for rows.Next() { + err := rows.Scan(&x) + if err != nil { + logger.Fatal(err) + } + fmt.Println(x) + } + } + runQuery("select number as a from system.numbers limit 2", processRows) + + processRows = func (rows *sql.Rows) { + var name string + var a int + for rows.Next() { + err := rows.Scan(&name, &a) + if err != nil { + logger.Fatal(err) + } + fmt.Println(name, a) + } + } + runQuery("select name, 1 as a from system.tables limit 2", processRows) + + runQuery("select 'тест' as a, 1 as b", processRows) + +} diff --git a/dbms/tests/integration/test_mysql_protocol/clients/mysql/docker_compose.yml b/dbms/tests/integration/test_mysql_protocol/clients/mysql/docker_compose.yml new file mode 100644 index 00000000000..777e2bad2e3 --- /dev/null +++ b/dbms/tests/integration/test_mysql_protocol/clients/mysql/docker_compose.yml @@ -0,0 +1,6 @@ +version: '2.2' +services: + mysql1: + image: mysql:5.7 + # rewriting default command, because starting server is unnecessary + command: sleep infinity diff --git a/dbms/tests/integration/test_mysql_protocol/test.py b/dbms/tests/integration/test_mysql_protocol/test.py index 587d36d3a1c..1720fbdf786 100644 --- a/dbms/tests/integration/test_mysql_protocol/test.py +++ b/dbms/tests/integration/test_mysql_protocol/test.py @@ -1,7 +1,9 @@ # coding: utf-8 import os +import docker import pytest +import subprocess import pymysql.connections from docker.models.containers import Container @@ -12,35 +14,37 @@ from helpers.cluster import ClickHouseCluster SCRIPT_DIR = os.path.dirname(os.path.realpath(__file__)) cluster = ClickHouseCluster(__file__, base_configs_dir=os.path.join(SCRIPT_DIR, './configs')) - -node = cluster.add_instance('node', with_mysql=True) +node = cluster.add_instance('node') server_port = 9001 @pytest.fixture(scope="module") -def started_cluster(): +def server_address(): cluster.start() try: - yield cluster + yield cluster.get_instance_ip('node') finally: cluster.shutdown() @pytest.fixture(scope='module') -def mysql_container(started_cluster): - # type: (ClickHouseCluster) -> Container - yield started_cluster.docker_client.containers.get(started_cluster.get_instance_docker_id('mysql1')) +def mysql_client(): + docker_compose = os.path.join(SCRIPT_DIR, 'clients', 'mysql', 'docker_compose.yml') + subprocess.check_call(['docker-compose', '-p', cluster.project_name, '-f', docker_compose, 'up', '--no-recreate', '-d', '--build']) + yield docker.from_env().containers.get(cluster.project_name + '_mysql1_1') @pytest.fixture(scope='module') -def server_address(started_cluster): - yield started_cluster.get_instance_ip('node') +def golang_container(): + docker_compose = os.path.join(SCRIPT_DIR, 'clients', 'golang', 'docker_compose.yml') + subprocess.check_call(['docker-compose', '-p', cluster.project_name, '-f', docker_compose, 'up', '--no-recreate', '-d', '--build']) + yield docker.from_env().containers.get(cluster.project_name + '_golang1_1') -def test_select(mysql_container, server_address): +def test_mysql_client(mysql_client, server_address): # type: (Container, str) -> None - code, (stdout, stderr) = mysql_container.exec_run(''' + code, (stdout, stderr) = mysql_client.exec_run(''' mysql --protocol tcp -h {host} -P {port} default -u default --enable-cleartext-plugin --password=123 -e "select 1 as a;" -e "select 'тест' as b;" @@ -48,22 +52,14 @@ def test_select(mysql_container, server_address): assert stdout == 'a\n1\nb\nтест\n' - -def test_authentication(mysql_container, server_address): - # type: (Container, str) -> None - - code, (stdout, stderr) = mysql_container.exec_run(''' + code, (stdout, stderr) = mysql_client.exec_run(''' mysql --protocol tcp -h {host} -P {port} default -u default --enable-cleartext-plugin --password=abc -e "select 1 as a;" '''.format(host=server_address, port=server_port), demux=True) assert stderr == 'mysql: [Warning] Using a password on the command line interface can be insecure.\n' \ 'ERROR 193 (00000): Wrong password for user default\n' - -def test_change_database(mysql_container, server_address): - # type: (Container, str) -> None - - code, (stdout, stderr) = mysql_container.exec_run(''' + code, (stdout, stderr) = mysql_client.exec_run(''' mysql --protocol tcp -h {host} -P {port} default -u default --enable-cleartext-plugin --password=123 -e "use system;" -e "select count(*) from (select name from tables limit 1);" @@ -75,7 +71,7 @@ def test_change_database(mysql_container, server_address): "ERROR 81 (00000) at line 1: Database system2 doesn't exist\n" -def test_py_client(server_address): +def test_python_client(server_address): with pytest.raises(pymysql.InternalError) as exc_info: pymysql.connections.Connection(host=server_address, user='default', password='abacab', database='default', port=server_port) @@ -98,3 +94,21 @@ def test_py_client(server_address): client.select_db('system2') assert exc_info.value.args == (81, "Database system2 doesn't exist") + + +def test_golang_client(server_address, golang_container): + # type: (str, Container) -> None + code, (stdout, stderr) = golang_container.exec_run('./main --host {host} --port {port} --user default --password 123 --database ' + 'abc'.format(host=server_address, port=server_port), demux=True) + + assert code == 1 + assert stderr == "Error 81: Database abc doesn't exist\n" + + code, (stdout, stderr) = golang_container.exec_run('./main --host {host} --port {port} --user default --password 123 --database ' + 'default'.format(host=server_address, port=server_port), demux=True) + + assert code == 0 + + with open(os.path.join(SCRIPT_DIR, 'clients', 'golang', '0.reference')) as fp: + reference = fp.read() + assert stdout == reference From 5b6754a2be8800ae826e6b7bd9be174964b2c25b Mon Sep 17 00:00:00 2001 From: Yuriy Date: Sun, 7 Apr 2019 13:32:52 +0300 Subject: [PATCH 038/709] gofmt --- .../test_mysql_protocol/clients/golang/main.go | 15 +++++++-------- 1 file changed, 7 insertions(+), 8 deletions(-) diff --git a/dbms/tests/integration/test_mysql_protocol/clients/golang/main.go b/dbms/tests/integration/test_mysql_protocol/clients/golang/main.go index 93eab9d8568..ac3a34eb49f 100644 --- a/dbms/tests/integration/test_mysql_protocol/clients/golang/main.go +++ b/dbms/tests/integration/test_mysql_protocol/clients/golang/main.go @@ -9,7 +9,6 @@ import ( "os" ) - func main() { host := flag.String("host", "localhost", "mysql server address") port := flag.Uint("port", 3306, "mysql server port") @@ -20,14 +19,14 @@ func main() { logger := log.New(os.Stderr, "", 0) dataSource := fmt.Sprintf("%s:%s@tcp(%s:%d)/%s?allowCleartextPasswords=1", *user, *password, *host, *port, *database) - db, err := sql.Open("mysql", dataSource) - - if err != nil { + db, err := sql.Open("mysql", dataSource) + + if err != nil { logger.Fatal(err) - } + } defer db.Close() - runQuery := func (query string, processRows func (*sql.Rows)) { + runQuery := func(query string, processRows func(*sql.Rows)) { rows, err := db.Query(query) if err != nil { logger.Fatal(err) @@ -63,7 +62,7 @@ func main() { } } - processRows := func (rows *sql.Rows) { + processRows := func(rows *sql.Rows) { var x int for rows.Next() { err := rows.Scan(&x) @@ -75,7 +74,7 @@ func main() { } runQuery("select number as a from system.numbers limit 2", processRows) - processRows = func (rows *sql.Rows) { + processRows = func(rows *sql.Rows) { var name string var a int for rows.Next() { From 1dc5c4cba336b2bf3e4ee7219b296f8762522a95 Mon Sep 17 00:00:00 2001 From: Yuriy Date: Sun, 7 Apr 2019 15:33:06 +0300 Subject: [PATCH 039/709] explicitly defined constructors --- dbms/src/Core/MySQLProtocol.h | 12 ++++++++++++ 1 file changed, 12 insertions(+) diff --git a/dbms/src/Core/MySQLProtocol.h b/dbms/src/Core/MySQLProtocol.h index 488bf1f7e7a..f22aeaf35f5 100644 --- a/dbms/src/Core/MySQLProtocol.h +++ b/dbms/src/Core/MySQLProtocol.h @@ -301,6 +301,10 @@ public: String database; String auth_plugin_name; + HandshakeResponse() = default; + + HandshakeResponse(const HandshakeResponse &) = default; + void readPayload(String s) override { std::istringstream ss(s); @@ -368,6 +372,10 @@ class NullTerminatedString : public ReadPacket public: String value; + NullTerminatedString() = default; + + NullTerminatedString(const NullTerminatedString &) = default; + void readPayload(String s) override { if (s.length() == 0 || s.back() != 0) @@ -542,6 +550,10 @@ class ComFieldList : public ReadPacket public: String table, field_wildcard; + ComFieldList() = default; + + ComFieldList(const ComFieldList &) = default; + void readPayload(String payload) { std::istringstream ss(payload); From 2789a83c0336f7d815c0a2ced6a14f1c9cf6d92b Mon Sep 17 00:00:00 2001 From: Yuriy Date: Mon, 8 Apr 2019 10:03:04 +0300 Subject: [PATCH 040/709] fixed compilation with clang --- dbms/programs/server/MySQLHandler.cpp | 7 +++++-- dbms/src/Core/MySQLProtocol.h | 20 ++------------------ 2 files changed, 7 insertions(+), 20 deletions(-) diff --git a/dbms/programs/server/MySQLHandler.cpp b/dbms/programs/server/MySQLHandler.cpp index 4f760c0c67f..f7ad2cf7c1f 100644 --- a/dbms/programs/server/MySQLHandler.cpp +++ b/dbms/programs/server/MySQLHandler.cpp @@ -41,7 +41,8 @@ void MySQLHandler::run() LOG_TRACE(log, "Sent handshake"); - auto handshake_response = packet_sender.receivePacket(); + HandshakeResponse handshake_response; + packet_sender.receivePacket(handshake_response); LOG_DEBUG(log, "Capabilities: " << handshake_response.capability_flags << "\nmax_packet_size: " @@ -74,7 +75,9 @@ void MySQLHandler::run() { packet_sender.sendPacket(AuthSwitchRequest(Authentication::ClearText, ""), true); - password = packet_sender.receivePacket().value; + NullTerminatedString password_packet; + packet_sender.receivePacket(password_packet); + password = password_packet.value; } else { diff --git a/dbms/src/Core/MySQLProtocol.h b/dbms/src/Core/MySQLProtocol.h index f22aeaf35f5..c1cccd689b5 100644 --- a/dbms/src/Core/MySQLProtocol.h +++ b/dbms/src/Core/MySQLProtocol.h @@ -186,13 +186,9 @@ public: return std::move(buf.str()); } - template - T receivePacket() + void receivePacket(ReadPacket & packet) { - static_assert(std::is_base_of()); - T packet; - packet.readPayload(std::move(receivePacketPayload())); - return packet; + packet.readPayload(receivePacketPayload()); } template @@ -301,10 +297,6 @@ public: String database; String auth_plugin_name; - HandshakeResponse() = default; - - HandshakeResponse(const HandshakeResponse &) = default; - void readPayload(String s) override { std::istringstream ss(s); @@ -372,10 +364,6 @@ class NullTerminatedString : public ReadPacket public: String value; - NullTerminatedString() = default; - - NullTerminatedString(const NullTerminatedString &) = default; - void readPayload(String s) override { if (s.length() == 0 || s.back() != 0) @@ -550,10 +538,6 @@ class ComFieldList : public ReadPacket public: String table, field_wildcard; - ComFieldList() = default; - - ComFieldList(const ComFieldList &) = default; - void readPayload(String payload) { std::istringstream ss(payload); From e6f9616abb279a9f47a9b35b0e744b898020a212 Mon Sep 17 00:00:00 2001 From: Yuriy Date: Mon, 8 Apr 2019 11:49:21 +0300 Subject: [PATCH 041/709] more stable golang client test --- .../clients/golang/0.reference | 3 +-- .../clients/golang/main.go | 19 ++++++++++++------- 2 files changed, 13 insertions(+), 9 deletions(-) diff --git a/dbms/tests/integration/test_mysql_protocol/clients/golang/0.reference b/dbms/tests/integration/test_mysql_protocol/clients/golang/0.reference index d1414bf6562..a151cc2592e 100644 --- a/dbms/tests/integration/test_mysql_protocol/clients/golang/0.reference +++ b/dbms/tests/integration/test_mysql_protocol/clients/golang/0.reference @@ -12,8 +12,7 @@ Column types: name BINARY a BINARY Result: -aggregate_function_combinators 1 -asynchronous_metrics 1 +tables 1 Columns: a b diff --git a/dbms/tests/integration/test_mysql_protocol/clients/golang/main.go b/dbms/tests/integration/test_mysql_protocol/clients/golang/main.go index ac3a34eb49f..70508334afb 100644 --- a/dbms/tests/integration/test_mysql_protocol/clients/golang/main.go +++ b/dbms/tests/integration/test_mysql_protocol/clients/golang/main.go @@ -26,7 +26,7 @@ func main() { } defer db.Close() - runQuery := func(query string, processRows func(*sql.Rows)) { + runQuery := func(query string, processRows func(*sql.Rows) error) { rows, err := db.Query(query) if err != nil { logger.Fatal(err) @@ -45,7 +45,10 @@ func main() { } fmt.Println("Result:") - processRows(rows) + err = processRows(rows) + if err != nil { + logger.Fatal(err) + } err = rows.Err() if err != nil { @@ -62,30 +65,32 @@ func main() { } } - processRows := func(rows *sql.Rows) { + processRows := func(rows *sql.Rows) error { var x int for rows.Next() { err := rows.Scan(&x) if err != nil { - logger.Fatal(err) + return err } fmt.Println(x) } + return nil } runQuery("select number as a from system.numbers limit 2", processRows) - processRows = func(rows *sql.Rows) { + processRows = func(rows *sql.Rows) error { var name string var a int for rows.Next() { err := rows.Scan(&name, &a) if err != nil { - logger.Fatal(err) + return err } fmt.Println(name, a) } + return nil } - runQuery("select name, 1 as a from system.tables limit 2", processRows) + runQuery("select name, 1 as a from system.tables where name == 'tables'", processRows) runQuery("select 'тест' as a, 1 as b", processRows) From 35a266c96a9451336431b3de43806d58165fdaa0 Mon Sep 17 00:00:00 2001 From: Alexander Kozhikhov Date: Tue, 9 Apr 2019 00:01:10 +0300 Subject: [PATCH 042/709] linear regression tests --- .../AggregateFunctionMLMethod.cpp | 53 +- .../AggregateFunctionMLMethod.h | 202 ++---- .../0_stateless/00950_ml_test.reference | 302 +-------- .../queries/0_stateless/00950_ml_test.sql | 8 +- .../0_stateless/00951_ml_test.reference | 96 +-- .../queries/0_stateless/00951_ml_test.sql | 7 +- .../queries/0_stateless/00952_ml_test.sql | 2 +- .../0_stateless/00953_dataset_test.reference | 1 + ...955_ml_test.sql => 00953_dataset_test.sql} | 6 +- .../0_stateless/00953_ml_test.good_reference | 580 ------------------ .../0_stateless/00953_ml_test.reference | 580 ------------------ .../00953_ml_test.rock_auc_reference | 1 - .../queries/0_stateless/00953_ml_test.sql | 25 - .../0_stateless/00954_ml_test.reference | 2 +- .../queries/0_stateless/00954_ml_test.sql | 6 +- .../0_stateless/00955_ml_test.reference | 1 - .../0_stateless/00960_dataset_test.sql | 22 - 17 files changed, 89 insertions(+), 1805 deletions(-) create mode 100644 dbms/tests/queries/0_stateless/00953_dataset_test.reference rename dbms/tests/queries/0_stateless/{00955_ml_test.sql => 00953_dataset_test.sql} (97%) delete mode 100644 dbms/tests/queries/0_stateless/00953_ml_test.good_reference delete mode 100644 dbms/tests/queries/0_stateless/00953_ml_test.reference delete mode 100644 dbms/tests/queries/0_stateless/00953_ml_test.rock_auc_reference delete mode 100644 dbms/tests/queries/0_stateless/00953_ml_test.sql delete mode 100644 dbms/tests/queries/0_stateless/00955_ml_test.reference delete mode 100644 dbms/tests/queries/0_stateless/00960_dataset_test.sql diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp index bd3aa51c2e2..7a4d5d731d2 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp @@ -19,6 +19,9 @@ AggregateFunctionPtr createAggregateFunctionMLMethod( if (parameters.size() > 4) throw Exception("Aggregate function " + name + " requires at most four parameters", ErrorCodes::NUMBER_OF_ARGUMENTS_DOESNT_MATCH); + if (argument_types.size() < 2) + throw Exception("Aggregate function " + name + " requires at least two arguments", ErrorCodes::NUMBER_OF_ARGUMENTS_DOESNT_MATCH); + for (size_t i = 0; i < argument_types.size(); ++i) { if (!WhichDataType(argument_types[i]).isFloat64()) @@ -28,58 +31,58 @@ AggregateFunctionPtr createAggregateFunctionMLMethod( } Float64 learning_rate = Float64(0.01); + Float64 l2_reg_coef = Float64(0.01); UInt32 batch_size = 1; - std::shared_ptr gc; std::shared_ptr wu; + std::shared_ptr gc; + if (!parameters.empty()) { learning_rate = applyVisitor(FieldVisitorConvertToNumber(), parameters[0]); } if (parameters.size() > 1) { - batch_size = applyVisitor(FieldVisitorConvertToNumber(), parameters[1]); - - } - - if (std::is_same::value) - { - gc = std::make_shared(); - } else if (std::is_same::value) - { - gc = std::make_shared(); - } else - { - throw Exception("Such gradient computer is not implemented yet", ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT); + l2_reg_coef = applyVisitor(FieldVisitorConvertToNumber(), parameters[1]); } if (parameters.size() > 2) { - if (applyVisitor(FieldVisitorConvertToNumber(), parameters[2]) == Float64{1.0}) + batch_size = applyVisitor(FieldVisitorConvertToNumber(), parameters[2]); + + } + if (parameters.size() > 3) + { + if (applyVisitor(FieldVisitorConvertToNumber(), parameters[3]) == Float64{1.0}) { wu = std::make_shared(); - } else if (applyVisitor(FieldVisitorConvertToNumber(), parameters[2]) == Float64{2.0}) + } else if (applyVisitor(FieldVisitorConvertToNumber(), parameters[3]) == Float64{2.0}) { wu = std::make_shared(); - } else if (applyVisitor(FieldVisitorConvertToNumber(), parameters[2]) == Float64{3.0}) + } else if (applyVisitor(FieldVisitorConvertToNumber(), parameters[3]) == Float64{3.0}) { wu = std::make_shared(); - } else if (applyVisitor(FieldVisitorConvertToNumber(), parameters[2]) == Float64{4.0}) - { - /// Adam should be here - wu = std::make_shared(); } else { - throw Exception("Such weights updater is not implemented yet", ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT); + throw Exception("Invalid parameter for weights updater", ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT); } } else { wu = std::make_unique(); } - if (argument_types.size() < 2) - throw Exception("Aggregate function " + name + " requires at least two arguments", ErrorCodes::NUMBER_OF_ARGUMENTS_DOESNT_MATCH); + if (std::is_same::value) + { + gc = std::make_shared(); + } else if (std::is_same::value) + { + gc = std::make_shared(); + } else + { + throw Exception("Such gradient computer is not implemented yet", ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT); + } - return std::make_shared(argument_types.size() - 1, gc, wu, learning_rate, batch_size, argument_types, parameters); + + return std::make_shared(argument_types.size() - 1, gc, wu, learning_rate, l2_reg_coef, batch_size, argument_types, parameters); } } diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h index 6bceb2ee8a8..f17572a5928 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h @@ -28,8 +28,7 @@ namespace ErrorCodes } /** -IGradientComputer class computes gradient according to its loss function -and stores mini-batch +GradientComputer class computes gradient according to its loss function */ class IGradientComputer { @@ -39,16 +38,12 @@ public: virtual ~IGradientComputer() = default; - /// Adds to batch_gradient computed gradient in point (weigts, bias) using corresponding loss function + /// Adds computed gradient in new point (weights, bias) to batch_gradient virtual void compute(std::vector * batch_gradient, const std::vector &weights, Float64 bias, - Float64 learning_rate, Float64 target, const IColumn **columns, size_t row_num) = 0; + Float64 learning_rate, Float64 l2_reg_coef, Float64 target, const IColumn **columns, size_t row_num) = 0; - virtual Float64 predict(const std::vector &predict_feature, - const std::vector &weights, - Float64 bias) const = 0; - - /// Now we should use predict_for_all function instead of predict - virtual void predict_for_all(ColumnVector::Container &container, + /// Now we should use predict_block function instead of predict + virtual void predict_block(ColumnVector::Container &container, Block &block, const ColumnNumbers &arguments, const std::vector &weights, Float64 bias) const = 0; @@ -62,7 +57,7 @@ public: {} void compute(std::vector * batch_gradient, const std::vector &weights, Float64 bias, - Float64 learning_rate, Float64 target, const IColumn **columns, size_t row_num) override + Float64 learning_rate, Float64 l2_reg_coef, Float64 target, const IColumn **columns, size_t row_num) override { Float64 derivative = (target - bias); for (size_t i = 0; i < weights.size(); ++i) @@ -75,27 +70,12 @@ public: for (size_t i = 0; i < weights.size(); ++i) { (*batch_gradient)[i] += - derivative * static_cast &>(*columns[i]).getData()[row_num]; + derivative * static_cast &>(*columns[i]).getData()[row_num] + - 2 * l2_reg_coef * weights[i]; } } - Float64 predict(const std::vector &predict_feature, - const std::vector &weights, Float64 bias) const override - { - /// не обновляем веса при предикте, т.к. это может замедлить предсказание - /// однако можно например обновлять их при каждом мердже не зависимо от того, сколько элементнов в батче - - Float64 res{0.0}; - for (size_t i = 0; i < predict_feature.size(); ++i) - { - res += predict_feature[i] * weights[i]; - } - res += bias; - - return res; - } - - void predict_for_all(ColumnVector::Container &container, + void predict_block(ColumnVector::Container &container, Block &block, const ColumnNumbers &arguments, const std::vector &weights, Float64 bias) const override @@ -133,7 +113,7 @@ public: {} void compute(std::vector * batch_gradient, const std::vector &weights, Float64 bias, - Float64 learning_rate, Float64 target, const IColumn **columns, size_t row_num) override + Float64 learning_rate, Float64 l2_reg_coef, Float64 target, const IColumn **columns, size_t row_num) override { Float64 derivative = bias; for (size_t i = 0; i < weights.size(); ++i) @@ -148,28 +128,12 @@ public: { (*batch_gradient)[i] += learning_rate * target * - static_cast &>(*columns[i]).getData()[row_num] - / (derivative + 1); + static_cast &>(*columns[i]).getData()[row_num] / (derivative + 1) + - 2 * l2_reg_coef * weights[i]; } } - Float64 predict(const std::vector &predict_feature, - const std::vector &weights, Float64 bias) const override - { - /// не обновляем веса при предикте, т.к. это может замедлить предсказание - /// однако можно например обновлять их при каждом мердже не зависимо от того, сколько элементнов в батче - - Float64 res{0.0}; - for (size_t i = 0; i < predict_feature.size(); ++i) - { - res += predict_feature[i] * weights[i]; - } - res += bias; - res = 1 / (1 + exp(-res)); - return res; - } - - void predict_for_all(ColumnVector::Container & container, + void predict_block(ColumnVector::Container & container, Block & block, const ColumnNumbers & arguments, const std::vector & weights, Float64 bias) const override @@ -199,8 +163,8 @@ public: /** -* IWeightsUpdater class defines the way to update current state -* and uses GradientComputer on each iteration +* IWeightsUpdater class defines the way to update current weights +* and uses class GradientComputer on each iteration */ class IWeightsUpdater { @@ -209,9 +173,9 @@ public: virtual void add_to_batch(std::vector * batch_gradient, std::shared_ptr gc, const std::vector & weights, Float64 bias, - Float64 learning_rate, Float64 target, const IColumn **columns, size_t row_num) + Float64 learning_rate, Float64 l2_reg_coef, Float64 target, const IColumn **columns, size_t row_num) { - gc->compute(batch_gradient, weights, bias, learning_rate, target, columns, row_num); + gc->compute(batch_gradient, weights, bias, learning_rate, l2_reg_coef, target, columns, row_num); } virtual void update(UInt32 batch_size, @@ -313,7 +277,7 @@ public: void add_to_batch(std::vector * batch_gradient, std::shared_ptr gc, const std::vector & weights, Float64 bias, - Float64 learning_rate, Float64 target, const IColumn ** columns, size_t row_num) override + Float64 learning_rate, Float64 l2_reg_coef, Float64 target, const IColumn ** columns, size_t row_num) override { if (accumulated_gradient.empty()) { @@ -327,7 +291,7 @@ public: } auto shifted_bias = bias + accumulated_gradient[weights.size()] * alpha_; - gc->compute(batch_gradient, shifted_weights, shifted_bias, learning_rate, target, columns, row_num); + gc->compute(batch_gradient, shifted_weights, shifted_bias, learning_rate, l2_reg_coef, target, columns, row_num); } void update(UInt32 batch_size, @@ -376,75 +340,8 @@ private: }; -// TODO: проверить после изменения логики моментума -/* -class Adam : public IWeightsUpdater -{ -public: - Adam() - {} - - Adam(Float64 betta1, Float64 betta2) : betta1_(betta1), betta2_(betta2), betta1t_(betta1), betta2t_(betta2) - {} - - void update(UInt32 cur_batch, - std::vector & weights, Float64 & bias, - std::vector * batch_gradient) override - { - if (mt_.size() == 0) - { - mt_.resize(batch_gradient.size(), Float64{0.0}); - vt_.resize(batch_gradient.size(), Float64{0.0}); - } - Float64 eps = 0.01; - for (size_t i = 0; i < batch_gradient.size(); ++i) - { - mt_[i] = mt_[i] * betta1_ + (1 - betta1_) * batch_gradient[i]; - vt_[i] = vt_[i] * betta2_ + (1 - betta2_) * batch_gradient[i] * batch_gradient[i]; - if (t < 8) - { - mt_[i] = mt_[i] / (1 - betta1t_); - betta1t_ *= betta1_; - } - if (t < 850) - { - vt_[i] = vt_[i] / (1 - betta2t_); - betta2t_ *= betta2_; - } - } - for (size_t i = 0; i < weights.size(); ++i) - { - weights[i] += (mt_[i] / (sqrt(vt_[i] + eps))) / cur_batch; - } - bias += (mt_[weights.size()] / (sqrt(vt_[weights.size()] + eps))) / cur_batch; - t += 1; - } - - virtual void merge(const IWeightsUpdater &rhs, Float64 frac, Float64 rhs_frac) override - { - auto &adam_rhs = static_cast(rhs); - for (size_t i = 0; i < mt_.size(); ++i) - { - mt_[i] = mt_[i] * frac + adam_rhs.mt_[i] * rhs_frac; - vt_[i] = vt_[i] * frac + adam_rhs.vt_[i] * rhs_frac; - } - } - -private: - Float64 betta1_{0.2}; - Float64 betta2_{0.3}; - Float64 betta1t_{0.3}; - Float64 betta2t_{0.3}; - UInt32 t = 0; - std::vector mt_; - std::vector vt_; -}; - */ - - /** * LinearModelData is a class which manages current state of learning -* and is stored as AggregateFunctionState */ class LinearModelData { @@ -453,11 +350,13 @@ public: {} LinearModelData(Float64 learning_rate, + Float64 l2_reg_coef, UInt32 param_num, UInt32 batch_capacity, std::shared_ptr gc, std::shared_ptr wu) : learning_rate(learning_rate), + l2_reg_coef(l2_reg_coef), batch_capacity(batch_capacity), batch_size(0), gradient_computer(std::move(gc)), @@ -474,7 +373,7 @@ public: /// Here we have columns + 1 as first column corresponds to target value, and others - to features weights_updater->add_to_batch(&gradient_batch, gradient_computer, - weights, bias, learning_rate, target, columns + 1, row_num); + weights, bias, learning_rate, l2_reg_coef, target, columns + 1, row_num); ++batch_size; if (batch_size == batch_capacity) @@ -489,20 +388,18 @@ public: return; update_state(); - /// нельзя обновить из-за константости -// rhs.update_weights(); + /// can't update rhs state because it's constant - Float64 frac = static_cast(iter_num) / (iter_num + rhs.iter_num); - Float64 rhs_frac = static_cast(rhs.iter_num) / (iter_num + rhs.iter_num); + Float64 frac = (static_cast(iter_num) * iter_num) / (iter_num * iter_num + rhs.iter_num * rhs.iter_num); for (size_t i = 0; i < weights.size(); ++i) { - weights[i] = weights[i] * frac + rhs.weights[i] * rhs_frac; + weights[i] = weights[i] * frac + rhs.weights[i] * (1 - frac); } + bias = bias * frac + rhs.bias * (1 - frac); - bias = bias * frac + rhs.bias * rhs_frac; iter_num += rhs.iter_num; - weights_updater->merge(*rhs.weights_updater, frac, rhs_frac); + weights_updater->merge(*rhs.weights_updater, frac, 1 - frac); } void write(WriteBuffer &buf) const @@ -525,21 +422,9 @@ public: weights_updater->read(buf); } - Float64 predict(const std::vector &predict_feature) const + void predict_block(ColumnVector::Container &container, Block &block, const ColumnNumbers &arguments) const { - /// не обновляем веса при предикте, т.к. это может замедлить предсказание - /// однако можно например обновлять их при каждом мердже независимо от того, сколько элементнов в батче -// if (cur_batch) -// { -// update_weights(); -// } - - return gradient_computer->predict(predict_feature, weights, bias); - } - - void predict_for_all(ColumnVector::Container &container, Block &block, const ColumnNumbers &arguments) const - { - gradient_computer->predict_for_all(container, block, arguments, weights, bias); + gradient_computer->predict_block(container, block, arguments, weights, bias); } private: @@ -547,6 +432,7 @@ private: Float64 bias{0.0}; Float64 learning_rate; + Float64 l2_reg_coef; UInt32 batch_capacity; UInt32 iter_num = 0; @@ -557,8 +443,8 @@ private: std::shared_ptr weights_updater; /** - * The function is called when we want to flush current batch and make a step with it - */ + * The function is called when we want to flush current batch and update our weights + */ void update_state() { if (batch_size == 0) @@ -587,12 +473,14 @@ public: std::shared_ptr gradient_computer, std::shared_ptr weights_updater, Float64 learning_rate, + Float64 l2_reg_coef, UInt32 batch_size, const DataTypes & argument_types, const Array & params) : IAggregateFunctionDataHelper>(argument_types, params), param_num(param_num), learning_rate(learning_rate), + l2_reg_coef(l2_reg_coef), batch_size(batch_size), gc(std::move(gradient_computer)), wu(std::move(weights_updater)) { @@ -605,7 +493,7 @@ public: void create(AggregateDataPtr place) const override { - new (place) Data(learning_rate, param_num, batch_size, gc, wu); + new (place) Data(learning_rate, l2_reg_coef, param_num, batch_size, gc, wu); } void add(AggregateDataPtr place, const IColumn ** columns, size_t row_num, Arena *) const override @@ -613,10 +501,8 @@ public: this->data(place).add(columns, row_num); } - /// хочется не константный rhs void merge(AggregateDataPtr place, ConstAggregateDataPtr rhs, Arena *) const override { - std::cout << "\nMERGING!!\n\n"; this->data(place).merge(this->data(rhs)); } @@ -632,8 +518,6 @@ public: void predictResultInto(ConstAggregateDataPtr place, IColumn & to, Block & block, const ColumnNumbers & arguments) const { - std::cout << "\nPREDICTING!!\n\n"; - if (arguments.size() != param_num + 1) throw Exception("Predict got incorrect number of arguments. Got: " + std::to_string(arguments.size()) + ". Required: " + std::to_string(param_num + 1), @@ -641,20 +525,7 @@ public: auto &column = dynamic_cast &>(to); - /// Так делали с одним предиктом, пока пусть побудет тут -// std::vector predict_features(arguments.size() - 1); -// for (size_t i = 1; i < arguments.size(); ++i) -// { -// const auto& element = (*block.getByPosition(arguments[i]).column)[row_num]; -// if (element.getType() != Field::Types::Float64) -// throw Exception("Prediction arguments must be values of type Float", -// ErrorCodes::BAD_ARGUMENTS); -// -//// predict_features[i - 1] = element.get(); -// } -// column.getData().push_back(this->data(place).predict(predict_features)); -// column.getData().push_back(this->data(place).predict_for_all()); - this->data(place).predict_for_all(column.getData(), block, arguments); + this->data(place).predict_block(column.getData(), block, arguments); } void insertResultInto(ConstAggregateDataPtr place, IColumn & to) const override @@ -669,6 +540,7 @@ public: private: UInt32 param_num; Float64 learning_rate; + Float64 l2_reg_coef; UInt32 batch_size; std::shared_ptr gc; std::shared_ptr wu; diff --git a/dbms/tests/queries/0_stateless/00950_ml_test.reference b/dbms/tests/queries/0_stateless/00950_ml_test.reference index 6326f98fcd1..6ed281c757a 100644 --- a/dbms/tests/queries/0_stateless/00950_ml_test.reference +++ b/dbms/tests/queries/0_stateless/00950_ml_test.reference @@ -1,300 +1,2 @@ --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 --67.00423606399804 +1 +1 diff --git a/dbms/tests/queries/0_stateless/00950_ml_test.sql b/dbms/tests/queries/0_stateless/00950_ml_test.sql index 0a009c29d29..b6a02893840 100644 --- a/dbms/tests/queries/0_stateless/00950_ml_test.sql +++ b/dbms/tests/queries/0_stateless/00950_ml_test.sql @@ -8,10 +8,10 @@ CREATE TABLE IF NOT EXISTS test.defaults predict1 Float64, predict2 Float64 ) ENGINE = Memory; -insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0), (-1.099, 2.755, -3.060, 20.0, 40.0), (1.090, 2.945, -2.346, 20.0, 40.0), (0.305, 2.179, -1.205, 20.0, 40.0), (-0.925, 0.702, 1.134, 20.0, 40.0), (3.178, -1.316, 7.221, 20.0, 40.0), (-2.756, -0.473, 2.569, 20.0, 40.0), (3.665, 2.303, 0.226, 20.0, 40.0), (1.662, 1.951, -0.070, 20.0, 40.0), (2.869, 0.593, 3.249, 20.0, 40.0), (0.818, -0.593, 4.594, 20.0, 40.0), (-1.917, 0.916, 0.209, 20.0, 40.0), (2.706, 1.523, 1.307, 20.0, 40.0), (0.219, 2.162, -1.214, 20.0, 40.0), (-4.510, 1.376, -2.007, 20.0, 40.0), (4.284, -0.515, 6.173, 20.0, 40.0), (-1.101, 2.810, -3.170, 20.0, 40.0), (-1.810, -1.117, 4.329, 20.0, 40.0), (0.055, 1.115, 0.797, 20.0, 40.0), (-2.178, 2.904, -3.898, 20.0, 40.0), (-3.494, -1.814, 4.882, 20.0, 40.0), (3.027, 0.476, 3.562, 20.0, 40.0), (-1.434, 1.151, -0.018, 20.0, 40.0), (1.180, 0.992, 1.606, 20.0, 40.0), (0.015, 0.971, 1.067, 20.0, 40.0), (-0.511, -0.875, 4.495, 20.0, 40.0), (0.961, 2.348, -1.216, 20.0, 40.0), (-2.279, 0.038, 1.785, 20.0, 40.0), (-1.568, -0.248, 2.712, 20.0, 40.0), (-0.496, 0.366, 2.020, 20.0, 40.0), (1.177, -1.401, 6.390, 20.0, 40.0), (2.882, -1.442, 7.325, 20.0, 40.0), (-1.066, 1.817, -1.167, 20.0, 40.0), (-2.144, 2.791, -3.655, 20.0, 40.0), (-4.370, 2.228, -3.642, 20.0, 40.0), (3.996, 2.775, -0.553, 20.0, 40.0), (0.289, 2.055, -0.965, 20.0, 40.0), (-0.588, -1.601, 5.908, 20.0, 40.0), (-1.801, 0.417, 1.265, 20.0, 40.0), (4.375, -1.499, 8.186, 20.0, 40.0), (-2.618, 0.038, 1.615, 20.0, 40.0), (3.616, -0.833, 6.475, 20.0, 40.0), (-4.045, -1.558, 4.094, 20.0, 40.0), (-3.962, 0.636, -0.253, 20.0, 40.0), (3.505, 2.625, -0.497, 20.0, 40.0), (3.029, -0.523, 5.560, 20.0, 40.0), (-3.520, -0.474, 2.188, 20.0, 40.0), (2.430, -1.469, 7.154, 20.0, 40.0), (1.547, -1.654, 7.082, 20.0, 40.0), (-1.370, 0.575, 1.165, 20.0, 40.0), (-1.869, -1.555, 5.176, 20.0, 40.0), (3.536, 2.841, -0.913, 20.0, 40.0), (-3.810, 1.220, -1.344, 20.0, 40.0), (-1.971, 1.462, -0.910, 20.0, 40.0), (-0.243, 0.167, 2.545, 20.0, 40.0), (-1.403, 2.645, -2.991, 20.0, 40.0), (0.532, -0.114, 3.494, 20.0, 40.0), (-1.678, 0.975, 0.212, 20.0, 40.0), (-0.656, 2.140, -1.609, 20.0, 40.0), (1.743, 2.631, -1.390, 20.0, 40.0), (2.586, 2.943, -1.593, 20.0, 40.0), (-0.512, 2.969, -3.195, 20.0, 40.0), (2.283, -0.100, 4.342, 20.0, 40.0), (-4.293, 0.872, -0.890, 20.0, 40.0), (3.411, 1.300, 2.106, 20.0, 40.0), (-0.281, 2.951, -3.042, 20.0, 40.0), (-4.442, 0.384, 0.012, 20.0, 40.0), (1.194, 1.746, 0.104, 20.0, 40.0), (-1.152, 1.862, -1.300, 20.0, 40.0), (1.362, -1.341, 6.363, 20.0, 40.0), (-4.488, 2.618, -4.481, 20.0, 40.0), (3.419, -0.564, 5.837, 20.0, 40.0), (-3.392, 0.396, 0.512, 20.0, 40.0), (-1.629, -0.909, 4.003, 20.0, 40.0), (4.447, -1.088, 7.399, 20.0, 40.0), (-1.232, 1.699, -1.014, 20.0, 40.0), (-1.286, -0.609, 3.575, 20.0, 40.0), (2.437, 2.796, -1.374, 20.0, 40.0), (-4.864, 1.989, -3.410, 20.0, 40.0), (-1.716, -1.399, 4.940, 20.0, 40.0), (-3.084, 1.858, -2.259, 20.0, 40.0), (2.828, -0.319, 5.053, 20.0, 40.0), (-1.226, 2.586, -2.786, 20.0, 40.0), (2.456, 0.092, 4.044, 20.0, 40.0), (-0.989, 2.375, -2.245, 20.0, 40.0), (3.268, 0.935, 2.765, 20.0, 40.0), (-4.128, -1.995, 4.927, 20.0, 40.0), (-1.083, 2.197, -1.935, 20.0, 40.0), (-3.471, -1.198, 3.660, 20.0, 40.0), (4.617, -1.136, 7.579, 20.0, 40.0), (2.054, -1.675, 7.378, 20.0, 40.0), (4.106, 2.326, 0.402, 20.0, 40.0), (1.558, 0.310, 3.158, 20.0, 40.0), (0.792, 0.900, 1.596, 20.0, 40.0), (-3.229, 0.300, 0.785, 20.0, 40.0), (3.787, -0.793, 6.479, 20.0, 40.0), (1.786, 2.288, -0.684, 20.0, 40.0), (2.643, 0.223, 3.875, 20.0, 40.0), (-3.592, 2.122, -3.040, 20.0, 40.0), (4.519, -1.760, 8.779, 20.0, 40.0), (3.221, 2.255, 0.101, 20.0, 40.0), (4.151, 1.788, 1.500, 20.0, 40.0), (-1.033, -1.195, 4.874, 20.0, 40.0), (-1.636, -1.037, 4.257, 20.0, 40.0), (-3.548, 1.911, -2.596, 20.0, 40.0), (4.829, -0.293, 6.001, 20.0, 40.0), (-4.684, -1.664, 3.986, 20.0, 40.0), (4.531, -0.503, 6.271, 20.0, 40.0), (-3.503, -1.606, 4.460, 20.0, 40.0), (-2.036, -1.522, 5.027, 20.0, 40.0), (-0.473, -0.617, 3.997, 20.0, 40.0), (-1.554, -1.630, 5.483, 20.0, 40.0), (-3.567, -1.043, 3.302, 20.0, 40.0), (-2.038, 0.579, 0.823, 20.0, 40.0), (-3.040, 0.857, -0.233, 20.0, 40.0), (4.610, 0.562, 4.181, 20.0, 40.0), (-3.323, -1.938, 5.215, 20.0, 40.0), (4.314, 1.720, 1.717, 20.0, 40.0), (-1.220, 0.615, 1.161, 20.0, 40.0), (-2.556, 1.120, -0.519, 20.0, 40.0), (-3.717, -0.108, 1.358, 20.0, 40.0), (4.689, -1.826, 8.996, 20.0, 40.0), (3.452, 0.506, 3.713, 20.0, 40.0), (2.472, 0.612, 3.012, 20.0, 40.0), (3.452, 0.450, 3.826, 20.0, 40.0), (1.207, 2.585, -1.567, 20.0, 40.0), (-4.826, 1.090, -1.593, 20.0, 40.0), (3.116, -1.118, 6.794, 20.0, 40.0), (0.448, 2.732, -2.240, 20.0, 40.0), (-1.096, -0.525, 3.503, 20.0, 40.0), (-4.680, -0.238, 1.137, 20.0, 40.0), (2.552, -1.403, 7.082, 20.0, 40.0), (0.719, 2.997, -2.635, 20.0, 40.0), (0.347, -1.966, 7.105, 20.0, 40.0), (2.958, -0.404, 5.288, 20.0, 40.0), (0.722, -1.950, 7.261, 20.0, 40.0), (-2.851, -0.986, 3.546, 20.0, 40.0), (-4.316, -0.439, 1.721, 20.0, 40.0), (-1.685, -0.201, 2.560, 20.0, 40.0), (1.856, 0.190, 3.549, 20.0, 40.0), (-2.052, 0.206, 1.562, 20.0, 40.0), (-2.504, -0.646, 3.041, 20.0, 40.0), (3.235, 0.882, 2.854, 20.0, 40.0), (-1.366, -1.573, 5.463, 20.0, 40.0), (-3.447, 2.419, -3.562, 20.0, 40.0), (4.155, 2.092, 0.893, 20.0, 40.0), (-0.935, 0.209, 2.116, 20.0, 40.0), (3.117, -1.821, 8.201, 20.0, 40.0), (3.759, 0.577, 3.725, 20.0, 40.0), (-0.938, 2.992, -3.453, 20.0, 40.0), (-0.525, 2.341, -1.945, 20.0, 40.0), (4.540, 2.625, 0.019, 20.0, 40.0), (-2.097, 1.190, -0.429, 20.0, 40.0), (-2.672, 1.983, -2.302, 20.0, 40.0), (-3.038, -1.490, 4.460, 20.0, 40.0), (-0.943, 2.149, -1.770, 20.0, 40.0), (0.739, 1.598, 0.174, 20.0, 40.0), (1.828, 1.853, 0.208, 20.0, 40.0), (4.856, 0.137, 5.153, 20.0, 40.0), (-1.617, 0.468, 1.255, 20.0, 40.0), (-1.972, 2.053, -2.092, 20.0, 40.0), (-4.633, 1.389, -2.094, 20.0, 40.0), (-3.628, -1.156, 3.498, 20.0, 40.0), (3.597, 1.034, 2.731, 20.0, 40.0), (-1.488, -0.002, 2.261, 20.0, 40.0), (0.749, 1.921, -0.468, 20.0, 40.0), (1.304, -1.371, 6.394, 20.0, 40.0), (4.587, 2.936, -0.579, 20.0, 40.0), (-2.241, 1.791, -1.703, 20.0, 40.0), (-2.945, 1.372, -1.216, 20.0, 40.0), (1.375, 0.395, 2.898, 20.0, 40.0), (-1.281, -0.641, 3.642, 20.0, 40.0), (2.178, 0.895, 2.299, 20.0, 40.0), (3.031, -0.786, 6.087, 20.0, 40.0), (-1.385, -0.375, 3.058, 20.0, 40.0), (4.041, -0.431, 5.882, 20.0, 40.0), (0.480, -0.507, 4.254, 20.0, 40.0), (-3.797, 0.140, 0.822, 20.0, 40.0), (2.355, 2.502, -0.827, 20.0, 40.0), (1.376, -1.583, 6.854, 20.0, 40.0), (0.164, 1.405, 0.273, 20.0, 40.0), (-1.273, 1.471, -0.579, 20.0, 40.0), (0.770, 2.246, -1.107, 20.0, 40.0), (4.552, 2.904, -0.533, 20.0, 40.0), (4.259, -1.772, 8.674, 20.0, 40.0), (-0.309, 1.159, 0.528, 20.0, 40.0), (3.581, 2.700, -0.610, 20.0, 40.0), (-3.202, 0.346, 0.707, 20.0, 40.0), (-1.575, 1.242, -0.271, 20.0, 40.0), (-1.584, -0.493, 3.194, 20.0, 40.0), (-3.778, 0.150, 0.810, 20.0, 40.0), (-4.675, 1.749, -2.835, 20.0, 40.0), (3.567, -0.792, 6.367, 20.0, 40.0), (-0.417, 1.399, -0.006, 20.0, 40.0), (-4.672, 2.007, -3.349, 20.0, 40.0), (-1.034, 0.196, 2.090, 20.0, 40.0), (-3.796, 2.496, -3.890, 20.0, 40.0), (3.532, -0.497, 5.759, 20.0, 40.0), (4.868, -1.359, 8.151, 20.0, 40.0), (-0.769, 0.302, 2.011, 20.0, 40.0), (4.475, 2.612, 0.014, 20.0, 40.0), (-3.532, -0.395, 2.024, 20.0, 40.0), (0.322, 0.675, 1.812, 20.0, 40.0), (-2.028, -1.942, 5.870, 20.0, 40.0), (1.810, -1.244, 6.392, 20.0, 40.0), (-0.783, 1.242, 0.124, 20.0, 40.0), (-4.745, -1.300, 3.227, 20.0, 40.0), (1.902, 1.973, 0.005, 20.0, 40.0), (-3.453, -1.429, 4.132, 20.0, 40.0), (1.559, 0.986, 1.808, 20.0, 40.0), (0.128, 2.754, -2.443, 20.0, 40.0), (2.759, 1.727, 0.926, 20.0, 40.0), (-4.468, 1.690, -2.614, 20.0, 40.0), (-2.368, -1.922, 5.659, 20.0, 40.0), (-2.766, 2.128, -2.640, 20.0, 40.0), (0.967, -1.825, 7.133, 20.0, 40.0), (-2.854, 2.855, -4.136, 20.0, 40.0), (-2.944, 1.875, -2.222, 20.0, 40.0), (-2.632, -0.983, 3.649, 20.0, 40.0), (2.427, 2.239, -0.266, 20.0, 40.0), (-1.726, -0.838, 3.812, 20.0, 40.0), (0.007, -0.903, 4.809, 20.0, 40.0), (-2.013, 1.092, -0.191, 20.0, 40.0), (-0.449, 0.970, 0.836, 20.0, 40.0), (1.396, 0.411, 2.876, 20.0, 40.0), (-1.115, -1.790, 6.023, 20.0, 40.0), (3.748, 1.917, 1.039, 20.0, 40.0), (2.978, 1.043, 2.404, 20.0, 40.0), (-3.969, 2.514, -4.013, 20.0, 40.0), (4.455, -0.050, 5.328, 20.0, 40.0), (-3.065, -0.846, 3.160, 20.0, 40.0), (-1.069, 2.167, -1.869, 20.0, 40.0), (3.016, -1.393, 7.294, 20.0, 40.0), (0.045, -1.928, 6.879, 20.0, 40.0), (-2.555, -0.984, 3.690, 20.0, 40.0), (-1.995, -0.054, 2.111, 20.0, 40.0), (4.600, -0.509, 6.318, 20.0, 40.0), (-1.942, 1.215, -0.402, 20.0, 40.0), (1.262, 2.765, -1.899, 20.0, 40.0), (2.617, -1.106, 6.521, 20.0, 40.0), (1.737, 0.554, 2.761, 20.0, 40.0), (-2.197, 0.632, 0.638, 20.0, 40.0), (4.768, 2.618, 0.147, 20.0, 40.0), (-3.737, -0.939, 3.010, 20.0, 40.0), (-2.623, 0.595, 0.499, 20.0, 40.0), (4.752, -0.340, 6.057, 20.0, 40.0), (2.333, -1.037, 6.240, 20.0, 40.0), (4.234, -1.882, 8.881, 20.0, 40.0), (-3.393, -0.812, 2.927, 20.0, 40.0), (0.885, 1.383, 0.678, 20.0, 40.0), (0.123, 2.937, -2.812, 20.0, 40.0), (2.969, 0.760, 2.964, 20.0, 40.0), (-4.929, 1.251, -1.967, 20.0, 40.0), (1.916, 2.223, -0.488, 20.0, 40.0), (-0.020, -1.740, 6.469, 20.0, 40.0), (0.702, -1.272, 5.895, 20.0, 40.0), (2.496, 2.648, -1.048, 20.0, 40.0), (4.067, -1.475, 7.984, 20.0, 40.0), (-3.717, 1.851, -2.561, 20.0, 40.0), (1.678, -0.624, 5.088, 20.0, 40.0), (1.073, 0.695, 2.146, 20.0, 40.0), (1.842, -0.749, 5.419, 20.0, 40.0), (-3.518, 1.909, -2.578, 20.0, 40.0), (2.229, 1.189, 1.737, 20.0, 40.0), (4.987, 2.893, -0.292, 20.0, 40.0), (-4.809, 1.043, -1.490, 20.0, 40.0), (-0.241, -0.728, 4.334, 20.0, 40.0), (-3.331, 0.590, 0.156, 20.0, 40.0), (-0.455, 2.621, -2.470, 20.0, 40.0), (1.492, 1.223, 1.301, 20.0, 40.0), (3.948, 2.841, -0.709, 20.0, 40.0), (0.732, 0.446, 2.475, 20.0, 40.0), (2.400, 2.390, -0.579, 20.0, 40.0), (-2.718, 1.427, -1.213, 20.0, 40.0), (-1.826, 1.451, -0.815, 20.0, 40.0), (1.125, 0.438, 2.686, 20.0, 40.0), (-4.918, 1.880, -3.219, 20.0, 40.0), (3.068, -0.442, 5.418, 20.0, 40.0), (1.982, 1.201, 1.589, 20.0, 40.0), (0.701, -1.709, 6.768, 20.0, 40.0), (-1.496, 2.564, -2.877, 20.0, 40.0), (-3.812, 0.974, -0.853, 20.0, 40.0), (-3.405, 2.018, -2.739, 20.0, 40.0), (2.211, 2.889, -1.674, 20.0, 40.0), (-2.481, 2.931, -4.103, 20.0, 40.0), (-3.721, 2.765, -4.391, 20.0, 40.0), (-1.768, -1.292, 4.699, 20.0, 40.0), (-4.462, 1.058, -1.347, 20.0, 40.0), (-3.516, -1.942, 5.126, 20.0, 40.0), (0.485, 2.420, -1.597, 20.0, 40.0), (-0.492, 0.242, 2.270, 20.0, 40.0), (4.245, 1.689, 1.744, 20.0, 40.0), (2.234, 0.364, 3.389, 20.0, 40.0), (2.629, 2.224, -0.134, 20.0, 40.0), (-4.375, 1.221, -1.630, 20.0, 40.0), (-0.618, 1.374, -0.057, 20.0, 40.0), (-2.580, -1.604, 4.918, 20.0, 40.0), (0.159, 1.104, 0.871, 20.0, 40.0), (-3.597, 0.975, -0.749, 20.0, 40.0); +insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0); DROP TABLE IF EXISTS test.model; -create table test.model engine = Memory as select LinearRegressionState(0.1, 5, 2.0)(target, param1, param2) as state from test.defaults; +create table test.model engine = Memory as select LinearRegressionState(0.1, 0.0, 2, 1.0)(target, param1, param2) as state from test.defaults; - -with (select state from test.model) as model select evalMLMethod(model, predict1, predict2) from test.defaults; +select ans < -61.374 and ans > -61.375 from +(with (select state from remote('127.0.0.1', test.model)) as model select evalMLMethod(model, predict1, predict2) as ans from remote('127.0.0.1', test.defaults)); diff --git a/dbms/tests/queries/0_stateless/00951_ml_test.reference b/dbms/tests/queries/0_stateless/00951_ml_test.reference index b636d351b84..f2599a746ac 100644 --- a/dbms/tests/queries/0_stateless/00951_ml_test.reference +++ b/dbms/tests/queries/0_stateless/00951_ml_test.reference @@ -1,92 +1,4 @@ -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 -0.014756373152892969 -0.9981703893717232 +0 +1 +1 +0 diff --git a/dbms/tests/queries/0_stateless/00951_ml_test.sql b/dbms/tests/queries/0_stateless/00951_ml_test.sql index 3bce8cc3085..9dbb7ece7fe 100644 --- a/dbms/tests/queries/0_stateless/00951_ml_test.sql +++ b/dbms/tests/queries/0_stateless/00951_ml_test.sql @@ -10,7 +10,10 @@ CREATE TABLE IF NOT EXISTS test.defaults ) ENGINE = Memory; insert into test.defaults values (1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2) DROP TABLE IF EXISTS test.model; -create table test.model engine = Memory as select LogisticRegressionState(0.1, 5, 1.0)(target, param1, param2) as state from test.defaults; +create table test.model engine = Memory as select LogisticRegressionState(0.1, 0.0, 1.0, 1)(target, param1, param2) as state from test.defaults; +select ans < 1.1 and ans > 0.9 from +(with (select state from test.model) as model select evalMLMethod(model, predict1, predict2) as ans from test.defaults limit 2); -with (select state from test.model) as model select evalMLMethod(model, predict1, predict2) from test.defaults; +select ans > -0.1 and ans < 0.1 from +(with (select state from test.model) as model select evalMLMethod(model, predict1, predict2) as ans from test.defaults limit 2); diff --git a/dbms/tests/queries/0_stateless/00952_ml_test.sql b/dbms/tests/queries/0_stateless/00952_ml_test.sql index 813131cf78d..94dea65ed55 100644 --- a/dbms/tests/queries/0_stateless/00952_ml_test.sql +++ b/dbms/tests/queries/0_stateless/00952_ml_test.sql @@ -21,5 +21,5 @@ CREATE TABLE IF NOT EXISTS test.defaults ) ENGINE = Memory; insert into test.defaults values (1.76210664421617,1.7469706406568504,0.7988286239230257,1.0938642223599824,1.167321139201246,1.7648182796261376,0.909111664354187,0.92,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.6276564089897139,-0.06763531281107672,0.7988286239230257,0.5966532121963541,1.167321139201246,0.4551512643242912,0.909111664354187,0.76,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(-0.07046681268810527,-0.5625278455750569,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-1.0056311758200724,0.909111664354187,0.72,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.4531256035702591,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-1.0614543055744028,0.11933920911869125,0.909111664354187,0.8,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(-0.24499761810756004,-0.7274920231630502,-0.952028633990455,-1.3921908284581592,-0.5042604443804907,-0.6530285178541898,-1.0999748867047898,0.65,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(1.1512488252480781,1.2520781078928702,1.674257252879766,1.0938642223599824,-0.5042604443804907,1.244309594057455,0.909111664354187,0.9,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,0.6101272780073337,-0.6698191206144725,0.909111664354187,0.75,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(-0.7685900343659244,-1.057420378339037,-0.952028633990455,-0.3977688081309026,0.6101272780073337,-1.1735372034228724,-1.0999748867047898,0.68,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(-1.2921824506242887,-0.8924562007510436,-1.8274572629471952,-1.3921908284581592,-2.175842027962227,-1.0056311758200724,-1.0999748867047898,0.5,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.5403910062799865,0.09732886477691666,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,0.0018049897967303734,-1.0999748867047898,0.45,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.7149218116994412,-0.2325994903990701,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.3340070654088696,0.909111664354187,0.52,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.889452617118896,0.5922213975408968,0.7988286239230257,0.5966532121963541,1.167321139201246,0.6734291002079332,0.909111664354187,0.84,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.9767180198286235,0.7571855751288902,0.7988286239230257,0.5966532121963541,1.167321139201246,0.8413351278107333,0.909111664354187,0.78,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(-0.8558554370756518,0.26229304236491,-0.0766000050337147,0.5966532121963541,-0.5042604443804907,-1.0056311758200724,0.909111664354187,0.62,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(-0.5067938262367422,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,-1.618648166768315,-0.6698191206144725,0.909111664354187,0.61,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(-0.24499761810756004,-0.39756366798706344,-0.0766000050337147,0.09944220203272576,-1.0614543055744028,-0.5019130930116695,-1.0999748867047898,0.54,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(0.016798590021622126,-0.06763531281107672,-0.0766000050337147,0.5966532121963541,-0.5042604443804907,0.16971101739953035,-1.0999748867047898,0.66,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(0.1913293954410769,-0.2325994903990701,-0.0766000050337147,0.5966532121963541,-0.5042604443804907,-1.0056311758200724,0.909111664354187,0.65,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(0.10406399273134952,0.4272572199529034,-0.0766000050337147,0.5966532121963541,-0.5042604443804907,0.3376170450023333,-1.0999748867047898,0.63,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(-1.2049170479145614,-0.8924562007510436,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,-0.1661010378060696,-1.0999748867047898,0.62,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(-0.41952842352701486,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,-1.618648166768315,-1.1735372034228724,0.909111664354187,0.64,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(0.7149218116994412,1.087113930304877,0.7988286239230257,-0.3977688081309026,-1.618648166768315,-0.3340070654088696,-1.0999748867047898,0.7,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(0.9767180198286235,1.4170422854808635,1.674257252879766,1.5910752325236108,1.724515000395158,1.5129592382219361,0.909111664354187,0.94,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(1.5003104360869879,1.9119348182448437,1.674257252879766,1.5910752325236108,1.167321139201246,1.848771293427536,0.909111664354187,0.95,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(1.6748412415064426,1.9119348182448437,1.674257252879766,0.5966532121963541,0.052933416813421515,2.016677321030339,0.909111664354187,0.97,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(2.023902852345352,2.076898995832837,1.674257252879766,1.0938642223599824,1.167321139201246,1.680865265824736,0.909111664354187,0.94,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(0.4531256035702591,0.26229304236491,1.674257252879766,1.0938642223599824,0.052933416813421515,0.3376170450023333,-1.0999748867047898,0.76,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(-1.6412440614631982,-1.5523129111030172,-0.952028633990455,-1.8894018386217877,-1.0614543055744028,-1.8451613138340752,0.909111664354187,0.44,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(-1.9030402695923805,-2.377133799042984,-1.8274572629471952,-1.3921908284581592,-1.618648166768315,-2.348879396642477,-1.0999748867047898,0.46,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(-0.5940592289464697,-1.3873487335150236,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-2.180973369039677,-1.0999748867047898,0.54,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(-1.4667132560437435,-1.7172770886910105,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,-0.8377251482172725,0.909111664354187,0.65,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(0.889452617118896,-0.7274920231630502,-0.0766000050337147,0.5966532121963541,0.6101272780073337,-0.5019130930116695,0.909111664354187,0.74,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(1.8493720469258974,1.7469706406568504,0.7988286239230257,-0.3977688081309026,1.167321139201246,1.3450532106191362,0.909111664354187,0.91,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(2.023902852345352,1.087113930304877,1.674257252879766,0.5966532121963541,0.6101272780073337,1.680865265824736,0.909111664354187,0.9,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(1.2385142279578056,0.7571855751288902,1.674257252879766,0.5966532121963541,1.724515000395158,2.016677321030339,0.909111664354187,0.94,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(0.2785947981508043,0.4272572199529034,1.674257252879766,1.5910752325236108,1.724515000395158,1.0092411554135332,0.909111664354187,0.88,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(-1.553978658753471,-0.2325994903990701,-0.952028633990455,0.5966532121963541,0.6101272780073337,-0.3340070654088696,-1.0999748867047898,0.64,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(-1.4667132560437435,-0.39756366798706344,-1.8274572629471952,-2.386612848785416,-1.618648166768315,-1.3414432310256739,-1.0999748867047898,0.58,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(-1.117651645204834,-0.39756366798706344,-1.8274572629471952,-0.3977688081309026,-2.175842027962227,-1.8451613138340752,-1.0999748867047898,0.52,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(-0.8558554370756518,0.09732886477691666,-0.952028633990455,0.5966532121963541,0.052933416813421515,-1.5093492586284738,-1.0999748867047898,0.48,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(-0.7685900343659244,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,-1.0056311758200724,0.909111664354187,0.46,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(-0.07046681268810527,-0.39756366798706344,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6698191206144725,0.909111664354187,0.49,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(-0.3322630208172874,-0.06763531281107672,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-0.1661010378060696,0.909111664354187,0.53,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(1.3257796306675331,1.582006463068857,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.8413351278107333,-1.0999748867047898,0.87,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(0.8021872144091686,0.9221497527168835,1.674257252879766,1.0938642223599824,0.6101272780073337,1.3450532106191362,0.909111664354187,0.91,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(0.4531256035702591,0.4272572199529034,1.674257252879766,1.5910752325236108,0.6101272780073337,0.8413351278107333,0.909111664354187,0.88,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(1.0639834225383509,1.087113930304877,1.674257252879766,0.5966532121963541,1.724515000395158,1.1771471830163363,0.909111664354187,0.86,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(1.9366374496356247,1.9119348182448437,1.674257252879766,1.0938642223599824,0.6101272780073337,1.848771293427536,-1.0999748867047898,0.89,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(0.36586020086053167,0.4272572199529034,-0.0766000050337147,0.09944220203272576,1.724515000395158,0.42157005880373183,0.909111664354187,0.82,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(0.889452617118896,0.5922213975408968,0.7988286239230257,-0.3977688081309026,0.6101272780073337,-0.3340070654088696,0.909111664354187,0.78,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(-0.3322630208172874,-1.5523129111030172,-0.0766000050337147,-0.8949798182945309,1.167321139201246,-0.5019130930116695,0.909111664354187,0.76,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-0.41952842352701486,-1.2223845559270303,-0.952028633990455,-1.8894018386217877,0.052933416813421515,-1.1735372034228724,0.909111664354187,0.56,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(1.5003104360869879,1.4170422854808635,0.7988286239230257,0.5966532121963541,-0.5042604443804907,-1.0056311758200724,0.909111664354187,0.78,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(0.6276564089897139,0.7571855751288902,0.7988286239230257,0.5966532121963541,-1.0614543055744028,-0.8377251482172725,0.909111664354187,0.72,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(0.4531256035702591,0.4272572199529034,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-1.0056311758200724,-1.0999748867047898,0.7,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(0.2785947981508043,-0.7274920231630502,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-1.5093492586284738,-1.0999748867047898,0.64,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-0.07046681268810527,-0.8924562007510436,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,-2.013067341436875,-1.0999748867047898,0.64,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-1.6412440614631982,-1.3873487335150236,-0.952028633990455,0.5966532121963541,-1.618648166768315,-1.6772552862312753,-1.0999748867047898,0.46,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-1.4667132560437435,-1.3873487335150236,-1.8274572629471952,-0.3977688081309026,-1.618648166768315,-3.0205035070536796,0.909111664354187,0.36,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-0.5067938262367422,-0.5625278455750569,-0.952028633990455,-1.3921908284581592,-1.618648166768315,-0.5019130930116695,-1.0999748867047898,0.42,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-0.681324631656197,-1.2223845559270303,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,-0.8377251482172725,-1.0999748867047898,0.48,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-0.8558554370756518,-1.057420378339037,-0.0766000050337147,0.5966532121963541,-0.5042604443804907,-0.6698191206144725,-1.0999748867047898,0.47,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-1.117651645204834,-0.39756366798706344,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,-0.6698191206144725,0.909111664354187,0.54,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(-0.15773221539783266,-0.06763531281107672,-0.952028633990455,0.5966532121963541,-0.5042604443804907,-0.1661010378060696,0.909111664354187,0.56,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(0.7149218116994412,0.5922213975408968,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.16971101739953035,-1.0999748867047898,0.52,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(0.7149218116994412,0.7571855751288902,0.7988286239230257,0.09944220203272576,0.052933416813421515,0.5391042781256927,-1.0999748867047898,0.55,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(0.889452617118896,1.087113930304877,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,0.7070103057284927,-1.0999748867047898,0.61,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(-0.07046681268810527,-0.06763531281107672,-0.952028633990455,0.09944220203272576,0.052933416813421515,0.06896740083785215,0.909111664354187,0.57,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(0.10406399273134952,0.26229304236491,-0.0766000050337147,0.09944220203272576,0.6101272780073337,1.0428223609340956,0.909111664354187,0.68,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(0.9767180198286235,1.2520781078928702,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9420787443724145,0.909111664354187,0.78,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(1.3257796306675331,1.7469706406568504,1.674257252879766,1.5910752325236108,1.724515000395158,1.7480276768658578,0.909111664354187,0.94,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(1.6748412415064426,0.7571855751288902,1.674257252879766,1.5910752325236108,1.724515000395158,1.9495149099892173,0.909111664354187,0.96,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(0.36586020086053167,0.5922213975408968,1.674257252879766,1.5910752325236108,1.724515000395158,1.4290062244205346,0.909111664354187,0.93,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(-0.24499761810756004,0.09732886477691666,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.7405915112490521,0.909111664354187,0.84,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(-0.24499761810756004,-0.2325994903990701,-0.0766000050337147,-0.3977688081309026,1.724515000395158,0.5055230726051333,-1.0999748867047898,0.74,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(1.0639834225383509,1.087113930304877,-0.952028633990455,-1.3921908284581592,0.6101272780073337,-0.06535742124438843,0.909111664354187,0.72,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(0.889452617118896,0.7571855751288902,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,0.20329222292009272,0.909111664354187,0.74,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(-1.3794478533340162,-1.3873487335150236,-0.952028633990455,-0.3977688081309026,-1.618648166768315,-0.6362379150939101,-1.0999748867047898,0.64,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(-1.8157748668826532,-2.0472054438669973,-0.952028633990455,-0.3977688081309026,-1.618648166768315,-1.777998902792955,0.909111664354187,0.44,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(-1.990305672302108,-2.377133799042984,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-2.0802297524779956,-1.0999748867047898,0.46,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(-0.41952842352701486,-0.39756366798706344,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,-0.972049970299513,0.909111664354187,0.5,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(2.023902852345352,2.076898995832837,0.7988286239230257,1.5910752325236108,1.724515000395158,1.5129592382219361,0.909111664354187,0.96,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(0.2785947981508043,0.4272572199529034,1.674257252879766,1.5910752325236108,1.167321139201246,1.0428223609340956,0.909111664354187,0.92,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(0.4531256035702591,1.2520781078928702,1.674257252879766,0.5966532121963541,1.167321139201246,1.2778907995780144,0.909111664354187,0.92,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(2.023902852345352,1.2520781078928702,1.674257252879766,1.0938642223599824,1.167321139201246,1.4290062244205346,0.909111664354187,0.94,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(0.1913293954410769,-0.7274920231630502,0.7988286239230257,1.0938642223599824,0.052933416813421515,0.10254860635841155,-1.0999748867047898,0.76,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(-0.15773221539783266,-0.2325994903990701,-0.0766000050337147,1.0938642223599824,0.052933416813421515,-0.30042585988831016,-1.0999748867047898,0.72,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(0.016798590021622126,-0.06763531281107672,-0.952028633990455,0.09944220203272576,-0.5042604443804907,-0.535494298532232,-1.0999748867047898,0.66,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(-0.24499761810756004,0.09732886477691666,-0.0766000050337147,1.0938642223599824,0.052933416813421515,-0.7705627371761508,-1.0999748867047898,0.64,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(-0.07046681268810527,0.26229304236491,0.7988286239230257,1.0938642223599824,0.052933416813421515,0.27045463396121155,0.909111664354187,0.74,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(0.10406399273134952,-0.2325994903990701,-0.952028633990455,0.5966532121963541,0.6101272780073337,-1.139955997902313,0.909111664354187,0.64,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(-1.553978658753471,-1.7172770886910105,-0.0766000050337147,1.5910752325236108,0.052933416813421515,-1.5765116696695942,-1.0999748867047898,0.38,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(-1.6412440614631982,-1.5523129111030172,-0.952028633990455,0.5966532121963541,-0.5042604443804907,-0.9552593675392334,-1.0999748867047898,0.34,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(-1.3794478533340162,-1.7172770886910105,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,-1.2071184089434333,0.909111664354187,0.44,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(-1.2049170479145614,-1.3873487335150236,-0.0766000050337147,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898,0.36,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(-1.117651645204834,-1.2223845559270303,0.7988286239230257,-1.8894018386217877,-1.0614543055744028,-1.2742808199845537,-1.0999748867047898,0.42,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(-0.9431208397853792,-1.2223845559270303,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,-1.0056311758200724,-1.0999748867047898,0.48,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(1.2385142279578056,2.076898995832837,-0.0766000050337147,0.5966532121963541,0.6101272780073337,0.6062666891668145,0.909111664354187,0.86,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(1.3257796306675331,1.9119348182448437,0.7988286239230257,1.5910752325236108,1.167321139201246,1.076403566454655,0.909111664354187,0.9,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(0.5403910062799865,0.9221497527168835,-0.0766000050337147,0.5966532121963541,0.6101272780073337,0.47194186708457386,0.909111664354187,0.79,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(0.4531256035702591,-0.06763531281107672,-0.0766000050337147,0.09944220203272576,0.052933416813421515,-0.2332634488471884,0.909111664354187,0.71,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-0.41952842352701486,-0.39756366798706344,-0.952028633990455,-0.8949798182945309,-0.5042604443804907,-0.8041439426967131,-1.0999748867047898,0.64,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-0.24499761810756004,-0.2325994903990701,-0.952028633990455,0.5966532121963541,0.052933416813421515,-0.585866106813071,-1.0999748867047898,0.62,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(0.016798590021622126,-0.5625278455750569,-0.952028633990455,1.0938642223599824,0.6101272780073337,-0.2164728460869087,-1.0999748867047898,0.57,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(0.8021872144091686,0.7571855751288902,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,0.7573821140093348,0.909111664354187,0.74,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-0.07046681268810527,0.4272572199529034,-0.0766000050337147,0.5966532121963541,1.167321139201246,0.30403583948177093,0.909111664354187,0.69,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,1.167321139201246,0.9756599498929738,0.909111664354187,0.87,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(1.8493720469258974,1.582006463068857,0.7988286239230257,0.09944220203272576,1.167321139201246,1.4457968271808173,0.909111664354187,0.91,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(1.2385142279578056,1.4170422854808635,1.674257252879766,1.5910752325236108,1.724515000395158,1.3114720050985766,0.909111664354187,0.93,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-1.117651645204834,-0.7274920231630502,1.674257252879766,1.5910752325236108,0.6101272780073337,0.06896740083785215,-1.0999748867047898,0.68,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-1.0303862424951067,0.09732886477691666,1.674257252879766,-0.3977688081309026,-0.5042604443804907,-0.199682243326629,-1.0999748867047898,0.61,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(0.36586020086053167,0.26229304236491,0.7988286239230257,0.5966532121963541,0.6101272780073337,0.13612981187897094,0.909111664354187,0.69,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(-1.3794478533340162,-0.06763531281107672,-0.0766000050337147,0.09944220203272576,0.052933416813421515,-0.4347506819705508,0.909111664354187,0.62,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(0.2785947981508043,0.4272572199529034,-0.952028633990455,0.5966532121963541,0.052933416813421515,-0.06535742124438843,-1.0999748867047898,0.72,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(-0.5067938262367422,-0.39756366798706344,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,-0.2500540516074711,0.909111664354187,0.59,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(-0.5940592289464697,-0.2325994903990701,0.7988286239230257,1.0938642223599824,1.167321139201246,0.7405915112490521,0.909111664354187,0.66,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(-1.553978658753471,-0.8924562007510436,-0.0766000050337147,0.5966532121963541,0.052933416813421515,0.03538619531728977,-1.0999748867047898,0.56,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(-2.3393672831410175,-0.5625278455750569,0.7988286239230257,-1.3921908284581592,-1.0614543055744028,-1.9123237248751956,-1.0999748867047898,0.45,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(-1.8157748668826532,-1.3873487335150236,-0.952028633990455,-0.3977688081309026,0.052933416813421515,-2.214554574560236,-1.0999748867047898,0.47,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(0.889452617118896,-0.5625278455750569,1.674257252879766,-0.3977688081309026,0.052933416813421515,0.4047794560434521,0.909111664354187,0.71,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,1.6137028547836172,0.909111664354187,0.94,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(1.5003104360869879,1.9119348182448437,1.674257252879766,1.0938642223599824,1.167321139201246,1.4793780327013768,0.909111664354187,0.94,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(-0.5940592289464697,-0.2325994903990701,0.7988286239230257,-1.8894018386217877,-1.0614543055744028,-0.40116947644999135,-1.0999748867047898,0.57,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(-0.7685900343659244,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.052933416813421515,-0.6362379150939101,-1.0999748867047898,0.61,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(-1.3794478533340162,-0.2325994903990701,0.7988286239230257,-0.8949798182945309,-0.5042604443804907,-0.2164728460869087,-1.0999748867047898,0.57,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.10254860635841155,0.909111664354187,0.64,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(0.5403910062799865,0.9221497527168835,-0.0766000050337147,0.5966532121963541,-0.5042604443804907,1.2107283885368956,0.909111664354187,0.85,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(0.1913293954410769,0.7571855751288902,-0.0766000050337147,-0.8949798182945309,-1.618648166768315,0.18650162015981303,0.909111664354187,0.78,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(0.8021872144091686,0.7571855751288902,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,0.8413351278107333,0.909111664354187,0.84,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(1.4130450333772604,1.7469706406568504,1.674257252879766,1.5910752325236108,1.724515000395158,1.2611001968177347,0.909111664354187,0.92,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(1.9366374496356247,1.087113930304877,1.674257252879766,0.5966532121963541,1.167321139201246,1.9495149099892173,0.909111664354187,0.96,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(-1.2049170479145614,-0.39756366798706344,1.674257252879766,1.5910752325236108,1.167321139201246,0.08575800359813185,-1.0999748867047898,0.77,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(-0.681324631656197,-0.39756366798706344,1.674257252879766,0.09944220203272576,0.052933416813421515,-0.06535742124438843,-1.0999748867047898,0.71,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(0.5403910062799865,0.7571855751288902,1.674257252879766,0.5966532121963541,1.167321139201246,0.30403583948177093,-1.0999748867047898,0.79,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(1.4130450333772604,0.9221497527168835,1.674257252879766,0.5966532121963541,0.6101272780073337,1.1435659774957738,0.909111664354187,0.89,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(-0.24499761810756004,0.26229304236491,0.7988286239230257,0.09944220203272576,0.6101272780073337,0.2872452367214912,0.909111664354187,0.82,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,1.5910752325236108,0.6101272780073337,-0.2500540516074711,-1.0999748867047898,0.76,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(-0.07046681268810527,-1.2223845559270303,-0.952028633990455,-1.8894018386217877,-0.5042604443804907,-0.7369815316555913,0.909111664354187,0.71,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(0.8021872144091686,1.4170422854808635,-0.952028633990455,1.0938642223599824,-0.5042604443804907,0.8077539222901738,0.909111664354187,0.8,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(0.10406399273134952,0.26229304236491,-1.8274572629471952,0.09944220203272576,0.052933416813421515,0.8749163333312926,-1.0999748867047898,0.78,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(1.0639834225383509,0.4272572199529034,-0.952028633990455,0.5966532121963541,-0.5042604443804907,0.9252881416121347,0.909111664354187,0.84,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(1.3257796306675331,1.7469706406568504,-0.952028633990455,1.0938642223599824,0.052933416813421515,1.2778907995780144,0.909111664354187,0.9,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(1.2385142279578056,1.2520781078928702,1.674257252879766,0.5966532121963541,0.052933416813421515,1.412215621660255,0.909111664354187,0.92,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(2.023902852345352,2.076898995832837,0.7988286239230257,1.0938642223599824,0.6101272780073337,2.2181645541536983,0.909111664354187,0.97,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(0.7149218116994412,0.7571855751288902,-0.952028633990455,-0.3977688081309026,0.052933416813421515,0.6062666891668145,0.909111664354187,0.8,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(0.2785947981508043,0.9221497527168835,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,0.06896740083785215,0.909111664354187,0.81,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(-0.15773221539783266,-0.39756366798706344,-0.0766000050337147,-1.3921908284581592,-1.0614543055744028,-0.199682243326629,-1.0999748867047898,0.75,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(0.8021872144091686,1.087113930304877,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,0.8581257305710129,0.909111664354187,0.83,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(1.9366374496356247,1.4170422854808635,0.7988286239230257,0.5966532121963541,0.052933416813421515,2.016677321030339,0.909111664354187,0.96,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(-0.5067938262367422,-0.2325994903990701,-0.952028633990455,0.09944220203272576,-0.5042604443804907,-0.5690755040527913,0.909111664354187,0.79,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(1.5003104360869879,1.087113930304877,0.7988286239230257,0.5966532121963541,0.6101272780073337,1.3954250188999753,0.909111664354187,0.93,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(1.3257796306675331,1.4170422854808635,1.674257252879766,1.5910752325236108,1.724515000395158,1.1435659774957738,0.909111664354187,0.94,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(0.36586020086053167,0.7571855751288902,1.674257252879766,1.5910752325236108,1.724515000395158,0.7741727167696144,0.909111664354187,0.86,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(0.6276564089897139,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.6101272780073337,0.25366403120093184,-1.0999748867047898,0.79,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(0.8021872144091686,0.09732886477691666,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.4887324698448536,-1.0999748867047898,0.8,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(-0.41952842352701486,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,0.15292041463925066,-1.0999748867047898,0.77,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(-0.15773221539783266,-0.39756366798706344,-0.0766000050337147,-1.3921908284581592,-1.0614543055744028,-0.4347506819705508,-1.0999748867047898,0.7,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(-0.681324631656197,-0.5625278455750569,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.5690755040527913,-1.0999748867047898,0.65,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(-0.9431208397853792,-0.2325994903990701,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.7705627371761508,-1.0999748867047898,0.61,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(-1.7285094641729257,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.1735372034228724,-1.0999748867047898,0.52,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(-0.15773221539783266,-0.7274920231630502,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.2406996144639928,-1.0999748867047898,0.57,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(-1.6412440614631982,-1.3873487335150236,-1.8274572629471952,-1.8894018386217877,-0.5042604443804907,-1.9123237248751956,-1.0999748867047898,0.53,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(0.10406399273134952,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.1661010378060696,-1.0999748867047898,0.67,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(0.016798590021622126,-0.39756366798706344,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,-0.06535742124438843,-1.0999748867047898,0.68,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.690219702968213,0.909111664354187,0.81,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(0.4531256035702591,0.4272572199529034,1.674257252879766,1.0938642223599824,0.6101272780073337,0.6230572919270941,-1.0999748867047898,0.78,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(-1.2921824506242887,-0.8924562007510436,-0.0766000050337147,0.09944220203272576,1.724515000395158,-0.45154128473083044,-1.0999748867047898,0.65,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(-0.3322630208172874,-0.8924562007510436,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,-0.5522849012925116,-1.0999748867047898,0.64,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(-2.0775710750118352,-1.7172770886910105,-0.952028633990455,-1.3921908284581592,0.6101272780073337,-1.3414432310256739,0.909111664354187,0.64,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(-0.5067938262367422,-1.3873487335150236,-0.952028633990455,-0.8949798182945309,-0.5042604443804907,-1.0392123813406318,-1.0999748867047898,0.65,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(-0.41952842352701486,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-0.9384687647789537,0.909111664354187,0.68,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(1.5003104360869879,1.582006463068857,1.674257252879766,0.5966532121963541,1.167321139201246,0.7909633195298942,0.909111664354187,0.89,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(0.4531256035702591,0.4272572199529034,0.7988286239230257,0.5966532121963541,1.724515000395158,0.8917069360915754,0.909111664354187,0.86,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(0.5403910062799865,0.9221497527168835,0.7988286239230257,0.5966532121963541,1.167321139201246,1.0596129636943752,0.909111664354187,0.89,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(0.36586020086053167,0.5922213975408968,0.7988286239230257,0.5966532121963541,0.6101272780073337,0.6230572919270941,0.909111664354187,0.87,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(0.2785947981508043,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.052933416813421515,0.4551512643242912,0.909111664354187,0.85,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(1.0639834225383509,1.9119348182448437,0.7988286239230257,1.0938642223599824,1.167321139201246,0.9420787443724145,0.909111664354187,0.9,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(0.1913293954410769,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,-1.0999748867047898,0.82,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(-0.681324631656197,0.09732886477691666,-0.0766000050337147,-0.8949798182945309,-0.5042604443804907,-0.8041439426967131,-1.0999748867047898,0.72,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(-0.8558554370756518,-0.8924562007510436,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.5522849012925116,-1.0999748867047898,0.73,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(-1.4667132560437435,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,-0.7369815316555913,-1.0999748867047898,0.71,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(-1.0303862424951067,-0.06763531281107672,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.30042585988831016,-1.0999748867047898,0.71,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(-1.553978658753471,-1.2223845559270303,-0.952028633990455,-0.3977688081309026,0.052933416813421515,-1.2071184089434333,-1.0999748867047898,0.68,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(-0.24499761810756004,0.4272572199529034,-0.0766000050337147,0.5966532121963541,0.6101272780073337,0.3376170450023333,-1.0999748867047898,0.75,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(-0.07046681268810527,-0.2325994903990701,-0.952028633990455,-0.8949798182945309,0.6101272780073337,-0.46833188749111015,-1.0999748867047898,0.72,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(0.889452617118896,0.9221497527168835,0.7988286239230257,1.0938642223599824,1.167321139201246,0.8581257305710129,0.909111664354187,0.89,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(0.016798590021622126,-0.06763531281107672,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,0.13612981187897094,0.909111664354187,0.84,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(1.5875758387967152,1.7469706406568504,1.674257252879766,1.0938642223599824,0.052933416813421515,1.412215621660255,0.909111664354187,0.93,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(1.2385142279578056,1.2520781078928702,1.674257252879766,1.0938642223599824,0.052933416813421515,1.2778907995780144,0.909111664354187,0.93,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(0.6276564089897139,0.7571855751288902,1.674257252879766,1.5910752325236108,1.724515000395158,0.8077539222901738,0.909111664354187,0.88,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(0.6276564089897139,0.5922213975408968,1.674257252879766,1.0938642223599824,0.6101272780073337,0.9420787443724145,0.909111664354187,0.9,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(0.5403910062799865,0.4272572199529034,1.674257252879766,0.5966532121963541,1.724515000395158,0.6398478946873739,0.909111664354187,0.87,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(0.4531256035702591,1.087113930304877,1.674257252879766,1.0938642223599824,0.6101272780073337,0.572685483646252,0.909111664354187,0.86,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(1.6748412415064426,1.7469706406568504,1.674257252879766,1.0938642223599824,1.724515000395158,1.5633310465027752,0.909111664354187,0.94,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(-0.07046681268810527,0.26229304236491,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,0.27045463396121155,-1.0999748867047898,0.77,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(-0.8558554370756518,-0.06763531281107672,-0.952028633990455,-0.3977688081309026,0.052933416813421515,-0.1325198322855102,0.909111664354187,0.78,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(-0.9431208397853792,-0.39756366798706344,-0.952028633990455,-0.3977688081309026,-1.0614543055744028,-0.5690755040527913,-1.0999748867047898,0.73,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(-0.5940592289464697,-0.2325994903990701,-0.952028633990455,0.09944220203272576,-1.0614543055744028,-0.45154128473083044,-1.0999748867047898,0.73,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(-0.5067938262367422,-0.5625278455750569,-0.0766000050337147,1.0938642223599824,1.167321139201246,-0.2836352571280305,-1.0999748867047898,0.7,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(-0.3322630208172874,-0.06763531281107672,-0.0766000050337147,0.5966532121963541,1.167321139201246,0.15292041463925066,-1.0999748867047898,0.72,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(0.016798590021622126,-0.7274920231630502,-0.0766000050337147,-0.8949798182945309,-0.5042604443804907,-0.0989386267649508,0.909111664354187,0.73,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(-0.15773221539783266,0.4272572199529034,-0.952028633990455,0.09944220203272576,-0.5042604443804907,-0.2332634488471884,0.909111664354187,0.72,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(2.023902852345352,2.076898995832837,1.674257252879766,1.0938642223599824,1.167321139201246,2.2013739513934185,0.909111664354187,0.97,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(1.5003104360869879,2.076898995832837,1.674257252879766,0.5966532121963541,1.724515000395158,2.1342115403522968,0.909111664354187,0.97,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(-1.6412440614631982,-0.39756366798706344,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.0989386267649508,-1.0999748867047898,0.69,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(-1.9030402695923805,-1.3873487335150236,-0.952028633990455,-0.8949798182945309,-0.5042604443804907,-1.5933022724298738,-1.0999748867047898,0.57,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(-0.15773221539783266,-1.3873487335150236,-0.952028633990455,0.09944220203272576,-0.5042604443804907,-1.1903278061831537,-1.0999748867047898,0.63,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(-0.5940592289464697,-0.8924562007510436,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.972049970299513,0.909111664354187,0.66,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(-1.0303862424951067,-0.2325994903990701,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,-0.7369815316555913,-1.0999748867047898,0.64,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(-1.3794478533340162,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.8041439426967131,0.909111664354187,0.68,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(0.7149218116994412,0.09732886477691666,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.7741727167696144,0.909111664354187,0.79,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(0.9767180198286235,0.4272572199529034,0.7988286239230257,1.5910752325236108,0.6101272780073337,0.908497538851855,0.909111664354187,0.82,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(1.8493720469258974,2.076898995832837,0.7988286239230257,1.5910752325236108,1.724515000395158,1.7816088823864173,0.909111664354187,0.95,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(1.4130450333772604,1.9119348182448437,1.674257252879766,1.5910752325236108,1.167321139201246,1.9830961155097766,0.909111664354187,0.96,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(1.2385142279578056,1.582006463068857,0.7988286239230257,1.0938642223599824,1.724515000395158,1.3786344161396955,0.909111664354187,0.94,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(1.1512488252480781,1.4170422854808635,1.674257252879766,1.5910752325236108,1.167321139201246,1.2778907995780144,0.909111664354187,0.93,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(0.4531256035702591,0.7571855751288902,0.7988286239230257,1.0938642223599824,1.167321139201246,1.1099847719752143,0.909111664354187,0.91,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(0.36586020086053167,0.26229304236491,0.7988286239230257,0.5966532121963541,0.6101272780073337,0.8917069360915754,0.909111664354187,0.85,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(0.6276564089897139,0.4272572199529034,0.7988286239230257,-0.3977688081309026,0.052933416813421515,0.6230572919270941,0.909111664354187,0.84,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(-0.41952842352701486,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.052933416813421515,-0.30042585988831016,-1.0999748867047898,0.74,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(-0.3322630208172874,-0.7274920231630502,-0.0766000050337147,0.5966532121963541,0.6101272780073337,0.25366403120093184,-1.0999748867047898,0.76,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(-0.07046681268810527,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.06535742124438843,-1.0999748867047898,0.75,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(0.6276564089897139,0.9221497527168835,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.32082644224205065,-1.0999748867047898,0.76,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(-0.7685900343659244,0.26229304236491,-0.952028633990455,-0.3977688081309026,0.6101272780073337,-0.2500540516074711,-1.0999748867047898,0.71,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(-1.0303862424951067,-0.39756366798706344,-0.952028633990455,-0.3977688081309026,-1.618648166768315,-0.6194473123336305,-1.0999748867047898,0.67,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(-1.8157748668826532,-1.3873487335150236,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.9552593675392334,-1.0999748867047898,0.61,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(-0.9431208397853792,0.4272572199529034,-0.952028633990455,0.09944220203272576,0.6101272780073337,-0.2500540516074711,-1.0999748867047898,0.63,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(-0.41952842352701486,0.4272572199529034,-0.952028633990455,0.09944220203272576,-0.5042604443804907,-0.1157292295252305,-1.0999748867047898,0.64,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(0.10406399273134952,0.7571855751288902,-0.0766000050337147,0.5966532121963541,0.052933416813421515,0.11933920911869125,-1.0999748867047898,0.71,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(0.6276564089897139,0.5922213975408968,0.7988286239230257,-0.3977688081309026,-0.5042604443804907,0.690219702968213,0.909111664354187,0.82,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(-0.3322630208172874,-0.5625278455750569,-0.0766000050337147,0.5966532121963541,1.167321139201246,0.08575800359813185,-1.0999748867047898,0.73,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(0.1913293954410769,-0.2325994903990701,-0.0766000050337147,0.09944220203272576,-1.0614543055744028,-0.45154128473083044,0.909111664354187,0.74,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(-0.41952842352701486,-0.06763531281107672,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-0.5522849012925116,-1.0999748867047898,0.69,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(-1.117651645204834,-1.2223845559270303,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-0.8880969564981116,-1.0999748867047898,0.64,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(1.1512488252480781,0.9221497527168835,1.674257252879766,1.5910752325236108,0.6101272780073337,1.1939377857766158,0.909111664354187,0.91,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(0.8021872144091686,0.5922213975408968,1.674257252879766,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187,0.88,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(0.7149218116994412,0.7571855751288902,0.7988286239230257,0.5966532121963541,1.167321139201246,0.9588693471326941,0.909111664354187,0.85,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(1.0639834225383509,1.087113930304877,1.674257252879766,1.0938642223599824,1.724515000395158,0.9924505526532535,0.909111664354187,0.86,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(-0.5940592289464697,-0.5625278455750569,-0.0766000050337147,-1.3921908284581592,0.052933416813421515,-0.3843788736897117,-1.0999748867047898,0.7,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(-1.553978658753471,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.1903278061831537,-1.0999748867047898,0.59,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(-1.8157748668826532,-1.057420378339037,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-1.5429304641490347,-1.0999748867047898,0.6,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(0.016798590021622126,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-0.753772134415871,-1.0999748867047898,0.65,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(0.6276564089897139,1.2520781078928702,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,0.27045463396121155,0.909111664354187,0.7,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(0.7149218116994412,1.087113930304877,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,0.7405915112490521,0.909111664354187,0.76,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(-0.24499761810756004,-0.06763531281107672,-0.952028633990455,-0.8949798182945309,0.6101272780073337,-0.06535742124438843,-1.0999748867047898,0.63,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(0.9767180198286235,0.4272572199529034,0.7988286239230257,0.5966532121963541,-1.0614543055744028,0.7070103057284927,0.909111664354187,0.81,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(-0.07046681268810527,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.22008282568037243,-1.0999748867047898,0.72,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(-0.5067938262367422,-0.5625278455750569,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-0.199682243326629,-1.0999748867047898,0.71,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4551512643242912,0.909111664354187,0.8,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.36586020086053167,0.5922213975408968,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.3879888532831724,0.909111664354187,0.77,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.2785947981508043,-0.5625278455750569,-0.0766000050337147,-0.3977688081309026,-1.0614543055744028,-0.04856681848410872,0.909111664354187,0.74,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(-0.07046681268810527,-1.3873487335150236,-0.952028633990455,-0.8949798182945309,-0.5042604443804907,0.6734291002079332,-1.0999748867047898,0.7,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.10406399273134952,-1.2223845559270303,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-0.0989386267649508,0.909111664354187,0.71,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(1.5875758387967152,1.2520781078928702,0.7988286239230257,1.0938642223599824,1.167321139201246,1.8151900879069767,0.909111664354187,0.93,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.36586020086053167,1.087113930304877,0.7988286239230257,0.5966532121963541,1.724515000395158,0.8749163333312926,-1.0999748867047898,0.85,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(-0.8558554370756518,0.4272572199529034,0.7988286239230257,0.5966532121963541,1.167321139201246,-0.3843788736897117,-1.0999748867047898,0.79,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(-0.681324631656197,-1.3873487335150236,-0.0766000050337147,0.5966532121963541,0.6101272780073337,-0.06535742124438843,-1.0999748867047898,0.76,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.6276564089897139,-1.2223845559270303,-0.0766000050337147,0.5966532121963541,1.724515000395158,0.06896740083785215,0.909111664354187,0.78,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.8021872144091686,-0.8924562007510436,0.7988286239230257,1.5910752325236108,1.724515000395158,0.27045463396121155,0.909111664354187,0.77,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(1.2385142279578056,1.9119348182448437,0.7988286239230257,1.5910752325236108,1.167321139201246,1.244309594057455,0.909111664354187,0.9,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(0.889452617118896,0.09732886477691666,1.674257252879766,1.5910752325236108,0.052933416813421515,0.8917069360915754,0.909111664354187,0.87,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(-0.41952842352701486,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.8545157509775522,-1.0999748867047898,0.71,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(-0.7685900343659244,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,0.6101272780073337,-0.40116947644999135,0.909111664354187,0.7,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(0.6276564089897139,0.5922213975408968,-0.0766000050337147,-0.8949798182945309,-2.175842027962227,0.32082644224205065,0.909111664354187,0.7,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(0.7149218116994412,0.4272572199529034,-0.952028633990455,-0.3977688081309026,-1.0614543055744028,0.27045463396121155,0.909111664354187,0.75,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(-0.3322630208172874,-0.8924562007510436,-0.0766000050337147,-0.8949798182945309,-1.0614543055744028,0.13612981187897094,-1.0999748867047898,0.71,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(-0.41952842352701486,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.2500540516074711,-1.0999748867047898,0.72,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(-0.24499761810756004,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.7201909288953117,0.909111664354187,0.73,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(0.889452617118896,0.9221497527168835,0.7988286239230257,1.0938642223599824,1.724515000395158,0.908497538851855,-1.0999748867047898,0.83,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(-0.7685900343659244,0.09732886477691666,0.7988286239230257,1.0938642223599824,1.724515000395158,-0.4347506819705508,-1.0999748867047898,0.77,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(-0.9431208397853792,-0.39756366798706344,-0.952028633990455,-0.8949798182945309,-0.5042604443804907,-0.6362379150939101,0.909111664354187,0.72,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(-1.553978658753471,-1.8822412662790038,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.2406996144639928,-1.0999748867047898,0.54,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(-1.990305672302108,-2.0472054438669973,-1.8274572629471952,-1.8894018386217877,-2.175842027962227,-1.610092875190155,-1.0999748867047898,0.49,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(-0.41952842352701486,-1.3873487335150236,-1.8274572629471952,-2.386612848785416,-2.175842027962227,-0.9888405730597928,0.909111664354187,0.52,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(-0.15773221539783266,-1.2223845559270303,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.0895841896214724,-1.0999748867047898,0.58,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(0.4531256035702591,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,0.6062666891668145,0.909111664354187,0.78,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(1.0639834225383509,0.9221497527168835,1.674257252879766,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187,0.89,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(0.2785947981508043,-1.057420378339037,-0.952028633990455,-0.8949798182945309,-0.5042604443804907,0.03538619531728977,-1.0999748867047898,0.7,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(-0.7685900343659244,-0.7274920231630502,-0.952028633990455,-0.3977688081309026,0.052933416813421515,-0.1828916405663493,-1.0999748867047898,0.66,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(-1.117651645204834,-0.8924562007510436,-0.952028633990455,-0.3977688081309026,0.6101272780073337,0.22008282568037243,-1.0999748867047898,0.67,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(-0.5067938262367422,-0.8924562007510436,-0.0766000050337147,1.0938642223599824,0.6101272780073337,0.06896740083785215,0.909111664354187,0.68,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(0.016798590021622126,0.4272572199529034,-0.0766000050337147,0.5966532121963541,1.167321139201246,0.8581257305710129,0.909111664354187,0.8,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(-0.41952842352701486,-0.2325994903990701,-0.0766000050337147,0.5966532121963541,0.052933416813421515,0.32082644224205065,0.909111664354187,0.81,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(0.36586020086053167,0.5922213975408968,-0.0766000050337147,-0.8949798182945309,-0.5042604443804907,0.5055230726051333,0.909111664354187,0.8,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(2.023902852345352,0.7571855751288902,0.7988286239230257,1.5910752325236108,1.167321139201246,1.7816088823864173,0.909111664354187,0.94,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(1.2385142279578056,1.4170422854808635,1.674257252879766,0.5966532121963541,0.6101272780073337,1.1099847719752143,0.909111664354187,0.93,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(1.6748412415064426,1.7469706406568504,1.674257252879766,1.0938642223599824,0.6101272780073337,0.9924505526532535,0.909111664354187,0.92,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(0.6276564089897139,1.087113930304877,1.674257252879766,1.5910752325236108,1.167321139201246,0.8077539222901738,0.909111664354187,0.89,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(-0.24499761810756004,-0.5625278455750569,0.7988286239230257,1.5910752325236108,1.724515000395158,0.7070103057284927,-1.0999748867047898,0.82,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(-0.3322630208172874,0.26229304236491,-0.0766000050337147,0.5966532121963541,0.052933416813421515,0.6734291002079332,-1.0999748867047898,0.79,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-0.8949798182945309,-0.5042604443804907,-1.5933022724298738,-1.0999748867047898,0.58,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(-1.4667132560437435,-0.8924562007510436,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.223909011703713,-1.0999748867047898,0.56,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(-1.2921824506242887,-1.3873487335150236,-0.952028633990455,-2.386612848785416,-1.618648166768315,-1.056002984100913,-1.0999748867047898,0.56,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(-0.41952842352701486,-1.5523129111030172,-1.8274572629471952,0.09944220203272576,-0.5042604443804907,-0.7034003261350319,0.909111664354187,0.64,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(-0.07046681268810527,-1.057420378339037,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-0.46833188749111015,0.909111664354187,0.61,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(0.016798590021622126,-1.2223845559270303,-0.952028633990455,-0.3977688081309026,-1.0614543055744028,-0.04856681848410872,-1.0999748867047898,0.68,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(-0.5940592289464697,-0.06763531281107672,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.11933920911869125,-1.0999748867047898,0.76,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(0.2785947981508043,2.076898995832837,-0.0766000050337147,0.5966532121963541,1.167321139201246,0.8581257305710129,-1.0999748867047898,0.86,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(1.1512488252480781,1.087113930304877,-0.0766000050337147,1.0938642223599824,1.167321139201246,1.076403566454655,0.909111664354187,0.9,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(-1.0303862424951067,0.7571855751288902,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.08575800359813185,-1.0999748867047898,0.71,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(-0.681324631656197,-0.2325994903990701,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-1.0056311758200724,-1.0999748867047898,0.62,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(0.1913293954410769,0.09732886477691666,-0.952028633990455,-0.8949798182945309,-0.5042604443804907,0.27045463396121155,-1.0999748867047898,0.66,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(0.4531256035702591,-0.39756366798706344,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,-0.2500540516074711,0.909111664354187,0.65,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(0.5403910062799865,-0.06763531281107672,-0.0766000050337147,0.09944220203272576,0.052933416813421515,-0.08214802400466813,0.909111664354187,0.73,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(-0.3322630208172874,-0.2325994903990701,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-0.2836352571280305,-1.0999748867047898,0.62,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(0.36586020086053167,0.26229304236491,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.3376170450023333,0.909111664354187,0.74,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(0.5403910062799865,0.4272572199529034,-0.0766000050337147,0.5966532121963541,0.052933416813421515,0.8413351278107333,0.909111664354187,0.79,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(0.7149218116994412,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.6101272780073337,0.6734291002079332,0.909111664354187,0.8,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(-0.41952842352701486,0.09732886477691666,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,-0.1157292295252305,-1.0999748867047898,0.69,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(-0.7685900343659244,0.4272572199529034,0.7988286239230257,0.09944220203272576,-0.5042604443804907,0.0018049897967303734,-1.0999748867047898,0.7,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(0.2785947981508043,-0.5625278455750569,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.23687342844065212,0.909111664354187,0.76,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(0.9767180198286235,0.09732886477691666,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9756599498929738,0.909111664354187,0.84,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(-0.5067938262367422,-0.06763531281107672,0.7988286239230257,1.0938642223599824,1.167321139201246,0.6734291002079332,0.909111664354187,0.78,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(-1.3794478533340162,-1.2223845559270303,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,-0.9384687647789537,-1.0999748867047898,0.67,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(-1.0303862424951067,-0.39756366798706344,-0.952028633990455,-0.3977688081309026,0.6101272780073337,-0.7873533399364304,-1.0999748867047898,0.66,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(-0.7685900343659244,-0.5625278455750569,-0.952028633990455,-0.8949798182945309,-0.5042604443804907,-0.8880969564981116,-1.0999748867047898,0.65,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(-1.6412440614631982,-1.057420378339037,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.2406996144639928,-1.0999748867047898,0.54,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(-1.4667132560437435,-1.3873487335150236,-1.8274572629471952,-2.386612848785416,-1.0614543055744028,-0.9888405730597928,-1.0999748867047898,0.58,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(0.6276564089897139,0.5922213975408968,-0.0766000050337147,-0.8949798182945309,-1.618648166768315,0.3376170450023333,0.909111664354187,0.79,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(0.889452617118896,0.9221497527168835,0.7988286239230257,0.09944220203272576,-0.5042604443804907,0.15292041463925066,0.909111664354187,0.8,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(0.016798590021622126,-0.2325994903990701,-0.0766000050337147,0.5966532121963541,0.052933416813421515,-0.1661010378060696,0.909111664354187,0.75,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(0.5403910062799865,-0.5625278455750569,-0.0766000050337147,0.5966532121963541,0.6101272780073337,-0.2668446543677508,0.909111664354187,0.73,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(-0.24499761810756004,-0.06763531281107672,-0.952028633990455,-0.8949798182945309,0.6101272780073337,-0.5522849012925116,-1.0999748867047898,0.72,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(-1.0303862424951067,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.7034003261350319,-1.0999748867047898,0.62,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(-0.15773221539783266,-0.5625278455750569,-0.0766000050337147,-0.3977688081309026,-1.0614543055744028,-0.45154128473083044,-1.0999748867047898,0.67,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(0.8021872144091686,1.4170422854808635,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.908497538851855,0.909111664354187,0.81,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(-1.553978658753471,-1.2223845559270303,-0.0766000050337147,-1.3921908284581592,-1.618648166768315,-0.972049970299513,-1.0999748867047898,0.63,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(-1.9030402695923805,-1.057420378339037,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.2406996144639928,-1.0999748867047898,0.69,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(0.6276564089897139,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.2872452367214912,0.909111664354187,0.8,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-2.175842027962227,-1.1903278061831537,-1.0999748867047898,0.43,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(0.889452617118896,0.9221497527168835,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,0.10254860635841155,0.909111664354187,0.8,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(-0.5067938262367422,-0.39756366798706344,-0.952028633990455,-0.3977688081309026,-1.618648166768315,-0.8041439426967131,0.909111664354187,0.73,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(-0.7685900343659244,-0.2325994903990701,-0.0766000050337147,0.09944220203272576,-1.0614543055744028,-0.6530285178541898,0.909111664354187,0.75,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(0.1913293954410769,0.09732886477691666,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.0989386267649508,0.909111664354187,0.71,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(-0.41952842352701486,-0.06763531281107672,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.08575800359813185,0.909111664354187,0.73,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(0.7149218116994412,0.5922213975408968,0.7988286239230257,0.5966532121963541,1.167321139201246,0.8581257305710129,0.909111664354187,0.83,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(0.1913293954410769,0.4272572199529034,-0.0766000050337147,-0.3977688081309026,-1.0614543055744028,0.32082644224205065,-1.0999748867047898,0.72,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(1.3257796306675331,1.7469706406568504,1.674257252879766,1.5910752325236108,1.724515000395158,1.462587429941097,0.909111664354187,0.94,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(0.5403910062799865,0.09732886477691666,1.674257252879766,0.5966532121963541,0.6101272780073337,0.23687342844065212,0.909111664354187,0.81,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(0.6276564089897139,-0.06763531281107672,1.674257252879766,0.09944220203272576,0.6101272780073337,0.10254860635841155,0.909111664354187,0.81,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(-0.41952842352701486,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.2332634488471884,0.909111664354187,0.75,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(0.8021872144091686,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.27045463396121155,0.909111664354187,0.79,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(-0.7685900343659244,-0.2325994903990701,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.6026567095733507,-1.0999748867047898,0.58,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(-1.0303862424951067,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-0.7873533399364304,-1.0999748867047898,0.59,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(-1.9030402695923805,-1.8822412662790038,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-2.1138109579985565,-1.0999748867047898,0.47,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(-0.07046681268810527,-1.5523129111030172,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.9626955331560363,-1.0999748867047898,0.49,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(-1.117651645204834,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.610092875190155,-1.0999748867047898,0.47,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(-1.553978658753471,-2.2121696214549904,-1.8274572629471952,-2.386612848785416,-2.7330358891561395,-2.1138109579985565,-1.0999748867047898,0.42,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(-1.2921824506242887,-1.3873487335150236,-1.8274572629471952,-1.3921908284581592,-1.618648166768315,-2.2649263828410766,-1.0999748867047898,0.57,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(-0.3322630208172874,-1.057420378339037,-0.0766000050337147,-0.8949798182945309,-0.5042604443804907,-0.9384687647789537,-1.0999748867047898,0.62,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(0.10406399273134952,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5522849012925116,0.909111664354187,0.74,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(0.7149218116994412,0.4272572199529034,0.7988286239230257,0.09944220203272576,0.6101272780073337,0.11933920911869125,0.909111664354187,0.73,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(-1.2049170479145614,-1.2223845559270303,-0.952028633990455,-0.3977688081309026,0.052933416813421515,-0.9048875592583913,0.909111664354187,0.64,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(-1.4667132560437435,-0.8924562007510436,-0.0766000050337147,0.09944220203272576,-1.0614543055744028,-0.7201909288953117,-1.0999748867047898,0.63,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(-1.7285094641729257,-1.5523129111030172,-0.952028633990455,-0.8949798182945309,-0.5042604443804907,-1.5597210669093144,-1.0999748867047898,0.59,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(0.016798590021622126,-0.2325994903990701,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8041439426967131,-1.0999748867047898,0.73,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(0.889452617118896,0.26229304236491,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.2872452367214912,0.909111664354187,0.79,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(-1.3794478533340162,-0.5625278455750569,-0.952028633990455,0.09944220203272576,0.052933416813421515,-1.1903278061831537,0.909111664354187,0.68,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(-0.24499761810756004,-0.39756366798706344,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.610092875190155,-1.0999748867047898,0.7,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187),(0.36586020086053167,-0.06763531281107672,-0.952028633990455,-1.3921908284581592,-2.175842027962227,-0.2668446543677508,-1.0999748867047898,0.81,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187),(0.4531256035702591,0.4272572199529034,-0.0766000050337147,0.5966532121963541,1.724515000395158,0.06896740083785215,0.909111664354187,0.85,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187),(1.5003104360869879,1.4170422854808635,0.7988286239230257,0.5966532121963541,0.052933416813421515,1.580121649263055,0.909111664354187,0.93,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187),(1.8493720469258974,1.2520781078928702,1.674257252879766,1.0938642223599824,1.724515000395158,1.0596129636943752,0.909111664354187,0.91,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187),(-0.9431208397853792,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-0.5042604443804907,-0.40116947644999135,-1.0999748867047898,0.69,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187),(-0.3322630208172874,-0.8924562007510436,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.5055230726051333,0.909111664354187,0.77,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187),(1.1512488252480781,1.087113930304877,0.7988286239230257,1.0938642223599824,-0.5042604443804907,0.9588693471326941,0.909111664354187,0.86,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187),(0.2785947981508043,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,1.167321139201246,-0.4347506819705508,0.909111664354187,0.74,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187),(-0.5067938262367422,-1.5523129111030172,-1.8274572629471952,-2.386612848785416,-1.0614543055744028,-1.9123237248751956,-1.0999748867047898,0.57,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187),(-1.6412440614631982,-2.5420979766309775,-1.8274572629471952,-1.3921908284581592,-1.618648166768315,-1.2071184089434333,-1.0999748867047898,0.51,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187),(-1.3794478533340162,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-0.5042604443804907,-0.9552593675392334,0.909111664354187,0.67,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187) DROP TABLE IF EXISTS test.model; -create table test.model engine = Memory as select LinearRegressionState(0.1, 5, 1.0)(target, param1, param2, param3, param4, param5, param6, param7) as state from test.defaults; +create table test.model engine = Memory as select LinearRegressionState(0.1, 0.0, 5, 1.0)(target, param1, param2, param3, param4, param5, param6, param7) as state from test.defaults; with (select state from test.model) as model select evalMLMethod(model, predict1, predict2, predict3, predict4, predict5, predict6, predict7) from test.defaults; diff --git a/dbms/tests/queries/0_stateless/00953_dataset_test.reference b/dbms/tests/queries/0_stateless/00953_dataset_test.reference new file mode 100644 index 00000000000..d00491fd7e5 --- /dev/null +++ b/dbms/tests/queries/0_stateless/00953_dataset_test.reference @@ -0,0 +1 @@ +1 diff --git a/dbms/tests/queries/0_stateless/00955_ml_test.sql b/dbms/tests/queries/0_stateless/00953_dataset_test.sql similarity index 97% rename from dbms/tests/queries/0_stateless/00955_ml_test.sql rename to dbms/tests/queries/0_stateless/00953_dataset_test.sql index 2df84c00d3f..2ade0fc412c 100644 --- a/dbms/tests/queries/0_stateless/00955_ml_test.sql +++ b/dbms/tests/queries/0_stateless/00953_dataset_test.sql @@ -11,7 +11,7 @@ CREATE TABLE IF NOT EXISTS test.defaults insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0), (-1.099, 2.755, -3.060, 20.0, 40.0), (1.090, 2.945, -2.346, 20.0, 40.0), (0.305, 2.179, -1.205, 20.0, 40.0), (-0.925, 0.702, 1.134, 20.0, 40.0), (3.178, -1.316, 7.221, 20.0, 40.0), (-2.756, -0.473, 2.569, 20.0, 40.0), (3.665, 2.303, 0.226, 20.0, 40.0), (1.662, 1.951, -0.070, 20.0, 40.0), (2.869, 0.593, 3.249, 20.0, 40.0), (0.818, -0.593, 4.594, 20.0, 40.0), (-1.917, 0.916, 0.209, 20.0, 40.0), (2.706, 1.523, 1.307, 20.0, 40.0), (0.219, 2.162, -1.214, 20.0, 40.0), (-4.510, 1.376, -2.007, 20.0, 40.0), (4.284, -0.515, 6.173, 20.0, 40.0), (-1.101, 2.810, -3.170, 20.0, 40.0), (-1.810, -1.117, 4.329, 20.0, 40.0), (0.055, 1.115, 0.797, 20.0, 40.0), (-2.178, 2.904, -3.898, 20.0, 40.0), (-3.494, -1.814, 4.882, 20.0, 40.0), (3.027, 0.476, 3.562, 20.0, 40.0), (-1.434, 1.151, -0.018, 20.0, 40.0), (1.180, 0.992, 1.606, 20.0, 40.0), (0.015, 0.971, 1.067, 20.0, 40.0), (-0.511, -0.875, 4.495, 20.0, 40.0), (0.961, 2.348, -1.216, 20.0, 40.0), (-2.279, 0.038, 1.785, 20.0, 40.0), (-1.568, -0.248, 2.712, 20.0, 40.0), (-0.496, 0.366, 2.020, 20.0, 40.0), (1.177, -1.401, 6.390, 20.0, 40.0), (2.882, -1.442, 7.325, 20.0, 40.0), (-1.066, 1.817, -1.167, 20.0, 40.0), (-2.144, 2.791, -3.655, 20.0, 40.0), (-4.370, 2.228, -3.642, 20.0, 40.0), (3.996, 2.775, -0.553, 20.0, 40.0), (0.289, 2.055, -0.965, 20.0, 40.0), (-0.588, -1.601, 5.908, 20.0, 40.0), (-1.801, 0.417, 1.265, 20.0, 40.0), (4.375, -1.499, 8.186, 20.0, 40.0), (-2.618, 0.038, 1.615, 20.0, 40.0), (3.616, -0.833, 6.475, 20.0, 40.0), (-4.045, -1.558, 4.094, 20.0, 40.0), (-3.962, 0.636, -0.253, 20.0, 40.0), (3.505, 2.625, -0.497, 20.0, 40.0), (3.029, -0.523, 5.560, 20.0, 40.0), (-3.520, -0.474, 2.188, 20.0, 40.0), (2.430, -1.469, 7.154, 20.0, 40.0), (1.547, -1.654, 7.082, 20.0, 40.0), (-1.370, 0.575, 1.165, 20.0, 40.0), (-1.869, -1.555, 5.176, 20.0, 40.0), (3.536, 2.841, -0.913, 20.0, 40.0), (-3.810, 1.220, -1.344, 20.0, 40.0), (-1.971, 1.462, -0.910, 20.0, 40.0), (-0.243, 0.167, 2.545, 20.0, 40.0), (-1.403, 2.645, -2.991, 20.0, 40.0), (0.532, -0.114, 3.494, 20.0, 40.0), (-1.678, 0.975, 0.212, 20.0, 40.0), (-0.656, 2.140, -1.609, 20.0, 40.0), (1.743, 2.631, -1.390, 20.0, 40.0), (2.586, 2.943, -1.593, 20.0, 40.0), (-0.512, 2.969, -3.195, 20.0, 40.0), (2.283, -0.100, 4.342, 20.0, 40.0), (-4.293, 0.872, -0.890, 20.0, 40.0), (3.411, 1.300, 2.106, 20.0, 40.0), (-0.281, 2.951, -3.042, 20.0, 40.0), (-4.442, 0.384, 0.012, 20.0, 40.0), (1.194, 1.746, 0.104, 20.0, 40.0), (-1.152, 1.862, -1.300, 20.0, 40.0), (1.362, -1.341, 6.363, 20.0, 40.0), (-4.488, 2.618, -4.481, 20.0, 40.0), (3.419, -0.564, 5.837, 20.0, 40.0), (-3.392, 0.396, 0.512, 20.0, 40.0), (-1.629, -0.909, 4.003, 20.0, 40.0), (4.447, -1.088, 7.399, 20.0, 40.0), (-1.232, 1.699, -1.014, 20.0, 40.0), (-1.286, -0.609, 3.575, 20.0, 40.0), (2.437, 2.796, -1.374, 20.0, 40.0), (-4.864, 1.989, -3.410, 20.0, 40.0), (-1.716, -1.399, 4.940, 20.0, 40.0), (-3.084, 1.858, -2.259, 20.0, 40.0), (2.828, -0.319, 5.053, 20.0, 40.0), (-1.226, 2.586, -2.786, 20.0, 40.0), (2.456, 0.092, 4.044, 20.0, 40.0), (-0.989, 2.375, -2.245, 20.0, 40.0), (3.268, 0.935, 2.765, 20.0, 40.0), (-4.128, -1.995, 4.927, 20.0, 40.0), (-1.083, 2.197, -1.935, 20.0, 40.0), (-3.471, -1.198, 3.660, 20.0, 40.0), (4.617, -1.136, 7.579, 20.0, 40.0), (2.054, -1.675, 7.378, 20.0, 40.0), (4.106, 2.326, 0.402, 20.0, 40.0), (1.558, 0.310, 3.158, 20.0, 40.0), (0.792, 0.900, 1.596, 20.0, 40.0), (-3.229, 0.300, 0.785, 20.0, 40.0), (3.787, -0.793, 6.479, 20.0, 40.0), (1.786, 2.288, -0.684, 20.0, 40.0), (2.643, 0.223, 3.875, 20.0, 40.0), (-3.592, 2.122, -3.040, 20.0, 40.0), (4.519, -1.760, 8.779, 20.0, 40.0), (3.221, 2.255, 0.101, 20.0, 40.0), (4.151, 1.788, 1.500, 20.0, 40.0), (-1.033, -1.195, 4.874, 20.0, 40.0), (-1.636, -1.037, 4.257, 20.0, 40.0), (-3.548, 1.911, -2.596, 20.0, 40.0), (4.829, -0.293, 6.001, 20.0, 40.0), (-4.684, -1.664, 3.986, 20.0, 40.0), (4.531, -0.503, 6.271, 20.0, 40.0), (-3.503, -1.606, 4.460, 20.0, 40.0), (-2.036, -1.522, 5.027, 20.0, 40.0), (-0.473, -0.617, 3.997, 20.0, 40.0), (-1.554, -1.630, 5.483, 20.0, 40.0), (-3.567, -1.043, 3.302, 20.0, 40.0), (-2.038, 0.579, 0.823, 20.0, 40.0), (-3.040, 0.857, -0.233, 20.0, 40.0), (4.610, 0.562, 4.181, 20.0, 40.0), (-3.323, -1.938, 5.215, 20.0, 40.0), (4.314, 1.720, 1.717, 20.0, 40.0), (-1.220, 0.615, 1.161, 20.0, 40.0), (-2.556, 1.120, -0.519, 20.0, 40.0), (-3.717, -0.108, 1.358, 20.0, 40.0), (4.689, -1.826, 8.996, 20.0, 40.0), (3.452, 0.506, 3.713, 20.0, 40.0), (2.472, 0.612, 3.012, 20.0, 40.0), (3.452, 0.450, 3.826, 20.0, 40.0), (1.207, 2.585, -1.567, 20.0, 40.0), (-4.826, 1.090, -1.593, 20.0, 40.0), (3.116, -1.118, 6.794, 20.0, 40.0), (0.448, 2.732, -2.240, 20.0, 40.0), (-1.096, -0.525, 3.503, 20.0, 40.0), (-4.680, -0.238, 1.137, 20.0, 40.0), (2.552, -1.403, 7.082, 20.0, 40.0), (0.719, 2.997, -2.635, 20.0, 40.0), (0.347, -1.966, 7.105, 20.0, 40.0), (2.958, -0.404, 5.288, 20.0, 40.0), (0.722, -1.950, 7.261, 20.0, 40.0), (-2.851, -0.986, 3.546, 20.0, 40.0), (-4.316, -0.439, 1.721, 20.0, 40.0), (-1.685, -0.201, 2.560, 20.0, 40.0), (1.856, 0.190, 3.549, 20.0, 40.0), (-2.052, 0.206, 1.562, 20.0, 40.0), (-2.504, -0.646, 3.041, 20.0, 40.0), (3.235, 0.882, 2.854, 20.0, 40.0), (-1.366, -1.573, 5.463, 20.0, 40.0), (-3.447, 2.419, -3.562, 20.0, 40.0), (4.155, 2.092, 0.893, 20.0, 40.0), (-0.935, 0.209, 2.116, 20.0, 40.0), (3.117, -1.821, 8.201, 20.0, 40.0), (3.759, 0.577, 3.725, 20.0, 40.0), (-0.938, 2.992, -3.453, 20.0, 40.0), (-0.525, 2.341, -1.945, 20.0, 40.0), (4.540, 2.625, 0.019, 20.0, 40.0), (-2.097, 1.190, -0.429, 20.0, 40.0), (-2.672, 1.983, -2.302, 20.0, 40.0), (-3.038, -1.490, 4.460, 20.0, 40.0), (-0.943, 2.149, -1.770, 20.0, 40.0), (0.739, 1.598, 0.174, 20.0, 40.0), (1.828, 1.853, 0.208, 20.0, 40.0), (4.856, 0.137, 5.153, 20.0, 40.0), (-1.617, 0.468, 1.255, 20.0, 40.0), (-1.972, 2.053, -2.092, 20.0, 40.0), (-4.633, 1.389, -2.094, 20.0, 40.0), (-3.628, -1.156, 3.498, 20.0, 40.0), (3.597, 1.034, 2.731, 20.0, 40.0), (-1.488, -0.002, 2.261, 20.0, 40.0), (0.749, 1.921, -0.468, 20.0, 40.0), (1.304, -1.371, 6.394, 20.0, 40.0), (4.587, 2.936, -0.579, 20.0, 40.0), (-2.241, 1.791, -1.703, 20.0, 40.0), (-2.945, 1.372, -1.216, 20.0, 40.0), (1.375, 0.395, 2.898, 20.0, 40.0), (-1.281, -0.641, 3.642, 20.0, 40.0), (2.178, 0.895, 2.299, 20.0, 40.0), (3.031, -0.786, 6.087, 20.0, 40.0), (-1.385, -0.375, 3.058, 20.0, 40.0), (4.041, -0.431, 5.882, 20.0, 40.0), (0.480, -0.507, 4.254, 20.0, 40.0), (-3.797, 0.140, 0.822, 20.0, 40.0), (2.355, 2.502, -0.827, 20.0, 40.0), (1.376, -1.583, 6.854, 20.0, 40.0), (0.164, 1.405, 0.273, 20.0, 40.0), (-1.273, 1.471, -0.579, 20.0, 40.0), (0.770, 2.246, -1.107, 20.0, 40.0), (4.552, 2.904, -0.533, 20.0, 40.0), (4.259, -1.772, 8.674, 20.0, 40.0), (-0.309, 1.159, 0.528, 20.0, 40.0), (3.581, 2.700, -0.610, 20.0, 40.0), (-3.202, 0.346, 0.707, 20.0, 40.0), (-1.575, 1.242, -0.271, 20.0, 40.0), (-1.584, -0.493, 3.194, 20.0, 40.0), (-3.778, 0.150, 0.810, 20.0, 40.0), (-4.675, 1.749, -2.835, 20.0, 40.0), (3.567, -0.792, 6.367, 20.0, 40.0), (-0.417, 1.399, -0.006, 20.0, 40.0), (-4.672, 2.007, -3.349, 20.0, 40.0), (-1.034, 0.196, 2.090, 20.0, 40.0), (-3.796, 2.496, -3.890, 20.0, 40.0), (3.532, -0.497, 5.759, 20.0, 40.0), (4.868, -1.359, 8.151, 20.0, 40.0), (-0.769, 0.302, 2.011, 20.0, 40.0), (4.475, 2.612, 0.014, 20.0, 40.0), (-3.532, -0.395, 2.024, 20.0, 40.0), (0.322, 0.675, 1.812, 20.0, 40.0), (-2.028, -1.942, 5.870, 20.0, 40.0), (1.810, -1.244, 6.392, 20.0, 40.0), (-0.783, 1.242, 0.124, 20.0, 40.0), (-4.745, -1.300, 3.227, 20.0, 40.0), (1.902, 1.973, 0.005, 20.0, 40.0), (-3.453, -1.429, 4.132, 20.0, 40.0), (1.559, 0.986, 1.808, 20.0, 40.0), (0.128, 2.754, -2.443, 20.0, 40.0), (2.759, 1.727, 0.926, 20.0, 40.0), (-4.468, 1.690, -2.614, 20.0, 40.0), (-2.368, -1.922, 5.659, 20.0, 40.0), (-2.766, 2.128, -2.640, 20.0, 40.0), (0.967, -1.825, 7.133, 20.0, 40.0), (-2.854, 2.855, -4.136, 20.0, 40.0), (-2.944, 1.875, -2.222, 20.0, 40.0), (-2.632, -0.983, 3.649, 20.0, 40.0), (2.427, 2.239, -0.266, 20.0, 40.0), (-1.726, -0.838, 3.812, 20.0, 40.0), (0.007, -0.903, 4.809, 20.0, 40.0), (-2.013, 1.092, -0.191, 20.0, 40.0), (-0.449, 0.970, 0.836, 20.0, 40.0), (1.396, 0.411, 2.876, 20.0, 40.0), (-1.115, -1.790, 6.023, 20.0, 40.0), (3.748, 1.917, 1.039, 20.0, 40.0), (2.978, 1.043, 2.404, 20.0, 40.0), (-3.969, 2.514, -4.013, 20.0, 40.0), (4.455, -0.050, 5.328, 20.0, 40.0), (-3.065, -0.846, 3.160, 20.0, 40.0), (-1.069, 2.167, -1.869, 20.0, 40.0), (3.016, -1.393, 7.294, 20.0, 40.0), (0.045, -1.928, 6.879, 20.0, 40.0), (-2.555, -0.984, 3.690, 20.0, 40.0), (-1.995, -0.054, 2.111, 20.0, 40.0), (4.600, -0.509, 6.318, 20.0, 40.0), (-1.942, 1.215, -0.402, 20.0, 40.0), (1.262, 2.765, -1.899, 20.0, 40.0), (2.617, -1.106, 6.521, 20.0, 40.0), (1.737, 0.554, 2.761, 20.0, 40.0), (-2.197, 0.632, 0.638, 20.0, 40.0), (4.768, 2.618, 0.147, 20.0, 40.0), (-3.737, -0.939, 3.010, 20.0, 40.0), (-2.623, 0.595, 0.499, 20.0, 40.0), (4.752, -0.340, 6.057, 20.0, 40.0), (2.333, -1.037, 6.240, 20.0, 40.0), (4.234, -1.882, 8.881, 20.0, 40.0), (-3.393, -0.812, 2.927, 20.0, 40.0), (0.885, 1.383, 0.678, 20.0, 40.0), (0.123, 2.937, -2.812, 20.0, 40.0), (2.969, 0.760, 2.964, 20.0, 40.0), (-4.929, 1.251, -1.967, 20.0, 40.0), (1.916, 2.223, -0.488, 20.0, 40.0), (-0.020, -1.740, 6.469, 20.0, 40.0), (0.702, -1.272, 5.895, 20.0, 40.0), (2.496, 2.648, -1.048, 20.0, 40.0), (4.067, -1.475, 7.984, 20.0, 40.0), (-3.717, 1.851, -2.561, 20.0, 40.0), (1.678, -0.624, 5.088, 20.0, 40.0), (1.073, 0.695, 2.146, 20.0, 40.0), (1.842, -0.749, 5.419, 20.0, 40.0), (-3.518, 1.909, -2.578, 20.0, 40.0), (2.229, 1.189, 1.737, 20.0, 40.0), (4.987, 2.893, -0.292, 20.0, 40.0), (-4.809, 1.043, -1.490, 20.0, 40.0), (-0.241, -0.728, 4.334, 20.0, 40.0), (-3.331, 0.590, 0.156, 20.0, 40.0), (-0.455, 2.621, -2.470, 20.0, 40.0), (1.492, 1.223, 1.301, 20.0, 40.0), (3.948, 2.841, -0.709, 20.0, 40.0), (0.732, 0.446, 2.475, 20.0, 40.0), (2.400, 2.390, -0.579, 20.0, 40.0), (-2.718, 1.427, -1.213, 20.0, 40.0), (-1.826, 1.451, -0.815, 20.0, 40.0), (1.125, 0.438, 2.686, 20.0, 40.0), (-4.918, 1.880, -3.219, 20.0, 40.0), (3.068, -0.442, 5.418, 20.0, 40.0), (1.982, 1.201, 1.589, 20.0, 40.0), (0.701, -1.709, 6.768, 20.0, 40.0), (-1.496, 2.564, -2.877, 20.0, 40.0), (-3.812, 0.974, -0.853, 20.0, 40.0), (-3.405, 2.018, -2.739, 20.0, 40.0), (2.211, 2.889, -1.674, 20.0, 40.0), (-2.481, 2.931, -4.103, 20.0, 40.0), (-3.721, 2.765, -4.391, 20.0, 40.0), (-1.768, -1.292, 4.699, 20.0, 40.0), (-4.462, 1.058, -1.347, 20.0, 40.0), (-3.516, -1.942, 5.126, 20.0, 40.0), (0.485, 2.420, -1.597, 20.0, 40.0), (-0.492, 0.242, 2.270, 20.0, 40.0), (4.245, 1.689, 1.744, 20.0, 40.0), (2.234, 0.364, 3.389, 20.0, 40.0), (2.629, 2.224, -0.134, 20.0, 40.0), (-4.375, 1.221, -1.630, 20.0, 40.0), (-0.618, 1.374, -0.057, 20.0, 40.0), (-2.580, -1.604, 4.918, 20.0, 40.0), (0.159, 1.104, 0.871, 20.0, 40.0), (-3.597, 0.975, -0.749, 20.0, 40.0); DROP TABLE IF EXISTS test.model; -create table test.model engine = Memory as select LinearRegressionState(0.1, 5, 1.0)(target, param1, param2) as state from test.defaults; +create table test.model engine = Memory as select LinearRegressionState(0.03, 0.00001, 2, 2.0)(target, param1, param2) as state from test.defaults; - -with (select state from test.model) as model select evalMLMethod(model, predict1, predict2) from test.defaults; +select ans > -67.0 and ans < -66.9 from +(with (select state + state + state from test.model) as model select evalMLMethod(model, predict1, predict2) as ans from test.defaults limit 1); diff --git a/dbms/tests/queries/0_stateless/00953_ml_test.good_reference b/dbms/tests/queries/0_stateless/00953_ml_test.good_reference deleted file mode 100644 index ff9c61e403b..00000000000 --- a/dbms/tests/queries/0_stateless/00953_ml_test.good_reference +++ /dev/null @@ -1,580 +0,0 @@ -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -0.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 -1.0 diff --git a/dbms/tests/queries/0_stateless/00953_ml_test.reference b/dbms/tests/queries/0_stateless/00953_ml_test.reference deleted file mode 100644 index 993fa484869..00000000000 --- a/dbms/tests/queries/0_stateless/00953_ml_test.reference +++ /dev/null @@ -1,580 +0,0 @@ -0.6411012851604063 -0.6411012851604063 -0.6411012851604063 -0.6411012851604063 -0.6411012851604063 -0.6411012851604063 -0.6411012851604063 -0.6411012851604063 -0.6411012851604063 -0.6411012851604063 -0.6411012851604063 -0.6411012851604063 -0.6411012851604063 -0.6411012851604063 -0.6411012851604063 -0.6411012851604063 -0.6411012851604063 -0.6411012851604063 -0.6411012851604063 -0.6411012851604063 -0.6411012851604063 -0.6411012851604063 -0.6411012851604063 -0.6411012851604063 -0.6411012851604063 -0.6411012851604063 -0.6411012851604063 -0.6411012851604063 -0.6411012851604063 -0.6882314202562039 -0.6882314202562039 -0.6882314202562039 -0.6882314202562039 -0.6882314202562039 -0.6882314202562039 -0.6882314202562039 -0.6882314202562039 -0.6882314202562039 -0.6882314202562039 -0.6882314202562039 -0.6882314202562039 -0.6882314202562039 -0.6882314202562039 -0.6882314202562039 -0.6882314202562039 -0.6882314202562039 -0.6882314202562039 -0.6882314202562039 -0.6882314202562039 -0.6882314202562039 -0.6882314202562039 -0.6882314202562039 -0.6882314202562039 -0.6882314202562039 -0.6882314202562039 -0.6882314202562039 -0.6882314202562039 -0.6882314202562039 -0.4364572659523192 -0.4364572659523192 -0.4364572659523192 -0.4364572659523192 -0.4364572659523192 -0.4364572659523192 -0.4364572659523192 -0.4364572659523192 -0.4364572659523192 -0.4364572659523192 -0.4364572659523192 -0.4364572659523192 -0.4364572659523192 -0.4364572659523192 -0.4364572659523192 -0.4364572659523192 -0.4364572659523192 -0.4364572659523192 -0.4364572659523192 -0.4364572659523192 -0.4364572659523192 -0.4364572659523192 -0.4364572659523192 -0.4364572659523192 -0.4364572659523192 -0.4364572659523192 -0.4364572659523192 -0.4364572659523192 -0.4364572659523192 -0.6093243100848463 -0.6093243100848463 -0.6093243100848463 -0.6093243100848463 -0.6093243100848463 -0.6093243100848463 -0.6093243100848463 -0.6093243100848463 -0.6093243100848463 -0.6093243100848463 -0.6093243100848463 -0.6093243100848463 -0.6093243100848463 -0.6093243100848463 -0.6093243100848463 -0.6093243100848463 -0.6093243100848463 -0.6093243100848463 -0.6093243100848463 -0.6093243100848463 -0.6093243100848463 -0.6093243100848463 -0.6093243100848463 -0.6093243100848463 -0.6093243100848463 -0.6093243100848463 -0.6093243100848463 -0.6093243100848463 -0.6093243100848463 -0.6997646999628921 -0.6997646999628921 -0.6997646999628921 -0.6997646999628921 -0.6997646999628921 -0.6997646999628921 -0.6997646999628921 -0.6997646999628921 -0.6997646999628921 -0.6997646999628921 -0.6997646999628921 -0.6997646999628921 -0.6997646999628921 -0.6997646999628921 -0.6997646999628921 -0.6997646999628921 -0.6997646999628921 -0.6997646999628921 -0.6997646999628921 -0.6997646999628921 -0.6997646999628921 -0.6997646999628921 -0.6997646999628921 -0.6997646999628921 -0.6997646999628921 -0.6997646999628921 -0.6997646999628921 -0.6997646999628921 -0.6997646999628921 -0.5422581250564131 -0.5422581250564131 -0.5422581250564131 -0.5422581250564131 -0.5422581250564131 -0.5422581250564131 -0.5422581250564131 -0.5422581250564131 -0.5422581250564131 -0.5422581250564131 -0.5422581250564131 -0.5422581250564131 -0.5422581250564131 -0.5422581250564131 -0.5422581250564131 -0.5422581250564131 -0.5422581250564131 -0.5422581250564131 -0.5422581250564131 -0.5422581250564131 -0.5422581250564131 -0.5422581250564131 -0.5422581250564131 -0.5422581250564131 -0.5422581250564131 -0.5422581250564131 -0.5422581250564131 -0.5422581250564131 -0.5422581250564131 -0.6508734063103988 -0.6508734063103988 -0.6508734063103988 -0.6508734063103988 -0.6508734063103988 -0.6508734063103988 -0.6508734063103988 -0.6508734063103988 -0.6508734063103988 -0.6508734063103988 -0.6508734063103988 -0.6508734063103988 -0.6508734063103988 -0.6508734063103988 -0.6508734063103988 -0.6508734063103988 -0.6508734063103988 -0.6508734063103988 -0.6508734063103988 -0.6508734063103988 -0.6508734063103988 -0.6508734063103988 -0.6508734063103988 -0.6508734063103988 -0.6508734063103988 -0.6508734063103988 -0.6508734063103988 -0.6508734063103988 -0.6508734063103988 -0.6985513111559237 -0.6985513111559237 -0.6985513111559237 -0.6985513111559237 -0.6985513111559237 -0.6985513111559237 -0.6985513111559237 -0.6985513111559237 -0.6985513111559237 -0.6985513111559237 -0.6985513111559237 -0.6985513111559237 -0.6985513111559237 -0.6985513111559237 -0.6985513111559237 -0.6985513111559237 -0.6985513111559237 -0.6985513111559237 -0.6985513111559237 -0.6985513111559237 -0.6985513111559237 -0.6985513111559237 -0.6985513111559237 -0.6985513111559237 -0.6985513111559237 -0.6985513111559237 -0.6985513111559237 -0.6985513111559237 -0.6985513111559237 -0.45244725477787 -0.45244725477787 -0.45244725477787 -0.45244725477787 -0.45244725477787 -0.45244725477787 -0.45244725477787 -0.45244725477787 -0.45244725477787 -0.45244725477787 -0.45244725477787 -0.45244725477787 -0.45244725477787 -0.45244725477787 -0.45244725477787 -0.45244725477787 -0.45244725477787 -0.45244725477787 -0.45244725477787 -0.45244725477787 -0.45244725477787 -0.45244725477787 -0.45244725477787 -0.45244725477787 -0.45244725477787 -0.45244725477787 -0.45244725477787 -0.45244725477787 -0.45244725477787 -0.6261675112820656 -0.6261675112820656 -0.6261675112820656 -0.6261675112820656 -0.6261675112820656 -0.6261675112820656 -0.6261675112820656 -0.6261675112820656 -0.6261675112820656 -0.6261675112820656 -0.6261675112820656 -0.6261675112820656 -0.6261675112820656 -0.6261675112820656 -0.6261675112820656 -0.6261675112820656 -0.6261675112820656 -0.6261675112820656 -0.6261675112820656 -0.6261675112820656 -0.6261675112820656 -0.6261675112820656 -0.6261675112820656 -0.6261675112820656 -0.6261675112820656 -0.6261675112820656 -0.6261675112820656 -0.6261675112820656 -0.6261675112820656 -0.7461838992404664 -0.7461838992404664 -0.7461838992404664 -0.7461838992404664 -0.7461838992404664 -0.7461838992404664 -0.7461838992404664 -0.7461838992404664 -0.7461838992404664 -0.7461838992404664 -0.7461838992404664 -0.7461838992404664 -0.7461838992404664 -0.7461838992404664 -0.7461838992404664 -0.7461838992404664 -0.7461838992404664 -0.7461838992404664 -0.7461838992404664 -0.7461838992404664 -0.7461838992404664 -0.7461838992404664 -0.7461838992404664 -0.7461838992404664 -0.7461838992404664 -0.7461838992404664 -0.7461838992404664 -0.7461838992404664 -0.7461838992404664 -0.7018563514656831 -0.7018563514656831 -0.7018563514656831 -0.7018563514656831 -0.7018563514656831 -0.7018563514656831 -0.7018563514656831 -0.7018563514656831 -0.7018563514656831 -0.7018563514656831 -0.7018563514656831 -0.7018563514656831 -0.7018563514656831 -0.7018563514656831 -0.7018563514656831 -0.7018563514656831 -0.7018563514656831 -0.7018563514656831 -0.7018563514656831 -0.7018563514656831 -0.7018563514656831 -0.7018563514656831 -0.7018563514656831 -0.7018563514656831 -0.7018563514656831 -0.7018563514656831 -0.7018563514656831 -0.7018563514656831 -0.7018563514656831 -0.36013871027066185 -0.36013871027066185 -0.36013871027066185 -0.36013871027066185 -0.36013871027066185 -0.36013871027066185 -0.36013871027066185 -0.36013871027066185 -0.36013871027066185 -0.36013871027066185 -0.36013871027066185 -0.36013871027066185 -0.36013871027066185 -0.36013871027066185 -0.36013871027066185 -0.36013871027066185 -0.36013871027066185 -0.36013871027066185 -0.36013871027066185 -0.36013871027066185 -0.36013871027066185 -0.36013871027066185 -0.36013871027066185 -0.36013871027066185 -0.36013871027066185 -0.36013871027066185 -0.36013871027066185 -0.36013871027066185 -0.36013871027066185 -0.5238855727602139 -0.5238855727602139 -0.5238855727602139 -0.5238855727602139 -0.5238855727602139 -0.5238855727602139 -0.5238855727602139 -0.5238855727602139 -0.5238855727602139 -0.5238855727602139 -0.5238855727602139 -0.5238855727602139 -0.5238855727602139 -0.5238855727602139 -0.5238855727602139 -0.5238855727602139 -0.5238855727602139 -0.5238855727602139 -0.5238855727602139 -0.5238855727602139 -0.5238855727602139 -0.5238855727602139 -0.5238855727602139 -0.5238855727602139 -0.5238855727602139 -0.5238855727602139 -0.5238855727602139 -0.5238855727602139 -0.5238855727602139 -0.6804249705341022 -0.6804249705341022 -0.6804249705341022 -0.6804249705341022 -0.6804249705341022 -0.6804249705341022 -0.6804249705341022 -0.6804249705341022 -0.6804249705341022 -0.6804249705341022 -0.6804249705341022 -0.6804249705341022 -0.6804249705341022 -0.6804249705341022 -0.6804249705341022 -0.6804249705341022 -0.6804249705341022 -0.6804249705341022 -0.6804249705341022 -0.6804249705341022 -0.6804249705341022 -0.6804249705341022 -0.6804249705341022 -0.6804249705341022 -0.6804249705341022 -0.6804249705341022 -0.6804249705341022 -0.6804249705341022 -0.6804249705341022 -0.6050764770369429 -0.6050764770369429 -0.6050764770369429 -0.6050764770369429 -0.6050764770369429 -0.6050764770369429 -0.6050764770369429 -0.6050764770369429 -0.6050764770369429 -0.6050764770369429 -0.6050764770369429 -0.6050764770369429 -0.6050764770369429 -0.6050764770369429 -0.6050764770369429 -0.6050764770369429 -0.6050764770369429 -0.6050764770369429 -0.6050764770369429 -0.6050764770369429 -0.6050764770369429 -0.6050764770369429 -0.6050764770369429 -0.6050764770369429 -0.6050764770369429 -0.6050764770369429 -0.6050764770369429 -0.6050764770369429 -0.6050764770369429 -0.6440334745784803 -0.6440334745784803 -0.6440334745784803 -0.6440334745784803 -0.6440334745784803 -0.6440334745784803 -0.6440334745784803 -0.6440334745784803 -0.6440334745784803 -0.6440334745784803 -0.6440334745784803 -0.6440334745784803 -0.6440334745784803 -0.6440334745784803 -0.6440334745784803 -0.6440334745784803 -0.6440334745784803 -0.6440334745784803 -0.6440334745784803 -0.6440334745784803 -0.6440334745784803 -0.6440334745784803 -0.6440334745784803 -0.6440334745784803 -0.6440334745784803 -0.6440334745784803 -0.6440334745784803 -0.6440334745784803 -0.6440334745784803 -0.5716205957425191 -0.5716205957425191 -0.5716205957425191 -0.5716205957425191 -0.5716205957425191 -0.5716205957425191 -0.5716205957425191 -0.5716205957425191 -0.5716205957425191 -0.5716205957425191 -0.5716205957425191 -0.5716205957425191 -0.5716205957425191 -0.5716205957425191 -0.5716205957425191 -0.5716205957425191 -0.5716205957425191 -0.5716205957425191 -0.5716205957425191 -0.5716205957425191 -0.5716205957425191 -0.5716205957425191 -0.5716205957425191 -0.5716205957425191 -0.5716205957425191 -0.5716205957425191 -0.5716205957425191 -0.5716205957425191 -0.5716205957425191 -0.5311888217657855 -0.5311888217657855 -0.5311888217657855 -0.5311888217657855 -0.5311888217657855 -0.5311888217657855 -0.5311888217657855 -0.5311888217657855 -0.5311888217657855 -0.5311888217657855 -0.5311888217657855 -0.5311888217657855 -0.5311888217657855 -0.5311888217657855 -0.5311888217657855 -0.5311888217657855 -0.5311888217657855 -0.5311888217657855 -0.5311888217657855 -0.5311888217657855 -0.5311888217657855 -0.5311888217657855 -0.5311888217657855 -0.5311888217657855 -0.5311888217657855 -0.5311888217657855 -0.5311888217657855 -0.5311888217657855 -0.5311888217657855 -0.6986271931040996 -0.6986271931040996 -0.6986271931040996 -0.6986271931040996 -0.6986271931040996 -0.6986271931040996 -0.6986271931040996 -0.6986271931040996 -0.6986271931040996 -0.6986271931040996 -0.6986271931040996 -0.6986271931040996 -0.6986271931040996 -0.6986271931040996 -0.6986271931040996 -0.6986271931040996 -0.6986271931040996 -0.6986271931040996 -0.6986271931040996 -0.6986271931040996 -0.6986271931040996 -0.6986271931040996 -0.6986271931040996 -0.6986271931040996 -0.6986271931040996 -0.6986271931040996 -0.6986271931040996 -0.6986271931040996 -0.6986271931040996 diff --git a/dbms/tests/queries/0_stateless/00953_ml_test.rock_auc_reference b/dbms/tests/queries/0_stateless/00953_ml_test.rock_auc_reference deleted file mode 100644 index a760c5b44b6..00000000000 --- a/dbms/tests/queries/0_stateless/00953_ml_test.rock_auc_reference +++ /dev/null @@ -1 +0,0 @@ -0.7692307692307693 diff --git a/dbms/tests/queries/0_stateless/00953_ml_test.sql b/dbms/tests/queries/0_stateless/00953_ml_test.sql deleted file mode 100644 index 8da2a81fb5c..00000000000 --- a/dbms/tests/queries/0_stateless/00953_ml_test.sql +++ /dev/null @@ -1,25 +0,0 @@ -CREATE DATABASE IF NOT EXISTS test; -DROP TABLE IF EXISTS test.defaults; -CREATE TABLE IF NOT EXISTS test.defaults -( - param1 Float64, - param2 Float64, - param3 Float64, - param4 Float64, - param5 Float64, - param6 Float64, - param7 Float64, - target Float64, - predict1 Float64, - predict2 Float64, - predict3 Float64, - predict4 Float64, - predict5 Float64, - predict6 Float64, - predict7 Float64 - -) ENGINE = Memory; -insert into test.defaults values (2.096042154435875,-1.430135166863733,0.552002055283785,5.530269265662427,-2.724119998880863,-2.727060497877947,-2.6521663150493935,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(2.156034808051058,-0.4519877395933891,0.34558837162895817,2.2798791370166707,-1.2600139205601857,-2.314726182739184,-0.9176776519268379,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(2.0227012823747095,0.7073993763424218,-2.526579837235766,2.8884210818462503,-0.04921172682949959,-0.9351603686160936,-0.5773308731642317,1.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(1.461704796035435,1.2400054513675245,1.3110456913590716,-1.22465515713176,-0.7935030458046264,-1.103533329941002,0.5919719712269023,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(2.3957050452186377,-1.9316918657725441,0.9190142057288935,7.155955775162267,-2.8869703029890026,-3.0234929608286194,-4.304748904849194,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(1.392556430407127,-1.7794168780763924,2.1181012869348086,-0.6814309766916051,2.00404915245683,-1.7928635680687615,-2.425109137822439,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(1.9685507597915972,0.8408759652866196,-1.2607782469598254,-1.5515619975922614,2.3915793036512913,-0.8003752729444923,0.3318055683772181,1.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.365215205131582,1.6421911754887804,-0.470904627839269,-2.195888125979813,0.9714278325597505,0.5976321868124256,1.1540464822511913,1.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.3351152167766934,0.9498577915117139,-0.879126536282473,-2.971335010973352,2.468544204807239,0.5553774318661323,1.093198284507689,1.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.03912510876000452,-1.3322341365102917,1.6434865408453003,2.7281117051531183,-2.719490284062717,-1.2856678156526198,-1.087994719221058,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.8110134301050786,0.10305735724313725,-0.019183566058287527,1.478933303100145,-0.8948542269544303,-0.7185915708657821,-0.5378349211144934,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.013571717295999042,-2.1401875522838942,1.5751388914372026,2.869365994906071,-2.263892397950471,-1.5905392928904198,-1.317250564711623,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(-1.3815235147212976,-0.9616053368120304,2.8150588272277965,0.14759793530998425,-1.620992799677878,0.20786388505596268,-0.9816032789320823,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(-0.11407654661743705,0.768404354463356,-0.3930175233254567,2.3015784648119375,-1.7211987426998967,0.45519975382978,-0.6156907430410832,1.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(1.8478239086918133,1.5409911767774376,1.6994582902088935,-0.941221552716078,-0.5161849474607861,-1.0836831033224825,-0.4295520072868204,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.05455524769902653,-0.44441732196125217,2.708301849219744,-4.119367835878758,1.145934474605499,-0.7195943706636994,0.790664128197853,1.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(2.1969604043817803,-0.32118839886233386,0.23529133982375638,2.0406253994414003,-0.9957550724767615,-2.2235912952793635,-0.8800043260355785,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(1.8220150519058342,-0.09416361439372012,-3.047770316012948,5.034883266354364,-2.0143105832194625,-1.5733009655638288,-0.0222530409439472,1.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.0161176246725091,2.6217682547175736,0.9626736958220774,-7.396443060155276,3.4854283180461727,1.4376798844052319,2.2403875697818205,1.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(1.5082554497694574,1.8467142393208946,1.6327843990728441,-3.2881109608057573,-0.4321005482505421,-1.0603588475156511,1.8575619836721444,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.42260650162006874,0.41155861800999316,0.7982889881884394,-0.7237985064171936,-0.8285415729659753,-0.5825003405465955,0.7630457046521066,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(2.4984953879098306,-1.1006932402217684,-0.4488170035755814,5.409789404959963,-2.734678167398622,-2.9680022720016557,-1.6313962465437406,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.9436912987053148,-1.9262688389287774,1.314850116820961,6.396062133529162,-2.842471758246596,-1.7716503301033386,-4.152218598373375,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(-0.16349909844947885,-2.1701452208414933,2.568526586668546,3.397671556920363,-0.8976577440476563,-0.7471631706579982,-4.256758308439956,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.43511790495037683,0.5111546228572755,1.5168239103908907,1.604718301244254,-2.095124808747114,-0.4602828633136912,-1.1177938053615741,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.5413156314344527,0.09335263935887883,0.5612958143676673,-3.7986008152463135,1.8342221950246018,-0.5809729319600001,1.6392301667689284,0.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(-1.4504814727811615,1.3493103008673883,-0.04616646907891209,1.3117933064479026,-0.7702114172619944,2.2759289480635956,-1.3306427086061552,1.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(-0.5130854076349335,0.6888754268554591,-0.24046616537106735,1.5838074220098308,-1.6445748079667983,0.6567869990109363,-0.10911343377083105,1.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(-0.24277413251186197,0.8473320183553533,0.13183067757383438,-1.285681114811781,0.8555624158828621,0.8394005656843551,-0.03496602415650052,1.0,2.2484776527244863,1.099880417196144,-3.288829727389001,5.753439524022788,-1.8752458625661363,-0.9823515324160276,-1.1222966894793052),(0.8369385120882685,-1.341251823971342,0.9554668074045201,1.4270151216516322,1.3962946241553666,-0.7795883140931273,-3.1902671851058684,0.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(1.1583479751809334,0.517409603059198,-0.6999515579272186,2.051960782143681,-1.715430664432116,-0.9939038452652763,0.23845436310251533,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(-0.8595203894117056,1.586295759104766,3.24464432451852,1.7792981720712642,-3.5599729812558625,1.0339349200010899,-2.0761447233122485,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(0.2187879306043835,0.785516320747686,-0.2648586496544352,-2.8228486010789404,1.128464932373549,0.09723332542813223,1.7886949807027714,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(0.5027908312527922,1.299795068598311,-2.247265548686248,0.3568369726515874,0.3094133364610945,0.4849256444073516,0.9882861752504595,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(-2.323680245156419,1.74815453644885,1.3056727348077939,0.19720821301977268,-1.3307294071180997,2.961691552540972,-1.1567709696086979,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(-3.4660709804341914,3.0020058328582584,1.5532651665598032,1.5583662913164948,-1.817494404470051,5.014323195426371,-3.0261871799657434,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(-0.07263506966702105,-0.9786215483869296,1.9521065048378694,-0.5412416965904013,-0.7526123488568063,-0.9097656582671574,-0.11616596119861677,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(-1.1101210747955936,0.45690435659743034,1.0024061194024203,3.151090618784407,-3.1293373639055435,0.9063184859725469,-1.4156004860432896,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(3.126163478788228,-1.3873077921754309,-1.6696389941434133,2.6802469210649256,-0.681228435146825,-3.632607072537458,0.5151315701276392,0.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(0.35121315158298516,3.269898801839016,-0.3139240954702248,-3.3982176643392235,1.5943902174769407,1.665406096965063,0.9632634643458649,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(0.7468935350733565,2.1854201988656303,-1.5921771449650985,-1.9866930130946439,2.2487176483490816,1.088338402207399,0.5136328198882177,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(-0.8336689441755065,1.9918308776801352,2.2772332104920645,-4.087683288038629,-1.0325983001724792,0.8849166354769218,2.286910253692919,0.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(1.977801713559557,2.047290687529743,-1.892163531069095,0.023277725464046682,1.5086179535693676,-0.02241979904892156,-0.3153319898124409,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(0.0518424311627248,1.8501419588702324,0.8505610339256306,-6.405529783623052,2.0897521277071087,0.570135066692417,3.065661906503785,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(-3.467126967504096,3.5784474447980568,-1.593527155162049,6.595207715742785,-3.872578649012629,5.606447409075812,-3.4752544483201677,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(-0.49490773800501286,1.595739466407145,0.28740296306486357,-3.824557248992501,-0.005517967878073571,0.6713599863888331,3.0557952294935538,0.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(0.544193867668699,2.3262231384923844,2.750917624599606,-3.510182442015632,-1.2164244818530026,-0.12870618351275448,1.4921405703258661,0.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(1.51316443936564,-1.2270576118491379,-0.1511873771860477,5.077623200702221,-2.47128253159166,-2.071110370778194,-1.938581109844371,0.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(0.6113192323231587,1.6659128724858379,-0.26101192082957914,-4.320443128005412,1.661337251012963,0.17282617602319883,2.521205470842835,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(1.8198275616708954,1.3675138581932453,2.4905089781034886,-4.065703441137424,-0.7766613572278701,-1.9487231810266057,2.467596447852433,0.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(-1.9560716071750701,1.8563089934671257,-1.089371283526789,0.45302651466747346,0.5754832357256494,3.377112037476161,-1.1078516930515567,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(1.5014679676763512,1.46456490318075,3.74940663345368,-0.5180207050201467,-0.9701148885455172,-0.7947236401223874,-2.385191842660675,0.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(1.316853101423458,1.2491089344703392,2.3725759643289566,-2.9342129359065137,-0.4183076327718859,-1.155701368032073,0.9779293936805153,0.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(1.1849117352329739,1.3925299588445736,1.5695966090587818,-2.1311823024234813,-0.9067969456142655,-0.9769402104776256,1.3185069398877736,0.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(2.373297959341027,2.775778233617674,-3.987898143897202,4.1703153450619785,0.47977169869012415,0.5341339903160455,-1.8868105390404768,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(2.3482349418405724,-3.1159637626200545,1.322069359815815,2.229373710192031,0.1833587373393235,-3.6718200269675574,-2.167407144040195,0.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(0.8243075201573921,1.3348585688363546,-2.0351861522550223,0.44274131356886665,0.7582729504076067,0.4043388560881777,0.26562738440084566,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(0.9481666208581829,0.22905400262922648,-1.2625401200379784,0.01891167448317009,-0.23629041979461762,-0.8959552087654045,1.483311569076668,1.0,1.0910432278349973,1.4357221361554606,0.4817644424944769,-2.8601508919307315,0.1669223465869939,-0.6543849583116184,1.9832087369769236),(-0.06585868557878616,1.4576378617673251,0.7399321196221702,-5.557327993134892,2.0615711774643364,0.59937804443105,2.443312546568034,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(-0.5617223747915407,-0.536515447514492,-0.9957168928986968,4.77783798052823,-3.0250516363531137,0.04763704320310812,-0.8503674789558922,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(-3.34324723959496,4.3926424059948035,-0.0495291336313155,2.6333253919636106,-1.8973423593226126,5.962186949574377,-3.1074374428513205,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.49887278027307114,2.4772176483573447,0.8766144403424073,-4.412341348998718,-0.06544816902397033,0.17540887369438027,2.973618255958296,0.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(-0.7781653022461528,1.6160279900558963,2.9043194289987406,-1.6138303698874787,-0.3568046596220451,1.4348863906315135,-1.472812006839362,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(1.0193028644873694,1.6299059681175168,0.7720871381731178,-6.526365022144807,3.602358868389331,0.05735615709042067,1.942603137953855,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(1.126058179631438,-0.08021399823747422,0.1845945629753224,0.17818816509562224,-0.738333890554967,-1.3667460232410276,0.6101098938191294,0.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.696410860620625,-0.6276802386587743,2.4836900187897752,-2.0850016187629534,0.24626466623836807,-1.3510098287109322,-0.044478444238072345,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(-2.2180272120355253,2.4305553228334267,-1.5801744943687832,4.862275527923406,-2.2752200612907183,3.8805912201348205,-2.6384927064003305,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(1.7567743245952139,-0.34730069944053166,-0.8948025108160138,3.0380121675012406,-1.1828054695478198,-1.7157828402064659,-0.7250035618486275,0.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.8454701528107351,-1.4667747625694347,1.3994753234952881,0.14108982726971897,-1.4662061418653511,-2.2561833089066807,0.7712682192410636,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.9311255806838445,0.30138652549697587,0.38513967479058675,1.3739433638375038,-1.148015783327944,-0.8064976661502308,-0.6120628161659272,0.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(3.364212163278218,-0.5777774492998544,-2.0960237073085235,2.7292130504797565,0.3929841930243696,-2.9133895273811254,-0.5391544963326877,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(1.0464711573814256,0.6301410336103881,0.6168596799831255,-1.032929924340855,-1.2787522510385279,-1.28640822590547,1.7388375253169488,0.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(-1.422247332703442,1.3099920188712886,2.4073061721409297,2.1870630187898,-2.906653106438294,1.6982591159934275,-2.362573454685344,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(3.1695741682612937,-0.18516594373997697,-0.7713888778777602,3.1151308383183576,-3.0028825960507337,-3.641700075824226,1.1176723514330833,0.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(-1.0201468439854502,2.0949741514552933,0.6385052523919061,1.8831849732743258,-2.2046121941585293,1.961396504470046,-1.341031552473416,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.9381164870495406,0.7569235185409051,-0.04079716532568112,-1.0646216144008618,-2.1229314622801283,-1.4627720410887246,3.205645865534935,0.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.9437251365046566,0.2476269059695898,0.04785469653893282,-3.162644357415593,1.5437021067561914,-0.853674727031123,1.7551166151989124,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.7011087711254909,1.2035331930765993,-1.4398091375364501,-0.22767686518825167,0.8665559020317706,0.35056665369985957,0.3315069768001421,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.7691595700548932,0.23226979363339084,-0.7524159985119943,-2.273159847018095,1.2051808874023429,-0.6613989835734112,1.904431917138825,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(-0.9901267648253292,0.8314035869824183,0.9623028761759912,3.0463733919904152,-2.623962359372865,1.2107802811322752,-1.9252298613127752,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.5670331443146553,1.8504800423581038,-0.644940607788113,-2.7678230888952498,1.5881287762026992,0.6450884188501608,1.2333970014028715,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.7215290147887311,-0.8847639920373926,0.4904341287870997,1.0732294179644357,-0.08407257982238703,-1.0427528377077504,-1.0423316359603254,0.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(-3.0571866679643755,3.3801167219727093,0.7666061453475292,-1.4047601244502173,1.2542122493912302,5.360634400210411,-2.408846721295774,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(-1.14458899707407,0.806558148488993,0.9258314968497899,1.6039908714694096,-1.8099931519413055,1.3287669410436236,-1.2183570331221776,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.0029511283094880714,0.7392527584182871,2.271615106839793,-0.4594423088240106,-1.302932906147438,-0.024854290186172693,-0.6305929459060517,0.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(-1.0262556462492007,3.106727638660441,1.552666143363748,-3.579169866499337,-1.4623529808205205,1.7247030376250396,2.395785937012022,0.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(0.9439810230045693,-0.03450351562051179,-1.8489916117037675,1.627016506901843,-0.2551150847440704,-0.7340241866844871,0.46366450521689084,1.0,-0.027051765610255796,-1.4990882375684091,3.3331673136920816,-2.748342229394801,0.7997536049262695,-1.1364348193148381,-0.48020428945931526),(-0.8995507828338771,2.637194803741764,0.5281828736349332,-5.263580235229065,0.7097535677602926,1.7093409623873352,3.1199605290151666,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(2.2331543227352126,0.576960304218676,-0.676727171313593,1.0171538582152717,-2.82527488357647,-2.6461049785824264,2.6088913588467775,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(-1.884286499274555,1.7159327959050787,3.786765950812899,-6.121056390326268,2.333369727673255,2.6168319013890295,-0.5366786842960347,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(-1.1382122858746933,-0.14299633489223185,0.8327531435987057,1.298580815498469,-0.8627965605758569,0.988030584240615,-1.3967521076705827,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(-0.6303393796237344,4.358235812284331,2.280888586413079,-8.838648817770522,2.239906490938857,2.4513045936352977,2.990325780977093,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(2.4442835629793667,-1.5595422106625365,-0.14785351526730506,2.4592541040486275,-0.0735148069297793,-2.8435659780281113,-1.3676274520194718,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(1.4143700456566066,0.8204418264435885,0.967997405875176,0.42646086353492046,-1.564532879987763,-1.275739590687965,0.1318313864473809,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(1.993790451964731,1.3774074310286606,3.280200674941446,-1.341646747143973,-0.7045036833894341,-1.426903501445604,-1.2265179636048882,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(-0.25515995427833005,-0.4671088714062114,2.2153588526087598,2.313329282416284,-3.5569628024009674,-0.8261756134416534,-0.7263653091644615,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(1.6355961932522634,-1.0282770582100191,-3.2173580488490123,4.559935052970455,-1.1214958228117986,-1.7827022934914223,0.07193385989494827,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(0.3283277042612722,3.4105121001777348,3.2195651165101515,-5.324711721749864,-0.9682526335929017,0.5004787785615196,2.2337122442476227,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(0.754679079237366,1.2099552379791747,-0.4385913525503159,-3.1077997316498673,1.9318023043436465,0.10670563866580032,1.3334679355779948,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(2.0317090865947613,0.8572264240668982,2.4095086017705816,-4.663118509638804,0.16709538369449373,-2.261736697516116,2.4428573077545996,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(2.1693473062725674,0.28205162253200255,-1.9303762140352645,0.9887844009255294,0.9897729061853578,-1.3590499520050627,-0.010177228789967074,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(1.0801920463321826,-0.4298481415473505,-0.33436737741767897,0.8097326513818011,-1.310248231723286,-1.6559624358526785,1.164300884735815,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(-0.04021181298242671,0.22389963328779605,1.9968767300385086,-0.019382197954940554,-1.4497486951865157,-0.29417522140873087,-0.47838412801942587,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(1.1239921256001624,-0.8638540030084805,-1.0178241055718993,-2.2937149162466777,2.565762757868864,-1.2141062999841048,1.274422252538015,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(-0.7413970807889825,1.5875817859558181,0.8403835779082484,-0.06969468265303144,-2.0112826998053173,0.9991342650707755,0.5897487899339218,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(0.21012246579494498,0.7349291140125731,1.1564215797263593,3.067109745050948,-3.8072019508231905,-0.4458351151041659,-0.6775773369205058,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(-0.2786193776514114,0.8391330674680333,-0.4026891923466751,-1.3731305159290677,-0.8305074905865648,0.169874931175302,2.3132805058219574,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(-1.2328709703392624,2.7597725867233383,0.5684016239686696,-2.9566618506267175,-1.5157478752904878,1.7699608909022329,2.8392511093116637,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(0.6871398306249665,-1.4103987067510992,1.0274161223406697,-0.5072792317407046,0.16697719764934948,-1.5964973105562557,0.07247594534487489,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(0.988330670186111,-0.5258004908649867,0.857816493019688,2.905878095316476,-0.3238823556705246,-0.7203927872533037,-3.1935613280291166,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(2.4322721114721757,0.30561297616901784,-1.5190220731160726,1.3743262473426763,-0.37180525132367603,-2.018098080706224,0.6319351503875634,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(1.4632563423687737,0.5381126931941951,0.9013515836533991,-0.4868930388692965,-0.8036249563776104,-1.424272458154115,0.4989428610329456,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(0.9759142028783296,0.0963990665555634,1.080300923613975,-3.059378549550568,1.7637552314639664,-0.8307617709909302,0.5002521536297346,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(0.8451444217468322,2.675124983592143,1.8034394339920048,-6.24356070906137,-0.1404077934628427,-0.4290049368154296,4.083301092855288,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(1.7832957038087498,0.46583490546204087,-2.8377296298346213,1.7314321239250723,1.4637196588786066,-0.5551666584209051,-0.560342527910989,1.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(2.0305985048097615,-0.8136835491751737,-1.5375629006726204,0.23344540733313246,-0.38312070583511015,-2.6407899536879547,2.2682169302221693,0.0,0.09011944877063804,0.4347954089652697,0.9137579529403927,-0.48385631481051244,-1.1073840104411428,-0.29844954258155465,0.6258307943091245),(-4.450198579702571,3.8044895601982978,1.340371422770127,3.236568823054465,-2.7997133244581374,6.476201660322862,-4.069014914211333,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(1.4825506606818901,1.8932394950918274,-1.6402434007292597,-0.6438070488741744,1.5377697938617518,0.2190653369274579,0.10746474982298349,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(-0.12865647469516983,-0.03277446362082159,0.3789672161429233,0.13234961251820676,0.10865846661989931,0.1899002744334014,-0.6210816810053859,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(-0.7483525163782037,1.911632146474509,1.0237857931937804,-5.939983118898138,0.18095426014013039,0.7464913363725915,4.2349290686151395,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(1.4639789336512659,-1.487762211307613,1.2333792712082898,-0.5819847984553231,1.367105196681563,-1.9311626412059815,-1.1352946822318226,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(-2.716437954263598,3.2172228184755456,2.486899575348391,-0.27826500422738343,-1.496858928573759,4.189036022930514,-2.271237075436395,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(2.0984679507408304,-0.39222671785000096,-0.00929742777138598,2.4355790415042984,-1.2773465142555198,-2.2069415614400536,-0.7601011284502681,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(-2.3851061122725956,1.2652524519794195,1.2056559497342312,0.2301402557556724,-0.13853039522345567,3.166739303466531,-2.143757701306856,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(-0.912501321700246,1.0668955351482894,0.031154669474161678,-0.2922639794504092,0.1586320914087691,1.5749108653175503,-0.4654455435433783,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(1.6897500753524755,-1.5877093887419145,-1.7611534048954183,2.033285149958932,-0.45562387935528914,-2.4572133028294783,0.9117001207364435,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(0.03279016425268144,-0.553487415980487,1.5178285275445653,-1.756383753660862,-1.6424327750282592,-1.3694706413196136,2.3514036487381236,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(0.58004120787043,-0.1972292963993476,-0.13424999439900343,0.0644658482737472,-0.5669375045425562,-0.8960436704764648,0.8194123344316495,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(0.3142690816498883,1.9522135610917537,1.3104586637571347,-3.120340694946515,-0.7990786213674381,0.031103936415356134,2.1367311835504337,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(1.2711769727288555,1.0981021590638618,-1.7957098361193409,0.11763102112672769,0.8889146120013874,-0.1919397644256007,0.4140737388483293,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(-0.2753034616688934,0.5396168159983519,-0.25856295996037804,-0.8784121825809064,0.6222845940416049,0.6514517789151233,0.268334498274877,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(-0.054143446852892296,-1.6609882776935554,1.6234667989235132,3.3387697001507917,-0.9389121245324956,-0.5846606129339186,-3.4424309279299794,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(0.26621832805226675,-0.18078638381031364,2.933879140489032,-0.46282747535339114,-1.7199780636897413,-1.01998740911614,-0.406866592293917,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(0.04897174356182843,-0.3676084862290635,0.9387028981245669,0.8918277660343057,-0.7366479777100163,-0.33317336104618817,-0.9185779389595495,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(-0.21696194123607038,0.21555874139491749,-0.005133162761840726,4.209335205163436,-2.985056254482762,0.1462920409430946,-1.4879483835912106,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(1.1919697926532478,-0.06899302259156948,1.011479220945279,-2.6782330940108325,1.4957262168280048,-1.167204400077594,0.5412644793623882,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(0.797384096830145,-2.8858544823493006,1.4613598752639518,4.082334904310998,-0.48025789276661146,-1.8693084187642843,-3.9155728821524383,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(0.8513327899828025,0.7458930410858058,-0.7732225705417501,-1.4870005874864665,0.6145060572057287,-0.45127579686900166,1.5047009176226747,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(1.2510116832256535,0.2754714151780169,-2.265757658761317,1.229877962757745,0.7099703142373317,-0.5550915813556282,0.20254867074113803,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(1.02808083853107,-0.040629553520089345,0.8900206816703727,-1.3480875179776237,1.3442347323117394,-0.7538223926536042,-0.6342339871101205,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(2.695776681946838,-0.8864088092399576,-0.0789578748776445,2.0458434092506015,-0.970225560557315,-3.0770089140411643,-0.3020299079680173,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(1.1631434432249037,0.2854532336635398,-2.390500707033707,1.7344940763151517,0.6923406830495642,-0.36218796498051203,-0.21341989806423345,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(-1.6503048195027281,0.5243299697796613,0.2251840345614935,3.781488078646145,-2.8118176812215054,1.6996229508611647,-1.7849702798837712,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(1.7841357579086083,1.4436543212940578,-4.6726465448085035,6.434459937635292,-0.5846417872195009,0.2849453543668835,-2.0775372719522043,1.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(1.0822211355799545,0.9994266546847871,1.0465138567217758,2.0558098640968043,-2.639498177967953,-0.8840583888113261,-0.6825001012379466,0.0,1.0707345643119455,1.5197069890176385,0.15944323972018903,-3.33715397951527,1.1562569334087802,-0.31728557033406735,1.7330782711294181),(0.848338734345929,-1.4745072026687287,0.37318698837288045,6.0929889409953235,-2.860229206267653,-1.4979288865033067,-3.1150236297626157,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(-1.2995339588833392,1.2407288550263273,2.640609187687466,-5.723460643589443,2.7512517947788786,1.946472506752308,-0.012081582228990029,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.9946726154312155,1.5401885333052683,3.32058260159335,-2.7680757902230586,-1.5330279328773837,-1.0093823869079046,0.8835422971914466,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(-1.1653969392564758,1.8477252075676,1.5154492658344962,-1.5050500138182235,-0.4399475400838969,1.8901940665945647,-0.3337717224590103,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(2.3410474945205646,0.9406941157522144,-0.31346932922698456,-0.5250458393014832,-0.5348245647633945,-1.952646624466109,1.3913067179555951,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(2.4376595283129783,0.12884481167739992,-0.7153536782631447,2.2980804863380264,-4.310130247410337,-3.425970247693062,3.0425484210457308,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(1.4242822094686205,-0.6739175649059916,-1.6207631956139514,0.9215275442056382,-0.2255601728743668,-1.7552758751749484,1.3017469600205345,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.5634426551277789,-1.5471077082024784,2.4165088824982957,-0.07551896335863666,0.7259879191915617,-1.19324872205996,-2.252728223170336,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.4438980206249631,3.2154267346236893,4.344033519574632,-7.789482359991429,0.27392642950548796,0.2323729828915657,2.58660101167189,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(-1.8266978944375327,2.764653149219914,0.44269893736952115,-1.448029334618218,-0.14573666828341858,3.209923834413559,-0.1568551995293309,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.49796742294949103,0.38611648047359515,0.947852631250811,1.921055938334201,-1.6442237026351973,-0.3807946252730803,-1.3171989797300596,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.2825028600006064,2.4079617426078688,1.3943677343584104,-5.068702752063692,0.3262485206507727,0.361686441352446,2.7646386524149182,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.22492901625026118,2.487212601897629,0.26524983577107275,-3.2366605539208284,-0.6423312073077014,0.4599935245385812,2.860371878492055,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(-0.04824496005648782,-0.41434421911898167,3.2271022590248886,-1.7830389885935827,-1.0845055278057123,-0.9148118678714859,0.10175737670186669,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(1.2494445038361341,-1.2605077919460772,-0.5919596470609547,2.65848661076861,-1.137208814184975,-1.89192004138945,-0.36297989181266965,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(1.9368152698009182,1.4026143232862036,2.654968484232417,-0.48052468015489747,-1.4353801796778478,-1.471326764204455,-0.8054078742203845,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(1.1144180116920606,1.9104663145213592,2.66246604484307,-5.074755087317627,-0.19811341338412658,-0.9123477120908239,2.440556004826056,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(-0.39453752442584944,-0.07366743472831994,1.9655786401195567,0.030511897442377315,-1.4873612106122647,-0.15769770005697964,-0.39586406801516416,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(-0.13705225566650903,-1.066340745793812,2.247663742284547,-2.2163700069902466,1.650571100968139,-0.34030614914782426,-1.086715918625918,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(1.257058965850754,-0.4841613444620174,0.11928070954945669,5.903325224092789,-3.2500639441872186,-1.4374965938334754,-2.6101536572472206,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(2.3338018044957725,-0.25783497499040453,-1.912097518989901,1.7897855693470501,0.6967346574866409,-1.8049321045768083,-0.3259566366550859,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(1.1597881133675316,0.18269125188689506,0.8486870733972146,0.9187771036928764,-1.3457464656817628,-1.263601970316707,-0.28154047796298953,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.3007389767680182,0.46484767063945054,-0.4886824605041771,-2.4201895447056203,1.3963201084273231,-0.007673513374869891,1.4417809458190534,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.24963563676970935,2.146378372977968,0.7902446346235774,-5.6573637067026645,1.9861496459522696,0.7047213943168629,2.3463141909563427,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.5836918839436678,1.3008666070056107,0.598629993661711,-0.10362396303302328,-1.5961048239125133,-0.3129853796094125,0.7514037918744904,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(-0.5229752172383009,0.24565782730994223,0.6095967557050924,0.688197893976115,-1.2881263450703708,0.3444699274985082,-0.15860735569730788,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.713159371718102,0.590874479989717,1.8556281124000433,-1.0879792739972094,-0.885690863908573,-0.8000805235607321,0.1725076813209897,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(2.8728203729298416,-0.8175386138217031,0.21256366729230014,1.4640205139258353,-1.175325702074738,-3.3996480522044146,0.24937101097686643,0.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.26386100804843426,-0.681937012093828,0.8719546263837685,0.6595807560020865,-1.0334232838287962,-0.9176670256552146,-0.13807803400017815,1.0,2.1588268729540068,-0.12806427617611837,-2.1775450174444995,3.1817127002444545,-0.4258797833112491,-1.683360836803028,-0.46622958963287386),(0.551767614016228,0.7109567026227261,-2.4802658442092,4.901977885732814,-3.066882464644468,-0.2414288804598717,0.13906877696470232,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(-0.9756434098282215,1.5177936333128244,1.0475803709656935,1.4474573922263465,-1.7751753583320031,1.6220531518629306,-1.4700570193599187,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.47763046455062,0.7743296610978223,-2.5287652392342297,0.7391934469677471,2.226326518880974,0.02544798983127873,-0.7676730030660792,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(-0.610702152006014,0.42910678217008225,3.0903157899137983,-5.390224952610268,1.3934337695947003,0.31851454704530224,1.054856662581439,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(3.0958554477794293,-1.4621148020869976,-0.5551243999064688,4.452619430630248,-1.379337013287443,-3.473330945653575,-1.677775172150648,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(3.362080810136683,-1.1400452123643188,0.6638526272830326,4.3778813924145785,-2.415943199028577,-3.8808958633487163,-1.7763856761782737,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(0.9515114782428997,2.5786148051977067,-1.4363545275647995,-0.6681291822406065,1.442317050314664,1.1465667088200706,-0.3269300577214689,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(-2.847938296751167,2.712497525564083,1.1348510423230198,-2.2420055180148903,1.4487652612218769,4.619765374911169,-1.766502892457076,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(-0.8552096265177644,-0.12433378867180744,0.06127441497123598,0.13124974598382613,0.21864608825429177,0.8516308714702762,-0.507455045151372,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(0.9413220120743674,-0.6671836871322345,1.1048795184969697,-0.251817589817712,-0.10041503067356516,-1.389149792100333,-0.26046842750699295,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.8515854524357955,-1.7456600581314028,-0.03925421048801203,1.5179974737998816,0.921332613668205,-2.223550296257367,-1.5207136810245006,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.8801336233511907,-0.4540198439328891,-0.07161754150108735,2.585913277189122,-2.060344360858858,-2.3122434286920814,-0.05721742141110542,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.1565930942796394,2.450186149747695,-0.36499519602591257,-2.6865164333840843,1.7817709621251276,0.5854922377125512,0.5256974003979489,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(2.285833909861166,0.28691651999098333,-1.099897735586095,0.9901853501724588,-0.6044670039367862,-2.050143304937507,0.8657679727222412,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(2.445814401245838,0.617451576980906,-3.6857076155185244,5.807368947766343,-0.7232837434835624,-1.0478351431241741,-1.7664121491248945,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.5724051967604904,1.043672733945267,-2.0466438205717346,1.4988175635419767,-0.022443970841448557,-0.5668460356271273,0.202681936318985,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.767326428923734,1.3282660371650246,0.6148708858259404,-5.476743033106995,0.10974913440714529,-1.9823302577814652,4.841465646867359,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.267326496231199,1.617557661552171,-0.15134447708394183,-3.488157628617435,0.05177221139688082,-0.9171772512777149,3.3253618318584692,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.0726650800289255,1.8463940170697746,-0.8554291334165234,0.2971150824858356,-0.9787305516015852,-0.15059128685897505,0.9251737194989748,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(0.6000678810964989,0.009464861555371407,0.32537504910087334,0.8785831725401735,-1.7720188770580114,-1.041503294055527,0.6853035439619124,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(-0.31903474892623174,-1.9161472026304565,3.249115661818257,-2.064008784693295,2.2511539463109678,-0.4181721655528234,-2.50536511723279,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(-0.27724311948888514,2.269876913502752,-1.0362588939415787,-0.4240851576553433,1.2557043908056547,2.115539216914462,-0.8397651617945024,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.6204471977858825,-0.7472757671052046,-0.44286591935948816,4.984083392550257,-3.765441418069141,-2.3924356302645933,-0.39967559303850064,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(2.4553901093631776,-1.401190635652457,-2.3384856201428965,2.7925686994223646,0.5230823350598678,-2.536900987998952,-0.31452413492174003,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(0.9908721193084293,0.33504947512645533,-0.15004041559882886,1.9914202896753672,-2.15972930497663,-1.1173470973110544,0.2876627916908172,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(-0.4268729371404919,0.0476100000649724,0.7234066075866292,0.9640920579044465,-0.8390128813007733,0.36362579291343516,-0.9290133023411948,1.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.7223130581227628,-1.5033618740143198,-1.0063691155313,3.7129996091186506,-0.18424839092347522,-1.9124490582287537,-1.9006188557753505,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.3863018949780674,-0.8118812038086545,-0.06824465995756457,2.3605677632827864,-1.9190940321241714,-2.074049594905443,0.10164582500649044,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(1.122137640295668,-0.7053791921624009,0.5001218626585733,2.202098650241533,-2.13406560335504,-1.846073420077453,-0.13442355611826817,0.0,0.20030571699179767,0.7574556531157274,-0.9544060121022918,-0.8745823460205342,-0.1314920389612082,0.019391277336385543,1.6943624790905165),(-2.612008274681875,2.9273962705582894,-0.6255802858328701,4.821435572962468,-3.6682637014042756,4.076926276736118,-2.3267975850725797,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(0.14722476209464985,0.7169962280383986,1.30877628107509,0.2902560870390723,-0.5278822077282794,0.2523150652935394,-1.279708896388758,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(-0.7291366403013744,-0.5270029128179039,1.3646324243209347,0.22878411183186387,-0.6994553559333184,0.18645848628858827,-0.7164866293982425,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(2.3179603782898544,-1.8426294837876296,-2.0930634395627186,2.2618833621656558,0.4353521009755007,-2.8422362994637034,0.2651206458970319,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(0.16403922504683877,4.218117350808432,-1.464621892755238,0.4525429538867001,-1.1098371609469235,2.24664042651435,0.36048324675723487,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(-0.3213609724022466,-0.025854561408853893,2.639880414243348,-2.0411613386965612,-0.2566331978960029,-0.15905221997635197,-0.12531363631323988,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(-0.5267173926293351,-1.2061059553159688,1.0942381290703467,5.103189751648365,-3.4155924589635265,-0.4164954791259518,-2.502649328522689,0.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(-0.4855645347515395,0.23735171533067967,-0.5003708194846357,1.7804232308433463,-0.7957779583467628,0.6944973953194824,-0.7601873835159783,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(-2.3971333169627815,2.1868183332652453,3.3450712958825215,-4.719603701036977,1.4718198666990285,3.3830233233505638,-0.9827919370657879,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(2.11857678473749,-0.2366895620149072,1.2347293251374487,2.4546831756152896,-1.8039261811587064,-2.269262710480983,-1.4811644132395334,0.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(0.9259627347147839,-1.2059713052048235,1.6474462871354079,0.788474193584277,0.4987767692224161,-1.2387227304804325,-2.2836695458167746,0.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(-3.000029275289839,2.924265303236554,1.5287904697666397,1.8091750655228505,-2.173785091949717,4.4352889084307785,-2.7944599158598593,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(0.509417258150962,0.9345200865941814,-1.2065038607091274,-0.7231863787024786,0.529992343413479,0.12208026281018039,1.064059623279838,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(0.843381208944096,-0.7839641420793553,1.1047338725131475,3.200498581509832,-3.6879624786217464,-1.9826767010553936,-0.17031233402775825,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(0.6996453363330898,1.834603462699156,-1.9563488472181594,-0.8078842985019533,1.603757579443418,0.9023581741197092,0.4157203160510998,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(1.8780698333418597,1.5711743895099697,-1.1532301645027747,-0.1279147199475934,0.3940852348745265,-0.6780554823489231,0.47599660994228743,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(4.074460008738832,-0.7586132247609974,-0.40680550183518793,2.80044141991812,-1.3520950083731564,-4.299897567538348,-0.23018611363621466,0.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(2.537343474263246,-2.346504411277027,1.0696587867609815,-0.09139515915291577,2.6976348801496677,-2.9037343661704513,-2.358064375853471,0.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(0.13810538048698184,0.4972293743727757,0.5170017632088637,3.8074275771962216,-3.441529620481504,-0.2520767485969924,-1.1460977221077522,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(-0.3716927651804762,1.5264964546073356,1.4116615829468997,-3.2696400437607975,-0.44330241396466785,0.5126776429602927,1.8969558924443808,0.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(-3.914146075904356,2.642868730715806,0.756953442096455,4.602054020453453,-3.1534100284140263,5.342012379341791,-4.033424004180775,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(0.6610025539601961,0.47098027882213267,0.09948302448982482,-3.936612690667609,2.4394531934109507,-0.2612419251520717,1.4621079847055367,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(-0.7686849946406735,2.704509185058657,1.3450572364169955,-7.822928994397781,2.9044544260546163,1.9358105418972935,2.7734907448226678,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(1.080539638439189,-2.1322877957031263,1.6986178322913714,0.36371624049923845,1.429812500230177,-1.7326917232712606,-2.4425242014940247,0.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(-1.167900481192102,0.1355097193610142,2.9097040430835177,-3.6404520903908724,0.9713474861844931,0.8816977448790321,-0.15831403216669404,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(-0.45514503610371104,-1.9645298836180913,2.3714681761255285,2.487263886450227,-1.4334710076423254,-0.7560866446214036,-2.677795087997294,0.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(2.205533638434593,0.1522422005591213,-1.2695825588015412,2.5717611851063906,-2.15564597325238,-2.3135028542159386,1.0008109723209975,0.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(1.1514247059211036,-1.0644545346285557,0.889971896861668,-0.8027781017855179,0.612875597105246,-1.7103926464884456,-0.014562305063810954,0.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(0.9177035463916016,1.3689702950747875,-1.3645490052164024,0.12947308667161297,0.383804924036368,0.15022529478155294,0.3474568882561838,1.0,-0.27127739049078037,1.2031874008603718,1.7773167215990346,-7.727460299109753,2.3889506493244994,0.3060921998513676,3.489168955680098),(1.0510311481075103,1.6986541281639824,1.4298397013825055,-2.24828571804734,-0.6193865199766544,-0.5672340485010048,1.131261958671076,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(-0.10475037404319854,1.9826630391809927,-0.4359458701822585,-1.9789206321994306,-0.5553707561694275,0.7295103208665263,2.2600055064016873,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(-0.43499110833343724,1.5870101815511446,0.9402541543282176,-2.933159361296762,-0.5955365826478517,0.6100236545656817,2.1125115594475554,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(2.4357050136448253,-0.5731495595770033,0.16933618049977095,-1.7352638099045383,2.4501836994395925,-2.140306061138697,-0.24355599298923802,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(1.9152646709544332,-1.1044398743526131,0.7264309168930094,2.751047949593423,-1.2155360000324171,-2.376314205559085,-1.5965277293217528,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(1.563555126365538,1.5905399716363626,-2.054401768001512,0.12558226223380958,1.579243827915478,0.11405592777658333,-0.21982342334862204,1.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(-0.730455784283673,0.6917046084758414,-0.7228104495687078,3.170055958828353,-1.447442840589877,1.2822906006373609,-1.5715790666666658,1.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(0.5567147832410433,-0.38074277886588925,-0.7250043310190759,2.9890681820702665,-1.7854730460169494,-0.8300350245815701,-0.38466093931103296,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(1.160113601533908,-2.0739287822796264,0.8656089350937013,2.5598075614900306,-0.4549159561400836,-2.039598659196028,-2.035308932344324,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(1.7301212300757651,1.7905058319133835,2.4785558633754987,-3.285854075731725,-0.2969054302783658,-1.2196278928218516,0.9665388396475895,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(0.15809910063242794,2.086280383850715,0.4267158940755982,-5.777388598503115,2.932621582965904,1.0770137767265244,1.8492278105417443,1.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(0.4346732485474898,0.6310734941541358,-1.404853676310947,-1.1002807120165736,1.4475439430359827,0.2545978186733911,0.8147445978455613,1.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(0.7111994909007124,-1.2485377736456615,0.00888551426993378,-2.6270035371594207,1.5232308527755958,-1.511116569724326,1.8232379971332986,1.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(1.7009681274533355,-2.098511498004252,0.49402451683802484,0.28198081101179506,1.092044026606271,-2.5049127881573976,-0.7737045360739153,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(1.350857441471699,-0.9080776890873943,0.4192135312704207,1.0335209980632558,0.5496545069678738,-1.424954540304835,-1.4810527974238206,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(0.6110098767879673,-0.19648138768779044,0.6976256713944607,0.7330099435441839,-0.4509443081740856,-0.6919587079193924,-0.7985836940346585,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(-0.7120668607049034,1.9568572093714138,1.0113558871394959,1.03831694531311,-1.3192489094050812,1.7439853418610345,-1.6131748737045164,1.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(0.025810229759270387,-1.1821577183920273,1.3502904597295187,3.316741043641779,-2.023622604735853,-0.7820762681282083,-2.2180784244243403,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(0.4823313839367841,0.9550640446662372,0.7796517614669789,-6.113481580673545,3.141750466778539,0.037999576976416934,2.1678622639783702,1.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(0.3198057040263189,1.067353282335374,-0.03774758522041055,-4.276016524189581,2.3619524359005077,0.3465583522342412,1.734889684984254,1.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(1.3206279075878253,2.9104551041192077,2.29210751642639,-5.248625098223054,-0.558629284361523,-0.6422444653370927,2.973566459413637,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(0.2335520332662372,-1.3483862701781133,1.6523781388128378,2.032580021967608,-1.9769743403072197,-1.351134129026289,-1.0913704298839408,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(-0.006197780146330656,1.5659161747636117,0.47428711078179253,-4.163105473654435,0.7532395776393404,0.41101356739081774,2.5389845366598145,1.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(-1.653872981072018,2.150652366216212,-0.682391413932038,1.0683573143849745,0.1041132013079018,3.2579744909035644,-1.7333419946625157,1.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(1.1929822852229999,0.6893229432312034,3.666180819002058,-0.8739189672652259,-1.4699333333739455,-1.292656078547559,-1.1401278912126873,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(1.155136793407768,1.556608797804812,2.6765890234500116,-6.068904790037338,0.06903301027490838,-1.3072077729905347,3.3564000590548333,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(0.21045240367371898,2.426324089796932,2.0395576967297147,-5.872734043014707,-0.09982516278127862,0.12243072729230661,3.4253409716774006,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(3.17277330610435,-0.4559861433811748,-1.4534816279072529,5.475931755644249,-2.7552146063412866,-3.221196770695242,-0.8814034920122698,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(1.6588973963601246,0.8461887027217563,0.18477915861912242,-3.5310792828384088,0.25782571964298096,-1.7173208517757454,3.2150078520616185,0.0,0.533518024888681,-1.374203575705224,3.332835310287897,-5.6590997182051685,2.4511299738745937,-1.608623021211426,0.9323095857175738),(0.17118349950674683,1.118995662564974,1.4568293787618913,-0.5051347078771523,-1.7022847156761762,-0.1348235263823884,0.47918217936316587,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(-0.22222924383517895,0.11857662096295907,0.07650096299472098,2.0379158249219897,-1.471446181869702,0.1853732522038508,-0.7926848379983182,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(1.3949446302922746,1.370416982034507,-0.3726578951573005,-1.507865895566473,-0.619512343610795,-1.0233127750108155,2.253197907579775,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(1.1892991131649973,0.2446002905843807,1.5298718807562723,-2.099232339908538,-0.5056025526011423,-1.5804405058815307,1.378631760774571,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(1.9397609220772734,0.14612060976419405,0.003327490192374327,1.4823264748097986,-2.108057107017595,-2.2375080799048814,0.8543685258649079,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(-1.9375716302148769,1.8574155817438662,2.006982221925343,-2.0459560007405906,0.6658052443469802,2.9620627786230567,-1.5001878399436688,1.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(-0.2402192482549249,0.8729678849935101,2.1191043260999765,-1.8209285767011751,0.0702401507261432,0.5135562190468611,-0.5577240325203157,1.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(2.797645624903333,-1.5347261778272303,-1.4584107801210373,6.541970409599133,-2.25967473302527,-3.1433214379816197,-2.1371760232834607,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(1.2101207627001906,0.8178658070050348,1.345409305335169,-1.9521840925844323,-0.8292096750094382,-1.3207710619636854,1.5018732200296,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(1.6843456669089063,0.48885992756272634,-2.6849559269116936,4.369671523773933,-1.4771168062402,-0.9821022416444716,-0.4805026737266491,1.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(-0.23784839921057732,1.3535111387210395,0.05320924751207967,-1.9541402009569646,-0.3500510709804364,0.5463348385111396,1.7919768604357116,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(0.13128543053550334,0.6798074445687711,-1.6368443198221256,4.528049001062067,-3.362666984877701,-0.02382357706983641,-0.014886019488387747,1.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(0.4538532345705868,-1.726862620300886,1.7759464630443889,0.9705528654666244,-0.49477289232990296,-1.4722744644269066,-1.4293619756392357,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(1.4801653855390309,-0.47453344733200986,-0.09260586995290043,2.687518390442803,-3.092103825000628,-2.3227047457368974,0.8704218574790192,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(0.5218708026806307,-0.06967317420230557,0.7596210580022738,1.4711668879037785,-2.2608212537809083,-1.0556984545567896,0.1697181766634217,1.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(1.4686426053930823,-0.6876980688572898,-2.318133723758386,4.0906358440061625,-2.2111071372497046,-1.888548462638197,0.6761113150287794,1.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(-0.4655020791006943,-0.18262886630424446,1.9618533997695677,0.8126903231715692,-1.989649844992524,-0.17976489249510838,-0.6676474866827617,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(2.6720786039475946,0.30664618627008156,-1.7819670224326658,3.342376634237586,-2.127744178113725,-2.492973506799871,0.6527115800200574,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(0.7709544863051466,2.089208572308133,1.43733785954422,-3.1347865929904026,-0.7427482316186719,-0.29003767369798433,1.9880762501233427,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(2.004914193301878,0.8836225844754194,-2.8167544354447296,3.730548925991903,-0.14698284122574812,-0.6606442717965159,-1.1677908246516493,1.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(2.178670695122552,-0.37343176507494813,1.6102782889058491,-0.289668173735893,-0.5685426730499268,-2.544466773299166,-0.14330590112211938,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(2.450240693081766,-1.7077791947369563,-0.29053907727783956,3.1577977578818204,-1.574125943917932,-3.3781022323795638,-0.35494151519927786,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(0.7949700874472329,-0.6895749747428475,0.5374981044761692,3.165455372090398,-1.3991901354081273,-1.017110351525864,-2.011720496675317,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(0.9997776221443948,2.602928645773437,-0.6342952955734563,-2.148426258044219,1.4364180609082342,0.8128055918648491,0.4823811597366997,1.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(-0.5142831732503337,0.39128528101053817,0.9008320554174565,2.720050611707023,-3.1508830104429366,0.18317686511736905,-0.7187511553625723,1.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(-0.24024843070289092,-1.3426586516159533,1.698263715427241,4.97158422740088,-3.607946860074412,-0.8589087656970434,-2.6384582242582013,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(2.0649229275070042,-0.8691362909724218,0.06127110963748894,-2.4577692790862034,1.3553513321670838,-2.5767544706205916,1.8244096384210655,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(0.0388578224017484,1.569409049304232,1.55168058988638,-2.7338899094060074,-0.4317685880775276,0.28142214179950714,1.2299760646928444,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(1.083150208364903,1.0544201332588858,0.4849275584677891,0.030545098979075733,-0.9479940248019967,-0.675804210647968,0.2250820171268385,0.0,-0.3194215339922578,0.7255222206183422,1.5762774480142578,1.1418654331056297,-2.496329543369968,0.14373598354206546,-0.4739282527711546),(1.321939824236789,-1.7325735166420875,-0.1953762072802312,5.922742281805113,-3.438389085025568,-2.409237434210855,-1.6126418088678278,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(0.08186040177412857,-2.5585139391025904,3.3632598057046548,-0.37100416034089057,1.3575022880583072,-1.1842671469006207,-3.156866442574128,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(0.6532751173456468,-0.1563829566175261,0.38904035718586505,-2.0827142213294705,-0.505080151941329,-1.3800157395745356,2.528797835185646,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(2.315159218931961,-0.09574244146296951,-2.870390868688257,5.331430959491889,-1.6278329123179232,-1.819930686484162,-0.8286246222285059,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(2.235231767737936,0.7854330832954342,-2.148601058467422,1.895492977094104,0.5666083244157072,-1.056258020890489,-0.5215948847904226,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(4.241292917178763,-0.9860709778639231,-2.0009845087092635,0.962148112338849,1.76426913823527,-3.885947965014016,0.1282356911817848,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(-1.1263292028928795,-2.4050273682272323,2.9554910083536323,1.7828090923807403,0.9076886004084566,0.3679450599509102,-4.839058422078569,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(-1.7101470672682688,2.847398191594129,-0.5856330427022973,2.8707227771069346,-2.014245686136327,3.3640164995655213,-1.8361445565243186,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(0.38581091755503416,0.5780440904400403,-0.5071088914742421,-0.6090146252730738,0.060807864136913636,-0.12211047185114299,0.8896074381060197,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(1.5231754402233766,1.9421603486454766,-1.7729788908428823,2.3753911110055963,-1.5997916313255445,-0.3262735124330241,0.2706188768556723,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(2.820843966643821,-0.10692047584327335,0.9321887238014344,1.719981242218561,-1.5089437086452422,-2.919276123151345,-0.6623159052278418,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(-0.6180585065606545,-1.7250090425434537,3.183283866457158,0.6566647784968032,-1.9066003341979854,-1.0063287837463553,-1.1432711661139228,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(0.8520873302590414,0.9591953810947647,0.12676127726500885,0.5343659255630722,-1.8092748172332644,-0.7540690279448913,0.9279444910129341,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(-0.31530621506647705,0.12176928364261552,-1.2806898307327894,7.142595241207153,-3.5977212186784424,0.5510238558258297,-2.725111194146174,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(0.3886220250322657,1.8576914505484492,-0.43244838707799194,-4.044760393601628,2.2839267628076234,0.8096845168000543,1.6330072957261046,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(0.6675726022935767,0.20087089318493057,0.6845200898058594,3.6937800329175112,-5.330865424937081,-1.706760651701588,0.9784018600546389,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(-0.6116081865842736,0.6341537797659369,2.8798713181168587,1.1828301568793216,-2.9571969765156374,0.24906758002449095,-1.2907026715079555,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(0.6989473726151247,1.2498504500564895,0.2060774042696093,1.1690938756831124,-1.5014992194769494,-0.14794637691692877,-0.2834799610847376,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(-1.5273671236385944,0.9999544767906874,2.7703496758203627,1.207722028899153,-2.501911705844986,1.5436946481674476,-1.9786310839177188,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(1.702511351487795,-0.34203109814603394,0.7835851548168504,-1.5405081514894055,0.2849694967382024,-2.0575090526779283,0.9992013412095553,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(0.9665214110949041,-0.19155552919216534,0.7199622529149727,2.9073996081407234,-1.9527120616051468,-1.1166708078512677,-1.5156463719764512,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(0.1972926334458771,0.28276647040138503,-0.5192444905278686,-2.5476955695233556,1.8593101847023514,0.12004744459504944,1.1846881329737942,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(1.0321665520706136,1.9966732155667404,-1.4686236794986778,2.3902186300815456,-4.092727086591983,-0.7734708607085561,2.4499981678087295,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(1.2698946255416441,-1.1605905587383079,0.4187489725358793,2.835484738320932,-0.68793046490086,-1.5864754446600542,-2.017976019601487,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(0.4416798285809602,0.24811827480851545,1.0654898348977437,-0.4024036574325009,-1.0692237349365254,-0.7179061516427682,0.48702102541566117,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(1.6907373915312665,0.5782488154633239,0.599945149500958,-0.2547283719058139,-1.1602651261549966,-1.7138182985715615,0.9289975810399699,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(-0.21388172717674148,0.3670796032199588,1.8010065450197448,-1.5292034217343784,-0.10056573944930569,0.13923292684787758,-0.17493465232059124,0.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(-0.8249165562810634,0.8118811935227044,2.3634010952575495,-8.883011395212582,2.455323134835944,0.3640943002357488,4.16121831002304,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(-1.6123614832674,1.0270743358787555,2.4191824925784884,2.264244528945494,-2.9165944742592664,1.7064826406612614,-2.3591040913743972,1.0,1.391800054486797,2.431427847224013,1.7830407589721604,-3.4889040923857064,-1.6192782127145382,-1.062097100908419,2.899791227533008),(-0.6856967207299276,1.7525897024574661,-1.1579023328670028,2.2589448355407176,-1.2312457357134239,1.8006792346334546,-0.8430752755923367,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(-1.8165914912002683,0.8803866404425429,2.316672635369382,-1.1810808635080954,-0.7924349556466443,1.8423790039564922,-0.7807611895668487,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(-1.5010244046779506,0.34523810497714713,1.3435520505455572,2.1639508161221426,-1.970858397807827,1.4462679112274643,-1.9102916382971258,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(0.5635922598273722,1.4033442818530633,1.683062562422878,1.0596983259384716,-2.158976282461896,-0.1331177596503839,-0.9781682769599302,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(0.28304003232809394,0.7811221245610349,-1.3923039114076419,3.99712372860234,-3.032968329036988,-0.08346940774160802,-0.044461198603807706,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(2.173115613211947,-0.45623120871027734,2.175888858443627,2.470563591949725,-1.8629450889871788,-2.445235352837583,-2.2353945966210875,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(-2.202431357080454,1.7546984246056434,1.1591425658354584,3.296837897884164,-2.99390938476279,2.901907693620618,-2.5643861199437623,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(1.2507060234279137,2.247796821591938,1.6608145081255743,-4.7160328360136115,-0.29001991756211454,-0.8166791671531242,2.9931321130155855,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(0.15573258355460207,2.172215007412987,1.8398328672983983,-9.111886152079743,3.1988497003563268,0.5434197773241329,3.727484292533844,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(-0.8328725961197609,-0.6837726198347411,2.9609894373395536,0.8541802329628736,-3.0704598054272783,-0.5282371583328125,-0.3954644151370479,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(-0.2305590281166081,2.1714878997598683,1.7808987263571887,-9.091214440959869,4.142077261397787,1.2804508330843913,2.7234893852433366,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(0.8464950859920972,1.8457460443518234,-0.7052530209199774,-0.8099187003486551,-0.49123726501052833,0.00934840017523153,1.4156707278241676,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(-0.7264984103515051,1.58762223148286,1.2543531688970304,-4.576041107988799,2.0471164338092316,1.556043827297222,0.7698900485966396,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(0.6310968833126964,-1.1557887631194408,1.8551643762629424,-1.3835655412181143,1.9814966914722598,-0.8322607453940875,-1.7817987572702223,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(2.1199173655735954,1.0316065570986357,-0.7388254953223654,-1.5610525631124597,1.5291161750630256,-1.1331188201036435,0.6838798263486152,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(0.5793958654817044,1.1370197985890995,-0.42699818741119544,0.451226751321184,-1.1762866346999212,-0.17284061128496353,0.7719883664743177,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(2.8052991708512645,-1.1543441822283065,-0.3079753774879235,0.7547558056367234,-0.39720293791911077,-3.439804665164511,0.8189837917408398,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(1.4024940524681682,0.7830543837865398,-0.11283237135740953,-1.5985039318124916,-0.026048812102019037,-1.1984529193448816,1.7287177333060695,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(3.0147217767070127,-1.0200781629431939,-0.7724586754852318,-1.6645919990450377,1.9943933870089592,-3.191360642502209,1.3263216762617858,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(-0.13531722708660943,1.9535028451727992,-0.04964794910170134,-4.546755747571752,1.8947915970446751,1.1248070457112436,2.0824716923788533,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(0.5780057561867775,2.4389883284494083,-0.06177856070697829,-2.748621215287728,0.45812115038086476,0.6152223729044103,1.5886901010362529,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(1.0546518884657923,0.18234244286557466,0.11030325399538321,3.2191661811958934,-2.36593743964414,-1.0692768734441718,-0.976407733545978,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(1.2933529177327734,-0.30513242091723924,-0.5615862663372806,1.3659303219726464,-1.362414397386018,-1.6806085153310848,0.8272333759272421,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(1.2391823930807615,0.4859918391655791,-0.4928502195038118,3.3616731079156708,-4.091655429873027,-1.7086947303342366,1.1409546244149862,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(-1.5054439327223408,-1.8924109686046506,2.5786138973436095,3.887056714146377,-1.6860332497357198,0.5234956471939621,-4.2927091788856995,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(-1.3147049070042374,2.9550742125471636,2.0805292078567885,-9.458984787991394,2.8909817970255327,2.2781958951820305,3.6332132074095567,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(0.1283229732783333,-1.5808489621836723,0.8581958490255427,5.390836449848271,-2.2509658655011426,-0.782618186639205,-3.5335726851924387,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(1.3314464140423534,0.8129182143050286,-0.8520617594080788,-1.0575404326246254,0.7809407543778316,-0.7064459840496876,0.9995381008322716,1.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(2.880225665985992,-1.0411359815296204,0.0510449350726625,-0.3878704148669313,1.401121588230164,-2.981523988078325,-0.2104726020045955,0.0,1.0567599957823515,1.5799941153962338,-1.4881062038692663,0.47637932703969943,0.16580318903746272,0.14603942213942162,0.2584430082763295),(1.1046212143302618,0.987236550938289,-0.42669185582239033,-4.241325872971698,3.3415739009279566,-0.08424468577629528,1.2092562055909368,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(-1.973789947376512,0.8223402130701964,1.304490015055944,-0.8651390659470903,0.41682754650717646,2.4517085988221443,-1.4055044396931808,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(0.06981536179516334,-1.2065227695226142,2.2774676130672953,-1.1447098015872619,-0.7121456855990037,-1.304068586802913,0.28777483307132834,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(1.9795069078477965,-1.4473444569218747,0.8422773780928017,0.6313697742033327,1.7025648211172815,-2.0075492615530264,-2.333059370251311,0.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(-2.0600652063829266,-0.6333837621853073,3.468536748603692,-0.8913322423271115,-1.757462156010717,0.812572213213716,-0.6022907633519164,0.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(-1.98791867951561,3.031826514239644,-0.7924161436687038,0.12654610966629276,0.7081579465881396,4.176833422654864,-1.6699406256082212,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(0.8426115606298852,1.521152762657554,-0.1337230146189129,-1.4434995314881074,-0.2896581375563225,-0.2428413848621396,1.4665671078648115,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(-0.7284609427171894,-0.0633581959686611,1.1837577791819778,1.4350302630784448,-1.685312280726362,0.3762055904421248,-0.9917669857292509,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(0.13284448420444384,0.48989059418620295,0.649707339140327,3.1534094899577343,-3.2386106987041243,-0.31590614582047116,-0.7870427657819528,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(1.2813990054292852,1.8372801264131764,-2.379643406798959,1.3652576471003457,0.8512744869758768,0.5316461788691897,-0.6156053305262073,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(2.2891125617289863,-1.034466590177339,-0.8528073168005216,0.25565750615528443,0.9498395616806752,-2.48113303573229,0.3410176709625573,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(1.1906881283588873,-1.056056540973113,1.3574824118581417,0.6476728621753428,-0.1322934876060734,-1.6819740111315091,-1.2235936957518294,0.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(-1.3905684814071666,1.2466198898609266,2.259663679830063,-4.14763740755883,1.900848972347196,2.0483451909922756,-0.4555035477919126,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(0.007915404964254469,0.9420317471279528,0.294832519263326,2.582719495108136,-2.3945080639778853,0.28592816588339703,-0.9237809797403697,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(0.583521877945629,0.5331277730352217,-0.48721239763332447,-0.9498752906318381,0.346744013775807,-0.30613068397450366,0.9852227565956533,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(0.3038572775603694,1.8199226286216352,1.7209044780887788,-5.871244361704007,0.03082808989632535,-0.3313693128329034,3.8557824350560352,0.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(-1.4668677560682444,0.615864357805121,1.7525182699336228,-0.8210346671163282,-0.06020757379664965,1.6749795990476146,-1.2205165325854055,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(0.6437634561464207,0.46869838369521777,0.2512633646181748,-4.172634394188566,1.8972887815402877,-0.5040107496571128,2.1281248265853847,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(-2.566685802269739,1.3703937592515176,0.5522319795313368,4.714571322966261,-3.304529843224266,3.1700807408713936,-3.0669517754857556,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(1.4321320759545988,-0.5852717998212875,0.9344530828549473,2.2230574005646426,-3.0763883080523486,-2.405005631784908,0.40557678200484926,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(0.9641855971738517,1.5212499636636303,0.6152159628327369,-0.6607640817743697,-1.6102751585503117,-0.6616239847898601,1.3104820483943997,0.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(1.7048725942936547,1.6561110071176048,-1.6410777840461575,-0.021542409537615766,0.8497272700517364,-0.27637230275554314,0.29379908986403824,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(2.3877637394253206,-1.260106166916444,0.24240366155067983,3.254511285225256,-0.3359126390530982,-2.495451370201776,-2.4430734577527575,0.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(-1.7159795394991253,2.058479403961047,-1.0298338285959132,3.8830429726396325,-1.9236847469944287,3.092667652752938,-2.2573319930263267,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(2.61157813457322,-2.4629468072718197,0.5947853311127764,2.611227042557338,1.956298392040809,-2.746393521796805,-3.94414512547543,0.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(2.100378156997694,-1.0254193606740454,-0.3383292598098695,3.2522179469555192,-0.9092591620666294,-2.3140923190362463,-1.4339917844306427,0.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(-1.5793051540109753,1.6188751709051976,1.3848844184755469,1.166034226400195,-1.1259010183836429,2.4684572651406573,-2.3025016844857564,1.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(-0.16989054765279876,3.48842017914546,1.9300555017851737,-4.960543036879973,-0.584002148725781,1.2038222628858277,2.568256118525951,0.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(1.3846175270079646,2.145798875875564,0.1748386720212266,-4.796962390806608,0.5073503830831803,-0.7852786914681317,3.731869923790979,0.0,0.5800002689945974,-2.1615756870411738,2.5269458208248503,1.9798771742587695,0.21887790707228438,-1.3414848698386221,-3.75764168088647),(2.463498091505543,-1.641948347672444,0.014419220996607973,1.2485427665891868,-0.4093101695125,-3.315069785949253,0.14698377443441846,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.3015458148717531,2.4084218001678828,-1.9377479084764957,0.1461762550285925,1.181541855937334,0.7614544555573661,-0.3175290393124959,1.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.1995047619542676,-0.5685997445105482,-0.7780001688368265,-0.4208529275293881,0.5408090529552546,-1.441434337645698,1.0491529750596622,1.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.2789267591912103,-0.24431600650961838,-1.7008831850097177,-0.3956028703382682,2.2778328150392717,-0.6617441978281935,-0.01943996576935536,1.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.4426854749839935,-0.4544872588795166,-1.5961072511292693,0.12966802768765306,1.393550473376669,-1.1771061322845136,0.352301270605195,1.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(0.3811254347865457,1.3090655871933126,-0.27688380534200907,-3.0070886914719375,1.064692283384284,0.222022515151732,1.8721838900322956,1.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.1193434289666437,-0.6252656232912621,0.23118248743666925,2.685581337005184,-2.153833997930418,-1.6998262419123031,-0.4037349176707249,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(0.929529577814512,-1.7024107022914883,1.2488247870677989,1.2738796125012244,-0.5345104518047759,-1.8796928677805893,-1.1427878473451383,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(0.8362075518180005,1.1085707711145794,0.9854067590709947,-1.314041820148795,-0.7016240360391046,-0.5921632413160102,0.8578333456580334,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(3.5781343752139643,-1.756334316490143,-1.8913637043295912,3.8207236620641587,0.5041362860876586,-3.5985748597254386,-1.4898228334981138,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(0.3438720049323608,-0.24833525627533626,-0.8346231392283516,-1.5319164096905173,0.7676105738102315,-0.5790077722354865,1.78082722778547,1.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(3.0647342782436895,-1.0260134932323655,-1.2844635442292494,4.455520074360008,-0.33555784108704956,-2.780046271993584,-2.251683378416552,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(0.1706511098490927,1.427297039001016,0.16198610469672814,-4.678308717576381,1.9758795045738022,0.4947574282507664,2.2002784569922085,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(-1.562622677878104,1.7307650405142323,0.30622820821123853,-2.7159606100756912,2.3010271547514884,2.9293712371855865,-0.7525506989141675,1.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.3230332705184404,0.43074369107629307,-1.012178677869002,0.3764842669438245,-0.08467152822680513,-0.9691680411489616,0.6840966010729281,1.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(-0.6935320192169789,0.7446618818491898,0.09665333347742111,2.668069679850536,-1.4079283621598315,1.2190489986881268,-1.877269359035067,1.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.6615988715176795,1.4283536020765286,1.1939007488960722,-0.8584576982487286,-0.9666534542260612,-1.1587443010384395,0.44873555048520886,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.3850989235975144,-1.321996217461353,0.6533355400578518,3.765014097672636,-1.0657673636987341,-1.7288501469488284,-2.7515588732367537,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.679404226498682,0.4488111266798771,-0.09194107232644777,-0.1276070545791313,-0.6321422212401715,-1.5847461579670379,0.9576005483141299,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(2.04659758707243,-0.09637025410588262,-0.5301580315997092,2.3882076811218886,-1.1488798805266265,-1.9448358030407187,-0.4760994417763218,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(0.9502778204515043,1.560900513420219,2.6139226644509987,-0.17703081525604314,-1.3385353345210982,-0.31964658388963124,-1.4084087880151692,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(-1.7064636980022851,0.7232269304349839,2.122895762364635,-0.16484613782968235,-0.5171650348762113,1.962539190063468,-1.877610385342741,1.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(-0.27650843111684753,0.8824040605554635,-0.30196780207451157,-2.686121134883907,-0.17986243753961562,0.1554027845787418,2.9180254329681845,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(0.4055828873228918,-1.686704469180161,2.267279261928881,1.4120459259316966,0.32553090572843124,-0.9591177085579479,-3.2406871412917724,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(2.7528205900707885,-0.7838213498913917,0.42720475600569097,2.4810550424721343,-2.2722544267653983,-3.448555825513464,0.07050855537470957,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.1680246800757323,-0.40872210452552404,-0.4508203946039193,1.8115932970624247,-1.3903370815714982,-1.5343584504031225,0.30070498273072843,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.641411139391031,0.13066169098555191,0.013403427494233067,1.5312226380139464,-1.797441178406297,-1.830627427150842,0.4303846195173422,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(1.955478907567246,-1.719506740185793,0.762082256889067,0.1866756780988265,-0.9744041434997593,-3.309776136185275,1.0986283866533104,1.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(2.029214776852436,-0.2878096697019167,0.4084705542378164,1.7382336286765805,-0.6833067762076729,-1.9810690593038442,-1.0883122722276921,0.0,1.695701231263981,-0.16867063677601735,0.5908825136117914,2.718573366080039,-1.3127841726517615,-1.5975869051979485,-1.7507584239074343),(-1.560341449711872,1.5663634023069921,1.0471848595431368,0.1098488111202763,-0.7390036919795584,2.3112166370786724,-1.236752105743788,1.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.2089307327631884,1.9964256833116285,1.226378416624192,-2.4725235681126247,-0.8107018052923085,0.30001515631040365,1.5070634835647967,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.9128041176239442,1.8895100577112083,2.2886808335130913,-3.820954170467079,-0.6052835544037938,-0.623305490142599,1.866033800845503,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(2.993453919875277,-0.901133069473183,-0.0373521979721787,4.2922014798199974,-1.4822374048552227,-3.057711957842002,-2.1409987015165632,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.6766898453496916,-0.5261764912138024,0.7312972156077737,3.9581515737988227,-3.6502190772987513,-1.4820841451981968,-0.7891414274310181,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.14295833912761002,1.6231233113707968,0.18467857172572733,-5.3244744678874545,2.795954007446923,0.8238138676166966,1.929063833460194,1.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(1.7984907565135961,-0.08748991514172744,-1.908421605424304,1.0997506504768602,0.0193869641026021,-1.6007691098789487,0.9508597268855666,1.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(1.4795447177170868,1.558265108527901,2.9519444855092285,-1.7082112440267474,-1.5242435982351923,-1.2321506790399888,0.17024643186890942,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(1.1397560857395845,0.9929628562316919,0.5750597254679413,-5.175405133250185,1.9970886299361146,-0.8051594629268625,2.6421930794939943,1.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(1.2740780719977765,1.1197184976428955,0.651490056121677,-4.4266113109917935,0.15736308604688132,-1.390854468713751,3.651477122782289,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(-1.0402991953119143,-2.06533833303297,3.758708846819417,3.6643483716116036,-1.9836502961873896,-0.15018640286882878,-4.728987719679379,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(1.388042546834122,0.6351311476333177,0.3087393130542635,-0.9747105355778285,-1.2058573277731863,-1.5810825745871568,1.9467994460089018,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(1.6408026773429794,1.4879283180814786,1.547058272073475,-1.3451802114196914,-1.1447992224936614,-1.2638772850029756,0.7853236881637284,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(2.0708542922701993,1.2711484350719897,1.4339591134115544,-0.16035643681145156,-1.184129814417774,-1.5691360483142587,-0.16642233400730944,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.8610958818630077,-1.8798623440397844,0.017309940244927047,1.5547116910354313,-1.2884818488253607,-2.214675539259715,0.5772827870563995,1.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.31017681214048487,-0.5669909849550294,1.9488706008510093,0.8765489312330507,-1.1971421401945954,-0.8532090545239664,-1.265147944962231,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.18497775560572882,0.4850151901864863,-0.6551824564727529,4.63982714028508,-3.2551402962092797,-0.09431469092158731,-1.0924304335485553,1.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(2.4669444008351666,1.859760910530527,-0.10218608993775513,-2.7065907109099916,-1.0087009804989429,-2.1344551850779685,3.6376693906822846,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.8238485766287365,-0.3526798936194202,1.5512566546145274,-0.783457568001856,-0.609118220503116,-1.3676361438381344,0.25775920670818486,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.4279886506498394,-1.318933410675522,1.786893864552341,2.319001466307592,-1.3636960802506595,-1.2080158126691145,-2.140891357760963,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(2.3245577743791705,-1.655861652943644,-0.5357071043474062,3.763999930078965,-0.8970789230750165,-2.833502507806386,-1.5072610448030646,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(1.285195766833195,1.6783115876604113,1.513434891521249,-2.2682980117838745,-0.45638868017239276,-0.7418730885738332,0.9488865767818059,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(1.3481586273438384,0.5174277441556074,0.8785338801961253,2.8147248395427154,-1.9625677135620347,-1.0292085195161238,-1.7895813340376878,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.6954065675726984,-1.3664621081516608,1.5476108546333234,2.180283590956567,-1.293895789561963,-1.5096513815855221,-1.7765071005868003,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.38827399019045394,-0.49792022753587073,1.0198058264078862,-1.5037569154998438,0.6543768219469193,-0.7437803404718291,0.2098285257737864,1.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(-0.3404731340559216,1.2427923266757308,-0.16300461061876503,0.2831612899496902,-0.34457609890571084,1.0720599628234369,-0.3514992450509097,1.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.3161748863138345,0.997351948912386,-1.0801295751777644,0.7571521026186296,0.0016508799060777068,0.48479285742246886,-0.13508160168753358,1.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.12681720829445697,0.11855714969664732,-0.9104184710851837,-1.085292209788002,-0.36232862899070417,-0.46951670408525054,2.366122573967455,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(0.7054632977954634,1.2572176853681154,0.860029635692299,-2.674401827682585,-0.6939897336698935,-0.6804162818791725,2.3309482151237217,0.0,-1.0528115875410609,1.2730779347336945,-0.28721494237508716,4.5331973204986475,-3.0601851835154528,1.6773444164064266,-2.050095126191308),(1.07976657146411,-1.4207183531564556,2.0010660824353304,-3.194648928592429,3.2399872347286767,-1.3523756841739691,-1.1253482654531937,0.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(0.23610519315312728,-1.7449703241490164,1.6819741303788158,-0.10873160707117276,0.05416324589686572,-1.3123804509649377,-0.7907457427267194,0.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(3.0428333674190866,-1.0841060957114639,0.17243967022211515,-2.377637313997145,4.364469885879871,-2.4605659936454316,-1.2447560474503905,0.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(1.6701855712395437,0.2928301757559636,-1.5428673307968002,1.287330415870048,0.2727252075767579,-1.0692518489650513,-0.035616454995755165,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(-3.4800819804037824,2.977389692948332,1.8517753132543673,-0.19008504775532553,-0.7707879065175474,5.033813816903953,-2.5333706554638304,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(1.140202012142074,2.378634968895875,2.7556348176530534,-5.2834702463746215,-0.3652107320195507,-0.7350150171567257,2.5581641229084484,0.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(1.0981169615204438,-1.0119127261725325,2.2820770387227434,-1.9614013769844154,-0.5644666042090782,-2.284934214852611,1.078012639576424,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(0.8517786531323737,3.6302113892867838,-2.0029871207282746,0.2619852928861331,0.17390567848052974,1.6325105715744603,0.09423329683760107,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(1.4165800771742705,1.1149308340527142,-2.271387795418956,0.24518100275596663,1.6930308923123703,0.0011584811148082907,-0.08553747108993615,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(-2.0053022769813875,1.9109759825293087,2.773376480448724,-4.517202660362165,1.395196983263658,2.817448384076263,-0.39825181111140695,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(-0.5355188940690749,0.6018680914829695,0.7541924354853773,1.0775908586661713,-1.0907319838063005,0.7639886786882052,-1.0624390472003777,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(0.6595797552374167,-0.294809475541403,-0.9630206945978195,-1.5012079340321822,1.0098225390572804,-0.8157334681048121,1.6881542023624867,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(-1.720237261284876,0.11277874103206109,1.844572508290903,3.1533623636012984,-3.9104997386815334,0.9943897606151588,-1.3654061835218285,0.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(0.6922463463083346,-0.35073899252145635,1.9626145160108819,0.08179158347355334,-0.9530812260330679,-1.159859309462594,-0.7170911906049338,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(0.6413378935676259,0.1773899280357525,2.490383604140318,-3.8237997263323082,0.3863233217240887,-1.1052859279962846,1.309165949800489,0.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(-0.918763813284105,1.203162397621166,2.561321396321196,-0.3779626409007189,-2.283467449993765,0.8127359401206152,-0.31172201669053634,0.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(-0.41808616994891934,0.6297437830552794,-0.43519990266235187,0.8152590429422543,-0.4861773114380574,0.7939395653553468,-0.2700384949502228,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(0.0589503046935691,1.1096474018520084,0.8430477162065145,1.017463543138896,-1.8449195206430737,0.23001103979814566,-0.41668386521379497,0.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(0.7035305093965771,1.852386714172002,-0.8581310953858379,-2.7047073013316734,1.7544323773483619,0.5857189112040242,1.2179049628159166,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(-2.404521999474064,1.956856261585237,2.743662957828813,-3.763120660309916,1.2341598733468144,3.336518429323325,-1.0843551531070281,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(-1.5787514548491495,0.9043297397824689,0.3647966016141414,1.5615325941265177,-1.2949689138659002,1.9742065688305668,-1.2806827013749367,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(-1.0235078222978835,3.0475095656963602,1.4758089211909295,-8.183689162345186,2.311408931029436,2.0996841788530536,3.4655603211752783,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(1.4171153313833007,1.5601837547522388,-1.788047063738159,0.6536070698420184,0.03991294542935109,-0.23285562477977859,0.5515980511199634,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(2.5943012663247385,0.768939524488533,-4.7102725616072085,6.878524574598383,-0.5433735742893244,-0.8204559726610645,-2.151320262569758,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(2.095928691139254,-1.5364598955767699,-3.539396767334079,9.353427912472746,-5.3917492321240745,-3.143207068564544,0.002434375177712278,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(1.1733973608839687,-0.4779398907232715,-0.8222573364108066,0.5741388087269558,-0.8233349828146013,-1.6623616225589888,1.4089015715206914,1.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(2.5968720217016728,-1.561183647496414,-0.5368548320897575,4.563481344641381,-1.1935320996872132,-2.9643545782562257,-2.0430397264366764,0.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(2.714041736048137,0.026319558085377337,2.358390982988962,1.3832961478997392,-1.1938325736946396,-2.6210410239146587,-2.0630733441327145,0.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(1.0224268255603193,-0.3251567068096688,-0.3890143766789398,4.248774781294234,-1.7156272804262211,-0.9098747934249555,-2.0634504893495587,0.0,1.040593452517384,0.4586921394256398,-0.12933873458544443,-0.318904627037739,-1.0558656645886797,-1.1779996974209512,1.531220594505215),(2.2466469802152655,-0.6104373122047839,0.013869093684521272,1.4174148121004353,-0.9299675669968678,-2.588397575094862,0.05056310478616921,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(-3.734598766339932,4.357711910775082,1.8063222011726097,0.5647484734204162,-1.2668904831697467,6.168350149687059,-3.383175902767071,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(-0.5075416946835463,2.826260938878084,1.6757291381825439,-7.312162195113464,0.5879313407461273,0.9973913776640214,4.309180001467237,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(1.46423411343145,-0.6005198090658379,0.9652261368365875,2.779552976547825,-2.60911189484479,-2.1363879310601983,-0.68726399922343,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(-2.1740091482509643,1.7158438812483352,1.207751628708825,2.1653318489129973,-1.9385559871567524,3.0041298293453407,-2.4842256171560244,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(-0.7576001841832798,-0.007594954223985706,1.0139997501431828,3.0324645799871592,-2.8287853572848425,0.352236350020044,-1.3663697410958096,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(0.22682005310878983,0.17882393778738837,0.6852239252823532,0.6996858648832547,-1.1005329373372745,-0.33694671576753815,-0.2923121947217511,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(1.6420808677485317,-1.567375548263394,1.3596455396410332,-3.18643779804509,2.6618463434153123,-2.2371667201597454,0.22533544015338114,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(-2.4762355913130216,2.18020271868241,1.3238107587214825,3.0782376854873186,-3.2670188241062785,3.2966864834016447,-2.424026089867702,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(0.4681164581671533,2.7802016066061546,2.4377514573974084,-3.504681185661089,-0.33038317365035264,0.576740491675048,0.6678482697206392,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(0.5911030428508862,-0.16060250554086664,-0.01306065642624099,3.934006680488941,-2.120769002361267,-0.6016009232082299,-1.8031712223115948,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(1.174745604954626,-0.4965423351198456,0.5943755851379704,-1.1052321260476299,0.2661649679666236,-1.5726083173913104,0.718004049467069,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(-0.7412751177208392,2.1327090440707304,1.194964453595523,-8.044195522762877,2.831742609518064,1.4456391207259371,3.4658128935875947,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(2.4728274623052195,-1.4446871431555646,-1.473077006061342,4.962183982602092,-0.877344961449386,-2.5959492339011856,-1.96852347020304,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(1.4964109038216507,0.20917901186206578,0.033859363997187364,-0.5696525703041693,-1.37076844681051,-1.950833571036897,2.1420942100235636,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(0.45583852223057186,0.9139217880820522,-0.503312639124806,0.5499114765531566,-1.2222692214056665,-0.20147776675726137,0.8599714517914723,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(-0.2737373806536043,1.27270826072556,0.4760375405877796,-1.801901825509861,-0.692130105318383,0.44709954001227903,1.6095875372621724,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(-1.347794187900541,0.2524553675565264,2.1003710485812177,-2.9225590783504978,1.4128230662455974,1.4304610174764638,-0.6822127662589081,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(0.5871361479153822,-0.8417339321943338,1.1995718501271524,0.8202523967506464,-2.301137318093607,-1.774115856891251,0.8098563835220876,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(-0.21508659002268615,1.569888963274912,0.03986115298828641,-3.9601982606129926,0.9380243205292723,0.7121236564430702,2.5119291735464375,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(2.7941481129839723,-1.0798806957539784,0.025240123668783254,2.633977218875101,1.0284753931360715,-2.3842856430416517,-3.002641820170753,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(0.21207162097481735,0.4647940297522595,0.46295798512172415,0.3232524421339397,-1.6159135710807149,-0.42882666161264194,0.7335086616487765,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(1.4929756391749678,-1.155157311134643,-3.4806846906158686,4.0693214517288965,0.35597074350303237,-1.2793994744342176,-0.6586972623541594,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(1.6854581171681562,0.1834002919426212,2.0365519468046482,3.858832265773903,-2.607252553631471,-1.5355541412174958,-3.1426914316979495,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(2.8327800893646486,-1.7343614197962078,-0.38324008318772385,4.214850202134405,-0.7612512185075357,-3.2089289677127355,-2.1597330449132066,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(0.07122882463582014,-0.6138287383249159,2.384026551347024,-1.7146604393110776,0.6628743724080095,-0.5031775744589227,-0.8780321112073121,0.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(0.5714623898190813,1.8499637809618559,-1.6528766898390757,0.7922648746756872,0.009123352945717644,0.7920546495067624,0.05588645257506697,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(-3.2633273539187027,1.911289368256512,2.065182047264482,1.922313389116063,-1.9358969584812344,4.156853974629493,-3.297822591979971,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(-1.0527594231003512,0.11046706857150712,-0.17034216295607751,2.002056902252602,-1.3909207669150798,0.9854200330466844,-0.729769914147927,1.0,-1.7952716016373547,0.7183349106068199,3.3300598259286227,-1.2033149160706158,-0.7588744068250339,1.7666798904766734,-1.6882292349201322),(1.9857432393597216,-0.797559664346102,-1.8628229075290526,0.7912416658605166,1.1189706285668513,-1.890957287869455,0.41557152949411214,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-2.504762737846811,2.1769977714122506,2.57992693306698,-1.8747939851770445,0.46865410489106774,3.7026137438952347,-2.2438143549852185,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-0.41886628561756134,1.997961493652824,0.45098865921149955,-3.9240951571422404,0.6720821012238447,1.1131211300973887,2.1496317763658626,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-1.269058850471455,0.9113128779485802,-0.987609614890711,5.17453944944951,-2.792635641455655,1.8633254768112497,-2.225434601190937,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(1.60221516530219,0.8573873954567277,-1.2532323321502234,1.4586670560212756,-1.2872866648841212,-1.184906097673008,0.88142213963169,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(0.664945717778535,1.7074410216455105,-0.9164942360480002,-1.7328352122931063,1.042439944629323,0.4681254075262177,1.034268339879112,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-1.0229129860675013,-2.780448032379326,3.2847626195180495,2.509568320419263,-0.8239377084416294,-0.47304522543584926,-3.9581559499963603,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(1.357349140742531,-2.30529006767782,0.09791220462993844,5.626021471718858,-1.5946347715827764,-2.1607839211751037,-3.248371527799422,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(0.19008566471204968,0.9075514438212983,-1.8650607875027787,-0.8680513536341087,0.7997443732584267,0.45238678503301627,1.526885288707088,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-2.9254711696053395,2.1750597750267042,2.1933277965486973,-2.4693963476817404,0.3973459599348179,3.9233999600808573,-1.2357640687177518,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(1.233619763358607,0.9913146965561134,2.3973693810536236,-0.8070564887140679,-1.45741017327986,-1.1664320360973062,-0.13201085846744465,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(0.3161303390254758,0.3276995534451512,-0.02889035651373595,-0.8230808482804979,-0.5319352491047409,-0.47967360079060634,1.36719581140463,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(0.5317287425894308,1.208735839267825,0.08407141955287045,-2.4813609730490715,-0.8888470073318796,-0.6122551141011588,3.060645109675252,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-0.07298769165290997,0.819808188036161,2.0384919882650516,-7.748399227191985,2.2435939891188377,-0.18719747936307643,3.6016374001334093,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-0.7901852621466418,0.5145825360308702,4.637957908386738,-6.150836801745065,1.3912229090534307,0.440132724867259,0.3252310211529108,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(1.831671718235779,0.5977438753380795,-2.321886357828979,2.9104235559256404,-1.017343884238508,-1.1877468146597532,0.22300620292739104,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-2.1539924701669846,1.883675370067507,-1.7680881855073274,5.807546701204832,-2.7646119804927913,3.473472133586789,-2.7200321903160463,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(1.756348176804372,1.7615764405819676,-1.5388289669836195,0.07080621692501461,0.6426698929723338,-0.3106612170666746,0.277797622658288,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-0.2487545187544351,2.609229589371483,1.8882144277890807,-6.154774232631951,-0.5638199006934052,0.43112941318589476,4.2027303973580565,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(0.10955533675333518,0.9087196837335013,0.1136664013383859,-4.1472494266956055,2.014924031822069,0.3431702042196298,1.8459002928252932,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-0.6652930532149404,1.197530864301426,0.9169919325624285,-5.961473613444594,1.8351066038331625,0.8272159997488158,2.950791256392912,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(2.9316838982943185,-0.6964392952831678,-1.1502529215081365,1.4921077726597665,-0.5780146627368032,-3.196356469849491,0.85907655235715,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(2.600077692763368,-1.2623740481307253,-0.8962595005959539,1.9679383389242255,1.2790953056015506,-2.4139441686510956,-1.6329167452667077,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(1.452791564760785,0.41146795445009166,0.14392806279219328,0.17108543131200796,-1.029600784845083,-1.469443131098191,0.8077470058618661,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(0.727098084005239,-2.5546937777149403,1.5105485872014457,-0.29443260630992396,1.1439390403078158,-1.9439707234539425,-1.1506513582879956,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(0.7021391905991415,2.4414499286754787,0.8074093066989305,-6.070712605446909,3.5191034192402006,0.9707334993431298,1.1288619039998729,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-0.9308026588402101,2.57928079368376,1.0748311675888704,-8.529095009719802,3.699706292413457,2.1444358957249268,2.9816820943899875,1.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(1.2360219692964298,-0.8921138259532037,1.324707218340896,-0.13529792443717042,0.03483533664127236,-1.7310071987282634,-0.5952741360978552,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(0.9580721326511403,1.515267173693862,0.9547831554732867,-3.792366629532976,0.14805240219415627,-0.6733000064089022,2.4871576141650023,0.0,0.13732503547731956,-0.3180335699548478,-1.6556599602211124,-1.1968994248078457,1.4860353840717266,-0.10837465708089232,1.4595607106322794),(-0.11224442995910122,1.6882722404753472,1.7161782543665778,-2.9486619700579975,-0.6165883797519401,0.3909989063485372,1.4200766219929295,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.4004498564816448,-0.5483306586274586,0.6884992629346187,1.6860799533920177,-2.4028921057076675,-2.221265193101131,0.4912576499341499,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.239942383240145,-1.5480563981269437,1.8577874744757454,0.7272933808052509,-0.9344450764118416,-2.3269279460451013,-0.7435854860482998,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.4542570156828636,-0.27176912816457977,-0.3618604064197557,-1.502224358768631,0.9678737333818738,-1.5496348751441344,1.2748010290281975,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.1468076270806558,1.2322052468347184,-1.7602650358096363,0.7212280541208039,0.024643216826090497,-0.1814752483470614,0.561492706792226,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.5077003347535025,1.088513118264028,1.7551210104319521,-0.736441038595527,-1.3056362875092131,-1.3166156974158438,0.2511173359195177,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(0.288389962747996,0.36332653636764256,1.6656089747619136,-0.571105661353323,-1.1612868506911342,-0.5432082064452731,0.11792111797788773,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.9995296056005114,1.3529339664784819,-2.3981864910916855,2.9849134331502665,-0.7407438786500962,-0.7264517691858112,-0.3538463287395124,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(-0.08579858389687023,1.7161890418770884,-0.06656951353461293,-4.105281638118306,1.5285630478172285,0.8775192894752291,2.1152291309916,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(0.9661724849567914,-0.40445855460769375,-0.8984041426116092,-0.036985924898836356,-0.8750620577241204,-1.5780799558007883,2.1207161932972505,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(0.8699336332979304,0.6851162561092408,-0.9012433467548683,-1.8635864465365037,1.9301898676639888,-0.0891783038473156,0.689996751808305,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(-3.390371025284407,4.3362614916709905,1.1553623702701241,-0.5402753273558951,-0.7164467112290367,5.759960343500196,-2.098251841172708,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(2.3121549519106877,-0.49079106810872064,1.0874868101059274,1.8775100736563255,-1.832698844916588,-2.771227001345358,-0.5639729980991646,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(0.5317909834339799,-0.31402050735813103,1.5222379228128546,1.1028560181554226,-2.2574716049926096,-1.2763341078397625,-0.0682234152133977,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(2.3489372887473756,-1.902965890195,-1.1058115737668315,6.444396538850495,-1.3013307250524164,-2.59335014865392,-3.2826286389085126,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(0.10352282484992748,1.7763521706893264,-0.98957323888984,-3.092145229794725,2.3159326671997436,1.2326770331559804,1.1091309782040397,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(-0.6781201591090096,-1.2017056619726723,3.1386436103718722,-1.4826197651366986,0.7413994646513105,-0.061222556588136814,-1.8011807696190751,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.3088071867454587,-0.9058060170486686,-1.533795865471077,4.443254383671029,-2.2143075168348214,-1.767491483116837,-0.3779098725243084,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(0.42758387794542607,1.3840546035724883,-0.10889830402413547,-3.1754775666120802,1.2232929860961135,0.25803202005775294,1.7027079999027905,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(0.1914622420587,1.6808636178618053,0.5565573242166482,-1.954492290078305,-0.9510650933441838,0.14161140375081846,1.868522343287696,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(2.327521800555288,1.707072587638922,-0.3408892551572401,-0.7841366540150495,-0.30706125962166064,-1.403400095559777,1.139293148033613,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(-1.6870712174917015,1.691651631532742,-2.288473035077086,4.52043452758501,-1.8935449916089768,2.9237857364797977,-1.609566360393679,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(-1.733708401198054,1.3041639797022042,1.400544122440466,-1.9741481668869392,0.4617729940086308,2.3114245726840337,-0.5274602470044196,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.7575715367081157,0.3753135909060661,-1.2693308636208644,0.5371878918731451,0.5384575757585188,-1.153326220541941,0.20366235231148166,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.4883842771922242,1.7515504950397989,1.038220064787369,-1.3034051909539248,-1.3740421429605687,-1.0453541069418544,1.3316370102880164,0.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.816707826258376,0.9334850907564992,-2.7235167200741737,2.561614634752468,0.5749390983559122,-0.42892177674740073,-0.8151907044116287,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.922399180978037,-0.47398744746047616,-1.086455344591692,0.5421631590354696,-0.17489100087797138,-2.141675253309839,1.1382797565150389,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(-0.4370945240496815,0.7406706373308528,2.3817851052918986,-1.5970867983837052,-0.5383146950358882,0.43966344292078025,-0.39121212011259565,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(1.5227791882404937,0.032628064555142666,-2.7346852692959223,3.6243268586724393,-0.4338687119554254,-0.8963076772737661,-0.5620760681630759,1.0,-1.8640115706592102,-0.40916214327036304,2.2813656654619234,4.344613955177877,-5.128071412845289,0.6023055734635931,-1.5913288564396306),(0.6925555904243851,2.2660402104433004,0.571879255854077,-5.136520159556465,0.23388977994347782,-0.21095746484974373,3.839104184046647,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(-0.6170807446057736,1.1618050798356736,-0.3318054593493467,6.307458106404423,-4.152242368795466,1.164412152487124,-2.6433851880918566,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.09933841297654922,-1.3009113230097453,2.3763024813118814,4.843663490637228,-2.7335802864430874,-0.8152959702787319,-4.019613642468096,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(-0.29723257606972664,1.534048303390355,-0.9278630836202846,4.548220911132926,-2.2312916467625055,1.4265140750671224,-2.3032786031118535,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(-1.8723473627536515,0.9717287860436329,2.3847715433643724,0.7344463319711535,-1.8629044282929315,1.9783943683566731,-1.8140411081153947,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.3005647919287311,0.3806355736171525,-0.27869848922330487,-0.8799959881301632,0.3995051923334578,-0.09156717805815423,0.6758278798998893,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(-0.5955050165131914,1.450567042185088,-0.9897943065169226,2.737681953113439,-0.7663788673735875,1.811148094805718,-1.854983423784701,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(2.9669296357978334,-1.3324159367684048,-3.104836225416732,5.208190995197741,-0.8202049866634673,-2.9861699841871703,-0.7016133155919906,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(-1.228016828510732,1.1216551175944176,-0.8558209427875334,4.258437071067928,-2.7976936142573496,1.759131670682027,-1.4539872453038518,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(1.2339963699690584,-0.2804755708218589,1.4715087228456836,-2.9261144609808616,0.355595728180802,-1.8268629783014674,1.6411674193628243,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.9659087122503214,-0.2548687699578174,2.104950827672197,-6.076161419668977,2.9878426404779534,-1.2192738796045464,1.5970699410759703,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.22061418917082676,1.7175054727901158,-0.5033501522353456,-3.8353548758394256,2.331439472843757,0.9401634108615404,1.4604187484921587,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(1.309907365358922,-0.12990852843173584,1.0737239270579344,0.7337127225434502,-1.246715098799017,-1.6078875928365746,-0.25052374133607436,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(-0.36721164916342697,-1.7079119599701718,3.0068461711549523,0.14826986026046768,-0.8186880144087275,-0.9349454628893296,-1.5313812357768914,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(1.6398796287916704,-0.2454439388782933,-0.3454790010819664,2.792239227481451,0.15344573827886987,-1.0493634503221692,-2.4336157756640855,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.7847363960073463,0.7363916664271204,-1.0119432855225785,-1.9544812667283535,1.277543003992446,-0.2529346594821023,1.5342034566540081,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(1.2232936134800012,-1.163429305152226,1.8203348565681234,-1.2313360448785429,1.1074565407265085,-1.7093423514569264,-0.9078154994566392,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.7585110515783027,1.565377477710182,2.027749458360845,-5.369019478696252,-0.3380358319830341,-0.9500514254177758,3.588791253857626,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.7362390304804842,-1.2017843711210685,0.8926545968864157,1.2399265238688837,-0.050827310016290705,-1.198605392602416,-1.5046056364379843,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.6451221517395296,-2.0484424552178737,0.6171428263446541,6.422100778753815,-2.577636468051222,-1.4890401115179508,-3.785907231054817,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(-1.765086441069906,0.3886895405231462,2.731661900411207,-1.3069068417000809,-0.19766973479399452,1.6879242979289697,-1.449585901495793,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.18985291006333638,-1.0740273879437814,1.2843531782256652,2.9867201516109323,-2.853724333474166,-1.267483825267256,-0.9631441174041762,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.9871628788591412,1.8534178483912092,-1.2805384917990295,-1.092147064487189,1.0822665318842248,0.4024378429492361,0.6510218029229897,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.3717600489367091,0.7167856864650772,-0.7499821639105004,-2.1169534465406232,-0.870825637391141,-0.7319917041438911,3.6275089929559368,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.34781014325513526,-0.42631045215441477,2.276403265265107,-1.7872802807090558,0.6460091472975253,-0.6707279710261537,-0.7145197261034959,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(0.6978341324237667,0.44583514954616277,2.5487409237553997,-3.883754805256149,-0.5331862190361614,-1.3497349443383184,2.16910621644326,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(-0.42196177110466704,2.16561337972615,1.3262059312894516,-5.6286300261936,-0.08711234527451972,0.5828901807272211,3.841164934415239,0.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(-1.16389008844843,1.2429168032114994,1.1288227844364782,-0.8914746299219967,-0.12326393212364906,1.7336169885979524,-0.6957687675851021,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706),(-0.97426704102067,-0.06480324801411252,1.2488895732194991,1.6784228029603945,-2.2987446544566623,0.42970828101052566,-0.7140097535913854,1.0,0.707294952739537,1.5034945173873893,-0.27126234266043536,-1.5739737031307273,-0.23896124879655845,-0.1412674512572589,1.6695598574688706) -DROP TABLE IF EXISTS test.model; -create table test.model engine = Memory as select LogisticRegressionState(0.005, 2, 2.0)(target, param1, param2, param3, param4, param5, param6, param7) as state from test.defaults; -with (select state from test.model) as model select evalMLMethod(model, predict1, predict2, predict3, predict4, predict5, predict6, predict7) from test.defaults; diff --git a/dbms/tests/queries/0_stateless/00954_ml_test.reference b/dbms/tests/queries/0_stateless/00954_ml_test.reference index 8575e00f538..d00491fd7e5 100644 --- a/dbms/tests/queries/0_stateless/00954_ml_test.reference +++ b/dbms/tests/queries/0_stateless/00954_ml_test.reference @@ -1 +1 @@ --66.98005053600168 +1 diff --git a/dbms/tests/queries/0_stateless/00954_ml_test.sql b/dbms/tests/queries/0_stateless/00954_ml_test.sql index 932924672d6..6152053f17a 100644 --- a/dbms/tests/queries/0_stateless/00954_ml_test.sql +++ b/dbms/tests/queries/0_stateless/00954_ml_test.sql @@ -11,7 +11,7 @@ CREATE TABLE IF NOT EXISTS test.defaults insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0), (-1.099, 2.755, -3.060, 20.0, 40.0), (1.090, 2.945, -2.346, 20.0, 40.0), (0.305, 2.179, -1.205, 20.0, 40.0), (-0.925, 0.702, 1.134, 20.0, 40.0), (3.178, -1.316, 7.221, 20.0, 40.0), (-2.756, -0.473, 2.569, 20.0, 40.0), (3.665, 2.303, 0.226, 20.0, 40.0), (1.662, 1.951, -0.070, 20.0, 40.0), (2.869, 0.593, 3.249, 20.0, 40.0), (0.818, -0.593, 4.594, 20.0, 40.0), (-1.917, 0.916, 0.209, 20.0, 40.0), (2.706, 1.523, 1.307, 20.0, 40.0), (0.219, 2.162, -1.214, 20.0, 40.0), (-4.510, 1.376, -2.007, 20.0, 40.0), (4.284, -0.515, 6.173, 20.0, 40.0), (-1.101, 2.810, -3.170, 20.0, 40.0), (-1.810, -1.117, 4.329, 20.0, 40.0), (0.055, 1.115, 0.797, 20.0, 40.0), (-2.178, 2.904, -3.898, 20.0, 40.0), (-3.494, -1.814, 4.882, 20.0, 40.0), (3.027, 0.476, 3.562, 20.0, 40.0), (-1.434, 1.151, -0.018, 20.0, 40.0), (1.180, 0.992, 1.606, 20.0, 40.0), (0.015, 0.971, 1.067, 20.0, 40.0), (-0.511, -0.875, 4.495, 20.0, 40.0), (0.961, 2.348, -1.216, 20.0, 40.0), (-2.279, 0.038, 1.785, 20.0, 40.0), (-1.568, -0.248, 2.712, 20.0, 40.0), (-0.496, 0.366, 2.020, 20.0, 40.0), (1.177, -1.401, 6.390, 20.0, 40.0), (2.882, -1.442, 7.325, 20.0, 40.0), (-1.066, 1.817, -1.167, 20.0, 40.0), (-2.144, 2.791, -3.655, 20.0, 40.0), (-4.370, 2.228, -3.642, 20.0, 40.0), (3.996, 2.775, -0.553, 20.0, 40.0), (0.289, 2.055, -0.965, 20.0, 40.0), (-0.588, -1.601, 5.908, 20.0, 40.0), (-1.801, 0.417, 1.265, 20.0, 40.0), (4.375, -1.499, 8.186, 20.0, 40.0), (-2.618, 0.038, 1.615, 20.0, 40.0), (3.616, -0.833, 6.475, 20.0, 40.0), (-4.045, -1.558, 4.094, 20.0, 40.0), (-3.962, 0.636, -0.253, 20.0, 40.0), (3.505, 2.625, -0.497, 20.0, 40.0), (3.029, -0.523, 5.560, 20.0, 40.0), (-3.520, -0.474, 2.188, 20.0, 40.0), (2.430, -1.469, 7.154, 20.0, 40.0), (1.547, -1.654, 7.082, 20.0, 40.0), (-1.370, 0.575, 1.165, 20.0, 40.0), (-1.869, -1.555, 5.176, 20.0, 40.0), (3.536, 2.841, -0.913, 20.0, 40.0), (-3.810, 1.220, -1.344, 20.0, 40.0), (-1.971, 1.462, -0.910, 20.0, 40.0), (-0.243, 0.167, 2.545, 20.0, 40.0), (-1.403, 2.645, -2.991, 20.0, 40.0), (0.532, -0.114, 3.494, 20.0, 40.0), (-1.678, 0.975, 0.212, 20.0, 40.0), (-0.656, 2.140, -1.609, 20.0, 40.0), (1.743, 2.631, -1.390, 20.0, 40.0), (2.586, 2.943, -1.593, 20.0, 40.0), (-0.512, 2.969, -3.195, 20.0, 40.0), (2.283, -0.100, 4.342, 20.0, 40.0), (-4.293, 0.872, -0.890, 20.0, 40.0), (3.411, 1.300, 2.106, 20.0, 40.0), (-0.281, 2.951, -3.042, 20.0, 40.0), (-4.442, 0.384, 0.012, 20.0, 40.0), (1.194, 1.746, 0.104, 20.0, 40.0), (-1.152, 1.862, -1.300, 20.0, 40.0), (1.362, -1.341, 6.363, 20.0, 40.0), (-4.488, 2.618, -4.481, 20.0, 40.0), (3.419, -0.564, 5.837, 20.0, 40.0), (-3.392, 0.396, 0.512, 20.0, 40.0), (-1.629, -0.909, 4.003, 20.0, 40.0), (4.447, -1.088, 7.399, 20.0, 40.0), (-1.232, 1.699, -1.014, 20.0, 40.0), (-1.286, -0.609, 3.575, 20.0, 40.0), (2.437, 2.796, -1.374, 20.0, 40.0), (-4.864, 1.989, -3.410, 20.0, 40.0), (-1.716, -1.399, 4.940, 20.0, 40.0), (-3.084, 1.858, -2.259, 20.0, 40.0), (2.828, -0.319, 5.053, 20.0, 40.0), (-1.226, 2.586, -2.786, 20.0, 40.0), (2.456, 0.092, 4.044, 20.0, 40.0), (-0.989, 2.375, -2.245, 20.0, 40.0), (3.268, 0.935, 2.765, 20.0, 40.0), (-4.128, -1.995, 4.927, 20.0, 40.0), (-1.083, 2.197, -1.935, 20.0, 40.0), (-3.471, -1.198, 3.660, 20.0, 40.0), (4.617, -1.136, 7.579, 20.0, 40.0), (2.054, -1.675, 7.378, 20.0, 40.0), (4.106, 2.326, 0.402, 20.0, 40.0), (1.558, 0.310, 3.158, 20.0, 40.0), (0.792, 0.900, 1.596, 20.0, 40.0), (-3.229, 0.300, 0.785, 20.0, 40.0), (3.787, -0.793, 6.479, 20.0, 40.0), (1.786, 2.288, -0.684, 20.0, 40.0), (2.643, 0.223, 3.875, 20.0, 40.0), (-3.592, 2.122, -3.040, 20.0, 40.0), (4.519, -1.760, 8.779, 20.0, 40.0), (3.221, 2.255, 0.101, 20.0, 40.0), (4.151, 1.788, 1.500, 20.0, 40.0), (-1.033, -1.195, 4.874, 20.0, 40.0), (-1.636, -1.037, 4.257, 20.0, 40.0), (-3.548, 1.911, -2.596, 20.0, 40.0), (4.829, -0.293, 6.001, 20.0, 40.0), (-4.684, -1.664, 3.986, 20.0, 40.0), (4.531, -0.503, 6.271, 20.0, 40.0), (-3.503, -1.606, 4.460, 20.0, 40.0), (-2.036, -1.522, 5.027, 20.0, 40.0), (-0.473, -0.617, 3.997, 20.0, 40.0), (-1.554, -1.630, 5.483, 20.0, 40.0), (-3.567, -1.043, 3.302, 20.0, 40.0), (-2.038, 0.579, 0.823, 20.0, 40.0), (-3.040, 0.857, -0.233, 20.0, 40.0), (4.610, 0.562, 4.181, 20.0, 40.0), (-3.323, -1.938, 5.215, 20.0, 40.0), (4.314, 1.720, 1.717, 20.0, 40.0), (-1.220, 0.615, 1.161, 20.0, 40.0), (-2.556, 1.120, -0.519, 20.0, 40.0), (-3.717, -0.108, 1.358, 20.0, 40.0), (4.689, -1.826, 8.996, 20.0, 40.0), (3.452, 0.506, 3.713, 20.0, 40.0), (2.472, 0.612, 3.012, 20.0, 40.0), (3.452, 0.450, 3.826, 20.0, 40.0), (1.207, 2.585, -1.567, 20.0, 40.0), (-4.826, 1.090, -1.593, 20.0, 40.0), (3.116, -1.118, 6.794, 20.0, 40.0), (0.448, 2.732, -2.240, 20.0, 40.0), (-1.096, -0.525, 3.503, 20.0, 40.0), (-4.680, -0.238, 1.137, 20.0, 40.0), (2.552, -1.403, 7.082, 20.0, 40.0), (0.719, 2.997, -2.635, 20.0, 40.0), (0.347, -1.966, 7.105, 20.0, 40.0), (2.958, -0.404, 5.288, 20.0, 40.0), (0.722, -1.950, 7.261, 20.0, 40.0), (-2.851, -0.986, 3.546, 20.0, 40.0), (-4.316, -0.439, 1.721, 20.0, 40.0), (-1.685, -0.201, 2.560, 20.0, 40.0), (1.856, 0.190, 3.549, 20.0, 40.0), (-2.052, 0.206, 1.562, 20.0, 40.0), (-2.504, -0.646, 3.041, 20.0, 40.0), (3.235, 0.882, 2.854, 20.0, 40.0), (-1.366, -1.573, 5.463, 20.0, 40.0), (-3.447, 2.419, -3.562, 20.0, 40.0), (4.155, 2.092, 0.893, 20.0, 40.0), (-0.935, 0.209, 2.116, 20.0, 40.0), (3.117, -1.821, 8.201, 20.0, 40.0), (3.759, 0.577, 3.725, 20.0, 40.0), (-0.938, 2.992, -3.453, 20.0, 40.0), (-0.525, 2.341, -1.945, 20.0, 40.0), (4.540, 2.625, 0.019, 20.0, 40.0), (-2.097, 1.190, -0.429, 20.0, 40.0), (-2.672, 1.983, -2.302, 20.0, 40.0), (-3.038, -1.490, 4.460, 20.0, 40.0), (-0.943, 2.149, -1.770, 20.0, 40.0), (0.739, 1.598, 0.174, 20.0, 40.0), (1.828, 1.853, 0.208, 20.0, 40.0), (4.856, 0.137, 5.153, 20.0, 40.0), (-1.617, 0.468, 1.255, 20.0, 40.0), (-1.972, 2.053, -2.092, 20.0, 40.0), (-4.633, 1.389, -2.094, 20.0, 40.0), (-3.628, -1.156, 3.498, 20.0, 40.0), (3.597, 1.034, 2.731, 20.0, 40.0), (-1.488, -0.002, 2.261, 20.0, 40.0), (0.749, 1.921, -0.468, 20.0, 40.0), (1.304, -1.371, 6.394, 20.0, 40.0), (4.587, 2.936, -0.579, 20.0, 40.0), (-2.241, 1.791, -1.703, 20.0, 40.0), (-2.945, 1.372, -1.216, 20.0, 40.0), (1.375, 0.395, 2.898, 20.0, 40.0), (-1.281, -0.641, 3.642, 20.0, 40.0), (2.178, 0.895, 2.299, 20.0, 40.0), (3.031, -0.786, 6.087, 20.0, 40.0), (-1.385, -0.375, 3.058, 20.0, 40.0), (4.041, -0.431, 5.882, 20.0, 40.0), (0.480, -0.507, 4.254, 20.0, 40.0), (-3.797, 0.140, 0.822, 20.0, 40.0), (2.355, 2.502, -0.827, 20.0, 40.0), (1.376, -1.583, 6.854, 20.0, 40.0), (0.164, 1.405, 0.273, 20.0, 40.0), (-1.273, 1.471, -0.579, 20.0, 40.0), (0.770, 2.246, -1.107, 20.0, 40.0), (4.552, 2.904, -0.533, 20.0, 40.0), (4.259, -1.772, 8.674, 20.0, 40.0), (-0.309, 1.159, 0.528, 20.0, 40.0), (3.581, 2.700, -0.610, 20.0, 40.0), (-3.202, 0.346, 0.707, 20.0, 40.0), (-1.575, 1.242, -0.271, 20.0, 40.0), (-1.584, -0.493, 3.194, 20.0, 40.0), (-3.778, 0.150, 0.810, 20.0, 40.0), (-4.675, 1.749, -2.835, 20.0, 40.0), (3.567, -0.792, 6.367, 20.0, 40.0), (-0.417, 1.399, -0.006, 20.0, 40.0), (-4.672, 2.007, -3.349, 20.0, 40.0), (-1.034, 0.196, 2.090, 20.0, 40.0), (-3.796, 2.496, -3.890, 20.0, 40.0), (3.532, -0.497, 5.759, 20.0, 40.0), (4.868, -1.359, 8.151, 20.0, 40.0), (-0.769, 0.302, 2.011, 20.0, 40.0), (4.475, 2.612, 0.014, 20.0, 40.0), (-3.532, -0.395, 2.024, 20.0, 40.0), (0.322, 0.675, 1.812, 20.0, 40.0), (-2.028, -1.942, 5.870, 20.0, 40.0), (1.810, -1.244, 6.392, 20.0, 40.0), (-0.783, 1.242, 0.124, 20.0, 40.0), (-4.745, -1.300, 3.227, 20.0, 40.0), (1.902, 1.973, 0.005, 20.0, 40.0), (-3.453, -1.429, 4.132, 20.0, 40.0), (1.559, 0.986, 1.808, 20.0, 40.0), (0.128, 2.754, -2.443, 20.0, 40.0), (2.759, 1.727, 0.926, 20.0, 40.0), (-4.468, 1.690, -2.614, 20.0, 40.0), (-2.368, -1.922, 5.659, 20.0, 40.0), (-2.766, 2.128, -2.640, 20.0, 40.0), (0.967, -1.825, 7.133, 20.0, 40.0), (-2.854, 2.855, -4.136, 20.0, 40.0), (-2.944, 1.875, -2.222, 20.0, 40.0), (-2.632, -0.983, 3.649, 20.0, 40.0), (2.427, 2.239, -0.266, 20.0, 40.0), (-1.726, -0.838, 3.812, 20.0, 40.0), (0.007, -0.903, 4.809, 20.0, 40.0), (-2.013, 1.092, -0.191, 20.0, 40.0), (-0.449, 0.970, 0.836, 20.0, 40.0), (1.396, 0.411, 2.876, 20.0, 40.0), (-1.115, -1.790, 6.023, 20.0, 40.0), (3.748, 1.917, 1.039, 20.0, 40.0), (2.978, 1.043, 2.404, 20.0, 40.0), (-3.969, 2.514, -4.013, 20.0, 40.0), (4.455, -0.050, 5.328, 20.0, 40.0), (-3.065, -0.846, 3.160, 20.0, 40.0), (-1.069, 2.167, -1.869, 20.0, 40.0), (3.016, -1.393, 7.294, 20.0, 40.0), (0.045, -1.928, 6.879, 20.0, 40.0), (-2.555, -0.984, 3.690, 20.0, 40.0), (-1.995, -0.054, 2.111, 20.0, 40.0), (4.600, -0.509, 6.318, 20.0, 40.0), (-1.942, 1.215, -0.402, 20.0, 40.0), (1.262, 2.765, -1.899, 20.0, 40.0), (2.617, -1.106, 6.521, 20.0, 40.0), (1.737, 0.554, 2.761, 20.0, 40.0), (-2.197, 0.632, 0.638, 20.0, 40.0), (4.768, 2.618, 0.147, 20.0, 40.0), (-3.737, -0.939, 3.010, 20.0, 40.0), (-2.623, 0.595, 0.499, 20.0, 40.0), (4.752, -0.340, 6.057, 20.0, 40.0), (2.333, -1.037, 6.240, 20.0, 40.0), (4.234, -1.882, 8.881, 20.0, 40.0), (-3.393, -0.812, 2.927, 20.0, 40.0), (0.885, 1.383, 0.678, 20.0, 40.0), (0.123, 2.937, -2.812, 20.0, 40.0), (2.969, 0.760, 2.964, 20.0, 40.0), (-4.929, 1.251, -1.967, 20.0, 40.0), (1.916, 2.223, -0.488, 20.0, 40.0), (-0.020, -1.740, 6.469, 20.0, 40.0), (0.702, -1.272, 5.895, 20.0, 40.0), (2.496, 2.648, -1.048, 20.0, 40.0), (4.067, -1.475, 7.984, 20.0, 40.0), (-3.717, 1.851, -2.561, 20.0, 40.0), (1.678, -0.624, 5.088, 20.0, 40.0), (1.073, 0.695, 2.146, 20.0, 40.0), (1.842, -0.749, 5.419, 20.0, 40.0), (-3.518, 1.909, -2.578, 20.0, 40.0), (2.229, 1.189, 1.737, 20.0, 40.0), (4.987, 2.893, -0.292, 20.0, 40.0), (-4.809, 1.043, -1.490, 20.0, 40.0), (-0.241, -0.728, 4.334, 20.0, 40.0), (-3.331, 0.590, 0.156, 20.0, 40.0), (-0.455, 2.621, -2.470, 20.0, 40.0), (1.492, 1.223, 1.301, 20.0, 40.0), (3.948, 2.841, -0.709, 20.0, 40.0), (0.732, 0.446, 2.475, 20.0, 40.0), (2.400, 2.390, -0.579, 20.0, 40.0), (-2.718, 1.427, -1.213, 20.0, 40.0), (-1.826, 1.451, -0.815, 20.0, 40.0), (1.125, 0.438, 2.686, 20.0, 40.0), (-4.918, 1.880, -3.219, 20.0, 40.0), (3.068, -0.442, 5.418, 20.0, 40.0), (1.982, 1.201, 1.589, 20.0, 40.0), (0.701, -1.709, 6.768, 20.0, 40.0), (-1.496, 2.564, -2.877, 20.0, 40.0), (-3.812, 0.974, -0.853, 20.0, 40.0), (-3.405, 2.018, -2.739, 20.0, 40.0), (2.211, 2.889, -1.674, 20.0, 40.0), (-2.481, 2.931, -4.103, 20.0, 40.0), (-3.721, 2.765, -4.391, 20.0, 40.0), (-1.768, -1.292, 4.699, 20.0, 40.0), (-4.462, 1.058, -1.347, 20.0, 40.0), (-3.516, -1.942, 5.126, 20.0, 40.0), (0.485, 2.420, -1.597, 20.0, 40.0), (-0.492, 0.242, 2.270, 20.0, 40.0), (4.245, 1.689, 1.744, 20.0, 40.0), (2.234, 0.364, 3.389, 20.0, 40.0), (2.629, 2.224, -0.134, 20.0, 40.0), (-4.375, 1.221, -1.630, 20.0, 40.0), (-0.618, 1.374, -0.057, 20.0, 40.0), (-2.580, -1.604, 4.918, 20.0, 40.0), (0.159, 1.104, 0.871, 20.0, 40.0), (-3.597, 0.975, -0.749, 20.0, 40.0); DROP TABLE IF EXISTS test.model; -create table test.model engine = Memory as select LinearRegressionState(0.01, 1, 2.0)(target, param1, param2) as state from test.defaults; +create table test.model engine = Memory as select LinearRegressionState(0.03, 0.00001, 2, 2.0)(target, param1, param2) as state from test.defaults; - -with (select state from test.model) as model select evalMLMethod(model, predict1, predict2) from test.defaults; +select ans > -67.0 and ans < -66.9 from +(with (select state from test.model) as model select evalMLMethod(model, predict1, predict2) as ans from test.defaults limit 1); diff --git a/dbms/tests/queries/0_stateless/00955_ml_test.reference b/dbms/tests/queries/0_stateless/00955_ml_test.reference deleted file mode 100644 index 8d19c2c21f6..00000000000 --- a/dbms/tests/queries/0_stateless/00955_ml_test.reference +++ /dev/null @@ -1 +0,0 @@ --70.73127165094067 diff --git a/dbms/tests/queries/0_stateless/00960_dataset_test.sql b/dbms/tests/queries/0_stateless/00960_dataset_test.sql deleted file mode 100644 index 1b065afdecb..00000000000 --- a/dbms/tests/queries/0_stateless/00960_dataset_test.sql +++ /dev/null @@ -1,22 +0,0 @@ --- CREATE DATABASE IF NOT EXISTS test; --- DROP TABLE IF EXISTS test.trainset; --- CREATE TABLE IF NOT EXISTS test.trainset --- ( --- param1 Float64, param2 Float64, param3 Float64, param4 Float64, param5 Float64, param6 Float64, param7 Float64, param8 Float64, param9 Float64, param10 Float64, param11 Float64, param12 Float64, param13 Float64, param14 Float64, param15 Float64, param16 Float64, param17 Float64, param18 Float64, param19 Float64, param20 Float64, param21 Float64, param22 Float64, param23 Float64, param24 Float64, param25 Float64, param26 Float64, param27 Float64, param28 Float64, param29 Float64, param30 Float64, param31 Float64, param32 Float64, param33 Float64, param34 Float64, param35 Float64, param36 Float64, param37 Float64, param38 Float64, param39 Float64, param40 Float64, param41 Float64, param42 Float64, param43 Float64, param44 Float64, param45 Float64, param46 Float64, param47 Float64, param48 Float64, param49 Float64, param50 Float64, param51 Float64, param52 Float64, param53 Float64, param54 Float64, param55 Float64, param56 Float64, param57 Float64, param58 Float64, param59 Float64, param60 Float64, param61 Float64, param62 Float64, param63 Float64, param64 Float64, param65 Float64, param66 Float64, param67 Float64, param68 Float64, param69 Float64, param70 Float64, param71 Float64, param72 Float64, param73 Float64, param74 Float64, param75 Float64, param76 Float64, param77 Float64, param78 Float64, param79 Float64, param80 Float64, param81 Float64, param82 Float64, param83 Float64, param84 Float64, param85 Float64, param86 Float64, param87 Float64, param88 Float64, param89 Float64, param90 Float64, param91 Float64, param92 Float64, param93 Float64, param94 Float64, param95 Float64, param96 Float64, param97 Float64, param98 Float64, param99 Float64, param100 Float64, param101 Float64, param102 Float64, param103 Float64, param104 Float64, param105 Float64, param106 Float64, param107 Float64, param108 Float64, param109 Float64, param110 Float64, param111 Float64, param112 Float64, param113 Float64, param114 Float64, param115 Float64, param116 Float64, param117 Float64, param118 Float64, param119 Float64, param120 Float64, param121 Float64, param122 Float64, param123 Float64, param124 Float64, param125 Float64, param126 Float64, param127 Float64, param128 Float64, param129 Float64, param130 Float64, param131 Float64, param132 Float64, param133 Float64, param134 Float64, param135 Float64, param136 Float64, param137 Float64, param138 Float64, param139 Float64, param140 Float64, param141 Float64, param142 Float64, param143 Float64, param144 Float64, param145 Float64, param146 Float64, param147 Float64, param148 Float64, param149 Float64, param150 Float64, param151 Float64, param152 Float64, param153 Float64, param154 Float64, param155 Float64, param156 Float64, param157 Float64, param158 Float64, param159 Float64, param160 Float64, param161 Float64, param162 Float64, param163 Float64, param164 Float64, param165 Float64, param166 Float64, param167 Float64, param168 Float64, param169 Float64, param170 Float64, param171 Float64, param172 Float64, param173 Float64, param174 Float64, param175 Float64, param176 Float64, param177 Float64, param178 Float64, param179 Float64, param180 Float64, param181 Float64, param182 Float64, param183 Float64, target Float64 --- ) ENGINE = Memory; --- DROP TABLE IF EXISTS test.testset; --- CREATE TABLE IF NOT EXISTS test.testset --- ( --- param1 Float64, param2 Float64, param3 Float64, param4 Float64, param5 Float64, param6 Float64, param7 Float64, param8 Float64, param9 Float64, param10 Float64, param11 Float64, param12 Float64, param13 Float64, param14 Float64, param15 Float64, param16 Float64, param17 Float64, param18 Float64, param19 Float64, param20 Float64, param21 Float64, param22 Float64, param23 Float64, param24 Float64, param25 Float64, param26 Float64, param27 Float64, param28 Float64, param29 Float64, param30 Float64, param31 Float64, param32 Float64, param33 Float64, param34 Float64, param35 Float64, param36 Float64, param37 Float64, param38 Float64, param39 Float64, param40 Float64, param41 Float64, param42 Float64, param43 Float64, param44 Float64, param45 Float64, param46 Float64, param47 Float64, param48 Float64, param49 Float64, param50 Float64, param51 Float64, param52 Float64, param53 Float64, param54 Float64, param55 Float64, param56 Float64, param57 Float64, param58 Float64, param59 Float64, param60 Float64, param61 Float64, param62 Float64, param63 Float64, param64 Float64, param65 Float64, param66 Float64, param67 Float64, param68 Float64, param69 Float64, param70 Float64, param71 Float64, param72 Float64, param73 Float64, param74 Float64, param75 Float64, param76 Float64, param77 Float64, param78 Float64, param79 Float64, param80 Float64, param81 Float64, param82 Float64, param83 Float64, param84 Float64, param85 Float64, param86 Float64, param87 Float64, param88 Float64, param89 Float64, param90 Float64, param91 Float64, param92 Float64, param93 Float64, param94 Float64, param95 Float64, param96 Float64, param97 Float64, param98 Float64, param99 Float64, param100 Float64, param101 Float64, param102 Float64, param103 Float64, param104 Float64, param105 Float64, param106 Float64, param107 Float64, param108 Float64, param109 Float64, param110 Float64, param111 Float64, param112 Float64, param113 Float64, param114 Float64, param115 Float64, param116 Float64, param117 Float64, param118 Float64, param119 Float64, param120 Float64, param121 Float64, param122 Float64, param123 Float64, param124 Float64, param125 Float64, param126 Float64, param127 Float64, param128 Float64, param129 Float64, param130 Float64, param131 Float64, param132 Float64, param133 Float64, param134 Float64, param135 Float64, param136 Float64, param137 Float64, param138 Float64, param139 Float64, param140 Float64, param141 Float64, param142 Float64, param143 Float64, param144 Float64, param145 Float64, param146 Float64, param147 Float64, param148 Float64, param149 Float64, param150 Float64, param151 Float64, param152 Float64, param153 Float64, param154 Float64, param155 Float64, param156 Float64, param157 Float64, param158 Float64, param159 Float64, param160 Float64, param161 Float64, param162 Float64, param163 Float64, param164 Float64, param165 Float64, param166 Float64, param167 Float64, param168 Float64, param169 Float64, param170 Float64, param171 Float64, param172 Float64, param173 Float64, param174 Float64, param175 Float64, param176 Float64, param177 Float64, param178 Float64, param179 Float64, param180 Float64, param181 Float64, param182 Float64, param183 Float64 --- ) ENGINE = Memory; - -SET send_logs_level = 'trace'; --- SET log_queries = 1; --- SET max_threads = 4; - --- drop table if exists test.model; --- create table if not exists test.model engine = Memory as select LinearRegressionState(0.0000001, 4, 2.0)(target, param1, param2, param3, param4, param5, param6, param7, param8, param9, param10, param11, param12, param13, param14, param15, param16, param17, param18, param19, param20, param21, param22, param23, param24, param25, param26, param27, param28, param29, param30, param31, param32, param33, param34, param35, param36, param37, param38, param39, param40, param41, param42, param43, param44, param45, param46, param47, param48, param49, param50, param51, param52, param53, param54, param55, param56, param57, param58, param59, param60, param61, param62, param63, param64, param65, param66, param67, param68, param69, param70, param71, param72, param73, param74, param75, param76, param77, param78, param79, param80, param81, param82, param83, param84, param85, param86, param87, param88, param89, param90, param91, param92, param93, param94, param95, param96, param97, param98, param99, param100, param101, param102, param103, param104, param105, param106, param107, param108, param109, param110, param111, param112, param113, param114, param115, param116, param117, param118, param119, param120, param121, param122, param123, param124, param125, param126, param127, param128, param129, param130, param131, param132, param133, param134, param135, param136, param137, param138, param139, param140, param141, param142, param143, param144, param145, param146, param147, param148, param149, param150, param151, param152, param153, param154, param155, param156, param157, param158, param159, param160, param161, param162, param163, param164, param165, param166, param167, param168, param169, param170, param171, param172, param173, param174, param175, param176, param177, param178, param179, param180, param181, param182, param183) as state from test.trainset; - -select LinearRegressionState(0.0000001, 4, 2.0)(target, param1, param2, param3, param4, param5, param6, param7, param8, param9, param10, param11, param12, param13, param14, param15, param16, param17, param18, param19, param20, param21, param22, param23, param24, param25, param26, param27, param28, param29, param30, param31, param32, param33, param34, param35, param36, param37, param38, param39, param40, param41, param42, param43, param44, param45, param46, param47, param48, param49, param50, param51, param52, param53, param54, param55, param56, param57, param58, param59, param60, param61, param62, param63, param64, param65, param66, param67, param68, param69, param70, param71, param72, param73, param74, param75, param76, param77, param78, param79, param80, param81, param82, param83, param84, param85, param86, param87, param88, param89, param90, param91, param92, param93, param94, param95, param96, param97, param98, param99, param100, param101, param102, param103, param104, param105, param106, param107, param108, param109, param110, param111, param112, param113, param114, param115, param116, param117, param118, param119, param120, param121, param122, param123, param124, param125, param126, param127, param128, param129, param130, param131, param132, param133, param134, param135, param136, param137, param138, param139, param140, param141, param142, param143, param144, param145, param146, param147, param148, param149, param150, param151, param152, param153, param154, param155, param156, param157, param158, param159, param160, param161, param162, param163, param164, param165, param166, param167, param168, param169, param170, param171, param172, param173, param174, param175, param176, param177, param178, param179, param180, param181, param182, param183) from test.trainset; - --- with (select state from test.model) as model select evalMLMethod(model, param1, param2, param3, param4, param5, param6, param7, param8, param9, param10, param11, param12, param13, param14, param15, param16, param17, param18, param19, param20, param21, param22, param23, param24, param25, param26, param27, param28, param29, param30, param31, param32, param33, param34, param35, param36, param37, param38, param39, param40, param41, param42, param43, param44, param45, param46, param47, param48, param49, param50, param51, param52, param53, param54, param55, param56, param57, param58, param59, param60, param61, param62, param63, param64, param65, param66, param67, param68, param69, param70, param71, param72, param73, param74, param75, param76, param77, param78, param79, param80, param81, param82, param83, param84, param85, param86, param87, param88, param89, param90, param91, param92, param93, param94, param95, param96, param97, param98, param99, param100, param101, param102, param103, param104, param105, param106, param107, param108, param109, param110, param111, param112, param113, param114, param115, param116, param117, param118, param119, param120, param121, param122, param123, param124, param125, param126, param127, param128, param129, param130, param131, param132, param133, param134, param135, param136, param137, param138, param139, param140, param141, param142, param143, param144, param145, param146, param147, param148, param149, param150, param151, param152, param153, param154, param155, param156, param157, param158, param159, param160, param161, param162, param163, param164, param165, param166, param167, param168, param169, param170, param171, param172, param173, param174, param175, param176, param177, param178, param179, param180, param181, param182, param183) from test.testset; \ No newline at end of file From c93aae67416133f135b1f7b136ba5fb05da8de03 Mon Sep 17 00:00:00 2001 From: Alexander Kozhikhov Date: Tue, 9 Apr 2019 01:40:37 +0300 Subject: [PATCH 043/709] linear regression --- .../AggregateFunctionMLMethod.h | 8 +- .../AggregateFunctions/IAggregateFunction.h | 2 +- dbms/src/Columns/ColumnAggregateFunction.cpp | 17 +- dbms/src/Functions/evalMLMethod.cpp | 129 +++--- ...test.reference => 00935_ml_test.reference} | 0 .../{00950_ml_test.sql => 00935_ml_test.sql} | 0 ...test.reference => 00936_ml_test.reference} | 0 .../{00951_ml_test.sql => 00936_ml_test.sql} | 0 ...test.reference => 00937_ml_test.reference} | 0 .../{00952_ml_test.sql => 00937_ml_test.sql} | 0 ...reference => 00938_dataset_test.reference} | 0 ...ataset_test.sql => 00938_dataset_test.sql} | 0 ...test.reference => 00939_ml_test.reference} | 0 .../{00954_ml_test.sql => 00939_ml_test.sql} | 0 .../0_stateless/00952_ml_test.good_reference | 370 ------------------ .../0_stateless/00952_ml_test.norm_reference | 1 - 16 files changed, 62 insertions(+), 465 deletions(-) rename dbms/tests/queries/0_stateless/{00950_ml_test.reference => 00935_ml_test.reference} (100%) rename dbms/tests/queries/0_stateless/{00950_ml_test.sql => 00935_ml_test.sql} (100%) rename dbms/tests/queries/0_stateless/{00951_ml_test.reference => 00936_ml_test.reference} (100%) rename dbms/tests/queries/0_stateless/{00951_ml_test.sql => 00936_ml_test.sql} (100%) rename dbms/tests/queries/0_stateless/{00952_ml_test.reference => 00937_ml_test.reference} (100%) rename dbms/tests/queries/0_stateless/{00952_ml_test.sql => 00937_ml_test.sql} (100%) rename dbms/tests/queries/0_stateless/{00953_dataset_test.reference => 00938_dataset_test.reference} (100%) rename dbms/tests/queries/0_stateless/{00953_dataset_test.sql => 00938_dataset_test.sql} (100%) rename dbms/tests/queries/0_stateless/{00954_ml_test.reference => 00939_ml_test.reference} (100%) rename dbms/tests/queries/0_stateless/{00954_ml_test.sql => 00939_ml_test.sql} (100%) delete mode 100644 dbms/tests/queries/0_stateless/00952_ml_test.good_reference delete mode 100644 dbms/tests/queries/0_stateless/00952_ml_test.norm_reference diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h index f17572a5928..dd3c2c35f23 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h @@ -459,10 +459,10 @@ private: template < - /// Implemented Machine Learning method - typename Data, - /// Name of the method - typename Name + /// Implemented Machine Learning method + typename Data, + /// Name of the method + typename Name > class AggregateFunctionMLMethod final : public IAggregateFunctionDataHelper> { diff --git a/dbms/src/AggregateFunctions/IAggregateFunction.h b/dbms/src/AggregateFunctions/IAggregateFunction.h index 2c784c6ab74..694a5955310 100644 --- a/dbms/src/AggregateFunctions/IAggregateFunction.h +++ b/dbms/src/AggregateFunctions/IAggregateFunction.h @@ -152,7 +152,7 @@ public: IAggregateFunctionDataHelper(const DataTypes & argument_types_, const Array & parameters_) : IAggregateFunctionHelper(argument_types_, parameters_) {} - virtual void create(AggregateDataPtr place) const override + void create(AggregateDataPtr place) const override { new (place) Data; } diff --git a/dbms/src/Columns/ColumnAggregateFunction.cpp b/dbms/src/Columns/ColumnAggregateFunction.cpp index 6a33a98f7ef..8deaee1991e 100644 --- a/dbms/src/Columns/ColumnAggregateFunction.cpp +++ b/dbms/src/Columns/ColumnAggregateFunction.cpp @@ -84,16 +84,11 @@ MutableColumnPtr ColumnAggregateFunction::convertToValues() const * AggregateFunction(quantileTiming(0.5), UInt64) * into UInt16 - already finished result of `quantileTiming`. */ -// if (const AggregateFunctionState * function_state = typeid_cast(func.get())) -// { -// auto res = createView(); -// res->set(function_state->getNestedFunction()); -// res->data.assign(data.begin(), data.end()); -// return res; -// } -// -// MutableColumnPtr res = func->getReturnType()->createColumn(); -// res->reserve(data.size()); + + /** Convertion function is used in convertToValues and predictValues + * in the similar part of both functions + */ + MutableColumnPtr res; if (convertion(&res)) { @@ -114,8 +109,6 @@ MutableColumnPtr ColumnAggregateFunction::predictValues(Block & block, const Col return res; } - /// На моих тестах дважды в эту функцию приходит нечтно, имеющее data.size() == 0 однако оно по сути ничего не делает в следующих строках - auto ML_function_Linear = typeid_cast *>(func.get()); auto ML_function_Logistic = typeid_cast *>(func.get()); if (ML_function_Linear) diff --git a/dbms/src/Functions/evalMLMethod.cpp b/dbms/src/Functions/evalMLMethod.cpp index 2585c2ae1c9..cacc72d88e2 100644 --- a/dbms/src/Functions/evalMLMethod.cpp +++ b/dbms/src/Functions/evalMLMethod.cpp @@ -25,84 +25,59 @@ namespace DB /** finalizeAggregation(agg_state) - get the result from the aggregation state. * Takes state of aggregate function. Returns result of aggregation (finalized state). */ - class FunctionEvalMLMethod : public IFunction +class FunctionEvalMLMethod : public IFunction +{ +public: + static constexpr auto name = "evalMLMethod"; + static FunctionPtr create(const Context &) { - public: - static constexpr auto name = "evalMLMethod"; - static FunctionPtr create(const Context &) - { - return std::make_shared(); - } - - String getName() const override - { - return name; - } - - bool isVariadic() const override { - return true; - } - size_t getNumberOfArguments() const override - { - return 0; - } - - DataTypePtr getReturnTypeImpl(const DataTypes & arguments) const override - { - const DataTypeAggregateFunction * type = checkAndGetDataType(arguments[0].get()); - if (!type) - throw Exception("Argument for function " + getName() + " must have type AggregateFunction - state of aggregate function.", - ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT); - - return type->getReturnType(); - } - - void executeImpl(Block & block, const ColumnNumbers & arguments, size_t result, size_t /*input_rows_count*/) override - { -// const ColumnAggregateFunction * column_with_states = -// typeid_cast(static_cast(&*block.getByPosition(arguments.at(0)).column)); - - - // завести МЛ_аггр_функции как отдельный класс, чтобы тут сразу это проверять, а не делать это внутри predictValues() - -// const ColumnAggregateFunction * column_with_states -// = typeid_cast(&*block.getByPosition(arguments.at(0)).column); - - - const ColumnConst * column_with_states - = typeid_cast(&*block.getByPosition(arguments.at(0)).column); - - - if (!column_with_states) - throw Exception("Illegal column " + block.getByPosition(arguments.at(0)).column->getName() - + " of first argument of function " - + getName(), - ErrorCodes::ILLEGAL_COLUMN); - -// const ColumnArray * col_array = checkAndGetColumnConstData(block.getByPosition(arguments[1]).column.get()); -// if (!col_array) -// throw std::runtime_error("wtf"); - -// const IColumn & array_elements = col_array->getData(); - -/* - std::vector predict_features(arguments.size()); - for (size_t i = 1; i < arguments.size(); ++i) - { -// predict_features[i] = array_elements[i].get(); - predict_features[i - 1] = typeid_cast(block.getByPosition(arguments[i]).column.get())->getValue(); - } - block.getByPosition(result).column = column_with_states->predictValues(predict_features); -*/ - block.getByPosition(result).column = - typeid_cast(&*column_with_states->getDataColumnPtr())->predictValues(block, arguments); - } - - }; - - void registerFunctionEvalMLMethod(FunctionFactory & factory) - { - factory.registerFunction(); + return std::make_shared(); } + String getName() const override + { + return name; + } + + bool isVariadic() const override { + return true; + } + size_t getNumberOfArguments() const override + { + return 0; + } + + DataTypePtr getReturnTypeImpl(const DataTypes & arguments) const override + { + const DataTypeAggregateFunction * type = checkAndGetDataType(arguments[0].get()); + if (!type) + throw Exception("Argument for function " + getName() + " must have type AggregateFunction - state of aggregate function.", + ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT); + + return type->getReturnType(); + } + + void executeImpl(Block & block, const ColumnNumbers & arguments, size_t result, size_t /*input_rows_count*/) override + { + const ColumnConst * column_with_states + = typeid_cast(&*block.getByPosition(arguments.at(0)).column); + + + if (!column_with_states) + throw Exception("Illegal column " + block.getByPosition(arguments.at(0)).column->getName() + + " of first argument of function " + + getName(), + ErrorCodes::ILLEGAL_COLUMN); + + block.getByPosition(result).column = + typeid_cast(&*column_with_states->getDataColumnPtr())->predictValues(block, arguments); + } + +}; + +void registerFunctionEvalMLMethod(FunctionFactory & factory) +{ + factory.registerFunction(); +} + } \ No newline at end of file diff --git a/dbms/tests/queries/0_stateless/00950_ml_test.reference b/dbms/tests/queries/0_stateless/00935_ml_test.reference similarity index 100% rename from dbms/tests/queries/0_stateless/00950_ml_test.reference rename to dbms/tests/queries/0_stateless/00935_ml_test.reference diff --git a/dbms/tests/queries/0_stateless/00950_ml_test.sql b/dbms/tests/queries/0_stateless/00935_ml_test.sql similarity index 100% rename from dbms/tests/queries/0_stateless/00950_ml_test.sql rename to dbms/tests/queries/0_stateless/00935_ml_test.sql diff --git a/dbms/tests/queries/0_stateless/00951_ml_test.reference b/dbms/tests/queries/0_stateless/00936_ml_test.reference similarity index 100% rename from dbms/tests/queries/0_stateless/00951_ml_test.reference rename to dbms/tests/queries/0_stateless/00936_ml_test.reference diff --git a/dbms/tests/queries/0_stateless/00951_ml_test.sql b/dbms/tests/queries/0_stateless/00936_ml_test.sql similarity index 100% rename from dbms/tests/queries/0_stateless/00951_ml_test.sql rename to dbms/tests/queries/0_stateless/00936_ml_test.sql diff --git a/dbms/tests/queries/0_stateless/00952_ml_test.reference b/dbms/tests/queries/0_stateless/00937_ml_test.reference similarity index 100% rename from dbms/tests/queries/0_stateless/00952_ml_test.reference rename to dbms/tests/queries/0_stateless/00937_ml_test.reference diff --git a/dbms/tests/queries/0_stateless/00952_ml_test.sql b/dbms/tests/queries/0_stateless/00937_ml_test.sql similarity index 100% rename from dbms/tests/queries/0_stateless/00952_ml_test.sql rename to dbms/tests/queries/0_stateless/00937_ml_test.sql diff --git a/dbms/tests/queries/0_stateless/00953_dataset_test.reference b/dbms/tests/queries/0_stateless/00938_dataset_test.reference similarity index 100% rename from dbms/tests/queries/0_stateless/00953_dataset_test.reference rename to dbms/tests/queries/0_stateless/00938_dataset_test.reference diff --git a/dbms/tests/queries/0_stateless/00953_dataset_test.sql b/dbms/tests/queries/0_stateless/00938_dataset_test.sql similarity index 100% rename from dbms/tests/queries/0_stateless/00953_dataset_test.sql rename to dbms/tests/queries/0_stateless/00938_dataset_test.sql diff --git a/dbms/tests/queries/0_stateless/00954_ml_test.reference b/dbms/tests/queries/0_stateless/00939_ml_test.reference similarity index 100% rename from dbms/tests/queries/0_stateless/00954_ml_test.reference rename to dbms/tests/queries/0_stateless/00939_ml_test.reference diff --git a/dbms/tests/queries/0_stateless/00954_ml_test.sql b/dbms/tests/queries/0_stateless/00939_ml_test.sql similarity index 100% rename from dbms/tests/queries/0_stateless/00954_ml_test.sql rename to dbms/tests/queries/0_stateless/00939_ml_test.sql diff --git a/dbms/tests/queries/0_stateless/00952_ml_test.good_reference b/dbms/tests/queries/0_stateless/00952_ml_test.good_reference deleted file mode 100644 index 5ad7a9176a4..00000000000 --- a/dbms/tests/queries/0_stateless/00952_ml_test.good_reference +++ /dev/null @@ -1,370 +0,0 @@ -0.72 -0.72 -0.72 -0.72 -0.72 -0.72 -0.72 -0.72 -0.72 -0.72 -0.72 -0.72 -0.72 -0.89 -0.89 -0.89 -0.89 -0.89 -0.89 -0.89 -0.89 -0.89 -0.89 -0.89 -0.89 -0.95 -0.95 -0.95 -0.95 -0.95 -0.95 -0.95 -0.95 -0.95 -0.95 -0.95 -0.95 -0.79 -0.79 -0.79 -0.79 -0.79 -0.79 -0.79 -0.79 -0.79 -0.79 -0.79 -0.79 -0.79 -0.39 -0.39 -0.39 -0.39 -0.39 -0.39 -0.39 -0.39 -0.39 -0.39 -0.39 -0.39 -0.38 -0.38 -0.38 -0.38 -0.38 -0.38 -0.38 -0.38 -0.38 -0.38 -0.38 -0.38 -0.34 -0.34 -0.34 -0.34 -0.34 -0.34 -0.34 -0.34 -0.34 -0.34 -0.34 -0.34 -0.34 -0.47 -0.47 -0.47 -0.47 -0.47 -0.47 -0.47 -0.47 -0.47 -0.47 -0.47 -0.47 -0.56 -0.56 -0.56 -0.56 -0.56 -0.56 -0.56 -0.56 -0.56 -0.56 -0.56 -0.56 -0.71 -0.71 -0.71 -0.71 -0.71 -0.71 -0.71 -0.71 -0.71 -0.71 -0.71 -0.71 -0.71 -0.78 -0.78 -0.78 -0.78 -0.78 -0.78 -0.78 -0.78 -0.78 -0.78 -0.78 -0.78 -0.73 -0.73 -0.73 -0.73 -0.73 -0.73 -0.73 -0.73 -0.73 -0.73 -0.73 -0.73 -0.82 -0.82 -0.82 -0.82 -0.82 -0.82 -0.82 -0.82 -0.82 -0.82 -0.82 -0.82 -0.82 -0.62 -0.62 -0.62 -0.62 -0.62 -0.62 -0.62 -0.62 -0.62 -0.62 -0.62 -0.62 -0.96 -0.96 -0.96 -0.96 -0.96 -0.96 -0.96 -0.96 -0.96 -0.96 -0.96 -0.96 -0.96 -0.96 -0.96 -0.96 -0.96 -0.96 -0.96 -0.96 -0.96 -0.96 -0.96 -0.96 -0.96 -0.46 -0.46 -0.46 -0.46 -0.46 -0.46 -0.46 -0.46 -0.46 -0.46 -0.46 -0.46 -0.53 -0.53 -0.53 -0.53 -0.53 -0.53 -0.53 -0.53 -0.53 -0.53 -0.53 -0.53 -0.49 -0.49 -0.49 -0.49 -0.49 -0.49 -0.49 -0.49 -0.49 -0.49 -0.49 -0.49 -0.49 -0.76 -0.76 -0.76 -0.76 -0.76 -0.76 -0.76 -0.76 -0.76 -0.76 -0.76 -0.76 -0.64 -0.64 -0.64 -0.64 -0.64 -0.64 -0.64 -0.64 -0.64 -0.64 -0.64 -0.64 -0.71 -0.71 -0.71 -0.71 -0.71 -0.71 -0.71 -0.71 -0.71 -0.71 -0.71 -0.71 -0.71 -0.84 -0.84 -0.84 -0.84 -0.84 -0.84 -0.84 -0.84 -0.84 -0.84 -0.84 -0.84 -0.77 -0.77 -0.77 -0.77 -0.77 -0.77 -0.77 -0.77 -0.77 -0.77 -0.77 -0.77 -0.89 -0.89 -0.89 -0.89 -0.89 -0.89 -0.89 -0.89 -0.89 -0.89 -0.89 -0.89 -0.89 -0.82 -0.82 -0.82 -0.82 -0.82 -0.82 -0.82 -0.82 -0.82 -0.82 -0.82 -0.82 -0.84 -0.84 -0.84 -0.84 -0.84 -0.84 -0.84 -0.84 -0.84 -0.84 -0.84 -0.84 -0.91 -0.91 -0.91 -0.91 -0.91 -0.91 -0.91 -0.91 -0.91 -0.91 -0.91 -0.91 -0.91 -0.67 -0.67 -0.67 -0.67 -0.67 -0.67 -0.67 -0.67 -0.67 -0.67 -0.67 -0.67 -0.95 -0.95 -0.95 -0.95 -0.95 -0.95 -0.95 -0.95 -0.95 -0.95 -0.95 -0.95 diff --git a/dbms/tests/queries/0_stateless/00952_ml_test.norm_reference b/dbms/tests/queries/0_stateless/00952_ml_test.norm_reference deleted file mode 100644 index dea24ee3047..00000000000 --- a/dbms/tests/queries/0_stateless/00952_ml_test.norm_reference +++ /dev/null @@ -1 +0,0 @@ -0.00676015 From 12132b8fdf8dafc745259baf52d44a4397349903 Mon Sep 17 00:00:00 2001 From: Alexander Kozhikhov Date: Mon, 15 Apr 2019 02:57:14 +0300 Subject: [PATCH 044/709] fix in evalMLMethod --- dbms/src/Functions/evalMLMethod.cpp | 12 +++++++++--- 1 file changed, 9 insertions(+), 3 deletions(-) diff --git a/dbms/src/Functions/evalMLMethod.cpp b/dbms/src/Functions/evalMLMethod.cpp index cacc72d88e2..37e872bf00b 100644 --- a/dbms/src/Functions/evalMLMethod.cpp +++ b/dbms/src/Functions/evalMLMethod.cpp @@ -49,6 +49,9 @@ public: DataTypePtr getReturnTypeImpl(const DataTypes & arguments) const override { + if (!arguments.size()) + throw Exception("Function " + getName() + " requires at least one argument", ErrorCodes::BAD_ARGUMENTS); + const DataTypeAggregateFunction * type = checkAndGetDataType(arguments[0].get()); if (!type) throw Exception("Argument for function " + getName() + " must have type AggregateFunction - state of aggregate function.", @@ -59,12 +62,15 @@ public: void executeImpl(Block & block, const ColumnNumbers & arguments, size_t result, size_t /*input_rows_count*/) override { + if (!arguments.size()) + throw Exception("Function " + getName() + " requires at least one argument", ErrorCodes::BAD_ARGUMENTS); + const ColumnConst * column_with_states - = typeid_cast(&*block.getByPosition(arguments.at(0)).column); + = typeid_cast(&*block.getByPosition(arguments[0]).column); if (!column_with_states) - throw Exception("Illegal column " + block.getByPosition(arguments.at(0)).column->getName() + throw Exception("Illegal column " + block.getByPosition(arguments[0]).column->getName() + " of first argument of function " + getName(), ErrorCodes::ILLEGAL_COLUMN); @@ -80,4 +86,4 @@ void registerFunctionEvalMLMethod(FunctionFactory & factory) factory.registerFunction(); } -} \ No newline at end of file +} From 19021e76bb7406dbf17ed9cd021706817d93c2fa Mon Sep 17 00:00:00 2001 From: Alexander Kozhikhov Date: Mon, 15 Apr 2019 03:16:13 +0300 Subject: [PATCH 045/709] style --- .../AggregateFunctionMLMethod.cpp | 23 +++++++++++-------- .../AggregateFunctionMLMethod.h | 4 ++-- dbms/src/Columns/ColumnAggregateFunction.cpp | 6 +++-- dbms/src/Functions/evalMLMethod.cpp | 3 ++- 4 files changed, 22 insertions(+), 14 deletions(-) diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp index 7a4d5d731d2..d217511b2bc 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp @@ -25,9 +25,7 @@ AggregateFunctionPtr createAggregateFunctionMLMethod( for (size_t i = 0; i < argument_types.size(); ++i) { if (!WhichDataType(argument_types[i]).isFloat64()) - throw Exception("Illegal type " + argument_types[i]->getName() + " of argument " - + std::to_string(i) + "for aggregate function " + name, - ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT); + throw Exception("Illegal type " + argument_types[i]->getName() + " of argument " + std::to_string(i) + "for aggregate function " + name, ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT); } Float64 learning_rate = Float64(0.01); @@ -55,17 +53,22 @@ AggregateFunctionPtr createAggregateFunctionMLMethod( if (applyVisitor(FieldVisitorConvertToNumber(), parameters[3]) == Float64{1.0}) { wu = std::make_shared(); - } else if (applyVisitor(FieldVisitorConvertToNumber(), parameters[3]) == Float64{2.0}) + } + else if (applyVisitor(FieldVisitorConvertToNumber(), parameters[3]) == Float64{2.0}) { wu = std::make_shared(); - } else if (applyVisitor(FieldVisitorConvertToNumber(), parameters[3]) == Float64{3.0}) + } + else if (applyVisitor(FieldVisitorConvertToNumber(), parameters[3]) == Float64{3.0}) { wu = std::make_shared(); - } else { + } + else + { throw Exception("Invalid parameter for weights updater", ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT); } - } else + } + else { wu = std::make_unique(); } @@ -73,10 +76,12 @@ AggregateFunctionPtr createAggregateFunctionMLMethod( if (std::is_same::value) { gc = std::make_shared(); - } else if (std::is_same::value) + } + else if (std::is_same::value) { gc = std::make_shared(); - } else + } + else { throw Exception("Such gradient computer is not implemented yet", ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT); } diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h index dd3c2c35f23..5b6cb5b02db 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h @@ -483,8 +483,8 @@ public: l2_reg_coef(l2_reg_coef), batch_size(batch_size), gc(std::move(gradient_computer)), - wu(std::move(weights_updater)) { - } + wu(std::move(weights_updater)) + {} DataTypePtr getReturnType() const override { diff --git a/dbms/src/Columns/ColumnAggregateFunction.cpp b/dbms/src/Columns/ColumnAggregateFunction.cpp index 8deaee1991e..8f92ccbd96a 100644 --- a/dbms/src/Columns/ColumnAggregateFunction.cpp +++ b/dbms/src/Columns/ColumnAggregateFunction.cpp @@ -120,7 +120,8 @@ MutableColumnPtr ColumnAggregateFunction::predictValues(Block & block, const Col ++row_num; } - } else if (ML_function_Logistic) + } + else if (ML_function_Logistic) { size_t row_num = 0; for (auto val : data) @@ -128,7 +129,8 @@ MutableColumnPtr ColumnAggregateFunction::predictValues(Block & block, const Col ML_function_Logistic->predictResultInto(val, *res, block, arguments); ++row_num; } - } else + } + else { throw Exception("Illegal aggregate function is passed", ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT); diff --git a/dbms/src/Functions/evalMLMethod.cpp b/dbms/src/Functions/evalMLMethod.cpp index 37e872bf00b..ffdad6cf26e 100644 --- a/dbms/src/Functions/evalMLMethod.cpp +++ b/dbms/src/Functions/evalMLMethod.cpp @@ -39,7 +39,8 @@ public: return name; } - bool isVariadic() const override { + bool isVariadic() const override + { return true; } size_t getNumberOfArguments() const override From 9ed740e3ea819df2cec8912c91256dd0aa620953 Mon Sep 17 00:00:00 2001 From: Alexander Kozhikhov Date: Mon, 15 Apr 2019 04:10:39 +0300 Subject: [PATCH 046/709] style --- dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h index 5b6cb5b02db..d6b0bd25981 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h @@ -123,7 +123,7 @@ public: derivative *= target; derivative = exp(derivative); - (*batch_gradient)[weights.size()] += learning_rate * target / (derivative + 1);; + (*batch_gradient)[weights.size()] += learning_rate * target / (derivative + 1); for (size_t i = 0; i < weights.size(); ++i) { (*batch_gradient)[i] += From a2a9d4b513ff8ccc2d9c6507262e39ba000f1d57 Mon Sep 17 00:00:00 2001 From: Alexander Kozhikhov Date: Mon, 15 Apr 2019 10:59:56 +0300 Subject: [PATCH 047/709] style --- .../AggregateFunctionMLMethod.h | 4 +- .../queries/0_stateless/00901_mytest.sql | 46 ------------------- 2 files changed, 2 insertions(+), 48 deletions(-) delete mode 100644 dbms/tests/queries/0_stateless/00901_mytest.sql diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h index d6b0bd25981..a7d2837abfa 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h @@ -475,9 +475,9 @@ public: Float64 learning_rate, Float64 l2_reg_coef, UInt32 batch_size, - const DataTypes & argument_types, + const DataTypes & arguments_types, const Array & params) - : IAggregateFunctionDataHelper>(argument_types, params), + : IAggregateFunctionDataHelper>(arguments_types, params), param_num(param_num), learning_rate(learning_rate), l2_reg_coef(l2_reg_coef), diff --git a/dbms/tests/queries/0_stateless/00901_mytest.sql b/dbms/tests/queries/0_stateless/00901_mytest.sql deleted file mode 100644 index f6bf6a5978f..00000000000 --- a/dbms/tests/queries/0_stateless/00901_mytest.sql +++ /dev/null @@ -1,46 +0,0 @@ -CREATE DATABASE IF NOT EXISTS test; -DROP TABLE IF EXISTS test.defaults; -CREATE TABLE IF NOT EXISTS test.defaults -( - param1 Float64, - param2 Float64, - target Float64, - predict1 Float64, - predict2 Float64 -) ENGINE = Memory; --- -- insert into test.defaults values (2.533, 0.543, 3.181), (1.999, 1.765, 0.470), (0.631, 2.580, -1.845), (-1.164, 0.889, 0.640), (2.110, 0.768, 2.519), (1.251, 0.483, 2.659), (-3.958, 1.299, -1.576), (-2.152, -1.316, 4.556), (3.269, 1.441, 1.753), (4.206, -1.635, 8.373), (-3.479, -0.544, 2.349), (4.006, 0.167, 4.670), (-4.478, 2.400, -4.039), (1.856, 0.256, 3.417), (1.470, 1.685, 0.366), (-4.052, 2.326, -3.678), (-0.971, -0.969, 4.453), (0.881, -1.848, 7.137), (-1.551, -1.766, 5.756), (-0.988, -0.945, 4.395), (-4.636, 1.074, -1.466), (-4.074, -1.486, 3.934), (0.754, 2.627, -1.877), (1.035, 0.889, 1.738), (3.707, -1.281, 7.415), (-2.215, 1.110, -0.327), (-2.965, -1.316, 4.150), (-3.581, 1.063, -0.917), (0.548, 0.343, 2.588), (3.023, -0.870, 6.251), (4.053, -1.441, 7.909), (-0.750, 0.639, 1.348), (-4.411, 1.636, -2.477), (1.786, 0.398, 3.096), (-2.514, 0.033, 1.676), (4.935, -0.840, 7.148), (1.075, -0.921, 5.380), (-3.418, 2.177, -3.063), (3.122, 1.883, 0.795), (-2.254, -1.389, 4.650), (-4.603, 2.909, -5.119), (-1.886, -1.220, 4.497), (-0.509, -1.498, 5.741), (2.192, 1.882, 0.332), (4.056, -1.108, 7.244), (-1.918, 0.230, 1.581), (4.867, 1.516, 2.401), (-0.993, -0.011, 2.526), (-0.757, -1.192, 5.006), (-4.161, 2.059, -3.198), (2.258, 1.157, 1.814), (-3.878, -0.052, 1.165), (1.915, 2.998, -2.038), (-2.164, 2.379, -2.841), (-0.114, -1.914, 6.772), (3.812, 2.138, 0.630), (-1.863, 1.508, -0.947), (-2.964, 0.398, 0.722), (-2.046, -0.193, 2.363), (-1.525, -0.836, 3.910), (-4.557, -0.582, 1.886), (1.031, -0.461, 4.437), (-0.802, 0.699, 1.201), (3.982, 2.084, 0.824), (-2.243, 2.726, -3.573), (-3.989, -0.803, 2.611), (4.900, 0.253, 4.944), (-1.208, -1.587, 5.571), (0.370, 2.579, -1.972), (2.824, 0.964, 2.484), (-1.290, -0.128, 2.611), (0.190, 2.058, -1.021), (4.058, 2.122, 0.784), (4.879, 0.945, 3.549), (1.119, 1.992, -0.424), (4.050, 2.005, 1.015), (-0.064, 1.485, -0.002), (-2.496, 0.456, 0.840), (-1.835, 1.586, -1.090), (0.603, 1.856, -0.411), (-3.062, -0.966, 3.401), (-3.351, 0.430, 0.465), (-2.724, -1.331, 4.299), (3.291, -1.027, 6.699), (-4.263, 0.785, -0.701), (-3.289, -0.886, 3.128), (4.627, 1.331, 2.651), (-0.618, 0.602, 1.486), (0.056, 1.778, -0.528), (4.823, 1.154, 3.103), (-3.983, 0.509, -0.010), (-4.474, -1.400, 3.563), (-3.782, 2.996, -4.883), (4.515, -0.656, 6.569), (1.269, 2.592, -1.549), (-1.710, -0.241, 2.627), (2.171, 1.453, 1.180), (-1.931, -1.845, 5.726), (1.767, -1.798, 7.480), (4.352, 2.369, 0.438), (-4.498, 2.611, -4.472), (0.067, 0.517, 2.000), (4.151, 0.624, 3.827), (0.409, -0.969, 5.142), (0.193, -1.713, 6.522), (-2.487, 2.827, -3.898), (-4.363, 2.011, -3.203), (-2.383, 2.554, -3.299), (-4.457, -0.958, 2.687), (3.342, -0.360, 5.392), (0.902, 2.978, -2.505), (4.073, -1.524, 8.084), (3.036, 1.672, 1.173), (2.169, -0.564, 5.213), (-4.780, 0.962, -1.313), (-1.815, 2.096, -2.100), (-1.445, 0.458, 1.362), (1.891, -1.437, 6.820), (1.942, -1.761, 7.493), (-4.613, -1.551, 3.795), (-3.472, -1.110, 3.485), (-2.026, 1.961, -1.935), (0.091, -0.961, 4.967), (3.902, -1.336, 7.622), (-3.483, -0.769, 2.796), (-0.066, -1.233, 5.433), (2.597, 2.789, -1.280), (-1.657, -1.842, 5.856), (0.232, -1.420, 5.957), (-3.321, 1.609, -1.879), (2.673, 2.781, -1.226), (0.869, 0.072, 3.291), (1.444, -1.271, 6.264), (1.190, 1.460, 0.675), (3.497, 0.870, 3.008), (-2.884, -1.303, 4.163), (3.620, 0.381, 4.047), (2.594, 0.247, 3.803), (-3.902, -1.315, 3.678), (-4.753, -1.005, 2.634), (0.881, 0.675, 2.091), (0.414, 2.071, -0.935), (3.458, -0.920, 6.568), (-2.986, -0.411, 2.329), (3.076, -1.960, 8.458), (2.951, 2.988, -1.501), (2.408, 1.301, 1.603), (4.725, 0.366, 4.631), (4.924, -1.762, 8.985), (3.719, 0.970, 2.920), (-0.295, 0.257, 2.340), (-4.607, 2.548, -4.400), (0.288, 1.953, -0.761), (-3.311, 0.844, -0.344), (3.679, -0.642, 6.123), (-2.310, -0.838, 3.522), (-4.397, -0.226, 1.254), (-4.366, -0.024, 0.864), (2.405, 1.458, 1.286), (-4.296, -1.071, 2.994), (0.452, -1.901, 7.028), (-0.214, -0.467, 3.827), (2.559, 1.547, 1.185), (0.990, 1.539, 0.417), (0.478, -0.089, 3.417), (-2.734, -1.007, 3.646), (3.483, 0.247, 4.247), (3.507, 2.727, -0.701), (-4.399, 2.437, -4.073), (3.785, 0.036, 4.820), (-0.824, 2.417, -2.245), (-2.588, 0.369, 0.968), (-3.037, -1.639, 4.759), (4.531, -0.499, 6.264), (4.742, -1.161, 7.693), (-0.063, -0.595, 4.159), (0.697, 2.281, -1.212), (0.413, 0.607, 1.992), (-4.081, 0.383, 0.194), (0.712, 2.638, -1.920), (-1.620, 1.092, 0.006), (-3.425, -0.911, 3.109), (-0.124, 1.711, -0.484), (4.347, 1.387, 2.399), (-3.237, -0.900, 3.182), (-3.961, 0.358, 0.304), (4.326, -0.068, 5.298), (3.846, 1.725, 1.473), (-2.089, 0.953, 0.049), (-1.025, -1.470, 5.428), (2.061, -0.156, 4.343), (1.547, -1.827, 7.427), (2.786, 0.460, 3.473), (0.076, 0.659, 1.720), (3.597, 1.966, 0.866), (-0.933, -1.180, 4.894), (4.647, 1.190, 2.943), (-0.032, 0.544, 1.896), (4.461, -1.806, 8.843), (-0.586, 1.821, -0.934), (3.725, 1.715, 1.432), (-2.091, 2.714, -3.474), (4.494, -1.494, 8.236), (3.766, -0.209, 5.301), (-1.991, 1.776, -1.548), (-4.992, -0.742, 1.989), (-2.400, 1.828, -1.855), (-1.329, 0.143, 2.050), (1.954, 1.759, 0.459), (-4.422, 1.507, -2.224), (-2.243, -1.126, 4.131), (4.417, -1.080, 7.368), (1.737, -1.144, 6.157), (2.661, -1.084, 6.498), (-3.198, 0.443, 0.515), (4.191, -1.250, 7.596), (-2.419, -0.163, 2.116), (1.910, -1.173, 6.301), (-0.241, 1.902, -0.925), (-4.415, 2.479, -4.165), (3.307, -0.465, 5.583), (-2.382, 1.364, -0.920), (-3.154, 2.953, -4.483), (-2.562, 2.803, -3.888), (3.076, 0.195, 4.149), (-0.101, 0.896, 1.157), (-2.067, 1.120, -0.273), (-4.680, 2.756, -4.851), (-4.283, -0.607, 2.072), (4.013, -1.072, 7.150), (-4.401, -0.896, 2.591), (4.544, 2.498, 0.276), (4.075, -1.204, 7.445), (-3.463, 1.242, -1.216), (3.992, 2.782, -0.568), (-4.503, 0.239, 0.270), (-3.095, 1.161, -0.870), (0.768, -0.904, 5.192), (1.255, 2.870, -2.112), (-1.537, -0.049, 2.330), (2.851, -1.182, 6.789), (1.974, -0.922, 5.832), (4.447, 2.719, -0.214), (-3.413, 0.555, 0.184), (4.943, 2.120, 1.231), (3.645, -0.413, 5.648), (-4.776, 0.079, 0.453), (1.991, 1.565, 0.866), (2.413, 1.793, 0.620), (4.245, 2.663, -0.205), (-2.022, -1.180, 4.350), (-2.285, -1.246, 4.350), (2.276, 0.488, 3.162), (2.582, -0.037, 4.365), (-4.875, 1.468, -2.374), (-2.492, 2.730, -3.706), (2.696, -1.833, 8.013), (4.618, -1.127, 7.563), (-4.156, 0.987, -1.053), (1.873, -1.566, 7.068), (1.699, 0.794, 2.262), (-3.181, 1.640, -1.871), (-3.225, 1.526, -1.664), (-2.679, -1.811, 5.281), (3.717, 1.532, 1.794), (1.288, -0.999, 5.642), (-1.057, 0.044, 2.384), (-0.147, 1.108, 0.711), (-3.827, -1.139, 3.365), (0.872, -1.482, 6.399), (1.982, 0.286, 3.418), (-1.381, 2.374, -2.439), (-1.091, 2.010, -1.565), (-1.192, 2.751, -3.097), (1.468, -0.992, 5.718), (2.249, 0.949, 2.228), (3.064, 0.911, 2.711), (-1.576, -1.584, 5.380), (2.130, -1.489, 7.043), (4.386, -1.284, 7.761), (1.662, -1.645, 7.121), (-3.395, 1.784, -2.265), (4.618, 1.951, 1.406), (-0.299, 0.378, 2.095), (-2.911, 2.131, -2.717), (0.876, 2.869, -2.301), (-1.785, 0.961, 0.186), (-4.188, 2.442, -3.977), (-1.128, 0.127, 2.181), (1.755, -1.215, 6.307), (-2.276, 0.596, 0.669), (-4.630, 1.978, -3.272), (-0.454, 0.275, 2.224), (-1.950, -1.385, 4.794), (-0.889, 2.696, -2.837), (-4.832, -0.038, 0.661), (3.738, 0.604, 3.662), (-0.224, -0.465, 3.819); --- -- insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0), (-1.099, 2.755, -3.060, 20.0, 40.0), (1.090, 2.945, -2.346, 20.0, 40.0), (0.305, 2.179, -1.205, 20.0, 40.0), (-0.925, 0.702, 1.134, 20.0, 40.0), (3.178, -1.316, 7.221, 20.0, 40.0), (-2.756, -0.473, 2.569, 20.0, 40.0), (3.665, 2.303, 0.226, 20.0, 40.0), (1.662, 1.951, -0.070, 20.0, 40.0), (2.869, 0.593, 3.249, 20.0, 40.0), (0.818, -0.593, 4.594, 20.0, 40.0), (-1.917, 0.916, 0.209, 20.0, 40.0), (2.706, 1.523, 1.307, 20.0, 40.0), (0.219, 2.162, -1.214, 20.0, 40.0), (-4.510, 1.376, -2.007, 20.0, 40.0), (4.284, -0.515, 6.173, 20.0, 40.0), (-1.101, 2.810, -3.170, 20.0, 40.0), (-1.810, -1.117, 4.329, 20.0, 40.0), (0.055, 1.115, 0.797, 20.0, 40.0), (-2.178, 2.904, -3.898, 20.0, 40.0), (-3.494, -1.814, 4.882, 20.0, 40.0), (3.027, 0.476, 3.562, 20.0, 40.0), (-1.434, 1.151, -0.018, 20.0, 40.0), (1.180, 0.992, 1.606, 20.0, 40.0), (0.015, 0.971, 1.067, 20.0, 40.0), (-0.511, -0.875, 4.495, 20.0, 40.0), (0.961, 2.348, -1.216, 20.0, 40.0), (-2.279, 0.038, 1.785, 20.0, 40.0), (-1.568, -0.248, 2.712, 20.0, 40.0), (-0.496, 0.366, 2.020, 20.0, 40.0), (1.177, -1.401, 6.390, 20.0, 40.0), (2.882, -1.442, 7.325, 20.0, 40.0), (-1.066, 1.817, -1.167, 20.0, 40.0), (-2.144, 2.791, -3.655, 20.0, 40.0), (-4.370, 2.228, -3.642, 20.0, 40.0), (3.996, 2.775, -0.553, 20.0, 40.0), (0.289, 2.055, -0.965, 20.0, 40.0), (-0.588, -1.601, 5.908, 20.0, 40.0), (-1.801, 0.417, 1.265, 20.0, 40.0), (4.375, -1.499, 8.186, 20.0, 40.0), (-2.618, 0.038, 1.615, 20.0, 40.0), (3.616, -0.833, 6.475, 20.0, 40.0), (-4.045, -1.558, 4.094, 20.0, 40.0), (-3.962, 0.636, -0.253, 20.0, 40.0), (3.505, 2.625, -0.497, 20.0, 40.0), (3.029, -0.523, 5.560, 20.0, 40.0), (-3.520, -0.474, 2.188, 20.0, 40.0), (2.430, -1.469, 7.154, 20.0, 40.0), (1.547, -1.654, 7.082, 20.0, 40.0), (-1.370, 0.575, 1.165, 20.0, 40.0), (-1.869, -1.555, 5.176, 20.0, 40.0), (3.536, 2.841, -0.913, 20.0, 40.0), (-3.810, 1.220, -1.344, 20.0, 40.0), (-1.971, 1.462, -0.910, 20.0, 40.0), (-0.243, 0.167, 2.545, 20.0, 40.0), (-1.403, 2.645, -2.991, 20.0, 40.0), (0.532, -0.114, 3.494, 20.0, 40.0), (-1.678, 0.975, 0.212, 20.0, 40.0), (-0.656, 2.140, -1.609, 20.0, 40.0), (1.743, 2.631, -1.390, 20.0, 40.0), (2.586, 2.943, -1.593, 20.0, 40.0), (-0.512, 2.969, -3.195, 20.0, 40.0), (2.283, -0.100, 4.342, 20.0, 40.0), (-4.293, 0.872, -0.890, 20.0, 40.0), (3.411, 1.300, 2.106, 20.0, 40.0), (-0.281, 2.951, -3.042, 20.0, 40.0), (-4.442, 0.384, 0.012, 20.0, 40.0), (1.194, 1.746, 0.104, 20.0, 40.0), (-1.152, 1.862, -1.300, 20.0, 40.0), (1.362, -1.341, 6.363, 20.0, 40.0), (-4.488, 2.618, -4.481, 20.0, 40.0), (3.419, -0.564, 5.837, 20.0, 40.0), (-3.392, 0.396, 0.512, 20.0, 40.0), (-1.629, -0.909, 4.003, 20.0, 40.0), (4.447, -1.088, 7.399, 20.0, 40.0), (-1.232, 1.699, -1.014, 20.0, 40.0), (-1.286, -0.609, 3.575, 20.0, 40.0), (2.437, 2.796, -1.374, 20.0, 40.0), (-4.864, 1.989, -3.410, 20.0, 40.0), (-1.716, -1.399, 4.940, 20.0, 40.0), (-3.084, 1.858, -2.259, 20.0, 40.0), (2.828, -0.319, 5.053, 20.0, 40.0), (-1.226, 2.586, -2.786, 20.0, 40.0), (2.456, 0.092, 4.044, 20.0, 40.0), (-0.989, 2.375, -2.245, 20.0, 40.0), (3.268, 0.935, 2.765, 20.0, 40.0), (-4.128, -1.995, 4.927, 20.0, 40.0), (-1.083, 2.197, -1.935, 20.0, 40.0), (-3.471, -1.198, 3.660, 20.0, 40.0), (4.617, -1.136, 7.579, 20.0, 40.0), (2.054, -1.675, 7.378, 20.0, 40.0), (4.106, 2.326, 0.402, 20.0, 40.0), (1.558, 0.310, 3.158, 20.0, 40.0), (0.792, 0.900, 1.596, 20.0, 40.0), (-3.229, 0.300, 0.785, 20.0, 40.0), (3.787, -0.793, 6.479, 20.0, 40.0), (1.786, 2.288, -0.684, 20.0, 40.0), (2.643, 0.223, 3.875, 20.0, 40.0), (-3.592, 2.122, -3.040, 20.0, 40.0), (4.519, -1.760, 8.779, 20.0, 40.0), (3.221, 2.255, 0.101, 20.0, 40.0), (4.151, 1.788, 1.500, 20.0, 40.0), (-1.033, -1.195, 4.874, 20.0, 40.0), (-1.636, -1.037, 4.257, 20.0, 40.0), (-3.548, 1.911, -2.596, 20.0, 40.0), (4.829, -0.293, 6.001, 20.0, 40.0), (-4.684, -1.664, 3.986, 20.0, 40.0), (4.531, -0.503, 6.271, 20.0, 40.0), (-3.503, -1.606, 4.460, 20.0, 40.0), (-2.036, -1.522, 5.027, 20.0, 40.0), (-0.473, -0.617, 3.997, 20.0, 40.0), (-1.554, -1.630, 5.483, 20.0, 40.0), (-3.567, -1.043, 3.302, 20.0, 40.0), (-2.038, 0.579, 0.823, 20.0, 40.0), (-3.040, 0.857, -0.233, 20.0, 40.0), (4.610, 0.562, 4.181, 20.0, 40.0), (-3.323, -1.938, 5.215, 20.0, 40.0), (4.314, 1.720, 1.717, 20.0, 40.0), (-1.220, 0.615, 1.161, 20.0, 40.0), (-2.556, 1.120, -0.519, 20.0, 40.0), (-3.717, -0.108, 1.358, 20.0, 40.0), (4.689, -1.826, 8.996, 20.0, 40.0), (3.452, 0.506, 3.713, 20.0, 40.0), (2.472, 0.612, 3.012, 20.0, 40.0), (3.452, 0.450, 3.826, 20.0, 40.0), (1.207, 2.585, -1.567, 20.0, 40.0), (-4.826, 1.090, -1.593, 20.0, 40.0), (3.116, -1.118, 6.794, 20.0, 40.0), (0.448, 2.732, -2.240, 20.0, 40.0), (-1.096, -0.525, 3.503, 20.0, 40.0), (-4.680, -0.238, 1.137, 20.0, 40.0), (2.552, -1.403, 7.082, 20.0, 40.0), (0.719, 2.997, -2.635, 20.0, 40.0), (0.347, -1.966, 7.105, 20.0, 40.0), (2.958, -0.404, 5.288, 20.0, 40.0), (0.722, -1.950, 7.261, 20.0, 40.0), (-2.851, -0.986, 3.546, 20.0, 40.0), (-4.316, -0.439, 1.721, 20.0, 40.0), (-1.685, -0.201, 2.560, 20.0, 40.0), (1.856, 0.190, 3.549, 20.0, 40.0), (-2.052, 0.206, 1.562, 20.0, 40.0), (-2.504, -0.646, 3.041, 20.0, 40.0), (3.235, 0.882, 2.854, 20.0, 40.0), (-1.366, -1.573, 5.463, 20.0, 40.0), (-3.447, 2.419, -3.562, 20.0, 40.0), (4.155, 2.092, 0.893, 20.0, 40.0), (-0.935, 0.209, 2.116, 20.0, 40.0), (3.117, -1.821, 8.201, 20.0, 40.0), (3.759, 0.577, 3.725, 20.0, 40.0), (-0.938, 2.992, -3.453, 20.0, 40.0), (-0.525, 2.341, -1.945, 20.0, 40.0), (4.540, 2.625, 0.019, 20.0, 40.0), (-2.097, 1.190, -0.429, 20.0, 40.0), (-2.672, 1.983, -2.302, 20.0, 40.0), (-3.038, -1.490, 4.460, 20.0, 40.0), (-0.943, 2.149, -1.770, 20.0, 40.0), (0.739, 1.598, 0.174, 20.0, 40.0), (1.828, 1.853, 0.208, 20.0, 40.0), (4.856, 0.137, 5.153, 20.0, 40.0), (-1.617, 0.468, 1.255, 20.0, 40.0), (-1.972, 2.053, -2.092, 20.0, 40.0), (-4.633, 1.389, -2.094, 20.0, 40.0), (-3.628, -1.156, 3.498, 20.0, 40.0), (3.597, 1.034, 2.731, 20.0, 40.0), (-1.488, -0.002, 2.261, 20.0, 40.0), (0.749, 1.921, -0.468, 20.0, 40.0), (1.304, -1.371, 6.394, 20.0, 40.0), (4.587, 2.936, -0.579, 20.0, 40.0), (-2.241, 1.791, -1.703, 20.0, 40.0), (-2.945, 1.372, -1.216, 20.0, 40.0), (1.375, 0.395, 2.898, 20.0, 40.0), (-1.281, -0.641, 3.642, 20.0, 40.0), (2.178, 0.895, 2.299, 20.0, 40.0), (3.031, -0.786, 6.087, 20.0, 40.0), (-1.385, -0.375, 3.058, 20.0, 40.0), (4.041, -0.431, 5.882, 20.0, 40.0), (0.480, -0.507, 4.254, 20.0, 40.0), (-3.797, 0.140, 0.822, 20.0, 40.0), (2.355, 2.502, -0.827, 20.0, 40.0), (1.376, -1.583, 6.854, 20.0, 40.0), (0.164, 1.405, 0.273, 20.0, 40.0), (-1.273, 1.471, -0.579, 20.0, 40.0), (0.770, 2.246, -1.107, 20.0, 40.0), (4.552, 2.904, -0.533, 20.0, 40.0), (4.259, -1.772, 8.674, 20.0, 40.0), (-0.309, 1.159, 0.528, 20.0, 40.0), (3.581, 2.700, -0.610, 20.0, 40.0), (-3.202, 0.346, 0.707, 20.0, 40.0), (-1.575, 1.242, -0.271, 20.0, 40.0), (-1.584, -0.493, 3.194, 20.0, 40.0), (-3.778, 0.150, 0.810, 20.0, 40.0), (-4.675, 1.749, -2.835, 20.0, 40.0), (3.567, -0.792, 6.367, 20.0, 40.0), (-0.417, 1.399, -0.006, 20.0, 40.0), (-4.672, 2.007, -3.349, 20.0, 40.0), (-1.034, 0.196, 2.090, 20.0, 40.0), (-3.796, 2.496, -3.890, 20.0, 40.0), (3.532, -0.497, 5.759, 20.0, 40.0), (4.868, -1.359, 8.151, 20.0, 40.0), (-0.769, 0.302, 2.011, 20.0, 40.0), (4.475, 2.612, 0.014, 20.0, 40.0), (-3.532, -0.395, 2.024, 20.0, 40.0), (0.322, 0.675, 1.812, 20.0, 40.0), (-2.028, -1.942, 5.870, 20.0, 40.0), (1.810, -1.244, 6.392, 20.0, 40.0), (-0.783, 1.242, 0.124, 20.0, 40.0), (-4.745, -1.300, 3.227, 20.0, 40.0), (1.902, 1.973, 0.005, 20.0, 40.0), (-3.453, -1.429, 4.132, 20.0, 40.0), (1.559, 0.986, 1.808, 20.0, 40.0), (0.128, 2.754, -2.443, 20.0, 40.0), (2.759, 1.727, 0.926, 20.0, 40.0), (-4.468, 1.690, -2.614, 20.0, 40.0), (-2.368, -1.922, 5.659, 20.0, 40.0), (-2.766, 2.128, -2.640, 20.0, 40.0), (0.967, -1.825, 7.133, 20.0, 40.0), (-2.854, 2.855, -4.136, 20.0, 40.0), (-2.944, 1.875, -2.222, 20.0, 40.0), (-2.632, -0.983, 3.649, 20.0, 40.0), (2.427, 2.239, -0.266, 20.0, 40.0), (-1.726, -0.838, 3.812, 20.0, 40.0), (0.007, -0.903, 4.809, 20.0, 40.0), (-2.013, 1.092, -0.191, 20.0, 40.0), (-0.449, 0.970, 0.836, 20.0, 40.0), (1.396, 0.411, 2.876, 20.0, 40.0), (-1.115, -1.790, 6.023, 20.0, 40.0), (3.748, 1.917, 1.039, 20.0, 40.0), (2.978, 1.043, 2.404, 20.0, 40.0), (-3.969, 2.514, -4.013, 20.0, 40.0), (4.455, -0.050, 5.328, 20.0, 40.0), (-3.065, -0.846, 3.160, 20.0, 40.0), (-1.069, 2.167, -1.869, 20.0, 40.0), (3.016, -1.393, 7.294, 20.0, 40.0), (0.045, -1.928, 6.879, 20.0, 40.0), (-2.555, -0.984, 3.690, 20.0, 40.0), (-1.995, -0.054, 2.111, 20.0, 40.0), (4.600, -0.509, 6.318, 20.0, 40.0), (-1.942, 1.215, -0.402, 20.0, 40.0), (1.262, 2.765, -1.899, 20.0, 40.0), (2.617, -1.106, 6.521, 20.0, 40.0), (1.737, 0.554, 2.761, 20.0, 40.0), (-2.197, 0.632, 0.638, 20.0, 40.0), (4.768, 2.618, 0.147, 20.0, 40.0), (-3.737, -0.939, 3.010, 20.0, 40.0), (-2.623, 0.595, 0.499, 20.0, 40.0), (4.752, -0.340, 6.057, 20.0, 40.0), (2.333, -1.037, 6.240, 20.0, 40.0), (4.234, -1.882, 8.881, 20.0, 40.0), (-3.393, -0.812, 2.927, 20.0, 40.0), (0.885, 1.383, 0.678, 20.0, 40.0), (0.123, 2.937, -2.812, 20.0, 40.0), (2.969, 0.760, 2.964, 20.0, 40.0), (-4.929, 1.251, -1.967, 20.0, 40.0), (1.916, 2.223, -0.488, 20.0, 40.0), (-0.020, -1.740, 6.469, 20.0, 40.0), (0.702, -1.272, 5.895, 20.0, 40.0), (2.496, 2.648, -1.048, 20.0, 40.0), (4.067, -1.475, 7.984, 20.0, 40.0), (-3.717, 1.851, -2.561, 20.0, 40.0), (1.678, -0.624, 5.088, 20.0, 40.0), (1.073, 0.695, 2.146, 20.0, 40.0), (1.842, -0.749, 5.419, 20.0, 40.0), (-3.518, 1.909, -2.578, 20.0, 40.0), (2.229, 1.189, 1.737, 20.0, 40.0), (4.987, 2.893, -0.292, 20.0, 40.0), (-4.809, 1.043, -1.490, 20.0, 40.0), (-0.241, -0.728, 4.334, 20.0, 40.0), (-3.331, 0.590, 0.156, 20.0, 40.0), (-0.455, 2.621, -2.470, 20.0, 40.0), (1.492, 1.223, 1.301, 20.0, 40.0), (3.948, 2.841, -0.709, 20.0, 40.0), (0.732, 0.446, 2.475, 20.0, 40.0), (2.400, 2.390, -0.579, 20.0, 40.0), (-2.718, 1.427, -1.213, 20.0, 40.0), (-1.826, 1.451, -0.815, 20.0, 40.0), (1.125, 0.438, 2.686, 20.0, 40.0), (-4.918, 1.880, -3.219, 20.0, 40.0), (3.068, -0.442, 5.418, 20.0, 40.0), (1.982, 1.201, 1.589, 20.0, 40.0), (0.701, -1.709, 6.768, 20.0, 40.0), (-1.496, 2.564, -2.877, 20.0, 40.0), (-3.812, 0.974, -0.853, 20.0, 40.0), (-3.405, 2.018, -2.739, 20.0, 40.0), (2.211, 2.889, -1.674, 20.0, 40.0), (-2.481, 2.931, -4.103, 20.0, 40.0), (-3.721, 2.765, -4.391, 20.0, 40.0), (-1.768, -1.292, 4.699, 20.0, 40.0), (-4.462, 1.058, -1.347, 20.0, 40.0), (-3.516, -1.942, 5.126, 20.0, 40.0), (0.485, 2.420, -1.597, 20.0, 40.0), (-0.492, 0.242, 2.270, 20.0, 40.0), (4.245, 1.689, 1.744, 20.0, 40.0), (2.234, 0.364, 3.389, 20.0, 40.0), (2.629, 2.224, -0.134, 20.0, 40.0), (-4.375, 1.221, -1.630, 20.0, 40.0), (-0.618, 1.374, -0.057, 20.0, 40.0), (-2.580, -1.604, 4.918, 20.0, 40.0), (0.159, 1.104, 0.871, 20.0, 40.0), (-3.597, 0.975, -0.749, 20.0, 40.0); --- -- insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1),(-3.273, -1.452, 4.267, 20.0, 1) -insert into test.defaults values (1,2,1,1,2), (1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2),(1,2,1,1,2) --- insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0), (-1.099, 2.755, -3.060, 20.0, 40.0), (1.090, 2.945, -2.346, 20.0, 40.0), (0.305, 2.179, -1.205, 20.0, 40.0), (-0.925, 0.702, 1.134, 20.0, 40.0), (3.178, -1.316, 7.221, 20.0, 40.0), (-2.756, -0.473, 2.569, 20.0, 40.0), (3.665, 2.303, 0.226, 20.0, 40.0), (1.662, 1.951, -0.070, 20.0, 40.0), (2.869, 0.593, 3.249, 20.0, 40.0), (0.818, -0.593, 4.594, 20.0, 40.0), (-1.917, 0.916, 0.209, 20.0, 40.0), (2.706, 1.523, 1.307, 20.0, 40.0), (0.219, 2.162, -1.214, 20.0, 40.0), (-4.510, 1.376, -2.007, 20.0, 40.0), (4.284, -0.515, 6.173, 20.0, 40.0), (-1.101, 2.810, -3.170, 20.0, 40.0), (-1.810, -1.117, 4.329, 20.0, 40.0), (0.055, 1.115, 0.797, 20.0, 40.0), (-2.178, 2.904, -3.898, 20.0, 40.0), (-3.494, -1.814, 4.882, 20.0, 40.0), (3.027, 0.476, 3.562, 20.0, 40.0), (-1.434, 1.151, -0.018, 20.0, 40.0), (1.180, 0.992, 1.606, 20.0, 40.0), (0.015, 0.971, 1.067, 20.0, 40.0), (-0.511, -0.875, 4.495, 20.0, 40.0), (0.961, 2.348, -1.216, 20.0, 40.0), (-2.279, 0.038, 1.785, 20.0, 40.0), (-1.568, -0.248, 2.712, 20.0, 40.0), (-0.496, 0.366, 2.020, 20.0, 40.0), (1.177, -1.401, 6.390, 20.0, 40.0), (2.882, -1.442, 7.325, 20.0, 40.0), (-1.066, 1.817, -1.167, 20.0, 40.0), (-2.144, 2.791, -3.655, 20.0, 40.0), (-4.370, 2.228, -3.642, 20.0, 40.0), (3.996, 2.775, -0.553, 20.0, 40.0), (0.289, 2.055, -0.965, 20.0, 40.0), (-0.588, -1.601, 5.908, 20.0, 40.0), (-1.801, 0.417, 1.265, 20.0, 40.0), (4.375, -1.499, 8.186, 20.0, 40.0), (-2.618, 0.038, 1.615, 20.0, 40.0), (3.616, -0.833, 6.475, 20.0, 40.0), (-4.045, -1.558, 4.094, 20.0, 40.0), (-3.962, 0.636, -0.253, 20.0, 40.0), (3.505, 2.625, -0.497, 20.0, 40.0), (3.029, -0.523, 5.560, 20.0, 40.0), (-3.520, -0.474, 2.188, 20.0, 40.0), (2.430, -1.469, 7.154, 20.0, 40.0), (1.547, -1.654, 7.082, 20.0, 40.0), (-1.370, 0.575, 1.165, 20.0, 40.0), (-1.869, -1.555, 5.176, 20.0, 40.0), (3.536, 2.841, -0.913, 20.0, 40.0), (-3.810, 1.220, -1.344, 20.0, 40.0), (-1.971, 1.462, -0.910, 20.0, 40.0), (-0.243, 0.167, 2.545, 20.0, 40.0), (-1.403, 2.645, -2.991, 20.0, 40.0), (0.532, -0.114, 3.494, 20.0, 40.0), (-1.678, 0.975, 0.212, 20.0, 40.0), (-0.656, 2.140, -1.609, 20.0, 40.0), (1.743, 2.631, -1.390, 20.0, 40.0), (2.586, 2.943, -1.593, 20.0, 40.0), (-0.512, 2.969, -3.195, 20.0, 40.0), (2.283, -0.100, 4.342, 20.0, 40.0), (-4.293, 0.872, -0.890, 20.0, 40.0), (3.411, 1.300, 2.106, 20.0, 40.0), (-0.281, 2.951, -3.042, 20.0, 40.0), (-4.442, 0.384, 0.012, 20.0, 40.0), (1.194, 1.746, 0.104, 20.0, 40.0), (-1.152, 1.862, -1.300, 20.0, 40.0), (1.362, -1.341, 6.363, 20.0, 40.0), (-4.488, 2.618, -4.481, 20.0, 40.0), (3.419, -0.564, 5.837, 20.0, 40.0), (-3.392, 0.396, 0.512, 20.0, 40.0), (-1.629, -0.909, 4.003, 20.0, 40.0), (4.447, -1.088, 7.399, 20.0, 40.0), (-1.232, 1.699, -1.014, 20.0, 40.0), (-1.286, -0.609, 3.575, 20.0, 40.0), (2.437, 2.796, -1.374, 20.0, 40.0), (-4.864, 1.989, -3.410, 20.0, 40.0), (-1.716, -1.399, 4.940, 20.0, 40.0), (-3.084, 1.858, -2.259, 20.0, 40.0), (2.828, -0.319, 5.053, 20.0, 40.0), (-1.226, 2.586, -2.786, 20.0, 40.0), (2.456, 0.092, 4.044, 20.0, 40.0), (-0.989, 2.375, -2.245, 20.0, 40.0), (3.268, 0.935, 2.765, 20.0, 40.0), (-4.128, -1.995, 4.927, 20.0, 40.0), (-1.083, 2.197, -1.935, 20.0, 40.0), (-3.471, -1.198, 3.660, 20.0, 40.0), (4.617, -1.136, 7.579, 20.0, 40.0), (2.054, -1.675, 7.378, 20.0, 40.0), (4.106, 2.326, 0.402, 20.0, 40.0), (1.558, 0.310, 3.158, 20.0, 40.0), (0.792, 0.900, 1.596, 20.0, 40.0), (-3.229, 0.300, 0.785, 20.0, 40.0), (3.787, -0.793, 6.479, 20.0, 40.0), (1.786, 2.288, -0.684, 20.0, 40.0), (2.643, 0.223, 3.875, 20.0, 40.0), (-3.592, 2.122, -3.040, 20.0, 40.0), (4.519, -1.760, 8.779, 20.0, 40.0), (3.221, 2.255, 0.101, 20.0, 40.0), (4.151, 1.788, 1.500, 20.0, 40.0), (-1.033, -1.195, 4.874, 20.0, 40.0), (-1.636, -1.037, 4.257, 20.0, 40.0), (-3.548, 1.911, -2.596, 20.0, 40.0), (4.829, -0.293, 6.001, 20.0, 40.0), (-4.684, -1.664, 3.986, 20.0, 40.0), (4.531, -0.503, 6.271, 20.0, 40.0), (-3.503, -1.606, 4.460, 20.0, 40.0), (-2.036, -1.522, 5.027, 20.0, 40.0), (-0.473, -0.617, 3.997, 20.0, 40.0), (-1.554, -1.630, 5.483, 20.0, 40.0), (-3.567, -1.043, 3.302, 20.0, 40.0), (-2.038, 0.579, 0.823, 20.0, 40.0), (-3.040, 0.857, -0.233, 20.0, 40.0), (4.610, 0.562, 4.181, 20.0, 40.0), (-3.323, -1.938, 5.215, 20.0, 40.0), (4.314, 1.720, 1.717, 20.0, 40.0), (-1.220, 0.615, 1.161, 20.0, 40.0), (-2.556, 1.120, -0.519, 20.0, 40.0), (-3.717, -0.108, 1.358, 20.0, 40.0), (4.689, -1.826, 8.996, 20.0, 40.0), (3.452, 0.506, 3.713, 20.0, 40.0), (2.472, 0.612, 3.012, 20.0, 40.0), (3.452, 0.450, 3.826, 20.0, 40.0), (1.207, 2.585, -1.567, 20.0, 40.0), (-4.826, 1.090, -1.593, 20.0, 40.0), (3.116, -1.118, 6.794, 20.0, 40.0), (0.448, 2.732, -2.240, 20.0, 40.0), (-1.096, -0.525, 3.503, 20.0, 40.0), (-4.680, -0.238, 1.137, 20.0, 40.0), (2.552, -1.403, 7.082, 20.0, 40.0), (0.719, 2.997, -2.635, 20.0, 40.0), (0.347, -1.966, 7.105, 20.0, 40.0), (2.958, -0.404, 5.288, 20.0, 40.0), (0.722, -1.950, 7.261, 20.0, 40.0), (-2.851, -0.986, 3.546, 20.0, 40.0), (-4.316, -0.439, 1.721, 20.0, 40.0), (-1.685, -0.201, 2.560, 20.0, 40.0), (1.856, 0.190, 3.549, 20.0, 40.0), (-2.052, 0.206, 1.562, 20.0, 40.0), (-2.504, -0.646, 3.041, 20.0, 40.0), (3.235, 0.882, 2.854, 20.0, 40.0), (-1.366, -1.573, 5.463, 20.0, 40.0), (-3.447, 2.419, -3.562, 20.0, 40.0), (4.155, 2.092, 0.893, 20.0, 40.0), (-0.935, 0.209, 2.116, 20.0, 40.0), (3.117, -1.821, 8.201, 20.0, 40.0), (3.759, 0.577, 3.725, 20.0, 40.0), (-0.938, 2.992, -3.453, 20.0, 40.0), (-0.525, 2.341, -1.945, 20.0, 40.0), (4.540, 2.625, 0.019, 20.0, 40.0), (-2.097, 1.190, -0.429, 20.0, 40.0), (-2.672, 1.983, -2.302, 20.0, 40.0), (-3.038, -1.490, 4.460, 20.0, 40.0), (-0.943, 2.149, -1.770, 20.0, 40.0), (0.739, 1.598, 0.174, 20.0, 40.0), (1.828, 1.853, 0.208, 20.0, 40.0), (4.856, 0.137, 5.153, 20.0, 40.0), (-1.617, 0.468, 1.255, 20.0, 40.0), (-1.972, 2.053, -2.092, 20.0, 40.0), (-4.633, 1.389, -2.094, 20.0, 40.0), (-3.628, -1.156, 3.498, 20.0, 40.0), (3.597, 1.034, 2.731, 20.0, 40.0), (-1.488, -0.002, 2.261, 20.0, 40.0), (0.749, 1.921, -0.468, 20.0, 40.0), (1.304, -1.371, 6.394, 20.0, 40.0), (4.587, 2.936, -0.579, 20.0, 40.0), (-2.241, 1.791, -1.703, 20.0, 40.0), (-2.945, 1.372, -1.216, 20.0, 40.0), (1.375, 0.395, 2.898, 20.0, 40.0), (-1.281, -0.641, 3.642, 20.0, 40.0), (2.178, 0.895, 2.299, 20.0, 40.0), (3.031, -0.786, 6.087, 20.0, 40.0), (-1.385, -0.375, 3.058, 20.0, 40.0), (4.041, -0.431, 5.882, 20.0, 40.0), (0.480, -0.507, 4.254, 20.0, 40.0), (-3.797, 0.140, 0.822, 20.0, 40.0), (2.355, 2.502, -0.827, 20.0, 40.0), (1.376, -1.583, 6.854, 20.0, 40.0), (0.164, 1.405, 0.273, 20.0, 40.0), (-1.273, 1.471, -0.579, 20.0, 40.0), (0.770, 2.246, -1.107, 20.0, 40.0), (4.552, 2.904, -0.533, 20.0, 40.0), (4.259, -1.772, 8.674, 20.0, 40.0), (-0.309, 1.159, 0.528, 20.0, 40.0), (3.581, 2.700, -0.610, 20.0, 40.0), (-3.202, 0.346, 0.707, 20.0, 40.0), (-1.575, 1.242, -0.271, 20.0, 40.0), (-1.584, -0.493, 3.194, 20.0, 40.0), (-3.778, 0.150, 0.810, 20.0, 40.0), (-4.675, 1.749, -2.835, 20.0, 40.0), (3.567, -0.792, 6.367, 20.0, 40.0), (-0.417, 1.399, -0.006, 20.0, 40.0), (-4.672, 2.007, -3.349, 20.0, 40.0), (-1.034, 0.196, 2.090, 20.0, 40.0), (-3.796, 2.496, -3.890, 20.0, 40.0), (3.532, -0.497, 5.759, 20.0, 40.0), (4.868, -1.359, 8.151, 20.0, 40.0), (-0.769, 0.302, 2.011, 20.0, 40.0), (4.475, 2.612, 0.014, 20.0, 40.0), (-3.532, -0.395, 2.024, 20.0, 40.0), (0.322, 0.675, 1.812, 20.0, 40.0), (-2.028, -1.942, 5.870, 20.0, 40.0), (1.810, -1.244, 6.392, 20.0, 40.0), (-0.783, 1.242, 0.124, 20.0, 40.0), (-4.745, -1.300, 3.227, 20.0, 40.0), (1.902, 1.973, 0.005, 20.0, 40.0), (-3.453, -1.429, 4.132, 20.0, 40.0), (1.559, 0.986, 1.808, 20.0, 40.0), (0.128, 2.754, -2.443, 20.0, 40.0), (2.759, 1.727, 0.926, 20.0, 40.0), (-4.468, 1.690, -2.614, 20.0, 40.0), (-2.368, -1.922, 5.659, 20.0, 40.0), (-2.766, 2.128, -2.640, 20.0, 40.0), (0.967, -1.825, 7.133, 20.0, 40.0), (-2.854, 2.855, -4.136, 20.0, 40.0), (-2.944, 1.875, -2.222, 20.0, 40.0), (-2.632, -0.983, 3.649, 20.0, 40.0), (2.427, 2.239, -0.266, 20.0, 40.0), (-1.726, -0.838, 3.812, 20.0, 40.0), (0.007, -0.903, 4.809, 20.0, 40.0), (-2.013, 1.092, -0.191, 20.0, 40.0), (-0.449, 0.970, 0.836, 20.0, 40.0), (1.396, 0.411, 2.876, 20.0, 40.0), (-1.115, -1.790, 6.023, 20.0, 40.0), (3.748, 1.917, 1.039, 20.0, 40.0), (2.978, 1.043, 2.404, 20.0, 40.0), (-3.969, 2.514, -4.013, 20.0, 40.0), (4.455, -0.050, 5.328, 20.0, 40.0), (-3.065, -0.846, 3.160, 20.0, 40.0), (-1.069, 2.167, -1.869, 20.0, 40.0), (3.016, -1.393, 7.294, 20.0, 40.0), (0.045, -1.928, 6.879, 20.0, 40.0), (-2.555, -0.984, 3.690, 20.0, 40.0), (-1.995, -0.054, 2.111, 20.0, 40.0), (4.600, -0.509, 6.318, 20.0, 40.0), (-1.942, 1.215, -0.402, 20.0, 40.0), (1.262, 2.765, -1.899, 20.0, 40.0), (2.617, -1.106, 6.521, 20.0, 40.0), (1.737, 0.554, 2.761, 20.0, 40.0), (-2.197, 0.632, 0.638, 20.0, 40.0), (4.768, 2.618, 0.147, 20.0, 40.0), (-3.737, -0.939, 3.010, 20.0, 40.0), (-2.623, 0.595, 0.499, 20.0, 40.0), (4.752, -0.340, 6.057, 20.0, 40.0), (2.333, -1.037, 6.240, 20.0, 40.0), (4.234, -1.882, 8.881, 20.0, 40.0), (-3.393, -0.812, 2.927, 20.0, 40.0), (0.885, 1.383, 0.678, 20.0, 40.0), (0.123, 2.937, -2.812, 20.0, 40.0), (2.969, 0.760, 2.964, 20.0, 40.0), (-4.929, 1.251, -1.967, 20.0, 40.0), (1.916, 2.223, -0.488, 20.0, 40.0), (-0.020, -1.740, 6.469, 20.0, 40.0), (0.702, -1.272, 5.895, 20.0, 40.0), (2.496, 2.648, -1.048, 20.0, 40.0), (4.067, -1.475, 7.984, 20.0, 40.0), (-3.717, 1.851, -2.561, 20.0, 40.0), (1.678, -0.624, 5.088, 20.0, 40.0), (1.073, 0.695, 2.146, 20.0, 40.0), (1.842, -0.749, 5.419, 20.0, 40.0), (-3.518, 1.909, -2.578, 20.0, 40.0), (2.229, 1.189, 1.737, 20.0, 40.0), (4.987, 2.893, -0.292, 20.0, 40.0), (-4.809, 1.043, -1.490, 20.0, 40.0), (-0.241, -0.728, 4.334, 20.0, 40.0), (-3.331, 0.590, 0.156, 20.0, 40.0), (-0.455, 2.621, -2.470, 20.0, 40.0), (1.492, 1.223, 1.301, 20.0, 40.0), (3.948, 2.841, -0.709, 20.0, 40.0), (0.732, 0.446, 2.475, 20.0, 40.0), (2.400, 2.390, -0.579, 20.0, 40.0), (-2.718, 1.427, -1.213, 20.0, 40.0), (-1.826, 1.451, -0.815, 20.0, 40.0), (1.125, 0.438, 2.686, 20.0, 40.0), (-4.918, 1.880, -3.219, 20.0, 40.0), (3.068, -0.442, 5.418, 20.0, 40.0), (1.982, 1.201, 1.589, 20.0, 40.0), (0.701, -1.709, 6.768, 20.0, 40.0), (-1.496, 2.564, -2.877, 20.0, 40.0), (-3.812, 0.974, -0.853, 20.0, 40.0), (-3.405, 2.018, -2.739, 20.0, 40.0), (2.211, 2.889, -1.674, 20.0, 40.0), (-2.481, 2.931, -4.103, 20.0, 40.0), (-3.721, 2.765, -4.391, 20.0, 40.0), (-1.768, -1.292, 4.699, 20.0, 40.0), (-4.462, 1.058, -1.347, 20.0, 40.0), (-3.516, -1.942, 5.126, 20.0, 40.0), (0.485, 2.420, -1.597, 20.0, 40.0), (-0.492, 0.242, 2.270, 20.0, 40.0), (4.245, 1.689, 1.744, 20.0, 40.0), (2.234, 0.364, 3.389, 20.0, 40.0), (2.629, 2.224, -0.134, 20.0, 40.0), (-4.375, 1.221, -1.630, 20.0, 40.0), (-0.618, 1.374, -0.057, 20.0, 40.0), (-2.580, -1.604, 4.918, 20.0, 40.0), (0.159, 1.104, 0.871, 20.0, 40.0), (-3.597, 0.975, -0.749, 20.0, 40.0); --- -DROP TABLE IF EXISTS test.model; -create table test.model engine = Memory as select LogisticRegressionState(0.1, 5, 1.0)(target, param1, param2) as state from test.defaults; --- -- select toTypeName(state) from test.model; --- -- --- -- DROP TABLE IF EXISTS test.tests; --- -- CREATE TABLE IF NOT EXISTS test.tests --- -- ( --- -- predict1 Float64, --- -- predict2 Float64, --- -- state1 AggregateFunction(LinReg(0.01), Float64, Float64, Float64) --- -- ) ENGINE = Memory; --- -- insert into test.tests select 20.0, 40.0, LinRegState(0.01)(target, param1, param2) from test.defaults; --- -- select evalLinReg(state1, predict1, predict2) from test.tests; --- --- --- --- -- DROP TABLE IF EXISTS test.prediction; --- -- CREATE TABLE IF NOT EXISTS test.prediction --- -- ( --- -- predict1 Float64, --- -- predict2 Float64 --- -- ) ENGINE = Memory; --- --- --- -- insert into test.prediction values (20.0, 40.0); --- --- -- select multiply(param1, param2) from test.defaults; --- --- -- select evalLinReg(LinRegState(0.01)(target, param1, param2), 20.0, 40.0) from test.defaults; -select evalMLMethod(state, predict1, predict2) from test.model cross join test.defaults; From 4cc0ee677a15c7019025ccaefe7a18a3ff4bfe6b Mon Sep 17 00:00:00 2001 From: Guillaume Tassery Date: Wed, 17 Apr 2019 13:21:26 +0700 Subject: [PATCH 048/709] Use gperf perfect hash for checking with a better accurency the tld for firstSignificantSubdomain and cutToFirstSignificantSubdomain --- .gitignore | 3 + CMakeLists.txt | 10 + dbms/src/Functions/CMakeLists.txt | 6 + .../src/Functions/firstSignificantSubdomain.h | 37 +- dbms/src/Functions/gperf/f.cpp | 41028 ++++++++++++++++ dbms/src/Functions/gperf/tldLookup.gperf | 8633 ++++ dbms/src/Functions/tldLookup.h | 16 + docs/en/development/build.md | 5 + docs/en/development/build_osx.md | 2 +- 9 files changed, 49712 insertions(+), 28 deletions(-) create mode 100644 dbms/src/Functions/gperf/f.cpp create mode 100644 dbms/src/Functions/gperf/tldLookup.gperf create mode 100644 dbms/src/Functions/tldLookup.h diff --git a/.gitignore b/.gitignore index 65b239a68ff..8cc0c3c8763 100644 --- a/.gitignore +++ b/.gitignore @@ -223,6 +223,9 @@ config-preprocessed.xml *.pb.cpp *.pb.h +# Gperf generated file +dbms/src/Functions/tldLookup.cpp + # Ignore symlink to private repository /private diff --git a/CMakeLists.txt b/CMakeLists.txt index 8c4802295a7..01506b6d9fc 100644 --- a/CMakeLists.txt +++ b/CMakeLists.txt @@ -250,6 +250,15 @@ if (USE_INCLUDE_WHAT_YOU_USE) endif() endif () +#Check if gperf was installed +option (USE_GPERF "Use gperf function hash generator tool" ON) +if (USE_GPERF) + find_program(GPERF gperf) + if (NOT GPERF) + message(FATAL_ERROR "Could not find the program gperf") + endif() +endif() + # Flags for test coverage if (TEST_COVERAGE) set (CMAKE_CXX_FLAGS_DEBUG "${CMAKE_CXX_FLAGS_DEBUG} -fprofile-arcs -ftest-coverage -DIS_DEBUG") @@ -323,6 +332,7 @@ find_contrib_lib(metrohash) find_contrib_lib(btrie) find_contrib_lib(double-conversion) include (cmake/find_parquet.cmake) + if (ENABLE_TESTS) include (cmake/find_gtest.cmake) endif () diff --git a/dbms/src/Functions/CMakeLists.txt b/dbms/src/Functions/CMakeLists.txt index 47d86190562..4247c26baa2 100644 --- a/dbms/src/Functions/CMakeLists.txt +++ b/dbms/src/Functions/CMakeLists.txt @@ -3,6 +3,12 @@ include(${ClickHouse_SOURCE_DIR}/cmake/dbms_glob_sources.cmake) add_headers_and_sources(clickhouse_functions ./GatherUtils) add_headers_and_sources(clickhouse_functions .) +add_custom_command( + OUTPUT ${CMAKE_CURRENT_SOURCE_DIR}/tldLookup.cpp + COMMAND ${GPERF} ${CMAKE_CURRENT_SOURCE_DIR}/gperf/tldLookup.gperf --output-file=${CMAKE_CURRENT_SOURCE_DIR}/tldLookup.cpp +) + +list(APPEND clickhouse_functions_sources tldLookup.cpp) list(REMOVE_ITEM clickhouse_functions_sources IFunction.cpp FunctionFactory.cpp FunctionHelpers.cpp) list(REMOVE_ITEM clickhouse_functions_headers IFunction.h FunctionFactory.h FunctionHelpers.h) diff --git a/dbms/src/Functions/firstSignificantSubdomain.h b/dbms/src/Functions/firstSignificantSubdomain.h index f464c3fdead..864b4d8bd8f 100644 --- a/dbms/src/Functions/firstSignificantSubdomain.h +++ b/dbms/src/Functions/firstSignificantSubdomain.h @@ -2,7 +2,7 @@ #include #include - +#include namespace DB { @@ -58,33 +58,16 @@ struct ExtractFirstSignificantSubdomain if (!last_3_periods[2]) last_3_periods[2] = begin - 1; - size_t size_of_second_subdomain_plus_period = last_3_periods[0] - last_3_periods[1]; - if (size_of_second_subdomain_plus_period == 4 || size_of_second_subdomain_plus_period == 3) - { - /// We will key by four bytes that are either ".xyz" or ".xy.". - UInt32 key = unalignedLoad(last_3_periods[1]); + if (tldLookup::is_valid(last_3_periods[1] + 1, end - last_3_periods[1] - 1) != nullptr) + { + res_data += last_3_periods[2] + 1 - begin; + res_size = last_3_periods[1] - last_3_periods[2] - 1; + } else { + res_data += last_3_periods[1] + 1 - begin; + res_size = last_3_periods[0] - last_3_periods[1] - 1; + } - /// NOTE: assuming little endian. - /// NOTE: does the compiler generate SIMD code? - /// NOTE: for larger amount of cases we can use a perfect hash table (see 'gperf' as an example). - if ( key == '.' + 'c' * 0x100U + 'o' * 0x10000U + 'm' * 0x1000000U - || key == '.' + 'n' * 0x100U + 'e' * 0x10000U + 't' * 0x1000000U - || key == '.' + 'o' * 0x100U + 'r' * 0x10000U + 'g' * 0x1000000U - || key == '.' + 'b' * 0x100U + 'i' * 0x10000U + 'z' * 0x1000000U - || key == '.' + 'g' * 0x100U + 'o' * 0x10000U + 'v' * 0x1000000U - || key == '.' + 'm' * 0x100U + 'i' * 0x10000U + 'l' * 0x1000000U - || key == '.' + 'e' * 0x100U + 'd' * 0x10000U + 'u' * 0x1000000U - || key == '.' + 'c' * 0x100U + 'o' * 0x10000U + '.' * 0x1000000U) - { - res_data += last_3_periods[2] + 1 - begin; - res_size = last_3_periods[1] - last_3_periods[2] - 1; - return; - } - } - - res_data += last_3_periods[1] + 1 - begin; - res_size = last_3_periods[0] - last_3_periods[1] - 1; - } + } }; } diff --git a/dbms/src/Functions/gperf/f.cpp b/dbms/src/Functions/gperf/f.cpp new file mode 100644 index 00000000000..f31ff34f8bf --- /dev/null +++ b/dbms/src/Functions/gperf/f.cpp @@ -0,0 +1,41028 @@ +/* C++ code produced by gperf version 3.1 */ +/* Command-line: gperf --output-file=./f.cpp tldLookup.gperf */ +/* Computed positions: -k'1-15,17,20,22,25,27' */ + +#if !((' ' == 32) && ('!' == 33) && ('"' == 34) && ('#' == 35) \ + && ('%' == 37) && ('&' == 38) && ('\'' == 39) && ('(' == 40) \ + && (')' == 41) && ('*' == 42) && ('+' == 43) && (',' == 44) \ + && ('-' == 45) && ('.' == 46) && ('/' == 47) && ('0' == 48) \ + && ('1' == 49) && ('2' == 50) && ('3' == 51) && ('4' == 52) \ + && ('5' == 53) && ('6' == 54) && ('7' == 55) && ('8' == 56) \ + && ('9' == 57) && (':' == 58) && (';' == 59) && ('<' == 60) \ + && ('=' == 61) && ('>' == 62) && ('?' == 63) && ('A' == 65) \ + && ('B' == 66) && ('C' == 67) && ('D' == 68) && ('E' == 69) \ + && ('F' == 70) && ('G' == 71) && ('H' == 72) && ('I' == 73) \ + && ('J' == 74) && ('K' == 75) && ('L' == 76) && ('M' == 77) \ + && ('N' == 78) && ('O' == 79) && ('P' == 80) && ('Q' == 81) \ + && ('R' == 82) && ('S' == 83) && ('T' == 84) && ('U' == 85) \ + && ('V' == 86) && ('W' == 87) && ('X' == 88) && ('Y' == 89) \ + && ('Z' == 90) && ('[' == 91) && ('\\' == 92) && (']' == 93) \ + && ('^' == 94) && ('_' == 95) && ('a' == 97) && ('b' == 98) \ + && ('c' == 99) && ('d' == 100) && ('e' == 101) && ('f' == 102) \ + && ('g' == 103) && ('h' == 104) && ('i' == 105) && ('j' == 106) \ + && ('k' == 107) && ('l' == 108) && ('m' == 109) && ('n' == 110) \ + && ('o' == 111) && ('p' == 112) && ('q' == 113) && ('r' == 114) \ + && ('s' == 115) && ('t' == 116) && ('u' == 117) && ('v' == 118) \ + && ('w' == 119) && ('x' == 120) && ('y' == 121) && ('z' == 122) \ + && ('{' == 123) && ('|' == 124) && ('}' == 125) && ('~' == 126)) +/* The character set is not based on ISO-646. */ +#error "gperf generated tables don't work with this execution character set. Please report a bug to ." +#endif + +#line 6 "tldLookup.gperf" + +namespace DB +{ +#include + +#define TOTAL_KEYWORDS 8626 +#define MIN_WORD_LENGTH 2 +#define MAX_WORD_LENGTH 41 +#define MIN_HASH_VALUE 6 +#define MAX_HASH_VALUE 263036 +/* maximum key range = 263031, duplicates = 0 */ + +class ltdLookup +{ +private: + static inline unsigned int hash (const char *str, size_t len); +public: + static const char *is_valid (const char *str, size_t len); +}; + +inline unsigned int +ltdLookup::hash (const char *str, size_t len) +{ + static const unsigned int asso_values[] = + { + 263037, 263037, 263037, 263037, 263037, 263037, 263037, 263037, 263037, 263037, + 263037, 263037, 263037, 263037, 263037, 263037, 263037, 263037, 263037, 263037, + 263037, 263037, 263037, 263037, 263037, 263037, 263037, 263037, 263037, 263037, + 263037, 263037, 263037, 0, 263037, 0, 263037, 263037, 263037, 263037, + 263037, 263037, 263037, 263037, 263037, 1075, 120, 620, 31291, 505, + 7650, 185, 0, 0, 0, 5, 0, 0, 0, 45, + 0, 263037, 0, 15, 745, 0, 5, 0, 0, 4950, + 80, 0, 0, 0, 0, 263037, 0, 263037, 0, 0, + 263037, 263037, 75, 5, 15, 40, 35, 90, 60, 85, + 80, 45, 263037, 263037, 263037, 263037, 263037, 40, 5435, 235, + 1240, 90, 37658, 2335, 6995, 645, 3770, 5140, 765, 1685, + 2910, 10, 4145, 2030, 185, 15, 5, 485, 865, 0, + 29726, 340, 16025, 26869, 6770, 3715, 62293, 64003, 160, 345, + 955, 30, 620, 55, 265, 65, 970, 22284, 2040, 31804, + 51623, 4700, 85666, 10295, 10, 15310, 75051, 20, 30074, 300, + 52823, 13320, 5222, 9765, 0, 15115, 670, 0, 40, 5, + 25, 5, 5, 10, 0, 25, 5, 0, 20, 0, + 30, 70, 25, 35, 0, 5, 0, 5, 20, 5, + 0, 5, 10, 65, 0, 0, 0, 0, 0, 0, + 5, 10, 0, 50, 0, 0, 5, 0, 0, 5, + 25, 0, 45, 5, 10, 0, 90, 0, 0, 0, + 5, 0, 20, 45, 0, 5, 10, 0, 0, 5, + 0, 0, 263037, 263037, 0, 20, 263037, 30, 5, 0, + 5, 5, 40, 0, 0, 5, 0, 15, 35, 5, + 0, 0, 45, 5, 20, 0, 5, 5, 5, 10, + 0, 0, 0, 263037, 263037, 263037, 263037, 263037, 0, 0, + 263037, 0, 10, 10, 10, 0, 40, 0, 263037, 0, + 0, 0, 263037, 263037, 263037, 263037, 263037, 263037, 263037, 263037, + 263037, 263037, 263037, 263037, 263037, 263037, 263037, 263037, 263037, 263037 + }; + unsigned int hval = len; + + switch (hval) + { + default: + hval += asso_values[static_cast(str[26])]; + /*FALLTHROUGH*/ + case 26: + case 25: + hval += asso_values[static_cast(str[24])]; + /*FALLTHROUGH*/ + case 24: + case 23: + case 22: + hval += asso_values[static_cast(str[21])]; + /*FALLTHROUGH*/ + case 21: + case 20: + hval += asso_values[static_cast(str[19])]; + /*FALLTHROUGH*/ + case 19: + case 18: + case 17: + hval += asso_values[static_cast(str[16])]; + /*FALLTHROUGH*/ + case 16: + case 15: + hval += asso_values[static_cast(str[14])]; + /*FALLTHROUGH*/ + case 14: + hval += asso_values[static_cast(str[13])]; + /*FALLTHROUGH*/ + case 13: + hval += asso_values[static_cast(str[12]+1)]; + /*FALLTHROUGH*/ + case 12: + hval += asso_values[static_cast(str[11])]; + /*FALLTHROUGH*/ + case 11: + hval += asso_values[static_cast(str[10])]; + /*FALLTHROUGH*/ + case 10: + hval += asso_values[static_cast(str[9]+1)]; + /*FALLTHROUGH*/ + case 9: + hval += asso_values[static_cast(str[8])]; + /*FALLTHROUGH*/ + case 8: + hval += asso_values[static_cast(str[7]+2)]; + /*FALLTHROUGH*/ + case 7: + hval += asso_values[static_cast(str[6]+4)]; + /*FALLTHROUGH*/ + case 6: + hval += asso_values[static_cast(str[5]+24)]; + /*FALLTHROUGH*/ + case 5: + hval += asso_values[static_cast(str[4])]; + /*FALLTHROUGH*/ + case 4: + hval += asso_values[static_cast(str[3]+14)]; + /*FALLTHROUGH*/ + case 3: + hval += asso_values[static_cast(str[2]+19)]; + /*FALLTHROUGH*/ + case 2: + hval += asso_values[static_cast(str[1])]; + /*FALLTHROUGH*/ + case 1: + hval += asso_values[static_cast(str[0]+34)]; + break; + } + return hval; +} + +const char * +ltdLookup::is_valid (const char *str, size_t len) +{ + static const char * const wordlist[] = + { + "", "", "", "", "", "", + "\347\275\221\347\273\234", + "", "", "", "", "", "", "", "", "", + "\347\275\221\345\272\227", + "", "", "", "", "", + "no", + "", "", "", + "\344\275\233\345\261\261", + "", "", + "\316\265\316\273", + "no.it", + "\330\271\330\261\330\250", + "aw", + "", "", "", + "\327\247\327\225\327\235", + "at", + "", "", "", "", + "ao", + "", "", + "at.it", + "", + "as", + "", "", + "ao.it", + "", + "na", + "", "", "", "", + "cw", + "", + "asda", + "na.it", + "\351\246\231\346\270\257", + "qa", + "", "", "", + "\345\271\277\344\270\234", + "co", + "", "", + "ct.it", + "\344\270\255\344\277\241", + "et", + "\330\250\330\247\330\261\330\252", + "", + "co.it", + "\331\205\330\265\330\261", + "\340\244\255\340\244\276\340\244\260\340\244\244", + "aaa", + "", + "cs.it", + "\347\275\221\347\253\231", + "\345\244\247\344\274\227\346\261\275\350\275\246", + "ntt", + "", + "co.at", + "\320\261\320\265\320\273", + "\340\246\255\340\246\276\340\247\260\340\246\244", + "", + "\340\244\250\340\245\207\340\244\237", + "co.ao", + "\345\267\245\350\241\214", + "", "", "", + "as.us", + "", + "ca", + "", "", + "codes", + "\325\260\325\241\325\265", + "ne", + "\320\264\320\265\321\202\320\270", + "\340\244\225\340\245\211\340\244\256", + "ca.it", + "\345\250\261\344\271\220", + "\340\246\255\340\246\276\340\246\260\340\246\244", + "", + "\350\257\272\345\237\272\344\272\232", + "ct.us", + "\320\272\320\276\320\274", + "", "", + "\320\272\320\260\321\202\320\276\320\273\320\270\320\272", + "co.us", + "\320\274\320\272\320\264", + "", "", "", + "\330\247\333\214\330\261\330\247\331\206", + "\341\203\222\341\203\224", + "ae", + "", + "\330\247\330\252\330\265\330\247\331\204\330\247\330\252", + "\330\250\330\247\330\262\330\247\330\261", + "", + "\330\247\331\205\330\247\330\261\330\247\330\252", + "\340\244\255\340\244\276\340\244\260\340\244\244\340\244\256\340\245\215", + "", "", "", + "\340\262\255\340\262\276\340\262\260\340\262\244", + "", + "\320\261\320\263", + "", + "\320\274\320\276\320\275", + "\320\276\320\275\320\273\320\260\320\271\320\275", + "", "", + "co.ua", + "", "", "", "", + "ca.us", + "\350\260\267\346\255\214", + "\340\254\255\340\254\276\340\254\260\340\254\244", + "", "", + "ne.us", + "", "", + "car", + "", + "ce.it", + "", + "ee", + "", "", + "\330\250\332\276\330\247\330\261\330\252", + "", + "\340\250\255\340\250\276\340\250\260\340\250\244", + "cat", + "", "", "", "", + "net", + "care", + "co.ae", + "", "", + "eat", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "\340\252\255\340\252\276\340\252\260\340\252\244", + "", "", + "nt.ro", + "", "", "", "", "", "", "", "", "", + "", "", "", + "nra", + "", "", "", "", "", "", "", "", "", + "\332\200\330\247\330\261\330\252", + "", "", "", + "ar", + "", "", "", "", "", "", "", + "ar.it", + "", "", + "com", + "name", + "co.rw", + "net.tm", + "", "", "", "", + "net.om", + "", "", "", "", + "net.to", + "cr", + "", "", + "co.rs", + "nom.tm", + "nc", + "", "", + "cr.it", + "net.so", + "", "", "", + "co.ir", + "", "", + "cam", + "arpa", + "", "", "", "", "", + "ar.us", + "net.am", + "ac", + "", "", "", "", "", "", "", "", + "\351\200\232\350\262\251", + "do", + "", "", "", "", "", + "art", + "", + "ac.at", + "", "", "", "", "", + "com.tm", + "cc", + "", "", + "nc.us", + "com.om", + "", + "aws", + "arte", + "", + "com.to", + "ec", + "", "", "", "", + "st", + "dad", + "", "", + "com.so", + "so", + "", "", + "cr.ua", + "\344\270\226\347\225\214", + "", "", "", + "so.it", + "\355\225\234\352\265\255", + "", "", "", + "ss.it", + "com.am", + "", "", "", "", "", "", "", "", "", + "net.th", + "", "", "", "", "", + "sa", + "dot", + "", "", + "net.sh", + "", "", "", + "sa.it", + "", "", "", "", + "cards", + "", + "de", + "", "", "", "", "", "", "", + "cc.ua", + "\345\201\245\345\272\267", + "", "", "", + "ac.ae", + "", "", + "sap", + "casa", + "", "", "", "", + "case", + "", + "n4t.co", + "", "", + "data", + "", "", "", "", + "date", + "", + "nat.tn", + "se", + "", "", "", + "\344\277\241\346\201\257", + "cy", + "", "", + "ny.us", + "", "", "", + "x.se", + "de.us", + "com.sh", + "", "", "", "", "", "", "", + "n.se", + "", "", + "name.mk", + "", "", + "co.st", + "", "", + "ees", + "", "", "", "", "", "", + "ac.rw", + "\320\276\320\264.\321\201\321\200\320\261", + "", "", + "a.se", + "", + "nom.ro", + "", "", + "\331\276\330\247\332\251\330\263\330\252\330\247\331\206", + "", + "net.tn", + "", "", + "army", + "ac.rs", + "", "", "", "", "", + "\320\260\320\272.\321\201\321\200\320\261", + "", "", + "cafe", + "ac.ir", + "\350\207\272\347\201\243", + "", "", + "c.se", + "", + "net.cm", + "", "", "", "", "", "", "", + "e.se", + "", + "net.co", + "", "", + "star", + "", + "stream", + "", "", "", "", + "com.ro", + "", "", "", "", + "nom.co", + "sr", + "", "", "", "", "", "", "", + "sr.it", + "", + "nu", + "", + "cars", + "co.ke", + "com.tn", + "", "", "", + "nu.it", + "", "", + "crs", + "", "", + "com.sn", + "", "", "", + "nt.au", + "", + "au", + "", + "audi", + "", + "com.cm", + "", "", "", "", + "net.sa", + "", "", "", + "audio", + "com.co", + "", "", "", + "ne.ke", + "", + "sc", + "nab", + "", + "stada", + "nym.sx", + "cu", + "sca", + "", "", + "nom.si", + "", "", "", + "dc.us", + "", + "eu", + "srt", + "", "", + "net.ai", + "", "", "", "", + "nym.sk", + "", "", "", "", + "art.sn", + "", "", "", "", + "nom.ai", + "", "", "", "", + "\350\201\224\351\200\232", + "", "", "", "", "", "", + "cab", + "", + "sc.us", + "com.sa", + "", "", "", "", "", "", "", "", + "co.kr", + "", "", "", + "erni", + "", "", "", "", "", "", "", "", + "sas", + "", + "es.kr", + "", "", "", "", "", + "com.ai", + "", "", "", "", "", + "bw", + "", + "desi", + "", "", + "bt", + "", "", + "ne.kr", + "", + "bo", + "ceb", + "", + "bt.it", + "", + "bs", + "", "", + "bo.it", + "", + "sy", + "", "", + "bs.it", + "", "", "", "", "", "", "", "", "", + "", "", + "ni", + "ses", + "", "", "", + "ba", + "\330\271\330\261\330\247\331\202", + "", "", "", "", "", + "d.se", + "ba.it", + "net.cn", + "zw", + "", "", "", + "natura", + "ai", + "", "", "", "", "", "", "", "", + "net.uk", + "", "", "", "", + "\345\234\250\347\272\277", + "", "", "", "", "", "", + "bot", + "safe", + "ac.ke", + "\344\270\255\345\234\213", + "ci", + "esq", + "s.se", + "ac.se", + "", + "name.na", + "", "", + "ci.it", + "", "", "", "", "", "", "", + "bar", + "", "", "", "", "", + "sony", + "", "", "", "", + "\320\265\321\216", + "", + "com.cn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "zt.ua", + "net.ci", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "nym.ro", + "\340\270\227\340\270\253\340\270\262\340\270\243.\340\271\204\340\270\227\340\270\242", + "", + "citi", + "", "", "", "", "", "", "", + "nl", + "bet", + "zara", + "co.ve", + "", "", "", "", "", "", + "su", + "", "", "", "", "", + "bom", + "", + "ac.kr", + "", + "al", + "", "", "", + "camera", + "", "", "", + "al.it", + "net.sl", + "br", + "", "", "", + "com.ci", + "", "", "", + "br.it", + "", "", + "eus", + "", "", "", + "cl", + "", "", "", "", "", "", "", + "cl.it", + "net.al", + "", "", + "city", + "co.il", + "", + "etne.no", + "", "", + "sa.au", + "", "", "", "", + "al.us", + "nom.al", + "", "", + "surf", + "", "", "", "", "", + "dodge", + "", "", "", "", "", "", "", "", "", + "", + "com.sl", + "", "", "", "", + "net.im", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "nom.im", + "", "", "", "", + "com.al", + "", "", "", + "co.gy", + "", "", "", "", "", "", "", + "\330\247\333\214\330\261\330\247\331\206.ir", + "", + "av.it", + "", "", "", "", "", "", "", "", "", + "ac.ru", + "", "", "", "", "", "", + "cv", + "", "", + "nv.us", + "", "", "", "", "", + "com.im", + "", "", "", "", "", "", + "csc", + "", + "sener", + "com.io", + "", "", "", "", "", + "si", + "", "", "", "", "", "", "", + "si.it", + "search", + "", "", "", "", "", + "by", + "", "", "", + "net.lk", + "", + "nec", + "", + "sc.ke", + "", "", "", "", "", + "\331\202\330\267\330\261", + "arna.no", + "", "", "", "", + "fo", + "", + "bofa", + "", "", "", "", "", "", + "\343\202\263\343\203\240", + "aure.no", + "xin", + "", + "cv.ua", + "net.ua", + "", "", "", "", "", "", "", "", + "citic", + "", "", "", "", + "dabur", + "\346\270\270\346\210\217", + "", "", "", "", "", "", + "\330\271\331\205\330\247\331\206", + "", "", "", "", + "scb", + "b.se", + "", + "com.lk", + "", "", + "site", + "co.tt", + "", "", + "ftr", + "", + "ac.il", + "", "", "", "", + "co.zw", + "nom.cl", + "", "", + "zone", + "", "", "", "", "", "", "", "", + "sus", + "", "", + "com.ua", + "", + "\321\201\320\260\320\271\321\202", + "", + "\340\264\255\340\264\276\340\264\260\340\264\244\340\264\202", + "", "", "", "", + "sc.kr", + "", + "sl", + "", "", + "fe.it", + "", "", "", + "z.se", + "\331\207\331\205\330\261\330\247\331\207", + "", "", "", "", + "co.za", + "net.in", + "", "", "", "", "", "", "", "", "", + "", "", "", + "x.bg", + "", "", + "\340\271\200\340\270\231\340\271\207\340\270\225.\340\271\204\340\270\227\340\270\242", + "", + "1.bg", + "", "", "", + "ceo", + "n.bg", + "", "", "", "", + "2.bg", + "", "", "", "", + "q.bg", + "", "", "", "", + "\351\243\236\345\210\251\346\265\246", + "", "", "", "", + "a.bg", + "\340\246\254\340\246\276\340\246\202\340\246\262\340\246\276", + "", "", "", + "4.bg", + "", + "net.tj", + "", "", + "3.bg", + "", "", "", "", + "9.bg", + "", "", "", "", + "song", + "", + "nom.tj", + "", "", + "c.bg", + "", "", "", "", + "6.bg", + "", "", + "fr", + "", + "e.bg", + "", "", "", "", + "bond", + "fr.it", + "", + "sv", + "", + "0.bg", + "", "", "", + "stc", + "8.bg", + "sv.it", + "", "", "", + "7.bg", + "", "", "", "", + "5.bg", + "", + "caseih", + "", + "dvr", + "", "", + "com.tj", + "", "", + "band", + "", "", "", "", "", "", "", + "nara.jp", + "bcn", + "", + "cymru", + "", "", "", "", "", "", "", "", + "baby", + "fc.it", + "", "", + "nyc", + "", "", "", + "conf.au", + "aco", + "ford", + "", "", "", + "cc.as.us", + "cash", + "", "", "", "", + "\343\202\273\343\203\274\343\203\253", + "", "", "", + "cc.ut.us", + "", + "ac.zw", + "", "", + "cc.ia.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "eco", + "", + "dy.fi", + "", "", "", "", "", "", + "bi", + "bid", + "", "", "", + "ad", + "", "", + "bi.it", + "net.la", + "alta.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "nom.li", + "cd", + "cc.wa.us", + "", + "nd.us", + "net.vn", + "", "", + "sina", + "", "", "", "", "", + "co.id", + "norton", + "", "", "", "", "", "", "", "", + "co.gl", + "", + "name.jo", + "", "", "", "", "", "", "", + "ed.ao", + "", "", "", "", + "co.vi", + "com.la", + "", "", "", "", "", "", "", "", "", + "sorreisa.no", + "", + "zip", + "bank", + "", "", "", "", + "seat", + "", "", "", + "fan", + "d.bg", + "", + "com.vn", + "domains", + "", "", "", "", "", "", "", "", + "nid.io", + "", "", + "f.se", + "", "", + "name.hr", + "", "", "", + "net.vi", + "", "", + "cyou", + "", "", "", "", + "b.br", + "nc.tr", + "", "", "", + "s.bg", + "bl.it", + "", "", + "cc.ar.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "\346\234\272\346\236\204", + "", "", "", + "co.hu", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "net.il", + "", "", "", "", + "com.vi", + "", "", + "duns", + "", "", "", "", + "\343\201\277\343\202\223\343\201\252", + "", "", "", "", "", "", "", + "city.hu", + "", "", "", "", "", "", "", "", + "net.dm", + "", "", "", "", + "datsun", + "", "", "", "", + "net.do", + "", + "cc.de.us", + "", "", "", "", "", "", "", "", + "bv", + "", + "docs", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "barsy.pro", + "ac.id", + "", "", "", "", + "store", + "", "", "", "", "", "", "", "", "", + "", + "com.dm", + "", "", "", "", "", "", "", "", "", + "com.do", + "", + "ads", + "", "", "", + "sd", + "catering", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "caravan", + "cc.ks.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "nissan", + "", "", "", "", + "\354\202\274\354\204\261", + "", "", "", "", "", "", + "boo", + "", + "sd.us", + "art.do", + "", "", "", + "dr.tr", + "", "", + "cc.wy.us", + "", "", "", "", "", "", "", "", "", + "", "", + "boats", + "", "", "", "", "", + "noticias.bo", + "fi", + "", "", "", + "nym.la", + "", + "cc.dc.us", + "dvag", + "fi.it", + "nym.li", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "\347\202\271\347\234\213", + "", "", + "scor", + "", "", + "berg.no", + "", + "\343\202\271\343\203\210\343\202\242", + "", + "swatch", + "", "", "", "", "", "", "", "", "", + "", + "stat.no", + "", "", "", "", "", "", "", "", "", + "", + "fit", + "", "", "", "", "", + "fire", + "beats", + "", "", "", "", "", "", "", "", "", + "", "", + "\330\247\330\261\330\247\331\205\331\203\331\210", + "", + "fans", + "", "", "", "", "", "", "", "", "", + "b.bg", + "", "", + "am", + "", "", "", "", + "sund.no", + "", "", "", "", "", + "cc.ga.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "cm", + "", "", + "nm.us", + "", + "\343\202\260\343\203\274\343\202\260\343\203\253", + "", "", "", "", "", + "qvc", + "", + "co.im", + "", "", "", "", "", "", "", "", + "z.bg", + "co.am", + "", "", "", "", "", "", "", + "dds", + "", "", "", "", "", "", "", "", "", + "cc.sc.us", + "", + "fl.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "fun", + "", + "study", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "cc.vt.us", + "", "", "", "", "", "", "", "", "", + "", "", "", + "social", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "cc.va.us", + "", "", + "net.mx", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "cc.ky.us", + "", "", + "net.mk", + "", "", "", "", "", "", "", "", + "dubai", + "", "", "", "", "", + "nom.mk", + "", + "cc.wi.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "net.mo", + "", "", "", "", + "com.mx", + "", "", + "book", + "", "", "", "", + "best", + "", "", "", + "foo", + "", "", "", "", "", "", "", + "com.mk", + "", "", "", "", "", + "dm", + "", "", + "ac.im", + "", "", "", + "duck", + "", "", "", "", "", "", "", "", + "cc.il.us", + "", "", "", "", + "cc.fl.us", + "", "", + "soc.lk", + "", + "cc.al.us", + "", "", + "com.mo", + "", "", "", "", "", + "sm", + "", + "fund", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "cc.ri.us", + "", + "sucks", + "", + "systems", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "\346\210\221\347\210\261\344\275\240", + "", "", "", "", "", + "av.tr", + "", "", "", + "dish", + "", + "b\303\241id\303\241r.no", + "ht", + "", "", "", "", "", "", "", "", "", + "", "", "", + "sm.ua", + "", + "aq", + "now", + "f.bg", + "", "", + "\343\203\235\343\202\244\343\203\263\343\203\210", + "", "", + "aq.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "alstom", + "", "", "", + "nt.ca", + "", + "drud.io", + "", "", "", "", + "sandvik", + "", + "bing", + "ns.ca", + "", + "\330\247\330\250\331\210\330\270\330\250\331\212", + "", "", "", "", "", "", "", + "bingo", + "narviika.no", + "", "", "", "", "", "", + "hot", + "", "", + "no.com", + "", + "cc.wv.us", + "food", + "", "", "", "", "", "", + "boston", + "", + "barsy.eu", + "e164.arpa", + "", "", + "fusa.no", + "", "", + "co.ca", + "\347\247\273\345\212\250", + "", + "new", + "", "", "", + "fl\303\245.no", + "", "", "", "", "", "", "", "", "", + "", "", "", + "smart", + "", "", "", "", "", + "co.com", + "", "", "", "", "", "", + "cc.gu.us", + "", "", + "studio", + "", "", "", "", "", "", "", "", "", + "", + "name.pr", + "", "", "", "", "", "", "", "", + "net.ma", + "", "", "", "", "", "", + "\343\203\225\343\202\241\343\203\203\343\202\267\343\203\247\343\203\263", + "here", + "", "", "", "", "", "", + "nym.mx", + "", "", "", "", + "net.tr", + "", "", "", "", "", "", + "bio", + "", "", "", + "hr", + "", "", "", "", "", "", + "fast", + "", + "fin.tn", + "", + "nrw", + "", "", + "now.sh", + "", + "seoul.kr", + "", + "homes", + "", "", "", "", "", + "net.ar", + "", "", "", "", "", "", "", "", "", + "", "", + "bargains", + "", "", "", "", "", "", "", "", "", + "", "", "", + "com.tr", + "", + "edu", + "", "", "", "", "", "", + "co.cr", + "", + "network", + "", "", "", "", "", "", "", "", "", + "", "", "", + "bd.se", + "career", + "careers", + "", "", "", "", + "bm", + "", "", "", + "com.ar", + "", "", "", "", + "ar.com", + "", "", "", "", + "dental", + "", "", "", "", "", "", "", "", + "qc.ca", + "", "", "", "", "", "", "", "", "", + "", + "edu.tm", + "", "", "", "", + "edu.om", + "ng", + "", "", "", + "edu.to", + "", "", "", "", + "qc.com", + "zm", + "", "", "", "", "", "", "", "", "", + "ag", + "", "", "", "", "", "", + "blue", + "ag.it", + "sld.do", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "cg", + "", "", "", "", "", "", "", "", + "airtel", + "eg", + "", "", "", "", "", "", "", "", "", + "", "", "", + "co.ag", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "sew", + "", + "co.ug", + "nic.in", + "", + "stcgroup", + "", "", + "sa.com", + "", + "cc.id.us", + "h.se", + "", "", "", "", + "scot", + "", "", "", "", "", "", + "de.com", + "", "", "", "", "", "", + "store.st", + "", "", + "nym.mn", + "", + "cc.vi.us", + "", + "ne.ug", + "", "", "", "", "", + "net.ml", + "", "", "", "", "", "", "", "", + "ac.cr", + "nic.tj", + "", "", + "news", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "email", + "", + "hu", + "", "", "", + "bostik", + "", "", "", "", + "com.ml", + "", "", "", "", + "net.qa", + "", "", "", + "horse", + "", "", "", "", "", "", "", "", "", + "", + "nom.qa", + "", "", "", + "sa.cr", + "edu.sn", + "", "", "", "", "", "", "", "", + "nu.ca", + "", "", + "bms", + "", "", "", "", "", + "fiat", + "", + "edu.co", + "", "", "", + "hs.kr", + "", "", "", "", "", "", "", "", "", + "archi", + "", "", "", "", "", + "com.qa", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "4u.com", + "", "", "", + "honda", + "", "", "", "", "", "", + "neustar", + "", "", + "ac.ug", + "edu.sa", + "sg", + "", "", + "ac.cy", + "", "", "", "", "", "", "", "", "", + "", + "eu.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "fm.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "forsale", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "a\303\251roport.ci", + "", "", + "co.tm", + "", "", + "cc.hi.us", + "", "", "", "", "", "", "", "", "", + "asnes.no", + "", + "co.zm", + "com.gh", + "", "", "", "", "", "", "", "", + "hi.us", + "", "", "", "", + "final", + "", "", "", "", + "co.ci", + "", "", "", + "fish", + "", "", "", "", "", + "forum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "net.gn", + "", + "sochi.su", + "", + "dance", + "", "", "", "", "", + "edu.cn", + "", "", "", "", "", "", + "cc.sd.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "arts.ro", + "", "", "", + "za.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "blog", + "", + "com.gn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "nl.ca", + "", "", "", "", "", + "net.ir", + "", "", "", "", + "edu.ci", + "", "", "", + "co.cl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "dynalias.net", + "dynu.net", + "", "", "", "", "", "", + "co.gg", + "", "", "", "", "", + "academia.bo", + "", "", "", "", "", "", "", "", + "sc.ug", + "br.com", + "frogans", + "", "", "", + "com.gi", + "", "", "", "", + "edu.sl", + "", "", "", "", + "dyn-ip24.de", + "", "", "", + "ac.zm", + "", "", "", "", + "bc.ca", + "", "", + "bod\303\270.no", + "", "", "", "", "", "", "", + "edu.al", + "", "", "", + "ac.ci", + "", "", "", "", + "an.it", + "", "", "", "", "", "", + "bg", + "", "", "", "", "", "", + "no.eu.org", + "bg.it", + "", + "cn", + "", "", "", "", "", "", "", + "cn.it", + "net.lr", + "", + "nnr", + "at.eu.org", + "co.in", + "", "", "", "", + "en.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "cisco", + "", "", "", "", "", "", "", "", "", + "", "", + "ddns.me", + "", + "es.eu.org", + "", "", "", "", "", "", "", "", "", + "", "", + "com.lr", + "", "", + "ca.eu.org", + "cn.ua", + "", + "fashion", + "", "", "", "", "", "", "", + "cloud", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "edu.lk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "ee.eu.org", + "", "", "", "", "", "", + "edu.ua", + "", "", "", "", "", + "news.hu", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "net.gl", + "", "", "", "", "", "", "", + "h.bg", + "", "", "", "", "", "", + "nom.gl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "nyc.mn", + "", "", "", "", "", "", "", "", + "ac.in", + "", "", "", "", "", + "com.gl", + "", "", "", "", + "edu.in", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "dnp", + "", "", "", + "sn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "design", + "", "", "", "", "", "", "", "", "", + "", + "auction", + "cc.ct.us", + "", "", + "edu.tj", + "", + "cc.co.us", + "", "", "", "", "", "", + "dn.ua", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "\303\245s.no", + "", + "cc.ca.us", + "host", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "samsclub", + "", "", "", "", + "ardal.no", + "", "", + "birkenes.no", + "", "", + "de.eu.org", + "", "", "", + "ngo", + "", "", "", "", "", + "adac", + "", "", "", "", "", + "fg.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "se.eu.org", + "", "", "", "", + "cy.eu.org", + "", + "casino", + "", "", "", "", "", "", "", + "sytes.net", + "hyatt", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "dep.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "edu.la", + "", "", "", "", "", "", "", "", "", + "", "", "", + "haus", + "", "", "", "", "", "", "", "", "", + "", "", + "edu.vn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "net.ni", + "ferrero", + "", "", "", "", "", "", "", "", "", + "", + "catholic", + "", "", + "nom.ni", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "au.eu.org", + "house", + "", "", "", "", "", "", "", + "agrar.hu", + "", "", "", "", "", "", "", + "net.gp", + "", "", "", "", + "com.na", + "", "", "", "", + "com.ni", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "author", + "", "", "", "", "", "", "", "", "", + "", "", + "barsy.uk", + "", "", + "ens.tn", + "", "", "", "", "", "", "", "", + "ed.cr", + "", "", "", "", "", "", + "bn", + "", "", "", + "com.gp", + "", "", "", + "bn.it", + "", "", "", "", "", "", "", + "cuneo.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "edu.dm", + "", "", "", "", + "center", + "", "", "", "", + "edu.do", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "forum.hu", + "", "", "", "", "", "", "", "", "", + "forde.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "be.eu.org", + "", "", "", "", "", "", "", "", "", + "", + "ac.gn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "bardu.no", + "", "", + "eid.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "nl.eu.org", + "", "", "", "", "", "", "", + "hm", + "", "", "", "", "", "", "", "", "", + "", "", + "al.eu.org", + "", "", "", "", "", "", "", "", + "hotel.hu", + "", "", "", "", "", "", + "amfam", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "cody.museum", + "", "", "", + "co.cm", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "ac.vn", + "", "", "", "", "", "", "", "", "", + "", "", + "cloudapp.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "nj.us", + "", "", "", "", + "fi.cr", + "", "", + "sauda.no", + "", "", "", "", "", + "barsy.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "carraramassa.it", + "", "", "", "", "", + "estate", + "", "", "", + "nowtv", + "", "", "", + "si.eu.org", + "", "", "", "", + "aero", + "", "", "", "", "", "", + "anquan", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "net.ae", + "", "", "", "", "", "", "", "", "", + "", "", + "aosta.it", + "", "", + "nom.ae", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "com.se", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "edu.mx", + "", "", "", "", "", "", "", "", + "ed.ci", + "", "", + "aoste.it", + "", "", "", "", "", "", "", + "edu.mk", + "", "", "", "", "", "", "", "", "", + "net.jo", + "", "", "", "", "", "", "", + "barsy.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "edu.mo", + "amot.no", + "", "", "", + "com.ee", + "dj", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "com.jo", + "", "", "", "", "", + "sj", + "", "", "", "", "", "", "", "", "", + "", "", + "sncf", + "", + "nom.re", + "", "", "", "", "", "", + "how", + "", "", "", "", + "ddns.net", + "fr.eu.org", + "", + "ngo.lk", + "", "", "", "", + "fet.no", + "", "", "", "", "", "", + "cc.in.us", + "", "", "", "", "", "", "", "", + "name.my", + "", "", "", "", "", "", "", "", + "com.re", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "zapto.org", + "", + "doctor", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "crown", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "dynv6.net", + "ap.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "app", + "", "", "", "", "", "", + "co.bw", + "", "", "", "", "", + "coffee", + "", "", "", "", "", "", "", + "\331\203\330\247\330\253\331\210\331\204\331\212\331\203", + "", + "edu.mn", + "", "", "", + "actor", + "broker", + "", "", + "cd.eu.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "nuoro.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "arts.museum", + "", "", "", "", "", + "servemp3.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "astronomy.museum", + "", "", + "auto", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "autos", + "", "", "", "", "", + "satx.museum", + "academy", + "", "", "", + "edu.tr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "net.pk", + "", + "bmw", + "", "", "", "", "", "", "", "", "", + "", "", "", + "edu.ar", + "", "", "", "", "", "", "", + "arab", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "sorum.no", + "", "", "", "", "", "", "", "", + "bj", + "busan.kr", + "", "", "", "", "", "", "", "", "", + "", "", "", + "com.pk", + "", "", "", "", + "nyny.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "sp.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "net.ph", + "", "", "", "", "", "", "", "", + "dp.ua", + "", "", "", + "ambulance.aero", + "", "", "", + "store.ro", + "", "", "", "", "", "", "", "", "", + "", "", + "ac.be", + "", "", "", "", "", "", "", "", "", + "", + "aip.ee", + "", + "froya.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "zero", + "", + "com.ph", + "", "", "", "", "", "", "", "", "", + "net.gr", + "", "", "", "", "", "", "", "", "", + "", "", "", + "fi.eu.org", + "", "", "", "", "", "", + "hiphop", + "", "", "", "", "", "", "", + "hsbc", + "", "", "", "", "", "", + "net.pn", + "", "", "", "", + "edu.ml", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "dgca.aero", + "", + "com.gr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "capital", + "", "", "", + "hu.com", + "", "", "", "", "", + "netbank", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "edu.qa", + "", "", + "ddnss.org", + "", + "net.pa", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "nom.pa", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "bnr.la", + "", "", "", "", "", + "kw", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "com.pa", + "", "", "", "", + "fla.no", + "", "", "", "", "", "", "", "", "", + "", "", + "barum.no", + "", "", "", "", + "hamar.no", + "", "", "", "", "", "", "", "", "", + "", "", "", + "net.ve", + "bodo.no", + "", "", "", "", "", "", "", "", "", + "", "", "", + "ks.us", + "", "", "", "", "", "", "", "", "", + "", + "edu.gh", + "", "", "", "", "", "", "", "", "", + "\345\205\253\345\215\246", + "arts.nf", + "", "", + "ks.ua", + "", + "ke", + "", "", + "co.tj", + "\345\276\256\345\215\232", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "com.ve", + "", "", "", "", + "\340\256\207\340\256\250\340\257\215\340\256\244\340\256\277\340\256\257\340\256\276", + "", "", "", + "\340\260\255\340\260\276\340\260\260\340\260\244\340\261\215", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "blogspot.no", + "", "", "", "", + "blogspot.ro", + "hitachi", + "", "", "", + "blogspot.rs", + "", "", "", "", "", "", "", "", + "co.bi", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "nym.ie", + "", "", "", "", + "edu.gn", + "flowers", + "", "", "", "", + "kr", + "krd", + "", + "zp.ua", + "nym.gr", + "", "", "", + "kr.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "net.au", + "", "", "", "", + "blogspot.se", + "", "", "", "", "", "", "", "", "", + "blogspot.re", + "", "", "", "", "", + "courses", + "", "", "", + "net.pl", + "", "", "", "", "", "", "", "", "", + "cruise", + "cruises", + "", "", "", + "nom.pl", + "hn", + "", "", "", "", "", "", "", + "kr.ua", + "edu.gi", + "", + "stord.no", + "", "", + "atm.pl", + "", "", "", "", + "com.au", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "ac.tj", + "com.pl", + "", "", "", "", + "blogspot.de", + "", "", "", "", "", "", "", "", "", + "", + "codespot.com", + "", "", "", "", "", "", "", "", + "h\303\245.no", + "", "", "", "", + "alsace", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "ky", + "xyz", + "", "", + "blogspot.qa", + "ferrari", + "", "", "", + "art.pl", + "", "", "", "", + "net.ru", + "", "", "", "", "", "", "", + "hgtv", + "", + "cn.com", + "", + "cc.tn.us", + "", "", "", "", "", "", "", + "act.au", + "", "", "", "", "", "", "", "", "", + "edu.lr", + "", "", "", + "ky.us", + "", "", "", "", "", + "blogspot.ba", + "", "", "", "", "", "", + "cc.or.us", + "k.se", + "", + "net.cu", + "", "", "", "", "", "", "", "", "", + "com.ru", + "", "", "", "", + "net.nr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "asn.au", + "", "", "", "", + "contractors", + "", "", "", "", + "blogspot.be", + "", "", "", "", "", "", + "software", + "", "", "", "", "", "", "", "", "", + "floro.no", + "", "", + "com.cu", + "", "", + "hr.eu.org", + "", "", "", "", "", "", + "saogonca.br", + "", "", "", "", + "com.nr", + "", "", "", "", + "com.de", + "", "", "", "", + "secure", + "", + "flora.no", + "", "", "", "", "", "", "", "", "", + "barsy.io", + "", "", "", "", "", "", + "ac.cn", + "", "", "", "", "", "", "", "", "", + "ak.us", + "", "", "", "", "", "", "", "", "", + "", + "nym.su", + "", + "\347\275\221\345\235\200", + "", "", + "edu.gl", + "vt.it", + "", + "nico", + "co.uk", + "", "", "", "", "", "", + "vs.it", + "", "", "", "", "", + "hitra.no", + "", "", "", "", "", "", "", + "durban", + "", "", + "va", + "", "", "", "", "", + "ck.ua", + "", + "va.it", + "", "", "", "", + "vt.us", + "", "", "", "", "", "", + "sanfrancisco.museum", + "", "", "", "", + "ng.eu.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "blogspot.tw", + "\330\247\331\212\330\261\330\247\331\206", + "", "", "", "", + "va.us", + "", + "ve", + "\330\250\331\212\330\252\331\203", + "vote", + "", + "\321\203\320\272\321\200", + "", "", + "blogspot.ru", + "ve.it", + "", "", "", "", "", "", "", "", "", + "", "", + "fido", + "", "", "", "", "", "", + "soccer", + "", "", "", "", + "sos.pl", + "", "", "", "", + "fam.pk", + "", + "kia", + "", "", "", "", + "dynathome.net", + "", "", "", "", "", "", "", "", "", + "", "", "", + "hof.no", + "dnsalias.net", + "", "", "", "", + "servep2p.com", + "", "", + "vet", + "nom.km", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "co.dk", + "", "", "", "", "", "", "", "", "", + "", "", + "dk", + "", "", "", "", "", "", "", "", "", + "vr.it", + "", "", "", "", "", "", "", "", + "com.km", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "ac.uk", + "", + "sk", + "", "", "", + "aid.pl", + "", "", "", "", "", "", + "nba", + "", "", "", "", "", + "vc", + "", + "c66.me", + "", "", "", "", "", + "vc.it", + "", + "hu.eu.org", + "co.om", + "blogspot.si", + "", "", "", "", "", "", "", "", + "sc.cn", + "", "", "", "", "", "", "", "", + "hopto.org", + "", "", "", "", "", "", "", "", + "cba", + "", + "cb.it", + "", "", "", "", "", "", "", + "kim", + "", "", + "ass.km", + "", "", "", "", "", "", "", "", "", + "", + "serveirc.com", + "", "", "", "", "", "", "", "", + "qld.au", + "", "", "", "", + "edu.ni", + "", + "nodum.io", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "sld.pa", + "", "", "", "", "", "", "", + "cbre", + "", "", "", "", "", + "sport", + "net.me", + "", "", "", "", + "net.kn", + "", "", "", "", "", "", "", "", "", + "edu.gp", + "", "", "", "", + "eastcoast.museum", + "", "", "", "", + "blogspot.nl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "vodka", + "", "", "", + "vana", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "stryn.no", + "", + "kv.ua", + "", "", "", "", "", "", "", "", "", + "", + "blogspot.hr", + "", "", + "hdfc", + "", + "net.ki", + "", "", "", "", + "net.bm", + "", "", "", + "associates", + "", "", "", "", "", + "net.bo", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "vu", + "", "", + "dynalias.com", + "", "", "", + "com.ki", + "", "", "", "", + "com.bm", + "", "", "", "", "", "", "", "", "", + "com.bo", + "", "", + "co.events", + "", + "net.vu", + "sb", + "herad.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "name.ng", + "cbs", + "", "", "", "", "", "", "", + "net.bh", + "", "", "", "", + "blogspot.kr", + "", "", "", "", "", + "s\303\274dtirol.it", + "", + "alfaromeo", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "k.bg", + "servehumour.com", + "com.vu", + "", "", "", + "nes.akershus.no", + "abarth", + "", "", "", "", "", "", "", "", + "sb.ua", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "com.bh", + "", "", "", "", "", "", "", "", "", + "", "", + "cbn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "barsy.me", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "nysa.pl", + "", + "vi", + "", + "net.bn", + "", "", "", "", "", + "vi.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "video", + "", + "bg.eu.org", + "vip", + "", "", + "snasa.no", + "", "", "", "", "", + "cn.eu.org", + "", "", "", "", "", "", + "nym.me", + "vi.us", + "", "", "", "", "", "", "", "", "", + "sumy.ua", + "", "", "", + "com.bn", + "", "", "", "", "", "", "", + "club", + "", "", "", "", + "kddi", + "", + "net.ba", + "", "", "", "", + "blogspot.hu", + "", + "abb", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "biz", + "", "", "", "", "", "", "", "", "", + "\345\230\211\351\207\214", + "", "", + "nym.lu", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "sbs", + "", "", + "com.ba", + "", "", "", "", + "com.bi", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "am.br", + "", "", "", "", "", "", + "bb", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "sites.static.land", + "", "", "", + "kaufen", + "", + "acct.pro", + "", "", + "nordkapp.no", + "", "", "", "", + "edu.ee", + "", "", "", + "\330\247\331\212\330\261\330\247\331\206.ir", + "", "", "", "", "", "", + "vv.it", + "", "", "", + "blogspot.ca", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "edu.jo", + "", "", "", "", "", "", + "bbt", + "", "", "", "", "", "", "", "", "", + "haram.no", + "", "", "", "", "", "", "", "", "", + "", "", "", + "visa", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "cloudaccess.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "nodum.co", + "", "", "", "", + "esurance", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "\303\245mot.no", + "", "", + "bir.ru", + "asso.km", + "", "", + "vin", + "", "", "", "", "", + "net.ge", + "", "", "", "", "", "", "", "", "", + "", "", + "aichi.jp", + "", "", + "nom.ge", + "", "", "", "", "", "", "", "", "", + "frog.museum", + "", "", + "voss.no", + "", "", "", "", "", "", "", "", + "c!www.ck", + "", "", "", + "singles", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "com.ge", + "aaa.pro", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "futbol", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "v.bg", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "abc", + "", "", + "est.pr", + "cartier", + "", "", "", + "com.kp", + "", "", "", "", "", "", "", "", "", + "", "", + "cc.ak.us", + "", "", + "net.pr", + "", "", + "spot", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "km", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "vision", + "", "", + "com.pr", + "", + "sport.hu", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "drud.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "definima.net", + "", "", "", + "edu.pk", + "", "", "", + "km.ua", + "", "", + "naroy.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "aca.pro", + "", "", "", "", "", "", "", + "sd.cn", + "", "", "", "", "", + "notaires.km", + "", "", "", "", "", "", "", + "vang.no", + "", "", "", "", "", "", "", "", "", + "", "", + "blogspot.lt", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "asso.mc", + "", "", "", + "blogspot.td", + "", "", "", "", "", "", "", "", "", + "net.mu", + "", "", "", "", + "notaires.fr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "space", + "", "", "", "", "", "", "", "", "", + "", + "edu.ph", + "", "", "", "", "", "", "", "", "", + "", "", + "hurum.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "de.cool", + "", "", "", + "com.mu", + "hoteles", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "nm.cn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "edu.gr", + "", "", + "xbox", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "edu.pn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "homesense", + "", + "cloudaccess.host", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "samsung", + "", "", + "video.hu", + "", + "cartoonart.museum", + "", "", "", "", + "asso.nc", + "", "", "", "", "", + "caa.aero", + "", "", "", "", "", "", "", + "edu.pa", + "", "", "", "", "", "", "", "", "", + "", "", "", + "buzz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "nt.no", + "", "", "", "", "", "", "", "", "", + "", + "nsw.au", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "blogspot.cl", + "", "", + "asia", + "", "", "", "", "", "", "", + "asso.re", + "", "", "", "", "", "", "", "", "", + "", "", "", + "co.no", + "", "", "", "", + "aa.no", + "blogspot.pt", + "", "", "", "", + "edu.ve", + "", "", "", "", "", "", "", "", "", + "kep.tr", + "", "", "", "", "", "", "", "", + "co.na", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "ca.na", + "", "", "", "", "", "", "", "", "", + "", "", + "bar.pro", + "bbc", + "", "", + "blogspot.cv", + "", "", + "barsy.pub", + "", + "biz.tj", + "", "", "", "", "", "", "", "", "", + "blogspot.pe", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "net.sd", + "", "", "", "", "", "", "", "", + "kyoto", + "", "", "", "", "", "", "", "", + "cern", + "", "", "", "", "", "", "", "", "", + "", "", + "kr.com", + "", "", "", + "fm.br", + "blogspot.lu", + "", "", "", "", + "nom.ad", + "", "", "", + "aetna", + "", "", "", "", "", "", "", "", "", + "", "", "", + "hyogo.jp", + "", "", + "com.sd", + "", + "dyroy.no", + "", "", + "edu.au", + "", "", "", + "ha.cn", + "", "", "", "", + "cq.cn", + "", "", "", "", "", "", + "kg", + "", "", "", "", "", "", "", "", + "edu.pl", + "", "", + "blogspot.co.ke", + "", "", + "ch", + "", "", + "nh.us", + "", "", "", "", + "ch.it", + "", "", + "sopot.pl", + "club.aero", + "", "", "", "", "", + "canon", + "", "", "", "", + "he.cn", + "", "", "", "", "", "", "", "", "", + "", + "ambulance.museum", + "", "", "", + "st.no", + "", "", "", "", "", "", "", "", "", + "", + "biz.vn", + "", "", "", + "cc.na", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "dedyn.io", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "blogspot.li", + "", "", "", "", "", "", "", "", "", + "blogspot.sg", + "", + "zgora.pl", + "", "", + "edu.ru", + "", "", "", "", "", "", "", "", "", + "", + "surgery", + "", "", "", "", + "hk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "net.hk", + "", "", "", "", "", "", "", "", "", + "net.gu", + "", + "cipriani", + "", "", "", "", "", "", "", + "edu.cu", + "", "", "", "", "", + "audible", + "", "", "", "", "", "", "", "", + "edu.nr", + "", "", "", "", "", "", "", "", "", + "biz.dk", + "bauhaus", + "", "", "", "", "", + "hkt", + "", "", "", "", "", "", "", + "com.hk", + "", "", "", "", "", "", "", "", + "dr.na", + "com.gu", + "", "", "", "", + "circle", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "sh", + "", "", + "barsy.shop", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "sardinia.it", + "", + "barsy.in", + "", "", "", "", + "virgin", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "blogspot.fr", + "", "", "", "", "", + "qa2.com", + "", "", "", "", "", "", + "no-ip.org", + "", "", "", "", + "shaw", + "", "", "", "", "", "", + "co.krd", + "", "", "", "", "", "", "", "", "", + "kirkenes.no", + "", "", "", "", "", "", "", "", "", + "", "", "", + "kiwi", + "", + "blogspot.bg", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "cooking", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "net.hn", + "", "", "", + "swiss", + "", "", "", "", "", "", "", "", "", + "", + "nom.hn", + "", "", "", "", "", "", "", "", + "barsy.club", + "", "", "", "", "", "", "", + "airforce", + "", "", "", "", + "democrat", + "", "", + "brasilia.me", + "", "", "", "", + "edu.km", + "", "", "", "", "", "", + "zarow.pl", + "", + "co.ni", + "", "", "", "", + "cargo.aero", + "com.hn", + "", "", "", + "chase", + "", "", + "hopto.me", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "sk.ca", + "", "", "", "", + "nb.ca", + "", "", "", + "no-ip.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "ab.ca", + "", "", "", "", "", "", "", "", "", + "", + "ntr.br", + "", "", "", "", "", "", "", + "vg", + "nl.no", + "", "", "", "", + "kg.kr", + "", "", + "no-ip.ca", + "", "", "", "", "", "", "", "", "", + "", "", + "al.no", + "", "", "", "", "", + "net.id", + "", "", "", "", + "esp.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "co.nl", + "", "", "", "", "", + "ngo.ph", + "kn", + "", "", "", "", + "bh", + "", "", "", "", "", "", "", "", + "karasjok.no", + "", "", "", + "hi.cn", + "", "", "", "", "", "", "", + "dontexist.com", + "", "", "", "", + "anz", + "", "", + "net.br", + "", "", "", "", "", "", "", + "a.run.app", + "", + "net.je", + "", "", "", "", + "krager\303\270.no", + "", "", + "barcelona", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "edu.me", + "", "", "", + "ac.ni", + "edu.kn", + "", "", "", "", "", "", + "\347\266\262\347\265\241.\351\246\231\346\270\257", + "", "", "", "", "", "", "", "", "", + "servepics.com", + "", "", + "com.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "blogspot.vn", + "", "", "", "", + "blogspot.sn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "hl.cn", + "", "", "", "", "", "", + "blogspot.com", + "", "", "", + "art.br", + "", "", "", "", + "edu.ki", + "", "", "", "", + "edu.bm", + "", "", "", "", "", "", "", "", "", + "edu.bo", + "", "", "", "", "", "", "", "", "", + "nhs.uk", + "", "", "", "", + "nom.nu", + "", "", "", "", + "blogspot.fi", + "", "", "", "", "", "", + "frogn.no", + "", "", "", "", "", "", + "vardo.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "kr.eu.org", + "", "", "", "", "", "", "", + "assn.lk", + "", "", "", "", "", "", "", "", + "edu.vu", + "", "", "", "", "", "", "", "", "", + "", "", "", + "hicam.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "edu.bh", + "br\303\270nn\303\270y.no", + "", "", "", "", "", "", "", "", "", + "", "", "", + "bu.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "blogspot.mr", + "", "", "", + "vadso.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "drive", + "", "", + "\345\200\213\344\272\272.\351\246\231\346\270\257", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "dontexist.net", + "dyn.cosidns.de", + "", "", "", "", "", "", + "kosher", + "", "", "", "", + "edu.bn", + "booking", + "", "", "", "", "", "", "", "", "", + "benevento.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "kinder", + "", "", + "chat", + "", + "biz.tr", + "", "", "", + "co.th", + "blogspot.ug", + "", "", "", "", "", "", "", "", "", + "net.pe", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "nom.pe", + "", "", "", "", "", "", "", "", "", + "edu.ba", + "netflix", + "barclays", + "", "", + "edu.bi", + "", + "cc.ne.us", + "", "", "", "", "", "", "", + "blogspot.my", + "", "", + "aerodrome.aero", + "", "", "", "", "", "", "", "", + "fyi", + "", "", "", "", "", "", "", + "com.pe", + "", "", "", "", "", + "desa.id", + "", "", "", "", "", "", "", + "baidu", + "", + "app.lmpm.com", + "", "", "", "", "", "", "", + "earth", + "", "", "", "", "", "", "", "", "", + "", + "ecn.br", + "", "", "", "", "", "", "", + "vn", + "", + "bharti", + "", "", "", "", "", "", "", "", "", + "", + "est-le-patron.com", + "", "", "", "", "", "", "", + "sn.cn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "def.br", + "", "", "", "", "", "", "", "", "", + "kerryhotels", + "", "", "", "", "", + "alstahaug.no", + "", "", "", "", "", "", "", "", "", + "dnsalias.com", + "", "", "", "", + "vn.ua", + "cc.nc.us", + "", "", "", "", "", "", "", "", "", + "", "", + "ac.th", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "shoes", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "bo.telemark.no", + "", "", "", "", "", "", "", "", "", + "show", + "", "", "", + "cc.ny.us", + "", "", + "arq.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "edu.ge", + "", "", "", "", "", "", "", "", "", + "cim.br", + "", "", "", "", "", "", + "barsy.support", + "dk.eu.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "bbs.tr", + "", "", "", + "barsyonline.com", + "nym.pe", + "", "", "", "", "", "", "", + "sk.eu.org", + "", "", "", "", "", "", + "edu.kp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "fh.se", + "", "", "", "", "", "", "", "", "", + "", + "etc.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "hbo", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "chrysler", + "", "", + "edu.pr", + "", "", "", "", + "ato.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "blogspot.com.es", + "", "", + "business", + "", "", "", + "copenhagen.museum", + "", "", "", "", "", + "namsskogan.no", + "", "", "", "", "", "", "", "", + "zone.id", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "fot.br", + "", "", "", "", + "fst.br", + "", "", "", "", "", "", "", "", "", + "vestv\303\245g\303\270y.no", + "", "", + "hashikami.aomori.jp", + "", + "far.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "blogspot.com.ee", + "", "", "", "", + "black", + "", "", "", "", + "blogspot.com.tr", + "", "", "", "", "", "", "", "", "", + "", + "church", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "blogspot.it", + "", "", "", "", + "bsb.br", + "", "", "", + "blogspot.com.ar", + "blogspot.is", + "", "", + "\347\266\262\350\267\257.tw", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "blogspot.com.co", + "", "", "", "", "", "", + "\347\245\236\345\245\210\345\267\235.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "\351\271\277\345\205\220\345\263\266.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "flir", + "", "", "", "", "", "", "", "", "", + "", "", + "blogspot.ie", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "xj.cn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "eco.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "amusement.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "store.nf", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "fishing", + "", "", "", "", "", + "etisalat", + "", "", "", "", + "hotel.lk", + "", "", "", "", "", "", "", "", "", + "", "", "", + "blogspot.bj", + "", "", + "saobernardo.br", + "", "", "", "", "", "", "", "", + "cc.nv.us", + "", "", "", "", "", "", "", "", + "kp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "ha.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "frosinone.it", + "", "", "", "", "", "", "", + "blogspot.com.au", + "", "", "", "", "", + "adm.br", + "", "", "", "", "", "", "", + "encyclopedic.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "blogspot.com.cy", + "", "", "", "", "", + "barclaycard", + "", "", "", "", "", "", "", + "nichinan.tottori.jp", + "", + "blogspot.md", + "", + "discount", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "hair", + "", + "voto", + "", + "\346\225\231\350\202\262.\351\246\231\346\270\257", + "nordre-land.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "nom.ke", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "edu.sd", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "fortmissoula.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "coach", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "nara.nara.jp", + "", "", "", "", "", + "vladimir.su", + "", "", + "eidsvoll.no", + "", + "kpn", + "kerrylogistics", + "", "", "", + "vladimir.ru", + "", "", "", "", "", "", + "blogspot.com.uy", + "", + "name.eg", + "", "", + "apartments", + "", "", + "cc.nd.us", + "", "", "", "", "", "", "", "", "", + "", "", "", + "biz.ni", + "", "", + "homedepot", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "1337.pictures", + "", "", "", "", "", "", "", "", "", + "softbank", + "", "", + "emp.br", + "", "", "", "", + "com.hr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "nom.gd", + "", "", "", "", "", "", + "andoy.no", + "", "", "", "", "", "", "", + "edu.hk", + "", "", "", "", "", "", "", "", "", + "edu.gu", + "", + "hobol.no", + "", "", "", "", "", "", "", "", + "hosting", + "", "", "", "", "", "", "", + "bj.cn", + "", "", "", "", "", + "kids.museum", + "", "", "", "", + "dray-dns.de", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "zj.cn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "feste-ip.net", + "bytom.pl", + "", "", "", "", "", + "show.aero", + "", "", "", "", "", + "fm.no", + "", + "dynalias.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "svn-repos.de", + "", "", "", "", "", "", "", "", "", + "", + "nesna.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "kpmg", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "auto.pl", + "", "", "", + "edu.hn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "slask.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "betainabox.com", + "", "", "", "", "", "", "", "", + "somna.no", + "", "", "", "", "", "", + "hl.no", + "", "", "", "", "", "", "", "", + "sondre-land.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "nord-aurdal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "barsy.menu", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "co.bb", + "spb.su", + "", "", "", "", "", "", + "cc.nm.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "veterinaire.km", + "", "", "", "", "", "", "", "", + "fj.cn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "bio.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "soni.nara.jp", + "", "", "", "", "", "", "", "", "", + "", + "donna.no", + "", "", "", "", "", "", "", "", "", + "", "", "", + "veterinaire.fr", + "", "", "", "", "", "", "", "", "", + "edu.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "ws", + "", "", "", + "bmd.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "s\303\270r-aurdal.no", + "", + "spb.ru", + "", "", "", "", + "\351\243\237\345\223\201", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "budapest", + "", "", "", "", "", "", + "wa.us", + "", "", + "wed", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "citadel", + "", + "xnbay.com", + "", "", + "\320\274\320\276\321\201\320\272\320\262\320\260", + "frontier", + "", "", "", "", "", "", + "hn.cn", + "", "", "", "", "", + "agr.br", + "", "", "", "", "", "", "", "", "", + "", + "shriram", + "", "", "", "", "", "", "", "", "", + "nordreisa.no", + "", "", + "bosch", + "", + "broke-it.net", + "", "", "", "", "", "", "", "", "", + "construction", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "blogspot.sk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "dattolocal.com", + "", "", "", "", "", "", "", "", "", + "ch.eu.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "co.financial", + "", "", "", "", "", "", "", "", "", + "", "", + "dst.mi.us", + "", + "blogspot.dk", + "", "", "", "", "", "", + "cc.ok.us", + "", "", "", "", "", "", "", "", "", + "", "", + "blogspot.com.mt", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "siracusa.it", + "", "", "", "", + "\345\225\206\345\272\227", + "", "", "", "", + "\345\225\206\345\237\216", + "", "", "", "", "", "", "", "", "", + "e12.ve", + "", "", "", "", "", "", + "wtf", + "", "", "", "", "", "", "", "", "", + "", "", "", + "definima.io", + "s\303\270rreisa.no", + "", "", "", + "\345\225\206\346\240\207", + "", "", "", "", "", "", "", "", "", + "edu.pe", + "", + "kyoto.jp", + "", "", + "biz.pk", + "", "", "", "", "", "", "", "", + "wy.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "w.se", + "", "", "", "", + "work", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "works", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "bentley", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "dnsup.net", + "", "", "", "", "", "", "", + "agakhan", + "", "", "", "", "", "", "", "", "", + "aabackplaneapp.io", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "kochi.jp", + "", "", "", "", + "frana.no", + "", + "ventures", + "", "", + "store.dk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "mw", + "", "", "", "", + "mt", + "", "", + "wa.au", + "", + "mo", + "", "", + "mt.it", + "", + "ms", + "msd", + "", + "mo.it", + "\347\217\240\345\256\235", + "", "", + "moda", + "ms.it", + "", "", + "demon.nl", + "", "", "", "", "", + "andria-barletta-trani.it", + "", + "\345\217\260\346\271\276", + "", "", "", "", "", + "ma", + "", "", "", + "sor-odal.no", + "", "", "", "", + "blogspot.ae", + "", "", "", + "mt.us", + "", "", "", "", + "mo.us", + "", "", + "mtr", + "", + "ms.us", + "kindle", + "", "", "", "", "", "", + "map", + "", "", "", "", "", "", "", "", "", + "", "", "", + "\345\205\254\345\217\270", + "", "", "", + "ma.us", + "economia.bo", + "me", + "med", + "", + "nishikatsura.yamanashi.jp", + "", "", "", "", + "me.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "cpa.pro", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "media", + "", "", "", "", + "me.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "\340\266\275\340\266\202\340\266\232\340\267\217", + "", "", "", + "med.om", + "android", + "", "", + "wi.us", + "", "", "", "", "", "", "", + "mom", + "", "", + "net.tw", + "", "", "", "", "", "", "", "", "", + "", + "mr", + "", "", "", "", "", + "brussels", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "hm.no", + "cnt.br", + "", "", "", "", "", + "kids.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "com.tw", + "mc", + "", "", + "mopar", + "", "", "", "", + "mc.it", + "", "", "", "", + "weber", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "amica", + "", "", "", + "meme", + "", + "com.aw", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "blogspot.hk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "my", + "wtc", + "wang", + "", "", "", "", "", "", + "web.co", + "", + "mtn", + "", "", + "net.rw", + "", "", "", "", + "\345\217\260\347\201\243", + "", "", + "\347\275\221\347\273\234.cn", + "", "", "", "", "", "", "", + "vb.it", + "", "", "", + "vacations", + "", "", + "\347\266\262\347\265\241.cn", + "", "", "", "", "", + "wv.us", + "botanical.museum", + "", + "man", + "", "", "", "", + "skaun.no", + "", "", "", "", "", "", "", "", "", + "", + "m.se", + "eurovision", + "net.cw", + "", "", "", "", "", "", "", "", "", + "com.rw", + "", "", "", "", + "naturalhistory.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", + "blogspot.co.il", + "", "", "", + "men", + "", "", + "biz.pl", + "", "", "", "", "", "", "", "", "", + "med.sa", + "sspacekit.io", + "", "", "", "", "", "", "", "", "", + "", + "win", + "", "", + "com.cw", + "", "", + "menu", + "", "", "", "", "", "", "", "", "", + "wine", + "", "", "", "", "", "", "", + "mu", + "", "", "", "", "", "", "", "", "", + "", "", + "mobi", + "", "", "", "", "", "", "", "", + "vgs.no", + "", + "blogspot.com.eg", + "", "", "", "", "", "", + "agrigento.it", + "", "", "", + "nym.tw", + "", + "barsy.de", + "", + "me.ke", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "ms.kr", + "monash", + "", "", "", "", "", "", "", "", "", + "a.ssl.fastly.net", + "himeshima.oita.jp", + "", "", "", "", "", "", + "w.bg", + "", + "br\303\270nn\303\270ysund.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "bozen.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "clothing", + "", "", + "abo.pa", + "", "", "", "", "", "", "", "", "", + "biz.nr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "abbvie", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "mi.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "konin.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "mi.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "suzuki", + "", + "mit", + "", + "money", + "", + "heroy.nordland.no", + "", "", "", "", "", "", "", "", + "blogspot.al", + "", "", "", + "newholland", + "", + "dlugoleka.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "barcelona.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "bjugn.no", + "", "", "", + "ml", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "epson", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "web.lk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "mv", + "serveminecraft.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "mango", + "", "", "", "", "", + "bern.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", + "bedzin.pl", + "", "", "", "", + "blogspot.co.id", + "", "", "", "", "", + "vefsn.no", + "fhs.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "design.aero", + "", "", "", "", "", "", "", "", "", + "", "", + "brand.se", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "mobi.na", + "", "", "", + "nissedal.no", + "", + "media.hu", + "", "", "", "", "", "", + "macys", + "", "", "", + "mini", + "", + "naustdal.no", + "", "", "", "", + "mer\303\245ker.no", + "", "", "", "", "", "", "", "", "", + "web.tj", + "", + "basilicata.it", + "", "", "", "", + "namdalseid.no", + "", "", + "fyresdal.no", + "", "", "", "", "", + "moss.no", + "", "", "", "", "", + "mls", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "fnd.br", + "", "", "", "", + "fedorapeople.org", + "", "", "", "", + "k12.vi", + "", "", "", "", "", + "agro.pl", + "", "", "", "", "", "", "", "", "", + "", "", + "m.bg", + "", "", "", "", "", "", + "bonn.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "k12.il", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "b.ssl.fastly.net", + "", "", "", "", "", "", "", "", "", + "", "", + "hemne.no", + "", "", + "biz.ki", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "vic.au", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "blogspot.in", + "", "", "", "", + "author.aero", + "", "", + "chtr.k12.ma.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "catering.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "md", + "", "", "", + "mutual", + "", "", "", "", "", "", + "mlb", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "ddnsking.com", + "", "", "", "", "", "", "", + "md.us", + "", "", "", "", "", "", + "mobi.ke", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "museum", + "dyn.ddnss.de", + "", "", + "sharp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "ddnss.de", + "", "", "", "", + "clan.rip", + "blogspot.co.at", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "web.do", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "mytis.ru", + "", "", "", "", + "dontexist.org", + "", + "varoy.no", + "", "", "", "", "", "", "", "", "", + "", + "nittedal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "fortal.br", + "", "", "", "", "", "", "", "", + "cc.nj.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "medicina.bo", + "", "", "", "", "", "", "", "", + "kh.ua", + "", "", "", "", "", "", "", "", "", + "", + "florence.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "myds.me", + "", "", "", "", "", "", "", "", "", + "", + "wow", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "botanicgarden.museum", + "", "", "", "", "", + "eidsberg.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "my.id", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "qpon", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "cc.oh.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "dnsalias.org", + "", "", "", "", "", "", "", "", + "blogspot.am", + "", "", + "akdn", + "", "", "", "", "", "", "", + "barsyonline.co.uk", + "", "", "", "", "", "", "", + "qh.cn", + "", "", + "spdns.eu", + "hatoyama.saitama.jp", + "", "", "", "", "", + "ah.cn", + "", "", "", "", "", + "badaddja.no", + "", "", "", "", + "barsy.co.uk", + "", "", "", "", "", "", + "mma", + "", "", "", + "apps.lair.io", + "", "", "", "", "", "", "", "", + "blogspot.gr", + "", "", "", "", "", "", "", + "historisches.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "mine.nu", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "va.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "www.ro", + "", "", "", "", "", "", "", + "equipment", + "", + "mattel", + "", "", "", "", "", "", "", "", "", + "hashimoto.wakayama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "hk.cn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "net.mw", + "", "", "", "", + "biz.pr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "blogspot.co.uk", + "", "", "", "", "", "", + "k12.tr", + "", "", "", "", + "com.mw", + "", + "ski", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "sh.cn", + "broker.aero", + "", "", + "mint", + "", "", "", "", "", "", + "aju.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "sandvikcoromant", + "", + "drayddns.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "assisi.museum", + "", "", "", "", "", "", "", "", + "mq", + "mmn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "storj.farm", + "", "", "", "", "", "", "", "", "", + "", + "web.tr", + "", "", + "historicalsociety.museum", + "", "", "", "", "", "", + "shouji", + "", + "klabu.no", + "", + "art.museum", + "", "", "", "", "", "", "", "", "", + "", + "sjc.br", + "", "", "", + "hb.cn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "stavanger.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "webcam", + "", "", "", "", "", "", "", "", "", + "aeroport.fr", + "homelink.one", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "sbi", + "hachinohe.aomori.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "sanok.pl", + "", "", + "moskenes.no", + "", "", "", "", "", "", "", "", "", + "", "", "", + "\303\270rsta.no", + "", + "kustanai.su", + "", "", "", + "can.museum", + "", "", "", "", "", + "kustanai.ru", + "", "", + "fujimino.saitama.jp", + "", "", "", "", "", "", + "edu.tw", + "", "", "", "", "", "", "", + "contemporary.museum", + "", "", "", "", + "\345\261\261\345\275\242.jp", + "", "", "", "", + "\345\257\214\345\261\261.jp", + "", "", "", "", + "\347\246\217\345\262\241.jp", + "", "", "", "", + "\345\262\241\345\261\261.jp", + "", "", "", "", + "\345\261\261\346\242\250.jp", + "", "", "", "", + "\351\235\231\345\262\241.jp", + "", "", "", "", + "\351\235\222\346\243\256.jp", + "", "", "", "", + "\345\263\266\346\240\271.jp", + "", + "bruxelles.museum", + "mg", + "", + "\346\235\261\344\272\254.jp", + "", "", "", "", + "\345\256\256\345\264\216.jp", + "", "", "", "", + "\345\256\256\345\237\216.jp", + "", + "hemsedal.no", + "", "", + "\347\237\263\345\267\235.jp", + "", "", "", "", + "\347\276\244\351\246\254.jp", + "cesenaforl\303\254.it", + "", + "cincinnati.museum", + "", + "\347\246\217\344\272\225.jp", + "", "", "", "", + "\345\205\265\345\272\253.jp", + "", "", "", "", + "\344\272\254\351\203\275.jp", + "", "", "", "", + "\351\246\231\345\267\235.jp", + "", "", "", "", + "\347\246\217\345\263\266.jp", + "", "", "", "", + "\345\276\263\345\263\266.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "\351\253\230\347\237\245.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "\303\245rdal.no", + "", "", "", "", + "hara.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "edu.rw", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "cesena-forl\303\254.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "edu.cw", + "", "", "", "", "", "", "", + "s\303\270rum.no", + "", "", "", "", "", "", "", + "siteleaf.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "equipment.aero", + "", "", "", "", "", + "air.museum", + "", "", + "vet.br", + "", "", + "fastpanel.direct", + "", "", "", "", "", "", "", "", "", + "blogspot.mk", + "", "", "", "", "", "", "", "", "", + "newspaper.museum", + "", "", "", "", "", "", "", + "dyn-o-saur.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "\351\225\267\345\264\216.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "asaka.saitama.jp", + "", "", "", "", "", + "nord-odal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "\351\225\267\351\207\216.jp", + "", + "mod.gi", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "nishikawa.yamagata.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "showtime", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "blogspot.ch", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "austrheim.no", + "", "", "", "", "", "", + "naruto.tokushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "b\303\246rum.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "ama.shimane.jp", + "", "", + "s\303\270r-odal.no", + "", "", "", "", "", "", "", "", + "foz.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "barsy.online", + "", "", "", "", + "banamex", + "", "", "", "", "", "", + "hatsukaichi.hiroshima.jp", + "", "", "", "", + "\346\204\233\347\237\245.jp", + "", "", "", "", + "stockholm", + "", "", "", "", + "narvik.no", + "mn.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "sango.nara.jp", + "", "", "", "", "", + "\346\204\233\345\252\233.jp", + "", "", "", "", + "mt.eu.org", + "", + "slz.br", + "", "", "", "", "", "", "", + "dnsfor.me", + "mn.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "\346\262\226\347\270\204.jp", + "", "", "", "", + "nishi.osaka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "hdfcbank", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "me.eu.org", + "", "", "", "", "", "", "", "", "", + "", + "nyc.museum", + "", "", "", + "\344\270\211\351\207\215.jp", + "", + "\346\276\263\351\227\250", + "", "", "", + "bss.design", + "", "", "", "", "", "", "", "", "", + "", + "\346\227\266\345\260\232", + "ua", + "", "", "", "", "", "", "", "", "", + "", "", + "\340\270\204\340\270\255\340\270\241", + "ut.us", + "", "", "", + "\340\271\204\340\270\227\340\270\242", + "", "", + "wanggou", + "", "", "", + "biz.id", + "", "", "", "", "", + "hyundai", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "durham.museum", + "", "", "", "", "", + "bergen.no", + "", "", "", "", "", "", "", "", + "media.pl", + "", "", "", "", "", + "suwa.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "\340\244\270\340\244\202\340\244\227\340\244\240\340\244\250", + "", "", "", + "mc.eu.org", + "", "", "", "", "", + "\321\203\320\277\321\200.\321\201\321\200\320\261", + "", + "historisch.museum", + "", "", "", + "nore-og-uvdal.no", + "", "", "", "", "", "", + "santamaria.br", + "", + "bus.museum", + "", "", "", "", "", "", "", "", "", + "\320\276\320\261\321\200.\321\201\321\200\320\261", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "\347\206\212\346\234\254.jp", + "", "", "", "", "", "", "", "", "", + "", + "\303\270stre-toten.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "country", + "", "", "", "", "", "", + "my.eu.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "\345\244\247\345\210\206.jp", + "", "", "", "", "", "", + "web.ni", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "capebreton.museum", + "", "", + "blogspot.com.ng", + "", + "h\303\270yanger.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "ddnsgeek.com", + "", "", "", "", "", "", + "fr\303\270ya.no", + "", "", "", "", "", "", "", "", "", + "sirdal.no", + "", "", + "uy", + "", "", "", "", "", "", "", "", "", + "", "", + "spdns.org", + "", "", + "neat-url.com", + "canada.museum", + "", "", "", "", "", "", + "ddr.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "u.se", + "", "", "", "", "", "", "", "", "", + "", "", "", + "abogado", + "", "", "", "", "", + "bauern.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "cloudeity.net", + "", "", "", "", + "boston.museum", + "", "", "", "", + "baseball", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "ah.no", + "abc.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "sande.m\303\270re-og-romsdal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "dynns.com", + "", "", "", "", "", "", "", "", "", + "", + "\340\270\250\340\270\266\340\270\201\340\270\251\340\270\262.\340\271\204\340\270\227\340\270\242", + "", "", "", "", "", "", + "alaheadju.no", + "", "", + "cesena-forli.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "historical.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "satte.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "amsterdam", + "", "", "", "", "", "", "", "", "", + "", + "blogspot.com.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "we.bs", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "\347\273\204\347\273\207\346\234\272\346\236\204", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "hamburg", + "", "", "", "", "", "", "", "", "", + "", + "brasil.museum", + "", "", "", "", "", "", "", "", "", + "", + "shia", + "", "", + "hita.oita.jp", + "", "", "", "", "", + "\340\270\243\340\270\261\340\270\220\340\270\232\340\270\262\340\270\245.\340\271\204\340\270\227\340\270\242", + "moto", + "", "", "", "", + "aquarelle", + "", "", "", "", "", "", "", "", "", + "", "", + "blogspot.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "moma.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "francaise.museum", + "andasuolo.no", + "", "", + "blogspot.com.by", + "", "", "", "", "", "", "", "", "", + "", + "fortworth.museum", + "", + "krodsherad.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "med.ee", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "flatanger.no", + "", "", + "md.ci", + "", "", + "sejny.pl", + "komvux.se", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "fudai.iwate.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "edu.mw", + "", "", "", "", "", "", "", + "bindal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "austin.museum", + "", "", "", + "brother", + "monza.it", + "", "", "", + "kumiyama.kyoto.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "eti.br", + "", + "modum.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "nanae.hokkaido.jp", + "", "", "", "", "", "", + "nt.edu.au", + "", "", "", "", "", "", "", "", "", + "", + "nrw.museum", + "", "", "", "", "", + "merseine.nu", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "accident-prevention.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "u.bg", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "mp", + "", "", "", "", "", "", "", "", "", + "bashkiria.su", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "\340\270\230\340\270\270\340\270\243\340\270\201\340\270\264\340\270\210.\340\271\204\340\270\227\340\270\242", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "cri.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "web.pk", + "cloudapps.digital", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "chanel", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "ud.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "manx.museum", + "", "", "", "", "", "", + "kepno.pl", + "", "", "", "", "", "", "", "", "", + "", + "frosta.no", + "", "", "", "", "", "", "", + "bashkiria.ru", + "", "", "", + "nom.pw", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "kurgan.su", + "", "", "", "", + "flor\303\270.no", + "", "", "", "", "", "", "", "", "", + "sa.edu.au", + "", "", + "shiksha", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "kashihara.nara.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "cinema.museum", + "", "", "", "", + "hasura-app.io", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "barsy.mobi", + "", "", "", "", "", "", "", "", "", + "click", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "bridgestone", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "s3-fips-us-gov-west-1.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "design.museum", + "", "", "", "", "", "", "", + "med.pa", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "sandnessj\303\270en.no", + "", "", + "sm\303\270la.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "\340\256\207\340\256\262\340\256\231\340\257\215\340\256\225\340\257\210", + "", "", "", "", "", "", "", + "web.ve", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "hadsel.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "cc.nh.us", + "hob\303\270l.no", + "", + "australia.museum", + "", "", "", "", "", "", "", "", "", + "", + "scrapping.cc", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "homesecuritypc.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "verisign", + "", "", "", + "kuokgroup", + "", "", "", "", "", "", "", "", + "kutno.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "eaton.mi.us", + "", + "ngrok.io", + "", "", "", "", "", "", + "and.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "altoadige.it", + "", "", "", "", "", "", "", "", + "chocolate.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "yt", + "", "", "", "", "", "", "", "", "", + "", + "software.aero", + "", "", + "\345\256\266\351\233\273", + "", "", + "kumagaya.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "med.pl", + "", "", "", "", "", "", "", "", "", + "\346\233\270\347\261\215", + "", "", "", "", "", "", "", "", "", + "\322\233\320\260\320\267", + "", "", "", "", + "\344\270\255\345\233\275", + "", "", "", "", + "kushimoto.wakayama.jp", + "", "", "", "", + "ski.no", + "", "", "", "", "", + "virtual-user.de", + "", "", "", + "\345\205\254\347\233\212", + "", "", "", "", + "nomi.ishikawa.jp", + "", + "\330\264\330\250\331\203\330\251", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "center.museum", + "", "", "", "", "", + "horten.no", + "", "", "", "", "", "", + "nativeamerican.museum", + "", "", + "hurdal.no", + "", "", "", "", "", "", "", "", "", + "casino.hu", + "mo.cn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "mobile", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "namerikawa.toyama.jp", + "", "", "", "", "", "", + "co.education", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "ot.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "ott", + "sn\303\245sa.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "bozen-s\303\274dtirol.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "us.com", + "mk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "arao.kumamoto.jp", + "", "", + "hasvik.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "est-mon-blogueur.com", + "", "", "", "", "", "", "", "", "", + "", + "hanyu.saitama.jp", + "", + "bozen-suedtirol.it", + "naturhistorisches.museum", + "", + "no-ip.co.uk", + "", "", "", "", + "net.sy", + "", "", "", "", "", "", "", + "\331\276\330\247\331\203\330\263\330\252\330\247\331\206", + "or.it", + "", "", "", "", + "mk.ua", + "", "", "", "", + "or.at", + "", "", "", + "y.se", + "", "", "", + "estate.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "or.us", + "", "", "", "", "", "", "", "", "", + "", + "com.sy", + "", "", "", + "me.uk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "monster", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "net.kw", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "verbania.it", + "hatogaya.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "ug", + "", "", "", "", + "songdalen.no", + "", "", "", + "com.kw", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "nature.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "o.se", + "osaka", + "net.cy", + "", "", "", "", "", + "ando.nara.jp", + "", "", "", "", "", + "football", + "", "", "", "", "", "", + "faith", + "", "", + "mba", + "", + "mb.it", + "", + "muni.il", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "uy.com", + "", "", "", "", "", "", + "anthro.museum", + "", "", "", "", "", "", "", + "com.cy", + "", "", "", "", "", "", "", "", "", + "", + "bestbuy", + "", "", + "barrell-of-knowledge.info", + "yandex", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "carboniaiglesias.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "kamiamakusa.kumamoto.jp", + "", "", + "web.bo", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "mycd.eu", + "", "", "", "", "", "", "", + "s3-us-gov-west-1.amazonaws.com", + "", "", "", "", "", "", "", + "\340\256\232\340\256\277\340\256\231\340\257\215\340\256\225\340\256\252\340\257\215\340\256\252\340\257\202\340\256\260\340\257\215", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "cesenaforli.it", + "", + "hjartdal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "or.ke", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "yun", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "sasayama.hyogo.jp", + "", "", "", + "net.uy", + "dbdebian.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "nom.uy", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "swidnica.pl", + "", "", "", "", "", "", "", "", "", + "safety", + "", "", "", "", "", "", "", "", + "or.kr", + "com.uy", + "", "", + "homesecuritymac.com", + "", "", "", "", "", "", "", + "nz", + "", "", "", "", "", "", "", "", + "cambridge.museum", + "", + "hosting-cluster.nl", + "", "", "", "", "", "", "", "", + "az", + "", "", "", "", "", "", "", "", + "beauty", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "cz", + "", "", "", "", "", "", "", + "cz.it", + "", "", "", "", "", "", + "wedding", + "you", + "", "", "", "", "", "", + "az.us", + "", "", "", "", + "co.ls", + "", "", "", "", "", "", "", + "akita.jp", + "", "", "", "", "", "", + "co.uz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "aeg", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "urn.arpa", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "y.bg", + "", + "net.sb", + "", "", "", "", "", "", "", + "fr\303\246na.no", + "homeip.net", + "", "", + "kicks-ass.net", + "", "", + "chrome", + "", "", "", "", "", "", "", "", "", + "ascoli-piceno.it", + "", "", "", "", "", "", "", "", "", + "net.ly", + "", "", "", "", + "net.zm", + "bibai.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "com.sb", + "", "", "", "", "", "", + "ooo", + "us.eu.org", + "", "", "", "", "", "", "", "", "", + "", "", "", + "dz", + "", "", "", "", "", "", "", "", "", + "", + "dog", + "", "", + "com.ly", + "", "", "", + "ac.ls", + "com.zm", + "", + "aeroclub.aero", + "", "", "", "", "", "", "", "", + "mobi.ng", + "", "", "", "", + "sz", + "", + "kawajima.saitama.jp", + "co.lc", + "", "", "", "", "", + "katsuragi.wakayama.jp", + "", "", "", "", "", "", "", + "snoasa.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "futsu.nagasaki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "deal", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "o.bg", + "deals", + "", "", "", "", "", "", "", "", "", + "mymailer.com.tw", + "", "", "", "", "", "", "", "", + "sarl", + "", "", "", "", "", "", "", + "name.mv", + "", "", "", "", + "zachpomor.pl", + "", "", + "co.sz", + "", + "vlaanderen", + "", "", "", "", "", "", "", + "sor-varanger.no", + "", "", "", "", "", + "olayan", + "edu.krd", + "", "", "", + "katowice.pl", + "arte.bo", + "", "", "", + "carrara-massa.it", + "", "", "", "", "", "", "", "", "", + "", + "naturalhistorymuseum.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "net.za", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "nom.za", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "\347\275\221\347\273\234.hk", + "", "", "", "", + "\347\275\221\347\265\241.hk", + "", "", "", "", + "\347\266\262\347\273\234.hk", + "sc.ls", + "", + "dattoweb.com", + "", + "\347\266\262\347\265\241.hk", + "", + "stockholm.museum", + "", "", "", "", "", + "med.pro", + "", "", + "ws.na", + "", "", "", "", "", "", "", "", "", + "", "", "", + "skjak.no", + "", "", "", "", + "kki", + "", "", + "waw.pl", + "", "", + "\347\256\207\344\272\272.hk", + "", + "nissay", + "", "", "", + "od.ua", + "", "", "", + "\344\270\252\344\272\272.hk", + "", "", "", "", "", "", "", "", "", + "anthropology.museum", + "ac.sz", + "", "", "", "", "", "", + "bz", + "", "", "", "", "", "", "", + "bz.it", + "", "", "", "", "", "", "", "", + "kawahara.tottori.jp", + "", "", "", "", "", + "elasticbeanstalk.com", + "", "", "", "", "", "", + "sanagochi.tokushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "hamatama.saga.jp", + "marylhurst.museum", + "aig", + "", "", + "mo\303\245reke.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "or.id", + "", "", "", "", "", "", "", "", "", + "", + "notodden.no", + "", "", "", "", "", + "krasnodar.su", + "", "", "", "", "", "", "", "", "", + "", + "hawaii.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "ustka.pl", + "", "", "", "", "", + "weir", + "", "", "", "", "", "", "", "", "", + "", "", "", + "kusu.oita.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "\345\200\213\344\272\272.hk", + "withyoutube.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "shacknet.nu", + "", "", "", "", "", "", "", "", "", + "", "", + "bcg", + "", "", "", "", "", "", "", "", "", + "koryo.nara.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "hiroshima.jp", + "cdn77-ssl.net", + "", "", "", "", "", "", "", "", + "bounceme.net", + "", "", "", "", "", "", "", "", "", + "", + "kv\303\246nangen.no", + "", "", "", "", "", + "aquila.it", + "", "", "", "", "", + "sling", + "hashbang.sh", + "", "", "", "", "", "", "", "", "", + "", "", + "masoy.no", + "", "", + "net.lb", + "katsuragi.nara.jp", + "", "", "", "", + "odda.no", + "", "", + "hasura.app", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "agriculture.museum", + "", "", "", "", "", "", "", "", + "om", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "aomori.jp", + "", "", "", "", "", "", + "com.lb", + "", + "mymediapc.net", + "", "", "", "", "", "", + "works.aero", + "nesodden.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "cool", + "co.tz", + "", "", "", + "fage", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "moi", + "", "", "", "", "", "", + "ne.tz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "nowaruda.pl", + "", "", + "maif", + "", + "bando.ibaraki.jp", + "oita.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "naturalsciences.museum", + "", + "nombre.bo", + "", + "konyvelo.hu", + "", "", + "stpetersburg.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "net.my", + "", "", "", "", "", "", "", "", "", + "med.sd", + "", "", "", "", "", "", "", "", "", + "", + "conf.lv", + "uno", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "com.my", + "", + "nose.osaka.jp", + "", "", + "alt.za", + "", "", "", "", "", "", + "cc.az.us", + "", "", "", "", "", "", "", "", "", + "", "", + "ac.tz", + "family", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "mr.no", + "", "", + "cc.la.us", + "", + "media.aero", + "", "", "", "", "", "", "", "", "", + "azure", + "", "", + "wlocl.pl", + "", "", "", "", "", "", "", + "nis.za", + "mh", + "association.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "cloud.goog", + "", + "sera.hiroshima.jp", + "", "", "", + "vard\303\270.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "kyiv.ua", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "amsterdam.museum", + "", "", "", "", "", "", + "ulsan.kr", + "honeywell", + "", "", "", "", + "9guacu.br", + "", + "web.gu", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "nishihara.kumamoto.jp", + "ama.aichi.jp", + "", "", "", "", "", "", + "est-a-la-maison.com", + "", "", "", "", "", "", "", "", "", + "", "", + "vads\303\270.no", + "", "", "", "", "", "", "", "", "", + "", "", "", + "drobak.no", + "", "", "", + "skien.no", + "", "", "", "", + "castle.museum", + "", "", "", + "asahi.mie.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "saga.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "asahi.ibaraki.jp", + "", "", "", "", "", "", + "cloud.fedoraproject.org", + "", "", "", "", + "ssbiz.ua", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "vistaprint", + "", "", "", "", "", "", "", "", "", + "", "", "", + "sc.tz", + "v\303\245g\303\245.no", + "", "", "", "", "", "", "", + "newhampshire.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "nes.buskerud.no", + "surnadal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "bronnoysund.no", + "", "", "", "", "", "", "", "", "", + "", "", + "edu.sy", + "stj\303\270rdal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "verran.no", + "", "", "", "", "", "", "", "", + "og.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "og.ao", + "", "", "", "", "", + "emb.kw", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "asuke.aichi.jp", + "", "", "", "", "", "", + "berlin", + "", "", + "napoli.it", + "", "", "", "", "", + "or.cr", + "edu.kw", + "", "", "", "", + "flickr", + "hiji.oita.jp", + "", + "versailles.museum", + "", "", "", "", "", "", + "maison", + "", + "ups", + "shiraoka.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "homebuilt.aero", + "", "", "", "", "", "", "", "", "", + "", "", + "web.id", + "", "", "", "", "", "", "", "", "", + "", "", + "shiga.jp", + "", "", "", "", "", "", + "nishikata.tochigi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "memorial", + "", "", "", "", "", "", + "mb.ca", + "\345\244\247\351\230\252.jp", + "", + "aland.fi", + "", "", "", "", "", "", "", + "net.gy", + "", "", "", "", + "\344\275\220\350\263\200.jp", + "", "", "", "", + "v\303\245gan.no", + "", "", "", "", "", "", "", "", "", + "\345\262\220\351\230\234.jp", + "", "", "", "", + "stjordal.no", + "", "", + "k12.tx.us", + "", + "utah.museum", + "", "", + "aisai.aichi.jp", + "", + "\346\273\213\350\263\200.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "or.ug", + "med.br", + "", "", + "k12.ok.us", + "bible", + "", "", "", "", "", + "com.gy", + "", "", "", "", + "mat.br", + "", "", "", "", "", "", "", + "\346\225\216\350\202\262.hk", + "", "", "", "", + "frontdoor", + "", "", "", "", + "k12.ak.us", + "", "", "", "", + "f\303\270rde.no", + "", "", "", + "aircraft.aero", + "\346\225\231\350\202\262.hk", + "", "", "", "", "", "", + "madrid", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "aga.niigata.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "biz.mw", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "k12.oh.us", + "", "", + "sk\303\245nland.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "verdal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "\345\205\254\345\217\270.\351\246\231\346\270\257", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "edu.uy", + "", "", "", "", "", "", "", + "asahi.chiba.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "k12.tn.us", + "", "", "", "", "", "", + "dunlop", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "e4.cz", + "", + "settlement.museum", + "", + "k12.co.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "nym.gy", + "", + "kunitachi.tokyo.jp", + "", "", "", "", "", + "k12.wa.us", + "", "", "", "", + "k12.wi.us", + "or.ci", + "", + "wroc.pl", + "", "", "", + "zhitomir.ua", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "whoswho", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "crafting.xyz", + "", "", "", "", "", + "alaska.museum", + "", + "adult", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "edu.sb", + "", "", "", "", "", "", "", "", + "cuisinella", + "health", + "", "", "", "", "", + "clubmed", + "", "", "", "", + "kitchen", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "edu.ly", + "", "", + "k12.ri.us", + "", + "edu.zm", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "khmelnitskiy.ua", + "", "", "", + "mk.eu.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "hanamaki.iwate.jp", + "", + "arteducation.museum", + "", "", "", "", + "k12.ca.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "uk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "bungoono.oita.jp", + "", "", "", "", "", + "hepforge.org", + "", + "k12.al.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "myftp.org", + "", + "dealer", + "", "", "", "", + "mus.br", + "", "", + "bitballoon.com", + "", "", "", "", + "kyowa.akita.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "veneto.it", + "", "", "", "", "", + "mytuleap.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "chungnam.kr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "vantaa.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "beardu.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "\345\225\206\346\245\255.tw", + "", + "edu.za", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "hockey", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "s3.dualstack.ca-central-1.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "k12.in.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "snaase.no", + "", "", "", "", "", + "mp.br", + "", "", "", "", "", "", "", "", "", + "", "", + "samnanger.no", + "", "", "", "", "", "", "", "", "", + "contemporaryart.museum", + "", + "vestvagoy.no", + "", "", + "nanyo.yamagata.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "k12.ia.us", + "", "", "", "", "", "", "", "", "", + "", "", + "noto.ishikawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "ena.gifu.jp", + "", "", + "kanan.osaka.jp", + "", "", + "vestre-toten.no", + "", "", "", "", "", + "square.museum", + "", "", "", "", "", "", "", "", "", + "", + "huissier-justice.fr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "daito.osaka.jp", + "", "", "", "", "", "", "", "", + "osaka.jp", + "", + "mi.th", + "", "", "", "", + "watch", + "akrehamn.no", + "", "", + "handa.aichi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "k12.la.us", + "", "", "", "", "", "", "", "", "", + "", + "biratori.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "hamatonbetsu.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "nz.eu.org", + "", "", "", "", + "skin", + "", "", "", "", "", "", "", + "blog.bo", + "", "", "", "", "", "", + "s3.dualstack.eu-central-1.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "surgeonshall.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "ubs", + "cz.eu.org", + "", "", "", "", "", "", "", "", "", + "k12.va.us", + "", "", "", "", + "k12.vi.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "orsta.no", + "", "", "", "", "", "", "", "", "", + "", "", "", + "edu.lb", + "", "", "", "", "", "", "", "", + "firebaseapp.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "k12.il.us", + "", "", "", "", "", "", "", "", "", + "", "", + "association.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "bomlo.no", + "", "", "", "", "", "", "", "", "", + "maori.nz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "\303\245mli.no", + "", + "washtenaw.mi.us", + "", "", "", "", "", "", "", "", "", + "", + "york.museum", + "", "", "", "", "", "", + "olawa.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "s\303\270gne.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "kozow.com", + "", "", "", "", + "museum.mw", + "", "", "", "", "", "", + "edu.my", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "suita.osaka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "nishihara.okinawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "xs4all.space", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "kawai.nara.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "kawai.iwate.jp", + "", "", "", "", + "k12.mo.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "net.py", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "hzc.io", + "saintlouis.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "winners", + "", "", "", "", "", "", "", "", + "ngo.za", + "habikino.osaka.jp", + "", "", "", "", "", "", "", "", "", + "", + "zao.miyagi.jp", + "", "", + "com.py", + "", "", "", "", "", "", "", "", "", + "", "", "", + "musica.ar", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "kuriyama.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "coal.museum", + "", "", "", "", "", "", "", + "beiarn.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "casadelamoneda.museum", + "", "", + "k12.mn.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "bhz.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "katashina.gunma.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "cyon.link", + "", "", + "blog.br", + "", "", "", "", "", "", "", "", + "vipsinaapp.com", + "", "", + "k12.ma.us", + "", "", "", "", + "k12.mi.us", + "", + "own.pm", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "k12.or.us", + "", "", "", "", "", "", "", "", "", + "", "", "", + "asahi.yamagata.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "nachikatsuura.wakayama.jp", + "", "", "", + "k12.ar.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "kiso.nagano.jp", + "", + "edu.gy", + "", + "kicks-ass.org", + "", "", "", "", "", "", "", "", + "kyowa.hokkaido.jp", + "", "", "", "", "", "", + "webhop.me", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "store.ve", + "", + "furubira.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "adult.ht", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "archaeology.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "aioi.hyogo.jp", + "", "", "", "", "", "", + "numata.gunma.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "aero.mv", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "museum.tt", + "", "", "", "", + "museum.mv", + "", "", "", "", + "hisayama.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "kochi.kochi.jp", + "us.na", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "aejrie.no", + "", "", "", + "karate.museum", + "scjohnson", + "kameyama.mie.jp", + "", "", "", + "moroyama.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "flog.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "camdvr.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "miasta.pl", + "", "", "", "", "", "", "", + "kuju.oita.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "or.bi", + "", "", "", "", + "on.ca", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "hiroo.hokkaido.jp", + "", + "anan.nagano.jp", + "", "", "", "", "", + "niikappu.hokkaido.jp", + "", "", + "kamishihoro.hokkaido.jp", + "", + "apple", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "aizumi.tokushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "degree", + "", "", "", "", "", "", "", "", + "kawatana.nagasaki.jp", + "", "", "", "", "", "", "", "", "", + "nerima.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "bunkyo.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "khmelnytskyi.ua", + "", "", "", "", "", "", "", "", + "wada.nagano.jp", + "", "", "", "", + "aigo", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "kyotango.kyoto.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "nagoya", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "ok.us", + "", "", "", + "k12.ga.us", + "", "", "", "", "", "", "", "", "", + "", + "soja.okayama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "musica.bo", + "", "", "", "", "", "", "", "", "", + "", "", + "suzu.ishikawa.jp", + "", "", + "est-a-la-masion.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "nishiokoppe.hokkaido.jp", + "chiropractic.museum", + "", + "uk.com", + "", "", "", "", "", "", "", "", "", + "", "", + "east-kazakhstan.su", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "honai.ehime.jp", + "", "", "", + "woodside", + "", "", "", "", "", "", "", + "net.ky", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "spdns.de", + "", "", "", "", "", "", "", "", "", + "", + "modelling.aero", + "", + "asahikawa.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "com.ky", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "sumida.tokyo.jp", + "", "", "", "", "", "", "", + "meteorapp.com", + "", "", "", + "kz", + "", "", "", "", "", "", "", "", "", + "", "", + "deatnu.no", + "", "", "", "", "", "", "", "", "", + "mus.mi.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "futuremailing.at", + "", "", "", "", "", "", + "herokussl.com", + "", "", "", "", "", "", + "weibo", + "", "", "", "", "", "", "", "", + "k12.nm.us", + "", + "\327\231\327\250\327\225\327\251\327\234\327\231\327\235.museum", + "", "", + "bo.nordland.no", + "", "", "", "", "", "", "", "", "", + "", "", "", + "bozen-sudtirol.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "kumatori.osaka.jp", + "", "", "", "", "", "", + "sabae.fukui.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "yorkshire.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "za.bz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "k12.nh.us", + "", "", "", + "brunel.museum", + "", "", + "bci.dnstrace.pro", + "", "", + "vlaanderen.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", + "homeunix.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "niiza.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "xz.cn", + "", "", "", "", "", + "com.by", + "", "", "", "", "", "", "", "", + "hamura.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "konsulat.gov.pl", + "", "", "", "", "", "", "", "", "", + "", + "kiwa.mie.jp", + "", "", + "maceio.br", + "", "", "", "", + "webspace.rocks", + "", "", "", "", "", "", "", "", "", + "skj\303\245k.no", + "", "", "", + "\347\265\204\347\271\224.\351\246\231\346\270\257", + "", "", "", "", "", + "\345\205\254\345\217\270.cn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "bandai.fukushima.jp", + "", "", + "botanicalgarden.museum", + "", "", "", "", "", "", "", "", + "otsuka", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "andria-trani-barletta.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "yoshinogari.saga.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "chiba.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "windows", + "", "", "", "", "", "", + "bamble.no", + "", + "nym.by", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "discourse.group", + "", "", "", "", "", + "kamimine.saga.jp", + "", "", "", "", "", "", + "vercelli.it", + "", + "asahi.nagano.jp", + "", "", "", "", "", "", "", + "smola.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "nishinoomote.kagoshima.jp", + "", + "hornindal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "seranishi.hiroshima.jp", + "", "", "", "", "", "", "", "", + "dvrcam.info", + "vegas", + "", "", "", "", "", + "kirovograd.ua", + "", "", "", "", "", + "hareid.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "kita.kyoto.jp", + "", "", "", "", "", + "uk.eu.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "kanie.aichi.jp", + "", "", + "digital", + "", "", + "ac.lk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "musashimurayama.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "mortgage", + "", "", "", "", "", "", "", "", "", + "kitaakita.akita.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "ainan.ehime.jp", + "", "", "", "", "", "", "", "", "", + "baidar.no", + "", "", "", "", "", "", + "biz.cy", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "net.bb", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "chattanooga.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "zama.kanagawa.jp", + "", "", "", "", "", "", "", "", "", + "com.bb", + "", "", + "k12.nj.us", + "", "", "", "", "", "", "", "", "", + "vaga.no", + "", "", "", "", "", "", "", "", "", + "", "", + "hanno.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "edu.py", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "vega.no", + "", "", "", "", "", "", "", + "choyo.kumamoto.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "net.eu.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "shirahama.wakayama.jp", + "nnot.br", + "", "", "", "", "", + "kami.kochi.jp", + "", "", "", "", "", "", "", "", "", + "", + "strand.no", + "", + "varese.it", + "", "", "", "", "", "", "", + "\347\265\204\347\271\224.tw", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "vig", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "shari.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "kumejima.okinawa.jp", + "", "", "", "", "", + "war.museum", + "", "", "", "", "", "", + "mo-i-rana.no", + "", "", "", "", "", + "arita.saga.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "oracle", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "biz.zm", + "", "", + "better-than.tv", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "blogspot.cz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "d\303\270nna.no", + "", "", "", "", "", "", "", + "kure.hiroshima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "cuiaba.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "nagatoro.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "blogspot.co.nz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "washingtondc.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "stokke.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "hanawa.fukushima.jp", + "", + "gw", + "", "", "", "", + "gt", + "", "", "", "", "", "", "", "", "", + "gs", + "agro.bo", + "", + "go.it", + "", "", "", "", "", + "or.na", + "", "", "", + "k12.pa.us", + "", "", "", "", "", "", "", "", "", + "", "", + "ga", + "gop", + "", "", + "yk.ca", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "kita.osaka.jp", + "", + "\346\211\213\350\241\250", + "", "", "", "", + "oh.us", + "", + "gap", + "", "", "", "", + "got", + "", "", "", "", + "kawanishi.nara.jp", + "", "", "", "", "", "", + "ga.us", + "", + "ge", + "", "", "", + "\350\264\255\347\211\251", + "", + "gea", + "", + "ge.it", + "", "", "", "", "", "", "", "", "", + "", "", "", + "weather", + "", "", "", "", "", + "navy", + "", "", + "s3.dualstack.ap-southeast-1.amazonaws.com", + "", "", "", "", + "venice.it", + "", "", + "ownip.net", + "", "", "", + "modern.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "sandnessjoen.no", + "", "", "", "", "", "", "", "", "", + "mad.museum", + "", "", "", "", "", + "hitachiota.ibaraki.jp", + "", "", "", "", + "gr", + "", "", "", "", "", "", + "democracia.bo", + "gr.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "hanamigawa.chiba.jp", + "", "", "", "", "", "", "", "", + "game", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "games", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "dtv", + "", "", "", "", + "for-some.biz", + "", "", "", + "aguni.okinawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "uri.arpa", + "hirata.fukushima.jp", + "", "", "", + "musashino.tokyo.jp", + "", "", "", "", "", "", "", "", + "watches", + "", "", "", "", "", "", "", "", + "gy", + "chintai", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "dev", + "save", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "zagan.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "stathelle.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "seihi.nagasaki.jp", + "g.se", + "", "", "", "", "", + "bananarepublic", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "morena.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "kyotanabe.kyoto.jp", + "", "", + "name.qa", + "", "", + "go.ke", + "", + "edu.ky", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "q-a.eu.org", + "", "", "", + "aisho.shiga.jp", + "", "", "", "", "", "", + "gu", + "", "", "", "", "", "", "", "", "", + "", "", "", + "k12.de.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "sydney", + "", + "hb.cldmail.ru", + "gu.us", + "", "", "", "", + "go.kr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "museumcenter.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "guru", + "", + "ol.no", + "", "", "", "", + "co.nz", + "ham-radio-op.net", + "", "", "", "", "", "", "", + "\351\263\245\345\217\226.jp", + "", + "date.hokkaido.jp", + "kwpsp.gov.pl", + "", "", "", "", "", "", "", "", "", + "", "", + "\345\261\261\345\217\243.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "urbino-pesaro.it", + "", "", "", "", "", "", "", "", "", + "moscow", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "garden", + "", "", "", "", "", + "gi", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "!city.sendai.jp", + "", "", "", "", "", "", + "s3.dualstack.ap-south-1.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "", "", "", + "yn.cn", + "", "", "", + "museum.om", + "fastly-terrarium.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "fauske.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "stj\303\270rdalshalsen.no", + "", "", "", "", "", "", "", "", "", + "", + "\346\211\213\346\234\272", + "!city.sapporo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "gl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "ac.nz", + "", + "for-more.biz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "asso.bj", + "", + "shangrila", + "", "", "", "", "", "", "", "", "", + "", + "net.iq", + "", "", + "seto.aichi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "vibovalentia.it", + "", "", "", + "aomori.aomori.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "\345\244\251\344\270\273\346\225\231", + "", "", "", "", "", "", "", "", "", + "", + "com.iq", + "", "", "", "", "", "", "", "", + "gv.at", + "", "", "", "", + "gv.ao", + "", "", + "hasuda.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "k12.me.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "goo", + "", "", "", "", "", "", "", "", "", + "", "", "", + "hachirogata.akita.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "suisse.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "grp.lk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "glade", + "", "", "", "", + "mandal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "games.hu", + "", "", "", "", "", "", "", + "kitanakagusuku.okinawa.jp", + "", "", + "g.bg", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "museum.no", + "", "", "", "", + "glass", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "or.th", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "naoshima.kagawa.jp", + "", "", "", "", "", "", "", + "daigo.ibaraki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "flt.cloud.muni.cz", + "", "", "", "", + "hitachinaka.ibaraki.jp", + "aogashima.tokyo.jp", + "", "", + "gd", + "", "", "", "", "", "", "", "", "", + "", "", "", + "go.id", + "", "", "", "", "", "", "", "", "", + "kumano.hiroshima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "ancona.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "audnedaln.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "gen.in", + "", "", "", "", + "gob.cl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "origins", + "minamioguni.kumamoto.jp", + "", "", "", "", "", "", "", "", "", + "gent", + "mosvik.no", + "", "", + "mydobiss.com", + "", "", "", "", + "eniwa.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "kota.aichi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "motoyama.kochi.jp", + "", "", "", "", "", + "goog", + "", "", + "edu.bb", + "", "", + "matera.it", + "", "", "", "", "", "", "", + "homeunix.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "fail", + "", "", "", "", "", "", "", "", "", + "", "", + "archaeological.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "midatlantic.museum", + "", "", "", "", "", "", "", + "grue.no", + "", "", "", "", "", "", "", "", "", + "", + "gdn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "yombo.me", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "fastlylb.net", + "", "", "", "", "", "", "", + "edu.eu.org", + "", "", "", "", "", "", "", "", "", + "", "", "", + "herokuapp.com", + "", "", "", "", "", "", "", "", "", + "", "", "", + "suifu.ibaraki.jp", + "", "", "", "", "", "", "", "", "", + "gm", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "\343\202\257\343\203\251\343\202\246\343\203\211", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "k12.pr.us", + "", "", "", "", + "ueda.nagano.jp", + "", + "safety.aero", + "", "", "", "", "", "", + "hitachiomiya.ibaraki.jp", + "", "", "", "", + "atsugi.kanagawa.jp", + "", "", "", "", "", "", + "nantan.kyoto.jp", + "", "", "", "", "", + "southwest.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "gob.do", + "", + "ostroleka.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "servebeer.com", + "", "", "", "", "", + "wa.edu.au", + "", "", "", "", + "krakow.pl", + "", + "kurotaki.nara.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "!city.nagoya.jp", + "", "", "", "", + "fujishiro.ibaraki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "gift", + "konan.aichi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "gifts", + "", "", "", "", "", "", "", "", "", + "", "", "", + "cust.prod.thingdust.io", + "", "", "", "", "", "", "", "", "", + "", + "sodegaura.chiba.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "gq", + "", "", "", "", "", "", "", "", "", + "", "", + "hizen.saga.jp", + "", "", "", "", "", "", + "ski.museum", + "", "", "", "", "", "", "", + "kira.aichi.jp", + "", + "my-firewall.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "fuso.aichi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "gifu.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "vlog.br", + "", "", "", "", "", "", "", "", "", + "k12.ne.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "gob.mx", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "management", + "", "", "", + "go.cr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "kawanishi.yamagata.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "kmpsp.gov.pl", + "", "", + "webhop.net", + "", "", "", "", + "gr.com", + "slg.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "kamo.kyoto.jp", + "gc.ca", + "", "", "", "", "", "", "", + "channel", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "gg", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "nuremberg.museum", + "", "", + "hasama.oita.jp", + "", "", + "gs.aa.no", + "", "", "", "", "", "", "", "", "", + "", "", + "go.ug", + "", "", "", "", "", "", "", "", "", + "marker.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "saiki.oita.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "nishinomiya.hyogo.jp", + "", "", + "komagane.nagano.jp", + "", "", "", "", "", "", "", "", + "ddnslive.com", + "", "", "", "", "", "", "", "", "", + "", "", + "gmail", + "", "", "", "", "", "", "", + "kuchinotsu.nagasaki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "gen.tr", + "", "", "", "", "", "", "", "", + "macapa.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "seiyo.ehime.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "mincom.tn", + "", "", "", "", "", "", "", + "drangedal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "k12.gu.us", + "gob.ar", + "", "", "", "", + "minamiawaji.hyogo.jp", + "", + "ouda.nara.jp", + "", "", + "smile", + "", "", "", "", "", "", "", "", "", + "", "", "", + "babia-gora.pl", + "", "", "", "", "", "", "", "", + "unusualperson.com", + "", "", "", "", "", "", + "andebu.no", + "kunneppu.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "gmo", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "zlg.br", + "", "", + "stange.no", + "", "", "", "", "", "", "", + "gs.st.no", + "", "", "", "", "", "", "", "", "", + "familyds.net", + "", "", "", "", "", "", "", "", "", + "hiv", + "", + "go.ci", + "", + "brindisi.it", + "kawaminami.miyazaki.jp", + "", "", "", "", "", "", "", "", + "odo.br", + "", "", "", "", "", + "katsuura.chiba.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "home.dyndns.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "osasco.br", + "", + "cranbrook.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "b\303\241hcavuotna.no", + "", "", + "stjordalshalsen.no", + "", "", "", + "kamagaya.chiba.jp", + "", "", "", "", "", "", "", "", + "unicom", + "", "", "", "", "", "", "", "", "", + "", + "dovre.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "verona.it", + "", "", "", "", "", "", "", "", + "build", + "massa-carrara.it", + "", "", + "marshalls", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "marine.ru", + "", "", "", "", "", + "kristiansund.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "gn", + "", "", "", "", "", "", "", "", "", + "", + "eng.pro", + "", "", + "edu.iq", + "", "", "", "", "", "", "", "", "", + "", "", + "aurskog-holand.no", + "", "", "", "", "", "", "", + "kurashiki.okayama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "k12.id.us", + "", + "shizuoka.jp", + "", "", "", + "matsumae.hokkaido.jp", + "\321\200\321\203\321\201", + "", "", "", "", "", "", "", "", "", + "", + "gs.va.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "kunisaki.oita.jp", + "", "", "", "", "", "", "", "", "", + "s3.dualstack.ap-northeast-1.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "gmbh", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "akita.akita.jp", + "", "", "", "", + "matsukawa.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "gr.eu.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "usa.museum", + "", + "shirakawa.gifu.jp", + "", "", "", "", "", "", + "myjino.ru", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "sogne.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "usantiques.museum", + "", "", "", "", "", "", "", + "s\303\270ndre-land.no", + "", + "gs.rl.no", + "", "", "", "", "", "", "", "", "", + "misasa.tottori.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "kitaaiki.nagano.jp", + "seven", + "", "", "", "", "", "", "", "", "", + "kunigami.okinawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "kamigori.hyogo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "kamoenai.hokkaido.jp", + "", + "gs.tr.no", + "hazu.aichi.jp", + "", "", "", "", + "usdecorativearts.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "starnberg.museum", + "", "", "", "", "", "", "", + "kanra.gunma.jp", + "", "", "", "", "", "", "", "", "", + "cog.mi.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "matsumoto.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "kuzumaki.iwate.jp", + "", + "skodje.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "giske.no", + "", + "utsira.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "nishiarita.saga.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "h\303\246gebostad.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "gob.ni", + "", "", "", "", "", "", "", "", "", + "", "", "", + "kizu.kyoto.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "gouv.km", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "hadano.kanagawa.jp", + "", "", "", "", "", "", + "yoshikawa.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "urawa.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "midtre-gauldal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "minami.tokushima.jp", + "", "", + "gs.hl.no", + "", "", + "urbinopesaro.it", + "", "", "", "", "", "", "", "", "", + "", + "soo.kagoshima.jp", + "", "", "", "", "", "", "", "", + "kitadaito.okinawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "oe.yamagata.jp", + "", "", + "abira.hokkaido.jp", + "engineer", + "k12.md.us", + "", "", + "kofu.yamanashi.jp", + "", "", "", "", + "gs.fm.no", + "", "", "", "", "", "", + "shiwa.iwate.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "gucci", + "", "", "", "", "", "", "", + "mz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "bearalvahki.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "ulm.museum", + "", "", "", + "modena.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "cbg.ru", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "fujimi.saitama.jp", + "", "", "", "", "", "", "", "", + "gp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "namie.fukushima.jp", + "kiryu.gunma.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "med.ly", + "", "", "", "", + "cng.br", + "", "", "", "", "", "", "", "", "", + "eng.br", + "", "", "", "", "", "", "", "", "", + "furudono.fukushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "gop.pk", + "", "", "", "", + "vagan.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "ninomiya.kanagawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "kvanangen.no", + "", + "kosei.shiga.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "workinggroup.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "olayangroup", + "", "", "", "", "", "", "", "", "", + "uvic.museum", + "oppeg\303\245rd.no", + "", "", "", "", "", + "stjohn.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "kasumigaura.ibaraki.jp", + "", "", + "aosta-valley.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "web.za", + "", "", "", "", "", "", "", "", "", + "", "", + "nemuro.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "kautokeino.no", + "", "", "", "", "", "", + "gos.pk", + "", "", "", "", + "channelsdvr.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "bloomberg", + "", "", "", "", + "statebank", + "", "", "", "", "", "", "", "", "", + "", "", + "nishi.fukuoka.jp", + "", "", "", "", "", + "navoi.su", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "futaba.fukushima.jp", + "", "", "", "", "", + "gon.pk", + "", "", "", "", + "b\303\270.telemark.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "kitakami.iwate.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "mobily", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "oamishirasato.chiba.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "co.mw", + "", "", "", "", + "\345\205\254\345\217\270.hk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "gob.pk", + "", "", "", "", "", "", "", "", "", + "", + "forl\303\254-cesena.it", + "", "", "", "", "", "", "", + "co.ma", + "", "", "", "", "", "", "", "", "", + "chieti.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "narashino.chiba.jp", + "", "", "", "", "", "", "", "", + "kppsp.gov.pl", + "", + "go.tj", + "nov.su", + "", "", "", + "co.me", + "", "", "", "", "", "", "", "", + "nango.fukushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "glas.museum", + "", "", "", "", + "net.sc", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "kunimi.fukushima.jp", + "", "", "", "", "", "", "", "", "", + "", + "net.ac", + "", "", "", "", "", + "satsumasendai.kagoshima.jp", + "", "", "", "", "", "", "", "", + "graz.museum", + "", "", "", "", + "world", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "com.sc", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "net.ec", + "", "", + "sumoto.kumamoto.jp", + "", "", "", "", "", + "ac.mw", + "com.ac", + "", "", "", "", + "kisosaki.mie.jp", + "", "", "", + "development.run", + "", "", + "gs.hm.no", + "", "", + "ath.cx", + "", "", + "doha", + "", "", "", "", "", "", + "beta.bounty-full.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "ac.ma", + "", "", "", "", "", + "webredirect.org", + "", "", "", "", + "com.ec", + "", + "kasuya.fukuoka.jp", + "numata.hokkaido.jp", + "", + "nov.ru", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "sohu", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "ac.me", + "gsm.pl", + "", "", "", "", "", "", "", "", "", + "", "", + "gs.tm.no", + "", + "gs.cn", + "", "", "", "", "", "", "", + "cloudycluster.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "gob.pa", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "yufu.oita.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "karasjohka.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "zentsuji.kagawa.jp", + "", "", "", + "oita.oita.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "gob.ve", + "", "", "", "", + "me.tz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "aramco", + "", + "hidaka.saitama.jp", + "nasushiobara.tochigi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "kl\303\246bu.no", + "", "", "", "", "", "", "", "", "", + "co.mu", + "", "", "", "", "", "", + "biz.bb", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "sosnowiec.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "homeunix.org", + "", "", "", + "abu.yamaguchi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "aso.kumamoto.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "unj\303\241rga.no", + "", + "obi", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "comsec", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "bearalv\303\241hki.no", + "", "", "", "", "", "", "", "", "", + "", + "shiki.saitama.jp", + "", "", "", "", "", "", "", "", "", + "cccus-east-1.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "", "", + "doshi.yamanashi.jp", + "", "", "", "", "", "", "", "", + "goodyear", + "", "", "", "", "", "", "", "", "", + "", "", + "group", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "ac.mu", + "", "", "", "", "", + "sado.niigata.jp", + "", "", "", "", "", + "arts.co", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "gb", + "", + "hioki.kagoshima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "sch.sa", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "dyr\303\270y.no", + "", "", "", "", "", "", "", + "familyds.com", + "", "", "", "", "", "", "", "", "", + "", "", "", + "net.lc", + "", "", "", "", + "site.builder.nu", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "annaka.gunma.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "xihuan", + "", "", "", "", "", "", "", "", "", + "com.lc", + "", "", "", "", "", "", + "alibaba", + "", "", + "mypep.link", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "sasaguri.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "net.vc", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "nom.vc", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "farm", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "com.vc", + "x443.pw", + "", "", "", "", "", "", + "hirosaki.aomori.jp", + "", "", "", "", "", "", "", + "at-band-camp.net", + "", "", "", "", + "s3-sa-east-1.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "sandoy.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "apigee.io", + "", "", "", + "surrey.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "ybo.party", + "", "", "", "", "", "", + "corsica", + "cc.mt.us", + "", "", "", "", + "cc.mo.us", + "", "", "", "", + "cc.ms.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "cc.ma.us", + "", "", "", "", + "kongsberg.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "nym.lc", + "", "", "", "", "", "", "", + "shibukawa.gunma.jp", + "", + "sumita.iwate.jp", + "", + "cc.me.us", + "", + "globo", + "viva", + "", + "boutique", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "sch.lk", + "", "", "", "", "", + "gouv.ml", + "", "", "", "", "", "", "", "", + "google", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "gob.bo", + "", "", "", "", "", "", "", "", "", + "", "", "", + "hidaka.wakayama.jp", + "", + "gda.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "fujiidera.osaka.jp", + "", "", + "orange", + "", "", "", "", + "uda.nara.jp", + "", "", "", "", + "yorii.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "bbva", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "kamikoani.akita.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "osoyro.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "ohtawara.tochigi.jp", + "", "", "", "", "", "", "", "", "", + "", + "shoo.okayama.jp", + "", "", "", "", "", "", "", "", "", + "nishio.aichi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "gd.cn", + "", "", "", "", "", "", "", "", "", + "daplie.me", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "kawasaki.miyagi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "kariwa.niigata.jp", + "", "", "", "", "", "", "", "", "", + "", + "atsuma.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "moriyoshi.akita.jp", + "", "", "", "", "", "", "", "", + "artgallery.museum", + "", "", "", "", "", "", "", "", "", + "", + "kimino.wakayama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "chuo.osaka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "mozilla-iot.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "cc.mi.us", + "", "", "", "", "", "", "", + "mlbfan.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "guardian", + "", "", "", "", "", + "n\303\270tter\303\270y.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "kawara.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "udi.br", + "", "", "", + "global", + "otaki.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "adachi.tokyo.jp", + "", + "hamada.shimane.jp", + "evje-og-hornnes.no", + "", "", "", "", "", + "showa.gunma.jp", + "", "", "", "", "", "", "", "", + "oyodo.nara.jp", + "", "", "", + "oga.akita.jp", + "", "", "", "", "", "", "", "", "", + "manchester.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "nishinoshima.shimane.jp", + "", "", "", "", "", "", "", "", "", + "family.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "konan.shiga.jp", + "fin.ec", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "hirono.fukushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "swinoujscie.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "kanoya.kagoshima.jp", + "", "", "", "", + "yawatahama.ehime.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "aknoluokta.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "yodobashi", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "webhop.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "oristano.it", + "", "", "", "", "", + "gs.ol.no", + "", "", + "mutsu.aomori.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "abiko.chiba.jp", + "", "", + "genoa.it", + "", "", "", "", "", "", + "higashimurayama.tokyo.jp", + "", + "engerdal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "kawakami.nara.jp", + "", + "kinko.kagoshima.jp", + "", "", + "koriyama.fukushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "muncie.museum", + "", + "edu.sc", + "", + "yamatokoriyama.nara.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "kasuga.fukuoka.jp", + "", "", + "edu.ac", + "", "", "", + "dattorelay.com", + "", + "firm.in", + "", "", "", "", "", "", "", "", "", + "", "", "", + "franziskaner.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "gs.bu.no", + "", "", "", "", + "shishikui.tokushima.jp", + "", "", + "edu.ec", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "kawaguchi.saitama.jp", + "", "", "", + "co.mg", + "", + "engineering", + "", "", "", "", + "gh", + "", + "bushey.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "anjo.aichi.jp", + "", "", "", "", "", "", "", "", + "cc.md.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "naie.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "esan.hokkaido.jp", + "uz", + "berlin.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "virtueeldomein.nl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "otoyo.kochi.jp", + "", "", "", "", "", "", "", "", "", + "", + "uz.ua", + "", "", "", "", "", "", "", "", "", + "", "", "", + "aktyubinsk.su", + "", "", "", "", "", + "umbria.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "kotohira.kagawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "myqnapcloud.com", + "", "", "", "", "", "", "", "", "", + "", + "kaneyama.fukushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "hongo.hiroshima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "george", + "", "", "", "", "", + "s3.dualstack.ap-southeast-2.amazonaws.com", + "", "", "", + "minato.tokyo.jp", + "", "", + "madrid.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "sigdal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "gran.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "services", + "minamisanriku.miyagi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "genting", + "", "", "", "", "", "", "", "", + "kristiansand.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "ax", + "", "", + "seiro.niigata.jp", + "", "", + "axa", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "sch.qa", + "", "", + "cx", + "", "", "", "", "", "", "", "", "", + "", "", "", + "nadex", + "", "", "", "", "", "", "", "", "", + "", "", + "serveblog.net", + "", "", "", + "otaru.hokkaido.jp", + "", "", "", "", "", "", + "guide", + "gb.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "matsuura.nagasaki.jp", + "", "", "", "", "", "", + "environment.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "co.je", + "", "", "", + "hinode.tokyo.jp", + "", "", "", + "\347\273\204\347\273\207.hk", + "", "", "", "", + "\347\265\204\347\273\207.hk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "\347\273\204\347\271\224.hk", + "edu.lc", + "", "", "", + "\347\265\204\347\271\224.hk", + "", "", "", "", "", "", "", + "matsumoto.kagoshima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "nom.nc", + "", "", "", "", "", "", "", + "health.museum", + "", "", "", "", "", "", "", "", "", + "marugame.kagawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "edu.vc", + "", "", "", "", "", "", "", "", "", + "", "", "", + "sx", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "odate.akita.jp", + "gob.hn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "and\303\270y.no", + "", "", "", "", "", "", + "farmers", + "", "", "", "", + "rw", + "", "", "", "", + "eisenbahn.museum", + "", "", "", "", + "ro", + "", "", "", "", + "rs", + "", "", + "ro.it", + "sch.ir", + "", "", "", "", + "\346\224\277\345\272\234", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "rodeo", + "", "", "", "", "", "", "", "", "", + "ra.it", + "", "", "", "", + "radio", + "", + "from.hr", + "", "", "", "", "", "", "", "", "", + "", "", + "kvinnherad.no", + "", "", "", "", "", "", "", "", "", + "", "", + "\344\274\201\344\270\232", + "", "", "", "", "", "", "", "", + "higashihiroshima.hiroshima.jp", + "", + "re", + "red", + "", "", "", "", "", "", + "re.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "notteroy.no", + "", "", "", "", "", "", "", + "builders", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "misawa.aomori.jp", + "", "", "", "", "", "", "", "", "", + "webhop.info", + "", "", + "exnet.su", + "", "", "", "", + "go.th", + "srv.br", + "", "", "", "", "", + "ogawa.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "fuchu.hiroshima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "asti.it", + "", "", "", "", "", "", "", "", "", + "", + "rc.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "read", + "", "", "", "", "", "", "", + "ftpaccess.cc", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "kurate.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "seek", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "r.se", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "misato.saitama.jp", + "", "", "", "", + "ren", + "", "", "", "", "", "", "", + "shizukuishi.iwate.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "rade.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "nanbu.yamanashi.jp", + "", "", + "ru", + "", "", "", "", "", "", "", "", "", + "", "", + "botany.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", + "quest", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "beer", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "fermo.it", + "", "", "", "", "", "", "", "", "", + "", "", + "chikuhoku.nagano.jp", + "gob.pe", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "ubank", + "", "", + "furano.hokkaido.jp", + "", "", "", "", + "gs.svalbard.no", + "", "", "", "", "", + "sicily.it", + "", "", "", "", + "re.kr", + "", "", "", "", "", + "abashiri.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "firm.ro", + "", "", "", "", "", "", "", + "ri.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "community", + "", "", "", "", "", "", "", "", + "rip", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "ri.us", + "", + "ninja", + "", "", "", "", "", "", "", "", "", + "forex", + "", "", "", "", "", + "marnardal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "fedex", + "katagami.akita.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "udine.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "kashiwazaki.niigata.jp", + "", "", "", "", "", "", "", "", + "rana.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "kaminoyama.yamagata.jp", + "", "", "", "", "", "", "", + "free", + "", "", "", "", "", "", + "run", + "", "", "", "", "", + "bari.it", + "", "", "", "", "", "", + "gru.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "name.cy", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "git-repos.de", + "", "", "", "", "", "", "", "", + "harima.hyogo.jp", + "", "", "", "", "", + "horokanai.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "cc.mn.us", + "", "", "", "", + "shiroishi.saga.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "nagasaki.jp", + "", "", "", "", "", "", "", + "rv.ua", + "", "", "", + "nome.pt", + "", "", + "caalwaysdata.net", + "", "", "", "", "", "", "", "", "", + "", + "yusuhara.kochi.jp", + "", "", + "adv.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "chita.aichi.jp", + "miasa.nagano.jp", + "her\303\270y.m\303\270re-og-romsdal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "naturbruksgymn.se", + "", + "ogata.akita.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "daegu.kr", + "", "", "", "", "", "", "", "", + "uconnect", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "ota.gunma.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "crew.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "yoga", + "sch.ae", + "", "", + "r.bg", + "", "", "", "", "", "", "", "", "", + "", "", "", + "kaminokawa.tochigi.jp", + "", "", "", + "cloud.metacentrum.cz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "shiftedit.io", + "", "", "", "", "", "", "", "", "", + "", "", + "artanddesign.museum", + "", "", + "capetown", + "", "", "", "", "", "", "", "", "", + "", "", "", + "sch.jo", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "hofu.yamaguchi.jp", + "", + "foggia.it", + "", "", "", "", "", + "rec.ro", + "", "", + "frei.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "grocery", + "", "", + "rocks", + "", "", "", "", "", "", "", + "ora.gunma.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "rec.co", + "", "", "", "", "", "", "", "", "", + "res.in", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "gs.nt.no", + "", "", "", "", "", "", "", "", "", + "", + "rest", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "misato.wakayama.jp", + "", "", "", "", "", "", "", + "edeka", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "kariya.aichi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "rent", + "", + "utazu.kagawa.jp", + "", "", "", "", "", "", "", "", + "cityeats", + "", "", "", "", "", "", "", "", "", + "kainan.tokushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "familyds.org", + "org", + "", "", "", + "emilia-romagna.it", + "", "", + "sumoto.hyogo.jp", + "", "", "", "", "", "", + "yamanashi.jp", + "minamiuonuma.niigata.jp", + "", "", "", "", "", "", "", + "ogose.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "\351\233\273\350\250\212\347\233\210\347\247\221", + "", "", "", "", "", "", "", "", + "agano.niigata.jp", + "", "", "", + "farm.museum", + "org.tm", + "", "", "", "", + "org.om", + "", "", "", + "diet", + "org.to", + "", "", "", "", "", + "kawachinagano.osaka.jp", + "", "", "", + "org.so", + "gs.ah.no", + "", "", "", "", "", "", "", "", "", + "", "", "", + "onion", + "org.am", + "", "", "", "", "", "", "", + "nagano.jp", + "kawaba.gunma.jp", + "", "", "", "", "", "", + "grane.no", + "", "", "", + "gose.nara.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "rio", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "ovre-eiker.no", + "", + "kamakura.kanagawa.jp", + "org.sh", + "", "", "", "", "", "", "", "", + "amex", + "rost.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "school", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "rm.it", + "", "", "", "", + "ro.im", + "", + "org.ro", + "", "", "", "", "", "", "", "", "", + "", + "attorney", + "", "", "", "", "", "", + "santabarbara.museum", + "", + "org.tn", + "", "", "", "", "", "", + "hagebostad.no", + "", "", + "org.sn", + "", "", "", "", + "it", + "", "", "", "", + "io", + "", "", "", "", + "is", + "", "", "", "", + "org.co", + "", "", + "is.it", + "", "", "", "", + "it.ao", + "oz.au", + "", "", "", "", "", "", "", "", "", + "\345\244\247\346\213\277", + "", + "yonago.tottori.jp", + "itau", + "", "", "", "", "", "", "", "", "", + "koshu.yamanashi.jp", + "", "", "", "", "", "", + "\353\213\267\354\273\264", + "", "", "", "", + "vivo", + "", "", "", "", "", "", "", "", "", + "", + "org.sa", + "", "", + "cc.tx.us", + "", "", + "ist", + "", "", "", "", "", "", + "ia.us", + "", + "ie", + "", + "usuki.oita.jp", + "", "", "", "", "", "", "", "", + "emerck", + "", + "wajiki.tokushima.jp", + "", + "org.ai", + "", "", "", + "oy.lc", + "", "", "", "", + "schule", + "", "", "", "", "", + "run.app", + "", "", + "\340\244\255\340\244\276\340\244\260\340\245\213\340\244\244", + "", "", "", + "2000.hu", + "", + "communications.museum", + "", "", + "on-the-web.tv", + "", "", "", "", "", + "chirurgiens-dentistes.fr", + "", "", "", "", "", "", + "sanuki.kagawa.jp", + "", + "2038.io", + "nexus", + "", "", "", "", "", "", "", "", "", + "higashiomi.shiga.jp", + "", "", "", "", "", "", "", "", "", + "", + "net.ws", + "oarai.ibaraki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "ir", + "", + "kashiwara.osaka.jp", + "kamisunagawa.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "recht.pro", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "org.cn", + "", "", "", "", "", "", "", "", + "com.ws", + "", "", "", "", "", + "org.uk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "game-host.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "nom.es", + "", "", "", + "funahashi.toyama.jp", + "", "", "", "", "", "", "", "", "", + "murakami.niigata.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "org.ci", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "com.es", + "", "", "", "", "", + "rentals", + "", "", "", "", "", + "gs.nl.no", + "", "", + "\346\224\277\345\212\241", + "", "", "", + "oppdal.no", + "", "", + "kurume.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", + "aurskog-h\303\270land.no", + "", "", + "org.sl", + "", "", "", "", "", "", "", + "kawaue.gifu.jp", + "\346\213\233\350\201\230", + "", "", "", "", + "nom.rs", + "", "", "", "", "", "", + "omura.nagasaki.jp", + "", "", "", + "org.al", + "", + "ouchi.saga.jp", + "", + "kamo.niigata.jp", + "", "", "", "", "", "", + "sex", + "", "", "", "", "", "", "", "", "", + "", + "i.se", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "org.im", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "sexy", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "browsersafetymark.io", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "saroma.hokkaido.jp", + "", "", + "org.lk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "glug.org.uk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "org.ua", + "", "", "", "", "", "", "", + "yonabaru.okinawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "moriyama.shiga.jp", + "", "", "", + "yac.za", + "", "", + "kanna.gunma.jp", + "", "", "", "", "", "", + "finance", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "condos", + "", "", "", + "rg.it", + "", "", "", + "gen.mi.us", + "davvenj\303\241rga.no", + "", "", "", "", "", "", "", "", "", + "", "", + "org.in", + "box", + "", "", + "ggf.br", + "", + "aki.kochi.jp", + "", "", "", + "s3.dualstack.ap-northeast-2.amazonaws.com", + "", "", "", "", "", "", + "rich", + "", + "shintoku.hokkaido.jp", + "", "", "", "", "", "", "", "", + "!city.kitakyushu.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "or.tz", + "", "", "", "", + "\353\213\267\353\204\267", + "org.tj", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "medio-campidano.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "nagi.okayama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "il", + "", "", "", "", "", "", "", "", "", + "guitars", + "", "", "", "", "", "", "", "", "", + "", + "mov", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "koori.fukushima.jp", + "il.us", + "net.is", + "", "", "", "", "", "", "", "", "", + "", + "org.la", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "r\303\245de.no", + "", "", "", + "org.vn", + "", "", "", + "ru.com", + "", "", "", "", + "nsn.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "com.is", + "", "", "", + "movie", + "", "", "", "", "", "", "", "", + "kawanishi.hyogo.jp", + "", "", + "boehringer", + "", "", "", "", + "firm.nf", + "", "", "", "", + "asso.ci", + "", "", "", "", "", "", + "haboro.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "r\303\270st.no", + "", "", "", + "org.vi", + "", "", "", + "net.ls", + "", "", "", "", "", "", + "v\303\245gs\303\270y.no", + "", "", "", "", "", "", "", "", "", + "", + "i.ng", + "", "", "", "", "", "", "", "", + "embroidery.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "fox", + "", "", "", + "org.il", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "org.dm", + "", + "i.ph", + "", "", "", "", "", + "otaki.chiba.jp", + "", + "org.do", + "", "", "", "", "", "", "", + "minoh.osaka.jp", + "", "", "", "", "", "", + "kvam.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "next", + "", + "2ix.ch", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "hvaler.no", + "", "", "", + "funabashi.chiba.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "repair", + "", "", + "i.bg", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "romsa.no", + "", "", "", "", "", "", "", "", "", + "chuo.yamanashi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "swiebodzin.pl", + "", "", "", "", "", "", "", "", "", + "", "", + "narita.chiba.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "rn.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "icu", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "ro.eu.org", + "", "", "", "", + "go-vip.co", + "", "", "", "", "", "", "", "", "", + "", "", "", + "id", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "buzen.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "id.us", + "", "", "", "", "", "", "", "", + "blogspot.co.za", + "", "", "", + "redstone", + "", "", "", "", + "kurogi.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "meiwa.mie.jp", + "", + "k12.wy.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "setagaya.tokyo.jp", + "namegawa.saitama.jp", + "", + "daisen.akita.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "fedje.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "sveio.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "org.mx", + "", "", "", "", "", "", "", "", "", + "", "", "", + "id.ir", + "", "", "", "", "", "", + "org.mk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "hiraya.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "org.mo", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "fresenius", + "environmentalconservation.museum", + "", "", "", "", "", "", + "bifuka.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "kaisei.kanagawa.jp", + "", "", "", "", "", "", + "susaki.kochi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "fed.us", + "", "", "", "", "", "", "", "", "", + "", "", + "s3.ap-south-1.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "", + "nishiwaki.hyogo.jp", + "", "", "", + "akaiwa.okayama.jp", + "", "", "", + "minamiashigara.kanagawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "k\303\241r\303\241\305\241johka.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "mywire.org", + "", "", "", "", "", "", "", + "os.hedmark.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "org.mn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "im", + "minano.saitama.jp", + "", "", "", "", "", "", + "im.it", + "", "", "", + "ru.eu.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "hotmail", + "", "", "", + "rns.tn", + "", "", + "enna.it", + "", "", "", + "mamurogawa.yamagata.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "id.au", + "", "", "", "", "", "", + "org.ma", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "org.tr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "xerox", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "org.ar", + "", "", "", "", "", "", "", + "okawa.kochi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "kitami.hokkaido.jp", + "", "", + "engine.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "net.ms", + "ogawa.ibaraki.jp", + "", "", "", "", "", "", "", "", "", + "", + "rissa.no", + "", "", "", "", "", "", "", "", "", + "", "", + "kagawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "com.ms", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "naganohara.gunma.jp", + "", "", + "keisen.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "himeji.hyogo.jp", + "", "", + "daiwa.hiroshima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "bergamo.it", + "", + "name.et", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "sondrio.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "org.ml", + "", "", "", "", + "iq", + "", "", "", "", "", "", "", "", + "broadcast.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "showa.yamanashi.jp", + "", "", "", "", "", + "yotsukaido.chiba.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "org.qa", + "", "", "", "", "", "", "", "", + "roma.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "civilisation.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "co.jp", + "", "", "", "", "", "", "", "", + "rocher", + "", "", + "esashi.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "ne.jp", + "", "", "", "", "", "", "", "", + "fhv.se", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "ogasawara.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "org.gh", + "", "", "", "", "", "", "", "", "", + "", "", + "mj\303\270ndalen.no", + "", "", + "godaddy", + "", + "asso.ht", + "", + "s3.cn-north-1.amazonaws.com.cn", + "", "", "", "", "", + "s3.us-east-2.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "koshimizu.hokkaido.jp", + "", + "davvenjarga.no", + "", + "edu.ws", + "", "", + "kawakami.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "yabu.hyogo.jp", + "", "", "", + "s3-ap-south-1.amazonaws.com", + "", "", "", "", "", "", "", + "community.museum", + "", "", "", "", "", + "org.gn", + "", "", "", "", "", "", "", "", "", + "", "", + "como.it", + "", "", + "ac.jp", + "", "", "", + "manno.kagawa.jp", + "", "", "", "", "", "", + "yamanashi.yamanashi.jp", + "", "", "", + "static-access.net", + "", "", "", "", "", "", "", "", "", + "", "", "", + "chirurgiens-dentistes-en-france.fr", + "", "", "", "", "", + "edu.es", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "org.gi", + "", "", "", "", + "org.ir", + "youtube", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "rnu.tn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "ong", + "", + "midori.gunma.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "edu.rs", + "", "", "", "", "", "", + "higashimatsushima.miyagi.jp", + "", "", + "newmexico.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "claims", + "", "", "", "", "", "", "", "", "", + "", + "org.lr", + "", "", + "communication.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "cloud66.ws", + "otobe.hokkaido.jp", + "", "", "", "", "", + "hidaka.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "myoko.niigata.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "marumori.miyagi.jp", + "", + "nagasaki.nagasaki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "financial", + "group.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "sydney.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "org.gl", + "", "", "", "", "", "", "", "", "", + "", "", + "showa.fukushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "kasuga.hyogo.jp", + "", "", "", "", "", "", "", "", "", + "", + "kui.hiroshima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "moscow.museum", + "", "", "", "", + "icbc", + "", + "sannan.hyogo.jp", + "", "", "", "", "", "", + "garden.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "cleaning", + "", "", "", "", "", + "idf.il", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "nx.cn", + "", "", "", + "mitaka.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "hotels", + "", "", "", "", "", "", "", "", + "fjaler.no", + "", + "in", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "edu.is", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "commbank", + "", "", "", "", "", + "it.eu.org", + "", "", "", "", "", "", "", + "saotome.st", + "", + "is.eu.org", + "in.us", + "", "", "", + "county.museum", + "", "", "", "", "", "", "", + "org.na", + "", "", "", "", + "org.ni", + "int", + "", "", "", "", "", "", + "in.ua", + "", + "s3-us-east-2.amazonaws.com", + "", "", "", "", "", + "sagae.yamagata.jp", + "", "", + "kred", + "", + "minami.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "sch.id", + "", "", "", "", "", + "org.gp", + "grong.no", + "", "", "", "", "", + "ie.eu.org", + "", "", "", "", "", "", "", "", "", + "", "", + "edu.ls", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "friulivgiulia.it", + "warabi.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "in.rs", + "", + "higashine.yamagata.jp", + "", "", "", "", "", "", "", + "yamato.fukushima.jp", + "", "", "", "", "", "", "", "", + "\345\262\251\346\211\213.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "kagoshima.jp", + "", "", "", + "blackbaudcdn.net", + "", "", "", "", + "ismaili", + "", "", "", + "hidaka.kochi.jp", + "", + "yoshioka.gunma.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "sx.cn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "settsu.osaka.jp", + "", "", "", "", + "ind.tn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "nagai.yamagata.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "int.co", + "", "", "", "", "", "", "", + "16-b.it", + "", "", "", "", "", "", "", + "cloudns.us", + "", "", "", "", "", + "usr.cloud.muni.cz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "ad.jp", + "", + "64-b.it", + "", "", "", + "fie.ee", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "ed.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "shiranuka.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "g12.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "org.se", + "", "", "", "", "", "", "", "", "", + "cloudns.in", + "", "", "", + "ras.ru", + "", "", "", "", "", "", "", "", "", + "", + "org.ae", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "org.ee", + "", "", "", "", "", "", + "googleapis.com", + "", "", "", "", + "cloudns.asia", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "higashiagatsuma.gunma.jp", + "", + "org.jo", + "", "", "", + "int.ci", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "yamashina.kyoto.jp", + "", "", "", + "seirou.niigata.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "sicilia.it", + "", "", "", "", + "firm.dk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "gbiz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "minamiminowa.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "crotone.it", + "", "", "", "", "", "", "", "", "", + "", "", + "il.eu.org", + "", "", "", "", "", "", "", "", + "4lima.at", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "diamonds", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "intel", + "", + "cloudns.eu", + "sandcats.io", + "", "", "", "", "", "", "", "", "", + "", "", "", + "int.lk", + "", + "inc", + "", "", "", "", "", "", "", "", "", + "", + "gamvik.no", + "", "", "", "", "", + "algard.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "rec.ve", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "ind.in", + "", "", "", "", "", "", "", "", "", + "", "", "", + "novara.it", + "", "", "", "", "", "", "", "", + "ostrowiec.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "ilawa.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "hisamitsu", + "", "", "", "", "", + "org.pk", + "", "", "", "", "", "", "", "", + "minami.kyoto.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "alvdal.no", + "", "", "", "", "", "", + "int.tj", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "edu.ms", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "bbe", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "kaga.ishikawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "org.ph", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "kosaka.akita.jp", + "", "", "", "", "", "", "", + "saxo", + "finnoy.no", + "otari.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", + "ferrara.it", + "", "", "", "", "", "", "", "", + "inf.ua", + "", "", "", "", + "int.la", + "", "", "", "", "", "", "", "", "", + "", + "org.gr", + "", "", "", "", "", "", + "insurance", + "", "", "", "", "", "", + "int.vn", + "armenia.su", + "", "", "", "", "", "", "", "", "", + "", "", "", + "kibichuo.okayama.jp", + "", "", "", "", + "marche.it", + "", + "org.pn", + "", "", "", "", "", + "beauxarts.museum", + "", "", "", + "catania.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "s3.dualstack.sa-east-1.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "suedtirol.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "org.pa", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "iwate.jp", + "", "", "", "", "", "", "", + "otaki.nagano.jp", + "", "", "", + "k12.ny.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "s3.dualstack.eu-west-3.amazonaws.com", + "minamidaito.okinawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "cloudns.cc", + "", "", "", "", "", "", "", "", "", + "", "", + "akune.kagoshima.jp", + "", "", "", + "sugito.saitama.jp", + "", "", "", + "org.ve", + "", "", "", "", "", "", "", "", "", + "", + "zgorzelec.pl", + "", + "ami.ibaraki.jp", + "net.ps", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "roros.no", + "", "", "", "", "", "", "", + "com.ps", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "yashio.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "chungbuk.kr", + "", "", "", "", "", "", + "engineer.aero", + "", "", + "org.au", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "org.pl", + "misato.shimane.jp", + "", "", + "rendalen.no", + "", "", "", "", + "hirono.iwate.jp", + "", "", "", "", "", "", "", "", "", + "rep.kp", + "", + "mjondalen.no", + "", "", "", "", "", "", "", "", "", + "", "", "", + "komaki.aichi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "omiya.saitama.jp", + "", "", "", "", "", "", "", "", "", + "s3.dualstack.eu-west-1.amazonaws.com", + "azurewebsites.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "s3.dualstack.us-east-1.amazonaws.com", + "", "", "", "", + "org.ru", + "", "", "", "", "", "", + "yamato.kanagawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "rodoy.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "org.cu", + "", "", "", "", "", + "kanuma.tochigi.jp", + "", "", + "union.aero", + "", + "radoy.no", + "", "", "", + "org.nr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "ditchyourip.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "ribeirao.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "firmdale", + "", "", "", "", "", "", "", "", "", + "kasama.ibaraki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "assabu.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "katano.osaka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "sennan.osaka.jp", + "", "", "", "", + "misato.akita.jp", + "", "", "", + "dnsiskinky.com", + "", "", "", + "shinshiro.aichi.jp", + "", "", "", "", + "insurance.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "bjark\303\270y.no", + "org.km", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "s3.eu-central-1.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "ryukyu", + "", "", "", "", + "inf.mk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "mitsue.nara.jp", + "", "", "", "", "", + "int.ar", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "shonai.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "giize.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "org.me", + "", "", "", "", + "org.kn", + "", "", "", "", "", "", "", "", "", + "ogano.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "sex.pl", + "", "", "", "", "", "", + "cloudns.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "org.ki", + "", "", "", "", + "org.bm", + "friuliv-giulia.it", + "", "", "", "", "", "", "", "", + "org.bo", + "", "", "", "", + "fujimi.nagano.jp", + "", "", + "homelinux.com", + "", + "komatsu", + "", "", "", + "warman", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "raid", + "", "", "", "", + "yurihonjo.akita.jp", + "mizumaki.fukuoka.jp", + "", "", "", "", "", "", "", + "res.aero", + "", "", "", + "org.vu", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "k12.ec", + "org.bh", + "duckdns.org", + "", "", "", "", + "organic", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "sassari.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "airbus", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "risor.no", + "", "", + "bounty-full.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "sec.ps", + "", "", "", "", "", "", + "masuda.shimane.jp", + "", "", "", "", "", "", "", "", + "org.bn", + "", "", "", + "norfolk.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "bradesco", + "", "", "", + "roan.no", + "", "", "", "", "", + "now-dns.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "org.ba", + "", "", "", "", + "org.bi", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "fujitsu", + "iamallama.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "med.ec", + "", "", + "hangout", + "", "", "", "", "", "", "", "", "", + "", + "homelinux.net", + "", "", "", + "immo", + "", "", "", "", "", + "reise", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "homedns.org", + "", "", "", "", + "obu.aichi.jp", + "", "", "", "", + "ibm", + "", "", "", "", "", "", "", + "net.bs", + "", "", + "shichikashuku.miyagi.jp", + "", "", "", + "dsmynas.org", + "", "", "", "", "", "", "", + "2ix.de", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "blogspot.mx", + "", "", "", "", "", "", "", "", "", + "", "", "", + "com.bs", + "", "", "", "", "", "", "", + "itayanagi.aomori.jp", + "", + "its.me", + "", "", "", "", + "ogawa.nagano.jp", + "kai.yamanashi.jp", + "", "", + "s3-eu-central-1.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "higashiura.aichi.jp", + "", "", "", "", "", "", "", "", "", + "", + "mormon", + "", "", "", "", "", "", + "entomology.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "avianca", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "org.ge", + "", "", "", "", "", + "grandrapids.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "yuu.yamaguchi.jp", + "", "", + "rl.no", + "", "", "", "", "", "", "", "", "", + "", "", + "org.kp", + "", + "imdb", + "", + "reisen", + "", "", "", "", "", "", + "ako.hyogo.jp", + "", "", "", "", "", "", + "go-vip.net", + "", "", + "yamaguchi.jp", + "in.eu.org", + "", "", + "git-pages.rit.edu", + "", "", "", "", "", "", "", "", + "nf", + "gratangen.no", + "", "", "", "", + "mypi.co", + "!city.yokohama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "af", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "org.pr", + "", "", "", + "cf", + "cfd", + "", "", "", "", + "cfa", + "", "", "", "", "", "", "", "", "", + "", "", + "achi.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "meiwa.gunma.jp", + "", + "science", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "\346\224\277\345\272\234.\351\246\231\346\270\257", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "yamato.kumamoto.jp", + "", "", + "bizen.okayama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "kazuno.akita.jp", + "", "", "", "", "", "", + "c.cdn77.org", + "", "", + "stalowa-wola.pl", + "", "", "", "", "", "", "", "", + "ooguy.com", + "nichinan.miyazaki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "unzen.nagasaki.jp", + "", "", "", "", + "nogata.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "reit", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "org.mu", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "kaneyama.yamagata.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "hirado.nagasaki.jp", + "", + "bahn.museum", + "", "", "", "", "", "", "", "", "", + "", "", + "is-by.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "shinanomachi.nagano.jp", + "kumakogen.ehime.jp", + "", "", + "ringsaker.no", + "", "", "", "", "", + "blogdns.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "sfr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "fujiyoshida.yamanashi.jp", + "int.ni", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "yonaguni.okinawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "maintenance.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", + "republican", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "cloudcontrolled.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "ca-central-1.elasticbeanstalk.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "udono.mie.jp", + "", "", "", "", "", "", "", "", + "karelia.su", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "karasuyama.tochigi.jp", + "", "", "", + "veg\303\245rshei.no", + "", "", "", "", "", "", "", "", "", + "edu.ps", + "", "", "", "", "", "", "", "", "", + "even\303\241\305\241\305\241i.no", + "", "", "", "", "", "", "", "", "", + "", + "cistron.nl", + "", "", "", "", "", "", "", "", "", + "nyuzen.toyama.jp", + "", "", "", "", "", + "dnsdojo.org", + "", "", "", "", "", "", + "nagareyama.chiba.jp", + "", "", + "ip6.arpa", + "hasami.nagasaki.jp", + "k12.ky.us", + "bf", + "", "", "", "", "", "", "", "", "", + "", + "myactivedirectory.com", + "", "", "", "", "", + "artcenter.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "org.sd", + "", "", + "s3.ca-central-1.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "africa", + "", "", "", "", "", "", "", + "kujukuri.chiba.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "hannan.osaka.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "mail.pl", + "", + "nextdirect", + "", "", "", "", "", "", "", + "yamada.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "oirase.aomori.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "miami", + "", "", "", "", + "everbank", + "", "", "", "", "", "", + "oumu.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "rec.br", + "", "", "", "", "", "", + "radom.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "aarborte.no", + "", "", "", "", "", "", "", + "biz.ls", + "", "", "", "", "", "", "", "", "", + "", + "org.hk", + "", "", "", "", "", "", "", "", "", + "org.gu", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "b\303\241jddar.no", + "", "", "", "", "", "", "", "", "", + "", + "kazimierz-dolny.pl", + "", "", "", "", "", + "eu-central-1.elasticbeanstalk.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "natal.br", + "hachioji.tokyo.jp", + "n\303\241vuotna.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "hyuga.miyazaki.jp", + "", "", "", "", "", "", "", "", + "komoro.nagano.jp", + "", "", "", + "station.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "kainan.wakayama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "ethnology.museum", + "", "", "", "", "", "", + "friulivegiulia.it", + "", "", "", "", "", "", "", "", + "natori.miyagi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "owariasahi.aichi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "info", + "", "", "", "", "", "", "", "", + "cloudns.pro", + "", "", "", + "org.hn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "guge", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "maniwa.okayama.jp", + "", "", "", "", "", "", "", "", + "recipes", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "insure", + "", "", "", "", "", "", "", "", "", + "fredrikstad.no", + "", "", "", "", "", "", "", "", "", + "", "", "", + "shiogama.miyagi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "gdansk.pl", + "", "", "", "", "", "", "", + "accountant", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "accountants", + "", "", + "costume.museum", + "", "", "", "", + "is-a-liberal.com", + "servecounterstrike.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "org.br", + "", "", "", "", "", "", "", "", "", + "org.je", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "synology-ds.de", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "gub.uy", + "", "", "", + "s3-ca-central-1.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "emergency.aero", + "vestby.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "kaita.hiroshima.jp", + "", "", "", "", "", "", "", "", + "uonuma.niigata.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "soundcast.me", + "", "", "", "", "", "", "", "", + "rio.br", + "", "", "", "", "", "", "", "", "", + "", + "is-a-musician.com", + "", "", + "mazury.pl", + "sciencecenters.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "kamisu.ibaraki.jp", + "moriguchi.osaka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "oharu.aichi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "info.na", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "go.tz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "exchange", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "omasvuotna.no", + "", "", "", "", "", "", "", "", "", + "", + "omi.niigata.jp", + "", "", "", "", "", + "kadoma.osaka.jp", + "barefoot", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "int.ve", + "", "", "", "", "", "", "", "", "", + "os.hordaland.no", + "", "", "", "", "", "", "", "", "", + "handson.museum", + "org.pe", + "", "", + "curitiba.br", + "", "", "", "", "", "", + "info.hu", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "niteroi.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "square7.ch", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "saarland", + "", + "yachimata.chiba.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "hotel.tz", + "", "", "", "", "", "", "", "", + "rmit", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "minamimaki.nagano.jp", + "info.ls", + "", "", "", + "edu.bs", + "", "", "", "", "", "", "", + "opole.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "ogi.saga.jp", + "", "", "", "", "", "", "", "", "", + "info.ke", + "raisa.no", + "", "", "", + "info.au", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "info.la", + "", "", "", "", "", "", "", "", "", + "oji.nara.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "yusui.kagoshima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "friulive-giulia.it", + "", + "akashi.hyogo.jp", + "", "", "", "", "", "", "", "", "", + "int.ru", + "", "", "", "", "", "", "", "", "", + "", "", + "sinaapp.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "services.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "oguni.kumamoto.jp", + "", "", "", "", "", "", "", + "futtsu.chiba.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "act.edu.au", + "", "", "", "", "", "", + "nf.ca", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "nosegawa.nara.jp", + "", "", "", "", "", "", "", "", + "minamifurano.hokkaido.jp", + "", "", "", "", "", "", + "barsy.bg", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "starachowice.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "servehttp.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "steiermark.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "is-a-libertarian.com", + "", "", "", "", "", "", + "info.pk", + "", "", "", "", "", "", "", + "nom.fr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "com.fr", + "", "", "", "", "", + "yawata.kyoto.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "matsue.shimane.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "shinto.gunma.jp", + "dyndns-server.com", + "clinique", + "", "", "", "", "", "", + "motosu.gifu.jp", + "", + "azure-mobile.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "inf.cu", + "", "", "", "", "", "", "", "", "", + "", + "\351\233\206\345\233\242", + "", "", "", "", "", "", + "sasebo.nagasaki.jp", + "", "", "", "", "", "", "", "", "", + "mx", + "heguri.nara.jp", + "", + "info.nr", + "", "", "", "", "", "", "", + "moe", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "newjersey.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "goto.nagasaki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "gjovik.no", + "siena.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "b\303\270mlo.no", + "", + "owani.aomori.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "medizinhistorisches.museum", + "", "", "", "", "", "", "", "", + "kamisato.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "qld.edu.au", + "", "", "", "", "", "", "", "", "", + "", "", + "yamanakako.yamanashi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "minato.osaka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "bloxcms.com", + "", "", "", "", "", "", "", + "consulado.st", + "", + "broadway", + "", "", "", "", "", "", "", "", "", + "", "", "", + "int.bo", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "okaya.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "murmansk.su", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "kvits\303\270y.no", + "", "", "", "", "", "", "", + "mifune.kumamoto.jp", + "", + "chino.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", + "fitness", + "", "", "", "", "", "", "", "", "", + "muika.niigata.jp", + "", "", "", "", + "i234.me", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "yamaga.kumamoto.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "sortland.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "genova.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "ariake.saga.jp", + "", "", "", "", + "shiroishi.miyagi.jp", + "", + "isa-geek.net", + "", "", "", "", "", "", "", "", "", + "store.bb", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "axis.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "indianapolis.museum", + "", "", "", + "gmina.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "freeddns.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "kiev.ua", + "", "", + "info.ki", + "", "", "", "", "", + "moriya.ibaraki.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "restaurant", + "", "", "", "", "", "", "", "", "", + "", + "static.land", + "", "", + "kamikawa.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "minamiyamashiro.kyoto.jp", + "", "", "", + "iris.arpa", + "yabuki.fukushima.jp", + "", "", "", "", "", + "synology.me", + "", + "4lima.ch", + "", "", "", "", "", "", "", "", + "utashinai.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "ringerike.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "info.pr", + "", "", "", "", + "oiso.kanagawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "hlsvtcjs.org", + "", "", "", "", "", "", "", "", "", + "", "", "", + "honefoss.no", + "", "", "", "", + "feedback", + "newyork.museum", + "", "", "", "", + "uto.kumamoto.jp", + "", + "skedsmokorset.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "mitsubishi", + "suzaka.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "academy.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "onna.okinawa.jp", + "info.ni", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "osaki.miyagi.jp", + "", "", "", "", "", + "mitoyo.kagawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "mizuho.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "cheap", + "", "", + "hammarfeasta.no", + "", "", "", "", "", "", "", "", "", + "", "", + "info.ro", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "higashisumiyoshi.osaka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "mitake.gifu.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "homelinux.org", + "meet", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "is-slick.com", + "", "", "", "", "", "", "", "", "", + "", "", + "groundhandling.aero", + "", "", "", + "dsmynas.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "fhsk.se", + "", "", "", "", + "fuoisku.no", + "", "", "", "", "", "", "", "", + "kitahiroshima.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", + "fuossko.no", + "", "", "", "", "", "", "", + "wme", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "sibenik.museum", + "", "", "", "", "", "", "", + "indianmarket.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "hinohara.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "servesarcasm.com", + "floripa.br", + "", "", "", "", + "barueri.br", + "", "", "", + "chosei.chiba.jp", + "childrens.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "embaixada.st", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "muroto.kochi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "fujisawa.iwate.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "karacol.su", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "imb.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "nsw.edu.au", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "mysecuritycamera.net", + "", "", + "ayabe.kyoto.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "dyndns-pics.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "in.na", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "semine.miyagi.jp", + "", "", "", + "indigena.bo", + "", + "obira.hokkaido.jp", + "", "", "", "", "", "", + "sciencecenter.museum", + "", "", "", "", "", "", "", "", "", + "", + "katori.chiba.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "stavern.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "alabama.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "a.prod.fastly.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "githubusercontent.com", + "", + "minakami.gunma.jp", + "", "", "", "", "", "", "", "", "", + "blogdns.com", + "", "", "", "", "", "", "", + "is-a-patsfan.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "castres.museum", + "ong.br", + "", + "saikai.nagasaki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "oizumi.gunma.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "higashitsuno.kochi.jp", + "", "", "", "", + "asaminami.hiroshima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "dyndns-wiki.com", + "", "", "", "", "", "", + "org.tw", + "", "", "", "", "", "", + "intelligence.museum", + "", "", "", "", "", "", "", "", "", + "mitou.yamaguchi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "marriott", + "", "", + "asso.eu.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "clinic", + "", "", "", "", "", "", "", "", "", + "obuse.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", + "kitagawa.kochi.jp", + "", "", "", "", "", "", "", "", "", + "shingo.aomori.jp", + "", "", "", "", + "savannahga.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "boomla.net", + "", "", "", "", "", "", "", + "nanjo.okinawa.jp", + "", "", "", "", "", + "steinkjer.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "dnsdojo.com", + "", "", "", "", "", "", "", + "is-very-evil.org", + "", "", "", + "shinshinotsu.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "v\303\245ler.hedmark.no", + "", "", "", + "crimea.ua", + "", "", + "dnsking.ch", + "", "", + "gushikami.okinawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "dyndns-at-work.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "blogsite.org", + "", + "carrier.museum", + "", "", "", "", "", "", "", "", "", + "", + "org.cw", + "", "", "", + "nago.okinawa.jp", + "", + "go.dyndns.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "kitamoto.saitama.jp", + "erotika.hu", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "in.ni", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "aya.miyazaki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "otoineppu.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "ind.br", + "", "", "", "", "", "", "", "", + "sauherad.no", + "", "", "", "", "", "", "", "", "", + "sweden.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "s\303\270mna.no", + "", + "dni.us", + "n\303\246r\303\270y.no", + "", + "r\303\241isa.no", + "", "", "", "", "", + "freemasonry.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "ninohe.iwate.jp", + "", "", "", + "ricoh", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "riik.ee", + "", "", "", "", "", + "homegoods", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "is-a-hard-worker.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "otake.hiroshima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "ashikaga.tochigi.jp", + "", "", "", "", "", "", "", "", + "motegi.tochigi.jp", + "savona.it", + "", "", "", "", "", "", + "wazuka.kyoto.jp", + "", "", "", "", + "aseral.no", + "", "", "", + "sanofi", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "matsubara.osaka.jp", + "", "", "", "", "", "", "", + "suwalki.pl", + "", "", "", + "co.business", + "", "", + "cloudns.club", + "", "", "", "", "", + "sunagawa.hokkaido.jp", + "", "", "", "", "", + "stadt.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "minamiaiki.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "inf.br", + "", "", "", "", "", "", "", "", "", + "", "", "", + "shiojiri.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "cechire.com", + "", "", "", + "kosai.shizuoka.jp", + "", "", "", "", "", "", + "is-a-landscaper.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "inc.hk", + "", "", "", "", + "oster\303\270y.no", + "", + "flesberg.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "versicherung", + "", "", "", "", "", "", "", "", "", + "", + "cleverapps.io", + "", "", "", + "onthewifi.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "in.th", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "assassination.museum", + "", "", "", "", "", "", "", "", + "cyon.site", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "\347\247\213\347\224\260.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "32-b.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "is-a-linux-user.org", + "", "", "", "", "", "", "", + "is-an-actress.com", + "", "", "", "", "", "", "", + "internet-dns.de", + "", "", "", "", "", "", + "higashiosaka.osaka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "fujinomiya.shizuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "or.mu", + "", "", + "saito.miyazaki.jp", + "", "", + "3utilities.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "riobranco.br", + "", "", "", "", "", + "ozu.ehime.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "gamagori.aichi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "info.nf", + "", "", "", "", + "elvendrell.museum", + "", "", "", "", + "sand\303\270y.no", + "", "", "", "", + "gouv.bj", + "", "", "", "", "", "", "", "", "", + "", "", "", + "yaotsu.gifu.jp", + "", "", "", "", + "co.mz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "sagamihara.kanagawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "mitane.akita.jp", + "", "", "", "", "", "", "", "", "", + "", + "cagliari.it", + "", "", "", + "cyber.museum", + "", + "ovh", + "", "", "", "", "", "", "", "", + "is-a-rockstar.com", + "", + "iida.nagano.jp", + "", "", "", "", "", "", + "neues.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "rawa-maz.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", + "is-a-republican.com", + "", + "kunitomi.miyazaki.jp", + "", "", "", + "sorocaba.br", + "", "", "", "", "", "", "", "", "", + "", "", "", + "arboretum.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "yasugi.shimane.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "ac.mz", + "cymru.museum", + "", "", "", "", + "mysecuritycamera.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "nagasu.kumamoto.jp", + "", "", "", + "now-dns.top", + "", "", "", "", "", "", "", "", "", + "", + "dyndns-web.com", + "", "", + "org.hu", + "", "", + "eidfjord.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "dominic.ua", + "", "", "", "", "", "", "", + "gz.cn", + "", "", "", "", "", "", "", "", "", + "", "", + "nirasaki.yamanashi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "interactive.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "omuta.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "isa-geek.com", + "", "", "", + "state.museum", + "", "", "", "", "", "", "", "", "", + "", + "\303\245seral.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "mypsx.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "iron.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", + "habmer.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "school.museum", + "", "", "", "", "", + "glogow.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "watch-and-clock.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "hapmir.no", + "", "", "", "", "", "", + "sch.ly", + "", "", "", "", + "sch.zm", + "", "", "", "", "", "", "", + "\320\270\320\272\320\276\320\274.museum", + "", "", "", "", "", "", "", + "org.mw", + "", "", "", "", "", "", "", "", "", + "", + "bzh", + "", "", "", + "barreau.bj", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "s3.dualstack.eu-west-2.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "s3.dualstack.us-east-2.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "stage.nodeart.io", + "baths.museum", + "", + "karikatur.museum", + "", "", "", "", "", "", "", "", + "oygarden.no", + "", "", "", "", "", "", "", "", "", + "", "", + "school.na", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "is-a-anarchist.com", + "", "", "", "", "", "", "", "", "", + "", "", "", + "sciencehistory.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "basel.museum", + "", "", "", "", + "murayama.yamagata.jp", + "", "", "", "", "", + "iyo.ehime.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "crafts.museum", + "", "", "", "", "", "", "", "", "", + "", + "matsuyama.ehime.jp", + "blogspot.cf", + "", "", "", + "rindal.no", + "", "", "", "", "", "", "", "", "", + "", + "ikano", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "ogori.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "yamada.iwate.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "russia.museum", + "", "", + "yasuda.kochi.jp", + "", "", "", "", "", "", + "ulvik.no", + "", "", "", "", "", "", "", + "mysecuritycamera.org", + "", "", "", + "nagaokakyo.kyoto.jp", + "", "", "", "", "", "", "", "", + "her\303\270y.nordland.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "mobara.chiba.jp", + "", "", "", "", "", "", "", + "dyndns.ws", + "", "", "", "", "", "", "", "", "", + "", "", + "bergbau.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "sex.hu", + "", + "4lima.de", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "ehime.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "foodnetwork", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "dyndns-mail.com", + "", + "info.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "yuzawa.niigata.jp", + "wajima.ishikawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "s3-ap-northeast-1.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "scrysec.com", + "", "", "", "", "", + "riodejaneiro.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "kagoshima.kagoshima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "s3-ap-southeast-1.amazonaws.com", + "", "", "", "", "", "", + "namsos.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "g\303\241ivuotna.no", + "", "", "", "", "", + "exposed", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "kanagawa.jp", + "", "", + "barsy.site", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "synology-diskstation.de", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "norddal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "oguni.yamagata.jp", + "", "", + "amber.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "cherkassy.ua", + "", + "is-a-painter.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "sor-fron.no", + "", "", + "okinawa", + "seika.kyoto.jp", + "", "", + "messina.it", + "", "", "", "", "", "", "", "", "", + "", "", + "urausu.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "higashimatsuyama.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "dattolocal.net", + "", "", + "batsfjord.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "yamanouchi.nagano.jp", + "etnedal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "mex.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "budejju.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "misaki.okayama.jp", + "", "", "", + "hamaroy.no", + "", "", "", + "honjo.akita.jp", + "", "", "", "", "", + "gov", + "", "", "", "", "", "", + "shinonsen.hyogo.jp", + "", "", + "dr\303\270bak.no", + "", "", + "stargard.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "gov.sx", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "honjo.saitama.jp", + "", + "gov.tm", + "", "", "", "", + "gov.om", + "wedeploy.me", + "", "", "", + "gov.to", + "", "", "", "", "", + "andriabarlettatrani.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "asago.hyogo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "haugesund.no", + "", "", "", "", "", "", + "k12.sc.us", + "", "", "", "", "", "", "", "", "", + "", "", "", + "customer.enonic.io", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "sf.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "gov.sh", + "", "", "", "", "", "", "", + "nagahama.shiga.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "watari.miyagi.jp", + "", "", + "minami-alps.yamanashi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "gov.cx", + "", "", "", "", "", "", "", "", + "ris\303\270r.no", + "", "", "", "", "", "", + "storfjord.no", + "", "", "", "", "", "", "", "", + "gov.tn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "gov.cm", + "", "", "", "", "", + "meguro.tokyo.jp", + "", "", "", + "gov.co", + "", "", "", "", + "comunica\303\247\303\265es.museum", + "", "", "", "", "", "", + "okawa.fukuoka.jp", + "", "", "", + "friuli-ve-giulia.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "shiriuchi.hokkaido.jp", + "", "", "", "", "", "", "", + "dyndns-work.com", + "", "", "", "", "", "", "", "", "", + "gov.sa", + "", "", "", "", "", "", + "info.ec", + "", "", "", "", "", "", "", + "wegrow.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "chiryu.aichi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "iwate.iwate.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "hammerfest.no", + "", "", "", "", + "ericsson", + "", "", "", "", + "accesscam.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "sanda.hyogo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "massacarrara.it", + "", "", "", "", + "gov.cn", + "", "", "", + "richardli", + "", + "alpha-myqnapcloud.com", + "is-a-democrat.com", + "", "", "", "", "", "", "", + "gov.uk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "force.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "vix.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "minowa.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "foundation", + "", "", "", "", "", "", "", "", + "is-an-artist.com", + "", "", "", + "gov.tl", + "", "", "", "", "", "", + "ox.rs", + "", "", + "gov.sl", + "", "", + "nanbu.tottori.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "mosj\303\270en.no", + "dyndns.tv", + "", "", "", "", "", + "gov.al", + "", "", "", + "gives", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "int.rw", + "", "", "", "", + "guovdageaidnu.no", + "matta-varjjat.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "koebenhavn.museum", + "", "", "", "", "", "", "", "", "", + "", "", + "fitjar.no", + "", "", "", "", "", "", "", "", "", + "r\303\241hkker\303\241vju.no", + "", "", "", "", "", "", "", "", "", + "", + "yoita.niigata.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "is-a-personaltrainer.com", + "", "", "", "", "", "", "", + "saitama.jp", + "", "", "", "", "", "", "", "", "", + "bajddar.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "omi.nagano.jp", + "gov.lk", + "", "", "", "", "", "", "", "", + "humanities.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "gov.ua", + "", "", + "mie.jp", + "", "", "", "", "", "", "", + "house.museum", + "", "", "", "", "", "", "", "", "", + "wedeploy.io", + "", "", "", "", "", "", "", "", + "gov.cl", + "", "", "", "", "", "", "", "", + "vanguard", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "gov.in", + "", "", "", "", "", "", + "stordal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "gov.tj", + "", "", "", "", "", "", "", "", "", + "", + "aerobatic.aero", + "", "", "", "", + "misaki.osaka.jp", + "", "", "", "", "", "", "", "", "", + "", + "murata.miyagi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "kyonan.chiba.jp", + "", "", "", "", "", "", + "macerata.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "krasnik.pl", + "", "", "", "", "", + "international", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "asmatart.museum", + "", "", + "misato.miyagi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "gov.la", + "", "", "", "", "", "", + "natural.bo", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "gov.vn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "syncloud.it", + "", "", "", "", + "yahoo", + "", "", "", "", "", "", "", "", + "chihayaakasaka.osaka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "feira.br", + "", "", "", "", "", "", + "iwatsuki.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "fbxos.fr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "gov.il", + "", + "sandnes.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "kragero.no", + "", "", + "gov.dm", + "", "", "", "", "", "", "", "", "", + "gov.do", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "ayase.kanagawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "noshiro.akita.jp", + "k12.dc.us", + "", "", "", "", + "oyer.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "rsc.cdn77.org", + "", "", "", "", "", "", + "shinjo.nara.jp", + "", "", "", "", "", "", + "nagiso.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "maserati", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "nishiawakura.okayama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "myvnc.com", + "", "", "", "", "", "", + "depot.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "irish", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "vic.edu.au", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "fairwinds", + "", + "health.nz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "history.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "higashikagawa.kagawa.jp", + "dyndns-home.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "school.za", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "nagawa.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "gov.mk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "warmia.pl", + "", "", "", "", "", "", "", "", "", + "", + "gov.mo", + "", "", + "ozora.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "sorfold.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "freeddns.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "andriatranibarletta.it", + "", "", "", "", "", "", "", "", "", + "", "", + "karaganda.su", + "", "", "", "", "", "", "", "", "", + "brussel.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "gov.mn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "gov.ma", + "flekkefjord.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "gov.tr", + "", "", "", "", "", "", "", "", "", + "", "", + "consulting", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "\346\224\277\345\272\234.hk", + "gov.ar", + "", "", + "indian.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "mediocampidano.it", + "circus.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "national.museum", + "cci.fr", + "int.mw", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "civilaviation.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "kunohe.iwate.jp", + "", "", "", "", "", "", "", "", "", + "", + "mx.na", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "org.sy", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "florida.museum", + "", + "dyndns-at-home.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "gov.ml", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "wien", + "", "", "", "", "", "", "", "", "", + "", "", "", + "myfirewall.org", + "", + "yatomi.aichi.jp", + "", "", "", "", + "university", + "", "", "", "", "", "", "", + "rimini.it", + "", "", "", "", + "szex.hu", + "", "", "", "", "", "", "", "", "", + "rybnik.pl", + "gov.qa", + "", "", "", "", "", "", + "org.kw", + "hagi.yamaguchi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "nerdpol.ovh", + "", + "north-kazakhstan.su", + "", + "emiliaromagna.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "forsand.no", + "", "", "", "", "", "", "", "", "", + "isa-geek.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "org.cy", + "", "", "", "", "", "", "", + "gov.gh", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "shiroi.chiba.jp", + "", "", "", "", "", + "slattum.no", + "kamioka.akita.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "realtor", + "", "", "", "", "", "", "", "", "", + "nishimera.miyazaki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "semboku.akita.jp", + "", "", "", + "utsunomiya.tochigi.jp", + "", "", "", + "masaki.ehime.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "gov.gn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "k\303\245fjord.no", + "", "", "", "", "", "", "", "", + "capitalone", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "omega", + "", "", "", "", + "org.bw", + "", "", "", "", "", "", "", + "gov.gi", + "", "", "", "", + "gov.ir", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "aquarium.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "yawara.ibaraki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "org.uy", + "", "", + "odesa.ua", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "agdenes.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "spjelkavik.no", + "", "", "", "", + "gov.lr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "wf", + "", "", "", "", "", "", "", "", "", + "kozaki.chiba.jp", + "rebun.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "v\303\246r\303\270y.no", + "", "", "", "", "", "", "", "", "", + "", "", + "reg.dk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "is-very-nice.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "farsund.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "namegata.ibaraki.jp", + "", "", "", "", "", + "org.sb", + "", "", "", "", + "fetsund.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "kanegasaki.iwate.jp", + "", "", + "hirakata.osaka.jp", + "", "", + "org.ly", + "", "", "", "", + "org.zm", + "", + "k12.nc.us", + "", + "chonan.chiba.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "cricket", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "swidnik.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "download", + "", "", "", + "stor-elvdal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "satosho.okayama.jp", + "", "", "", "", "", "", "", "", "", + "", + "midori.chiba.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "vaporcloud.io", + "", "", "", "", "", "", "", "", "", + "", "", + "erimo.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "shisui.chiba.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "shioya.tochigi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "gemological.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "kunst.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "damnserver.com", + "", "", "", "", "", "", "", "", "", + "otsuki.kochi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "org.za", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "dyndns-blog.com", + "", "", "", "", + "enterprises", + "gosen.niigata.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "is-a-doctor.com", + "", "", "", "", "", "", "", "", "", + "", + "ddnsfree.com", + "", "", "", "", "", "", "", "", + "one", + "", "", "", "", "", "", "", "", "", + "", "", "", + "akishima.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "shingu.wakayama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "is-an-actor.com", + "", "", "", + "zushi.kanagawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "kr\303\270dsherad.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "genkai.saga.jp", + "", "", "", "", "", "", + "itako.ibaraki.jp", + "", "", "", + "kvafjord.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "anani.br", + "", "", "", "", "", "", + "chernihiv.ua", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "harstad.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "is-very-good.org", + "", "", "", "", "", "", "", "", "", + "choshi.chiba.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "kumamoto.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "gov.mr", + "", "", "", "", "", "", + "org.lb", + "imari.saga.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "fuel.aero", + "", "", "", + "gov.ae", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "virtual.museum", + "", "", + "aogaki.hyogo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "ojiya.niigata.jp", + "", "", + "gov.ee", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "gov.jo", + "", "", "", "", "", "", + "global.prod.fastly.net", + "", "", "", + "mansion.museum", + "", "", "", "", "", "", "", + "kasamatsu.gifu.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "fujisawa.kanagawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "stranda.no", + "", "", "", "", "", "", + "verm\303\266gensberater", + "", "", "", "", "", "", "", + "scholarships", + "", "", "", "", "", "", "", "", "", + "org.my", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "space.museum", + "", "", "", + "kasaoka.okayama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "ipiranga", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "webhop.biz", + "hiratsuka.kanagawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "avoues.fr", + "", "", "", + "research.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "bristol.museum", + "", "", "", "", + "wedeploy.sh", + "", "", "", "", "", "", "", "", + "in-dsl.net", + "", "", "", "", + "\304\215\303\241hcesuolo.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "yachts", + "", "", "", "", "", "", "", "", + "mmafan.biz", + "", "", "", "", "", "", "", "", "", + "scienceandindustry.museum", + "", "", "", + "kudamatsu.yamaguchi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "koza.wakayama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "gov.pk", + "", "", "", "", "", "", + "vagsoy.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "is-a-knight.org", + "", "", "", "", "", "", "", "", "", + "", "", + "championship.aero", + "mangyshlak.su", + "", "", + "scrapper-site.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "h\303\270ylandet.no", + "", "", "", + "santacruz.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "cloudcontrolapp.com", + "", "", "", + "vennesla.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "shinkamigoto.nagasaki.jp", + "", "", "", "", "", "", "", "", "", + "iz.hr", + "", "", "", "", + "gov.ph", + "", + "nagano.nagano.jp", + "", "", "", "", "", "", "", + "worse-than.tv", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "yugawara.kanagawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "gov.ie", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "gov.gr", + "", "", "", "", + "samukawa.kanagawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "burghof.museum", + "", "", + "africa.com", + "", + "kv\303\246fjord.no", + "", "", "", + "gov.pn", + "", "", "", "", + "freeboxos.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "kamikawa.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "dinosaur.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "ashiya.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "\303\270rskog.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "barsy.info", + "", "", "", "", "", "", "", + "ivgu.no", + "", "", "", "", "", "", "", "", + "nagara.chiba.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "czest.pl", + "", "", "", "", + "gov.ve", + "", "", "", "", "", "", + "org.gy", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "naha.okinawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "nanto.toyama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "exchange.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "rygge.no", + "", "", "", "", "", "", + "gov.au", + "", "", "", "", "", "", "", "", + "ujitawara.kyoto.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "shingu.fukuoka.jp", + "", + "gov.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "ann-arbor.mi.us", + "", "", + "or.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "chernigov.ua", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "b\303\245d\303\245ddj\303\245.no", + "", + "id.ly", + "", "", "", "", "", "", "", "", "", + "", "", "", + "dyndns-ip.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "asahi.toyama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "gov.ru", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "ikawa.akita.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "gov.cu", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "gov.nr", + "", "", "", "", "", + "kiho.mie.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "beskidy.pl", + "", + "scienceandhistory.museum", + "", + "kagami.kochi.jp", + "", "", "", "", "", "", "", "", "", + "", + "moareke.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "other.nf", + "", "", "", "", "", "", "", "", "", + "", + "foundation.museum", + "", + "vf.no", + "", "", "", "", "", "", "", + "k12.as.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "noheji.aomori.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "noda.chiba.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "gob.ec", + "", "", "", "", "", "", "", "", + "forlicesena.it", + "", "", + "eidskog.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "osakikamijima.hiroshima.jp", + "", "", "", "", "", "", "", + "gov.km", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "hiranai.aomori.jp", + "", "", "", "", "", "", "", "", "", + "kasai.hyogo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "starhub", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "kamikawa.hyogo.jp", + "", "", "", "", "", "", "", "", "", + "", + "kitagata.saga.jp", + "", "", + "western.museum", + "", "", "", "", "", "", "", + "space-to-rent.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "id.lv", + "", "", "", + "yamaxun", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "missile.museum", + "", "", "", + "on-web.fr", + "", "", "", "", "", "", "", "", "", + "gov.me", + "", "", "", "", + "gov.kn", + "north.museum", + "", "", "", "", "", "", "", "", "", + "freebox-os.com", + "", "", "", "", "", "", "", "", "", + "", "", "", + "\345\245\210\350\211\257.jp", + "", "", "", "", "", + "virtualuser.de", + "", + "monzaedellabrianza.it", + "", "", "", "", "", "", "", "", "", + "", "", + "ina.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "myhome-server.de", + "", "", "", "", "", "", "", "", + "gov.ki", + "", "", "", "", + "gov.bm", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "britishcolumbia.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "kamitonda.wakayama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "ind.kw", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "gov.bh", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "khakassia.su", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "kamiichi.toyama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "sosa.chiba.jp", + "", + "gov.bn", + "", "", "", "", "", "", "", "", "", + "", "", "", + "customer.speedpartner.de", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "dyn.home-webserver.de", + "", "", "", "", "", "", "", "", "", + "furukawa.miyagi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "gov.ba", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "air-surveillance.aero", + "", "", "", "", "", + "sannohe.aomori.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "in-the-band.net", + "", "", "", "", + "southcarolina.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "coastaldefence.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "my-router.de", + "", "", + "s3.ap-northeast-2.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "ukiha.fukuoka.jp", + "", + "hattfjelldal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "mypets.ws", + "", "", "", "", "", "", "", "", + "energy", + "", "", "", + "medecin.km", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "matsubushi.saitama.jp", + "", "", + "friuli-vegiulia.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "hamburg.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "friuli-vgiulia.it", + "", "", "", "", "", "", "", "", "", + "settlers.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "gov.ge", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "gov.kp", + "", "", + "ono.hyogo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "kami.miyagi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "yasaka.nagano.jp", + "ing", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "grozny.ru", + "", "", "", "", + "\303\245snes.no", + "gov.pr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "kin.okinawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "finn\303\270y.no", + "", + "microsoft", + "", "", + "h\303\241bmer.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "ota.tokyo.jp", + "", "", "", "", "", "", + "histoire.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "ap-southeast-1.elasticbeanstalk.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "clock.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "kyotamba.kyoto.jp", + "", "", "", "", "", + "ranzan.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "gov.mu", + "", "", "", "", "", "", "", "", "", + "", "", + "org.py", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "wzmiuw.gov.pl", + "omachi.saga.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "enonic.io", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "rugby", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "monzabrianza.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "clinton.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "s3-ap-northeast-2.amazonaws.com", + "", "", "", "", "", "", "", "", + "chimkent.su", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "verm\303\266gensberatung", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "grozny.su", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "skanland.no", + "hughes", + "", "", + "k12.ms.us", + "", "", + "s3-ap-southeast-2.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "cadaques.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "mydissent.net", + "", + "gov.sd", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "dynvpn.de", + "", "", "", "", "", "", "", "", "", + "university.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "qld.gov.au", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "sciencesnaturelles.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "zapto.xyz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "yugawa.fukushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "vestnes.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "friuli-v-giulia.it", + "", "", + "cust.dev.thingdust.io", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "fuchu.toyama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "gov.cd", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "gov.hk", + "", "", "", "", "", + "medical.museum", + "", "", "", + "gov.gu", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "stuff-4-sale.org", + "", "", "", "", + "custom.metacentrum.cz", + "", "", "", "", "", "", + "gs.mr.no", + "", "", "", "", "", "", "", "", "", + "", + "konskowola.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "dynamic-dns.info", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "jot", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "je", + "", "", "", "", "", "", + "childrensgarden.museum", + "fosnes.no", + "", + "samegawa.fukushima.jp", + "", "", "", "", + "uki.kumamoto.jp", + "", + "virtuel.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "net.tt", + "", "", "", "", "", "", "", "", "", + "net.st", + "", "", "", "", "", + "endofinternet.org", + "", "", "", "", "", "", "", "", + "nom.st", + "", "", "", "", "", "", + "bjarkoy.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "com.tt", + "", "", "", + "database.museum", + "", "", "", "", "", + "com.st", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "net.et", + "", "", "", "", "", "", + "jcp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "miniserver.com", + "", "", "", "", "", + "mizusawa.iwate.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "day", + "", "", "", "", + "soy", + "", "", "", "", "", "", "", + "com.et", + "", "", "", + "stuff-4-sale.us", + "", "", + "kamogawa.chiba.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "is-a-llama.com", + "", "", "", "", "", "", "", + "org.ky", + "", "", "", "", + "sunndal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "kamaishi.iwate.jp", + "", "", "", "", "", "", "", + "gov.br", + "", + "monticello.museum", + "", + "manaus.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "blogsite.xyz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "moonscale.net", + "", "", "", "", "", "", "", "", "", + "net-freaks.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "kumenan.okayama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "osen.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "hitachi.ibaraki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "yuza.yamagata.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "amami.kagoshima.jp", + "", "", "", "", "", "", + "reggioemilia.it", + "", "", "", "", "", "", + "jcb", + "", "", "", "", "", "", "", + "kagamino.okayama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "nationalheritage.museum", + "", "", "", "", "", "", "", "", + "endofinternet.net", + "001www.com", + "", "", "", + "media.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "jobs", + "", "", "", "", "", "", "", "", "", + "", + "bjerkreim.no", + "", "", "", "", "", "", + "higashikagura.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "yamada.toyama.jp", + "", "", "", "", "", "", "", + "cam.it", + "", "", "", "", "", "", + "diy", + "shinjo.okayama.jp", + "", + "immobilien", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "gouv.ci", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "arida.wakayama.jp", + "", "", "", "", + "sor-aurdal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "virginia.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "freedesktop.org", + "", + "no-ip.info", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "nanao.ishikawa.jp", + "", "", + "notogawa.shiga.jp", + "", "", "", "", "", "", "", + "sar.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "ritto.shiga.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "m\303\245s\303\270y.no", + "", "", "", "", "", + "j.bg", + "", + "dyndns.org", + "", "", "", "", "", "", "", "", "", + "", "", + "buy", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "bayern", + "", "", "", + "jetzt", + "", "", "", + "shimonita.gunma.jp", + "", "", "", "", "", + "hemnes.no", + "", "", "", "", "", "", "", "", "", + "gle", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "carbonia-iglesias.it", + "", + "ntdll.top", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "abeno.osaka.jp", + "", "", "", "", "", "", "", "", "", + "tw", + "", "", "", "", + "tt", + "", "", "", "", + "to", + "", "", "", "", + "name.tr", + "", "", + "to.it", + "direct", + "", "", "", + "ts.it", + "", "", "", + "sanjo.niigata.jp", + "", "", "", "", "", "", + "\331\203\331\210\331\205", + "", "", "", "", "", "", + "top", + "", "", + "in-vpn.net", + "", "", "", + "ta.it", + "", "", "", "", "", "", "", "", "", + "", "", "", + "\331\205\331\210\331\202\330\271", + "", + "airtraffic.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "nym.lt", + "", + "\330\252\331\210\331\206\330\263", + "", "", "", "", "", "", "", "", "", + "", "", + "\330\263\331\210\330\257\330\247\331\206", + "", + "gouv.rw", + "", "", + "te.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "\346\267\241\351\251\254\351\224\241", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "dvrdns.org", + "", "", "", "", "", "", "", "", "", + "", "", "", + "co.technology", + "", "", + "money.museum", + "nabari.mie.jp", + "", "", "", "", "", "", + "ascolipiceno.it", + "", "", "", "", "", "", "", + "org.bb", + "", + "te.ua", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "tr", + "", "", "", "", "", "", "", + "tr.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "nationalfirearms.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "tc", + "", "", "", "", "", "", "", "", "", + "", "", + "usa.oita.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "dynamisches-dns.de", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "dynserv.org", + "", "", "", + "wodzislaw.pl", + "", "", "", "", "", "", "", "", "", + "", "", + "tatar", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "in-dsl.org", + "", "", "", "", "", "", "", "", "", + "bahccavuotna.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "github.io", + "", "", "", "", "", "", "", "", "", + "today", + "", "", "", "", "", "", "", "", "", + "", + "bas.it", + "uruma.okinawa.jp", + "", "", "", "", "", + "gunma.jp", + "directory", + "", "", "", "", "", + "gaular.no", + "", "", "", "", "", "", "", + "kumamoto.kumamoto.jp", + "", "", "", "", + "jio", + "t.se", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "toray", + "", + "music.museum", + "randaberg.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "movimiento.bo", + "hirokawa.fukuoka.jp", + "", "", "", "", + "blogsyte.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "trade", + "", "", "", "", "", "", "", "", + "suginami.tokyo.jp", + "", "", "", "", "", "", "", "", + "off", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "couchpotatofries.org", + "", "", "", "", "", "", "", + "modalen.no", + "", "", "", "", + "jmp", + "", "", "", "", "", "", "", "", "", + "tab", + "", "", "", "", "", "", "", "", "", + "fly", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "koeln", + "", + "heritage.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "kitayama.wakayama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "fujisato.akita.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "net.mt", + "", "", + "biei.hokkaido.jp", + "", "", "", "", + "tiaa", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "dev-myqnapcloud.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "com.mt", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "tires", + "fjell.no", + "", "", "", + "mihara.hiroshima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "bronnoy.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "tl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "redumbrella", + "dyn-berlin.de", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "tana.no", + "", "", "", "", "", "", "", "", "", + "", + "shijonawate.osaka.jp", + "", "", "", + "kamitsue.oita.jp", + "", "", "", "", "", "", "", "", + "is-an-accountant.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "kasukabe.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", + "total", + "", "", "", "", "", "", "", "", "", + "tunes", + "", + "tv", + "", "", "", "", "", "", "", + "tv.it", + "off.ai", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "kurobe.toyama.jp", + "", "", "", "", "", + "fujioka.gunma.jp", + "", "", "", "", "", + "fedorainfracloud.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "uji.kyoto.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "tube", + "", "", "", + "shell", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "ohira.miyagi.jp", + "", + "ebino.miyazaki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "tips", + "", "", "", "", "", + "brussels.museum", + "", + "stateofdelaware.museum", + "higashichichibu.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "szczecin.pl", + "", + "avellino.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "kembuchi.hokkaido.jp", + "", "", + "gouv.ht", + "", + "m\303\241tta-v\303\241rjjat.no", + "", "", "", "", "", + "dyndns.info", + "", "", "", + "edu.tt", + "", "", "", "", "", "", "", + "t.bg", + "workshop.museum", + "edu.st", + "tcp4.me", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "oguchi.aichi.jp", + "", + "cancerresearch", + "", "", "", "", "", "", "", "", + "tvs", + "", "", "", "", "", "", "", + "tattoo", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "tours", + "", "", "", "", "", "", "", "", "", + "", + "edu.et", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "hanggliding.aero", + "", "", "", "", "", + "time.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "kashima.ibaraki.jp", + "td", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "emr.it", + "", "", "", "", + "sic.it", + "", "", + "istanbul", + "", "", "", "", "", "", "", "", + "itv", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "\303\270yer.no", + "", "", + "net.gt", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "nom.gt", + "", "", "", "", "", "", "", + "sande.more-og-romsdal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "com.gt", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "nedre-eiker.no", + "", "", "", "", "", "", "", "", "", + "", "", + "nahari.kochi.jp", + "", "", "", + "antiques.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "minnesota.museum", + "", "", "", "", "", + "is-a-designer.com", + "", "", "", "", "", "", "", "", "", + "kobayashi.miyazaki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "ap-northeast-3.elasticbeanstalk.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "kashima.saga.jp", + "", "", "", "", "", "", + "trust", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "travel", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "ggee", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "ashiya.hyogo.jp", + "", "", + "hachijo.tokyo.jp", + "", "", "", "", "", "", "", + "saijo.ehime.jp", + "", "", "", "", "", "", + "agency", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "org.iq", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "dnsupdater.de", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "wloclawek.pl", + "", "", "", + "tm", + "", "", "", "", "", "", "", + "tt.im", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "edu.it", + "", "", "", "", "", "", "", + "kitahata.saga.jp", + "", "", "", "", "", + "venezia.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "kouhoku.saga.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "viterbo.it", + "", "", "", + "soeda.fukuoka.jp", + "wpdevcloud.com", + "", "", "", "", "", "", "", "", "", + "", "", "", + "ap-northeast-1.elasticbeanstalk.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "tech", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "shingu.hyogo.jp", + "", "", "", "", + "odessa.ua", + "", "", "", + "gob.es", + "", "", "", + "tm.ro", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "amagasaki.hyogo.jp", + "tm.fr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "k12.ks.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "artsandcrafts.museum", + "", "", "", "", + "tv.tr", + "", "", "", "", "", "", "", + "inabe.mie.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "gov.tw", + "name.tj", + "", "", "", "", "", "", "", "", "", + "", "", + "\346\226\260\345\212\240\345\235\241", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "tushu", + "", "", "", "", "", "", "", + "info.bo", + "miners.museum", + "", "", "", "", "", "", "", "", "", + "", + "tm.se", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "info.mv", + "", "", "", "", "", "", "", "", "", + "yura.wakayama.jp", + "", "", "", "", "", "", "", "", "", + "noboribetsu.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "travelers", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "firewall-gateway.de", + "", "", "", "", "", + "firewall-gateway.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "gov.rw", + "", "", "", "", + "kunstsammlung.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "eu.int", + "", "", "", + "kerryproperties", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "green", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "tg", + "", "", "", + "shizuoka.shizuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "azerbaijan.su", + "ing.pa", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "magazine.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "tv.sd", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "kotoura.tottori.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "merckmsd", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "ontario.museum", + "", "", "", "", "", "", "", "", "", + "s3.eu-west-3.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "tv.im", + "", "", "", "", "", "", "", "", + "shinjuku.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "kvitsoy.no", + "", "", "", "", "", "", "", + "tur.ar", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "chizu.tottori.jp", + "", "", "", + "kanzaki.saga.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "ikata.ehime.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "tm.za", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "firm.co", + "", "", "", "", "", "", "", + "aviation.museum", + "", + "servebbs.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "edu.mt", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "kamikitayama.nara.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "nuernberg.museum", + "", "", "", "", "", "", "", "", + "tunk.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "tn", + "univ.sn", + "", "", "", + "gonohe.aomori.jp", + "", "", + "tn.it", + "", "", "", "", "", "", "", "", "", + "iitate.fukushima.jp", + "", "", "", "", "", + "annefrank.museum", + "", + "kviteseid.no", + "", "", "", "", "", "", "", "", + "jp", + "", "", + "sandiego.museum", + "", "", + "gmx", + "", + "mansions.museum", + "", "", "", "", + "tn.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "higashiyama.kyoto.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "tm.hu", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "gratis", + "", "", "", "", "", "", + "in-berlin.de", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "mashiki.kumamoto.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "net.pt", + "", "", "", "", "", "", + "shimoichi.nara.jp", + "", "", "", "", "", + "tr.eu.org", + "", "", + "open", + "", "", "", "", "", + "kawanehon.shizuoka.jp", + "", "", "", "", "", "", "", "", + "s3-us-west-1.amazonaws.com", + "", "", "", "", "", + "morimachi.shizuoka.jp", + "", "", + "komatsushima.tokushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "is-an-anarchist.com", + "com.pt", + "gouv.sn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "b\303\270.nordland.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "os\303\270yro.no", + "", "", "", "", "", "", "", "", "", + "symantec", + "", "", "", + "kawagoe.mie.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "s3-eu-west-3.amazonaws.com", + "", + "k12.fl.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "accenture", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "ees3.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "go.jp", + "ino.kochi.jp", + "jprs", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "omachi.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "edu.gt", + "", + "tydal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "susono.shizuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "nym.pt", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "ina.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "gr.jp", + "", "", "", "", "", + "jjo", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "s3-eu-west-1.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "int.eu.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "kodaira.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "jeju.kr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "kuromatsunai.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "tm.km", + "", "", "", + "reggio-calabria.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "oi.kanagawa.jp", + "", "", "", + "gov.mw", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "js.cn", + "", "", "", "", "", + "saitama.saitama.jp", + "", "", "", + "inzai.chiba.jp", + "", + "tj", + "", + "nankoku.kochi.jp", + "", "", + "warszawa.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "test.ru", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "ybo.science", + "", "", "", "", "", "", "", "", "", + "nishiaizu.fukushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "geisei.kochi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "firewall-gateway.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "abudhabi", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "isa.kagoshima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "temasek", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "shima.mie.jp", + "", "", "", "", "", "", "", "", + "ingatlan.hu", + "", "", "", "", "", "", "", "", "", + "", "", "", + "tm.cy", + "", "", "", "", "", "", "", + "kudoyama.wakayama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "ooreadthedocs.io", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "gx.cn", + "", + "usarts.museum", + "", "", "", "", "", "", "", "", "", + "shimamoto.osaka.jp", + "", "", "", "", "", "", "", "", "", + "", + "tp.it", + "", "", "", "", "", "", "", "", "", + "", "", + "birthplace.museum", + "vpndns.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "targi.pl", + "", + "greta.fr", + "", "", "", "", "", "", + "aizubange.fukushima.jp", + "", + "ashoro.hokkaido.jp", + "", "", "", + "sky", + "", "", "", "", "", + "realm.cz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "training", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "quicksytes.com", + "", "", "", "", "", "", "", "", + "yaese.okinawa.jp", + "", "", "", "", "", + "read-books.org", + "", "", "", "", + "baseball.museum", + "", "", "", + "my-wan.de", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "tank.museum", + "", "", "", + "miura.kanagawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "air-traffic-control.aero", + "", "", "", "", "", "", + "net.bt", + "", "", "", "", "", "", "", "", + "rad\303\270y.no", + "mesaverde.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "office", + "", "", + "hobby-site.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "com.bt", + "", "", "", "", + "time.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "jl.cn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "in-vpn.org", + "", "", "", + "vic.gov.au", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "yamagata.jp", + "", "", "", "", "", "", "", "", + "midsund.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "jewishart.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "sdn.gov.pl", + "", "", "", "", "", "", + "yoichi.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "of.by", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "higashiizumo.shimane.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "firestone", + "", "", "", "", "", "", "", "", "", + "ruhr", + "", "", "", "", "", "", + "biz.tt", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "saga.saga.jp", + "", "", "", "", "", "", + "countryestate.museum", + "oregon.museum", + "", "", "", "", + "biz.at", + "", "", "", "", "", "", + "minamata.kumamoto.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "biz.et", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "shibecha.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "osteroy.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "tw.cn", + "", "", "", "", "", "", "", "", "", + "", "", + "otago.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "abr.it", + "", "", "", "", "", "", "", "", "", + "r\303\270mskog.no", + "", + "okayama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "tiffany", + "", "", "", "", "", + "org.zw", + "", + "tv.bo", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "tas.au", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "room", + "", "", + "averoy.no", + "honjyo.akita.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "ven.it", + "", "", "", "", "", "", "", "", "", + "", + "mmayfirst.info", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "tk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "ap-southeast-2.elasticbeanstalk.com", + "", "", "", "", "", + "contact", + "tirol", + "", "", "", "", "", "", "", + "eigersund.no", + "", "", "", "", "", "", + "tv.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "edu.pt", + "", "", "", "", "", "", "", "", + "utazas.hu", + "", "", "", "", "", "", "", "", "", + "", "", "", + "\346\276\263\351\226\200", + "", "", + "taobao", + "", "", "", "", "", "", "", "", "", + "", "", + "vestre-slidre.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "jgora.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "historichouses.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "maritimo.museum", + "kawagoe.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "flanders.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "akagi.shimane.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "tychy.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "jnj", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "bihoro.hokkaido.jp", + "", "", "", + "yao.osaka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "watarai.mie.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "tec.ve", + "", "", "", "", "", + "jur.pro", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "servebbs.com", + "", "", "", "", "", "", "", "", "", + "shintomi.miyazaki.jp", + "", "", "", "", "", "", "", "", "", + "org.sc", + "", "", "", "", "", "", "", + "security", + "", "", + "mragowo.pl", + "for-the.biz", + "", "", "", "", "", "", "", "", "", + "", "", "", + "org.ac", + "", "", "", "", + "georgia.su", + "", "", "", "", + "umaji.kochi.jp", + "", "", "", "", + "jpn.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "maritime.museum", + "", "", "", "", "", "", + "org.ec", + "", "", "", "", "", + "vao.it", + "", "", "", "", "", "", + "zamami.okinawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "nesoddtangen.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "meraker.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "firm.ht", + "", "", "", "", "", "", + "is-very-bad.org", + "", "", "", "", "", "", "", "", + "shiso.hyogo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "health.vn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "marburg.museum", + "", + "jp.eu.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "vda.it", + "", "", "", "", "", "", + "healthcare", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "beeldengeluid.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "net.ht", + "", "", "", "", "", "", "", + "nisshin.aichi.jp", + "karmoy.no", + "", "", "", "", "", "", + "ozu.kumamoto.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "com.ht", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "hirara.okinawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "se.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "nesseby.no", + "", "", "", "", "", "", "", + "art.ht", + "", "", "", "", "", "", + "turin.it", + "kaizuka.osaka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "iwaki.fukushima.jp", + "", "", "", "", "", "", "", "", "", + "", + "applicationcloud.io", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "architecture.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "nozawaonsen.nagano.jp", + "", "", + "withgoogle.com", + "", "", "", "", "", "", "", "", "", + "", "", + "dupont", + "", "", "", "", "", "", "", "", + "bialowieza.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "minamiizu.shizuoka.jp", + "", "", "", "", "", "", "", "", + "\303\270ystre-slidre.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "tra.kp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "barrel-of-knowledge.info", + "", "", "", "", "", "", "", + "org.lc", + "", "", "", "", "", "", "", "", + "jor.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "za.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "rishirifuji.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "trading", + "", "", "", "", + "org.vc", + "", "", "", "", "", + "olbia-tempio.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "arakawa.saitama.jp", + "", "", + "zuerich", + "ragusa.it", + "", "", "", "", "", "", "", "", "", + "", + "edu.bt", + "", "", "", + "fidelity", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "ochi.kochi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "alto-adige.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "kasugai.aichi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "heroy.more-og-romsdal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "!city.kobe.jp", + "", "", "", + "accident-investigation.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "yanagawa.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "ostroda.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "higashiyoshino.nara.jp", + "", "", "", "", "", "", + "school.nz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "myddns.rocks", + "", "", "", "", "", "", "", "", "", + "tgory.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", + "jab.br", + "", "", "", "", "", "", "", + "cust.disrec.thingdust.io", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "ivano-frankivsk.ua", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "gjerdrum.no", + "", "", "", + "shirakawa.fukushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "of.no", + "ito.shizuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "inatsuki.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "tr.no", + "", "", "", "", "", "", "", "", "", + "rwe", + "", + "arezzo.it", + "klodzko.pl", + "", "", "", "", + "rovno.ua", + "", "", "", "", "", "", "", "", + "th", + "thd", + "", "", "", "", "", "", "", "", + "bible.museum", + "tci", + "", "", "", "", "", "", "", "", "", + "", + "cloudns.biz", + "", "", "", "", "", "", "", "", "", + "", "", + "jus.br", + "", "", "", "", "", + "gangwon.kr", + "", "", "", "", "", "", "", "", "", + "omaha.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "gov.sy", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "gf", + "", "", "", "", "", "", "", "", "", + "", "", "", + "arakawa.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "mihama.wakayama.jp", + "", + "okuizumo.shimane.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "gov.kw", + "", "", + "koto.shiga.jp", + "", "", "", "", "", "", "", "", "", + "", + "oseto.nagasaki.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "shimokawa.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "tui", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "minamiise.mie.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "gov.cy", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "kawamata.fukushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "kumano.mie.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "masfjorden.no", + "", "", "", "", + "cn-north-1.eb.amazonaws.com.cn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "kwp.gov.pl", + "", "", "", "", "", "", "", "", + "jewelry", + "rauma.no", + "", "", "", + "\345\214\227\346\265\267\351\201\223.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "moseushi.hokkaido.jp", + "", "", "", "", "", "", + "yaizu.shizuoka.jp", + "", + "horonobe.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "is-a-bookkeeper.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "microlight.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "roma.it", + "", "", "", "", + "rome.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "sebastopol.ua", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "trd.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "tv.na", + "", "", "", "", "", "", "", "", "", + "", + "gojome.akita.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "rivne.ua", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "chigasaki.kanagawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "bungotakada.oita.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "myshopblocks.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "gov.sb", + "", "", "", "", "", "", "", "", + "vegarshei.no", + "", "", "", "", "", "", + "sande.vestfold.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "gov.ly", + "", "", "", + "higashiyodogawa.osaka.jp", + "gov.zm", + "", "", "", "", "", "", "", "", + "sowa.ibaraki.jp", + "", "", "", "", "", "", "", "", "", + "", + "jdf.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "yomitan.okinawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "naples.it", + "", "", "", "", "", "", + "munakata.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "tur.br", + "", "", "", "", + "oppegard.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "is-a-photographer.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "edu.ht", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "biella.it", + "", "", "", "", "", "", "", "", + "soundandvision.museum", + "", "", "", "", "", "", "", "", "", + "", "", + "r\303\246lingen.no", + "", "", + "gov.za", + "", "", "", "", + "hermes", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "hobby-site.com", + "", "", "", "", "", "", "", "", "", + "", + "asakuchi.okayama.jp", + "", "", "", "", "", "", + "tinn.no", + "", + "furniture", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "hu.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "christmas", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "chikuma.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "memorial.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "juniper", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "tachikawa.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "tm.no", + "", "", "", "", "", + "abbott", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "quebec", + "", "", "", "", "", "", "", + "teo.br", + "", "", "", "", "", "", "", "", "", + "", "", + "yuasa.wakayama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "gov.lb", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "ybo.trade", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "chuo.chiba.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "realty", + "", "", "", "", "", + "turek.pl", + "", "", "", "", "", "", "", "", "", + "", "", + "xxx", + "", "", "", "", + "tj.cn", + "", + "user.party.eus", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "nonoichi.ishikawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "gov.my", + "", "", "", "", "", "", "", "", "", + "", "", + "bryne.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "ieee", + "", "", "", "", + "svalbard.no", + "olecko.pl", + "", + "town", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "fribourg.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", + "obama.nagasaki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "\303\270rland.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "ap-northeast-2.elasticbeanstalk.com", + "", + "ice", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "finland.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "higashikawa.hokkaido.jp", + "friuli-venezia-giulia.it", + "", "", "", "", "", "", + "akiruno.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "westfalen.museum", + "", "", "", + "kouzushima.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "montreal.museum", + "", "", "", + "express", + "", "", "", "", "", "", "", "", "", + "", + "yasuoka.nagano.jp", + "", "", "", "", "", "", "", "", + "shirako.chiba.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "inder\303\270y.no", + "", "", "", "", "", "", "", "", "", + "", "", + "sko.gov.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "fujikawaguchiko.yamanashi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "kouyama.kagoshima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "tmp.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "shimamaki.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "servebbs.org", + "", "", "", "", "", + "trana.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "edogawa.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "miharu.fukushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "gov.gy", + "", "", "", "", "", "", "", "", "", + "", "", "", + "twmail.cc", + "", "", "", "", "", "", "", "", + "aurland.no", + "", + "inashiki.ibaraki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "kitakata.fukushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "myravendb.com", + "", "", "", "", "", "", + "ina.ibaraki.jp", + "", "", "", "", + "nokia", + "idv.hk", + "", "", "", + "co.pw", + "", "", "", "", "", "", "", + "spreadbetting", + "", "", "", "", "", "", "", "", "", + "kuwana.mie.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "ne.pw", + "", "", "", "", "", "", "", "", "", + "", + "oshima.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "aarp", + "", "", "", "", "", "", "", "", "", + "", "", + "tingvoll.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "market", + "markets", + "", "", "", "", "", "", "", + "unazuki.toyama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "rehab", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "net.af", + "", "", "", "", "", "", "", "", "", + "jefferson.museum", + "", "", "", "", + "nom.af", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "juif.museum", + "", "", "", "", "", "", "", "", "", + "", "", + "kvinesdal.no", + "", "", "", "", "", + "camp", + "", "", "", "", "", "", "", "", "", + "", "", + "com.af", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "education", + "ac.pa", + "", + "gs.sf.no", + "", "", "", + "yamagata.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "baghdad.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "yamagata.ibaraki.jp", + "", "", "", + "mar.it", + "", "", "", "", "", "", "", "", "", + "yatsuka.shimane.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "mitsuke.niigata.jp", + "", "", "", "", + "is-a-caterer.com", + "", "", "", "", "", + "commune.am", + "", "", "", "", "", "", "", + "ac.pr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "georgia.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "s3.eu-west-2.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "review", + "reviews", + "", "", "", "", "", "", "", "", + "friuli-veneziagiulia.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "travel.tt", + "", "", "", "", "", "", "", + "gs.vf.no", + "", "", "", "", "", "", "", "", "", + "", + "suzuka.mie.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "voyage", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "uenohara.yamanashi.jp", + "", "", "", "", "", + "travel.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "nike", + "", + "gateway.museum", + "", + "karlsoy.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "name.az", + "", "", "", "", "", "", "", + "misconfused.org", + "", "", "", "", "", "", "", "", + "ap-south-1.elasticbeanstalk.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "uk0.bigv.io", + "", "", "", + "terni.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "ryuoh.shiga.jp", + "", "", + "travelersinsurance", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "uchinomi.kagawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "s3-us-west-2.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "", "", "", + "co.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "grosseto.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "sakura", + "", "", "", "", "", "", "", "", "", + "", + "charity", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "doomdns.org", + "", "", "", "", "", "", + "tv.bb", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "nh-serv.co.uk", + "reggio-emilia.it", + "", "", "", "", "", "", "", "", "", + "", "", + "coop", + "", "", "", "", + "kuroishi.aomori.jp", + "", "", "", "", "", "", "", + "org.ws", + "kaszuby.pl", + "", "", "", "", "", "", "", + "trader.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "windmill.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "shunan.yamaguchi.jp", + "", + "org.es", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "komono.mie.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "tec.mi.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "org.rs", + "", "", "", "", "", "", "", "", "", + "", "", "", + "ooshika.nagano.jp", + "", "", "", "", + "watchandclock.museum", + "", "", + "cc.pa.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "uchihara.ibaraki.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "s3-eu-west-2.amazonaws.com", + "", "", "", "", "", "", + "bike", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "tomi.nagano.jp", + "kadena.okinawa.jp", + "", "", "", "", "", "", "", "", "", + "ed.pw", + "", + "website", + "", "", "", + "coupon", + "coupons", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "shikama.miyagi.jp", + "kasahara.gifu.jp", + "", "", "", + "forl\303\254cesena.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "northwesternmutual", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "cc.pr.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "jerusalem.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "ogimi.okinawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "froland.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "swiftcover", + "", "", + "katsushika.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "no-ip.biz", + "", "", + "is-a-cpa.com", + "", "", "", "", "", "", + "comcast", + "", "", "", "", + "dentist", + "", "", "", "", "", "", "", "", "", + "", "", "", + "niimi.okayama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "afjord.no", + "", "", "", "", + "vladikavkaz.su", + "", "", "", "", "", "", "", "", "", + "vladikavkaz.ru", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "judygarland.museum", + "", "", + "artdeco.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "org.is", + "", + "brescia.it", + "", "", + "kamijima.ehime.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "chichibu.saitama.jp", + "", "", "", "", "", + "missoula.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "gov.py", + "", "", "", + "overhalla.no", + "", "", + "aol", + "", "", "", "", "", "", "", "", "", + "", "", + "kosuge.yamanashi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "m\303\245lselv.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "kr\303\245anghke.no", + "", "", "", + "org.ls", + "", "", "", + "okayama.okayama.jp", + "", + "cal", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "isa.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "iizuka.fukuoka.jp", + "", "", "", "", + "higashiyamato.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "ebina.kanagawa.jp", + "shirosato.ibaraki.jp", + "", "", "", "", + "transport.museum", + "", "", "", "", "", "", "", + "cookingchannel", + "", + "net.sg", + "", "", + "c.la", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "mydrobo.com", + "", + "net.ag", + "", + "boavista.br", + "", "", + "blockbuster", + "", "", "", "", "", "", "", "", "", + "nom.ag", + "", "", "", + "nagato.yamaguchi.jp", + "", "", "", + "nesset.no", + "", "", "", "", "", "", "", "", "", + "\350\214\250\345\237\216.jp", + "", + "com.sg", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "net.eg", + "", "", "", "", "", "", "", "", "", + "com.ag", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "figueres.museum", + "kvalsund.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "com.eg", + "", "", "", "", "", "", + "funagata.yamagata.jp", + "", "", + "tonsberg.no", + "onjuku.chiba.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "higashiizu.shizuoka.jp", + "", "", "", "", + "sale", + "", "", "", "", "", "", + "furniture.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "minamiboso.chiba.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "iide.yamagata.jp", + "from-me.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "iveco", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "skole.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "srl", + "kashiwa.chiba.jp", + "", "", "", "", "", "", "", + "atami.shizuoka.jp", + "", "", "", "", "", "", "", + "kitashiobara.fukushima.jp", + "", "", "", "", + "solar", + "", "", "", + "shonai.yamagata.jp", + "", + "tashkent.su", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "fussa.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "campinas.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "official.academy", + "", "", "", "", "", + "freesite.host", + "", "", "", "", "", "", "", + "app.os.fedoraproject.org", + "edu.af", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "narusawa.yamanashi.jp", + "", + "jondal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "nom.ug", + "", "", "", "", "", "", "", "", + "rieti.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "com.ug", + "", "", "", "", "", "", "", "", "", + "", + "sola.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "setouchi.okayama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "scientist.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "asker.no", + "", "", "", "", "", + "dclk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "ally", + "", "", "", "", "", "", "", "", "", + "", "", + "jessheim.no", + "", "", "", "", "", "", "", "", "", + "gorge.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "diskstation.me", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "yamatotakada.nara.jp", + "", + "oketo.hokkaido.jp", + "", "", "", "", "", + "eun.eg", + "", "", "", "", "", "", + "isa-hockeynut.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "org.ms", + "", "", "", "", + "gs.oslo.no", + "", "", "", "", "", "", "", "", "", + "", "", + "florist", + "", + "gov.ky", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "yamamoto.miyagi.jp", + "", "", "", "", + "nom.vg", + "", "", "", "", "", "", "", "", "", + "zhytomyr.ua", + "", "", "", "", "", "", "", "", "", + "naval.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "mihara.kochi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "iwanai.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "frl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "travelchannel", + "", "", "", "", "", "", "", "", + "sula.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "feifuturehosting.at", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "s3-website.ap-south-1.amazonaws.com", + "", + "compare", + "", "", "", "", "", "", "", "", "", + "uhren.museum", + "", "", "", "", "", "", "", "", + "myphotos.cc", + "", + "agric.za", + "", + "co.pn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "silk", + "", + "town.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "aukra.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "gov.by", + "", "", "", "", "", "", "", "", "", + "", "", + "wsa.gov.pl", + "", + "tcm.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", + "supplies", + "", + "delta", + "", "", "", "", "", + "mashiko.tochigi.jp", + "", "", "", "", "", "", "", "", "", + "net.nf", + "", "", "", "", + "glass.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "suli.hu", + "", "", "", + "mihama.fukui.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "com.nf", + "", "", + "statefarm", + "", "", "", "", "", "", "", "", + "ureshino.mie.jp", + "", "", "", "", "", "", + "americanantiques.museum", + "", "", "", "", "", "", "", "", "", + "", + "higashi.okinawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "\346\226\260\346\275\237.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "coop.km", + "", + "\345\272\203\345\263\266.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "wielun.pl", + "", "", "", + "kitagawa.miyazaki.jp", + "", "", "", "", "", "", + "katsuyama.fukui.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "jambyl.su", + "", "", "", "", "", "", "", "", "", + "kameoka.kyoto.jp", + "", "", "", "", "", "", "", "", + "jewish.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "yoshino.nara.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "matsudo.chiba.jp", + "", "", "", "", + "s3-website-ap-southeast-1.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "gj\303\270vik.no", + "", "", "", + "idv.tw", + "", "", "", "", "", "", + "belau.pw", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "reggiocalabria.it", + "", "", "", "", "", "", "", "", "", + "", "", "", + "ttttuxfamily.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "info.co", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "mihama.aichi.jp", + "", "", "", "", "", "", + "misugi.mie.jp", + "", "", "", + "gobo.wakayama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "fffm", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "nom.mg", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "com.mg", + "", "", "", "", "", "", "", "", "", + "shimodate.ibaraki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "gs.of.no", + "educator.aero", + "", "", + "education.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "youth.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "kazo.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "gov.bb", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "fuchu.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "storage", + "tenri.nara.jp", + "\346\240\203\346\234\250.jp", + "", "", "", "", "", "", "", + "amli.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "stalbans.museum", + "", "", "", "", "", "", "", "", "", + "", + "\346\226\260\351\227\273", + "", "", "", "", + "denmark.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "bolt.hu", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "for-better.biz", + "kawakita.ishikawa.jp", + "yaita.tochigi.jp", + "", "", "", "", "", "", + "edu.sg", + "", "", "", "", "", "", + "wif.gov.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "askim.no", + "", "", "", "", "", "", "", "", + "is-a-blogger.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "ternopil.ua", + "", "", "", "", "", + "ibara.okayama.jp", + "", "", "", "", "", "", "", "", "", + "", + "mup.gov.pl", + "", "", "", "", "", "", "", + "edu.eg", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "nagaoka.niigata.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "hole.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "net.gg", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "company", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "farmers.museum", + "", "", "", "", "", "", "", "", "", + "", + "imperia.it", + "", "", "", "", + "jan-mayen.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "contagem.br", + "", "", "", "", "", "", + "yamakita.kanagawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "twmail.net", + "", "", + "\340\270\255\340\270\207\340\270\204\340\271\214\340\270\201\340\270\243.\340\271\204\340\270\227\340\270\242", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "salat.no", + "", "", "", "", "", "", "", + "com.pf", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "shika.ishikawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "s3-website.eu-central-1.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "cya.gg", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "bel.tr", + "", "", "", "", "", "", "", "", "", + "", "", + "americana.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "matsushima.miyagi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "mimata.miyazaki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "half.host", + "", "", "", "", "", "", "", "", "", + "", "", "", + "fujieda.shizuoka.jp", + "mein-iserv.de", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "aizumisato.fukushima.jp", + "", "", + "chernivtsi.ua", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "chikusei.ibaraki.jp", + "", "", "", "", "", + "toba.mie.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "doomdns.com", + "", "", "", "", "", "", "", + "yoshimi.saitama.jp", + "", + "balat.no", + "yasu.shiga.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "\303\245l.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "ebetsu.hokkaido.jp", + "", "", "", "", + "net.ng", + "", "", "", "", "", + "staples", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "otsu.shiga.jp", + "", + "com.ng", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "detroit.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "sogndal.no", + "", "", "", "", "", "", "", "", "", + "", + "shitara.aichi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "int.is", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "dating", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "asso.fr", + "", "", "", "", "", "", "", "", "", + "", "", + "ujiie.tochigi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "oceanographique.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "0appspot.com", + "", "", "", + "sel.no", + "eu-3.evennode.com", + "", "", "", "", + "eu-4.evennode.com", + "", "", "", "", + "defense.tn", + "", "", "", "", + "eu-1.evennode.com", + "", "", "", "", "", "", "", "", "", + "komae.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "certification.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "americanart.museum", + "", "", "", "", "", "", "", + "from-ks.com", + "", "", "", "", "", "", "", "", "", + "", + "cooperativa.bo", + "", "", "", "", "", "", "", "", "", + "", "", "", + "org.ps", + "from-ms.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "from-mo.com", + "", "", "", "", + "from-ok.com", + "", + "viajes", + "", "", "", "", "", "", "", "", "", + "", "", "", + "torino.museum", + "", + "gov.iq", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "teramo.it", + "", "", "", + "bnl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "from-ma.com", + "", "", "", "", "", + "rovigo.it", + "", "", "", "", "", + "obama.fukui.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "fukui.jp", + "", "", "", "", "", "", "", "", + "flights", + "", "", "", "", "", + "convent.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "mishima.shizuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "from-mn.com", + "", "", "", "", "", + "kimobetsu.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "maibara.shiga.jp", + "", + "oxford.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "avocat.pro", + "", + "gausdal.no", + "", "", "", "", "", "", + "gaivuotna.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "umb.it", + "", "", "", "", "", "", + "from-ak.com", + "", "", "", "", + "oyabe.toyama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "tateyama.toyama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "flynnhub.com", + "", "", "", "", "", "", "", "", "", + "", + "from-ia.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "radio.br", + "oceanographic.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "gitlab.io", + "elk.pl", + "", "", "", "", "", "", "", "", + "cheltenham.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "gotdns.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "tysvar.no", + "", "", "", "", "", "", "", "", + "from-in.com", + "", "", "", "", "", "", "", + "dali.museum", + "", "", "", "", "", "", "", "", "", + "edu.mg", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "wiw.gov.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "iijima.nagano.jp", + "", "", "", "", "", "", "", "", + "ae.org", + "higashinaruse.akita.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "style", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "tr\303\246na.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "eu-2.evennode.com", + "", "", "", "", + "coop.py", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "co.place", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "asso.gp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "\344\270\255\346\226\207\347\275\221", + "spy.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "s3-website-ap-northeast-1.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "from-oh.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "mielno.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "bale.museum", + "", + "from-ne.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "from-or.com", + "", "", "", "", "", "", "", "", "", + "", "", "", + "securitytactics.com", + "", "", "", "", "", "", "", "", "", + "", "", "", + "otama.fukushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "elverum.no", + "", "", "", "", "", "", "", "", "", + "kannami.shizuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "oystre-slidre.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "from-nh.com", + "", "", "", "", "", "", "", + "eu.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "from-pa.com", + "cloudns.pw", + "", "", "", "", "", "", "", "", + "iwaizumi.iwate.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "machida.tokyo.jp", + "", "", + "is-a-cubicle-slave.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "kadogawa.miyazaki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "diskstation.org", + "", "", "", "", "", "", "", "", "", + "", + "za.org", + "", "", "", "", "", "", + "from-ar.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "shobara.hiroshima.jp", + "torino.it", + "", "", "", "", "", "", "", "", "", + "", "", + "campania.it", + "", "", "", "", + "\346\205\210\345\226\204", + "", "", "", "", "", "", "", "", "", + "", "", + "askoy.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "edu.pf", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "org.bs", + "", + "ostrowwlkp.pl", + "", "", "", + "halsa.no", + "", "", "", "", "", "", "", "", "", + "", + "info.ht", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "bmoattachments.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "groks-the.info", + "tz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "oto.fukuoka.jp", + "", "", "", "", + "solutions", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "bremanger.no", + "", "", "", "", "", + "ogawara.miyagi.jp", + "", + "erotica.hu", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "silk.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "info.at", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "balsan-sudtirol.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "granvin.no", + "", "", "", + "sardegna.it", + "", "", "", "", "", "", "", "", "", + "med.ht", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "ufcfan.org", + "", "", "", "", "", "", "", "", "", + "", + "hol.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "ybo.faith", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "serveexchange.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "servegame.com", + "", "", "", "", "", "", "", "", + "gwangju.kr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "from-mi.com", + "", "", "", "", "", "", "", "", + "goiania.br", + "", "", "", "", "", "", "", "", "", + "", "", + "chiyoda.gunma.jp", + "", "", + "kushiro.hokkaido.jp", + "", "", "", "", "", "", "", "", + "edu.ng", + "", "", "", "", + "voagat.no", + "", + "tobishima.aichi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "kfh", + "", "", + "forli-cesena.it", + "", "", "", "", "", "", "", + "events", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "from-pr.com", + "", "", "", "", "", "", "", "", "", + "from-hi.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "kita.tokyo.jp", + "", "", "", "", + "kisofukushima.nagano.jp", + "", "", "", + "\303\245krehamn.no", + "", "", "", "", "", "", "", "", "", + "", + "nhk", + "", "", "", "", "", "", "", "", "", + "", "", "", + "net.kg", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "com.kg", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "aizuwakamatsu.fukushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "bulsan-sudtirol.it", + "", "", "", + "arai.shizuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "tateyama.chiba.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "able", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "ube.yamaguchi.jp", + "", "", "", "", + "if.ua", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "nikon", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "starostwo.gov.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "ifm", + "", "", "", "", "", "", "", "", + "troandin.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "donetsk.ua", + "", "", "", "", "", "", "", "", "", + "", "", + "k12.ct.us", + "building.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "from-nm.com", + "", "", "", "", "", "", "", + "stuttgart.museum", + "", "", + "chiyoda.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "iwata.shizuoka.jp", + "", "", "", "", "", "", "", "", "", + "", + "entertainment.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "honbetsu.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", + "jaguar", + "", "", "", "", "", "", "", "", "", + "baltimore.museum", + "", "", "", "", "", "", + "birdart.museum", + "", "", "", "", "", "", "", "", "", + "", "", + "tools", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "farmequipment.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "volvo", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "noip.me", + "", "", + "numazu.shizuoka.jp", + "", "", "", "", "", "", "", "", "", + "", + "kawanabe.kagoshima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "k12.ut.us", + "", "", + "haibara.shizuoka.jp", + "olsztyn.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "nobeoka.miyazaki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "\303\270ygarden.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "from-nc.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "tosa.kochi.jp", + "", "", "", "", "", "", "", "", + "kiwi.nz", + "", "", "", "", "", "", "", "", "", + "matsuda.kanagawa.jp", + "", "", "", "", "", "", + "agrinet.tn", + "", "", "", "", "", "", "", "", "", + "", "", "", + "bokn.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "fvg.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "tado.mie.jp", + "", "", "", "", "", "", + "u2.xnbay.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "yatsushiro.kumamoto.jp", + "", "", "", "", "", "", "", "", "", + "divttasvuotna.no", + "", "", "", "", + "kishiwada.osaka.jp", + "", "", "", "", "", "", "", "", + "iizuna.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "fineart.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "kharkov.ua", + "", "", "", "", "", + "k12.vt.us", + "", "", "", + "cherkasy.ua", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "timekeeping.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "avocat.fr", + "", "", "", "", "", "", + "ccupcake.is", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "usculture.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "bugatti", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "shop", + "", "", "", "", "", + "shimonoseki.yamaguchi.jp", + "", "", "", "", "", "", + "oishida.yamagata.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "kharkiv.ua", + "", "", "", "", + "from-nj.com", + "", "", "", "", "", "", "", "", "", + "hino.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", + "marketing", + "", "", "", + "yahiko.niigata.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "tv.tz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "dielddanuorri.no", + "", "", "", "", "", "", "", + "toshiba", + "", "", "", "", + "ono.fukui.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "odawara.kanagawa.jp", + "", "", "", "", "", "", "", "", "", + "", + "scapp.io", + "higashishirakawa.gifu.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "gov.zw", + "", "", "", "", "", "", "", "", + "bnpparibas", + "", "", "", "", "", "", "", "", "", + "", "", + "chofu.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "salon", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "wassamu.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "cologne", + "", "", "", "", "", + "kashiba.nara.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "twmail.org", + "", "", "", "", "", "", "", "", + "k12.mt.us", + "", "", "", + "vik.no", + "itoigawa.niigata.jp", + "", "", "", + "from-ri.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "from-ky.com", + "", "", "", + "shop.hu", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "kitakata.miyazaki.jp", + "", "", "", "", "", "", + "oksnes.no", + "", + "noda.iwate.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "gorizia.it", + "fujixerox", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "drammen.no", + "dhl", + "", "", "", "", "", "", "", "", + "dreamhosters.com", + "", "", "", "", "", "", + "vinnytsia.ua", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "nationwide", + "tmall", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "selbu.no", + "", "", "", "", "", "", "", "", "", + "is-gone.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "holiday", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "sci.eg", + "", "", "", "", "", "", "", "", + "hayashima.okayama.jp", + "unnan.shimane.jp", + "", "", "", "", "", "", "", "", "", + "edu.kg", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "s3-website.ca-central-1.amazonaws.com", + "", "", "", "", "", + "cloudfunctions.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "gov.sc", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "augustow.pl", + "kommune.no", + "", "", + "gov.ac", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "oum.gov.pl", + "", "", "", "", "", "", "", + "qsl.br", + "", "", "", "", "", "", "", "", "", + "hjelmeland.no", + "", "", + "okutama.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", + "gov.ec", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "naamesjevuemie.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "indiana.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "balsan-s\303\274dtirol.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "valdaosta.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "volda.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "tendo.yamagata.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "hamamatsu.shizuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "from-al.com", + "", "", "", + "eu-west-3.elasticbeanstalk.com", + "from-il.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "sa-east-1.elasticbeanstalk.com", + "", "", "", "", "", "", "", "", "", + "", + "is-a-candidate.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "gotdns.ch", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "byen.site", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "essex.museum", + "", "", + "yono.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "dscloud.mobi", + "", "", "", "", "", "", "", "", + "bulsan-s\303\274dtirol.it", + "", + "yoshida.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "iki.nagasaki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "higashikurume.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "edunet.tn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "voting", + "", + "gov.lc", + "", "", "", "", "", + "draydns.de", + "", "", "", "", "", + "eu-west-1.elasticbeanstalk.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "dyndns.biz", + "", + "akabira.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "omitama.ibaraki.jp", + "mayfirst.org", + "", "", "", "", "", "", "", + "gov.vc", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "r\303\270d\303\270y.no", + "", + "info.et", + "", "", "", "", "", "", + "salvador.br", + "", "", "", "", "", "", + "koto.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "mihama.chiba.jp", + "", "", "", "", + "iruma.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "ginowan.okinawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "shikokuchuo.ehime.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "m\304\201ori.nz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "shinichi.hiroshima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "info.cx", + "", + "is-very-sweet.org", + "", "", "", "", "", "", "", "", + "helsinki", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "holtalen.no", + "", "", "", "", "", "", "", "", "", + "kanazawa.ishikawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "tateshina.nagano.jp", + "", "", "", "", + "ohira.tochigi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "journalism.museum", + "", + "berkeley.museum", + "", "", "", "", + "wiki", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "shop.ro", + "", "", "", "", "", "", + "analytics", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "s3-website-ap-southeast-2.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "holdings", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "educational.museum", + "caxias.br", + "", "", "", "", "", "", "", "", "", + "", "", + "dagestan.su", + "", "", "", "", "", "", "", "", "", + "dagestan.ru", + "", "", + "aver\303\270y.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "volyn.ua", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "hino.tottori.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "aoki.nagano.jp", + "", "", "", + "cloudns.info", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "mashike.hokkaido.jp", + "", "", "", + "christiansburg.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "slupsk.pl", + "quebec.museum", + "", + "nord-fron.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "servequake.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "nishitosa.kochi.jp", + "", + "mito.ibaraki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "rennes\303\270y.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "cable-modem.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "svizzera.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "miyashiro.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "trondheim.no", + "", "", "", "", "", "", "", "", "", + "", "", "", + "urasoe.okinawa.jp", + "", "", + "servegame.org", + "", "", "", "", "", "", "", "", "", + "", "", + "infiniti", + "", "", "", + "okazaki.aichi.jp", + "", "", + "s\303\270r-fron.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "is-a-socialist.com", + "", "", "", "", "", "", "", + "dyn-vpn.de", + "asso.dz", + "", "", "", "", + "sayama.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "incheon.kr", + "", "", "", + "consultant.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", + "onojo.fukuoka.jp", + "", "", "", "", + "saku.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "is-a-celticsfan.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "ogaki.gifu.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "tsuno.kochi.jp", + "", "", "", "", "", "", "", "", "", + "kahoku.ishikawa.jp", + "", "", "", + "ketrzyn.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "steam.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "karm\303\270y.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "shimokitayama.nara.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "ichinohe.iwate.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "shinjo.yamagata.jp", + "", "", "", "", "", "", "", "", "", + "skedsmo.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "tj\303\270me.no", + "", "", "", "", + "nannestad.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "wales", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "r\303\270ros.no", + "", "", "", "", "", "", + "ono.fukushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "noip.us", + "", "", "", "", "", "", "", "", "", + "", "", + "rahkkeravju.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "java", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "barsycenter.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "teaches-yoga.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "thruhere.net", + "", "", "", "", "", "", "", "", "", + "sn\303\245ase.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "teshikaga.hokkaido.jp", + "", "", "", + "otsuki.yamanashi.jp", + "", "", "", "", "", + "makeup", + "", "", "", "", "", "", "", "", "", + "", "", + "sayo.hyogo.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "gotdns.org", + "", "", "", + "sakai.osaka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "ui.nabu.casa", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "j\303\270rpeland.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "fukushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "exeter.museum", + "", "", "", + "science.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "tomigusuku.okinawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "umi.fukuoka.jp", + "", "", + "fuji.shizuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "s3-website.ap-northeast-2.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "museet.museum", + "", "", "", "", "", "", "", "", "", + "b\303\241hccavuotna.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "taiki.hokkaido.jp", + "", "", "", "", "", + "from-md.com", + "", "", "", "", "", + "okuma.fukushima.jp", + "", "", "", "", "", "", "", "", "", + "", + "nasu.tochigi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "federation.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "awaji.hyogo.jp", + "", "", "", "", "", "", + "evenassi.no", + "", "", "", "", "", "", + "navuotna.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "steigen.no", + "", "", + "sakaiminato.tottori.jp", + "", "", "", "", "", "", "", "", + "iwama.ibaraki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "yahaba.iwate.jp", + "", + "from-nd.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "cust.testing.thingdust.io", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "minokamo.gifu.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "tozsde.hu", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "from-id.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "fujikawa.yamanashi.jp", + "", "", "", "", "", "", "", "", "", + "empresa.bo", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "nieruchomosci.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "from-de.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "casacam.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "filegear.me", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "mobi.gp", + "", "", "", "", "", "", "", + "forgot.her.name", + "", "", "", "", "", "", "", "", "", + "", "", "", + "mil", + "", "", "", "", "", "", "", "", "", + "control.aero", + "", "", + "uchinada.ishikawa.jp", + "", "", "", "", "", "", "", "", "", + "", + "kutchan.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "memset.net", + "", "", "", + "myftp.biz", + "", "", "", "", "", "", "", + "egersund.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "mil.tm", + "", "", "", "", "", "", "", "", "", + "mil.to", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "shakotan.hokkaido.jp", + "", "", "", "", + "pw", + "", "", "", "", + "pt", + "", "", "", "", "", "", "", + "pt.it", + "", + "ps", + "", "", + "po.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "hk.org", + "", "", "", + "pa", + "", "", "", "", "", "", "", + "pa.it", + "", "", "", "", "", "", + "gotsu.shimane.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "\330\247\331\204\331\205\330\272\330\261\330\250", + "mil.sh", + "", "", "", "", "", + "\330\247\331\204\330\254\330\262\330\247\330\246\330\261", + "", "", "", "", "", "", "", "", + "towada.aomori.jp", + "", + "pa.us", + "", + "pe", + "", "", "", "", "", "", "", + "pe.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "paris", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "\330\247\331\204\331\212\331\205\331\206", + "", "", "", "", "", "", "", "", "", + "", "", "", + "pet", + "", + "teva", + "", "", + "dnshome.de", + "", "", "", "", "", "", "", "", "", + "", + "\321\200\321\204", + "", "", "", "", "", "", "", "", "", + "", "", "", + "pr", + "", "", "", "", + "shiiba.miyazaki.jp", + "", + "harvestcelebration.museum", + "pr.it", + "", "", + "mil.co", + "", "", "", "", "", "", "", "", "", + "", "", "", + "net.az", + "", + "szczytno.pl", + "h\303\270nefoss.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "enebakk.no", + "", "", "", + "pr.us", + "", "", "", "", "", + "v\303\241rgg\303\241t.no", + "", "", + "trv", + "pc.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "com.az", + "", "", "", "", "", "", + "calvinklein", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "whaling.museum", + "", "", "", "", "", + "cahcesuolo.no", + "", "", "", "", "", "", + "\330\247\331\204\330\247\330\261\330\257\331\206", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "py", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "muroran.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "mil.cn", + "", "", "", "", "", + "p.se", + "", "", "", "", "", "", "", "", "", + "gs.jan-mayen.no", + "", "", "", "", "", "", "", "", "", + "", "", "", + "forgot.his.name", + "", "", "", "", "", "", + "now-dns.net", + "", "", "", "", "", "", "", "", "", + "pars", + "", "", "", "", "", "", + "ciscofreak.com", + "", "", "", "", "", "", "", "", "", + "vm.bytemark.co.uk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "pu.it", + "", "", + "web.nf", + "", "", "", "", "", "", "", + "muosat.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "chuo.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "mil.al", + "", "", "", "", "", "", + "v-info.info", + "", "", + "flight.aero", + "", "", "", "", "", "", "", "", "", + "", + "dsmynas.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "sandefjord.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "pe.kr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "pid", + "", "", "", "", "", "", + "pi.it", + "net.uz", + "", "", "", "", "", "", "", "", "", + "", + "bolzano-altoadige.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "tsushima.aichi.jp", + "", + "com.uz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "shop.pl", + "", "", "", + "izu.shizuoka.jp", + "", + "davvesiida.no", + "", "", "", "", "", "", "", "", "", + "", "", "", + "mil.cl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "map.fastlylb.net", + "", "", "", "", + "mil.in", + "", "", "", "", "", + "dh.bytemark.co.uk", + "", "", "", "", "", + "shopping", + "", "", "", "", + "opoczno.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "play", + "pl.ua", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "mil.tj", + "", "", "", "", "", "", "", "", "", + "pwc", + "", "", "", "", "", "", + "pv.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "opencraft.hosting", + "", "", "", + "is-a-lawyer.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "fundacio.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "tsukui.kanagawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "pub", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "kawazu.shizuoka.jp", + "", "", "", "", "", + "pin", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "nanmoku.gunma.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "parts", + "", "", "", "", + "tawaramoto.nara.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "p.bg", + "", "", "", "", "", "", "", "", "", + "", + "praxi", + "", "", "", "", "", "", "", "", "", + "", + "filegear-de.me", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "shiraoi.hokkaido.jp", + "", "", "", "", "", "", "", "", + "pro", + "", "", "", "", "", + "prof", + "", "", "", "", + "blogdns.net", + "", + "nebraska.museum", + "", + "pru", + "pccw", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "mil.do", + "", "", "", "", "", + "ibaraki.jp", + "", + "pro.om", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "mizunami.gifu.jp", + "", + "for-our.info", + "", "", "", + "post", + "b\303\245tsfjord.no", + "", "", "", "", "", "", "", "", "", + "valer.ostfold.no", + "skanit.no", + "", "", "", + "pd.it", + "", "", "", "", "", + "per.la", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "flynnhosting.net", + "", "", "", "", "", "", "", "", "", + "", + "shikaoi.hokkaido.jp", + "", "", "", + "resindevice.io", + "", "", "", "", "", "", "", "", "", + "", + "prod", + "", + "pub.sa", + "", "", + "pink", + "", "", + "gov.ws", + "", "", "", "", "", "", "", + "ybo.review", + "", "", "", "", "", "", "", "", "", + "\303\270vre-eiker.no", + "", "", "", "", "", "", "", "", "", + "", "", "", + "kushima.miyazaki.jp", + "saves-the-whales.com", + "", "", "", "", "", "", "", + "gov.as", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "party", + "", "", "", "", "", + "simple-url.com", + "", "", "", "", "", "", "", "", "", + "net.dz", + "", "", "", "", "", "", "", + "instantcloud.cn", + "", "", "", "", "", "", "", "", "", + "dnsdojo.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "taiki.mie.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "com.dz", + "", + "amakusa.kumamoto.jp", + "", + "from-dc.com", + "", "", "", + "ping", + "", "", "", "", "", "", "", "", "", + "nakamura.kochi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "varggat.no", + "", "", "", + "tsushima.nagasaki.jp", + "", "", "", "", "", "", "", "", "", + "gov.rs", + "", + "schoenbrunn.museum", + "", + "art.dz", + "", "", + "ssl.origin.cdn77-secure.org", + "", "", "", + "penza.su", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "sklep.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "zakopane.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "selfip.com", + "", + "shimabara.nagasaki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "uchiko.ehime.jp", + "", "", "", "", "", + "g\303\241ls\303\241.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "pm", + "", "", "", "", + "gob.gt", + "", "", "", "", "", "", "", "", + "ishigaki.okinawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "knightpoint.systems", + "", "", "", "", "", "", "", "", "", + "\303\241lt\303\241.no", + "", "", "", "", + "sk\303\241nit.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "isumi.chiba.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "kihoku.ehime.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "ikoma.nara.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "molde.no", + "", "", "", "", "", "", "", "", "", + "", "", "", + "walter", + "", "", "", "", "", "", "", + "net.mz", + "", "", + "pics", + "", "", "", "", "", "", + "rifu.miyagi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "aparecida.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "uk.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "alesund.no", + "alessandria.it", + "", "", "", "", "", "", "", "", "", + "", + "my-vigor.de", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "mil.tr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "xenapponazure.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "mil.ar", + "", "", "", + "gov.is", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "inderoy.no", + "", + "fuefuki.yamanashi.jp", + "", "", "", "", "", "", "", "", "", + "", + "volkenkunde.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "fujikawa.shizuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "afamilycompany", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "plus", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "corporation.museum", + "", + "gov.ls", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "elburg.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "plc.uk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "pe.ca", + "", "", + "ushuaia.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "perso.ht", + "", "", "", + "vikna.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "mil.qa", + "", "", "", "", + "msk.su", + "", "", + "pro.vn", + "", "", "", "", "", "", "", "", + "uol", + "", "", "", "", "", "", "", "", "", + "", "", "", + "kitaura.miyazaki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "edu.az", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "miyawaka.fukuoka.jp", + "", "", "", + "pg.it", + "", "", "", "", "", "", "", "", "", + "", "", "", + "calabria.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "mil.gh", + "", "", + "suldal.no", + "", "", "", "", "", "", + "square7.de", + "iwade.wakayama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "\303\245fjord.no", + "", + "msk.ru", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "campidano-medio.it", + "civilwar.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "r\303\270yken.no", + "", + "wmflabs.org", + "", "", "", "", "", "", "", "", "", + "", "", + "komatsu.ishikawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "ichiba.tokushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "otofuke.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "tecnologia.bo", + "", "", "", "", "", "", "", + "finearts.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "googlecode.com", + "", "", "", "", "", "", "", "", "", + "", + "arkhangelsk.su", + "", "", "", "", "", "", "", + "info.sd", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "1kapp.com", + "", "", "", + "gamo.shiga.jp", + "", "", "", "", "", "", "", + "ikeda.osaka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "nowruz", + "", "", "", "", "", "", "", "", "", + "", + "v\303\245ler.\303\270stfold.no", + "", "", "", "", "", "", "", "", "", + "", + "shirataka.yamagata.jp", + "", "", "", "", "", "", "", "", + "or.pw", + "", "", "", "", "", + "padua.it", + "", "", "", "", "", "", + "from-wa.com", + "vinnica.ua", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "miyagi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "yamagata.yamagata.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "creation.museum", + "", "", "", + "mombetsu.hokkaido.jp", + "omaezaki.shizuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "kraanghke.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "mil.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "place", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "pn", + "", "", "", "", "", "", "", + "pn.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "pt.eu.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "koganei.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "wroclaw.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "trani-andria-barletta.it", + "", "", "", "", "", + "vald-aosta.it", + "", "", "", "", + "gov.ms", + "", + "shikatsu.aichi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "val-daosta.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "balsan.it", + "", + "rogers", + "", "", "", "", "", "", "", "", "", + "", "", + "is-a-nurse.com", + "net.nz", + "", "", "", + "geelvinck.museum", + "", + "minobu.yamanashi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "prof.pr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "onagawa.miyagi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "mil.ni", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "british.museum", + "", "", "", "", "", + "tamamura.gunma.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "filegear-sg.me", + "", "", "", + "cnpy.gdn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "selfip.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "halden.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "nym.nz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "anan.tokushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "yoshida.shizuoka.jp", + "", "", "", "", "", "", "", + "sano.tochigi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "bulsan.it", + "", "", "", "", "", "", "", "", "", + "edu.dz", + "", "", "", "", "", "", "", "", "", + "", + "bato.tochigi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "divtasvuodna.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "tochio.niigata.jp", + "bygland.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "agents.aero", + "", "", "", "", "", "", + "tatebayashi.gunma.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "mil.ae", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "ciencia.bo", + "", "", "", "", "", "", "", "", "", + "", "", "", + "pl.eu.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "mil.jo", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "ohda.shimane.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "pnc", + "", "", "", "", "", + "england.museum", + "", "", "", "", "", "", "", "", + "prato.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "chernovtsy.ua", + "", "", "", "", "", "", "", "", "", + "", + "spydeberg.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "aridagawa.wakayama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "shimane.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "myasustor.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "edu.mz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "koga.ibaraki.jp", + "", "", "", "", "", "", "", "", + "kherson.ua", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "dyndns-remote.com", + "", "", "", "", "", "", "", "", "", + "frankfurt.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "square7.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "weatherchannel", + "", + "parti.se", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "supply", + "", "", "", "", "", "", "", + "tgwiddle.co.uk", + "", "", "", "", "", "", + "sakai.ibaraki.jp", + "", "", "", "", "", + "naka.hiroshima.jp", + "", + "is-a-hunter.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "mil.ph", + "", "", + "sakae.chiba.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "pp.ua", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "romskog.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "eu-west-2.elasticbeanstalk.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "from-wi.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "omihachiman.shiga.jp", + "", "", + "pro.na", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "saka.hiroshima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "catanzaro.it", + "", + "coop.mv", + "", "", "", "", "", "", "", "", + "mil.ve", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "api.stdlib.com", + "", "", "", "", "", "", "", "", "", + "", + "jinsekikogen.hiroshima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "qvapor.cloud", + "ushiku.ibaraki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "pp.se", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "tomika.gifu.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "mil.pl", + "", + "tomari.hokkaido.jp", + "", "", + "tomakomai.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "eksservice.gov.uk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "joinville.br", + "", "", "", + "perso.sn", + "", "", + "tajimi.gifu.jp", + "", "", "", + "team", + "", "", "", "", "", "", "", "", "", + "", + "s\303\241lat.no", + "", "", "", "", + "shinyoshitomi.fukuoka.jp", + "motobu.okinawa.jp", + "", + "eastafrica.museum", + "", "", "", "", "", "", "", "", "", + "", "", + "oki.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "mil.ru", + "", "", "", "", "", "", "", "", "", + "", "", + "pp.ru", + "filegear-ie.me", + "", + "knowsitall.info", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "in-addr.arpa", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "mima.tokushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "holt\303\245len.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "tsuru.yamanashi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "rankoshi.hokkaido.jp", + "", "", "", "", "", "", + "kuji.iwate.jp", + "tenei.fukushima.jp", + "", "", "", "", "", "", "", "", "", + "", + "kaluga.su", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "beppu.oita.jp", + "call", + "", "", "", "", "", "", "", "", "", + "", "", + "medecin.fr", + "", "", + "s\303\270rfold.no", + "", + "mil.km", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "us-3.evennode.com", + "", + "muos\303\241t.no", + "", "", + "us-4.evennode.com", + "", "", "", "", + "isteingeek.de", + "", "", "", "", + "us-1.evennode.com", + "", "", "", "", "", "", "", "", "", + "date.fukushima.jp", + "", "", "", "", "", "", "", + "pk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "is-a-player.com", + "", "", "", "", "", "", + "yachiyo.ibaraki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "soma.fukushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "wolterskluwer", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "coop.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "net.kz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "dell", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "com.kz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "prd.km", + "", "", "", "", "", "", "", "", + "iheya.okinawa.jp", + "yachiyo.chiba.jp", + "", + "mil.bo", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "yamazoe.nara.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "milan.it", + "", "", "", "", "", "", "", "", "", + "pb.ao", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "gov.ps", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "sweetpepper.org", + "ohi.fukui.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "net.bz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "decorativearts.museum", + "", "", + "nakadomari.aomori.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "nym.kz", + "", "", "", "", + "olbiatempio.it", + "", "", "", "", + "com.bz", + "", "", "", "", "", "", + "mil.ba", + "", "", "", "", "", + "volkswagen", + "", "", + "tsuchiura.ibaraki.jp", + "", "", "", "", "", "", "", "", + "ikeda.hokkaido.jp", + "", "", "", + "meloy.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "tsuiki.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "arendal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "yalta.ua", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "valer.hedmark.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "ichihara.chiba.jp", + "", "", "", "", + "us-2.evennode.com", + "", "", "", "", "", "", "", "", "", + "", "", + "nakatombetsu.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "charter.aero", + "", "", + "mil.ge", + "", "", + "nym.bz", + "", "", "", "", "", "", "", + "ginan.gifu.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "dnipropetrovsk.ua", + "", "", "", "", "", "", "", "", "", + "", "", + "porsangu.no", + "", "", "", "", + "biz.az", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "panasonic", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "shichinohe.aomori.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "vindafjord.no", + "evenes.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "bilbao.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", + "pictures", + "", "", "", "", "", "", "", "", + "pordenone.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "us.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "kijo.miyazaki.jp", + "", "", "", "", "", "", "", "", "", + "", + "hirogawa.wakayama.jp", + "", "", "", "", "", "", "", + "children.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "schlesisches.museum", + "", "", "", + "naklo.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "alpha.bounty-full.com", + "", + "fastvps-server.com", + "", "", "", "", "", "", "", "", "", + "", "", + "pizza", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "from-wy.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "maizuru.kyoto.jp", + "shibetsu.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "recife.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "okinawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "s3-website.eu-west-3.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "sciences.museum", + "", "", "", "", + "freebox-os.fr", + "", "", "", "", "", "", "", "", "", + "tm.mc", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "jevnaker.no", + "", "", "", "", "", "", "", "", "", + "", "", + "expert", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "bykle.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "fukusaki.hyogo.jp", + "in-dsl.de", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "name.tt", + "", "", "", "", "", "", "", "", "", + "", "", + "ishikari.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "iki.fi", + "", "", + "council.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "progressive", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "nayoro.hokkaido.jp", + "", + "gov.bs", + "", "", "", "", + "ryokami.saitama.jp", + "", "", "", "", + "ashgabad.su", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "kusatsu.shiga.jp", + "", "", "", + "kamifurano.hokkaido.jp", + "", "", "", "", + "porn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "filegear-au.me", + "", "", "", "", "", "", "", "", "", + "", "", + "is-found.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "kisarazu.chiba.jp", + "", "", "", "", "", "", + "research.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "horology.museum", + "", "", "", "", + "pvt.ge", + "", "", "", "", "", "", "", "", "", + "ichinomiya.chiba.jp", + "", + "phd", + "", "", "", "", "", "", "", "", "", + "filatelia.museum", + "", "", "", "", "", "", "", "", "", + "val-d-aosta.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "kanmaki.nara.jp", + "", "", "", "", "", "", "", "", + "mil.kr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "technology", + "", "", "", "", "", "", "", "", "", + "pisz.pl", + "", + "t\303\270nsberg.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "kafjord.no", + "", + "mil.hn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "onl", + "ome.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "omigawa.chiba.jp", + "", "", + "sevastopol.ua", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "nakamichi.yamanashi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "global.ssl.fastly.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "u2-local.xnbay.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "mil.id", + "", "", "", "", "", + "campidanomedio.it", + "", + "s3-website-us-west-1.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "pro.pr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "mil.br", + "credit", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "s3-website-us-east-1.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "edu.kz", + "sakae.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "tanabe.wakayama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "poa.br", + "", "", "", + "museumvereniging.museum", + "", "", "", "", + "dd-dns.de", + "", "", "", "", "", + "mosjoen.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "tx.us", + "", "", "", + "kiyose.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "paris.eu.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "correios-e-telecomunica\303\247\303\265es.museum", + "", "", "", "", "", "", + "syno-ds.de", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "edu.bz", + "", "", "", "", "", "", "", "", "", + "salvadordali.museum", + "", "", "", "", "", "", + "tanagura.fukushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "mil.pe", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "s3-website-eu-west-1.amazonaws.com", + "", "", "", "", + "protonet.io", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "sayama.osaka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "selfip.org", + "", "", "", "", "", "", + "hoylandet.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "naumburg.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "brumunddal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "priv.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "gov.nc.tr", + "shibuya.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "tamayu.shimane.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "sue.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "org.tt", + "", "", "", "", "", "", "", "", "", + "org.st", + "", "", "", "", "", + "sakado.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "itakura.gunma.jp", + "", "", "", + "gleeze.com", + "", "", "", "", "", "", + "sakai.fukui.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "tsukiyono.gunma.jp", + "", "", + "org.et", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "priv.hu", + "", + "haebaru.okinawa.jp", + "conference.aero", + "", "", + "santoandre.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "vuelos", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "ryugasaki.ibaraki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "workers.dev", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "motorcycles", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "psc.br", + "", "", "", "", "", "", "", "", "", + "imageandsound.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "oslo.no", + "", "", + "priv.me", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "nishiazai.shiga.jp", + "", "", + "hokkaido.jp", + "", "", "", "", "", "", "", "", + "nakano.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "ecologia.bo", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "ishinomaki.miyagi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "kiyama.saga.jp", + "", + "nakagusuku.okinawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "fukaya.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "pro.br", + "", "", "", "", "", + "\345\222\214\346\255\214\345\261\261.jp", + "router.management", + "", "", "", "", "", + "torahime.shiga.jp", + "freeboxos.fr", + "", "", "", "", "", + "yashiro.hyogo.jp", + "", "", "", "", "", + "nhlfan.net", + "", "", "", "", "", "", "", "", "", + "", "", "", + "from-nv.com", + "", "", "", "", "", + "tm.mg", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "ollo", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "meeres.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "tamano.okayama.jp", + "", "", "", "", "", "", "", "", + "blackfriday", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "automotive.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "airguard.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "chambagri.fr", + "", "", "", "", "", "", + "photo", + "", "", "", "", "", "", "", "", "", + "eating-organic.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "selfip.info", + "", "", "", "", "", + "appchizi.com", + "", "", "", "", "", "", "", "", + "partners", + "", "", + "isen.kagoshima.jp", + "", "", "", "", "", "", + "fukudomi.saga.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "n\303\245\303\245mesjevuemie.no", + "", "", "", "", "", "", "", + "2ix.at", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "sakuragawa.ibaraki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "kozagawa.wakayama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "monzaebrianza.it", + "", "", "", "", "", + "tsunan.niigata.jp", + "", "", "", "", "", "", "", + "taiwa.miyagi.jp", + "", "", "", "", "", + "fukushima.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "kokubunji.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "oregontrail.museum", + "", "", "", "", "", "", "", "", "", + "movistar", + "", "", "", "", "", "", "", "", "", + "", + "aikawa.kanagawa.jp", + "fukui.fukui.jp", + "", "", "", "", "", "", "", "", "", + "dyndns-free.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "niihama.ehime.jp", + "", "", "", "", "", "", + "dyndns.ddnss.de", + "", "", "", "", + "s\303\241l\303\241t.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "urakawa.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "wakayama.jp", + "", + "rightathome", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "usgarden.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "schokokeks.net", + "passenger-association.aero", + "", "", "", "", "", "", "", + "hida.gifu.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "club.tw", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "campobasso.it", + "", "", "", "", "", "", "", "", "", + "", + "go.pw", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "karatsu.saga.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "sarpsborg.no", + "", "", "", "", "", "", "", "", "", + "", "", "", + "tsuruoka.yamagata.jp", + "", "", "", "", "", "", "", "", "", + "", + "consulting.aero", + "", "", "", "", "", "", "", "", "", + "", + "tax", + "taxi", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "etajima.hiroshima.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "caserta.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "b\303\241l\303\241t.no", + "", "", "", "", + "ikusaka.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "tanabe.kyoto.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "scotland.museum", + "", "", "", "", + "iwakura.aichi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "portlligat.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "org.mt", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "niyodogawa.kochi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "fbx-os.fr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "us-east-1.elasticbeanstalk.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "bill.museum", + "uhk.com", + "", "", "", + "fukuyama.hiroshima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "cri.nz", + "", "", "", "", "", "", "", "", + "ibaraki.osaka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "us-west-1.elasticbeanstalk.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "pesaro-urbino.it", + "", "", "", "", "", + "farmstead.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "nakatane.kagoshima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "uzs.gov.pl", + "", "", "", "", "", "", "", "", "", + "myeffect.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "patria.bo", + "", "", "", + "alipay", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "kimitsu.chiba.jp", + "", "", + "mil.tw", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "filegear-jp.me", + "", + "creditcard", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "isshiki.aichi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "ashibetsu.hokkaido.jp", + "", "", "", "", + "aero.tt", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "grondar.za", + "", "", "", "", "", "", + "dscloud.biz", + "", "", "", "", "", "", "", + "gniezno.pl", + "", "", "", "", "", "", + "\345\215\203\350\221\211.jp", + "", "", "", "", "", "", + "mil.rw", + "", "", "", "", "", "", "", "", "", + "niki.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "org.gt", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "monza-brianza.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "parachuting.aero", + "", "", "", "", "", + "mibu.tochigi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "lt", + "ltd", + "", "", "", "", "", "", + "lt.it", + "", + "ls", + "", + "ltda", + "lo.it", + "\351\244\220\345\216\205", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "la", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "report", + "", "", "", "", "", "", "", "", + "\320\276\321\200\320\263", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "lt.ua", + "", "", "", "", "", "", "", "", "", + "la.us", + "", "", "", "", "", "", "", "", "", + "le.it", + "", "", "", "", "", "", "", + "lat", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "pri.ee", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "solund.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "lr", + "", + "nakama.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "in-vpn.de", + "", "", + "freiburg.museum", + "iwakuni.yamaguchi.jp", + "", "", + "lc", + "", "", "", "", "", "", "", + "lc.it", + "com.sv", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "rnrt.tn", + "", "", "", "", "", "", + "oyama.tochigi.jp", + "", "", "", "", + "inuyama.aichi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "tajiri.osaka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "allfinanz", + "", "", "", "", "", + "osakasayama.osaka.jp", + "", "", "", "", "", "", "", "", "", + "natuurwetenschappen.museum", + "", "", "", "", "", "", "", "", "", + "ly", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "\321\201\321\200\320\261", + "", "", "", "", "", "", "", "", + "kusatsu.gunma.jp", + "", + "yazu.tottori.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "l.se", + "lamer", + "", "", "", + "miyama.fukuoka.jp", + "", + "\320\277\321\200.\321\201\321\200\320\261", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "ichinomiya.aichi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "lu", + "", "", "", "", "", "", "", + "lu.it", + "", "", "", "", "", + "siellak.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "ltd.uk", + "", "", "", "", "", "", "", "", + "lease", + "", + "name.vn", + "", + "hakata.fukuoka.jp", + "", "", + "gb.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "land", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "jx.cn", + "", "", "", "", "", "", "", "", "", + "", "", + "golf", + "", "", "", "", "", "", + "li", + "", "", "", "", "", "", "", + "li.it", + "", "", "", "", "", "", "", "", + "gal", + "", + "lefrak", + "", "", "", "", "", "", "", "", "", + "is-uberleet.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "ringebu.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "tree.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", + "int.tt", + "", "", "", "", + "iwafune.tochigi.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "wakasa.tottori.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "ltd.lk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "gold", + "london", + "", "", "", "", + "svelvik.no", + "", "", + "is-a-nascarfan.com", + "", "", "", "", "", "", + "ltd.ua", + "", "", + "tjmaxx", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "lv", + "", "", "", "", "", "", "", "", "", + "", "", + "schokoladen.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "ibaraki.ibaraki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "liaison", + "", "", + "locus", + "", "", "", "", "", "", "", "", "", + "", + "net.lv", + "", "", "", + "lv.ua", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "technology.museum", + "", "", "", "", + "ikeda.nagano.jp", + "", "", "", "", "", "", "", "", + "tatamotors", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "com.lv", + "", "", "", "", "", "", "", + "life", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "lotto", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "giehtavuoatna.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "l.bg", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "lotte", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "tjome.no", + "", "", "", + "ikeda.fukui.jp", + "", "", "", + "joboji.iwate.jp", + "", "", "", "", "", "", "", "", + "asn.lv", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "koge.tottori.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "tranoy.no", + "", "", + "kani.gifu.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "linde", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "loft", + "", "", + "porsanger.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "link", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "lipsy", + "", "", "", + "kinokawa.wakayama.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "meldal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "monza-e-della-brianza.it", + "arts.ve", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "intuit", + "", "", "", "", + "lund.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "shimosuwa.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "fantasyleague.cc", + "", "", "", + "izumi.osaka.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "gouv.fr", + "", "", "", "", + "lds", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "org.pt", + "", "", "", "", + "llc", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "lacaixa", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "getmyip.com", + "\331\205\331\210\330\250\330\247\331\212\331\204\331\212", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "toride.ibaraki.jp", + "", + "s3-website-sa-east-1.amazonaws.com", + "", "", "", "", "", "", "", + "matsuno.ehime.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "malvik.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "airline.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "net.mv", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "com.mv", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "dev.static.land", + "", "", "", "", "", "", "", "", "", + "", "", "", + "vall\303\251eaoste.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "uryu.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "valle.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "londrina.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "law", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "url.tw", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "motorcycle.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "priv.pl", + "", "", "", "", "", "", + "tkmaxx", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "toscana.it", + "", "", "", "", "", + "kommunalforbund.se", + "", + "edu.sv", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "obninsk.su", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "nakanojo.gunma.jp", + "", "", "", "", "", "", "", + "lasalle", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "tomiya.miyagi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "lg.ua", + "", "", "", "", "", "", "", "", "", + "", "", "", + "hashima.gifu.jp", + "", "", "", "", "", "", "", "", + "pioneer", + "", "", "", "", "", "", "", "", "", + "", + "ravenna.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "minamiechizen.fukui.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "sells-it.net", + "", "", "", "", "", "", "", + "yamanobe.yamagata.jp", + "", "", "", "", "", "", "", "", "", + "is-a-teacher.com", + "", + "miyakonojo.miyazaki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "kitagata.gifu.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "iwanuma.miyagi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "krym.ua", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "namikata.ehime.jp", + "melbourne", + "", "", "", "", + "ltd.gi", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "portal.museum", + "", "", "", "", "", "", "", "", + "shimane.shimane.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "tjx", + "", "", "", "", "", "", + "co.network", + "", "", "", "", "", "", "", "", "", + "filegear-gb.me", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "shimoji.okinawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "skoczow.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "lenug.su", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "org.bt", + "", "", "", "", "", "", "", "", + "wake.okayama.jp", + "", "", "", "", + "jamison.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "lt.eu.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "okinoshima.shimane.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "s3-website.us-east-2.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "ind.gt", + "", + "folkebibl.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "edu.lv", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "latino", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "gok.pk", + "", "", "", "", "", "", "", "", "", + "vall\303\251e-d-aoste.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "lancome", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "lom.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "yonezawa.yamagata.jp", + "", "", "", "", "", "", "", + "zaporizhzhe.ua", + "", "", "", "", "", "", + "online", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "wiki.bo", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "tosashimizu.kochi.jp", + "", "", "", "", + "kakinoki.shimane.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "galsa.no", + "", + "locker", + "", "", "", "", "", "", "", "", "", + "s3-website.eu-west-2.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "ru.net", + "", "", "", "", "", "", + "sykkylven.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "lancia", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "lu.eu.org", + "lupin", + "", "", "", "", "", "", "", "", "", + "", + "jdevcloud.com", + "", "", "", "", "", "", "", "", "", + "", "", + "panama.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "anpachi.gifu.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "outsystemscloud.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "miyako.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "gol.no", + "", "", "", + "es.leg.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "okinawa.okinawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "psi.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "ce.leg.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "matsusaka.mie.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "pesarourbino.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "lgbt", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "ask\303\270y.no", + "", "", "", "", + "ac.leg.br", + "", "", "", "", "", "", "", + "lv.eu.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "institute", + "", + "lincoln", + "", "", "", "", + "wakkanai.hokkaido.jp", + "", "", "", + "s3-website-us-west-2.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "discover", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "zaporizhzhia.ua", + "", "", "", "", "", "", "", "", "", + "", + "ayagawa.kagawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "se.leg.br", + "", "", "", "", "", "", "", + "imizu.toyama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "cremona.it", + "edu.mv", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "zoological.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "wiki.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "sc.leg.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "sakawa.kochi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "mining.museum", + "", "", + "lomza.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", + "ba.leg.br", + "", "", "", + "phone", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "pgfog.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "lawyer", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "elblag.pl", + "", "", "", "", + "al.leg.br", + "", "", "", + "nohost.me", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "hiraizumi.iwate.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "grainger", + "", + "lans.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "metlife", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "pgafan.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "org.ht", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "tainai.niigata.jp", + "", "", "", "", "", "", "", + "nogi.tochigi.jp", + "", + "limo", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "science-fiction.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "turen.tn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "mil.sy", + "", "", "", "", "", "", "", "", "", + "", "", + "kamiizumi.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "hikawa.shimane.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "coop.mw", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "orkdal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "tf", + "", "", "", "", "", "", "", + "goshiki.hyogo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "pors\303\241\305\213gu.no", + "", "", "", + "int.pt", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "field.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "lib.ee", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "hokuto.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "myiphost.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "info.tn", + "", "", "", "", "", "", "", "", "", + "", + "tagawa.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "milano.it", + "", "", "", "", "", "", "", "", + "yokohama", + "", "", + "mil.uy", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "porsgrunn.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "lk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "government.aero", + "", "", + "tonami.toyama.jp", + "", + "kagamiishi.fukushima.jp", + "", "", "", "", "", + "molise.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "shinagawa.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "am.leg.br", + "", + "neyagawa.osaka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "loten.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "mil.zm", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "lapy.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "pz.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "lb", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "land-4-sale.us", + "", + "azumino.nagano.jp", + "", "", + "page", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "vallee-aoste.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "obihiro.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "linz.museum", + "", "", "", "", "", "", "", + "shikabe.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "lecco.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "mil.za", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "kiyosu.aichi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "lecce.it", + "", "", "", "", + "info.tr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "schmidt", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "plc.co.im", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "togo.aichi.jp", + "", "", "", "", + "gdynia.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "tienda", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "flakstad.no", + "", "", "", "", "", "", "", "", "", + "gripe", + "", "", "", "", "", + "sukumo.kochi.jp", + "", "", "", "", "", "", + "applinzi.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "miki.hyogo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "historyofscience.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "kayabe.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "lucca.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "mihama.mie.jp", + "", + "pro.cy", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "oco.cz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "principe.st", + "", + "schwarz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "ebiz.tw", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "bialystok.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "morotsuka.miyazaki.jp", + "", "", "", "", "", "", + "orskog.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "mil.my", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "gulen.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "hikimi.shimane.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "szkola.pl", + "przeworsk.pl", + "", "", "", "", "", + "tuscany.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "us-east-2.elasticbeanstalk.com", + "", "", "", "", "", "", "", "", "", + "sarufutsu.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "rennebu.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "us-west-2.elasticbeanstalk.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "theatre", + "", "", "", "", "", "", + "haga.tochigi.jp", + "mielec.pl", + "", + "noho.st", + "", "", "", "", + "mobi.tt", + "", "", "", "", "", "", + "home-webserver.de", + "", "", "", "", "", "", "", "", "", + "is-an-entertainer.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "oshima.yamaguchi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "is-an-engineer.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "tranby.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "lutsk.ua", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "workisboring.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "loan", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "ladbrokes", + "loans", + "", "", "", "", "", "", "", "", "", + "", "", + "tennis", + "", "", "", + "undersea.museum", + "", "", "", + "film", + "industries", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "sells-for-less.com", + "", "", "", + "sakura.tochigi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "tas.edu.au", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "lubin.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "luroy.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "info.bb", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "kanonji.kagawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "ide.kyoto.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "ltd.hk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "tromso.no", + "", + "itano.tokushima.jp", + "", "", "", "", "", "", "", "", + "miyake.nara.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "plc.ly", + "", "", "", + "muko.kyoto.jp", + "", "", "", "", "", "", "", "", "", + "maryland.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "padova.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "s\303\270r-varanger.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "yosemite.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "k12.az.us", + "", "", + "valleaosta.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "kounosu.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "tromsa.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "plurinacional.bo", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "lazio.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "ostre-toten.no", + "", "", "", "", "", "", "", "", "", + "", + "yamatsuri.fukushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "society.museum", + "film.hu", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "sobetsu.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "trentinsudtirol.it", + "in.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "discovery.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "tysv\303\246r.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "biz.mv", + "", "", "", + "coop.ht", + "", "", "", "", + "basketball", + "", "", "", "", "", "", "", "", "", + "", "", "", + "tabayama.yamanashi.jp", + "", "", "", "", "", "", + "urayasu.chiba.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "trentin-s\303\274d-tirol.it", + "", "", "", "", "", "", "", "", "", + "", "", + "ap.leg.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "giessen.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "localhost.daplie.me", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "railway.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "aibetsu.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "miyazaki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "ln.cn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "tsu.mie.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "serveftp.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "sp.leg.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "openair.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "from-wv.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "org.af", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "himi.toyama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "\320\276\321\200\320\263.\321\201\321\200\320\261", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "law.pro", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "sherbrooke.museum", + "", "", "", "", "", "", "", + "miyada.nagano.jp", + "", "", "", "", "", + "friuliveneziagiulia.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "trentin-s\303\274dtirol.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "taishi.hyogo.jp", + "", "", "", "", "", "", "", "", + "kopervik.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "theater", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "wpcomstaging.com", + "", "", + "tara.saga.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "royken.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "valled-aosta.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "kahoku.yamagata.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "trentinos-tirol.it", + "", "", "", "", "", "", "", + "trentin-sued-tirol.it", + "", "", "", "", + "tagami.niigata.jp", + "", "", + "sch.ng", + "", "", "", + "ine.kyoto.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "tosu.saga.jp", + "", "", "", + "saskatchewan.museum", + "", + "from-ca.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "mil.py", + "", "", "", "", "", + "pharmaciens.km", + "", "", "", "", "", "", "", "", "", + "", "", "", + "\345\230\211\351\207\214\345\244\247\351\205\222\345\272\227", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "is-into-cars.com", + "", + "lib.tx.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "happou.akita.jp", + "", "", "", "", "", "", + "lib.ok.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "chuo.fukuoka.jp", + "", "", "", "", "", "", + "lib.ak.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "trentino-s\303\274dtirol.it", + "", "", "", + "embetsu.hokkaido.jp", + "", "", + "bielawa.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "creditunion", + "", "", "", + "mill.museum", + "", "", "", "", "", "", "", "", + "kuroiso.tochigi.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "lib.oh.us", + "", "", "", "", + "karuizawa.nagano.jp", + "", "", + "miyako.iwate.jp", + "", "", + "trentino-s\303\274d-tirol.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "tottori.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "friulivenezia-giulia.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "ril", + "", "", "", "", "", "", "", + "austevoll.no", + "", "", "", "", "", + "athleta", + "lib.tn.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "lib.co.us", + "", "", "", "", + "trentinos\303\274d-tirol.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "lib.wa.us", + "", "", "", "", + "lib.wi.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "zappos", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "sa.gov.au", + "", "", "", "", "", "", "", "", "", + "", + "support", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "ballangen.no", + "", "", + "vevelstad.no", + "", + "graphics", + "", "", "", "", "", "", "", "", + "trentins\303\274d-tirol.it", + "", "", "", "", + "gotemba.shizuoka.jp", + "", "", "", "", + "imakane.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "trentin-suedtirol.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "lib.ri.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "sells-for-u.com", + "", + "lib.ca.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "so.gov.pl", + "", "", "", "", "", "", "", + "bievat.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "sa.gov.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "lib.al.us", + "", "", "", "", "", "", "", "", "", + "trentino-suedtirol.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "nakano.nagano.jp", + "", "", "", "", + "gliwice.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "nakayama.yamagata.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "trustee.museum", + "", "", "", "", "", "", "", "", "", + "", "", + "balashov.su", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "trentino-sued-tirol.it", + "", "", "", "", "", "", "", "", "", + "pp.az", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "trentino-stirol.it", + "", "", + "sr.gov.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "azurecontainer.io", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "es.gov.br", + "", "", "", "", "", "", "", "", "", + "", + "koeln.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "kakamigahara.gifu.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "tsuno.miyazaki.jp", + "", "", "", "", "", "", "", "", "", + "lib.in.us", + "", "", "", "", "", "", "", "", "", + "ce.gov.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "nikaho.akita.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "uscountryestate.museum", + "", "", "", "", "", "", "", + "trentinos\303\274dtirol.it", + "tomobe.ibaraki.jp", + "", "", "", "", "", "", "", "", "", + "poznan.pl", + "", "", "", "", "", "", "", "", "", + "lib.ia.us", + "", "", "", "", "", "", "", "", + "isahaya.nagasaki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "ac.gov.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "org.sg", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "org.ag", + "", "", "", "", "", + "lib.la.us", + "", "", "", "", + "loseyourip.com", + "", "", "", "", "", "", "", + "ushistory.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "mugi.tokushima.jp", + "ruovat.no", + "", "", "", "", "", "", "", + "org.eg", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "se.gov.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "koya.wakayama.jp", + "", "", "", "", "", "", "", "", "", + "", + "lib.va.us", + "", "", "", "", + "lib.vi.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "mil.by", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "valleeaoste.it", + "", "", "", + "sakura.chiba.jp", + "", "", "", "", "", "", + "trentinosued-tirol.it", + "", "", "", "", "", "", "", "", "", + "lib.il.us", + "hakone.kanagawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "shell.museum", + "", "", "", + "sc.gov.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "muenchen.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "forumz.info", + "", "", "", "", "", "", "", "", + "yoka.hyogo.jp", + "theworkpc.com", + "", "", + "dell-ogliastra.it", + "", "", + "trentins\303\274dtirol.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "pruszkow.pl", + "", "", "", "", + "meland.no", + "", "", "", "", "", "", "", "", "", + "", "", "", + "ba.gov.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "tysfjord.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "trentin-sud-tirol.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "trentino.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "org.ug", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "al.gov.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "colonialwilliamsburg.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "inazawa.aichi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "film.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "taishi.osaka.jp", + "", "", + "izena.okinawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "rennesoy.no", + "", "", "", + "gov.tt", + "", "", "", + "civilization.museum", + "", "", "", + "lib.mo.us", + "", + "gov.st", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "rec.nf", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "trentinsud-tirol.it", + "", "", "", "", "", "", "", "", + "health-carereform.com", + "trust.museum", + "", "", "", + "gov.et", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "trentino-sud-tirol.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "game-server.cc", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "trentinosuedtirol.it", + "", "", "", "", + "rishiri.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "tarnobrzeg.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "lib.mn.us", + "", "", "", "", "", + "serveftp.com", + "", "", "", "", + "pantheonsite.io", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "miyota.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "lib.ma.us", + "", "", "", "", + "lib.mi.us", + "", "", "", "", "", "", "", "", "", + "", "", + "selje.no", + "", "", "", "", "", "", "", + "lib.or.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "goldpoint", + "", "", "", "", "", "", + "writesthisblog.com", + "", "", "", "", "", "", + "lib.ar.us", + "", "", + "daejeon.kr", + "", "", + "idrett.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "schaeffler", + "", "", "", "", "", + "eu.meteorapp.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "delivery", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "niigata.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "togakushi.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "jewelry.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "mino.gifu.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "gov.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "trentin-sudtirol.it", + "", "", "", "", "", "", "", "", "", + "", + "valle-aosta.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "am.gov.br", + "", "", "", "", "", "", "", "", "", + "", "", + "gov.lt", + "", "", "", "", "", "", + "trentino-sudtirol.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "ink", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "the.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "vanylven.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "usui.fukuoka.jp", + "test-iserv.de", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "paroch.k12.ma.us", + "", "", + "lib.ga.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "limited", + "", "", "", "", "", "", "", "", + "from-mt.com", + "", "", "", "", "", "", "", "", "", + "is-not-certified.com", + "", + "org.mg", + "", "", "", "", "", + "localhistory.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "salerno.it", + "", + "aremark.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "wanouchi.gifu.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "posts-and-telecommunications.museum", + "", "", + "trentinosud-tirol.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "readmyblog.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "deporte.bo", + "lib.nm.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "tsuyama.okayama.jp", + "", "", "", "", "", + "uzhgorod.ua", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "isernia.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "is-a-bruinsfan.org", + "", "", "", "", + "lib.nh.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "allstate", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "izunokuni.shizuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "paderborn.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "onomichi.hiroshima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "tsuga.tochigi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "valleedaoste.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "isla.pr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "org.gg", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "mil.iq", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "racing", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "navigation.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "sakaki.nagano.jp", + "", "", "", "", + "org.pf", + "", "", "", "", "", "", + "beep.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "tksat.bo", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "wakasa.fukui.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "asakawa.fukushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "yame.fukuoka.jp", + "london.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "yamagata.gifu.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "oshino.yamanashi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "rackmaze.net", + "trentinoalto-adige.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "skierv\303\241.no", + "", "", "", "", "", "", "", "", "", + "", "", "", + "\345\237\274\347\216\211.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "inagi.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "trentinosudtirol.it", + "", "", "", "", "", "", "", "", + "epilepsy.museum", + "", "", "", "", "", "", "", + "uslivinghistory.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "trentino-s-tirol.it", + "", + "lib.nj.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "bolzano.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "lardal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "org.ng", + "", "", "", "", "", "", "", "", "", + "", "", + "trentinostirol.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "lerdal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "industria.bo", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "kalmykia.su", + "", "", "", "", "", "", "", "", "", + "kalmykia.ru", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "delmenhorst.museum", + "", "", "", "", "", "", "", "", + "bukhara.su", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "tomisato.chiba.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "valledaosta.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "mordovia.su", + "", "", "", "", "", "", "", "", "", + "mordovia.ru", + "", "", "", "", "", "", "", + "lebork.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "l\303\270ten.no", + "", "", + "leadpages.co", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "tsugaru.aomori.jp", + "", "", "", + "tadaoka.osaka.jp", + "", "", "", "", "", + "tome.miyagi.jp", + "", + "lviv.ua", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "larvik.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "goip.de", + "", "", "", "", "", + "valle-daosta.it", + "", "", "", "", "", "", "", "", "", + "", "", "", + "skjerv\303\270y.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "rel.pl", + "", + "is-a-therapist.com", + "", + "ginoza.okinawa.jp", + "", "", + "ap.gov.pl", + "", "", "", "", "", "", "", "", "", + "lib.pa.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "kunstunddesign.museum", + "", "", "", "", "", "", "", + "lyngen.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "ueno.gunma.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "reliance", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "nikolaev.ua", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "lenvik.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "togura.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "is-into-games.com", + "rochester.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "izumi.kagoshima.jp", + "", "", "", "", "", "", "", "", + "ap.gov.br", + "\330\247\331\204\330\263\330\271\331\210\330\257\331\212\331\207", + "cieszyn.pl", + "", "", + "lib.de.us", + "", "", "", "", "", + "\330\247\331\204\330\263\330\271\331\210\330\257\331\212\330\251", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "leczna.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "mt.leg.br", + "", "", "", "", "", "", "", "", "", + "ms.leg.br", + "", "", "", "", "", "", + "dscloud.me", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "ma.leg.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "sakuho.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "zp.gov.pl", + "", "", "", "", "", + "sakyo.kyoto.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "rockart.museum", + "mukawa.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "iraq.museum", + "", "", + "r\303\245holt.no", + "", "", "", + "mydatto.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "sp.gov.br", + "", "", + "biev\303\241t.no", + "", "", "", + "maebashi.gunma.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "grajewo.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "itabashi.tokyo.jp", + "mikasa.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "miho.ibaraki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "lundbeck", + "", "", "", "", "", "", "", "", "", + "", + "lib.me.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "is-a-techie.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "extraspace", + "", "", "", "", "", + "hakuba.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "tsukumi.oita.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "pavia.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "diskstation.eu", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "mishima.fukushima.jp", + "", "", "", "", "", "", + "serveftp.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "gjesdal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "adv.mz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "williamhill", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "tatsuno.nagano.jp", + "gov.pt", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "trentinoa-adige.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "stufftoread.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "ltd.co.im", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "online.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "shop.ht", + "", + "pittsburgh.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "sampa.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "torsken.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "lib.pr.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "org.kg", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "gen.nz", + "tsuwano.shimane.jp", + "ishikawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "l\303\270dingen.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "yoro.gifu.jp", + "", "", "", "", "", "", + "student.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "brandywinevalley.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "lcube-server.de", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "is-a-bulls-fan.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "orland.no", + "", "", "", "", "", "", + "fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "rackmaze.com", + "", "", "", "", "", "", "", "", "", + "adygeya.su", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "lib.ne.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "game.tw", + "", "", "", "", "", "", "", "", + "fukuchiyama.kyoto.jp", + "santafe.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "jeonnam.kr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "adygeya.ru", + "", + "in-brb.de", + "ltd.cy", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "trentinoaltoadige.it", + "", "", "", "", "", "", "", "", "", + "", + "lib.sd.us", + "", "", "", "", "", "", "", "", "", + "", + "donostia.museum", + "", "", + "mil.zw", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "luster.no", + "", "", "", "", "", + "ise.mie.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "groks-this.info", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "tamba.hyogo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "certmgr.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "boxfuse.io", + "", + "snillfjord.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "toei.aichi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "lib.gu.us", + "", "", "", "", "", + "ishikawa.okinawa.jp", + "mel\303\270y.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "info.az", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "tomioka.gunma.jp", + "tachiarai.fukuoka.jp", + "", "", "", "", "", "", "", "", + "from-sc.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "gov.bt", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "nfl", + "", "", "", "", "", "", "", "", "", + "taxi.br", + "", "", "", "", "", "", "", "", "", + "afl", + "", "", "", "", "", "", "", "", "", + "tamatsukuri.ibaraki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "devices.resinstaging.io", + "", "", "", "", "", "", "", "", + "buyshouses.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "krokstadelva.no", + "tottori.tottori.jp", + "exhibition.museum", + "", "", "", "", "", "", + "lib.hi.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "latina.it", + "", "", "", "", "", "", + "mg.leg.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "from-ut.com", + "", "", "", "", "", "", + "tran\303\270y.no", + "", "", "", + "mil.ac", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "lib.id.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "mil.ec", + "", "", + "chijiwa.nagasaki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "m\303\241latvuopmi.no", + "", "", "", "", "", "", "", "", "", + "yokosuka.kanagawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "coldwar.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "l\303\270renskog.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "fuettertdasnetz.de", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "l-o-g-i-n.de", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "is-a-guru.com", + "", "", "", "", "", "", "", "", "", + "", "", + "lamborghini", + "", "", "", + "is-with-theband.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "lidl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "gallo", + "", "", "", "", "", "", "", "", "", + "", + "trento.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "selfip.biz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "is-into-cartoons.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "legal", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "shimoda.shizuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "shimada.shizuoka.jp", + "", "", "", "", "", "", "", "", + "latrobe", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "from-la.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "mil.vc", + "", "", "", + "\303\241k\305\213oluokta.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "ppg.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "intl.tn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "yokoshibahikari.chiba.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "louvre.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "trentino-a-adige.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "lib.md.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "luzern.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "issmarterthanyou.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "tanohata.iwate.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "kakuda.miyagi.jp", + "", "", "", "", "", "", + "rhcloud.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "promo", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "pro.ec", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "\303\245lg\303\245rd.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "info.gu", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "joy", + "", "", "", "", "", "", "", "", + "operaunite.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "badajoz.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "chikuho.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "malopolska.pl", + "berlevag.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "bologna.it", + "", "", "", "", "", "", + "itami.hyogo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "koga.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "gorlice.pl", + "", "", "", "", "", "", "", + "nakagawa.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "toshima.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "tas.gov.au", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "ichinoseki.iwate.jp", + "", "", "", "", "", "", "", "", "", + "gallup", + "", "", "", "", "", "", "", "", "", + "", "", "", + "journalist.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "sekikawa.niigata.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "ichikawa.hyogo.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "tysnes.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "klepp.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "makinohara.shizuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "dnepropetrovsk.ua", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "mochizuki.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "labour.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "law.za", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "lib.nd.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "belem.br", + "", "", + "chikujo.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "yakumo.shimane.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "celtic.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "kiyosato.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", + "wa.gov.au", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "12hp.de", + "", "", "", "", "", "", "", + "online.th", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "leikanger.no", + "", "", "", "", "", + "lighting", + "", "", "", "", "", "", "", "", "", + "", "", "", + "nishiizu.shizuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "\330\263\331\210\330\261\331\212\330\247", + "", "", "", "", "", "", "", "", "", + "\330\263\331\210\330\261\331\212\330\251", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "recreation.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "yokawa.hyogo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "parma.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "touch.museum", + "", "", "", "", "", "", "", "", "", + "", "", + "toys", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "iglesias-carbonia.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "ichikawamisato.yamanashi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "landrover", + "", "", "", "", "", "", "", "", + "ichikawa.chiba.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "is-a-chef.com", + "mw.gov.pl", + "", "", "", "", "", "", "", "", "", + "", "", + "fukagawa.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "target", + "", "", "", "", "", "", "", "", "", + "", "", + "gifu.gifu.jp", + "", "", "", "", "", "", "", + "taa.it", + "hikone.shiga.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "culture.museum", + "", "", "", "", "", "", "", + "tabuse.yamaguchi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "nakaniikawa.toyama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "gliding.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "doesntexist.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "endoftheinternet.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "press", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "remotewd.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "tos.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "salud.bo", + "", "", "", "", + "is-a-chef.net", + "", "", "", "", "", "", + "trentino-alto-adige.it", + "", "", "", "", "", "", "", "", "", + "yakumo.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "hakusan.ishikawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "lego", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "lombardia.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "mt.gov.br", + "", "", "", "", "", "", "", "", "", + "ms.gov.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "ma.gov.br", + "", "", "", + "h\303\241pmir.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "nalchik.su", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "barletta-trani-andria.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "williamsburg.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "miyazu.kyoto.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "toda.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "nalchik.ru", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "americanexpress", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "from-ny.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "jeonbuk.kr", + "", "", "", "", "", "", "", "", + "dyndns1.de", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "pramerica", + "", "", "", + "pph", + "", "", "", "", "", + "r.cdn77.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "askvoll.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "s3-external-1.amazonaws.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "pisa.it", + "", "", "", "", "", "", "", "", "", + "", "", "", + "koshigaya.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "from-sd.com", + "", "", "", "", "", "", + "tahara.aichi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "nakagawa.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "tickets", + "", "", "", "", "", "", "", "", "", + "", "", + "k12.nv.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "philips", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "lpusercontent.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "saigawa.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "org.sz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "org.az", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "utwente.io", + "", "", "", "", "", "", + "trentinoaadige.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "nikko.tochigi.jp", + "", + "h\303\241mm\303\241rfeasta.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "trentino-aadige.it", + "", "", "", "", "", + "american.museum", + "", + "map.fastly.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "\303\245lesund.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "vibo-valentia.it", + "", "", "", "", "", + "nakagawa.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "siljan.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "bolivia.bo", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "chesapeakebay.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "gov.af", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "\331\205\331\204\331\212\330\263\331\212\330\247", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "tozawa.yamagata.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "tamakawa.fukushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "org.uz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "tagajo.miyagi.jp", + "", "", "", + "leclerc", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "is-a-green.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "boleslawiec.pl", + "", "", "", "", "", "", "", + "xfinity", + "wakuya.miyagi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "lunner.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "hokksund.no", + "", "", "", "", "", "", "", "", "", + "", "", + "chitose.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "\330\247\331\204\330\271\331\204\331\212\330\247\331\206", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "witd.gov.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "\331\201\331\204\330\263\330\267\331\212\331\206", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "observer", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "inami.wakayama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "\303\270ksnes.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "tselinograd.su", + "", "", "", "", "", "", "", "", "", + "", "", + "boldlygoingnowhere.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "press.ma", + "", "", "", "", "", "", "", + "cn-northwest-1.eb.amazonaws.com.cn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "taira.toyama.jp", + "", "", + "minamitane.kagoshima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "press.se", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "trentino-altoadige.it", + "", "", "", "", "", "", "", + "sologne.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "ookuwa.nagano.jp", + "", "", + "org.dz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "godo.gifu.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "higashi.fukushima.jp", + "", "", "", + "tuva.su", + "", + "mg.gov.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "love", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "salem.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "togane.chiba.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "mutsuzawa.chiba.jp", + "", "", "", "", "", "", "", "", "", + "", + "uw.gov.pl", + "nakai.kanagawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "us.gov.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "transporte.bo", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "freetls.fastly.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "gallery", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "govt.nz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "nakasatsunai.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "org.mz", + "", "", "", "", "", "", "", "", "", + "niepce.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "tobe.ehime.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "valle-d-aosta.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "tarui.gifu.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "balsfjord.no", + "", "", + "barlettatraniandria.it", + "", + "berlev\303\245g.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "gob.sv", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "wios.gov.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "toyota", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "gov.sg", + "", "", "", "", "", "", "", "", "", + "", "", + "live", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "gov.eg", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "chikuzen.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "test.tj", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "tsubame.niigata.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "wuoz.gov.pl", + "", "", "", "", + "prime", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "doesntexist.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "ilovecollege.info", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "uozu.toyama.jp", + "", "", + "is-a-chef.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "kiyokawa.kanagawa.jp", + "", "", "", "", + "townnews-staging.com", + "", "", "", "", "", "", "", "", "", + "higashi.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "leg.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "saltdal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "okegawa.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "org.nz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "perso.tn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "is-a-geek.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "is-a-conservative.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "matsushige.tokushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "um.gov.pl", + "", "", "", "", + "lib.wy.us", + "", "", "", "", "", "", "", "", "", + "", "", + "pistoia.it", + "", "", + "balsan-suedtirol.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "shimotsuma.ibaraki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "int.az", + "", "", "", "", "", + "niigata.niigata.jp", + "", "", "", "", "", "", "", + "is-a-geek.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "inami.toyama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "mykolaiv.ua", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "bulsan-suedtirol.it", + "", "", + "yokote.akita.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "pvh.br", + "", "", "", "", "", + "gov.mg", + "plumbing", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "inagawa.hyogo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "lugs.org.uk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "tamaki.mie.jp", + "", "", "", "", "", "", + "joetsu.niigata.jp", + "", "", "", + "ug.gov.pl", + "", + "perugia.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "office-on-the.net", + "", + "trani-barletta-andria.it", + "", "", "", "", "", + "tarama.okinawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "podzone.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "fukushima.fukushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "americanfamily", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "cosenza.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "nakagawa.tokushima.jp", + "", "", "", "", "", "", "", "", + "okagaki.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "delaware.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "yakage.okayama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "caltanissetta.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "geekgalaxy.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "go.leg.br", + "gov.ng", + "", "", "", "", "", "", "", "", + "tone.ibaraki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "nakijin.okinawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "is-a-financialadvisor.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "winb.gov.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "org.kz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "karumai.iwate.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "kikuchi.kumamoto.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "pagespeedmobilizer.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "vaksdal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "org.bz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "imamat", + "", + "gujo.gifu.jp", + "", "", + "pescara.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "isesaki.gunma.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "sakata.yamagata.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "giving", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "press.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", + "lublin.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "oldnavy", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "gov.bf", + "piedmont.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "cloudfront.net", + "", "", + "valley.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "tenkawa.nara.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "chikushino.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "lib.ny.us", + "", "", "", "", "", "", "", "", "", + "", "", "", + "ishikawa.fukushima.jp", + "", "", "", "", "", "", "", + "pf", + "", "", "", "", "", "", "", "", "", + "", + "firenze.it", + "", "", "", + "plo.ps", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "priv.at", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "vpnplus.to", + "", "", "", "", "", "", "", + "kakogawa.hyogo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "pimienta.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "ibestad.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "obanazawa.yamagata.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "hakodate.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "sakurai.nara.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "lur\303\270y.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "prudential", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "oshu.iwate.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "pharmacy", + "", "", "", "", "", + "sokndal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "komforb.se", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "is-a-geek.org", + "hikari.yamaguchi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "tondabayashi.osaka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "gov.kg", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "morioka.iwate.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "joso.ibaraki.jp", + "", "", "", "", "", "", "", + "belluno.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "eiheiji.fukui.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "repbody.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "guam.gu", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "juegos", + "", "", "", "", + "maringa.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "jp.net", + "", "", "", + "tonaki.okinawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "sukagawa.fukushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "vologda.su", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "podhale.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "cultural.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "miyazaki.miyazaki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "rokunohe.aomori.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "rexroth", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "traniandriabarletta.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "knx-server.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "yolasite.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "rsvp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "trolley.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "wiih.gov.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "lib.ky.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "prd.fr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "firm.ve", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "fukumitsu.toyama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "lanbib.se", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "geek.nz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "tokyo", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "is-certified.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "upow.gov.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "computer", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "soka.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "itoman.okinawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "toon.ehime.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "potager.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "photos", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "wales.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "red.sv", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "lodi.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "helsinki.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "iiyama.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "info.zm", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "turystyka.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "judaica.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "select", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "parliament.cy", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "joburg", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "tdk", + "", "", "", "", "", "", "", "", "", + "", "", "", + "cal.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "jll", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "chicago.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "investments", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "miyoshi.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "miyama.mie.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "iwi.nz", + "", "", "", "", "", "", + "poivron.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "isehara.kanagawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "lier.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "wolomin.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "tama.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "tel", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "onga.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", + "london.cloudapps.digital", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "apps.fbsbx.com", + "", "", "", "", "", "", "", "", "", + "bplaced.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "paris.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "campinagrande.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "org.sv", + "", + "bydgoszcz.pl", + "talk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "vicenza.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "hakui.ishikawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "redirectme.net", + "", "", "", "", "", "", "", "", "", + "imabari.ehime.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "johana.toyama.jp", + "", + "tynset.no", + "", "", "", "", "", "", "", + "california.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "presse.ci", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "hokuto.yamanashi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "presse.ml", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "go.gov.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "tm.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "pixolino.com", + "", "", + "lexus", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "malbork.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "logoip.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "okoppe.hokkaido.jp", + "", "", "", + "villas", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "bahcavuotna.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "tokke.no", + "", "", "", "", "", + "hekinan.aichi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "org.lv", + "", + "pohl", + "", "", "", + "troitsk.su", + "", "", "", "", "", "", "", "", "", + "", + "luxe", + "leangaviika.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "lima-city.at", + "", "", "", "", "", "", "", + "uppo.gov.pl", + "", "", "", + "kokonoe.oita.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "trysil.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "lesja.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "mazowsze.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "kaho.fukuoka.jp", + "", "", "", "", + "gyokuto.kumamoto.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "miyoshi.aichi.jp", + "", "", "", "", "", "", + "tsukuba.ibaraki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "lanxess", + "", "", "", + "iglesiascarbonia.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "togliatti.su", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "koka.shiga.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "ipifony.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "uber.space", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "tatsuno.hyogo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "plaza.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "nflfan.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "org.mv", + "", "", "", "", "", "", "", + "lixil", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "tel.tr", + "", "", "", "", + "dyndns-office.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "shibata.miyagi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "umig.gov.pl", + "", "", "", "", "", "", "", "", "", + "toyama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "monmouth.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "pueblo.bo", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "us-gov-west-1.elasticbeanstalk.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "troms\303\270.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "from-tn.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "lima-city.de", + "", "", "", "", + "ichikai.tochigi.jp", + "", "", "", + "ro.leg.br", + "", "", "", "", + "rs.leg.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "bryansk.su", + "", "", "", "", "", "", "", "", "", + "", "", "", + "melhus.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "skype", + "", "", "", "", "", "", "", "", "", + "rr.leg.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "limanowa.pl", + "is-leet.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "r\303\270yrvik.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "kyuragi.saga.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "my-gateway.de", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "tolga.no", + "", "", "", "", "", "", "", "", "", + "", + "gov.az", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "tourism.tn", + "", "", + "uwajima.ehime.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "hospital", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "presse.km", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "j\303\270lster.no", + "", "", + "yokoze.saitama.jp", + "", "", "", + "wakayama.wakayama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "onyourside", + "", "", + "sekigahara.gifu.jp", + "", "", "", "", "", "", "", + "laquila.it", + "", "", "", "", "", "", "", "", "", + "", "", "", + "pvt.k12.ma.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "shibata.niigata.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "netlify.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "info.tt", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "salzburg.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "kuki.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "tohma.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "fukuroi.shizuoka.jp", + "", "", + "reklam.hu", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "naka.ibaraki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "gov.dz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "tananger.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "otsuchi.iwate.jp", + "", "", "", "", "", "", + "hichiso.gifu.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "miyoshi.tokushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "toyonaka.osaka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "nakanoto.ishikawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "tsubetsu.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "profesional.bo", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "gov.mz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "lib.sc.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "puglia.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "hoyanger.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "royrvik.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "tempio-olbia.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "servehalflife.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "pomorskie.pl", + "", "", "", + "ikeda.gifu.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "lg.jp", + "", "", "", "", "", "", "", + "ullensaker.no", + "", "", "", "", "", "", "", "", "", + "", "", "", + "zoology.museum", + "", + "tr\303\270gstad.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "skjervoy.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "izumiotsu.osaka.jp", + "", "", "", "", "", "", "", "", "", + "kartuzy.pl", + "", "", "", + "int.mv", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "rn.leg.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "miyoshi.hiroshima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "dolls.museum", + "", "", "", "", "", "", + "on-aptible.com", + "", "", "", "", "", "", "", "", + "plantation.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", + "sakegawa.yamagata.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "taipei", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "pubol.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "ppxen.prgmr.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "lib.dc.us", + "", "", "", "", "", + "pfizer", + "", "", "", + "unjarga.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "mikawa.yamagata.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "lucania.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "publ.pt", + "", "", "", "", "", "", "", "", "", + "", "", + "larsson.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "joyo.kyoto.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "taito.tokyo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "rj.leg.br", + "", "", "", "", "", "", "", "", "", + "", "", + "shop.th", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "t3l3p0rt.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "hayakawa.yamanashi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "gildeskal.no", + "", "", "", "", "", "", + "philadelphia.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "tranibarlettaandria.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "jorpeland.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "dallas.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "tokushima.tokushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "from-ct.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "homeoffice.gov.uk", + "", "", + "iveland.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "textile.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "pasadena.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "fhapp.xyz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "lib.nc.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "\303\241laheadju.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "traeumtgerade.de", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "lima-city.rocks", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "12hp.ch", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "auspost", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "lucerne.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "info.vn", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "gov.kz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "lindesnes.no", + "", "", "", "", "", "", "", "", "", + "", + "mobi.tz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "coloradoplateau.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "raholt.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "nanporo.hokkaido.jp", + "", "", + "michigan.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "shimofusa.chiba.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "gov.bz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "folldal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "toyo.kochi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "juedisches.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "homeftp.org", + "", "", "", + "lima-city.ch", + "", "", "", "", "", "", "", "", + "wildlife.museum", + "", "", "", "", "", "", "", "", "", + "", + "lind\303\245s.no", + "", "", "", "", "", "", "", "", "", + "info.ve", + "", + "rikuzentakata.iwate.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "agematsu.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "ro.gov.br", + "", "", "", "", + "rs.gov.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "rr.gov.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "matsuzaki.shizuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "tourism.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "tokushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "hellas.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "gets-it.net", + "", "", "", "", "", "", "", "", + "from-tx.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "in-butter.de", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "columbus.museum", + "", "", "", "", + "lincoln.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "plants.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "mulhouse.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "griw.gov.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "paragliding.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "lib.as.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "ekloges.cy", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "mol.it", + "", "", "", "", + "mil.st", + "", + "is.gov.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "schweiz.museum", + "", "", "", "", "", "", "", "", "", + "texas.museum", + "", "", "", "", "", "", "", "", "", + "pay", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "ic.gov.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "temp-dns.com", + "", "", + "toyotomi.hokkaido.jp", + "", "", "", "", "", + "toya.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "12hp.at", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "philadelphiaarea.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "columbia.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "df.leg.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "izumisano.osaka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "izumo.shimane.jp", + "", "", "", "", "", "", + "balestrand.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "gjemnes.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "television.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "pro.tt", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "corvette.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "piaget", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "gildesk\303\245l.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "lib.ms.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "tono.iwate.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "jpmorgan", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "\351\246\231\346\240\274\351\207\214\346\213\211", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "rn.gov.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "app.os.stg.fedoraproject.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "lorenskog.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "help", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "trading.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "gotpantheon.com", + "", "", "", + "resistance.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "taki.mie.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "from-co.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "mil.gt", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "yokaichiba.chiba.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "point2this.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "abruzzo.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "rj.gov.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "pictet", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "vall\303\251e-aoste.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "journal.aero", + "pmn.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "yokkaichi.mie.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "akkeshi.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "phoenix.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "istmein.de", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "pharmacien.fr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "trainer.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "malselv.no", + "", "", "", + "landes.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "is-into-anime.com", + "parliament.nz", + "", "", + "lombardy.it", + "mantova.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "podlasie.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "l\303\246rdal.no", + "", "", "", + "kkknssy!city.kawasaki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "lpages.co", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "sakahogi.gifu.jp", + "", + "riopreto.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "echizen.fukui.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "linkyard.cloud", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "lindas.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "theater.museum", + "", "", + "psp.gov.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "lyngdal.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "takatori.nara.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "seaport.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "gov.lv", + "webhosting.be", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "gyeongnam.kr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "express.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "lajolla.museum", + "pup.gov.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "public.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "lib.ks.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "from-ga.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "l\303\241hppi.no", + "", "", "", "", "", "", "", "", "", + "tokai.ibaraki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "gov.mv", + "", "", "", "", "", "", "", "", "", + "", + "jelenia-gora.pl", + "", "", + "inawashiro.fukushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "tokai.aichi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "labor.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "tempioolbia.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "leirvik.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "freight.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "takinoue.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "walmart", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "aostavalley.it", + "", "", "", "", "", "", "", "", "", + "", "", + "taketomi.okinawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "gloppen.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "newport.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "lib.fl.us", + "", "", "", "", "", "", "", "", "", + "", + "takayama.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "topology.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "takko.aomori.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "poniatowa.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "trentinsued-tirol.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "df.gov.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "preservation.museum", + "piw.gov.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "does-it.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "gangaviika.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "luxury", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "uklugs.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "taka.hyogo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "from-fl.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "toyohashi.aichi.jp", + "", "", "", "", "", "", + "yukuhashi.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "jobs.tt", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "lifeinsurance", + "", "", "", + "trentinsuedtirol.it", + "", "", "", "", + "ballooning.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "oyamazaki.kyoto.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "mydatto.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "hembygdsforbund.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "computerhistory.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "iselect", + "", "", + "ohkura.yamagata.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "railroad.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "is-a-soxfan.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "gyeonggi.kr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "toyota.aichi.jp", + "", "", "", "", + "l\303\244ns.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "vallee-d-aoste.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "press.cy", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "lierne.no", + "", + "tohnosho.chiba.jp", + "takashima.shiga.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "physio", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "pro.ht", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "ravendb.run", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "mckinsey", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "viking", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "takasago.hyogo.jp", + "", "", "", "", "", "", "", "", + "lewismiller.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "chippubetsu.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "tonosho.kagawa.jp", + "", "", + "taiji.wakayama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "liguria.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "taketa.oita.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "takayama.gunma.jp", + "toyako.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "tokashiki.okinawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", + "tsurugashima.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "leirfjord.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "kakegawa.shizuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "playstation", + "", "", "", "", "", "", "", "", "", + "", "", "", + "experts-comptables.fr", + "", "", + "yuki.ibaraki.jp", + "salangen.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "kikonai.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "skierva.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "takahama.aichi.jp", + "", "", "", "", "", "", "", + "kikugawa.shizuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "takata.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "tarumizu.kagoshima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "takamori.kumamoto.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "powiat.pl", + "", "", "", "", "", "", "", "", "", + "kongsvinger.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "wallonie.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "poker", + "", "", "", "", "", "", "", "", "", + "takamori.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "nfshost.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "jaworzno.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "is-a-student.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "lom.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "rotorcraft.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "pc.pl", + "", "", "", "", "", "", + "mallorca.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "tsukigata.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "takasaki.gunma.jp", + "", "", "", "", "", "", "", "", "", + "sellsyourhome.org", + "", "", "", "", "", "", "", "", "", + "", "", "", + "tokamachi.niigata.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "tokoname.aichi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "linkyard-cloud.ch", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "takahama.fukui.jp", + "", "", "", + "productions", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "vossevangen.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "leitungsen.de", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "protection", + "", "", "", "", "", "", + "ibigawa.gifu.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "mil.eg", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "ptplus.fit", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "per.sg", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "port.fr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "oirm.gov.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "taranto.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "toyono.osaka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "telekommunikation.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "politie", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "kobierzyce.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "hokuryu.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "per.nf", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "taifun-dns.de", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "nakagyo.kyoto.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "mil.mg", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "toyone.aichi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "prd.mg", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "pol.tr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "laakesvuemie.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "ownprovider.com", + "", "", "", + "seljord.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "planetarium.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "lubartow.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "takehara.hiroshima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "mil.ng", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "lug.org.uk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "to.leg.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "toyama.toyama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "politica.bo", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "laz.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "takahashi.okayama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "heimatunduhren.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "muenster.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "pyatigorsk.ru", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "ravendb.community", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "geology.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "gokase.miyazaki.jp", + "", "", "", "", "", + "jeep", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "is-lost.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "pug.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "trogstad.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "mil.kg", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "lebesby.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "trieste.it", + "", "", "", "", "", "", "", "", "", + "", + "seki.gifu.jp", + "", + "piacenza.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "linkitools.space", + "", "", "", "", "", "", "", "", "", + "ogliastra.it", + "", "", "", "", "", "", "", "", "", + "", "", "", + "passagens", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "tjeldsund.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "gallery.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "coop.tt", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "college", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "takino.hyogo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "pila.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "lifestyle", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "revista.bo", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "livorno.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "gjerstad.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "orkanger.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "nsupdate.info", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "grimstad.no", + "", "", "", "", "", "", + "tobetsu.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "realestate", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "here-for-more.info", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "takasu.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "ugim.gov.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "ullensvang.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "abkhazia.su", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "lib.ct.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "anamizu.ishikawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "military.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "collection.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "lib.ut.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "tvedestrand.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "viking.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "moka.tochigi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "lib.vt.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "press.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "luxembourg.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "takahagi.ibaraki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "takagi.nagano.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "lib.mt.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "tokigawa.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "to.gov.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "treviso.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "tsuruta.aomori.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "togitsu.nagasaki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "leka.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "like", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "podzone.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "lakas.hu", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "\330\247\331\204\330\263\330\271\331\210\330\257\333\214\333\203", + "", "", "", "", + "\330\247\331\204\330\263\330\271\331\210\330\257\333\214\330\251", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "lavagis.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "hyllestad.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "tula.su", + "", "", "", "", "", "", "", + "pagefrontapp.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "lol", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "trapani.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "bplaced.de", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "mil.tz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "mil.az", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "ikaruga.nara.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "tsubata.ishikawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "pilot.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "loppa.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "culturalcenter.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "pro.az", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "rikubetsu.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "bplaced.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "realestate.pl", + "", "", "", "", "", "", "", "", "", + "mil.mz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "jampa.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "mein-vigor.de", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "lancaster", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "pippu.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "kolobrzeg.pl", + "", + "deloitte", + "", "", "", "", "", "", "", + "kalisz.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "logoip.de", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "skydiving.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "toyokawa.aichi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "rel.ht", + "", "", "", "", "", "", "", "", "", + "", "", "", + "pacific.museum", + "", "", "", "", "", "", "", + "info.tz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "mil.nz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "shimotsuke.tochigi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "from-va.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "loabat.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "iwamizawa.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "takaharu.miyazaki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "nishigo.fukushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "lpl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "photography", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "collegefan.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "fukuchi.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "lig.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "jogasz.hu", + "", "", "", "", + "fylkesbibl.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "palace.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "taishin.fukushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "tokuyama.yamaguchi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "mil.kz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "lukow.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "atlanta.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "police.uk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "logistics.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "holmestrand.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "rzeszow.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "golffan.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "lebtimnetz.de", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "taku.saga.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "toyota.yamaguchi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "pharmacy.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "dazaifu.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "polkowice.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "lel.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "ivanovo.su", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "lodingen.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "loab\303\241t.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "tochigi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "vaapste.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "photography.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "guernsey.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "takaoka.toyama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "portland.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "privatizehealthinsurance.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "computer.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "toyoake.aichi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "jolster.no", + "", "", "", "", "", "", "", "", "", + "", "", + "illustration.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "rzgw.gov.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "takikawa.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "toyosato.shiga.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "rakkestad.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "presidio.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "toga.toyama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "bieszczady.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "dellogliastra.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "tsurugi.ishikawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "publishproxy.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "takamatsu.kagawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "losangeles.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "g\303\241\305\213gaviika.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "prochowice.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "leasing.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "mil.lv", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "pcloud.host", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "skiptvet.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "olkusz.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "mil.mv", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "tele.amune.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "likes-pie.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "takaishi.osaka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "lezajsk.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "homeftp.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "la-spezia.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "pulawy.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "pro.mv", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "termez.su", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "jfk.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "is-saved.org", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "philately.museum", + "lplfinancial", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "airport.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "egyptian.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "pa.leg.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "pe.leg.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "pr.leg.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "from-az.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "takatsuki.osaka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "pi.leg.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "trafficplex.cloud", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "telefonica", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "lima.zone", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "ralingen.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "toho.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "vall\303\251edaoste.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "lilly", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "isleofman.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "takazaki.miyazaki.jp", + "", "", "", "", "", "", "", "", "", + "tadotsu.kagawa.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "takatsuki.shiga.jp", + "", "", "", "", "", "", + "chikugo.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "tsumagoi.gunma.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "izumozaki.niigata.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "czeladz.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "lancashire.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "takayama.gifu.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "makurazaki.kagoshima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "piemonte.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "tako.chiba.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "wskr.gov.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "walbrzych.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "lib.az.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "pb.leg.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "po.gov.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "pa.gov.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "malatvuopmi.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "omotego.fukushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "pa.gov.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "pe.gov.br", + "", "", "", "", "", "", "", "", + "ravendb.me", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "pr.gov.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "nakatsugawa.gifu.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "pi.gov.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "toyoura.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "lowicz.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "gyeongbuk.kr", + "", "", "", "", "", "", "", "", "", + "", "", + "shimizu.shizuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "palermo.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "pointto.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "psse.gov.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "toyooka.hyogo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "langevag.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "legnica.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "tochigi.tochigi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "lugansk.ua", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "wellbeingzone.eu", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "wellbeingzone.co.uk", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "living", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "properties", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "pb.gov.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "levanger.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "production.aero", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "pinb.gov.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "shimizu.hokkaido.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "langev\303\245g.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "yanaizu.fukushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "lavangen.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "paleo.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "takahata.yamagata.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "loyalist.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "from-vt.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "lib.nv.us", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "ponpes.id", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "potenza.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "rollag.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "pilots.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "palmsprings.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "village.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "living.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "leksvik.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "telebit.io", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "takanabe.miyazaki.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "telebit.app", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "lahppi.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "pomorze.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "halloffame.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "shimogo.fukushima.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "karpacz.pl", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "keymachine.de", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", + "toki.gifu.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", + "property", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "myfritz.net", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "pol.ht", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "izumizaki.fukushima.jp", + "", "", "", "", "", + "tokorozawa.saitama.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "project.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "livinghistory.museum", + "", "", + "tsuruga.fukui.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "likescandy.com", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "lillehammer.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", + "palmas.br", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", + "lillesand.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "takanezawa.tochigi.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "bellevue.museum", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "takarazuka.hyogo.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "pol.dz", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "ofunato.iwate.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", + "lea\305\213gaviika.no", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "pokrovsk.su", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", + "loginto.me", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "toyotsu.fukuoka.jp", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", + "laspezia.it", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "geometre-expert.fr", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", "", "", "", "", "", + "", "", "", "", + "poltava.ua" + }; + + if (len <= MAX_WORD_LENGTH && len >= MIN_WORD_LENGTH) + { + unsigned int key = hash (str, len); + + if (key <= MAX_HASH_VALUE) + { + const char *s = wordlist[key]; + + if (*str == *s && !strcmp (str + 1, s + 1)) + return s; + } + } + return 0; +} +#line 8638 "tldLookup.gperf" + +%{ +} +%} diff --git a/dbms/src/Functions/gperf/tldLookup.gperf b/dbms/src/Functions/gperf/tldLookup.gperf new file mode 100644 index 00000000000..e849bbb1545 --- /dev/null +++ b/dbms/src/Functions/gperf/tldLookup.gperf @@ -0,0 +1,8633 @@ +%language=C++ +%define lookup-function-name is_valid +%define class-name tldLookupHash +%readonly-tables +%includes +%% +ac +com.ac +edu.ac +gov.ac +net.ac +mil.ac +org.ac +ad +nom.ad +ae +co.ae +net.ae +org.ae +sch.ae +ac.ae +gov.ae +mil.ae +aero +accident-investigation.aero +accident-prevention.aero +aerobatic.aero +aeroclub.aero +aerodrome.aero +agents.aero +aircraft.aero +airline.aero +airport.aero +air-surveillance.aero +airtraffic.aero +air-traffic-control.aero +ambulance.aero +amusement.aero +association.aero +author.aero +ballooning.aero +broker.aero +caa.aero +cargo.aero +catering.aero +certification.aero +championship.aero +charter.aero +civilaviation.aero +club.aero +conference.aero +consultant.aero +consulting.aero +control.aero +council.aero +crew.aero +design.aero +dgca.aero +educator.aero +emergency.aero +engine.aero +engineer.aero +entertainment.aero +equipment.aero +exchange.aero +express.aero +federation.aero +flight.aero +freight.aero +fuel.aero +gliding.aero +government.aero +groundhandling.aero +group.aero +hanggliding.aero +homebuilt.aero +insurance.aero +journal.aero +journalist.aero +leasing.aero +logistics.aero +magazine.aero +maintenance.aero +media.aero +microlight.aero +modelling.aero +navigation.aero +parachuting.aero +paragliding.aero +passenger-association.aero +pilot.aero +press.aero +production.aero +recreation.aero +repbody.aero +res.aero +research.aero +rotorcraft.aero +safety.aero +scientist.aero +services.aero +show.aero +skydiving.aero +software.aero +student.aero +trader.aero +trading.aero +trainer.aero +union.aero +workinggroup.aero +works.aero +af +gov.af +com.af +org.af +net.af +edu.af +ag +com.ag +org.ag +net.ag +co.ag +nom.ag +ai +off.ai +com.ai +net.ai +org.ai +al +com.al +edu.al +gov.al +mil.al +net.al +org.al +am +co.am +com.am +commune.am +net.am +org.am +ao +ed.ao +gv.ao +og.ao +co.ao +pb.ao +it.ao +aq +ar +com.ar +edu.ar +gob.ar +gov.ar +int.ar +mil.ar +musica.ar +net.ar +org.ar +tur.ar +arpa +e164.arpa +in-addr.arpa +ip6.arpa +iris.arpa +uri.arpa +urn.arpa +as +gov.as +asia +at +ac.at +co.at +gv.at +or.at +au +com.au +net.au +org.au +edu.au +gov.au +asn.au +id.au +info.au +conf.au +oz.au +act.au +nsw.au +nt.au +qld.au +sa.au +tas.au +vic.au +wa.au +act.edu.au +nsw.edu.au +nt.edu.au +qld.edu.au +sa.edu.au +tas.edu.au +vic.edu.au +wa.edu.au +qld.gov.au +sa.gov.au +tas.gov.au +vic.gov.au +wa.gov.au +aw +com.aw +ax +az +com.az +net.az +int.az +gov.az +org.az +edu.az +info.az +pp.az +mil.az +name.az +pro.az +biz.az +ba +com.ba +edu.ba +gov.ba +mil.ba +net.ba +org.ba +bb +biz.bb +co.bb +com.bb +edu.bb +gov.bb +info.bb +net.bb +org.bb +store.bb +tv.bb +bbe +ac.be +bf +gov.bf +bg +a.bg +b.bg +c.bg +d.bg +e.bg +f.bg +g.bg +h.bg +i.bg +j.bg +k.bg +l.bg +m.bg +n.bg +o.bg +p.bg +q.bg +r.bg +s.bg +t.bg +u.bg +v.bg +w.bg +x.bg +y.bg +z.bg +0.bg +1.bg +2.bg +3.bg +4.bg +5.bg +6.bg +7.bg +8.bg +9.bg +bh +com.bh +edu.bh +net.bh +org.bh +gov.bh +bi +co.bi +com.bi +edu.bi +or.bi +org.bi +biz +bj +asso.bj +barreau.bj +gouv.bj +bm +com.bm +edu.bm +gov.bm +net.bm +org.bm +bn +com.bn +edu.bn +gov.bn +net.bn +org.bn +bo +com.bo +edu.bo +gob.bo +int.bo +org.bo +net.bo +mil.bo +tv.bo +web.bo +academia.bo +agro.bo +arte.bo +blog.bo +bolivia.bo +ciencia.bo +cooperativa.bo +democracia.bo +deporte.bo +ecologia.bo +economia.bo +empresa.bo +indigena.bo +industria.bo +info.bo +medicina.bo +movimiento.bo +musica.bo +natural.bo +nombre.bo +noticias.bo +patria.bo +politica.bo +profesional.bo +plurinacional.bo +pueblo.bo +revista.bo +salud.bo +tecnologia.bo +tksat.bo +transporte.bo +wiki.bo +br +9guacu.br +abc.br +adm.br +adv.br +agr.br +aju.br +am.br +anani.br +aparecida.br +arq.br +art.br +ato.br +b.br +barueri.br +belem.br +bhz.br +bio.br +blog.br +bmd.br +boavista.br +bsb.br +campinagrande.br +campinas.br +caxias.br +cim.br +cng.br +cnt.br +com.br +contagem.br +coop.br +cri.br +cuiaba.br +curitiba.br +def.br +ecn.br +eco.br +edu.br +emp.br +eng.br +esp.br +etc.br +eti.br +far.br +feira.br +flog.br +floripa.br +fm.br +fnd.br +fortal.br +fot.br +foz.br +fst.br +g12.br +ggf.br +goiania.br +gov.br +ac.gov.br +al.gov.br +am.gov.br +ap.gov.br +ba.gov.br +ce.gov.br +df.gov.br +es.gov.br +go.gov.br +ma.gov.br +mg.gov.br +ms.gov.br +mt.gov.br +pa.gov.br +pb.gov.br +pe.gov.br +pi.gov.br +pr.gov.br +rj.gov.br +rn.gov.br +ro.gov.br +rr.gov.br +rs.gov.br +sc.gov.br +se.gov.br +sp.gov.br +to.gov.br +gru.br +imb.br +ind.br +inf.br +jab.br +jampa.br +jdf.br +joinville.br +jor.br +jus.br +leg.br +lel.br +londrina.br +macapa.br +maceio.br +manaus.br +maringa.br +mat.br +med.br +mil.br +morena.br +mp.br +mus.br +natal.br +net.br +niteroi.br +nnot.br +ntr.br +odo.br +ong.br +org.br +osasco.br +palmas.br +poa.br +ppg.br +pro.br +psc.br +psi.br +pvh.br +qsl.br +radio.br +rec.br +recife.br +ribeirao.br +rio.br +riobranco.br +riopreto.br +salvador.br +sampa.br +santamaria.br +santoandre.br +saobernardo.br +saogonca.br +sjc.br +slg.br +slz.br +sorocaba.br +srv.br +taxi.br +teo.br +the.br +tmp.br +trd.br +tur.br +tv.br +udi.br +vet.br +vix.br +vlog.br +wiki.br +zlg.br +bs +com.bs +net.bs +org.bs +edu.bs +gov.bs +bt +com.bt +edu.bt +gov.bt +net.bt +org.bt +bv +bw +co.bw +org.bw +by +gov.by +mil.by +com.by +of.by +bz +com.bz +net.bz +org.bz +edu.bz +gov.bz +ca +ab.ca +bc.ca +mb.ca +nb.ca +nf.ca +nl.ca +ns.ca +nt.ca +nu.ca +on.ca +pe.ca +qc.ca +sk.ca +yk.ca +gc.ca +cat +cc +cd +gov.cd +cf +cg +ch +ci +org.ci +or.ci +com.ci +co.ci +edu.ci +ed.ci +ac.ci +net.ci +go.ci +asso.ci +aéroport.ci +int.ci +presse.ci +md.ci +gouv.ci +c!www.ck +cl +gov.cl +gob.cl +co.cl +mil.cl +cm +co.cm +com.cm +gov.cm +net.cm +cn +ac.cn +com.cn +edu.cn +gov.cn +net.cn +org.cn +mil.cn +公司.cn +网络.cn +網絡.cn +ah.cn +bj.cn +cq.cn +fj.cn +gd.cn +gs.cn +gz.cn +gx.cn +ha.cn +hb.cn +he.cn +hi.cn +hl.cn +hn.cn +jl.cn +js.cn +jx.cn +ln.cn +nm.cn +nx.cn +qh.cn +sc.cn +sd.cn +sh.cn +sn.cn +sx.cn +tj.cn +xj.cn +xz.cn +yn.cn +zj.cn +hk.cn +mo.cn +tw.cn +co +arts.co +com.co +edu.co +firm.co +gov.co +info.co +int.co +mil.co +net.co +nom.co +org.co +rec.co +web.co +com +coop +cr +ac.cr +co.cr +ed.cr +fi.cr +go.cr +or.cr +sa.cr +cu +com.cu +edu.cu +org.cu +net.cu +gov.cu +inf.cu +cv +cw +com.cw +edu.cw +net.cw +org.cw +cx +gov.cx +cy +ac.cy +biz.cy +com.cy +ekloges.cy +gov.cy +ltd.cy +name.cy +net.cy +org.cy +parliament.cy +press.cy +pro.cy +tm.cy +cz +de +dj +dk +dm +com.dm +net.dm +org.dm +edu.dm +gov.dm +do +art.do +com.do +edu.do +gob.do +gov.do +mil.do +net.do +org.do +sld.do +web.do +dz +com.dz +org.dz +net.dz +gov.dz +edu.dz +asso.dz +pol.dz +art.dz +ec +com.ec +info.ec +net.ec +fin.ec +k12.ec +med.ec +pro.ec +org.ec +edu.ec +gov.ec +gob.ec +mil.ec +edu +ee +edu.ee +gov.ee +riik.ee +lib.ee +med.ee +com.ee +pri.ee +aip.ee +org.ee +fie.ee +eg +com.eg +edu.eg +eun.eg +gov.eg +mil.eg +name.eg +net.eg +org.eg +sci.eg +ees +com.es +nom.es +org.es +gob.es +edu.es +et +com.et +gov.et +org.et +edu.et +biz.et +name.et +info.et +net.et +eu +fi +aland.fi +fffm +fo +fr +asso.fr +com.fr +gouv.fr +nom.fr +prd.fr +tm.fr +aeroport.fr +avocat.fr +avoues.fr +cci.fr +chambagri.fr +chirurgiens-dentistes.fr +experts-comptables.fr +geometre-expert.fr +greta.fr +huissier-justice.fr +medecin.fr +notaires.fr +pharmacien.fr +port.fr +veterinaire.fr +ga +gb +gd +ge +com.ge +edu.ge +gov.ge +org.ge +mil.ge +net.ge +pvt.ge +gf +gg +co.gg +net.gg +org.gg +gh +com.gh +edu.gh +gov.gh +org.gh +mil.gh +gi +com.gi +ltd.gi +gov.gi +mod.gi +edu.gi +org.gi +gl +co.gl +com.gl +edu.gl +net.gl +org.gl +gm +gn +ac.gn +com.gn +edu.gn +gov.gn +org.gn +net.gn +gov +gp +com.gp +net.gp +mobi.gp +edu.gp +org.gp +asso.gp +gq +gr +com.gr +edu.gr +net.gr +org.gr +gov.gr +gs +gt +com.gt +edu.gt +gob.gt +ind.gt +mil.gt +net.gt +org.gt +gu +com.gu +edu.gu +gov.gu +guam.gu +info.gu +net.gu +org.gu +web.gu +gw +gy +co.gy +com.gy +edu.gy +gov.gy +net.gy +org.gy +hk +com.hk +edu.hk +gov.hk +idv.hk +net.hk +org.hk +公司.hk +教育.hk +敎育.hk +政府.hk +個人.hk +个人.hk +箇人.hk +網络.hk +网络.hk +组織.hk +網絡.hk +网絡.hk +组织.hk +組織.hk +組织.hk +hm +hn +com.hn +edu.hn +org.hn +net.hn +mil.hn +gob.hn +hr +iz.hr +from.hr +name.hr +com.hr +ht +com.ht +shop.ht +firm.ht +info.ht +adult.ht +net.ht +pro.ht +org.ht +med.ht +art.ht +coop.ht +pol.ht +asso.ht +edu.ht +rel.ht +gouv.ht +perso.ht +hu +co.hu +info.hu +org.hu +priv.hu +sport.hu +tm.hu +2000.hu +agrar.hu +bolt.hu +casino.hu +city.hu +erotica.hu +erotika.hu +film.hu +forum.hu +games.hu +hotel.hu +ingatlan.hu +jogasz.hu +konyvelo.hu +lakas.hu +media.hu +news.hu +reklam.hu +sex.hu +shop.hu +suli.hu +szex.hu +tozsde.hu +utazas.hu +video.hu +id +ac.id +biz.id +co.id +desa.id +go.id +mil.id +my.id +net.id +or.id +ponpes.id +sch.id +web.id +ie +gov.ie +il +ac.il +co.il +gov.il +idf.il +k12.il +muni.il +net.il +org.il +im +ac.im +co.im +com.im +ltd.co.im +net.im +org.im +plc.co.im +tt.im +tv.im +in +co.in +firm.in +net.in +org.in +gen.in +ind.in +nic.in +ac.in +edu.in +res.in +gov.in +mil.in +info +int +eu.int +io +com.io +iq +gov.iq +edu.iq +mil.iq +com.iq +org.iq +net.iq +ir +ac.ir +co.ir +gov.ir +id.ir +net.ir +org.ir +sch.ir +ایران.ir +ايران.ir +is +net.is +com.is +edu.is +gov.is +org.is +int.is +it +gov.it +edu.it +abr.it +abruzzo.it +aosta-valley.it +aostavalley.it +bas.it +basilicata.it +cal.it +calabria.it +cam.it +campania.it +emilia-romagna.it +emiliaromagna.it +emr.it +friuli-v-giulia.it +friuli-ve-giulia.it +friuli-vegiulia.it +friuli-venezia-giulia.it +friuli-veneziagiulia.it +friuli-vgiulia.it +friuliv-giulia.it +friulive-giulia.it +friulivegiulia.it +friulivenezia-giulia.it +friuliveneziagiulia.it +friulivgiulia.it +fvg.it +laz.it +lazio.it +lig.it +liguria.it +lom.it +lombardia.it +lombardy.it +lucania.it +mar.it +marche.it +mol.it +molise.it +piedmont.it +piemonte.it +pmn.it +pug.it +puglia.it +sar.it +sardegna.it +sardinia.it +sic.it +sicilia.it +sicily.it +taa.it +tos.it +toscana.it +trentin-sud-tirol.it +trentin-süd-tirol.it +trentin-sudtirol.it +trentin-südtirol.it +trentin-sued-tirol.it +trentin-suedtirol.it +trentino-a-adige.it +trentino-aadige.it +trentino-alto-adige.it +trentino-altoadige.it +trentino-s-tirol.it +trentino-stirol.it +trentino-sud-tirol.it +trentino-süd-tirol.it +trentino-sudtirol.it +trentino-südtirol.it +trentino-sued-tirol.it +trentino-suedtirol.it +trentino.it +trentinoa-adige.it +trentinoaadige.it +trentinoalto-adige.it +trentinoaltoadige.it +trentinos-tirol.it +trentinostirol.it +trentinosud-tirol.it +trentinosüd-tirol.it +trentinosudtirol.it +trentinosüdtirol.it +trentinosued-tirol.it +trentinosuedtirol.it +trentinsud-tirol.it +trentinsüd-tirol.it +trentinsudtirol.it +trentinsüdtirol.it +trentinsued-tirol.it +trentinsuedtirol.it +tuscany.it +umb.it +umbria.it +val-d-aosta.it +val-daosta.it +vald-aosta.it +valdaosta.it +valle-aosta.it +valle-d-aosta.it +valle-daosta.it +valleaosta.it +valled-aosta.it +valledaosta.it +vallee-aoste.it +vallée-aoste.it +vallee-d-aoste.it +vallée-d-aoste.it +valleeaoste.it +valléeaoste.it +valleedaoste.it +valléedaoste.it +vao.it +vda.it +ven.it +veneto.it +ag.it +agrigento.it +al.it +alessandria.it +alto-adige.it +altoadige.it +an.it +ancona.it +andria-barletta-trani.it +andria-trani-barletta.it +andriabarlettatrani.it +andriatranibarletta.it +ao.it +aosta.it +aoste.it +ap.it +aq.it +aquila.it +ar.it +arezzo.it +ascoli-piceno.it +ascolipiceno.it +asti.it +at.it +av.it +avellino.it +ba.it +balsan-sudtirol.it +balsan-südtirol.it +balsan-suedtirol.it +balsan.it +bari.it +barletta-trani-andria.it +barlettatraniandria.it +belluno.it +benevento.it +bergamo.it +bg.it +bi.it +biella.it +bl.it +bn.it +bo.it +bologna.it +bolzano-altoadige.it +bolzano.it +bozen-sudtirol.it +bozen-südtirol.it +bozen-suedtirol.it +bozen.it +br.it +brescia.it +brindisi.it +bs.it +bt.it +bulsan-sudtirol.it +bulsan-südtirol.it +bulsan-suedtirol.it +bulsan.it +bz.it +ca.it +cagliari.it +caltanissetta.it +campidano-medio.it +campidanomedio.it +campobasso.it +carbonia-iglesias.it +carboniaiglesias.it +carrara-massa.it +carraramassa.it +caserta.it +catania.it +catanzaro.it +cb.it +ce.it +cesena-forli.it +cesena-forlì.it +cesenaforli.it +cesenaforlì.it +ch.it +chieti.it +ci.it +cl.it +cn.it +co.it +como.it +cosenza.it +cr.it +cremona.it +crotone.it +cs.it +ct.it +cuneo.it +cz.it +dell-ogliastra.it +dellogliastra.it +en.it +enna.it +fc.it +fe.it +fermo.it +ferrara.it +fg.it +fi.it +firenze.it +florence.it +fm.it +foggia.it +forli-cesena.it +forlì-cesena.it +forlicesena.it +forlìcesena.it +fr.it +frosinone.it +ge.it +genoa.it +genova.it +go.it +gorizia.it +gr.it +grosseto.it +iglesias-carbonia.it +iglesiascarbonia.it +im.it +imperia.it +is.it +isernia.it +kr.it +la-spezia.it +laquila.it +laspezia.it +latina.it +lc.it +le.it +lecce.it +lecco.it +li.it +livorno.it +lo.it +lodi.it +lt.it +lu.it +lucca.it +macerata.it +mantova.it +massa-carrara.it +massacarrara.it +matera.it +mb.it +mc.it +me.it +medio-campidano.it +mediocampidano.it +messina.it +mi.it +milan.it +milano.it +mn.it +mo.it +modena.it +monza-brianza.it +monza-e-della-brianza.it +monza.it +monzabrianza.it +monzaebrianza.it +monzaedellabrianza.it +ms.it +mt.it +na.it +naples.it +napoli.it +no.it +novara.it +nu.it +nuoro.it +og.it +ogliastra.it +olbia-tempio.it +olbiatempio.it +or.it +oristano.it +ot.it +pa.it +padova.it +padua.it +palermo.it +parma.it +pavia.it +pc.it +pd.it +pe.it +perugia.it +pesaro-urbino.it +pesarourbino.it +pescara.it +pg.it +pi.it +piacenza.it +pisa.it +pistoia.it +pn.it +po.it +pordenone.it +potenza.it +pr.it +prato.it +pt.it +pu.it +pv.it +pz.it +ra.it +ragusa.it +ravenna.it +rc.it +re.it +reggio-calabria.it +reggio-emilia.it +reggiocalabria.it +reggioemilia.it +rg.it +ri.it +rieti.it +rimini.it +rm.it +rn.it +ro.it +roma.it +rome.it +rovigo.it +sa.it +salerno.it +sassari.it +savona.it +si.it +siena.it +siracusa.it +so.it +sondrio.it +sp.it +sr.it +ss.it +suedtirol.it +südtirol.it +sv.it +ta.it +taranto.it +te.it +tempio-olbia.it +tempioolbia.it +teramo.it +terni.it +tn.it +to.it +torino.it +tp.it +tr.it +trani-andria-barletta.it +trani-barletta-andria.it +traniandriabarletta.it +tranibarlettaandria.it +trapani.it +trento.it +treviso.it +trieste.it +ts.it +turin.it +tv.it +ud.it +udine.it +urbino-pesaro.it +urbinopesaro.it +va.it +varese.it +vb.it +vc.it +ve.it +venezia.it +venice.it +verbania.it +vercelli.it +verona.it +vi.it +vibo-valentia.it +vibovalentia.it +vicenza.it +viterbo.it +vr.it +vs.it +vt.it +vv.it +je +co.je +net.je +org.je +jjo +com.jo +org.jo +net.jo +edu.jo +sch.jo +gov.jo +mil.jo +name.jo +jobs +jp +ac.jp +ad.jp +co.jp +ed.jp +go.jp +gr.jp +lg.jp +ne.jp +or.jp +aichi.jp +akita.jp +aomori.jp +chiba.jp +ehime.jp +fukui.jp +fukuoka.jp +fukushima.jp +gifu.jp +gunma.jp +hiroshima.jp +hokkaido.jp +hyogo.jp +ibaraki.jp +ishikawa.jp +iwate.jp +kagawa.jp +kagoshima.jp +kanagawa.jp +kochi.jp +kumamoto.jp +kyoto.jp +mie.jp +miyagi.jp +miyazaki.jp +nagano.jp +nagasaki.jp +nara.jp +niigata.jp +oita.jp +okayama.jp +okinawa.jp +osaka.jp +saga.jp +saitama.jp +shiga.jp +shimane.jp +shizuoka.jp +tochigi.jp +tokushima.jp +tokyo.jp +tottori.jp +toyama.jp +wakayama.jp +yamagata.jp +yamaguchi.jp +yamanashi.jp +栃木.jp +愛知.jp +愛媛.jp +兵庫.jp +熊本.jp +茨城.jp +北海道.jp +千葉.jp +和歌山.jp +長崎.jp +長野.jp +新潟.jp +青森.jp +静岡.jp +東京.jp +石川.jp +埼玉.jp +三重.jp +京都.jp +佐賀.jp +大分.jp +大阪.jp +奈良.jp +宮城.jp +宮崎.jp +富山.jp +山口.jp +山形.jp +山梨.jp +岩手.jp +岐阜.jp +岡山.jp +島根.jp +広島.jp +徳島.jp +沖縄.jp +滋賀.jp +神奈川.jp +福井.jp +福岡.jp +福島.jp +秋田.jp +群馬.jp +香川.jp +高知.jp +鳥取.jp +鹿児島.jp +kkknssy!city.kawasaki.jp +!city.kitakyushu.jp +!city.kobe.jp +!city.nagoya.jp +!city.sapporo.jp +!city.sendai.jp +!city.yokohama.jp +aisai.aichi.jp +ama.aichi.jp +anjo.aichi.jp +asuke.aichi.jp +chiryu.aichi.jp +chita.aichi.jp +fuso.aichi.jp +gamagori.aichi.jp +handa.aichi.jp +hazu.aichi.jp +hekinan.aichi.jp +higashiura.aichi.jp +ichinomiya.aichi.jp +inazawa.aichi.jp +inuyama.aichi.jp +isshiki.aichi.jp +iwakura.aichi.jp +kanie.aichi.jp +kariya.aichi.jp +kasugai.aichi.jp +kira.aichi.jp +kiyosu.aichi.jp +komaki.aichi.jp +konan.aichi.jp +kota.aichi.jp +mihama.aichi.jp +miyoshi.aichi.jp +nishio.aichi.jp +nisshin.aichi.jp +obu.aichi.jp +oguchi.aichi.jp +oharu.aichi.jp +okazaki.aichi.jp +owariasahi.aichi.jp +seto.aichi.jp +shikatsu.aichi.jp +shinshiro.aichi.jp +shitara.aichi.jp +tahara.aichi.jp +takahama.aichi.jp +tobishima.aichi.jp +toei.aichi.jp +togo.aichi.jp +tokai.aichi.jp +tokoname.aichi.jp +toyoake.aichi.jp +toyohashi.aichi.jp +toyokawa.aichi.jp +toyone.aichi.jp +toyota.aichi.jp +tsushima.aichi.jp +yatomi.aichi.jp +akita.akita.jp +daisen.akita.jp +fujisato.akita.jp +gojome.akita.jp +hachirogata.akita.jp +happou.akita.jp +higashinaruse.akita.jp +honjo.akita.jp +honjyo.akita.jp +ikawa.akita.jp +kamikoani.akita.jp +kamioka.akita.jp +katagami.akita.jp +kazuno.akita.jp +kitaakita.akita.jp +kosaka.akita.jp +kyowa.akita.jp +misato.akita.jp +mitane.akita.jp +moriyoshi.akita.jp +nikaho.akita.jp +noshiro.akita.jp +odate.akita.jp +oga.akita.jp +ogata.akita.jp +semboku.akita.jp +yokote.akita.jp +yurihonjo.akita.jp +aomori.aomori.jp +gonohe.aomori.jp +hachinohe.aomori.jp +hashikami.aomori.jp +hiranai.aomori.jp +hirosaki.aomori.jp +itayanagi.aomori.jp +kuroishi.aomori.jp +misawa.aomori.jp +mutsu.aomori.jp +nakadomari.aomori.jp +noheji.aomori.jp +oirase.aomori.jp +owani.aomori.jp +rokunohe.aomori.jp +sannohe.aomori.jp +shichinohe.aomori.jp +shingo.aomori.jp +takko.aomori.jp +towada.aomori.jp +tsugaru.aomori.jp +tsuruta.aomori.jp +abiko.chiba.jp +asahi.chiba.jp +chonan.chiba.jp +chosei.chiba.jp +choshi.chiba.jp +chuo.chiba.jp +funabashi.chiba.jp +futtsu.chiba.jp +hanamigawa.chiba.jp +ichihara.chiba.jp +ichikawa.chiba.jp +ichinomiya.chiba.jp +inzai.chiba.jp +isumi.chiba.jp +kamagaya.chiba.jp +kamogawa.chiba.jp +kashiwa.chiba.jp +katori.chiba.jp +katsuura.chiba.jp +kimitsu.chiba.jp +kisarazu.chiba.jp +kozaki.chiba.jp +kujukuri.chiba.jp +kyonan.chiba.jp +matsudo.chiba.jp +midori.chiba.jp +mihama.chiba.jp +minamiboso.chiba.jp +mobara.chiba.jp +mutsuzawa.chiba.jp +nagara.chiba.jp +nagareyama.chiba.jp +narashino.chiba.jp +narita.chiba.jp +noda.chiba.jp +oamishirasato.chiba.jp +omigawa.chiba.jp +onjuku.chiba.jp +otaki.chiba.jp +sakae.chiba.jp +sakura.chiba.jp +shimofusa.chiba.jp +shirako.chiba.jp +shiroi.chiba.jp +shisui.chiba.jp +sodegaura.chiba.jp +sosa.chiba.jp +tako.chiba.jp +tateyama.chiba.jp +togane.chiba.jp +tohnosho.chiba.jp +tomisato.chiba.jp +urayasu.chiba.jp +yachimata.chiba.jp +yachiyo.chiba.jp +yokaichiba.chiba.jp +yokoshibahikari.chiba.jp +yotsukaido.chiba.jp +ainan.ehime.jp +honai.ehime.jp +ikata.ehime.jp +imabari.ehime.jp +iyo.ehime.jp +kamijima.ehime.jp +kihoku.ehime.jp +kumakogen.ehime.jp +masaki.ehime.jp +matsuno.ehime.jp +matsuyama.ehime.jp +namikata.ehime.jp +niihama.ehime.jp +ozu.ehime.jp +saijo.ehime.jp +seiyo.ehime.jp +shikokuchuo.ehime.jp +tobe.ehime.jp +toon.ehime.jp +uchiko.ehime.jp +uwajima.ehime.jp +yawatahama.ehime.jp +echizen.fukui.jp +eiheiji.fukui.jp +fukui.fukui.jp +ikeda.fukui.jp +katsuyama.fukui.jp +mihama.fukui.jp +minamiechizen.fukui.jp +obama.fukui.jp +ohi.fukui.jp +ono.fukui.jp +sabae.fukui.jp +sakai.fukui.jp +takahama.fukui.jp +tsuruga.fukui.jp +wakasa.fukui.jp +ashiya.fukuoka.jp +buzen.fukuoka.jp +chikugo.fukuoka.jp +chikuho.fukuoka.jp +chikujo.fukuoka.jp +chikushino.fukuoka.jp +chikuzen.fukuoka.jp +chuo.fukuoka.jp +dazaifu.fukuoka.jp +fukuchi.fukuoka.jp +hakata.fukuoka.jp +higashi.fukuoka.jp +hirokawa.fukuoka.jp +hisayama.fukuoka.jp +iizuka.fukuoka.jp +inatsuki.fukuoka.jp +kaho.fukuoka.jp +kasuga.fukuoka.jp +kasuya.fukuoka.jp +kawara.fukuoka.jp +keisen.fukuoka.jp +koga.fukuoka.jp +kurate.fukuoka.jp +kurogi.fukuoka.jp +kurume.fukuoka.jp +minami.fukuoka.jp +miyako.fukuoka.jp +miyama.fukuoka.jp +miyawaka.fukuoka.jp +mizumaki.fukuoka.jp +munakata.fukuoka.jp +nakagawa.fukuoka.jp +nakama.fukuoka.jp +nishi.fukuoka.jp +nogata.fukuoka.jp +ogori.fukuoka.jp +okagaki.fukuoka.jp +okawa.fukuoka.jp +oki.fukuoka.jp +omuta.fukuoka.jp +onga.fukuoka.jp +onojo.fukuoka.jp +oto.fukuoka.jp +saigawa.fukuoka.jp +sasaguri.fukuoka.jp +shingu.fukuoka.jp +shinyoshitomi.fukuoka.jp +shonai.fukuoka.jp +soeda.fukuoka.jp +sue.fukuoka.jp +tachiarai.fukuoka.jp +tagawa.fukuoka.jp +takata.fukuoka.jp +toho.fukuoka.jp +toyotsu.fukuoka.jp +tsuiki.fukuoka.jp +ukiha.fukuoka.jp +umi.fukuoka.jp +usui.fukuoka.jp +yamada.fukuoka.jp +yame.fukuoka.jp +yanagawa.fukuoka.jp +yukuhashi.fukuoka.jp +aizubange.fukushima.jp +aizumisato.fukushima.jp +aizuwakamatsu.fukushima.jp +asakawa.fukushima.jp +bandai.fukushima.jp +date.fukushima.jp +fukushima.fukushima.jp +furudono.fukushima.jp +futaba.fukushima.jp +hanawa.fukushima.jp +higashi.fukushima.jp +hirata.fukushima.jp +hirono.fukushima.jp +iitate.fukushima.jp +inawashiro.fukushima.jp +ishikawa.fukushima.jp +iwaki.fukushima.jp +izumizaki.fukushima.jp +kagamiishi.fukushima.jp +kaneyama.fukushima.jp +kawamata.fukushima.jp +kitakata.fukushima.jp +kitashiobara.fukushima.jp +koori.fukushima.jp +koriyama.fukushima.jp +kunimi.fukushima.jp +miharu.fukushima.jp +mishima.fukushima.jp +namie.fukushima.jp +nango.fukushima.jp +nishiaizu.fukushima.jp +nishigo.fukushima.jp +okuma.fukushima.jp +omotego.fukushima.jp +ono.fukushima.jp +otama.fukushima.jp +samegawa.fukushima.jp +shimogo.fukushima.jp +shirakawa.fukushima.jp +showa.fukushima.jp +soma.fukushima.jp +sukagawa.fukushima.jp +taishin.fukushima.jp +tamakawa.fukushima.jp +tanagura.fukushima.jp +tenei.fukushima.jp +yabuki.fukushima.jp +yamato.fukushima.jp +yamatsuri.fukushima.jp +yanaizu.fukushima.jp +yugawa.fukushima.jp +anpachi.gifu.jp +ena.gifu.jp +gifu.gifu.jp +ginan.gifu.jp +godo.gifu.jp +gujo.gifu.jp +hashima.gifu.jp +hichiso.gifu.jp +hida.gifu.jp +higashishirakawa.gifu.jp +ibigawa.gifu.jp +ikeda.gifu.jp +kakamigahara.gifu.jp +kani.gifu.jp +kasahara.gifu.jp +kasamatsu.gifu.jp +kawaue.gifu.jp +kitagata.gifu.jp +mino.gifu.jp +minokamo.gifu.jp +mitake.gifu.jp +mizunami.gifu.jp +motosu.gifu.jp +nakatsugawa.gifu.jp +ogaki.gifu.jp +sakahogi.gifu.jp +seki.gifu.jp +sekigahara.gifu.jp +shirakawa.gifu.jp +tajimi.gifu.jp +takayama.gifu.jp +tarui.gifu.jp +toki.gifu.jp +tomika.gifu.jp +wanouchi.gifu.jp +yamagata.gifu.jp +yaotsu.gifu.jp +yoro.gifu.jp +annaka.gunma.jp +chiyoda.gunma.jp +fujioka.gunma.jp +higashiagatsuma.gunma.jp +isesaki.gunma.jp +itakura.gunma.jp +kanna.gunma.jp +kanra.gunma.jp +katashina.gunma.jp +kawaba.gunma.jp +kiryu.gunma.jp +kusatsu.gunma.jp +maebashi.gunma.jp +meiwa.gunma.jp +midori.gunma.jp +minakami.gunma.jp +naganohara.gunma.jp +nakanojo.gunma.jp +nanmoku.gunma.jp +numata.gunma.jp +oizumi.gunma.jp +ora.gunma.jp +ota.gunma.jp +shibukawa.gunma.jp +shimonita.gunma.jp +shinto.gunma.jp +showa.gunma.jp +takasaki.gunma.jp +takayama.gunma.jp +tamamura.gunma.jp +tatebayashi.gunma.jp +tomioka.gunma.jp +tsukiyono.gunma.jp +tsumagoi.gunma.jp +ueno.gunma.jp +yoshioka.gunma.jp +asaminami.hiroshima.jp +daiwa.hiroshima.jp +etajima.hiroshima.jp +fuchu.hiroshima.jp +fukuyama.hiroshima.jp +hatsukaichi.hiroshima.jp +higashihiroshima.hiroshima.jp +hongo.hiroshima.jp +jinsekikogen.hiroshima.jp +kaita.hiroshima.jp +kui.hiroshima.jp +kumano.hiroshima.jp +kure.hiroshima.jp +mihara.hiroshima.jp +miyoshi.hiroshima.jp +naka.hiroshima.jp +onomichi.hiroshima.jp +osakikamijima.hiroshima.jp +otake.hiroshima.jp +saka.hiroshima.jp +sera.hiroshima.jp +seranishi.hiroshima.jp +shinichi.hiroshima.jp +shobara.hiroshima.jp +takehara.hiroshima.jp +abashiri.hokkaido.jp +abira.hokkaido.jp +aibetsu.hokkaido.jp +akabira.hokkaido.jp +akkeshi.hokkaido.jp +asahikawa.hokkaido.jp +ashibetsu.hokkaido.jp +ashoro.hokkaido.jp +assabu.hokkaido.jp +atsuma.hokkaido.jp +bibai.hokkaido.jp +biei.hokkaido.jp +bifuka.hokkaido.jp +bihoro.hokkaido.jp +biratori.hokkaido.jp +chippubetsu.hokkaido.jp +chitose.hokkaido.jp +date.hokkaido.jp +ebetsu.hokkaido.jp +embetsu.hokkaido.jp +eniwa.hokkaido.jp +erimo.hokkaido.jp +esan.hokkaido.jp +esashi.hokkaido.jp +fukagawa.hokkaido.jp +fukushima.hokkaido.jp +furano.hokkaido.jp +furubira.hokkaido.jp +haboro.hokkaido.jp +hakodate.hokkaido.jp +hamatonbetsu.hokkaido.jp +hidaka.hokkaido.jp +higashikagura.hokkaido.jp +higashikawa.hokkaido.jp +hiroo.hokkaido.jp +hokuryu.hokkaido.jp +hokuto.hokkaido.jp +honbetsu.hokkaido.jp +horokanai.hokkaido.jp +horonobe.hokkaido.jp +ikeda.hokkaido.jp +imakane.hokkaido.jp +ishikari.hokkaido.jp +iwamizawa.hokkaido.jp +iwanai.hokkaido.jp +kamifurano.hokkaido.jp +kamikawa.hokkaido.jp +kamishihoro.hokkaido.jp +kamisunagawa.hokkaido.jp +kamoenai.hokkaido.jp +kayabe.hokkaido.jp +kembuchi.hokkaido.jp +kikonai.hokkaido.jp +kimobetsu.hokkaido.jp +kitahiroshima.hokkaido.jp +kitami.hokkaido.jp +kiyosato.hokkaido.jp +koshimizu.hokkaido.jp +kunneppu.hokkaido.jp +kuriyama.hokkaido.jp +kuromatsunai.hokkaido.jp +kushiro.hokkaido.jp +kutchan.hokkaido.jp +kyowa.hokkaido.jp +mashike.hokkaido.jp +matsumae.hokkaido.jp +mikasa.hokkaido.jp +minamifurano.hokkaido.jp +mombetsu.hokkaido.jp +moseushi.hokkaido.jp +mukawa.hokkaido.jp +muroran.hokkaido.jp +naie.hokkaido.jp +nakagawa.hokkaido.jp +nakasatsunai.hokkaido.jp +nakatombetsu.hokkaido.jp +nanae.hokkaido.jp +nanporo.hokkaido.jp +nayoro.hokkaido.jp +nemuro.hokkaido.jp +niikappu.hokkaido.jp +niki.hokkaido.jp +nishiokoppe.hokkaido.jp +noboribetsu.hokkaido.jp +numata.hokkaido.jp +obihiro.hokkaido.jp +obira.hokkaido.jp +oketo.hokkaido.jp +okoppe.hokkaido.jp +otaru.hokkaido.jp +otobe.hokkaido.jp +otofuke.hokkaido.jp +otoineppu.hokkaido.jp +oumu.hokkaido.jp +ozora.hokkaido.jp +pippu.hokkaido.jp +rankoshi.hokkaido.jp +rebun.hokkaido.jp +rikubetsu.hokkaido.jp +rishiri.hokkaido.jp +rishirifuji.hokkaido.jp +saroma.hokkaido.jp +sarufutsu.hokkaido.jp +shakotan.hokkaido.jp +shari.hokkaido.jp +shibecha.hokkaido.jp +shibetsu.hokkaido.jp +shikabe.hokkaido.jp +shikaoi.hokkaido.jp +shimamaki.hokkaido.jp +shimizu.hokkaido.jp +shimokawa.hokkaido.jp +shinshinotsu.hokkaido.jp +shintoku.hokkaido.jp +shiranuka.hokkaido.jp +shiraoi.hokkaido.jp +shiriuchi.hokkaido.jp +sobetsu.hokkaido.jp +sunagawa.hokkaido.jp +taiki.hokkaido.jp +takasu.hokkaido.jp +takikawa.hokkaido.jp +takinoue.hokkaido.jp +teshikaga.hokkaido.jp +tobetsu.hokkaido.jp +tohma.hokkaido.jp +tomakomai.hokkaido.jp +tomari.hokkaido.jp +toya.hokkaido.jp +toyako.hokkaido.jp +toyotomi.hokkaido.jp +toyoura.hokkaido.jp +tsubetsu.hokkaido.jp +tsukigata.hokkaido.jp +urakawa.hokkaido.jp +urausu.hokkaido.jp +uryu.hokkaido.jp +utashinai.hokkaido.jp +wakkanai.hokkaido.jp +wassamu.hokkaido.jp +yakumo.hokkaido.jp +yoichi.hokkaido.jp +aioi.hyogo.jp +akashi.hyogo.jp +ako.hyogo.jp +amagasaki.hyogo.jp +aogaki.hyogo.jp +asago.hyogo.jp +ashiya.hyogo.jp +awaji.hyogo.jp +fukusaki.hyogo.jp +goshiki.hyogo.jp +harima.hyogo.jp +himeji.hyogo.jp +ichikawa.hyogo.jp +inagawa.hyogo.jp +itami.hyogo.jp +kakogawa.hyogo.jp +kamigori.hyogo.jp +kamikawa.hyogo.jp +kasai.hyogo.jp +kasuga.hyogo.jp +kawanishi.hyogo.jp +miki.hyogo.jp +minamiawaji.hyogo.jp +nishinomiya.hyogo.jp +nishiwaki.hyogo.jp +ono.hyogo.jp +sanda.hyogo.jp +sannan.hyogo.jp +sasayama.hyogo.jp +sayo.hyogo.jp +shingu.hyogo.jp +shinonsen.hyogo.jp +shiso.hyogo.jp +sumoto.hyogo.jp +taishi.hyogo.jp +taka.hyogo.jp +takarazuka.hyogo.jp +takasago.hyogo.jp +takino.hyogo.jp +tamba.hyogo.jp +tatsuno.hyogo.jp +toyooka.hyogo.jp +yabu.hyogo.jp +yashiro.hyogo.jp +yoka.hyogo.jp +yokawa.hyogo.jp +ami.ibaraki.jp +asahi.ibaraki.jp +bando.ibaraki.jp +chikusei.ibaraki.jp +daigo.ibaraki.jp +fujishiro.ibaraki.jp +hitachi.ibaraki.jp +hitachinaka.ibaraki.jp +hitachiomiya.ibaraki.jp +hitachiota.ibaraki.jp +ibaraki.ibaraki.jp +ina.ibaraki.jp +inashiki.ibaraki.jp +itako.ibaraki.jp +iwama.ibaraki.jp +joso.ibaraki.jp +kamisu.ibaraki.jp +kasama.ibaraki.jp +kashima.ibaraki.jp +kasumigaura.ibaraki.jp +koga.ibaraki.jp +miho.ibaraki.jp +mito.ibaraki.jp +moriya.ibaraki.jp +naka.ibaraki.jp +namegata.ibaraki.jp +oarai.ibaraki.jp +ogawa.ibaraki.jp +omitama.ibaraki.jp +ryugasaki.ibaraki.jp +sakai.ibaraki.jp +sakuragawa.ibaraki.jp +shimodate.ibaraki.jp +shimotsuma.ibaraki.jp +shirosato.ibaraki.jp +sowa.ibaraki.jp +suifu.ibaraki.jp +takahagi.ibaraki.jp +tamatsukuri.ibaraki.jp +tokai.ibaraki.jp +tomobe.ibaraki.jp +tone.ibaraki.jp +toride.ibaraki.jp +tsuchiura.ibaraki.jp +tsukuba.ibaraki.jp +uchihara.ibaraki.jp +ushiku.ibaraki.jp +yachiyo.ibaraki.jp +yamagata.ibaraki.jp +yawara.ibaraki.jp +yuki.ibaraki.jp +anamizu.ishikawa.jp +hakui.ishikawa.jp +hakusan.ishikawa.jp +kaga.ishikawa.jp +kahoku.ishikawa.jp +kanazawa.ishikawa.jp +kawakita.ishikawa.jp +komatsu.ishikawa.jp +nakanoto.ishikawa.jp +nanao.ishikawa.jp +nomi.ishikawa.jp +nonoichi.ishikawa.jp +noto.ishikawa.jp +shika.ishikawa.jp +suzu.ishikawa.jp +tsubata.ishikawa.jp +tsurugi.ishikawa.jp +uchinada.ishikawa.jp +wajima.ishikawa.jp +fudai.iwate.jp +fujisawa.iwate.jp +hanamaki.iwate.jp +hiraizumi.iwate.jp +hirono.iwate.jp +ichinohe.iwate.jp +ichinoseki.iwate.jp +iwaizumi.iwate.jp +iwate.iwate.jp +joboji.iwate.jp +kamaishi.iwate.jp +kanegasaki.iwate.jp +karumai.iwate.jp +kawai.iwate.jp +kitakami.iwate.jp +kuji.iwate.jp +kunohe.iwate.jp +kuzumaki.iwate.jp +miyako.iwate.jp +mizusawa.iwate.jp +morioka.iwate.jp +ninohe.iwate.jp +noda.iwate.jp +ofunato.iwate.jp +oshu.iwate.jp +otsuchi.iwate.jp +rikuzentakata.iwate.jp +shiwa.iwate.jp +shizukuishi.iwate.jp +sumita.iwate.jp +tanohata.iwate.jp +tono.iwate.jp +yahaba.iwate.jp +yamada.iwate.jp +ayagawa.kagawa.jp +higashikagawa.kagawa.jp +kanonji.kagawa.jp +kotohira.kagawa.jp +manno.kagawa.jp +marugame.kagawa.jp +mitoyo.kagawa.jp +naoshima.kagawa.jp +sanuki.kagawa.jp +tadotsu.kagawa.jp +takamatsu.kagawa.jp +tonosho.kagawa.jp +uchinomi.kagawa.jp +utazu.kagawa.jp +zentsuji.kagawa.jp +akune.kagoshima.jp +amami.kagoshima.jp +hioki.kagoshima.jp +isa.kagoshima.jp +isen.kagoshima.jp +izumi.kagoshima.jp +kagoshima.kagoshima.jp +kanoya.kagoshima.jp +kawanabe.kagoshima.jp +kinko.kagoshima.jp +kouyama.kagoshima.jp +makurazaki.kagoshima.jp +matsumoto.kagoshima.jp +minamitane.kagoshima.jp +nakatane.kagoshima.jp +nishinoomote.kagoshima.jp +satsumasendai.kagoshima.jp +soo.kagoshima.jp +tarumizu.kagoshima.jp +yusui.kagoshima.jp +aikawa.kanagawa.jp +atsugi.kanagawa.jp +ayase.kanagawa.jp +chigasaki.kanagawa.jp +ebina.kanagawa.jp +fujisawa.kanagawa.jp +hadano.kanagawa.jp +hakone.kanagawa.jp +hiratsuka.kanagawa.jp +isehara.kanagawa.jp +kaisei.kanagawa.jp +kamakura.kanagawa.jp +kiyokawa.kanagawa.jp +matsuda.kanagawa.jp +minamiashigara.kanagawa.jp +miura.kanagawa.jp +nakai.kanagawa.jp +ninomiya.kanagawa.jp +odawara.kanagawa.jp +oi.kanagawa.jp +oiso.kanagawa.jp +sagamihara.kanagawa.jp +samukawa.kanagawa.jp +tsukui.kanagawa.jp +yamakita.kanagawa.jp +yamato.kanagawa.jp +yokosuka.kanagawa.jp +yugawara.kanagawa.jp +zama.kanagawa.jp +zushi.kanagawa.jp +aki.kochi.jp +geisei.kochi.jp +hidaka.kochi.jp +higashitsuno.kochi.jp +ino.kochi.jp +kagami.kochi.jp +kami.kochi.jp +kitagawa.kochi.jp +kochi.kochi.jp +mihara.kochi.jp +motoyama.kochi.jp +muroto.kochi.jp +nahari.kochi.jp +nakamura.kochi.jp +nankoku.kochi.jp +nishitosa.kochi.jp +niyodogawa.kochi.jp +ochi.kochi.jp +okawa.kochi.jp +otoyo.kochi.jp +otsuki.kochi.jp +sakawa.kochi.jp +sukumo.kochi.jp +susaki.kochi.jp +tosa.kochi.jp +tosashimizu.kochi.jp +toyo.kochi.jp +tsuno.kochi.jp +umaji.kochi.jp +yasuda.kochi.jp +yusuhara.kochi.jp +amakusa.kumamoto.jp +arao.kumamoto.jp +aso.kumamoto.jp +choyo.kumamoto.jp +gyokuto.kumamoto.jp +kamiamakusa.kumamoto.jp +kikuchi.kumamoto.jp +kumamoto.kumamoto.jp +mashiki.kumamoto.jp +mifune.kumamoto.jp +minamata.kumamoto.jp +minamioguni.kumamoto.jp +nagasu.kumamoto.jp +nishihara.kumamoto.jp +oguni.kumamoto.jp +ozu.kumamoto.jp +sumoto.kumamoto.jp +takamori.kumamoto.jp +uki.kumamoto.jp +uto.kumamoto.jp +yamaga.kumamoto.jp +yamato.kumamoto.jp +yatsushiro.kumamoto.jp +ayabe.kyoto.jp +fukuchiyama.kyoto.jp +higashiyama.kyoto.jp +ide.kyoto.jp +ine.kyoto.jp +joyo.kyoto.jp +kameoka.kyoto.jp +kamo.kyoto.jp +kita.kyoto.jp +kizu.kyoto.jp +kumiyama.kyoto.jp +kyotamba.kyoto.jp +kyotanabe.kyoto.jp +kyotango.kyoto.jp +maizuru.kyoto.jp +minami.kyoto.jp +minamiyamashiro.kyoto.jp +miyazu.kyoto.jp +muko.kyoto.jp +nagaokakyo.kyoto.jp +nakagyo.kyoto.jp +nantan.kyoto.jp +oyamazaki.kyoto.jp +sakyo.kyoto.jp +seika.kyoto.jp +tanabe.kyoto.jp +uji.kyoto.jp +ujitawara.kyoto.jp +wazuka.kyoto.jp +yamashina.kyoto.jp +yawata.kyoto.jp +asahi.mie.jp +inabe.mie.jp +ise.mie.jp +kameyama.mie.jp +kawagoe.mie.jp +kiho.mie.jp +kisosaki.mie.jp +kiwa.mie.jp +komono.mie.jp +kumano.mie.jp +kuwana.mie.jp +matsusaka.mie.jp +meiwa.mie.jp +mihama.mie.jp +minamiise.mie.jp +misugi.mie.jp +miyama.mie.jp +nabari.mie.jp +shima.mie.jp +suzuka.mie.jp +tado.mie.jp +taiki.mie.jp +taki.mie.jp +tamaki.mie.jp +toba.mie.jp +tsu.mie.jp +udono.mie.jp +ureshino.mie.jp +watarai.mie.jp +yokkaichi.mie.jp +furukawa.miyagi.jp +higashimatsushima.miyagi.jp +ishinomaki.miyagi.jp +iwanuma.miyagi.jp +kakuda.miyagi.jp +kami.miyagi.jp +kawasaki.miyagi.jp +marumori.miyagi.jp +matsushima.miyagi.jp +minamisanriku.miyagi.jp +misato.miyagi.jp +murata.miyagi.jp +natori.miyagi.jp +ogawara.miyagi.jp +ohira.miyagi.jp +onagawa.miyagi.jp +osaki.miyagi.jp +rifu.miyagi.jp +semine.miyagi.jp +shibata.miyagi.jp +shichikashuku.miyagi.jp +shikama.miyagi.jp +shiogama.miyagi.jp +shiroishi.miyagi.jp +tagajo.miyagi.jp +taiwa.miyagi.jp +tome.miyagi.jp +tomiya.miyagi.jp +wakuya.miyagi.jp +watari.miyagi.jp +yamamoto.miyagi.jp +zao.miyagi.jp +aya.miyazaki.jp +ebino.miyazaki.jp +gokase.miyazaki.jp +hyuga.miyazaki.jp +kadogawa.miyazaki.jp +kawaminami.miyazaki.jp +kijo.miyazaki.jp +kitagawa.miyazaki.jp +kitakata.miyazaki.jp +kitaura.miyazaki.jp +kobayashi.miyazaki.jp +kunitomi.miyazaki.jp +kushima.miyazaki.jp +mimata.miyazaki.jp +miyakonojo.miyazaki.jp +miyazaki.miyazaki.jp +morotsuka.miyazaki.jp +nichinan.miyazaki.jp +nishimera.miyazaki.jp +nobeoka.miyazaki.jp +saito.miyazaki.jp +shiiba.miyazaki.jp +shintomi.miyazaki.jp +takaharu.miyazaki.jp +takanabe.miyazaki.jp +takazaki.miyazaki.jp +tsuno.miyazaki.jp +achi.nagano.jp +agematsu.nagano.jp +anan.nagano.jp +aoki.nagano.jp +asahi.nagano.jp +azumino.nagano.jp +chikuhoku.nagano.jp +chikuma.nagano.jp +chino.nagano.jp +fujimi.nagano.jp +hakuba.nagano.jp +hara.nagano.jp +hiraya.nagano.jp +iida.nagano.jp +iijima.nagano.jp +iiyama.nagano.jp +iizuna.nagano.jp +ikeda.nagano.jp +ikusaka.nagano.jp +ina.nagano.jp +karuizawa.nagano.jp +kawakami.nagano.jp +kiso.nagano.jp +kisofukushima.nagano.jp +kitaaiki.nagano.jp +komagane.nagano.jp +komoro.nagano.jp +matsukawa.nagano.jp +matsumoto.nagano.jp +miasa.nagano.jp +minamiaiki.nagano.jp +minamimaki.nagano.jp +minamiminowa.nagano.jp +minowa.nagano.jp +miyada.nagano.jp +miyota.nagano.jp +mochizuki.nagano.jp +nagano.nagano.jp +nagawa.nagano.jp +nagiso.nagano.jp +nakagawa.nagano.jp +nakano.nagano.jp +nozawaonsen.nagano.jp +obuse.nagano.jp +ogawa.nagano.jp +okaya.nagano.jp +omachi.nagano.jp +omi.nagano.jp +ookuwa.nagano.jp +ooshika.nagano.jp +otaki.nagano.jp +otari.nagano.jp +sakae.nagano.jp +sakaki.nagano.jp +saku.nagano.jp +sakuho.nagano.jp +shimosuwa.nagano.jp +shinanomachi.nagano.jp +shiojiri.nagano.jp +suwa.nagano.jp +suzaka.nagano.jp +takagi.nagano.jp +takamori.nagano.jp +takayama.nagano.jp +tateshina.nagano.jp +tatsuno.nagano.jp +togakushi.nagano.jp +togura.nagano.jp +tomi.nagano.jp +ueda.nagano.jp +wada.nagano.jp +yamagata.nagano.jp +yamanouchi.nagano.jp +yasaka.nagano.jp +yasuoka.nagano.jp +chijiwa.nagasaki.jp +futsu.nagasaki.jp +goto.nagasaki.jp +hasami.nagasaki.jp +hirado.nagasaki.jp +iki.nagasaki.jp +isahaya.nagasaki.jp +kawatana.nagasaki.jp +kuchinotsu.nagasaki.jp +matsuura.nagasaki.jp +nagasaki.nagasaki.jp +obama.nagasaki.jp +omura.nagasaki.jp +oseto.nagasaki.jp +saikai.nagasaki.jp +sasebo.nagasaki.jp +seihi.nagasaki.jp +shimabara.nagasaki.jp +shinkamigoto.nagasaki.jp +togitsu.nagasaki.jp +tsushima.nagasaki.jp +unzen.nagasaki.jp +ando.nara.jp +gose.nara.jp +heguri.nara.jp +higashiyoshino.nara.jp +ikaruga.nara.jp +ikoma.nara.jp +kamikitayama.nara.jp +kanmaki.nara.jp +kashiba.nara.jp +kashihara.nara.jp +katsuragi.nara.jp +kawai.nara.jp +kawakami.nara.jp +kawanishi.nara.jp +koryo.nara.jp +kurotaki.nara.jp +mitsue.nara.jp +miyake.nara.jp +nara.nara.jp +nosegawa.nara.jp +oji.nara.jp +ouda.nara.jp +oyodo.nara.jp +sakurai.nara.jp +sango.nara.jp +shimoichi.nara.jp +shimokitayama.nara.jp +shinjo.nara.jp +soni.nara.jp +takatori.nara.jp +tawaramoto.nara.jp +tenkawa.nara.jp +tenri.nara.jp +uda.nara.jp +yamatokoriyama.nara.jp +yamatotakada.nara.jp +yamazoe.nara.jp +yoshino.nara.jp +aga.niigata.jp +agano.niigata.jp +gosen.niigata.jp +itoigawa.niigata.jp +izumozaki.niigata.jp +joetsu.niigata.jp +kamo.niigata.jp +kariwa.niigata.jp +kashiwazaki.niigata.jp +minamiuonuma.niigata.jp +mitsuke.niigata.jp +muika.niigata.jp +murakami.niigata.jp +myoko.niigata.jp +nagaoka.niigata.jp +niigata.niigata.jp +ojiya.niigata.jp +omi.niigata.jp +sado.niigata.jp +sanjo.niigata.jp +seiro.niigata.jp +seirou.niigata.jp +sekikawa.niigata.jp +shibata.niigata.jp +tagami.niigata.jp +tainai.niigata.jp +tochio.niigata.jp +tokamachi.niigata.jp +tsubame.niigata.jp +tsunan.niigata.jp +uonuma.niigata.jp +yahiko.niigata.jp +yoita.niigata.jp +yuzawa.niigata.jp +beppu.oita.jp +bungoono.oita.jp +bungotakada.oita.jp +hasama.oita.jp +hiji.oita.jp +himeshima.oita.jp +hita.oita.jp +kamitsue.oita.jp +kokonoe.oita.jp +kuju.oita.jp +kunisaki.oita.jp +kusu.oita.jp +oita.oita.jp +saiki.oita.jp +taketa.oita.jp +tsukumi.oita.jp +usa.oita.jp +usuki.oita.jp +yufu.oita.jp +akaiwa.okayama.jp +asakuchi.okayama.jp +bizen.okayama.jp +hayashima.okayama.jp +ibara.okayama.jp +kagamino.okayama.jp +kasaoka.okayama.jp +kibichuo.okayama.jp +kumenan.okayama.jp +kurashiki.okayama.jp +maniwa.okayama.jp +misaki.okayama.jp +nagi.okayama.jp +niimi.okayama.jp +nishiawakura.okayama.jp +okayama.okayama.jp +satosho.okayama.jp +setouchi.okayama.jp +shinjo.okayama.jp +shoo.okayama.jp +soja.okayama.jp +takahashi.okayama.jp +tamano.okayama.jp +tsuyama.okayama.jp +wake.okayama.jp +yakage.okayama.jp +aguni.okinawa.jp +ginowan.okinawa.jp +ginoza.okinawa.jp +gushikami.okinawa.jp +haebaru.okinawa.jp +higashi.okinawa.jp +hirara.okinawa.jp +iheya.okinawa.jp +ishigaki.okinawa.jp +ishikawa.okinawa.jp +itoman.okinawa.jp +izena.okinawa.jp +kadena.okinawa.jp +kin.okinawa.jp +kitadaito.okinawa.jp +kitanakagusuku.okinawa.jp +kumejima.okinawa.jp +kunigami.okinawa.jp +minamidaito.okinawa.jp +motobu.okinawa.jp +nago.okinawa.jp +naha.okinawa.jp +nakagusuku.okinawa.jp +nakijin.okinawa.jp +nanjo.okinawa.jp +nishihara.okinawa.jp +ogimi.okinawa.jp +okinawa.okinawa.jp +onna.okinawa.jp +shimoji.okinawa.jp +taketomi.okinawa.jp +tarama.okinawa.jp +tokashiki.okinawa.jp +tomigusuku.okinawa.jp +tonaki.okinawa.jp +urasoe.okinawa.jp +uruma.okinawa.jp +yaese.okinawa.jp +yomitan.okinawa.jp +yonabaru.okinawa.jp +yonaguni.okinawa.jp +zamami.okinawa.jp +abeno.osaka.jp +chihayaakasaka.osaka.jp +chuo.osaka.jp +daito.osaka.jp +fujiidera.osaka.jp +habikino.osaka.jp +hannan.osaka.jp +higashiosaka.osaka.jp +higashisumiyoshi.osaka.jp +higashiyodogawa.osaka.jp +hirakata.osaka.jp +ibaraki.osaka.jp +ikeda.osaka.jp +izumi.osaka.jp +izumiotsu.osaka.jp +izumisano.osaka.jp +kadoma.osaka.jp +kaizuka.osaka.jp +kanan.osaka.jp +kashiwara.osaka.jp +katano.osaka.jp +kawachinagano.osaka.jp +kishiwada.osaka.jp +kita.osaka.jp +kumatori.osaka.jp +matsubara.osaka.jp +minato.osaka.jp +minoh.osaka.jp +misaki.osaka.jp +moriguchi.osaka.jp +neyagawa.osaka.jp +nishi.osaka.jp +nose.osaka.jp +osakasayama.osaka.jp +sakai.osaka.jp +sayama.osaka.jp +sennan.osaka.jp +settsu.osaka.jp +shijonawate.osaka.jp +shimamoto.osaka.jp +suita.osaka.jp +tadaoka.osaka.jp +taishi.osaka.jp +tajiri.osaka.jp +takaishi.osaka.jp +takatsuki.osaka.jp +tondabayashi.osaka.jp +toyonaka.osaka.jp +toyono.osaka.jp +yao.osaka.jp +ariake.saga.jp +arita.saga.jp +fukudomi.saga.jp +genkai.saga.jp +hamatama.saga.jp +hizen.saga.jp +imari.saga.jp +kamimine.saga.jp +kanzaki.saga.jp +karatsu.saga.jp +kashima.saga.jp +kitagata.saga.jp +kitahata.saga.jp +kiyama.saga.jp +kouhoku.saga.jp +kyuragi.saga.jp +nishiarita.saga.jp +ogi.saga.jp +omachi.saga.jp +ouchi.saga.jp +saga.saga.jp +shiroishi.saga.jp +taku.saga.jp +tara.saga.jp +tosu.saga.jp +yoshinogari.saga.jp +arakawa.saitama.jp +asaka.saitama.jp +chichibu.saitama.jp +fujimi.saitama.jp +fujimino.saitama.jp +fukaya.saitama.jp +hanno.saitama.jp +hanyu.saitama.jp +hasuda.saitama.jp +hatogaya.saitama.jp +hatoyama.saitama.jp +hidaka.saitama.jp +higashichichibu.saitama.jp +higashimatsuyama.saitama.jp +honjo.saitama.jp +ina.saitama.jp +iruma.saitama.jp +iwatsuki.saitama.jp +kamiizumi.saitama.jp +kamikawa.saitama.jp +kamisato.saitama.jp +kasukabe.saitama.jp +kawagoe.saitama.jp +kawaguchi.saitama.jp +kawajima.saitama.jp +kazo.saitama.jp +kitamoto.saitama.jp +koshigaya.saitama.jp +kounosu.saitama.jp +kuki.saitama.jp +kumagaya.saitama.jp +matsubushi.saitama.jp +minano.saitama.jp +misato.saitama.jp +miyashiro.saitama.jp +miyoshi.saitama.jp +moroyama.saitama.jp +nagatoro.saitama.jp +namegawa.saitama.jp +niiza.saitama.jp +ogano.saitama.jp +ogawa.saitama.jp +ogose.saitama.jp +okegawa.saitama.jp +omiya.saitama.jp +otaki.saitama.jp +ranzan.saitama.jp +ryokami.saitama.jp +saitama.saitama.jp +sakado.saitama.jp +satte.saitama.jp +sayama.saitama.jp +shiki.saitama.jp +shiraoka.saitama.jp +soka.saitama.jp +sugito.saitama.jp +toda.saitama.jp +tokigawa.saitama.jp +tokorozawa.saitama.jp +tsurugashima.saitama.jp +urawa.saitama.jp +warabi.saitama.jp +yashio.saitama.jp +yokoze.saitama.jp +yono.saitama.jp +yorii.saitama.jp +yoshida.saitama.jp +yoshikawa.saitama.jp +yoshimi.saitama.jp +aisho.shiga.jp +gamo.shiga.jp +higashiomi.shiga.jp +hikone.shiga.jp +koka.shiga.jp +konan.shiga.jp +kosei.shiga.jp +koto.shiga.jp +kusatsu.shiga.jp +maibara.shiga.jp +moriyama.shiga.jp +nagahama.shiga.jp +nishiazai.shiga.jp +notogawa.shiga.jp +omihachiman.shiga.jp +otsu.shiga.jp +ritto.shiga.jp +ryuoh.shiga.jp +takashima.shiga.jp +takatsuki.shiga.jp +torahime.shiga.jp +toyosato.shiga.jp +yasu.shiga.jp +akagi.shimane.jp +ama.shimane.jp +gotsu.shimane.jp +hamada.shimane.jp +higashiizumo.shimane.jp +hikawa.shimane.jp +hikimi.shimane.jp +izumo.shimane.jp +kakinoki.shimane.jp +masuda.shimane.jp +matsue.shimane.jp +misato.shimane.jp +nishinoshima.shimane.jp +ohda.shimane.jp +okinoshima.shimane.jp +okuizumo.shimane.jp +shimane.shimane.jp +tamayu.shimane.jp +tsuwano.shimane.jp +unnan.shimane.jp +yakumo.shimane.jp +yasugi.shimane.jp +yatsuka.shimane.jp +arai.shizuoka.jp +atami.shizuoka.jp +fuji.shizuoka.jp +fujieda.shizuoka.jp +fujikawa.shizuoka.jp +fujinomiya.shizuoka.jp +fukuroi.shizuoka.jp +gotemba.shizuoka.jp +haibara.shizuoka.jp +hamamatsu.shizuoka.jp +higashiizu.shizuoka.jp +ito.shizuoka.jp +iwata.shizuoka.jp +izu.shizuoka.jp +izunokuni.shizuoka.jp +kakegawa.shizuoka.jp +kannami.shizuoka.jp +kawanehon.shizuoka.jp +kawazu.shizuoka.jp +kikugawa.shizuoka.jp +kosai.shizuoka.jp +makinohara.shizuoka.jp +matsuzaki.shizuoka.jp +minamiizu.shizuoka.jp +mishima.shizuoka.jp +morimachi.shizuoka.jp +nishiizu.shizuoka.jp +numazu.shizuoka.jp +omaezaki.shizuoka.jp +shimada.shizuoka.jp +shimizu.shizuoka.jp +shimoda.shizuoka.jp +shizuoka.shizuoka.jp +susono.shizuoka.jp +yaizu.shizuoka.jp +yoshida.shizuoka.jp +ashikaga.tochigi.jp +bato.tochigi.jp +haga.tochigi.jp +ichikai.tochigi.jp +iwafune.tochigi.jp +kaminokawa.tochigi.jp +kanuma.tochigi.jp +karasuyama.tochigi.jp +kuroiso.tochigi.jp +mashiko.tochigi.jp +mibu.tochigi.jp +moka.tochigi.jp +motegi.tochigi.jp +nasu.tochigi.jp +nasushiobara.tochigi.jp +nikko.tochigi.jp +nishikata.tochigi.jp +nogi.tochigi.jp +ohira.tochigi.jp +ohtawara.tochigi.jp +oyama.tochigi.jp +sakura.tochigi.jp +sano.tochigi.jp +shimotsuke.tochigi.jp +shioya.tochigi.jp +takanezawa.tochigi.jp +tochigi.tochigi.jp +tsuga.tochigi.jp +ujiie.tochigi.jp +utsunomiya.tochigi.jp +yaita.tochigi.jp +aizumi.tokushima.jp +anan.tokushima.jp +ichiba.tokushima.jp +itano.tokushima.jp +kainan.tokushima.jp +komatsushima.tokushima.jp +matsushige.tokushima.jp +mima.tokushima.jp +minami.tokushima.jp +miyoshi.tokushima.jp +mugi.tokushima.jp +nakagawa.tokushima.jp +naruto.tokushima.jp +sanagochi.tokushima.jp +shishikui.tokushima.jp +tokushima.tokushima.jp +wajiki.tokushima.jp +adachi.tokyo.jp +akiruno.tokyo.jp +akishima.tokyo.jp +aogashima.tokyo.jp +arakawa.tokyo.jp +bunkyo.tokyo.jp +chiyoda.tokyo.jp +chofu.tokyo.jp +chuo.tokyo.jp +edogawa.tokyo.jp +fuchu.tokyo.jp +fussa.tokyo.jp +hachijo.tokyo.jp +hachioji.tokyo.jp +hamura.tokyo.jp +higashikurume.tokyo.jp +higashimurayama.tokyo.jp +higashiyamato.tokyo.jp +hino.tokyo.jp +hinode.tokyo.jp +hinohara.tokyo.jp +inagi.tokyo.jp +itabashi.tokyo.jp +katsushika.tokyo.jp +kita.tokyo.jp +kiyose.tokyo.jp +kodaira.tokyo.jp +koganei.tokyo.jp +kokubunji.tokyo.jp +komae.tokyo.jp +koto.tokyo.jp +kouzushima.tokyo.jp +kunitachi.tokyo.jp +machida.tokyo.jp +meguro.tokyo.jp +minato.tokyo.jp +mitaka.tokyo.jp +mizuho.tokyo.jp +musashimurayama.tokyo.jp +musashino.tokyo.jp +nakano.tokyo.jp +nerima.tokyo.jp +ogasawara.tokyo.jp +okutama.tokyo.jp +ome.tokyo.jp +oshima.tokyo.jp +ota.tokyo.jp +setagaya.tokyo.jp +shibuya.tokyo.jp +shinagawa.tokyo.jp +shinjuku.tokyo.jp +suginami.tokyo.jp +sumida.tokyo.jp +tachikawa.tokyo.jp +taito.tokyo.jp +tama.tokyo.jp +toshima.tokyo.jp +chizu.tottori.jp +hino.tottori.jp +kawahara.tottori.jp +koge.tottori.jp +kotoura.tottori.jp +misasa.tottori.jp +nanbu.tottori.jp +nichinan.tottori.jp +sakaiminato.tottori.jp +tottori.tottori.jp +wakasa.tottori.jp +yazu.tottori.jp +yonago.tottori.jp +asahi.toyama.jp +fuchu.toyama.jp +fukumitsu.toyama.jp +funahashi.toyama.jp +himi.toyama.jp +imizu.toyama.jp +inami.toyama.jp +johana.toyama.jp +kamiichi.toyama.jp +kurobe.toyama.jp +nakaniikawa.toyama.jp +namerikawa.toyama.jp +nanto.toyama.jp +nyuzen.toyama.jp +oyabe.toyama.jp +taira.toyama.jp +takaoka.toyama.jp +tateyama.toyama.jp +toga.toyama.jp +tonami.toyama.jp +toyama.toyama.jp +unazuki.toyama.jp +uozu.toyama.jp +yamada.toyama.jp +arida.wakayama.jp +aridagawa.wakayama.jp +gobo.wakayama.jp +hashimoto.wakayama.jp +hidaka.wakayama.jp +hirogawa.wakayama.jp +inami.wakayama.jp +iwade.wakayama.jp +kainan.wakayama.jp +kamitonda.wakayama.jp +katsuragi.wakayama.jp +kimino.wakayama.jp +kinokawa.wakayama.jp +kitayama.wakayama.jp +koya.wakayama.jp +koza.wakayama.jp +kozagawa.wakayama.jp +kudoyama.wakayama.jp +kushimoto.wakayama.jp +mihama.wakayama.jp +misato.wakayama.jp +nachikatsuura.wakayama.jp +shingu.wakayama.jp +shirahama.wakayama.jp +taiji.wakayama.jp +tanabe.wakayama.jp +wakayama.wakayama.jp +yuasa.wakayama.jp +yura.wakayama.jp +asahi.yamagata.jp +funagata.yamagata.jp +higashine.yamagata.jp +iide.yamagata.jp +kahoku.yamagata.jp +kaminoyama.yamagata.jp +kaneyama.yamagata.jp +kawanishi.yamagata.jp +mamurogawa.yamagata.jp +mikawa.yamagata.jp +murayama.yamagata.jp +nagai.yamagata.jp +nakayama.yamagata.jp +nanyo.yamagata.jp +nishikawa.yamagata.jp +obanazawa.yamagata.jp +oe.yamagata.jp +oguni.yamagata.jp +ohkura.yamagata.jp +oishida.yamagata.jp +sagae.yamagata.jp +sakata.yamagata.jp +sakegawa.yamagata.jp +shinjo.yamagata.jp +shirataka.yamagata.jp +shonai.yamagata.jp +takahata.yamagata.jp +tendo.yamagata.jp +tozawa.yamagata.jp +tsuruoka.yamagata.jp +yamagata.yamagata.jp +yamanobe.yamagata.jp +yonezawa.yamagata.jp +yuza.yamagata.jp +abu.yamaguchi.jp +hagi.yamaguchi.jp +hikari.yamaguchi.jp +hofu.yamaguchi.jp +iwakuni.yamaguchi.jp +kudamatsu.yamaguchi.jp +mitou.yamaguchi.jp +nagato.yamaguchi.jp +oshima.yamaguchi.jp +shimonoseki.yamaguchi.jp +shunan.yamaguchi.jp +tabuse.yamaguchi.jp +tokuyama.yamaguchi.jp +toyota.yamaguchi.jp +ube.yamaguchi.jp +yuu.yamaguchi.jp +chuo.yamanashi.jp +doshi.yamanashi.jp +fuefuki.yamanashi.jp +fujikawa.yamanashi.jp +fujikawaguchiko.yamanashi.jp +fujiyoshida.yamanashi.jp +hayakawa.yamanashi.jp +hokuto.yamanashi.jp +ichikawamisato.yamanashi.jp +kai.yamanashi.jp +kofu.yamanashi.jp +koshu.yamanashi.jp +kosuge.yamanashi.jp +minami-alps.yamanashi.jp +minobu.yamanashi.jp +nakamichi.yamanashi.jp +nanbu.yamanashi.jp +narusawa.yamanashi.jp +nirasaki.yamanashi.jp +nishikatsura.yamanashi.jp +oshino.yamanashi.jp +otsuki.yamanashi.jp +showa.yamanashi.jp +tabayama.yamanashi.jp +tsuru.yamanashi.jp +uenohara.yamanashi.jp +yamanakako.yamanashi.jp +yamanashi.yamanashi.jp +ke +ac.ke +co.ke +go.ke +info.ke +me.ke +mobi.ke +ne.ke +or.ke +sc.ke +kg +org.kg +net.kg +com.kg +edu.kg +gov.kg +mil.kg +kki +edu.ki +biz.ki +net.ki +org.ki +gov.ki +info.ki +com.ki +km +org.km +nom.km +gov.km +prd.km +tm.km +edu.km +mil.km +ass.km +com.km +coop.km +asso.km +presse.km +medecin.km +notaires.km +pharmaciens.km +veterinaire.km +gouv.km +kn +net.kn +org.kn +edu.kn +gov.kn +kp +com.kp +edu.kp +gov.kp +org.kp +rep.kp +tra.kp +kr +ac.kr +co.kr +es.kr +go.kr +hs.kr +kg.kr +mil.kr +ms.kr +ne.kr +or.kr +pe.kr +re.kr +sc.kr +busan.kr +chungbuk.kr +chungnam.kr +daegu.kr +daejeon.kr +gangwon.kr +gwangju.kr +gyeongbuk.kr +gyeonggi.kr +gyeongnam.kr +incheon.kr +jeju.kr +jeonbuk.kr +jeonnam.kr +seoul.kr +ulsan.kr +kw +com.kw +edu.kw +emb.kw +gov.kw +ind.kw +net.kw +org.kw +ky +edu.ky +gov.ky +com.ky +org.ky +net.ky +kz +org.kz +edu.kz +net.kz +gov.kz +mil.kz +com.kz +la +int.la +net.la +info.la +edu.la +gov.la +per.la +com.la +org.la +lb +com.lb +edu.lb +gov.lb +net.lb +org.lb +lc +com.lc +net.lc +co.lc +org.lc +edu.lc +gov.lc +li +lk +gov.lk +sch.lk +net.lk +int.lk +com.lk +org.lk +edu.lk +ngo.lk +soc.lk +web.lk +ltd.lk +assn.lk +grp.lk +hotel.lk +ac.lk +lr +com.lr +edu.lr +gov.lr +org.lr +net.lr +ls +ac.ls +biz.ls +co.ls +edu.ls +gov.ls +info.ls +net.ls +org.ls +sc.ls +lt +gov.lt +lu +lv +com.lv +edu.lv +gov.lv +org.lv +mil.lv +id.lv +net.lv +asn.lv +conf.lv +ly +com.ly +net.ly +gov.ly +plc.ly +edu.ly +sch.ly +med.ly +org.ly +id.ly +ma +co.ma +net.ma +gov.ma +org.ma +ac.ma +press.ma +mc +tm.mc +asso.mc +md +me +co.me +net.me +org.me +edu.me +ac.me +gov.me +its.me +priv.me +mg +org.mg +nom.mg +gov.mg +prd.mg +tm.mg +edu.mg +mil.mg +com.mg +co.mg +mh +mil +mk +com.mk +org.mk +net.mk +edu.mk +gov.mk +inf.mk +name.mk +ml +com.ml +edu.ml +gouv.ml +gov.ml +net.ml +org.ml +presse.ml +mmn +gov.mn +edu.mn +org.mn +mo +com.mo +net.mo +org.mo +edu.mo +gov.mo +mobi +mp +mq +mr +gov.mr +ms +com.ms +edu.ms +gov.ms +net.ms +org.ms +mt +com.mt +edu.mt +net.mt +org.mt +mu +com.mu +net.mu +org.mu +gov.mu +ac.mu +co.mu +or.mu +museum +academy.museum +agriculture.museum +air.museum +airguard.museum +alabama.museum +alaska.museum +amber.museum +ambulance.museum +american.museum +americana.museum +americanantiques.museum +americanart.museum +amsterdam.museum +and.museum +annefrank.museum +anthro.museum +anthropology.museum +antiques.museum +aquarium.museum +arboretum.museum +archaeological.museum +archaeology.museum +architecture.museum +art.museum +artanddesign.museum +artcenter.museum +artdeco.museum +arteducation.museum +artgallery.museum +arts.museum +artsandcrafts.museum +asmatart.museum +assassination.museum +assisi.museum +association.museum +astronomy.museum +atlanta.museum +austin.museum +australia.museum +automotive.museum +aviation.museum +axis.museum +badajoz.museum +baghdad.museum +bahn.museum +bale.museum +baltimore.museum +barcelona.museum +baseball.museum +basel.museum +baths.museum +bauern.museum +beauxarts.museum +beeldengeluid.museum +bellevue.museum +bergbau.museum +berkeley.museum +berlin.museum +bern.museum +bible.museum +bilbao.museum +bill.museum +birdart.museum +birthplace.museum +bonn.museum +boston.museum +botanical.museum +botanicalgarden.museum +botanicgarden.museum +botany.museum +brandywinevalley.museum +brasil.museum +bristol.museum +british.museum +britishcolumbia.museum +broadcast.museum +brunel.museum +brussel.museum +brussels.museum +bruxelles.museum +building.museum +burghof.museum +bus.museum +bushey.museum +cadaques.museum +california.museum +cambridge.museum +can.museum +canada.museum +capebreton.museum +carrier.museum +cartoonart.museum +casadelamoneda.museum +castle.museum +castres.museum +celtic.museum +center.museum +chattanooga.museum +cheltenham.museum +chesapeakebay.museum +chicago.museum +children.museum +childrens.museum +childrensgarden.museum +chiropractic.museum +chocolate.museum +christiansburg.museum +cincinnati.museum +cinema.museum +circus.museum +civilisation.museum +civilization.museum +civilwar.museum +clinton.museum +clock.museum +coal.museum +coastaldefence.museum +cody.museum +coldwar.museum +collection.museum +colonialwilliamsburg.museum +coloradoplateau.museum +columbia.museum +columbus.museum +communication.museum +communications.museum +community.museum +computer.museum +computerhistory.museum +comunicações.museum +contemporary.museum +contemporaryart.museum +convent.museum +copenhagen.museum +corporation.museum +correios-e-telecomunicações.museum +corvette.museum +costume.museum +countryestate.museum +county.museum +crafts.museum +cranbrook.museum +creation.museum +cultural.museum +culturalcenter.museum +culture.museum +cyber.museum +cymru.museum +dali.museum +dallas.museum +database.museum +ddr.museum +decorativearts.museum +delaware.museum +delmenhorst.museum +denmark.museum +depot.museum +design.museum +detroit.museum +dinosaur.museum +discovery.museum +dolls.museum +donostia.museum +durham.museum +eastafrica.museum +eastcoast.museum +education.museum +educational.museum +egyptian.museum +eisenbahn.museum +elburg.museum +elvendrell.museum +embroidery.museum +encyclopedic.museum +england.museum +entomology.museum +environment.museum +environmentalconservation.museum +epilepsy.museum +essex.museum +estate.museum +ethnology.museum +exeter.museum +exhibition.museum +family.museum +farm.museum +farmequipment.museum +farmers.museum +farmstead.museum +field.museum +figueres.museum +filatelia.museum +film.museum +fineart.museum +finearts.museum +finland.museum +flanders.museum +florida.museum +force.museum +fortmissoula.museum +fortworth.museum +foundation.museum +francaise.museum +frankfurt.museum +franziskaner.museum +freemasonry.museum +freiburg.museum +fribourg.museum +frog.museum +fundacio.museum +furniture.museum +gallery.museum +garden.museum +gateway.museum +geelvinck.museum +gemological.museum +geology.museum +georgia.museum +giessen.museum +glas.museum +glass.museum +gorge.museum +grandrapids.museum +graz.museum +guernsey.museum +halloffame.museum +hamburg.museum +handson.museum +harvestcelebration.museum +hawaii.museum +health.museum +heimatunduhren.museum +hellas.museum +helsinki.museum +hembygdsforbund.museum +heritage.museum +histoire.museum +historical.museum +historicalsociety.museum +historichouses.museum +historisch.museum +historisches.museum +history.museum +historyofscience.museum +horology.museum +house.museum +humanities.museum +illustration.museum +imageandsound.museum +indian.museum +indiana.museum +indianapolis.museum +indianmarket.museum +intelligence.museum +interactive.museum +iraq.museum +iron.museum +isleofman.museum +jamison.museum +jefferson.museum +jerusalem.museum +jewelry.museum +jewish.museum +jewishart.museum +jfk.museum +journalism.museum +judaica.museum +judygarland.museum +juedisches.museum +juif.museum +karate.museum +karikatur.museum +kids.museum +koebenhavn.museum +koeln.museum +kunst.museum +kunstsammlung.museum +kunstunddesign.museum +labor.museum +labour.museum +lajolla.museum +lancashire.museum +landes.museum +lans.museum +läns.museum +larsson.museum +lewismiller.museum +lincoln.museum +linz.museum +living.museum +livinghistory.museum +localhistory.museum +london.museum +losangeles.museum +louvre.museum +loyalist.museum +lucerne.museum +luxembourg.museum +luzern.museum +mad.museum +madrid.museum +mallorca.museum +manchester.museum +mansion.museum +mansions.museum +manx.museum +marburg.museum +maritime.museum +maritimo.museum +maryland.museum +marylhurst.museum +media.museum +medical.museum +medizinhistorisches.museum +meeres.museum +memorial.museum +mesaverde.museum +michigan.museum +midatlantic.museum +military.museum +mill.museum +miners.museum +mining.museum +minnesota.museum +missile.museum +missoula.museum +modern.museum +moma.museum +money.museum +monmouth.museum +monticello.museum +montreal.museum +moscow.museum +motorcycle.museum +muenchen.museum +muenster.museum +mulhouse.museum +muncie.museum +museet.museum +museumcenter.museum +museumvereniging.museum +music.museum +national.museum +nationalfirearms.museum +nationalheritage.museum +nativeamerican.museum +naturalhistory.museum +naturalhistorymuseum.museum +naturalsciences.museum +nature.museum +naturhistorisches.museum +natuurwetenschappen.museum +naumburg.museum +naval.museum +nebraska.museum +neues.museum +newhampshire.museum +newjersey.museum +newmexico.museum +newport.museum +newspaper.museum +newyork.museum +niepce.museum +norfolk.museum +north.museum +nrw.museum +nuernberg.museum +nuremberg.museum +nyc.museum +nyny.museum +oceanographic.museum +oceanographique.museum +omaha.museum +online.museum +ontario.museum +openair.museum +oregon.museum +oregontrail.museum +otago.museum +oxford.museum +pacific.museum +paderborn.museum +palace.museum +paleo.museum +palmsprings.museum +panama.museum +paris.museum +pasadena.museum +pharmacy.museum +philadelphia.museum +philadelphiaarea.museum +philately.museum +phoenix.museum +photography.museum +pilots.museum +pittsburgh.museum +planetarium.museum +plantation.museum +plants.museum +plaza.museum +portal.museum +portland.museum +portlligat.museum +posts-and-telecommunications.museum +preservation.museum +presidio.museum +press.museum +project.museum +public.museum +pubol.museum +quebec.museum +railroad.museum +railway.museum +research.museum +resistance.museum +riodejaneiro.museum +rochester.museum +rockart.museum +roma.museum +russia.museum +saintlouis.museum +salem.museum +salvadordali.museum +salzburg.museum +sandiego.museum +sanfrancisco.museum +santabarbara.museum +santacruz.museum +santafe.museum +saskatchewan.museum +satx.museum +savannahga.museum +schlesisches.museum +schoenbrunn.museum +schokoladen.museum +school.museum +schweiz.museum +science.museum +scienceandhistory.museum +scienceandindustry.museum +sciencecenter.museum +sciencecenters.museum +science-fiction.museum +sciencehistory.museum +sciences.museum +sciencesnaturelles.museum +scotland.museum +seaport.museum +settlement.museum +settlers.museum +shell.museum +sherbrooke.museum +sibenik.museum +silk.museum +ski.museum +skole.museum +society.museum +sologne.museum +soundandvision.museum +southcarolina.museum +southwest.museum +space.museum +spy.museum +square.museum +stadt.museum +stalbans.museum +starnberg.museum +state.museum +stateofdelaware.museum +station.museum +steam.museum +steiermark.museum +stjohn.museum +stockholm.museum +stpetersburg.museum +stuttgart.museum +suisse.museum +surgeonshall.museum +surrey.museum +svizzera.museum +sweden.museum +sydney.museum +tank.museum +tcm.museum +technology.museum +telekommunikation.museum +television.museum +texas.museum +textile.museum +theater.museum +time.museum +timekeeping.museum +topology.museum +torino.museum +touch.museum +town.museum +transport.museum +tree.museum +trolley.museum +trust.museum +trustee.museum +uhren.museum +ulm.museum +undersea.museum +university.museum +usa.museum +usantiques.museum +usarts.museum +uscountryestate.museum +usculture.museum +usdecorativearts.museum +usgarden.museum +ushistory.museum +ushuaia.museum +uslivinghistory.museum +utah.museum +uvic.museum +valley.museum +vantaa.museum +versailles.museum +viking.museum +village.museum +virginia.museum +virtual.museum +virtuel.museum +vlaanderen.museum +volkenkunde.museum +wales.museum +wallonie.museum +war.museum +washingtondc.museum +watchandclock.museum +watch-and-clock.museum +western.museum +westfalen.museum +whaling.museum +wildlife.museum +williamsburg.museum +windmill.museum +workshop.museum +york.museum +yorkshire.museum +yosemite.museum +youth.museum +zoological.museum +zoology.museum +ירושלים.museum +иком.museum +mv +aero.mv +biz.mv +com.mv +coop.mv +edu.mv +gov.mv +info.mv +int.mv +mil.mv +museum.mv +name.mv +net.mv +org.mv +pro.mv +mw +ac.mw +biz.mw +co.mw +com.mw +coop.mw +edu.mw +gov.mw +int.mw +museum.mw +net.mw +org.mw +mx +com.mx +org.mx +gob.mx +edu.mx +net.mx +my +com.my +net.my +org.my +gov.my +edu.my +mil.my +name.my +mz +ac.mz +adv.mz +co.mz +edu.mz +gov.mz +mil.mz +net.mz +org.mz +na +info.na +pro.na +name.na +school.na +or.na +dr.na +us.na +mx.na +ca.na +in.na +cc.na +tv.na +ws.na +mobi.na +co.na +com.na +org.na +name +nc +asso.nc +nom.nc +ne +net +nf +com.nf +net.nf +per.nf +rec.nf +web.nf +arts.nf +firm.nf +info.nf +other.nf +store.nf +ng +com.ng +edu.ng +gov.ng +i.ng +mil.ng +mobi.ng +name.ng +net.ng +org.ng +sch.ng +ni +ac.ni +biz.ni +co.ni +com.ni +edu.ni +gob.ni +in.ni +info.ni +int.ni +mil.ni +net.ni +nom.ni +org.ni +web.ni +nl +no +fhs.no +vgs.no +fylkesbibl.no +folkebibl.no +museum.no +idrett.no +priv.no +mil.no +stat.no +dep.no +kommune.no +herad.no +aa.no +ah.no +bu.no +fm.no +hl.no +hm.no +jan-mayen.no +mr.no +nl.no +nt.no +of.no +ol.no +oslo.no +rl.no +sf.no +st.no +svalbard.no +tm.no +tr.no +va.no +vf.no +gs.aa.no +gs.ah.no +gs.bu.no +gs.fm.no +gs.hl.no +gs.hm.no +gs.jan-mayen.no +gs.mr.no +gs.nl.no +gs.nt.no +gs.of.no +gs.ol.no +gs.oslo.no +gs.rl.no +gs.sf.no +gs.st.no +gs.svalbard.no +gs.tm.no +gs.tr.no +gs.va.no +gs.vf.no +akrehamn.no +åkrehamn.no +algard.no +ålgård.no +arna.no +brumunddal.no +bryne.no +bronnoysund.no +brønnøysund.no +drobak.no +drøbak.no +egersund.no +fetsund.no +floro.no +florø.no +fredrikstad.no +hokksund.no +honefoss.no +hønefoss.no +jessheim.no +jorpeland.no +jørpeland.no +kirkenes.no +kopervik.no +krokstadelva.no +langevag.no +langevåg.no +leirvik.no +mjondalen.no +mjøndalen.no +mo-i-rana.no +mosjoen.no +mosjøen.no +nesoddtangen.no +orkanger.no +osoyro.no +osøyro.no +raholt.no +råholt.no +sandnessjoen.no +sandnessjøen.no +skedsmokorset.no +slattum.no +spjelkavik.no +stathelle.no +stavern.no +stjordalshalsen.no +stjørdalshalsen.no +tananger.no +tranby.no +vossevangen.no +afjord.no +åfjord.no +agdenes.no +al.no +ål.no +alesund.no +ålesund.no +alstahaug.no +alta.no +áltá.no +alaheadju.no +álaheadju.no +alvdal.no +amli.no +åmli.no +amot.no +åmot.no +andebu.no +andoy.no +andøy.no +andasuolo.no +ardal.no +årdal.no +aremark.no +arendal.no +ås.no +aseral.no +åseral.no +asker.no +askim.no +askvoll.no +askoy.no +askøy.no +asnes.no +åsnes.no +audnedaln.no +aukra.no +aure.no +aurland.no +aurskog-holand.no +aurskog-høland.no +austevoll.no +austrheim.no +averoy.no +averøy.no +balestrand.no +ballangen.no +balat.no +bálát.no +balsfjord.no +bahccavuotna.no +báhccavuotna.no +bamble.no +bardu.no +beardu.no +beiarn.no +bajddar.no +bájddar.no +baidar.no +báidár.no +berg.no +bergen.no +berlevag.no +berlevåg.no +bearalvahki.no +bearalváhki.no +bindal.no +birkenes.no +bjarkoy.no +bjarkøy.no +bjerkreim.no +bjugn.no +bodo.no +bodø.no +badaddja.no +bådåddjå.no +budejju.no +bokn.no +bremanger.no +bronnoy.no +brønnøy.no +bygland.no +bykle.no +barum.no +bærum.no +bo.telemark.no +bø.telemark.no +bo.nordland.no +bø.nordland.no +bievat.no +bievát.no +bomlo.no +bømlo.no +batsfjord.no +båtsfjord.no +bahcavuotna.no +báhcavuotna.no +dovre.no +drammen.no +drangedal.no +dyroy.no +dyrøy.no +donna.no +dønna.no +eid.no +eidfjord.no +eidsberg.no +eidskog.no +eidsvoll.no +eigersund.no +elverum.no +enebakk.no +engerdal.no +etne.no +etnedal.no +evenes.no +evenassi.no +evenášši.no +evje-og-hornnes.no +farsund.no +fauske.no +fuossko.no +fuoisku.no +fedje.no +fet.no +finnoy.no +finnøy.no +fitjar.no +fjaler.no +fjell.no +flakstad.no +flatanger.no +flekkefjord.no +flesberg.no +flora.no +fla.no +flå.no +folldal.no +forsand.no +fosnes.no +frei.no +frogn.no +froland.no +frosta.no +frana.no +fræna.no +froya.no +frøya.no +fusa.no +fyresdal.no +forde.no +førde.no +gamvik.no +gangaviika.no +gáŋgaviika.no +gaular.no +gausdal.no +gildeskal.no +gildeskål.no +giske.no +gjemnes.no +gjerdrum.no +gjerstad.no +gjesdal.no +gjovik.no +gjøvik.no +gloppen.no +gol.no +gran.no +grane.no +granvin.no +gratangen.no +grimstad.no +grong.no +kraanghke.no +kråanghke.no +grue.no +gulen.no +hadsel.no +halden.no +halsa.no +hamar.no +hamaroy.no +habmer.no +hábmer.no +hapmir.no +hápmir.no +hammerfest.no +hammarfeasta.no +hámmárfeasta.no +haram.no +hareid.no +harstad.no +hasvik.no +aknoluokta.no +ákŋoluokta.no +hattfjelldal.no +aarborte.no +haugesund.no +hemne.no +hemnes.no +hemsedal.no +heroy.more-og-romsdal.no +herøy.møre-og-romsdal.no +heroy.nordland.no +herøy.nordland.no +hitra.no +hjartdal.no +hjelmeland.no +hobol.no +hobøl.no +hof.no +hol.no +hole.no +holmestrand.no +holtalen.no +holtålen.no +hornindal.no +horten.no +hurdal.no +hurum.no +hvaler.no +hyllestad.no +hagebostad.no +hægebostad.no +hoyanger.no +høyanger.no +hoylandet.no +høylandet.no +ha.no +hå.no +ibestad.no +inderoy.no +inderøy.no +iveland.no +jevnaker.no +jondal.no +jolster.no +jølster.no +karasjok.no +karasjohka.no +kárášjohka.no +karlsoy.no +galsa.no +gálsá.no +karmoy.no +karmøy.no +kautokeino.no +guovdageaidnu.no +klepp.no +klabu.no +klæbu.no +kongsberg.no +kongsvinger.no +kragero.no +kragerø.no +kristiansand.no +kristiansund.no +krodsherad.no +krødsherad.no +kvalsund.no +rahkkeravju.no +ráhkkerávju.no +kvam.no +kvinesdal.no +kvinnherad.no +kviteseid.no +kvitsoy.no +kvitsøy.no +kvafjord.no +kvæfjord.no +giehtavuoatna.no +kvanangen.no +kvænangen.no +navuotna.no +návuotna.no +kafjord.no +kåfjord.no +gaivuotna.no +gáivuotna.no +larvik.no +lavangen.no +lavagis.no +loabat.no +loabát.no +lebesby.no +davvesiida.no +leikanger.no +leirfjord.no +leka.no +leksvik.no +lenvik.no +leangaviika.no +leaŋgaviika.no +lesja.no +levanger.no +lier.no +lierne.no +lillehammer.no +lillesand.no +lindesnes.no +lindas.no +lindås.no +lom.no +loppa.no +lahppi.no +láhppi.no +lund.no +lunner.no +luroy.no +lurøy.no +luster.no +lyngdal.no +lyngen.no +ivgu.no +lardal.no +lerdal.no +lærdal.no +lodingen.no +lødingen.no +lorenskog.no +lørenskog.no +loten.no +løten.no +malvik.no +masoy.no +måsøy.no +muosat.no +muosát.no +mandal.no +marker.no +marnardal.no +masfjorden.no +meland.no +meldal.no +melhus.no +meloy.no +meløy.no +meraker.no +meråker.no +moareke.no +moåreke.no +midsund.no +midtre-gauldal.no +modalen.no +modum.no +molde.no +moskenes.no +moss.no +mosvik.no +malselv.no +målselv.no +malatvuopmi.no +málatvuopmi.no +namdalseid.no +aejrie.no +namsos.no +namsskogan.no +naamesjevuemie.no +nååmesjevuemie.no +laakesvuemie.no +nannestad.no +narvik.no +narviika.no +naustdal.no +nedre-eiker.no +nes.akershus.no +nes.buskerud.no +nesna.no +nesodden.no +nesseby.no +unjarga.no +unjárga.no +nesset.no +nissedal.no +nittedal.no +nord-aurdal.no +nord-fron.no +nord-odal.no +norddal.no +nordkapp.no +davvenjarga.no +davvenjárga.no +nordre-land.no +nordreisa.no +raisa.no +ráisa.no +nore-og-uvdal.no +notodden.no +naroy.no +nærøy.no +notteroy.no +nøtterøy.no +odda.no +oksnes.no +øksnes.no +oppdal.no +oppegard.no +oppegård.no +orkdal.no +orland.no +ørland.no +orskog.no +ørskog.no +orsta.no +ørsta.no +os.hedmark.no +os.hordaland.no +osen.no +osteroy.no +osterøy.no +ostre-toten.no +østre-toten.no +overhalla.no +ovre-eiker.no +øvre-eiker.no +oyer.no +øyer.no +oygarden.no +øygarden.no +oystre-slidre.no +øystre-slidre.no +porsanger.no +porsangu.no +porsáŋgu.no +porsgrunn.no +radoy.no +radøy.no +rakkestad.no +rana.no +ruovat.no +randaberg.no +rauma.no +rendalen.no +rennebu.no +rennesoy.no +rennesøy.no +rindal.no +ringebu.no +ringerike.no +ringsaker.no +rissa.no +risor.no +risør.no +roan.no +rollag.no +rygge.no +ralingen.no +rælingen.no +rodoy.no +rødøy.no +romskog.no +rømskog.no +roros.no +røros.no +rost.no +røst.no +royken.no +røyken.no +royrvik.no +røyrvik.no +rade.no +råde.no +salangen.no +siellak.no +saltdal.no +salat.no +sálát.no +sálat.no +samnanger.no +sande.more-og-romsdal.no +sande.møre-og-romsdal.no +sande.vestfold.no +sandefjord.no +sandnes.no +sandoy.no +sandøy.no +sarpsborg.no +sauda.no +sauherad.no +sel.no +selbu.no +selje.no +seljord.no +sigdal.no +siljan.no +sirdal.no +skaun.no +skedsmo.no +ski.no +skien.no +skiptvet.no +skjervoy.no +skjervøy.no +skierva.no +skiervá.no +skjak.no +skjåk.no +skodje.no +skanland.no +skånland.no +skanit.no +skánit.no +smola.no +smøla.no +snillfjord.no +snasa.no +snåsa.no +snoasa.no +snaase.no +snåase.no +sogndal.no +sokndal.no +sola.no +solund.no +songdalen.no +sortland.no +spydeberg.no +stange.no +stavanger.no +steigen.no +steinkjer.no +stjordal.no +stjørdal.no +stokke.no +stor-elvdal.no +stord.no +stordal.no +storfjord.no +omasvuotna.no +strand.no +stranda.no +stryn.no +sula.no +suldal.no +sund.no +sunndal.no +surnadal.no +sveio.no +svelvik.no +sykkylven.no +sogne.no +søgne.no +somna.no +sømna.no +sondre-land.no +søndre-land.no +sor-aurdal.no +sør-aurdal.no +sor-fron.no +sør-fron.no +sor-odal.no +sør-odal.no +sor-varanger.no +sør-varanger.no +matta-varjjat.no +mátta-várjjat.no +sorfold.no +sørfold.no +sorreisa.no +sørreisa.no +sorum.no +sørum.no +tana.no +deatnu.no +time.no +tingvoll.no +tinn.no +tjeldsund.no +dielddanuorri.no +tjome.no +tjøme.no +tokke.no +tolga.no +torsken.no +tranoy.no +tranøy.no +tromso.no +tromsø.no +tromsa.no +romsa.no +trondheim.no +troandin.no +trysil.no +trana.no +træna.no +trogstad.no +trøgstad.no +tvedestrand.no +tydal.no +tynset.no +tysfjord.no +divtasvuodna.no +divttasvuotna.no +tysnes.no +tysvar.no +tysvær.no +tonsberg.no +tønsberg.no +ullensaker.no +ullensvang.no +ulvik.no +utsira.no +vadso.no +vadsø.no +cahcesuolo.no +čáhcesuolo.no +vaksdal.no +valle.no +vang.no +vanylven.no +vardo.no +vardø.no +varggat.no +várggát.no +vefsn.no +vaapste.no +vega.no +vegarshei.no +vegårshei.no +vennesla.no +verdal.no +verran.no +vestby.no +vestnes.no +vestre-slidre.no +vestre-toten.no +vestvagoy.no +vestvågøy.no +vevelstad.no +vik.no +vikna.no +vindafjord.no +volda.no +voss.no +varoy.no +værøy.no +vagan.no +vågan.no +voagat.no +vagsoy.no +vågsøy.no +vaga.no +vågå.no +valer.ostfold.no +våler.østfold.no +valer.hedmark.no +våler.hedmark.no +nnr +biz.nr +info.nr +gov.nr +edu.nr +org.nr +net.nr +com.nr +nu +nz +ac.nz +co.nz +cri.nz +geek.nz +gen.nz +govt.nz +health.nz +iwi.nz +kiwi.nz +maori.nz +mil.nz +māori.nz +net.nz +org.nz +parliament.nz +school.nz +om +co.om +com.om +edu.om +gov.om +med.om +museum.om +net.om +org.om +pro.om +onion +org +pa +ac.pa +gob.pa +com.pa +org.pa +sld.pa +edu.pa +net.pa +ing.pa +abo.pa +med.pa +nom.pa +pe +edu.pe +gob.pe +nom.pe +mil.pe +org.pe +com.pe +net.pe +pf +com.pf +org.pf +edu.pf +pph +com.ph +net.ph +org.ph +gov.ph +edu.ph +ngo.ph +mil.ph +i.ph +pk +com.pk +net.pk +edu.pk +org.pk +fam.pk +biz.pk +web.pk +gov.pk +gob.pk +gok.pk +gon.pk +gop.pk +gos.pk +info.pk +pl +com.pl +net.pl +org.pl +aid.pl +agro.pl +atm.pl +auto.pl +biz.pl +edu.pl +gmina.pl +gsm.pl +info.pl +mail.pl +miasta.pl +media.pl +mil.pl +nieruchomosci.pl +nom.pl +pc.pl +powiat.pl +priv.pl +realestate.pl +rel.pl +sex.pl +shop.pl +sklep.pl +sos.pl +szkola.pl +targi.pl +tm.pl +tourism.pl +travel.pl +turystyka.pl +gov.pl +ap.gov.pl +ic.gov.pl +is.gov.pl +us.gov.pl +kmpsp.gov.pl +kppsp.gov.pl +kwpsp.gov.pl +psp.gov.pl +wskr.gov.pl +kwp.gov.pl +mw.gov.pl +ug.gov.pl +um.gov.pl +umig.gov.pl +ugim.gov.pl +upow.gov.pl +uw.gov.pl +starostwo.gov.pl +pa.gov.pl +po.gov.pl +psse.gov.pl +pup.gov.pl +rzgw.gov.pl +sa.gov.pl +so.gov.pl +sr.gov.pl +wsa.gov.pl +sko.gov.pl +uzs.gov.pl +wiih.gov.pl +winb.gov.pl +pinb.gov.pl +wios.gov.pl +witd.gov.pl +wzmiuw.gov.pl +piw.gov.pl +wiw.gov.pl +griw.gov.pl +wif.gov.pl +oum.gov.pl +sdn.gov.pl +zp.gov.pl +uppo.gov.pl +mup.gov.pl +wuoz.gov.pl +konsulat.gov.pl +oirm.gov.pl +augustow.pl +babia-gora.pl +bedzin.pl +beskidy.pl +bialowieza.pl +bialystok.pl +bielawa.pl +bieszczady.pl +boleslawiec.pl +bydgoszcz.pl +bytom.pl +cieszyn.pl +czeladz.pl +czest.pl +dlugoleka.pl +elblag.pl +elk.pl +glogow.pl +gniezno.pl +gorlice.pl +grajewo.pl +ilawa.pl +jaworzno.pl +jelenia-gora.pl +jgora.pl +kalisz.pl +kazimierz-dolny.pl +karpacz.pl +kartuzy.pl +kaszuby.pl +katowice.pl +kepno.pl +ketrzyn.pl +klodzko.pl +kobierzyce.pl +kolobrzeg.pl +konin.pl +konskowola.pl +kutno.pl +lapy.pl +lebork.pl +legnica.pl +lezajsk.pl +limanowa.pl +lomza.pl +lowicz.pl +lubin.pl +lukow.pl +malbork.pl +malopolska.pl +mazowsze.pl +mazury.pl +mielec.pl +mielno.pl +mragowo.pl +naklo.pl +nowaruda.pl +nysa.pl +olawa.pl +olecko.pl +olkusz.pl +olsztyn.pl +opoczno.pl +opole.pl +ostroda.pl +ostroleka.pl +ostrowiec.pl +ostrowwlkp.pl +pila.pl +pisz.pl +podhale.pl +podlasie.pl +polkowice.pl +pomorze.pl +pomorskie.pl +prochowice.pl +pruszkow.pl +przeworsk.pl +pulawy.pl +radom.pl +rawa-maz.pl +rybnik.pl +rzeszow.pl +sanok.pl +sejny.pl +slask.pl +slupsk.pl +sosnowiec.pl +stalowa-wola.pl +skoczow.pl +starachowice.pl +stargard.pl +suwalki.pl +swidnica.pl +swiebodzin.pl +swinoujscie.pl +szczecin.pl +szczytno.pl +tarnobrzeg.pl +tgory.pl +turek.pl +tychy.pl +ustka.pl +walbrzych.pl +warmia.pl +warszawa.pl +waw.pl +wegrow.pl +wielun.pl +wlocl.pl +wloclawek.pl +wodzislaw.pl +wolomin.pl +wroclaw.pl +zachpomor.pl +zagan.pl +zarow.pl +zgora.pl +zgorzelec.pl +pm +pn +gov.pn +co.pn +org.pn +edu.pn +net.pn +post +pr +com.pr +net.pr +org.pr +gov.pr +edu.pr +isla.pr +pro.pr +biz.pr +info.pr +name.pr +est.pr +prof.pr +ac.pr +pro +aaa.pro +aca.pro +acct.pro +avocat.pro +bar.pro +cpa.pro +eng.pro +jur.pro +law.pro +med.pro +recht.pro +ps +edu.ps +gov.ps +sec.ps +plo.ps +com.ps +org.ps +net.ps +pt +net.pt +gov.pt +org.pt +edu.pt +int.pt +publ.pt +com.pt +nome.pt +pw +co.pw +ne.pw +or.pw +ed.pw +go.pw +belau.pw +py +com.py +coop.py +edu.py +gov.py +mil.py +net.py +org.py +qa +com.qa +edu.qa +gov.qa +mil.qa +name.qa +net.qa +org.qa +sch.qa +re +asso.re +com.re +nom.re +ro +arts.ro +com.ro +firm.ro +info.ro +nom.ro +nt.ro +org.ro +rec.ro +store.ro +tm.ro +www.ro +rs +ac.rs +co.rs +edu.rs +gov.rs +in.rs +org.rs +ru +ac.ru +edu.ru +gov.ru +int.ru +mil.ru +test.ru +rw +gov.rw +net.rw +edu.rw +ac.rw +com.rw +co.rw +int.rw +mil.rw +gouv.rw +sa +com.sa +net.sa +org.sa +gov.sa +med.sa +pub.sa +edu.sa +sch.sa +sb +com.sb +edu.sb +gov.sb +net.sb +org.sb +sc +com.sc +gov.sc +net.sc +org.sc +edu.sc +sd +com.sd +net.sd +org.sd +edu.sd +med.sd +tv.sd +gov.sd +info.sd +se +a.se +ac.se +b.se +bd.se +brand.se +c.se +d.se +e.se +f.se +fh.se +fhsk.se +fhv.se +g.se +h.se +i.se +k.se +komforb.se +kommunalforbund.se +komvux.se +l.se +lanbib.se +m.se +n.se +naturbruksgymn.se +o.se +org.se +p.se +parti.se +pp.se +press.se +r.se +s.se +t.se +tm.se +u.se +w.se +x.se +y.se +z.se +sg +com.sg +net.sg +org.sg +gov.sg +edu.sg +per.sg +sh +com.sh +net.sh +gov.sh +org.sh +mil.sh +si +sj +sk +sl +com.sl +net.sl +edu.sl +gov.sl +org.sl +sm +sn +art.sn +com.sn +edu.sn +gouv.sn +org.sn +perso.sn +univ.sn +so +com.so +net.so +org.so +sr +st +co.st +com.st +consulado.st +edu.st +embaixada.st +gov.st +mil.st +net.st +org.st +principe.st +saotome.st +store.st +su +sv +com.sv +edu.sv +gob.sv +org.sv +red.sv +sx +gov.sx +sy +edu.sy +gov.sy +net.sy +mil.sy +com.sy +org.sy +sz +co.sz +ac.sz +org.sz +tc +td +tel +tf +tg +th +ac.th +co.th +go.th +in.th +mi.th +net.th +or.th +tj +ac.tj +biz.tj +co.tj +com.tj +edu.tj +go.tj +gov.tj +int.tj +mil.tj +name.tj +net.tj +nic.tj +org.tj +test.tj +web.tj +tk +tl +gov.tl +tm +com.tm +co.tm +org.tm +net.tm +nom.tm +gov.tm +mil.tm +edu.tm +tn +com.tn +ens.tn +fin.tn +gov.tn +ind.tn +intl.tn +nat.tn +net.tn +org.tn +info.tn +perso.tn +tourism.tn +edunet.tn +rnrt.tn +rns.tn +rnu.tn +mincom.tn +agrinet.tn +defense.tn +turen.tn +to +com.to +gov.to +net.to +org.to +edu.to +mil.to +tr +com.tr +info.tr +biz.tr +net.tr +org.tr +web.tr +gen.tr +tv.tr +av.tr +dr.tr +bbs.tr +name.tr +tel.tr +gov.tr +bel.tr +pol.tr +mil.tr +k12.tr +edu.tr +kep.tr +nc.tr +gov.nc.tr +tt +co.tt +com.tt +org.tt +net.tt +biz.tt +info.tt +pro.tt +int.tt +coop.tt +jobs.tt +mobi.tt +travel.tt +museum.tt +aero.tt +name.tt +gov.tt +edu.tt +tv +tw +edu.tw +gov.tw +mil.tw +com.tw +net.tw +org.tw +idv.tw +game.tw +ebiz.tw +club.tw +網路.tw +組織.tw +商業.tw +tz +ac.tz +co.tz +go.tz +hotel.tz +info.tz +me.tz +mil.tz +mobi.tz +ne.tz +or.tz +sc.tz +tv.tz +ua +com.ua +edu.ua +gov.ua +in.ua +net.ua +org.ua +cherkassy.ua +cherkasy.ua +chernigov.ua +chernihiv.ua +chernivtsi.ua +chernovtsy.ua +ck.ua +cn.ua +cr.ua +crimea.ua +cv.ua +dn.ua +dnepropetrovsk.ua +dnipropetrovsk.ua +dominic.ua +donetsk.ua +dp.ua +if.ua +ivano-frankivsk.ua +kh.ua +kharkiv.ua +kharkov.ua +kherson.ua +khmelnitskiy.ua +khmelnytskyi.ua +kiev.ua +kirovograd.ua +km.ua +kr.ua +krym.ua +ks.ua +kv.ua +kyiv.ua +lg.ua +lt.ua +lugansk.ua +lutsk.ua +lv.ua +lviv.ua +mk.ua +mykolaiv.ua +nikolaev.ua +od.ua +odesa.ua +odessa.ua +pl.ua +poltava.ua +rivne.ua +rovno.ua +rv.ua +sb.ua +sebastopol.ua +sevastopol.ua +sm.ua +sumy.ua +te.ua +ternopil.ua +uz.ua +uzhgorod.ua +vinnica.ua +vinnytsia.ua +vn.ua +volyn.ua +yalta.ua +zaporizhzhe.ua +zaporizhzhia.ua +zhitomir.ua +zhytomyr.ua +zp.ua +zt.ua +ug +co.ug +or.ug +ac.ug +sc.ug +go.ug +ne.ug +com.ug +org.ug +uk +ac.uk +co.uk +gov.uk +ltd.uk +me.uk +net.uk +nhs.uk +org.uk +plc.uk +police.uk +sus +dni.us +fed.us +isa.us +kids.us +nsn.us +ak.us +al.us +ar.us +as.us +az.us +ca.us +co.us +ct.us +dc.us +de.us +fl.us +ga.us +gu.us +hi.us +ia.us +id.us +il.us +in.us +ks.us +ky.us +la.us +ma.us +md.us +me.us +mi.us +mn.us +mo.us +ms.us +mt.us +nc.us +nd.us +ne.us +nh.us +nj.us +nm.us +nv.us +ny.us +oh.us +ok.us +or.us +pa.us +pr.us +ri.us +sc.us +sd.us +tn.us +tx.us +ut.us +vi.us +vt.us +va.us +wa.us +wi.us +wv.us +wy.us +k12.ak.us +k12.al.us +k12.ar.us +k12.as.us +k12.az.us +k12.ca.us +k12.co.us +k12.ct.us +k12.dc.us +k12.de.us +k12.fl.us +k12.ga.us +k12.gu.us +k12.ia.us +k12.id.us +k12.il.us +k12.in.us +k12.ks.us +k12.ky.us +k12.la.us +k12.ma.us +k12.md.us +k12.me.us +k12.mi.us +k12.mn.us +k12.mo.us +k12.ms.us +k12.mt.us +k12.nc.us +k12.ne.us +k12.nh.us +k12.nj.us +k12.nm.us +k12.nv.us +k12.ny.us +k12.oh.us +k12.ok.us +k12.or.us +k12.pa.us +k12.pr.us +k12.ri.us +k12.sc.us +k12.tn.us +k12.tx.us +k12.ut.us +k12.vi.us +k12.vt.us +k12.va.us +k12.wa.us +k12.wi.us +k12.wy.us +cc.ak.us +cc.al.us +cc.ar.us +cc.as.us +cc.az.us +cc.ca.us +cc.co.us +cc.ct.us +cc.dc.us +cc.de.us +cc.fl.us +cc.ga.us +cc.gu.us +cc.hi.us +cc.ia.us +cc.id.us +cc.il.us +cc.in.us +cc.ks.us +cc.ky.us +cc.la.us +cc.ma.us +cc.md.us +cc.me.us +cc.mi.us +cc.mn.us +cc.mo.us +cc.ms.us +cc.mt.us +cc.nc.us +cc.nd.us +cc.ne.us +cc.nh.us +cc.nj.us +cc.nm.us +cc.nv.us +cc.ny.us +cc.oh.us +cc.ok.us +cc.or.us +cc.pa.us +cc.pr.us +cc.ri.us +cc.sc.us +cc.sd.us +cc.tn.us +cc.tx.us +cc.ut.us +cc.vi.us +cc.vt.us +cc.va.us +cc.wa.us +cc.wi.us +cc.wv.us +cc.wy.us +lib.ak.us +lib.al.us +lib.ar.us +lib.as.us +lib.az.us +lib.ca.us +lib.co.us +lib.ct.us +lib.dc.us +lib.fl.us +lib.ga.us +lib.gu.us +lib.hi.us +lib.ia.us +lib.id.us +lib.il.us +lib.in.us +lib.ks.us +lib.ky.us +lib.la.us +lib.ma.us +lib.md.us +lib.me.us +lib.mi.us +lib.mn.us +lib.mo.us +lib.ms.us +lib.mt.us +lib.nc.us +lib.nd.us +lib.ne.us +lib.nh.us +lib.nj.us +lib.nm.us +lib.nv.us +lib.ny.us +lib.oh.us +lib.ok.us +lib.or.us +lib.pa.us +lib.pr.us +lib.ri.us +lib.sc.us +lib.sd.us +lib.tn.us +lib.tx.us +lib.ut.us +lib.vi.us +lib.vt.us +lib.va.us +lib.wa.us +lib.wi.us +lib.wy.us +pvt.k12.ma.us +chtr.k12.ma.us +paroch.k12.ma.us +ann-arbor.mi.us +cog.mi.us +dst.mi.us +eaton.mi.us +gen.mi.us +mus.mi.us +tec.mi.us +washtenaw.mi.us +uy +com.uy +edu.uy +gub.uy +mil.uy +net.uy +org.uy +uz +co.uz +com.uz +net.uz +org.uz +va +vc +com.vc +net.vc +org.vc +gov.vc +mil.vc +edu.vc +ve +arts.ve +co.ve +com.ve +e12.ve +edu.ve +firm.ve +gob.ve +gov.ve +info.ve +int.ve +mil.ve +net.ve +org.ve +rec.ve +store.ve +tec.ve +web.ve +vg +vi +co.vi +com.vi +k12.vi +net.vi +org.vi +vn +com.vn +net.vn +org.vn +edu.vn +gov.vn +int.vn +ac.vn +biz.vn +info.vn +name.vn +pro.vn +health.vn +vu +com.vu +edu.vu +net.vu +org.vu +wf +ws +com.ws +net.ws +org.ws +gov.ws +edu.ws +yt +امارات +հայ +বাংলা +бг +бел +中国 +中國 +الجزائر +مصر +ею +გე +ελ +香港 +公司.香港 +教育.香港 +政府.香港 +個人.香港 +網絡.香港 +組織.香港 +ಭಾರತ +ଭାରତ +ভাৰত +भारतम् +भारोत +ڀارت +ഭാരതം +भारत +بارت +بھارت +భారత్ +ભારત +ਭਾਰਤ +ভারত +இந்தியா +ایران +ايران +عراق +الاردن +한국 +қаз +ලංකා +இலங்கை +المغرب +мкд +мон +澳門 +澳门 +مليسيا +عمان +پاکستان +پاكستان +فلسطين +срб +пр.срб +орг.срб +обр.срб +од.срб +упр.срб +ак.срб +рф +قطر +السعودية +السعودیة +السعودیۃ +السعوديه +سودان +新加坡 +சிங்கப்பூர் +سورية +سوريا +ไทย +ศึกษา.ไทย +ธุรกิจ.ไทย +รัฐบาล.ไทย +ทหาร.ไทย +เน็ต.ไทย +องค์กร.ไทย +تونس +台灣 +台湾 +臺灣 +укр +اليمن +xxx +yac.za +agric.za +alt.za +co.za +edu.za +gov.za +grondar.za +law.za +mil.za +net.za +ngo.za +nis.za +nom.za +org.za +school.za +tm.za +web.za +zm +ac.zm +biz.zm +co.zm +com.zm +edu.zm +gov.zm +info.zm +mil.zm +net.zm +org.zm +sch.zm +zw +ac.zw +co.zw +gov.zw +mil.zw +org.zw +aaa +aarp +abarth +abb +abbott +abbvie +abc +able +abogado +abudhabi +academy +accenture +accountant +accountants +aco +actor +adac +ads +adult +aeg +aetna +afamilycompany +afl +africa +agakhan +agency +aig +aigo +airbus +airforce +airtel +akdn +alfaromeo +alibaba +alipay +allfinanz +allstate +ally +alsace +alstom +americanexpress +americanfamily +amex +amfam +amica +amsterdam +analytics +android +anquan +anz +aol +apartments +app +apple +aquarelle +arab +aramco +archi +army +art +arte +asda +associates +athleta +attorney +auction +audi +audible +audio +auspost +author +auto +autos +avianca +aws +axa +azure +baby +baidu +banamex +bananarepublic +band +bank +bar +barcelona +barclaycard +barclays +barefoot +bargains +baseball +basketball +bauhaus +bayern +bbc +bbt +bbva +bcg +bcn +beats +beauty +beer +bentley +berlin +best +bestbuy +bet +bharti +bible +bid +bike +bing +bingo +bio +black +blackfriday +blockbuster +blog +bloomberg +blue +bms +bmw +bnl +bnpparibas +boats +boehringer +bofa +bom +bond +boo +book +booking +bosch +bostik +boston +bot +boutique +box +bradesco +bridgestone +broadway +broker +brother +brussels +budapest +bugatti +build +builders +business +buy +buzz +bzh +cab +cafe +cal +call +calvinklein +cam +camera +camp +cancerresearch +canon +capetown +capital +capitalone +car +caravan +cards +care +career +careers +cars +cartier +casa +case +caseih +cash +casino +catering +catholic +cba +cbn +cbre +cbs +ceb +center +ceo +cern +cfa +cfd +chanel +channel +charity +chase +chat +cheap +chintai +christmas +chrome +chrysler +church +cipriani +circle +cisco +citadel +citi +citic +city +cityeats +claims +cleaning +click +clinic +clinique +clothing +cloud +club +clubmed +coach +codes +coffee +college +cologne +comcast +commbank +community +company +compare +computer +comsec +condos +construction +consulting +contact +contractors +cooking +cookingchannel +cool +corsica +country +coupon +coupons +courses +credit +creditcard +creditunion +cricket +crown +crs +cruise +cruises +csc +cuisinella +cymru +cyou +dabur +dad +dance +data +date +dating +datsun +day +dclk +dds +deal +dealer +deals +degree +delivery +dell +deloitte +delta +democrat +dental +dentist +desi +design +dev +dhl +diamonds +diet +digital +direct +directory +discount +discover +dish +diy +dnp +docs +doctor +dodge +dog +doha +domains +dot +download +drive +dtv +dubai +duck +dunlop +duns +dupont +durban +dvag +dvr +earth +eat +eco +edeka +education +email +emerck +energy +engineer +engineering +enterprises +epson +equipment +ericsson +erni +esq +estate +esurance +etisalat +eurovision +eus +events +everbank +exchange +expert +exposed +express +extraspace +fage +fail +fairwinds +faith +family +fan +fans +farm +farmers +fashion +fast +fedex +feedback +ferrari +ferrero +fiat +fidelity +fido +film +final +finance +financial +fire +firestone +firmdale +fish +fishing +fit +fitness +flickr +flights +flir +florist +flowers +fly +foo +food +foodnetwork +football +ford +forex +forsale +forum +foundation +fox +free +fresenius +frl +frogans +frontdoor +frontier +ftr +fujitsu +fujixerox +fun +fund +furniture +futbol +fyi +gal +gallery +gallo +gallup +game +games +gap +garden +gbiz +gdn +gea +gent +genting +george +ggee +gift +gifts +gives +giving +glade +glass +gle +global +globo +gmail +gmbh +gmo +gmx +godaddy +gold +goldpoint +golf +goo +goodyear +goog +google +gop +got +grainger +graphics +gratis +green +gripe +grocery +group +guardian +gucci +guge +guide +guitars +guru +hair +hamburg +hangout +haus +hbo +hdfc +hdfcbank +health +healthcare +help +helsinki +here +hermes +hgtv +hiphop +hisamitsu +hitachi +hiv +hkt +hockey +holdings +holiday +homedepot +homegoods +homes +homesense +honda +honeywell +horse +hospital +host +hosting +hot +hoteles +hotels +hotmail +house +how +hsbc +hughes +hyatt +hyundai +ibm +icbc +ice +icu +ieee +ifm +ikano +imamat +imdb +immo +immobilien +inc +industries +infiniti +ing +ink +institute +insurance +insure +intel +international +intuit +investments +ipiranga +irish +iselect +ismaili +ist +istanbul +itau +itv +iveco +jaguar +java +jcb +jcp +jeep +jetzt +jewelry +jio +jll +jmp +jnj +joburg +jot +joy +jpmorgan +jprs +juegos +juniper +kaufen +kddi +kerryhotels +kerrylogistics +kerryproperties +kfh +kia +kim +kinder +kindle +kitchen +kiwi +koeln +komatsu +kosher +kpmg +kpn +krd +kred +kuokgroup +kyoto +lacaixa +ladbrokes +lamborghini +lamer +lancaster +lancia +lancome +land +landrover +lanxess +lasalle +lat +latino +latrobe +law +lawyer +lds +lease +leclerc +lefrak +legal +lego +lexus +lgbt +liaison +lidl +life +lifeinsurance +lifestyle +lighting +like +lilly +limited +limo +lincoln +linde +link +lipsy +live +living +lixil +llc +loan +loans +locker +locus +loft +lol +london +lotte +lotto +love +lpl +lplfinancial +ltd +ltda +lundbeck +lupin +luxe +luxury +macys +madrid +maif +maison +makeup +man +management +mango +map +market +marketing +markets +marriott +marshalls +maserati +mattel +mba +mckinsey +med +media +meet +melbourne +meme +memorial +men +menu +merckmsd +metlife +miami +microsoft +mini +mint +mit +mitsubishi +mlb +mls +mma +mobile +mobily +moda +moe +moi +mom +monash +money +monster +mopar +mormon +mortgage +moscow +moto +motorcycles +mov +movie +movistar +msd +mtn +mtr +mutual +nab +nadex +nagoya +nationwide +natura +navy +nba +nec +netbank +netflix +network +neustar +new +newholland +news +next +nextdirect +nexus +nfl +ngo +nhk +nico +nike +nikon +ninja +nissan +nissay +nokia +northwesternmutual +norton +now +nowruz +nowtv +nra +nrw +ntt +nyc +obi +observer +off +office +okinawa +olayan +olayangroup +oldnavy +ollo +omega +one +ong +onl +online +onyourside +ooo +open +oracle +orange +organic +origins +osaka +otsuka +ott +ovh +page +panasonic +paris +pars +partners +parts +party +passagens +pay +pccw +pet +pfizer +pharmacy +phd +philips +phone +photo +photography +photos +physio +piaget +pics +pictet +pictures +pid +pin +ping +pink +pioneer +pizza +place +play +playstation +plumbing +plus +pnc +pohl +poker +politie +porn +pramerica +praxi +press +prime +prod +productions +prof +progressive +promo +properties +property +protection +pru +prudential +pub +pwc +qpon +quebec +quest +qvc +racing +radio +raid +read +realestate +realtor +realty +recipes +red +redstone +redumbrella +rehab +reise +reisen +reit +reliance +ren +rent +rentals +repair +report +republican +rest +restaurant +review +reviews +rexroth +rich +richardli +ricoh +rightathome +ril +rio +rip +rmit +rocher +rocks +rodeo +rogers +room +rsvp +rugby +ruhr +run +rwe +ryukyu +saarland +safe +safety +sakura +sale +salon +samsclub +samsung +sandvik +sandvikcoromant +sanofi +sap +sarl +sas +save +saxo +sbi +sbs +sca +scb +schaeffler +schmidt +scholarships +school +schule +schwarz +science +scjohnson +scor +scot +search +seat +secure +security +seek +select +sener +services +ses +seven +sew +sex +sexy +sfr +shangrila +sharp +shaw +shell +shia +shiksha +shoes +shop +shopping +shouji +show +showtime +shriram +silk +sina +singles +site +ski +skin +sky +skype +sling +smart +smile +sncf +soccer +social +softbank +software +sohu +solar +solutions +song +sony +soy +space +sport +spot +spreadbetting +srl +srt +stada +staples +star +starhub +statebank +statefarm +stc +stcgroup +stockholm +storage +store +stream +studio +study +style +sucks +supplies +supply +support +surf +surgery +suzuki +swatch +swiftcover +swiss +sydney +symantec +systems +tab +taipei +talk +taobao +target +tatamotors +tatar +tattoo +tax +taxi +tci +tdk +team +tech +technology +telefonica +temasek +tennis +teva +thd +theater +theatre +tiaa +tickets +tienda +tiffany +tips +tires +tirol +tjmaxx +tjx +tkmaxx +tmall +today +tokyo +tools +top +toray +toshiba +total +tours +town +toyota +toys +trade +trading +training +travel +travelchannel +travelers +travelersinsurance +trust +trv +tube +tui +tunes +tushu +tvs +ubank +ubs +uconnect +unicom +university +uno +uol +ups +vacations +vana +vanguard +vegas +ventures +verisign +versicherung +vet +viajes +video +vig +viking +villas +vin +vip +virgin +visa +vision +vistaprint +viva +vivo +vlaanderen +vodka +volkswagen +volvo +vote +voting +voto +voyage +vuelos +wales +walmart +walter +wang +wanggou +warman +watch +watches +weather +weatherchannel +webcam +weber +website +wed +wedding +weibo +weir +whoswho +wien +wiki +williamhill +win +windows +wine +winners +wme +wolterskluwer +woodside +work +works +world +wow +wtc +wtf +xbox +xerox +xfinity +xihuan +xin +कॉम +セール +佛山 +慈善 +集团 +在线 +大众汽车 +点看 +คอม +八卦 +موقع +公益 +公司 +香格里拉 +网站 +移动 +我爱你 +москва +католик +онлайн +сайт +联通 +קום +时尚 +微博 +淡马锡 +ファッション +орг +नेट +ストア +삼성 +商标 +商店 +商城 +дети +ポイント +新闻 +工行 +家電 +كوم +中文网 +中信 +娱乐 +谷歌 +電訊盈科 +购物 +クラウド +通販 +网店 +संगठन +餐厅 +网络 +ком +诺基亚 +食品 +飞利浦 +手表 +手机 +ارامكو +العليان +اتصالات +بازار +موبايلي +ابوظبي +كاثوليك +همراه +닷컴 +政府 +شبكة +بيتك +عرب +机构 +组织机构 +健康 +招聘 +рус +珠宝 +大拿 +みんな +グーグル +世界 +書籍 +网址 +닷넷 +コム +天主教 +游戏 +vermögensberater +vermögensberatung +企业 +信息 +嘉里大酒店 +嘉里 +广东 +政务 +xyz +yachts +yahoo +yamaxun +yandex +yodobashi +yoga +yokohama +you +youtube +yun +zappos +zara +zero +zip +zone +zuerich +cc.ua +inf.ua +ltd.ua +beep.pl +caalwaysdata.net +cloudfront.net +cccus-east-1.amazonaws.com +cn-north-1.eb.amazonaws.com.cn +cn-northwest-1.eb.amazonaws.com.cn +elasticbeanstalk.com +ap-northeast-1.elasticbeanstalk.com +ap-northeast-2.elasticbeanstalk.com +ap-northeast-3.elasticbeanstalk.com +ap-south-1.elasticbeanstalk.com +ap-southeast-1.elasticbeanstalk.com +ap-southeast-2.elasticbeanstalk.com +ca-central-1.elasticbeanstalk.com +eu-central-1.elasticbeanstalk.com +eu-west-1.elasticbeanstalk.com +eu-west-2.elasticbeanstalk.com +eu-west-3.elasticbeanstalk.com +sa-east-1.elasticbeanstalk.com +us-east-1.elasticbeanstalk.com +us-east-2.elasticbeanstalk.com +us-gov-west-1.elasticbeanstalk.com +us-west-1.elasticbeanstalk.com +us-west-2.elasticbeanstalk.com +ees3.amazonaws.com +s3-ap-northeast-1.amazonaws.com +s3-ap-northeast-2.amazonaws.com +s3-ap-south-1.amazonaws.com +s3-ap-southeast-1.amazonaws.com +s3-ap-southeast-2.amazonaws.com +s3-ca-central-1.amazonaws.com +s3-eu-central-1.amazonaws.com +s3-eu-west-1.amazonaws.com +s3-eu-west-2.amazonaws.com +s3-eu-west-3.amazonaws.com +s3-external-1.amazonaws.com +s3-fips-us-gov-west-1.amazonaws.com +s3-sa-east-1.amazonaws.com +s3-us-gov-west-1.amazonaws.com +s3-us-east-2.amazonaws.com +s3-us-west-1.amazonaws.com +s3-us-west-2.amazonaws.com +s3.ap-northeast-2.amazonaws.com +s3.ap-south-1.amazonaws.com +s3.cn-north-1.amazonaws.com.cn +s3.ca-central-1.amazonaws.com +s3.eu-central-1.amazonaws.com +s3.eu-west-2.amazonaws.com +s3.eu-west-3.amazonaws.com +s3.us-east-2.amazonaws.com +s3.dualstack.ap-northeast-1.amazonaws.com +s3.dualstack.ap-northeast-2.amazonaws.com +s3.dualstack.ap-south-1.amazonaws.com +s3.dualstack.ap-southeast-1.amazonaws.com +s3.dualstack.ap-southeast-2.amazonaws.com +s3.dualstack.ca-central-1.amazonaws.com +s3.dualstack.eu-central-1.amazonaws.com +s3.dualstack.eu-west-1.amazonaws.com +s3.dualstack.eu-west-2.amazonaws.com +s3.dualstack.eu-west-3.amazonaws.com +s3.dualstack.sa-east-1.amazonaws.com +s3.dualstack.us-east-1.amazonaws.com +s3.dualstack.us-east-2.amazonaws.com +s3-website-us-east-1.amazonaws.com +s3-website-us-west-1.amazonaws.com +s3-website-us-west-2.amazonaws.com +s3-website-ap-northeast-1.amazonaws.com +s3-website-ap-southeast-1.amazonaws.com +s3-website-ap-southeast-2.amazonaws.com +s3-website-eu-west-1.amazonaws.com +s3-website-sa-east-1.amazonaws.com +s3-website.ap-northeast-2.amazonaws.com +s3-website.ap-south-1.amazonaws.com +s3-website.ca-central-1.amazonaws.com +s3-website.eu-central-1.amazonaws.com +s3-website.eu-west-2.amazonaws.com +s3-website.eu-west-3.amazonaws.com +s3-website.us-east-2.amazonaws.com +t3l3p0rt.net +tele.amune.org +apigee.io +on-aptible.com +user.party.eus +pimienta.org +poivron.org +potager.org +sweetpepper.org +myasustor.com +go-vip.co +go-vip.net +wpcomstaging.com +myfritz.net +aabackplaneapp.io +betainabox.com +bnr.la +blackbaudcdn.net +boomla.net +boxfuse.io +square7.ch +bplaced.com +bplaced.de +square7.de +bplaced.net +square7.net +browsersafetymark.io +uk0.bigv.io +dh.bytemark.co.uk +vm.bytemark.co.uk +mycd.eu +ae.org +ar.com +br.com +cn.com +com.de +com.se +de.com +eu.com +gb.com +gb.net +hu.com +hu.net +jp.net +jpn.com +kr.com +mex.com +no.com +qc.com +ru.com +sa.com +se.net +uk.com +uk.net +us.com +uy.com +za.bz +za.com +africa.com +gr.com +in.net +us.org +co.com +c.la +certmgr.org +xenapponazure.com +discourse.group +virtueeldomein.nl +cleverapps.io +c66.me +cloud66.ws +jdevcloud.com +wpdevcloud.com +cloudaccess.host +freesite.host +cloudaccess.net +cloudcontrolled.com +cloudcontrolapp.com +workers.dev +co.ca +oco.cz +c.cdn77.org +cdn77-ssl.net +r.cdn77.net +rsc.cdn77.org +ssl.origin.cdn77-secure.org +cloudns.asia +cloudns.biz +cloudns.club +cloudns.cc +cloudns.eu +cloudns.in +cloudns.info +cloudns.org +cloudns.pro +cloudns.pw +cloudns.us +cloudeity.net +cnpy.gdn +co.nl +co.no +webhosting.be +hosting-cluster.nl +dyn.cosidns.de +dynamisches-dns.de +dnsupdater.de +internet-dns.de +l-o-g-i-n.de +dynamic-dns.info +feste-ip.net +knx-server.net +static-access.net +realm.cz +ccupcake.is +cyon.link +cyon.site +daplie.me +localhost.daplie.me +dattolocal.com +dattorelay.com +dattoweb.com +mydatto.com +dattolocal.net +mydatto.net +biz.dk +co.dk +firm.dk +reg.dk +store.dk +dbdebian.net +dedyn.io +dnshome.de +online.th +shop.th +drayddns.com +dreamhosters.com +mydrobo.com +drud.io +drud.us +duckdns.org +dy.fi +tunk.org +dyndns-at-home.com +dyndns-at-work.com +dyndns-blog.com +dyndns-free.com +dyndns-home.com +dyndns-ip.com +dyndns-mail.com +dyndns-office.com +dyndns-pics.com +dyndns-remote.com +dyndns-server.com +dyndns-web.com +dyndns-wiki.com +dyndns-work.com +dyndns.biz +dyndns.info +dyndns.org +dyndns.tv +at-band-camp.net +ath.cx +barrel-of-knowledge.info +barrell-of-knowledge.info +better-than.tv +blogdns.com +blogdns.net +blogdns.org +blogsite.org +boldlygoingnowhere.org +broke-it.net +buyshouses.net +cechire.com +dnsalias.com +dnsalias.net +dnsalias.org +dnsdojo.com +dnsdojo.net +dnsdojo.org +does-it.net +doesntexist.com +doesntexist.org +dontexist.com +dontexist.net +dontexist.org +doomdns.com +doomdns.org +dvrdns.org +dyn-o-saur.com +dynalias.com +dynalias.net +dynalias.org +dynathome.net +dyndns.ws +endofinternet.net +endofinternet.org +endoftheinternet.org +est-a-la-maison.com +est-a-la-masion.com +est-le-patron.com +est-mon-blogueur.com +for-better.biz +for-more.biz +for-our.info +for-some.biz +for-the.biz +forgot.her.name +forgot.his.name +from-ak.com +from-al.com +from-ar.com +from-az.net +from-ca.com +from-co.net +from-ct.com +from-dc.com +from-de.com +from-fl.com +from-ga.com +from-hi.com +from-ia.com +from-id.com +from-il.com +from-in.com +from-ks.com +from-ky.com +from-la.net +from-ma.com +from-md.com +from-me.org +from-mi.com +from-mn.com +from-mo.com +from-ms.com +from-mt.com +from-nc.com +from-nd.com +from-ne.com +from-nh.com +from-nj.com +from-nm.com +from-nv.com +from-ny.net +from-oh.com +from-ok.com +from-or.com +from-pa.com +from-pr.com +from-ri.com +from-sc.com +from-sd.com +from-tn.com +from-tx.com +from-ut.com +from-va.com +from-vt.com +from-wa.com +from-wi.com +from-wv.com +from-wy.com +ftpaccess.cc +fuettertdasnetz.de +game-host.org +game-server.cc +getmyip.com +gets-it.net +go.dyndns.org +gotdns.com +gotdns.org +groks-the.info +groks-this.info +ham-radio-op.net +here-for-more.info +hobby-site.com +hobby-site.org +home.dyndns.org +homedns.org +homeftp.net +homeftp.org +homeip.net +homelinux.com +homelinux.net +homelinux.org +homeunix.com +homeunix.net +homeunix.org +iamallama.com +in-the-band.net +is-a-anarchist.com +is-a-blogger.com +is-a-bookkeeper.com +is-a-bruinsfan.org +is-a-bulls-fan.com +is-a-candidate.org +is-a-caterer.com +is-a-celticsfan.org +is-a-chef.com +is-a-chef.net +is-a-chef.org +is-a-conservative.com +is-a-cpa.com +is-a-cubicle-slave.com +is-a-democrat.com +is-a-designer.com +is-a-doctor.com +is-a-financialadvisor.com +is-a-geek.com +is-a-geek.net +is-a-geek.org +is-a-green.com +is-a-guru.com +is-a-hard-worker.com +is-a-hunter.com +is-a-knight.org +is-a-landscaper.com +is-a-lawyer.com +is-a-liberal.com +is-a-libertarian.com +is-a-linux-user.org +is-a-llama.com +is-a-musician.com +is-a-nascarfan.com +is-a-nurse.com +is-a-painter.com +is-a-patsfan.org +is-a-personaltrainer.com +is-a-photographer.com +is-a-player.com +is-a-republican.com +is-a-rockstar.com +is-a-socialist.com +is-a-soxfan.org +is-a-student.com +is-a-teacher.com +is-a-techie.com +is-a-therapist.com +is-an-accountant.com +is-an-actor.com +is-an-actress.com +is-an-anarchist.com +is-an-artist.com +is-an-engineer.com +is-an-entertainer.com +is-by.us +is-certified.com +is-found.org +is-gone.com +is-into-anime.com +is-into-cars.com +is-into-cartoons.com +is-into-games.com +is-leet.com +is-lost.org +is-not-certified.com +is-saved.org +is-slick.com +is-uberleet.com +is-very-bad.org +is-very-evil.org +is-very-good.org +is-very-nice.org +is-very-sweet.org +is-with-theband.com +isa-geek.com +isa-geek.net +isa-geek.org +isa-hockeynut.com +issmarterthanyou.com +isteingeek.de +istmein.de +kicks-ass.net +kicks-ass.org +knowsitall.info +land-4-sale.us +lebtimnetz.de +leitungsen.de +likes-pie.com +likescandy.com +merseine.nu +mine.nu +misconfused.org +mypets.ws +myphotos.cc +neat-url.com +office-on-the.net +on-the-web.tv +podzone.net +podzone.org +readmyblog.org +saves-the-whales.com +scrapper-site.net +scrapping.cc +selfip.biz +selfip.com +selfip.info +selfip.net +selfip.org +sells-for-less.com +sells-for-u.com +sells-it.net +sellsyourhome.org +servebbs.com +servebbs.net +servebbs.org +serveftp.net +serveftp.org +servegame.org +shacknet.nu +simple-url.com +space-to-rent.com +stuff-4-sale.org +stuff-4-sale.us +teaches-yoga.com +thruhere.net +traeumtgerade.de +webhop.biz +webhop.info +webhop.net +webhop.org +worse-than.tv +writesthisblog.com +ddnss.de +dyn.ddnss.de +dyndns.ddnss.de +dyndns1.de +dyn-ip24.de +home-webserver.de +dyn.home-webserver.de +myhome-server.de +ddnss.org +definima.net +definima.io +bci.dnstrace.pro +ddnsfree.com +ddnsgeek.com +giize.com +gleeze.com +kozow.com +loseyourip.com +ooguy.com +theworkpc.com +casacam.net +dynu.net +accesscam.org +camdvr.org +freeddns.org +mywire.org +webredirect.org +myddns.rocks +blogsite.xyz +dynv6.net +e4.cz +mytuleap.com +enonic.io +customer.enonic.io +eu.org +al.eu.org +asso.eu.org +at.eu.org +au.eu.org +be.eu.org +bg.eu.org +ca.eu.org +cd.eu.org +ch.eu.org +cn.eu.org +cy.eu.org +cz.eu.org +de.eu.org +dk.eu.org +edu.eu.org +ee.eu.org +es.eu.org +fi.eu.org +fr.eu.org +gr.eu.org +hr.eu.org +hu.eu.org +ie.eu.org +il.eu.org +in.eu.org +int.eu.org +is.eu.org +it.eu.org +jp.eu.org +kr.eu.org +lt.eu.org +lu.eu.org +lv.eu.org +mc.eu.org +me.eu.org +mk.eu.org +mt.eu.org +my.eu.org +net.eu.org +ng.eu.org +nl.eu.org +no.eu.org +nz.eu.org +paris.eu.org +pl.eu.org +pt.eu.org +q-a.eu.org +ro.eu.org +ru.eu.org +se.eu.org +si.eu.org +sk.eu.org +tr.eu.org +uk.eu.org +us.eu.org +eu-1.evennode.com +eu-2.evennode.com +eu-3.evennode.com +eu-4.evennode.com +us-1.evennode.com +us-2.evennode.com +us-3.evennode.com +us-4.evennode.com +twmail.cc +twmail.net +twmail.org +mymailer.com.tw +url.tw +apps.fbsbx.com +ru.net +adygeya.ru +bashkiria.ru +bir.ru +cbg.ru +com.ru +dagestan.ru +grozny.ru +kalmykia.ru +kustanai.ru +marine.ru +mordovia.ru +msk.ru +mytis.ru +nalchik.ru +nov.ru +pyatigorsk.ru +spb.ru +vladikavkaz.ru +vladimir.ru +abkhazia.su +adygeya.su +aktyubinsk.su +arkhangelsk.su +armenia.su +ashgabad.su +azerbaijan.su +balashov.su +bashkiria.su +bryansk.su +bukhara.su +chimkent.su +dagestan.su +east-kazakhstan.su +exnet.su +georgia.su +grozny.su +ivanovo.su +jambyl.su +kalmykia.su +kaluga.su +karacol.su +karaganda.su +karelia.su +khakassia.su +krasnodar.su +kurgan.su +kustanai.su +lenug.su +mangyshlak.su +mordovia.su +msk.su +murmansk.su +nalchik.su +navoi.su +north-kazakhstan.su +nov.su +obninsk.su +penza.su +pokrovsk.su +sochi.su +spb.su +tashkent.su +termez.su +togliatti.su +troitsk.su +tselinograd.su +tula.su +tuva.su +vladikavkaz.su +vladimir.su +vologda.su +channelsdvr.net +fastly-terrarium.com +fastlylb.net +map.fastlylb.net +freetls.fastly.net +map.fastly.net +a.prod.fastly.net +global.prod.fastly.net +a.ssl.fastly.net +b.ssl.fastly.net +global.ssl.fastly.net +fastpanel.direct +fastvps-server.com +fhapp.xyz +fedorainfracloud.org +fedorapeople.org +cloud.fedoraproject.org +app.os.fedoraproject.org +app.os.stg.fedoraproject.org +mydobiss.com +filegear.me +filegear-au.me +filegear-de.me +filegear-gb.me +filegear-ie.me +filegear-jp.me +filegear-sg.me +firebaseapp.com +flynnhub.com +flynnhosting.net +freebox-os.com +freeboxos.com +fbx-os.fr +fbxos.fr +freebox-os.fr +freeboxos.fr +freedesktop.org +feifuturehosting.at +futuremailing.at +eksservice.gov.uk +github.io +githubusercontent.com +gitlab.io +cloudapps.digital +london.cloudapps.digital +homeoffice.gov.uk +ro.im +shop.ro +goip.de +run.app +a.run.app +0appspot.com +blogspot.ae +blogspot.al +blogspot.am +blogspot.ba +blogspot.be +blogspot.bg +blogspot.bj +blogspot.ca +blogspot.cf +blogspot.ch +blogspot.cl +blogspot.co.at +blogspot.co.id +blogspot.co.il +blogspot.co.ke +blogspot.co.nz +blogspot.co.uk +blogspot.co.za +blogspot.com +blogspot.com.ar +blogspot.com.au +blogspot.com.br +blogspot.com.by +blogspot.com.co +blogspot.com.cy +blogspot.com.ee +blogspot.com.eg +blogspot.com.es +blogspot.com.mt +blogspot.com.ng +blogspot.com.tr +blogspot.com.uy +blogspot.cv +blogspot.cz +blogspot.de +blogspot.dk +blogspot.fi +blogspot.fr +blogspot.gr +blogspot.hk +blogspot.hr +blogspot.hu +blogspot.ie +blogspot.in +blogspot.is +blogspot.it +blogspot.jp +blogspot.kr +blogspot.li +blogspot.lt +blogspot.lu +blogspot.md +blogspot.mk +blogspot.mr +blogspot.mx +blogspot.my +blogspot.nl +blogspot.no +blogspot.pe +blogspot.pt +blogspot.qa +blogspot.re +blogspot.ro +blogspot.rs +blogspot.ru +blogspot.se +blogspot.sg +blogspot.si +blogspot.sk +blogspot.sn +blogspot.td +blogspot.tw +blogspot.ug +blogspot.vn +cloudfunctions.net +cloud.goog +codespot.com +googleapis.com +googlecode.com +pagespeedmobilizer.com +publishproxy.com +withgoogle.com +withyoutube.com +hashbang.sh +hasura.app +hasura-app.io +hepforge.org +herokuapp.com +herokussl.com +myravendb.com +ravendb.community +ravendb.me +development.run +ravendb.run +moonscale.net +iki.fi +dyn-berlin.de +in-berlin.de +in-brb.de +in-butter.de +in-dsl.de +in-dsl.net +in-dsl.org +in-vpn.de +in-vpn.net +in-vpn.org +biz.at +info.at +info.cx +ac.leg.br +al.leg.br +am.leg.br +ap.leg.br +ba.leg.br +ce.leg.br +df.leg.br +es.leg.br +go.leg.br +ma.leg.br +mg.leg.br +ms.leg.br +mt.leg.br +pa.leg.br +pb.leg.br +pe.leg.br +pi.leg.br +pr.leg.br +rj.leg.br +rn.leg.br +ro.leg.br +rr.leg.br +rs.leg.br +sc.leg.br +se.leg.br +sp.leg.br +to.leg.br +pixolino.com +ipifony.net +mein-iserv.de +test-iserv.de +myjino.ru +hlsvtcjs.org +keymachine.de +knightpoint.systems +co.krd +edu.krd +git-repos.de +lcube-server.de +svn-repos.de +leadpages.co +lpages.co +lpusercontent.com +co.business +co.education +co.events +co.financial +co.network +co.place +co.technology +app.lmpm.com +linkitools.space +linkyard.cloud +linkyard-cloud.ch +we.bs +krasnik.pl +leczna.pl +lubartow.pl +lublin.pl +poniatowa.pl +swidnik.pl +uklugs.org +glug.org.uk +lug.org.uk +lugs.org.uk +barsy.bg +barsy.co.uk +barsyonline.co.uk +barsycenter.com +barsyonline.com +barsy.club +barsy.de +barsy.eu +barsy.in +barsy.info +barsy.io +barsy.me +barsy.menu +barsy.mobi +barsy.net +barsy.online +barsy.org +barsy.pro +barsy.pub +barsy.shop +barsy.site +barsy.support +barsy.uk +mmayfirst.info +mayfirst.org +hb.cldmail.ru +miniserver.com +memset.net +cloud.metacentrum.cz +custom.metacentrum.cz +flt.cloud.muni.cz +usr.cloud.muni.cz +meteorapp.com +eu.meteorapp.com +co.pl +azurecontainer.io +azurewebsites.net +azure-mobile.net +cloudapp.net +mozilla-iot.org +bmoattachments.org +net.ru +org.ru +pp.ru +ui.nabu.casa +bitballoon.com +netlify.com +4u.com +ngrok.io +nh-serv.co.uk +nfshost.com +dnsking.ch +mypi.co +n4t.co +001www.com +ddnslive.com +myiphost.com +forumz.info +16-b.it +32-b.it +64-b.it +soundcast.me +tcp4.me +dnsup.net +hicam.net +now-dns.net +ownip.net +vpndns.net +dynserv.org +now-dns.org +x443.pw +now-dns.top +ntdll.top +freeddns.us +crafting.xyz +zapto.xyz +nsupdate.info +nerdpol.ovh +blogsyte.com +brasilia.me +cable-modem.org +ciscofreak.com +collegefan.org +couchpotatofries.org +damnserver.com +ddns.me +ditchyourip.com +dnsfor.me +dnsiskinky.com +dvrcam.info +dynns.com +eating-organic.net +fantasyleague.cc +geekgalaxy.com +golffan.us +health-carereform.com +homesecuritymac.com +homesecuritypc.com +hopto.me +ilovecollege.info +loginto.me +mlbfan.org +mmafan.biz +myactivedirectory.com +mydissent.net +myeffect.net +mymediapc.net +mypsx.net +mysecuritycamera.com +mysecuritycamera.net +mysecuritycamera.org +net-freaks.com +nflfan.org +nhlfan.net +no-ip.ca +no-ip.co.uk +no-ip.net +noip.us +onthewifi.com +pgafan.net +point2this.com +pointto.us +privatizehealthinsurance.net +quicksytes.com +read-books.org +securitytactics.com +serveexchange.com +servehumour.com +servep2p.com +servesarcasm.com +stufftoread.com +ufcfan.org +unusualperson.com +workisboring.com +3utilities.com +bounceme.net +ddns.net +ddnsking.com +gotdns.ch +hopto.org +myftp.biz +myftp.org +myvnc.com +no-ip.biz +no-ip.info +no-ip.org +noip.me +redirectme.net +servebeer.com +serveblog.net +servecounterstrike.com +serveftp.com +servegame.com +servehalflife.com +servehttp.com +serveirc.com +serveminecraft.net +servemp3.com +servepics.com +servequake.com +sytes.net +webhop.me +zapto.org +stage.nodeart.io +nodum.co +nodum.io +pcloud.host +nyc.mn +nom.ae +nom.af +nom.ai +nom.al +nym.by +nym.bz +nom.cl +nom.gd +nom.ge +nom.gl +nym.gr +nom.gt +nym.gy +nom.hn +nym.ie +nom.im +nom.ke +nym.kz +nym.la +nym.lc +nom.li +nym.li +nym.lt +nym.lu +nym.me +nom.mk +nym.mn +nym.mx +nom.nu +nym.nz +nym.pe +nym.pt +nom.pw +nom.qa +nym.ro +nom.rs +nom.si +nym.sk +nom.st +nym.su +nym.sx +nom.tj +nym.tw +nom.ug +nom.uy +nom.vc +nom.vg +cya.gg +cloudycluster.net +nid.io +opencraft.hosting +operaunite.com +outsystemscloud.com +ownprovider.com +own.pm +ox.rs +oy.lc +pgfog.com +pagefrontapp.com +art.pl +gliwice.pl +krakow.pl +poznan.pl +wroc.pl +zakopane.pl +pantheonsite.io +gotpantheon.com +mypep.link +on-web.fr +ppxen.prgmr.com +priv.at +protonet.io +chirurgiens-dentistes-en-france.fr +byen.site +instantcloud.cn +ras.ru +qa2.com +dev-myqnapcloud.com +alpha-myqnapcloud.com +myqnapcloud.com +qvapor.cloud +vaporcloud.io +rackmaze.com +rackmaze.net +ooreadthedocs.io +rhcloud.com +resindevice.io +devices.resinstaging.io +hzc.io +wellbeingzone.eu +ptplus.fit +wellbeingzone.co.uk +git-pages.rit.edu +sandcats.io +logoip.de +logoip.com +schokokeks.net +scrysec.com +firewall-gateway.com +firewall-gateway.de +my-gateway.de +my-router.de +spdns.de +spdns.eu +firewall-gateway.net +my-firewall.org +myfirewall.org +spdns.org +ssbiz.ua +co.ua +pp.ua +shiftedit.io +myshopblocks.com +1kapp.com +appchizi.com +applinzi.com +sinaapp.com +vipsinaapp.com +siteleaf.net +bounty-full.com +alpha.bounty-full.com +beta.bounty-full.com +static.land +dev.static.land +sites.static.land +apps.lair.io +sspacekit.io +customer.speedpartner.de +api.stdlib.com +storj.farm +utwente.io +temp-dns.com +applicationcloud.io +scapp.io +syncloud.it +diskstation.me +dscloud.biz +dscloud.me +dscloud.mobi +dsmynas.com +dsmynas.net +dsmynas.org +familyds.com +familyds.net +familyds.org +i234.me +myds.me +synology.me +vpnplus.to +taifun-dns.de +gda.pl +gdansk.pl +gdynia.pl +med.pl +sopot.pl +telebit.app +telebit.io +tgwiddle.co.uk +cust.dev.thingdust.io +cust.disrec.thingdust.io +cust.prod.thingdust.io +cust.testing.thingdust.io +bloxcms.com +townnews-staging.com +12hp.at +2ix.at +4lima.at +lima-city.at +12hp.ch +2ix.ch +4lima.ch +lima-city.ch +trafficplex.cloud +de.cool +12hp.de +2ix.de +4lima.de +lima-city.de +1337.pictures +clan.rip +lima-city.rocks +webspace.rocks +lima.zone +ttttuxfamily.org +dd-dns.de +diskstation.eu +diskstation.org +dray-dns.de +draydns.de +dyn-vpn.de +dynvpn.de +mein-vigor.de +my-vigor.de +my-wan.de +syno-ds.de +synology-diskstation.de +synology-ds.de +uber.space +uhk.com +hk.org +ltd.hk +inc.hk +virtualuser.de +virtual-user.de +lib.de.us +2038.io +router.management +v-info.info +wedeploy.io +wedeploy.me +wedeploy.sh +remotewd.com +wmflabs.org +half.host +xnbay.com +u2.xnbay.com +u2-local.xnbay.com +cistron.nl +demon.nl +xs4all.space +official.academy +yolasite.com +ybo.faith +yombo.me +homelink.one +ybo.party +ybo.review +ybo.science +ybo.trade +nohost.me +noho.st +za.net +za.org +now.sh +bss.design +site.builder.nu +zone.id +%% diff --git a/dbms/src/Functions/tldLookup.h b/dbms/src/Functions/tldLookup.h new file mode 100644 index 00000000000..76a87e6b8c7 --- /dev/null +++ b/dbms/src/Functions/tldLookup.h @@ -0,0 +1,16 @@ +#pragma once + + +// Definition of the class generated by gperf, present on gperf/tldLookup.gperf +class tldLookupHash +{ +private: + static inline unsigned int hash (const char *str, size_t len); +public: + static const char *is_valid (const char *str, size_t len); +}; + +namespace DB +{ + using tldLookup = tldLookupHash; +} diff --git a/docs/en/development/build.md b/docs/en/development/build.md index 82d8070780b..9a0b160d705 100644 --- a/docs/en/development/build.md +++ b/docs/en/development/build.md @@ -70,6 +70,11 @@ export CXX=g++-7 sudo apt-get install libicu-dev libreadline-dev ``` +## Install Additional dependencies +```bash +sudo apt-get install gperf +``` + ## Checkout ClickHouse Sources ```bash diff --git a/docs/en/development/build_osx.md b/docs/en/development/build_osx.md index 35e8158d8b2..928f8f88dfd 100644 --- a/docs/en/development/build_osx.md +++ b/docs/en/development/build_osx.md @@ -11,7 +11,7 @@ Build should work on Mac OS X 10.12. ## Install Required Compilers, Tools, and Libraries ```bash -brew install cmake ninja gcc icu4c openssl libtool gettext readline +brew install cmake ninja gcc icu4c openssl libtool gettext readline gperf ``` ## Checkout ClickHouse Sources From 1eccfacca5a1f740d1af5a09d38e83e1d571a5a4 Mon Sep 17 00:00:00 2001 From: Guillaume Tassery Date: Wed, 17 Apr 2019 19:27:15 +0700 Subject: [PATCH 049/709] Take into account when we have content after the dns on (cutTo)firstSignificantSubdomain function --- dbms/src/Functions/firstSignificantSubdomain.h | 8 +++++++- dbms/src/Functions/gperf/tldLookup.gperf | 3 +++ .../00381_first_significant_subdomain.reference | 2 +- .../0_stateless/00381_first_significant_subdomain.sql | 2 -- 4 files changed, 11 insertions(+), 4 deletions(-) diff --git a/dbms/src/Functions/firstSignificantSubdomain.h b/dbms/src/Functions/firstSignificantSubdomain.h index 864b4d8bd8f..7ba6ea36905 100644 --- a/dbms/src/Functions/firstSignificantSubdomain.h +++ b/dbms/src/Functions/firstSignificantSubdomain.h @@ -58,7 +58,13 @@ struct ExtractFirstSignificantSubdomain if (!last_3_periods[2]) last_3_periods[2] = begin - 1; - if (tldLookup::is_valid(last_3_periods[1] + 1, end - last_3_periods[1] - 1) != nullptr) + auto end_of_level_domain = find_first_symbols<'/'>(last_3_periods[0], end); + if (!end_of_level_domain) + { + end_of_level_domain = end; + } + + if (tldLookup::is_valid(last_3_periods[1] + 1, end_of_level_domain - last_3_periods[1] - 1) != nullptr) { res_data += last_3_periods[2] + 1 - begin; res_size = last_3_periods[1] - last_3_periods[2] - 1; diff --git a/dbms/src/Functions/gperf/tldLookup.gperf b/dbms/src/Functions/gperf/tldLookup.gperf index e849bbb1545..b88acdfea77 100644 --- a/dbms/src/Functions/gperf/tldLookup.gperf +++ b/dbms/src/Functions/gperf/tldLookup.gperf @@ -3,6 +3,9 @@ %define class-name tldLookupHash %readonly-tables %includes +%compare-strncmp + +# List generated using https://publicsuffix.org/list/public_suffix_list.dat %% ac com.ac diff --git a/dbms/tests/queries/0_stateless/00381_first_significant_subdomain.reference b/dbms/tests/queries/0_stateless/00381_first_significant_subdomain.reference index 7f8c9ba186c..f13e9ddb1bd 100644 --- a/dbms/tests/queries/0_stateless/00381_first_significant_subdomain.reference +++ b/dbms/tests/queries/0_stateless/00381_first_significant_subdomain.reference @@ -1,3 +1,3 @@ canada congo net-domena -yandex yandex yandex yandex яндекс яндекс yandex +yandex yandex yandex яндекс yandex canada hello hello hello hello hello canada canada diff --git a/dbms/tests/queries/0_stateless/00381_first_significant_subdomain.sql b/dbms/tests/queries/0_stateless/00381_first_significant_subdomain.sql index b5154e2d725..5badd14f200 100644 --- a/dbms/tests/queries/0_stateless/00381_first_significant_subdomain.sql +++ b/dbms/tests/queries/0_stateless/00381_first_significant_subdomain.sql @@ -8,8 +8,6 @@ SELECT firstSignificantSubdomain('https://www.yandex.ua/news.html'), firstSignificantSubdomain('magnet:yandex.abc'), firstSignificantSubdomain('ftp://www.yandex.co.uk/news.html'), - firstSignificantSubdomain('ftp://yandex.co.yandex'), - firstSignificantSubdomain('http://ввв.яндекс.org.рф'), firstSignificantSubdomain('https://api.www3.static.dev.ввв.яндекс.рф'), firstSignificantSubdomain('//www.yandex.com.tr/news.html'); From 65fc607c1840b204b08b94904a4021398102a2c9 Mon Sep 17 00:00:00 2001 From: Guillaume Tassery Date: Wed, 17 Apr 2019 19:40:11 +0700 Subject: [PATCH 050/709] Modify tldlookup.gperf file for include only second level domain --- dbms/src/Functions/gperf/tldLookup.gperf | 3813 +--------------------- 1 file changed, 30 insertions(+), 3783 deletions(-) diff --git a/dbms/src/Functions/gperf/tldLookup.gperf b/dbms/src/Functions/gperf/tldLookup.gperf index b88acdfea77..0c6dd47f221 100644 --- a/dbms/src/Functions/gperf/tldLookup.gperf +++ b/dbms/src/Functions/gperf/tldLookup.gperf @@ -7,16 +7,14 @@ # List generated using https://publicsuffix.org/list/public_suffix_list.dat %% -ac + com.ac edu.ac gov.ac net.ac mil.ac org.ac -ad nom.ad -ae co.ae net.ae org.ae @@ -24,7 +22,6 @@ sch.ae ac.ae gov.ae mil.ae -aero accident-investigation.aero accident-prevention.aero aerobatic.aero @@ -112,45 +109,37 @@ trainer.aero union.aero workinggroup.aero works.aero -af gov.af com.af org.af net.af edu.af -ag com.ag org.ag net.ag co.ag nom.ag -ai off.ai com.ai net.ai org.ai -al com.al edu.al gov.al mil.al net.al org.al -am co.am com.am commune.am net.am org.am -ao ed.ao gv.ao og.ao co.ao pb.ao it.ao -aq -ar com.ar edu.ar gob.ar @@ -161,22 +150,17 @@ musica.ar net.ar org.ar tur.ar -arpa e164.arpa in-addr.arpa ip6.arpa iris.arpa uri.arpa urn.arpa -as gov.as -asia -at ac.at co.at gv.at or.at -au com.au net.au org.au @@ -195,23 +179,7 @@ sa.au tas.au vic.au wa.au -act.edu.au -nsw.edu.au -nt.edu.au -qld.edu.au -sa.edu.au -tas.edu.au -vic.edu.au -wa.edu.au -qld.gov.au -sa.gov.au -tas.gov.au -vic.gov.au -wa.gov.au -aw com.aw -ax -az com.az net.az int.az @@ -224,14 +192,12 @@ mil.az name.az pro.az biz.az -ba com.ba edu.ba gov.ba mil.ba net.ba org.ba -bb biz.bb co.bb com.bb @@ -242,11 +208,9 @@ net.bb org.bb store.bb tv.bb -bbe +*.bd ac.be -bf gov.bf -bg a.bg b.bg c.bg @@ -283,36 +247,29 @@ z.bg 7.bg 8.bg 9.bg -bh com.bh edu.bh net.bh org.bh gov.bh -bi co.bi com.bi edu.bi or.bi org.bi -biz -bj asso.bj barreau.bj gouv.bj -bm com.bm edu.bm gov.bm net.bm org.bm -bn com.bn edu.bn gov.bn net.bn org.bn -bo com.bo edu.bo gob.bo @@ -354,7 +311,6 @@ tecnologia.bo tksat.bo transporte.bo wiki.bo -br 9guacu.br abc.br adm.br @@ -411,33 +367,6 @@ g12.br ggf.br goiania.br gov.br -ac.gov.br -al.gov.br -am.gov.br -ap.gov.br -ba.gov.br -ce.gov.br -df.gov.br -es.gov.br -go.gov.br -ma.gov.br -mg.gov.br -ms.gov.br -mt.gov.br -pa.gov.br -pb.gov.br -pe.gov.br -pi.gov.br -pr.gov.br -rj.gov.br -rn.gov.br -ro.gov.br -rr.gov.br -rs.gov.br -sc.gov.br -se.gov.br -sp.gov.br -to.gov.br gru.br imb.br ind.br @@ -464,7 +393,7 @@ mus.br natal.br net.br niteroi.br -nnot.br +not.br ntr.br odo.br ong.br @@ -509,34 +438,27 @@ vix.br vlog.br wiki.br zlg.br -bs com.bs net.bs org.bs edu.bs gov.bs -bt com.bt edu.bt gov.bt net.bt org.bt -bv -bw co.bw org.bw -by gov.by mil.by com.by of.by -bz com.bz net.bz org.bz edu.bz gov.bz -ca ab.ca bc.ca mb.ca @@ -552,14 +474,7 @@ qc.ca sk.ca yk.ca gc.ca -cat -cc -cd gov.cd -cf -cg -ch -ci org.ci or.ci com.ci @@ -575,18 +490,16 @@ int.ci presse.ci md.ci gouv.ci -c!www.ck -cl +*.ck +!www.ck gov.cl gob.cl co.cl mil.cl -cm co.cm com.cm gov.cm net.cm -cn ac.cn com.cn edu.cn @@ -631,7 +544,6 @@ zj.cn hk.cn mo.cn tw.cn -co arts.co com.co edu.co @@ -645,9 +557,6 @@ nom.co org.co rec.co web.co -com -coop -cr ac.cr co.cr ed.cr @@ -655,22 +564,17 @@ fi.cr go.cr or.cr sa.cr -cu com.cu edu.cu org.cu net.cu gov.cu inf.cu -cv -cw com.cw edu.cw net.cw org.cw -cx gov.cx -cy ac.cy biz.cy com.cy @@ -684,17 +588,11 @@ parliament.cy press.cy pro.cy tm.cy -cz -de -dj -dk -dm com.dm net.dm org.dm edu.dm gov.dm -do art.do com.do edu.do @@ -705,7 +603,6 @@ net.do org.do sld.do web.do -dz com.dz org.dz net.dz @@ -714,7 +611,6 @@ edu.dz asso.dz pol.dz art.dz -ec com.ec info.ec net.ec @@ -727,8 +623,6 @@ edu.ec gov.ec gob.ec mil.ec -edu -ee edu.ee gov.ee riik.ee @@ -739,7 +633,6 @@ pri.ee aip.ee org.ee fie.ee -eg com.eg edu.eg eun.eg @@ -749,13 +642,12 @@ name.eg net.eg org.eg sci.eg -ees +*.er com.es nom.es org.es gob.es edu.es -et com.et gov.et org.et @@ -764,12 +656,9 @@ biz.et name.et info.et net.et -eu -fi aland.fi -fffm -fo -fr +*.fj +*.fk asso.fr com.fr gouv.fr @@ -791,10 +680,6 @@ notaires.fr pharmacien.fr port.fr veterinaire.fr -ga -gb -gd -ge com.ge edu.ge gov.ge @@ -802,55 +687,42 @@ org.ge mil.ge net.ge pvt.ge -gf -gg co.gg net.gg org.gg -gh com.gh edu.gh gov.gh org.gh mil.gh -gi com.gi ltd.gi gov.gi mod.gi edu.gi org.gi -gl co.gl com.gl edu.gl net.gl org.gl -gm -gn ac.gn com.gn edu.gn gov.gn org.gn net.gn -gov -gp com.gp net.gp mobi.gp edu.gp org.gp asso.gp -gq -gr com.gr edu.gr net.gr org.gr gov.gr -gs -gt com.gt edu.gt gob.gt @@ -858,7 +730,6 @@ ind.gt mil.gt net.gt org.gt -gu com.gu edu.gu gov.gu @@ -867,15 +738,12 @@ info.gu net.gu org.gu web.gu -gw -gy co.gy com.gy edu.gy gov.gy net.gy org.gy -hk com.hk edu.hk gov.hk @@ -897,20 +765,16 @@ org.hk 组织.hk 組織.hk 組织.hk -hm -hn com.hn edu.hn org.hn net.hn mil.hn gob.hn -hr iz.hr from.hr name.hr com.hr -ht com.ht shop.ht firm.ht @@ -928,7 +792,6 @@ edu.ht rel.ht gouv.ht perso.ht -hu co.hu info.hu org.hu @@ -960,7 +823,6 @@ szex.hu tozsde.hu utazas.hu video.hu -id ac.id biz.id co.id @@ -973,9 +835,7 @@ or.id ponpes.id sch.id web.id -ie gov.ie -il ac.il co.il gov.il @@ -984,17 +844,13 @@ k12.il muni.il net.il org.il -im ac.im co.im com.im -ltd.co.im net.im org.im -plc.co.im tt.im tv.im -in co.in firm.in net.in @@ -1007,19 +863,14 @@ edu.in res.in gov.in mil.in -info -int eu.int -io com.io -iq gov.iq edu.iq mil.iq com.iq org.iq net.iq -ir ac.ir co.ir gov.ir @@ -1029,14 +880,12 @@ org.ir sch.ir ایران.ir ايران.ir -is net.is com.is edu.is gov.is org.is int.is -it gov.it edu.it abr.it @@ -1443,11 +1292,10 @@ vr.it vs.it vt.it vv.it -je co.je net.je org.je -jjo +*.jm com.jo org.jo net.jo @@ -1456,8 +1304,6 @@ sch.jo gov.jo mil.jo name.jo -jobs -jp ac.jp ad.jp co.jp @@ -1561,1687 +1407,6 @@ yamanashi.jp 高知.jp 鳥取.jp 鹿児島.jp -kkknssy!city.kawasaki.jp -!city.kitakyushu.jp -!city.kobe.jp -!city.nagoya.jp -!city.sapporo.jp -!city.sendai.jp -!city.yokohama.jp -aisai.aichi.jp -ama.aichi.jp -anjo.aichi.jp -asuke.aichi.jp -chiryu.aichi.jp -chita.aichi.jp -fuso.aichi.jp -gamagori.aichi.jp -handa.aichi.jp -hazu.aichi.jp -hekinan.aichi.jp -higashiura.aichi.jp -ichinomiya.aichi.jp -inazawa.aichi.jp -inuyama.aichi.jp -isshiki.aichi.jp -iwakura.aichi.jp -kanie.aichi.jp -kariya.aichi.jp -kasugai.aichi.jp -kira.aichi.jp -kiyosu.aichi.jp -komaki.aichi.jp -konan.aichi.jp -kota.aichi.jp -mihama.aichi.jp -miyoshi.aichi.jp -nishio.aichi.jp -nisshin.aichi.jp -obu.aichi.jp -oguchi.aichi.jp -oharu.aichi.jp -okazaki.aichi.jp -owariasahi.aichi.jp -seto.aichi.jp -shikatsu.aichi.jp -shinshiro.aichi.jp -shitara.aichi.jp -tahara.aichi.jp -takahama.aichi.jp -tobishima.aichi.jp -toei.aichi.jp -togo.aichi.jp -tokai.aichi.jp -tokoname.aichi.jp -toyoake.aichi.jp -toyohashi.aichi.jp -toyokawa.aichi.jp -toyone.aichi.jp -toyota.aichi.jp -tsushima.aichi.jp -yatomi.aichi.jp -akita.akita.jp -daisen.akita.jp -fujisato.akita.jp -gojome.akita.jp -hachirogata.akita.jp -happou.akita.jp -higashinaruse.akita.jp -honjo.akita.jp -honjyo.akita.jp -ikawa.akita.jp -kamikoani.akita.jp -kamioka.akita.jp -katagami.akita.jp -kazuno.akita.jp -kitaakita.akita.jp -kosaka.akita.jp -kyowa.akita.jp -misato.akita.jp -mitane.akita.jp -moriyoshi.akita.jp -nikaho.akita.jp -noshiro.akita.jp -odate.akita.jp -oga.akita.jp -ogata.akita.jp -semboku.akita.jp -yokote.akita.jp -yurihonjo.akita.jp -aomori.aomori.jp -gonohe.aomori.jp -hachinohe.aomori.jp -hashikami.aomori.jp -hiranai.aomori.jp -hirosaki.aomori.jp -itayanagi.aomori.jp -kuroishi.aomori.jp -misawa.aomori.jp -mutsu.aomori.jp -nakadomari.aomori.jp -noheji.aomori.jp -oirase.aomori.jp -owani.aomori.jp -rokunohe.aomori.jp -sannohe.aomori.jp -shichinohe.aomori.jp -shingo.aomori.jp -takko.aomori.jp -towada.aomori.jp -tsugaru.aomori.jp -tsuruta.aomori.jp -abiko.chiba.jp -asahi.chiba.jp -chonan.chiba.jp -chosei.chiba.jp -choshi.chiba.jp -chuo.chiba.jp -funabashi.chiba.jp -futtsu.chiba.jp -hanamigawa.chiba.jp -ichihara.chiba.jp -ichikawa.chiba.jp -ichinomiya.chiba.jp -inzai.chiba.jp -isumi.chiba.jp -kamagaya.chiba.jp -kamogawa.chiba.jp -kashiwa.chiba.jp -katori.chiba.jp -katsuura.chiba.jp -kimitsu.chiba.jp -kisarazu.chiba.jp -kozaki.chiba.jp -kujukuri.chiba.jp -kyonan.chiba.jp -matsudo.chiba.jp -midori.chiba.jp -mihama.chiba.jp -minamiboso.chiba.jp -mobara.chiba.jp -mutsuzawa.chiba.jp -nagara.chiba.jp -nagareyama.chiba.jp -narashino.chiba.jp -narita.chiba.jp -noda.chiba.jp -oamishirasato.chiba.jp -omigawa.chiba.jp -onjuku.chiba.jp -otaki.chiba.jp -sakae.chiba.jp -sakura.chiba.jp -shimofusa.chiba.jp -shirako.chiba.jp -shiroi.chiba.jp -shisui.chiba.jp -sodegaura.chiba.jp -sosa.chiba.jp -tako.chiba.jp -tateyama.chiba.jp -togane.chiba.jp -tohnosho.chiba.jp -tomisato.chiba.jp -urayasu.chiba.jp -yachimata.chiba.jp -yachiyo.chiba.jp -yokaichiba.chiba.jp -yokoshibahikari.chiba.jp -yotsukaido.chiba.jp -ainan.ehime.jp -honai.ehime.jp -ikata.ehime.jp -imabari.ehime.jp -iyo.ehime.jp -kamijima.ehime.jp -kihoku.ehime.jp -kumakogen.ehime.jp -masaki.ehime.jp -matsuno.ehime.jp -matsuyama.ehime.jp -namikata.ehime.jp -niihama.ehime.jp -ozu.ehime.jp -saijo.ehime.jp -seiyo.ehime.jp -shikokuchuo.ehime.jp -tobe.ehime.jp -toon.ehime.jp -uchiko.ehime.jp -uwajima.ehime.jp -yawatahama.ehime.jp -echizen.fukui.jp -eiheiji.fukui.jp -fukui.fukui.jp -ikeda.fukui.jp -katsuyama.fukui.jp -mihama.fukui.jp -minamiechizen.fukui.jp -obama.fukui.jp -ohi.fukui.jp -ono.fukui.jp -sabae.fukui.jp -sakai.fukui.jp -takahama.fukui.jp -tsuruga.fukui.jp -wakasa.fukui.jp -ashiya.fukuoka.jp -buzen.fukuoka.jp -chikugo.fukuoka.jp -chikuho.fukuoka.jp -chikujo.fukuoka.jp -chikushino.fukuoka.jp -chikuzen.fukuoka.jp -chuo.fukuoka.jp -dazaifu.fukuoka.jp -fukuchi.fukuoka.jp -hakata.fukuoka.jp -higashi.fukuoka.jp -hirokawa.fukuoka.jp -hisayama.fukuoka.jp -iizuka.fukuoka.jp -inatsuki.fukuoka.jp -kaho.fukuoka.jp -kasuga.fukuoka.jp -kasuya.fukuoka.jp -kawara.fukuoka.jp -keisen.fukuoka.jp -koga.fukuoka.jp -kurate.fukuoka.jp -kurogi.fukuoka.jp -kurume.fukuoka.jp -minami.fukuoka.jp -miyako.fukuoka.jp -miyama.fukuoka.jp -miyawaka.fukuoka.jp -mizumaki.fukuoka.jp -munakata.fukuoka.jp -nakagawa.fukuoka.jp -nakama.fukuoka.jp -nishi.fukuoka.jp -nogata.fukuoka.jp -ogori.fukuoka.jp -okagaki.fukuoka.jp -okawa.fukuoka.jp -oki.fukuoka.jp -omuta.fukuoka.jp -onga.fukuoka.jp -onojo.fukuoka.jp -oto.fukuoka.jp -saigawa.fukuoka.jp -sasaguri.fukuoka.jp -shingu.fukuoka.jp -shinyoshitomi.fukuoka.jp -shonai.fukuoka.jp -soeda.fukuoka.jp -sue.fukuoka.jp -tachiarai.fukuoka.jp -tagawa.fukuoka.jp -takata.fukuoka.jp -toho.fukuoka.jp -toyotsu.fukuoka.jp -tsuiki.fukuoka.jp -ukiha.fukuoka.jp -umi.fukuoka.jp -usui.fukuoka.jp -yamada.fukuoka.jp -yame.fukuoka.jp -yanagawa.fukuoka.jp -yukuhashi.fukuoka.jp -aizubange.fukushima.jp -aizumisato.fukushima.jp -aizuwakamatsu.fukushima.jp -asakawa.fukushima.jp -bandai.fukushima.jp -date.fukushima.jp -fukushima.fukushima.jp -furudono.fukushima.jp -futaba.fukushima.jp -hanawa.fukushima.jp -higashi.fukushima.jp -hirata.fukushima.jp -hirono.fukushima.jp -iitate.fukushima.jp -inawashiro.fukushima.jp -ishikawa.fukushima.jp -iwaki.fukushima.jp -izumizaki.fukushima.jp -kagamiishi.fukushima.jp -kaneyama.fukushima.jp -kawamata.fukushima.jp -kitakata.fukushima.jp -kitashiobara.fukushima.jp -koori.fukushima.jp -koriyama.fukushima.jp -kunimi.fukushima.jp -miharu.fukushima.jp -mishima.fukushima.jp -namie.fukushima.jp -nango.fukushima.jp -nishiaizu.fukushima.jp -nishigo.fukushima.jp -okuma.fukushima.jp -omotego.fukushima.jp -ono.fukushima.jp -otama.fukushima.jp -samegawa.fukushima.jp -shimogo.fukushima.jp -shirakawa.fukushima.jp -showa.fukushima.jp -soma.fukushima.jp -sukagawa.fukushima.jp -taishin.fukushima.jp -tamakawa.fukushima.jp -tanagura.fukushima.jp -tenei.fukushima.jp -yabuki.fukushima.jp -yamato.fukushima.jp -yamatsuri.fukushima.jp -yanaizu.fukushima.jp -yugawa.fukushima.jp -anpachi.gifu.jp -ena.gifu.jp -gifu.gifu.jp -ginan.gifu.jp -godo.gifu.jp -gujo.gifu.jp -hashima.gifu.jp -hichiso.gifu.jp -hida.gifu.jp -higashishirakawa.gifu.jp -ibigawa.gifu.jp -ikeda.gifu.jp -kakamigahara.gifu.jp -kani.gifu.jp -kasahara.gifu.jp -kasamatsu.gifu.jp -kawaue.gifu.jp -kitagata.gifu.jp -mino.gifu.jp -minokamo.gifu.jp -mitake.gifu.jp -mizunami.gifu.jp -motosu.gifu.jp -nakatsugawa.gifu.jp -ogaki.gifu.jp -sakahogi.gifu.jp -seki.gifu.jp -sekigahara.gifu.jp -shirakawa.gifu.jp -tajimi.gifu.jp -takayama.gifu.jp -tarui.gifu.jp -toki.gifu.jp -tomika.gifu.jp -wanouchi.gifu.jp -yamagata.gifu.jp -yaotsu.gifu.jp -yoro.gifu.jp -annaka.gunma.jp -chiyoda.gunma.jp -fujioka.gunma.jp -higashiagatsuma.gunma.jp -isesaki.gunma.jp -itakura.gunma.jp -kanna.gunma.jp -kanra.gunma.jp -katashina.gunma.jp -kawaba.gunma.jp -kiryu.gunma.jp -kusatsu.gunma.jp -maebashi.gunma.jp -meiwa.gunma.jp -midori.gunma.jp -minakami.gunma.jp -naganohara.gunma.jp -nakanojo.gunma.jp -nanmoku.gunma.jp -numata.gunma.jp -oizumi.gunma.jp -ora.gunma.jp -ota.gunma.jp -shibukawa.gunma.jp -shimonita.gunma.jp -shinto.gunma.jp -showa.gunma.jp -takasaki.gunma.jp -takayama.gunma.jp -tamamura.gunma.jp -tatebayashi.gunma.jp -tomioka.gunma.jp -tsukiyono.gunma.jp -tsumagoi.gunma.jp -ueno.gunma.jp -yoshioka.gunma.jp -asaminami.hiroshima.jp -daiwa.hiroshima.jp -etajima.hiroshima.jp -fuchu.hiroshima.jp -fukuyama.hiroshima.jp -hatsukaichi.hiroshima.jp -higashihiroshima.hiroshima.jp -hongo.hiroshima.jp -jinsekikogen.hiroshima.jp -kaita.hiroshima.jp -kui.hiroshima.jp -kumano.hiroshima.jp -kure.hiroshima.jp -mihara.hiroshima.jp -miyoshi.hiroshima.jp -naka.hiroshima.jp -onomichi.hiroshima.jp -osakikamijima.hiroshima.jp -otake.hiroshima.jp -saka.hiroshima.jp -sera.hiroshima.jp -seranishi.hiroshima.jp -shinichi.hiroshima.jp -shobara.hiroshima.jp -takehara.hiroshima.jp -abashiri.hokkaido.jp -abira.hokkaido.jp -aibetsu.hokkaido.jp -akabira.hokkaido.jp -akkeshi.hokkaido.jp -asahikawa.hokkaido.jp -ashibetsu.hokkaido.jp -ashoro.hokkaido.jp -assabu.hokkaido.jp -atsuma.hokkaido.jp -bibai.hokkaido.jp -biei.hokkaido.jp -bifuka.hokkaido.jp -bihoro.hokkaido.jp -biratori.hokkaido.jp -chippubetsu.hokkaido.jp -chitose.hokkaido.jp -date.hokkaido.jp -ebetsu.hokkaido.jp -embetsu.hokkaido.jp -eniwa.hokkaido.jp -erimo.hokkaido.jp -esan.hokkaido.jp -esashi.hokkaido.jp -fukagawa.hokkaido.jp -fukushima.hokkaido.jp -furano.hokkaido.jp -furubira.hokkaido.jp -haboro.hokkaido.jp -hakodate.hokkaido.jp -hamatonbetsu.hokkaido.jp -hidaka.hokkaido.jp -higashikagura.hokkaido.jp -higashikawa.hokkaido.jp -hiroo.hokkaido.jp -hokuryu.hokkaido.jp -hokuto.hokkaido.jp -honbetsu.hokkaido.jp -horokanai.hokkaido.jp -horonobe.hokkaido.jp -ikeda.hokkaido.jp -imakane.hokkaido.jp -ishikari.hokkaido.jp -iwamizawa.hokkaido.jp -iwanai.hokkaido.jp -kamifurano.hokkaido.jp -kamikawa.hokkaido.jp -kamishihoro.hokkaido.jp -kamisunagawa.hokkaido.jp -kamoenai.hokkaido.jp -kayabe.hokkaido.jp -kembuchi.hokkaido.jp -kikonai.hokkaido.jp -kimobetsu.hokkaido.jp -kitahiroshima.hokkaido.jp -kitami.hokkaido.jp -kiyosato.hokkaido.jp -koshimizu.hokkaido.jp -kunneppu.hokkaido.jp -kuriyama.hokkaido.jp -kuromatsunai.hokkaido.jp -kushiro.hokkaido.jp -kutchan.hokkaido.jp -kyowa.hokkaido.jp -mashike.hokkaido.jp -matsumae.hokkaido.jp -mikasa.hokkaido.jp -minamifurano.hokkaido.jp -mombetsu.hokkaido.jp -moseushi.hokkaido.jp -mukawa.hokkaido.jp -muroran.hokkaido.jp -naie.hokkaido.jp -nakagawa.hokkaido.jp -nakasatsunai.hokkaido.jp -nakatombetsu.hokkaido.jp -nanae.hokkaido.jp -nanporo.hokkaido.jp -nayoro.hokkaido.jp -nemuro.hokkaido.jp -niikappu.hokkaido.jp -niki.hokkaido.jp -nishiokoppe.hokkaido.jp -noboribetsu.hokkaido.jp -numata.hokkaido.jp -obihiro.hokkaido.jp -obira.hokkaido.jp -oketo.hokkaido.jp -okoppe.hokkaido.jp -otaru.hokkaido.jp -otobe.hokkaido.jp -otofuke.hokkaido.jp -otoineppu.hokkaido.jp -oumu.hokkaido.jp -ozora.hokkaido.jp -pippu.hokkaido.jp -rankoshi.hokkaido.jp -rebun.hokkaido.jp -rikubetsu.hokkaido.jp -rishiri.hokkaido.jp -rishirifuji.hokkaido.jp -saroma.hokkaido.jp -sarufutsu.hokkaido.jp -shakotan.hokkaido.jp -shari.hokkaido.jp -shibecha.hokkaido.jp -shibetsu.hokkaido.jp -shikabe.hokkaido.jp -shikaoi.hokkaido.jp -shimamaki.hokkaido.jp -shimizu.hokkaido.jp -shimokawa.hokkaido.jp -shinshinotsu.hokkaido.jp -shintoku.hokkaido.jp -shiranuka.hokkaido.jp -shiraoi.hokkaido.jp -shiriuchi.hokkaido.jp -sobetsu.hokkaido.jp -sunagawa.hokkaido.jp -taiki.hokkaido.jp -takasu.hokkaido.jp -takikawa.hokkaido.jp -takinoue.hokkaido.jp -teshikaga.hokkaido.jp -tobetsu.hokkaido.jp -tohma.hokkaido.jp -tomakomai.hokkaido.jp -tomari.hokkaido.jp -toya.hokkaido.jp -toyako.hokkaido.jp -toyotomi.hokkaido.jp -toyoura.hokkaido.jp -tsubetsu.hokkaido.jp -tsukigata.hokkaido.jp -urakawa.hokkaido.jp -urausu.hokkaido.jp -uryu.hokkaido.jp -utashinai.hokkaido.jp -wakkanai.hokkaido.jp -wassamu.hokkaido.jp -yakumo.hokkaido.jp -yoichi.hokkaido.jp -aioi.hyogo.jp -akashi.hyogo.jp -ako.hyogo.jp -amagasaki.hyogo.jp -aogaki.hyogo.jp -asago.hyogo.jp -ashiya.hyogo.jp -awaji.hyogo.jp -fukusaki.hyogo.jp -goshiki.hyogo.jp -harima.hyogo.jp -himeji.hyogo.jp -ichikawa.hyogo.jp -inagawa.hyogo.jp -itami.hyogo.jp -kakogawa.hyogo.jp -kamigori.hyogo.jp -kamikawa.hyogo.jp -kasai.hyogo.jp -kasuga.hyogo.jp -kawanishi.hyogo.jp -miki.hyogo.jp -minamiawaji.hyogo.jp -nishinomiya.hyogo.jp -nishiwaki.hyogo.jp -ono.hyogo.jp -sanda.hyogo.jp -sannan.hyogo.jp -sasayama.hyogo.jp -sayo.hyogo.jp -shingu.hyogo.jp -shinonsen.hyogo.jp -shiso.hyogo.jp -sumoto.hyogo.jp -taishi.hyogo.jp -taka.hyogo.jp -takarazuka.hyogo.jp -takasago.hyogo.jp -takino.hyogo.jp -tamba.hyogo.jp -tatsuno.hyogo.jp -toyooka.hyogo.jp -yabu.hyogo.jp -yashiro.hyogo.jp -yoka.hyogo.jp -yokawa.hyogo.jp -ami.ibaraki.jp -asahi.ibaraki.jp -bando.ibaraki.jp -chikusei.ibaraki.jp -daigo.ibaraki.jp -fujishiro.ibaraki.jp -hitachi.ibaraki.jp -hitachinaka.ibaraki.jp -hitachiomiya.ibaraki.jp -hitachiota.ibaraki.jp -ibaraki.ibaraki.jp -ina.ibaraki.jp -inashiki.ibaraki.jp -itako.ibaraki.jp -iwama.ibaraki.jp -joso.ibaraki.jp -kamisu.ibaraki.jp -kasama.ibaraki.jp -kashima.ibaraki.jp -kasumigaura.ibaraki.jp -koga.ibaraki.jp -miho.ibaraki.jp -mito.ibaraki.jp -moriya.ibaraki.jp -naka.ibaraki.jp -namegata.ibaraki.jp -oarai.ibaraki.jp -ogawa.ibaraki.jp -omitama.ibaraki.jp -ryugasaki.ibaraki.jp -sakai.ibaraki.jp -sakuragawa.ibaraki.jp -shimodate.ibaraki.jp -shimotsuma.ibaraki.jp -shirosato.ibaraki.jp -sowa.ibaraki.jp -suifu.ibaraki.jp -takahagi.ibaraki.jp -tamatsukuri.ibaraki.jp -tokai.ibaraki.jp -tomobe.ibaraki.jp -tone.ibaraki.jp -toride.ibaraki.jp -tsuchiura.ibaraki.jp -tsukuba.ibaraki.jp -uchihara.ibaraki.jp -ushiku.ibaraki.jp -yachiyo.ibaraki.jp -yamagata.ibaraki.jp -yawara.ibaraki.jp -yuki.ibaraki.jp -anamizu.ishikawa.jp -hakui.ishikawa.jp -hakusan.ishikawa.jp -kaga.ishikawa.jp -kahoku.ishikawa.jp -kanazawa.ishikawa.jp -kawakita.ishikawa.jp -komatsu.ishikawa.jp -nakanoto.ishikawa.jp -nanao.ishikawa.jp -nomi.ishikawa.jp -nonoichi.ishikawa.jp -noto.ishikawa.jp -shika.ishikawa.jp -suzu.ishikawa.jp -tsubata.ishikawa.jp -tsurugi.ishikawa.jp -uchinada.ishikawa.jp -wajima.ishikawa.jp -fudai.iwate.jp -fujisawa.iwate.jp -hanamaki.iwate.jp -hiraizumi.iwate.jp -hirono.iwate.jp -ichinohe.iwate.jp -ichinoseki.iwate.jp -iwaizumi.iwate.jp -iwate.iwate.jp -joboji.iwate.jp -kamaishi.iwate.jp -kanegasaki.iwate.jp -karumai.iwate.jp -kawai.iwate.jp -kitakami.iwate.jp -kuji.iwate.jp -kunohe.iwate.jp -kuzumaki.iwate.jp -miyako.iwate.jp -mizusawa.iwate.jp -morioka.iwate.jp -ninohe.iwate.jp -noda.iwate.jp -ofunato.iwate.jp -oshu.iwate.jp -otsuchi.iwate.jp -rikuzentakata.iwate.jp -shiwa.iwate.jp -shizukuishi.iwate.jp -sumita.iwate.jp -tanohata.iwate.jp -tono.iwate.jp -yahaba.iwate.jp -yamada.iwate.jp -ayagawa.kagawa.jp -higashikagawa.kagawa.jp -kanonji.kagawa.jp -kotohira.kagawa.jp -manno.kagawa.jp -marugame.kagawa.jp -mitoyo.kagawa.jp -naoshima.kagawa.jp -sanuki.kagawa.jp -tadotsu.kagawa.jp -takamatsu.kagawa.jp -tonosho.kagawa.jp -uchinomi.kagawa.jp -utazu.kagawa.jp -zentsuji.kagawa.jp -akune.kagoshima.jp -amami.kagoshima.jp -hioki.kagoshima.jp -isa.kagoshima.jp -isen.kagoshima.jp -izumi.kagoshima.jp -kagoshima.kagoshima.jp -kanoya.kagoshima.jp -kawanabe.kagoshima.jp -kinko.kagoshima.jp -kouyama.kagoshima.jp -makurazaki.kagoshima.jp -matsumoto.kagoshima.jp -minamitane.kagoshima.jp -nakatane.kagoshima.jp -nishinoomote.kagoshima.jp -satsumasendai.kagoshima.jp -soo.kagoshima.jp -tarumizu.kagoshima.jp -yusui.kagoshima.jp -aikawa.kanagawa.jp -atsugi.kanagawa.jp -ayase.kanagawa.jp -chigasaki.kanagawa.jp -ebina.kanagawa.jp -fujisawa.kanagawa.jp -hadano.kanagawa.jp -hakone.kanagawa.jp -hiratsuka.kanagawa.jp -isehara.kanagawa.jp -kaisei.kanagawa.jp -kamakura.kanagawa.jp -kiyokawa.kanagawa.jp -matsuda.kanagawa.jp -minamiashigara.kanagawa.jp -miura.kanagawa.jp -nakai.kanagawa.jp -ninomiya.kanagawa.jp -odawara.kanagawa.jp -oi.kanagawa.jp -oiso.kanagawa.jp -sagamihara.kanagawa.jp -samukawa.kanagawa.jp -tsukui.kanagawa.jp -yamakita.kanagawa.jp -yamato.kanagawa.jp -yokosuka.kanagawa.jp -yugawara.kanagawa.jp -zama.kanagawa.jp -zushi.kanagawa.jp -aki.kochi.jp -geisei.kochi.jp -hidaka.kochi.jp -higashitsuno.kochi.jp -ino.kochi.jp -kagami.kochi.jp -kami.kochi.jp -kitagawa.kochi.jp -kochi.kochi.jp -mihara.kochi.jp -motoyama.kochi.jp -muroto.kochi.jp -nahari.kochi.jp -nakamura.kochi.jp -nankoku.kochi.jp -nishitosa.kochi.jp -niyodogawa.kochi.jp -ochi.kochi.jp -okawa.kochi.jp -otoyo.kochi.jp -otsuki.kochi.jp -sakawa.kochi.jp -sukumo.kochi.jp -susaki.kochi.jp -tosa.kochi.jp -tosashimizu.kochi.jp -toyo.kochi.jp -tsuno.kochi.jp -umaji.kochi.jp -yasuda.kochi.jp -yusuhara.kochi.jp -amakusa.kumamoto.jp -arao.kumamoto.jp -aso.kumamoto.jp -choyo.kumamoto.jp -gyokuto.kumamoto.jp -kamiamakusa.kumamoto.jp -kikuchi.kumamoto.jp -kumamoto.kumamoto.jp -mashiki.kumamoto.jp -mifune.kumamoto.jp -minamata.kumamoto.jp -minamioguni.kumamoto.jp -nagasu.kumamoto.jp -nishihara.kumamoto.jp -oguni.kumamoto.jp -ozu.kumamoto.jp -sumoto.kumamoto.jp -takamori.kumamoto.jp -uki.kumamoto.jp -uto.kumamoto.jp -yamaga.kumamoto.jp -yamato.kumamoto.jp -yatsushiro.kumamoto.jp -ayabe.kyoto.jp -fukuchiyama.kyoto.jp -higashiyama.kyoto.jp -ide.kyoto.jp -ine.kyoto.jp -joyo.kyoto.jp -kameoka.kyoto.jp -kamo.kyoto.jp -kita.kyoto.jp -kizu.kyoto.jp -kumiyama.kyoto.jp -kyotamba.kyoto.jp -kyotanabe.kyoto.jp -kyotango.kyoto.jp -maizuru.kyoto.jp -minami.kyoto.jp -minamiyamashiro.kyoto.jp -miyazu.kyoto.jp -muko.kyoto.jp -nagaokakyo.kyoto.jp -nakagyo.kyoto.jp -nantan.kyoto.jp -oyamazaki.kyoto.jp -sakyo.kyoto.jp -seika.kyoto.jp -tanabe.kyoto.jp -uji.kyoto.jp -ujitawara.kyoto.jp -wazuka.kyoto.jp -yamashina.kyoto.jp -yawata.kyoto.jp -asahi.mie.jp -inabe.mie.jp -ise.mie.jp -kameyama.mie.jp -kawagoe.mie.jp -kiho.mie.jp -kisosaki.mie.jp -kiwa.mie.jp -komono.mie.jp -kumano.mie.jp -kuwana.mie.jp -matsusaka.mie.jp -meiwa.mie.jp -mihama.mie.jp -minamiise.mie.jp -misugi.mie.jp -miyama.mie.jp -nabari.mie.jp -shima.mie.jp -suzuka.mie.jp -tado.mie.jp -taiki.mie.jp -taki.mie.jp -tamaki.mie.jp -toba.mie.jp -tsu.mie.jp -udono.mie.jp -ureshino.mie.jp -watarai.mie.jp -yokkaichi.mie.jp -furukawa.miyagi.jp -higashimatsushima.miyagi.jp -ishinomaki.miyagi.jp -iwanuma.miyagi.jp -kakuda.miyagi.jp -kami.miyagi.jp -kawasaki.miyagi.jp -marumori.miyagi.jp -matsushima.miyagi.jp -minamisanriku.miyagi.jp -misato.miyagi.jp -murata.miyagi.jp -natori.miyagi.jp -ogawara.miyagi.jp -ohira.miyagi.jp -onagawa.miyagi.jp -osaki.miyagi.jp -rifu.miyagi.jp -semine.miyagi.jp -shibata.miyagi.jp -shichikashuku.miyagi.jp -shikama.miyagi.jp -shiogama.miyagi.jp -shiroishi.miyagi.jp -tagajo.miyagi.jp -taiwa.miyagi.jp -tome.miyagi.jp -tomiya.miyagi.jp -wakuya.miyagi.jp -watari.miyagi.jp -yamamoto.miyagi.jp -zao.miyagi.jp -aya.miyazaki.jp -ebino.miyazaki.jp -gokase.miyazaki.jp -hyuga.miyazaki.jp -kadogawa.miyazaki.jp -kawaminami.miyazaki.jp -kijo.miyazaki.jp -kitagawa.miyazaki.jp -kitakata.miyazaki.jp -kitaura.miyazaki.jp -kobayashi.miyazaki.jp -kunitomi.miyazaki.jp -kushima.miyazaki.jp -mimata.miyazaki.jp -miyakonojo.miyazaki.jp -miyazaki.miyazaki.jp -morotsuka.miyazaki.jp -nichinan.miyazaki.jp -nishimera.miyazaki.jp -nobeoka.miyazaki.jp -saito.miyazaki.jp -shiiba.miyazaki.jp -shintomi.miyazaki.jp -takaharu.miyazaki.jp -takanabe.miyazaki.jp -takazaki.miyazaki.jp -tsuno.miyazaki.jp -achi.nagano.jp -agematsu.nagano.jp -anan.nagano.jp -aoki.nagano.jp -asahi.nagano.jp -azumino.nagano.jp -chikuhoku.nagano.jp -chikuma.nagano.jp -chino.nagano.jp -fujimi.nagano.jp -hakuba.nagano.jp -hara.nagano.jp -hiraya.nagano.jp -iida.nagano.jp -iijima.nagano.jp -iiyama.nagano.jp -iizuna.nagano.jp -ikeda.nagano.jp -ikusaka.nagano.jp -ina.nagano.jp -karuizawa.nagano.jp -kawakami.nagano.jp -kiso.nagano.jp -kisofukushima.nagano.jp -kitaaiki.nagano.jp -komagane.nagano.jp -komoro.nagano.jp -matsukawa.nagano.jp -matsumoto.nagano.jp -miasa.nagano.jp -minamiaiki.nagano.jp -minamimaki.nagano.jp -minamiminowa.nagano.jp -minowa.nagano.jp -miyada.nagano.jp -miyota.nagano.jp -mochizuki.nagano.jp -nagano.nagano.jp -nagawa.nagano.jp -nagiso.nagano.jp -nakagawa.nagano.jp -nakano.nagano.jp -nozawaonsen.nagano.jp -obuse.nagano.jp -ogawa.nagano.jp -okaya.nagano.jp -omachi.nagano.jp -omi.nagano.jp -ookuwa.nagano.jp -ooshika.nagano.jp -otaki.nagano.jp -otari.nagano.jp -sakae.nagano.jp -sakaki.nagano.jp -saku.nagano.jp -sakuho.nagano.jp -shimosuwa.nagano.jp -shinanomachi.nagano.jp -shiojiri.nagano.jp -suwa.nagano.jp -suzaka.nagano.jp -takagi.nagano.jp -takamori.nagano.jp -takayama.nagano.jp -tateshina.nagano.jp -tatsuno.nagano.jp -togakushi.nagano.jp -togura.nagano.jp -tomi.nagano.jp -ueda.nagano.jp -wada.nagano.jp -yamagata.nagano.jp -yamanouchi.nagano.jp -yasaka.nagano.jp -yasuoka.nagano.jp -chijiwa.nagasaki.jp -futsu.nagasaki.jp -goto.nagasaki.jp -hasami.nagasaki.jp -hirado.nagasaki.jp -iki.nagasaki.jp -isahaya.nagasaki.jp -kawatana.nagasaki.jp -kuchinotsu.nagasaki.jp -matsuura.nagasaki.jp -nagasaki.nagasaki.jp -obama.nagasaki.jp -omura.nagasaki.jp -oseto.nagasaki.jp -saikai.nagasaki.jp -sasebo.nagasaki.jp -seihi.nagasaki.jp -shimabara.nagasaki.jp -shinkamigoto.nagasaki.jp -togitsu.nagasaki.jp -tsushima.nagasaki.jp -unzen.nagasaki.jp -ando.nara.jp -gose.nara.jp -heguri.nara.jp -higashiyoshino.nara.jp -ikaruga.nara.jp -ikoma.nara.jp -kamikitayama.nara.jp -kanmaki.nara.jp -kashiba.nara.jp -kashihara.nara.jp -katsuragi.nara.jp -kawai.nara.jp -kawakami.nara.jp -kawanishi.nara.jp -koryo.nara.jp -kurotaki.nara.jp -mitsue.nara.jp -miyake.nara.jp -nara.nara.jp -nosegawa.nara.jp -oji.nara.jp -ouda.nara.jp -oyodo.nara.jp -sakurai.nara.jp -sango.nara.jp -shimoichi.nara.jp -shimokitayama.nara.jp -shinjo.nara.jp -soni.nara.jp -takatori.nara.jp -tawaramoto.nara.jp -tenkawa.nara.jp -tenri.nara.jp -uda.nara.jp -yamatokoriyama.nara.jp -yamatotakada.nara.jp -yamazoe.nara.jp -yoshino.nara.jp -aga.niigata.jp -agano.niigata.jp -gosen.niigata.jp -itoigawa.niigata.jp -izumozaki.niigata.jp -joetsu.niigata.jp -kamo.niigata.jp -kariwa.niigata.jp -kashiwazaki.niigata.jp -minamiuonuma.niigata.jp -mitsuke.niigata.jp -muika.niigata.jp -murakami.niigata.jp -myoko.niigata.jp -nagaoka.niigata.jp -niigata.niigata.jp -ojiya.niigata.jp -omi.niigata.jp -sado.niigata.jp -sanjo.niigata.jp -seiro.niigata.jp -seirou.niigata.jp -sekikawa.niigata.jp -shibata.niigata.jp -tagami.niigata.jp -tainai.niigata.jp -tochio.niigata.jp -tokamachi.niigata.jp -tsubame.niigata.jp -tsunan.niigata.jp -uonuma.niigata.jp -yahiko.niigata.jp -yoita.niigata.jp -yuzawa.niigata.jp -beppu.oita.jp -bungoono.oita.jp -bungotakada.oita.jp -hasama.oita.jp -hiji.oita.jp -himeshima.oita.jp -hita.oita.jp -kamitsue.oita.jp -kokonoe.oita.jp -kuju.oita.jp -kunisaki.oita.jp -kusu.oita.jp -oita.oita.jp -saiki.oita.jp -taketa.oita.jp -tsukumi.oita.jp -usa.oita.jp -usuki.oita.jp -yufu.oita.jp -akaiwa.okayama.jp -asakuchi.okayama.jp -bizen.okayama.jp -hayashima.okayama.jp -ibara.okayama.jp -kagamino.okayama.jp -kasaoka.okayama.jp -kibichuo.okayama.jp -kumenan.okayama.jp -kurashiki.okayama.jp -maniwa.okayama.jp -misaki.okayama.jp -nagi.okayama.jp -niimi.okayama.jp -nishiawakura.okayama.jp -okayama.okayama.jp -satosho.okayama.jp -setouchi.okayama.jp -shinjo.okayama.jp -shoo.okayama.jp -soja.okayama.jp -takahashi.okayama.jp -tamano.okayama.jp -tsuyama.okayama.jp -wake.okayama.jp -yakage.okayama.jp -aguni.okinawa.jp -ginowan.okinawa.jp -ginoza.okinawa.jp -gushikami.okinawa.jp -haebaru.okinawa.jp -higashi.okinawa.jp -hirara.okinawa.jp -iheya.okinawa.jp -ishigaki.okinawa.jp -ishikawa.okinawa.jp -itoman.okinawa.jp -izena.okinawa.jp -kadena.okinawa.jp -kin.okinawa.jp -kitadaito.okinawa.jp -kitanakagusuku.okinawa.jp -kumejima.okinawa.jp -kunigami.okinawa.jp -minamidaito.okinawa.jp -motobu.okinawa.jp -nago.okinawa.jp -naha.okinawa.jp -nakagusuku.okinawa.jp -nakijin.okinawa.jp -nanjo.okinawa.jp -nishihara.okinawa.jp -ogimi.okinawa.jp -okinawa.okinawa.jp -onna.okinawa.jp -shimoji.okinawa.jp -taketomi.okinawa.jp -tarama.okinawa.jp -tokashiki.okinawa.jp -tomigusuku.okinawa.jp -tonaki.okinawa.jp -urasoe.okinawa.jp -uruma.okinawa.jp -yaese.okinawa.jp -yomitan.okinawa.jp -yonabaru.okinawa.jp -yonaguni.okinawa.jp -zamami.okinawa.jp -abeno.osaka.jp -chihayaakasaka.osaka.jp -chuo.osaka.jp -daito.osaka.jp -fujiidera.osaka.jp -habikino.osaka.jp -hannan.osaka.jp -higashiosaka.osaka.jp -higashisumiyoshi.osaka.jp -higashiyodogawa.osaka.jp -hirakata.osaka.jp -ibaraki.osaka.jp -ikeda.osaka.jp -izumi.osaka.jp -izumiotsu.osaka.jp -izumisano.osaka.jp -kadoma.osaka.jp -kaizuka.osaka.jp -kanan.osaka.jp -kashiwara.osaka.jp -katano.osaka.jp -kawachinagano.osaka.jp -kishiwada.osaka.jp -kita.osaka.jp -kumatori.osaka.jp -matsubara.osaka.jp -minato.osaka.jp -minoh.osaka.jp -misaki.osaka.jp -moriguchi.osaka.jp -neyagawa.osaka.jp -nishi.osaka.jp -nose.osaka.jp -osakasayama.osaka.jp -sakai.osaka.jp -sayama.osaka.jp -sennan.osaka.jp -settsu.osaka.jp -shijonawate.osaka.jp -shimamoto.osaka.jp -suita.osaka.jp -tadaoka.osaka.jp -taishi.osaka.jp -tajiri.osaka.jp -takaishi.osaka.jp -takatsuki.osaka.jp -tondabayashi.osaka.jp -toyonaka.osaka.jp -toyono.osaka.jp -yao.osaka.jp -ariake.saga.jp -arita.saga.jp -fukudomi.saga.jp -genkai.saga.jp -hamatama.saga.jp -hizen.saga.jp -imari.saga.jp -kamimine.saga.jp -kanzaki.saga.jp -karatsu.saga.jp -kashima.saga.jp -kitagata.saga.jp -kitahata.saga.jp -kiyama.saga.jp -kouhoku.saga.jp -kyuragi.saga.jp -nishiarita.saga.jp -ogi.saga.jp -omachi.saga.jp -ouchi.saga.jp -saga.saga.jp -shiroishi.saga.jp -taku.saga.jp -tara.saga.jp -tosu.saga.jp -yoshinogari.saga.jp -arakawa.saitama.jp -asaka.saitama.jp -chichibu.saitama.jp -fujimi.saitama.jp -fujimino.saitama.jp -fukaya.saitama.jp -hanno.saitama.jp -hanyu.saitama.jp -hasuda.saitama.jp -hatogaya.saitama.jp -hatoyama.saitama.jp -hidaka.saitama.jp -higashichichibu.saitama.jp -higashimatsuyama.saitama.jp -honjo.saitama.jp -ina.saitama.jp -iruma.saitama.jp -iwatsuki.saitama.jp -kamiizumi.saitama.jp -kamikawa.saitama.jp -kamisato.saitama.jp -kasukabe.saitama.jp -kawagoe.saitama.jp -kawaguchi.saitama.jp -kawajima.saitama.jp -kazo.saitama.jp -kitamoto.saitama.jp -koshigaya.saitama.jp -kounosu.saitama.jp -kuki.saitama.jp -kumagaya.saitama.jp -matsubushi.saitama.jp -minano.saitama.jp -misato.saitama.jp -miyashiro.saitama.jp -miyoshi.saitama.jp -moroyama.saitama.jp -nagatoro.saitama.jp -namegawa.saitama.jp -niiza.saitama.jp -ogano.saitama.jp -ogawa.saitama.jp -ogose.saitama.jp -okegawa.saitama.jp -omiya.saitama.jp -otaki.saitama.jp -ranzan.saitama.jp -ryokami.saitama.jp -saitama.saitama.jp -sakado.saitama.jp -satte.saitama.jp -sayama.saitama.jp -shiki.saitama.jp -shiraoka.saitama.jp -soka.saitama.jp -sugito.saitama.jp -toda.saitama.jp -tokigawa.saitama.jp -tokorozawa.saitama.jp -tsurugashima.saitama.jp -urawa.saitama.jp -warabi.saitama.jp -yashio.saitama.jp -yokoze.saitama.jp -yono.saitama.jp -yorii.saitama.jp -yoshida.saitama.jp -yoshikawa.saitama.jp -yoshimi.saitama.jp -aisho.shiga.jp -gamo.shiga.jp -higashiomi.shiga.jp -hikone.shiga.jp -koka.shiga.jp -konan.shiga.jp -kosei.shiga.jp -koto.shiga.jp -kusatsu.shiga.jp -maibara.shiga.jp -moriyama.shiga.jp -nagahama.shiga.jp -nishiazai.shiga.jp -notogawa.shiga.jp -omihachiman.shiga.jp -otsu.shiga.jp -ritto.shiga.jp -ryuoh.shiga.jp -takashima.shiga.jp -takatsuki.shiga.jp -torahime.shiga.jp -toyosato.shiga.jp -yasu.shiga.jp -akagi.shimane.jp -ama.shimane.jp -gotsu.shimane.jp -hamada.shimane.jp -higashiizumo.shimane.jp -hikawa.shimane.jp -hikimi.shimane.jp -izumo.shimane.jp -kakinoki.shimane.jp -masuda.shimane.jp -matsue.shimane.jp -misato.shimane.jp -nishinoshima.shimane.jp -ohda.shimane.jp -okinoshima.shimane.jp -okuizumo.shimane.jp -shimane.shimane.jp -tamayu.shimane.jp -tsuwano.shimane.jp -unnan.shimane.jp -yakumo.shimane.jp -yasugi.shimane.jp -yatsuka.shimane.jp -arai.shizuoka.jp -atami.shizuoka.jp -fuji.shizuoka.jp -fujieda.shizuoka.jp -fujikawa.shizuoka.jp -fujinomiya.shizuoka.jp -fukuroi.shizuoka.jp -gotemba.shizuoka.jp -haibara.shizuoka.jp -hamamatsu.shizuoka.jp -higashiizu.shizuoka.jp -ito.shizuoka.jp -iwata.shizuoka.jp -izu.shizuoka.jp -izunokuni.shizuoka.jp -kakegawa.shizuoka.jp -kannami.shizuoka.jp -kawanehon.shizuoka.jp -kawazu.shizuoka.jp -kikugawa.shizuoka.jp -kosai.shizuoka.jp -makinohara.shizuoka.jp -matsuzaki.shizuoka.jp -minamiizu.shizuoka.jp -mishima.shizuoka.jp -morimachi.shizuoka.jp -nishiizu.shizuoka.jp -numazu.shizuoka.jp -omaezaki.shizuoka.jp -shimada.shizuoka.jp -shimizu.shizuoka.jp -shimoda.shizuoka.jp -shizuoka.shizuoka.jp -susono.shizuoka.jp -yaizu.shizuoka.jp -yoshida.shizuoka.jp -ashikaga.tochigi.jp -bato.tochigi.jp -haga.tochigi.jp -ichikai.tochigi.jp -iwafune.tochigi.jp -kaminokawa.tochigi.jp -kanuma.tochigi.jp -karasuyama.tochigi.jp -kuroiso.tochigi.jp -mashiko.tochigi.jp -mibu.tochigi.jp -moka.tochigi.jp -motegi.tochigi.jp -nasu.tochigi.jp -nasushiobara.tochigi.jp -nikko.tochigi.jp -nishikata.tochigi.jp -nogi.tochigi.jp -ohira.tochigi.jp -ohtawara.tochigi.jp -oyama.tochigi.jp -sakura.tochigi.jp -sano.tochigi.jp -shimotsuke.tochigi.jp -shioya.tochigi.jp -takanezawa.tochigi.jp -tochigi.tochigi.jp -tsuga.tochigi.jp -ujiie.tochigi.jp -utsunomiya.tochigi.jp -yaita.tochigi.jp -aizumi.tokushima.jp -anan.tokushima.jp -ichiba.tokushima.jp -itano.tokushima.jp -kainan.tokushima.jp -komatsushima.tokushima.jp -matsushige.tokushima.jp -mima.tokushima.jp -minami.tokushima.jp -miyoshi.tokushima.jp -mugi.tokushima.jp -nakagawa.tokushima.jp -naruto.tokushima.jp -sanagochi.tokushima.jp -shishikui.tokushima.jp -tokushima.tokushima.jp -wajiki.tokushima.jp -adachi.tokyo.jp -akiruno.tokyo.jp -akishima.tokyo.jp -aogashima.tokyo.jp -arakawa.tokyo.jp -bunkyo.tokyo.jp -chiyoda.tokyo.jp -chofu.tokyo.jp -chuo.tokyo.jp -edogawa.tokyo.jp -fuchu.tokyo.jp -fussa.tokyo.jp -hachijo.tokyo.jp -hachioji.tokyo.jp -hamura.tokyo.jp -higashikurume.tokyo.jp -higashimurayama.tokyo.jp -higashiyamato.tokyo.jp -hino.tokyo.jp -hinode.tokyo.jp -hinohara.tokyo.jp -inagi.tokyo.jp -itabashi.tokyo.jp -katsushika.tokyo.jp -kita.tokyo.jp -kiyose.tokyo.jp -kodaira.tokyo.jp -koganei.tokyo.jp -kokubunji.tokyo.jp -komae.tokyo.jp -koto.tokyo.jp -kouzushima.tokyo.jp -kunitachi.tokyo.jp -machida.tokyo.jp -meguro.tokyo.jp -minato.tokyo.jp -mitaka.tokyo.jp -mizuho.tokyo.jp -musashimurayama.tokyo.jp -musashino.tokyo.jp -nakano.tokyo.jp -nerima.tokyo.jp -ogasawara.tokyo.jp -okutama.tokyo.jp -ome.tokyo.jp -oshima.tokyo.jp -ota.tokyo.jp -setagaya.tokyo.jp -shibuya.tokyo.jp -shinagawa.tokyo.jp -shinjuku.tokyo.jp -suginami.tokyo.jp -sumida.tokyo.jp -tachikawa.tokyo.jp -taito.tokyo.jp -tama.tokyo.jp -toshima.tokyo.jp -chizu.tottori.jp -hino.tottori.jp -kawahara.tottori.jp -koge.tottori.jp -kotoura.tottori.jp -misasa.tottori.jp -nanbu.tottori.jp -nichinan.tottori.jp -sakaiminato.tottori.jp -tottori.tottori.jp -wakasa.tottori.jp -yazu.tottori.jp -yonago.tottori.jp -asahi.toyama.jp -fuchu.toyama.jp -fukumitsu.toyama.jp -funahashi.toyama.jp -himi.toyama.jp -imizu.toyama.jp -inami.toyama.jp -johana.toyama.jp -kamiichi.toyama.jp -kurobe.toyama.jp -nakaniikawa.toyama.jp -namerikawa.toyama.jp -nanto.toyama.jp -nyuzen.toyama.jp -oyabe.toyama.jp -taira.toyama.jp -takaoka.toyama.jp -tateyama.toyama.jp -toga.toyama.jp -tonami.toyama.jp -toyama.toyama.jp -unazuki.toyama.jp -uozu.toyama.jp -yamada.toyama.jp -arida.wakayama.jp -aridagawa.wakayama.jp -gobo.wakayama.jp -hashimoto.wakayama.jp -hidaka.wakayama.jp -hirogawa.wakayama.jp -inami.wakayama.jp -iwade.wakayama.jp -kainan.wakayama.jp -kamitonda.wakayama.jp -katsuragi.wakayama.jp -kimino.wakayama.jp -kinokawa.wakayama.jp -kitayama.wakayama.jp -koya.wakayama.jp -koza.wakayama.jp -kozagawa.wakayama.jp -kudoyama.wakayama.jp -kushimoto.wakayama.jp -mihama.wakayama.jp -misato.wakayama.jp -nachikatsuura.wakayama.jp -shingu.wakayama.jp -shirahama.wakayama.jp -taiji.wakayama.jp -tanabe.wakayama.jp -wakayama.wakayama.jp -yuasa.wakayama.jp -yura.wakayama.jp -asahi.yamagata.jp -funagata.yamagata.jp -higashine.yamagata.jp -iide.yamagata.jp -kahoku.yamagata.jp -kaminoyama.yamagata.jp -kaneyama.yamagata.jp -kawanishi.yamagata.jp -mamurogawa.yamagata.jp -mikawa.yamagata.jp -murayama.yamagata.jp -nagai.yamagata.jp -nakayama.yamagata.jp -nanyo.yamagata.jp -nishikawa.yamagata.jp -obanazawa.yamagata.jp -oe.yamagata.jp -oguni.yamagata.jp -ohkura.yamagata.jp -oishida.yamagata.jp -sagae.yamagata.jp -sakata.yamagata.jp -sakegawa.yamagata.jp -shinjo.yamagata.jp -shirataka.yamagata.jp -shonai.yamagata.jp -takahata.yamagata.jp -tendo.yamagata.jp -tozawa.yamagata.jp -tsuruoka.yamagata.jp -yamagata.yamagata.jp -yamanobe.yamagata.jp -yonezawa.yamagata.jp -yuza.yamagata.jp -abu.yamaguchi.jp -hagi.yamaguchi.jp -hikari.yamaguchi.jp -hofu.yamaguchi.jp -iwakuni.yamaguchi.jp -kudamatsu.yamaguchi.jp -mitou.yamaguchi.jp -nagato.yamaguchi.jp -oshima.yamaguchi.jp -shimonoseki.yamaguchi.jp -shunan.yamaguchi.jp -tabuse.yamaguchi.jp -tokuyama.yamaguchi.jp -toyota.yamaguchi.jp -ube.yamaguchi.jp -yuu.yamaguchi.jp -chuo.yamanashi.jp -doshi.yamanashi.jp -fuefuki.yamanashi.jp -fujikawa.yamanashi.jp -fujikawaguchiko.yamanashi.jp -fujiyoshida.yamanashi.jp -hayakawa.yamanashi.jp -hokuto.yamanashi.jp -ichikawamisato.yamanashi.jp -kai.yamanashi.jp -kofu.yamanashi.jp -koshu.yamanashi.jp -kosuge.yamanashi.jp -minami-alps.yamanashi.jp -minobu.yamanashi.jp -nakamichi.yamanashi.jp -nanbu.yamanashi.jp -narusawa.yamanashi.jp -nirasaki.yamanashi.jp -nishikatsura.yamanashi.jp -oshino.yamanashi.jp -otsuki.yamanashi.jp -showa.yamanashi.jp -tabayama.yamanashi.jp -tsuru.yamanashi.jp -uenohara.yamanashi.jp -yamanakako.yamanashi.jp -yamanashi.yamanashi.jp -ke ac.ke co.ke go.ke @@ -3251,14 +1416,13 @@ mobi.ke ne.ke or.ke sc.ke -kg org.kg net.kg com.kg edu.kg gov.kg mil.kg -kki +*.kh edu.ki biz.ki net.ki @@ -3266,7 +1430,6 @@ org.ki gov.ki info.ki com.ki -km org.km nom.km gov.km @@ -3284,19 +1447,16 @@ notaires.km pharmaciens.km veterinaire.km gouv.km -kn net.kn org.kn edu.kn gov.kn -kp com.kp edu.kp gov.kp org.kp rep.kp tra.kp -kr ac.kr co.kr es.kr @@ -3326,7 +1486,6 @@ jeonbuk.kr jeonnam.kr seoul.kr ulsan.kr -kw com.kw edu.kw emb.kw @@ -3334,20 +1493,17 @@ gov.kw ind.kw net.kw org.kw -ky edu.ky gov.ky com.ky org.ky net.ky -kz org.kz edu.kz net.kz gov.kz mil.kz com.kz -la int.la net.la info.la @@ -3356,21 +1512,17 @@ gov.la per.la com.la org.la -lb com.lb edu.lb gov.lb net.lb org.lb -lc com.lc net.lc co.lc org.lc edu.lc gov.lc -li -lk gov.lk sch.lk net.lk @@ -3386,13 +1538,11 @@ assn.lk grp.lk hotel.lk ac.lk -lr com.lr edu.lr gov.lr org.lr net.lr -ls ac.ls biz.ls co.ls @@ -3402,10 +1552,7 @@ info.ls net.ls org.ls sc.ls -lt gov.lt -lu -lv com.lv edu.lv gov.lv @@ -3415,7 +1562,6 @@ id.lv net.lv asn.lv conf.lv -ly com.ly net.ly gov.ly @@ -3425,18 +1571,14 @@ sch.ly med.ly org.ly id.ly -ma co.ma net.ma gov.ma org.ma ac.ma press.ma -mc tm.mc asso.mc -md -me co.me net.me org.me @@ -3445,7 +1587,6 @@ ac.me gov.me its.me priv.me -mg org.mg nom.mg gov.mg @@ -3455,9 +1596,6 @@ edu.mg mil.mg com.mg co.mg -mh -mil -mk com.mk org.mk net.mk @@ -3465,7 +1603,6 @@ edu.mk gov.mk inf.mk name.mk -ml com.ml edu.ml gouv.ml @@ -3473,33 +1610,25 @@ gov.ml net.ml org.ml presse.ml -mmn +*.mm gov.mn edu.mn org.mn -mo com.mo net.mo org.mo edu.mo gov.mo -mobi -mp -mq -mr gov.mr -ms com.ms edu.ms gov.ms net.ms org.ms -mt com.mt edu.mt net.mt org.mt -mu com.mu net.mu org.mu @@ -3507,7 +1636,6 @@ gov.mu ac.mu co.mu or.mu -museum academy.museum agriculture.museum air.museum @@ -4056,7 +2184,6 @@ zoological.museum zoology.museum ירושלים.museum иком.museum -mv aero.mv biz.mv com.mv @@ -4071,7 +2198,6 @@ name.mv net.mv org.mv pro.mv -mw ac.mw biz.mw co.mw @@ -4083,13 +2209,11 @@ int.mw museum.mw net.mw org.mw -mx com.mx org.mx gob.mx edu.mx net.mx -my com.my net.my org.my @@ -4097,7 +2221,6 @@ gov.my edu.my mil.my name.my -mz ac.mz adv.mz co.mz @@ -4106,7 +2229,6 @@ gov.mz mil.mz net.mz org.mz -na info.na pro.na name.na @@ -4124,13 +2246,8 @@ mobi.na co.na com.na org.na -name -nc asso.nc nom.nc -ne -net -nf com.nf net.nf per.nf @@ -4141,7 +2258,6 @@ firm.nf info.nf other.nf store.nf -ng com.ng edu.ng gov.ng @@ -4152,7 +2268,6 @@ name.ng net.ng org.ng sch.ng -ni ac.ni biz.ni co.ni @@ -4167,8 +2282,6 @@ net.ni nom.ni org.ni web.ni -nl -no fhs.no vgs.no fylkesbibl.no @@ -4202,27 +2315,6 @@ tm.no tr.no va.no vf.no -gs.aa.no -gs.ah.no -gs.bu.no -gs.fm.no -gs.hl.no -gs.hm.no -gs.jan-mayen.no -gs.mr.no -gs.nl.no -gs.nt.no -gs.of.no -gs.ol.no -gs.oslo.no -gs.rl.no -gs.sf.no -gs.st.no -gs.svalbard.no -gs.tm.no -gs.tr.no -gs.va.no -gs.vf.no akrehamn.no åkrehamn.no algard.no @@ -4359,10 +2451,6 @@ bygland.no bykle.no barum.no bærum.no -bo.telemark.no -bø.telemark.no -bo.nordland.no -bø.nordland.no bievat.no bievát.no bomlo.no @@ -4476,10 +2564,6 @@ haugesund.no hemne.no hemnes.no hemsedal.no -heroy.more-og-romsdal.no -herøy.møre-og-romsdal.no -heroy.nordland.no -herøy.nordland.no hitra.no hjartdal.no hjelmeland.no @@ -4640,8 +2724,6 @@ narvik.no narviika.no naustdal.no nedre-eiker.no -nes.akershus.no -nes.buskerud.no nesna.no nesodden.no nesseby.no @@ -4680,8 +2762,6 @@ orskog.no ørskog.no orsta.no ørsta.no -os.hedmark.no -os.hordaland.no osen.no osteroy.no osterøy.no @@ -4744,9 +2824,6 @@ salat.no sálát.no sálat.no samnanger.no -sande.more-og-romsdal.no -sande.møre-og-romsdal.no -sande.vestfold.no sandefjord.no sandnes.no sandoy.no @@ -4918,11 +2995,7 @@ vagsoy.no vågsøy.no vaga.no vågå.no -valer.ostfold.no -våler.østfold.no -valer.hedmark.no -våler.hedmark.no -nnr +*.np biz.nr info.nr gov.nr @@ -4930,8 +3003,6 @@ edu.nr org.nr net.nr com.nr -nu -nz ac.nz co.nz cri.nz @@ -4948,7 +3019,6 @@ net.nz org.nz parliament.nz school.nz -om co.om com.om edu.om @@ -4958,9 +3028,6 @@ museum.om net.om org.om pro.om -onion -org -pa ac.pa gob.pa com.pa @@ -4972,7 +3039,6 @@ ing.pa abo.pa med.pa nom.pa -pe edu.pe gob.pe nom.pe @@ -4980,11 +3046,10 @@ mil.pe org.pe com.pe net.pe -pf com.pf org.pf edu.pf -pph +*.pg com.ph net.ph org.ph @@ -4993,7 +3058,6 @@ edu.ph ngo.ph mil.ph i.ph -pk com.pk net.pk edu.pk @@ -5008,7 +3072,6 @@ gon.pk gop.pk gos.pk info.pk -pl com.pl net.pl org.pl @@ -5043,53 +3106,6 @@ tourism.pl travel.pl turystyka.pl gov.pl -ap.gov.pl -ic.gov.pl -is.gov.pl -us.gov.pl -kmpsp.gov.pl -kppsp.gov.pl -kwpsp.gov.pl -psp.gov.pl -wskr.gov.pl -kwp.gov.pl -mw.gov.pl -ug.gov.pl -um.gov.pl -umig.gov.pl -ugim.gov.pl -upow.gov.pl -uw.gov.pl -starostwo.gov.pl -pa.gov.pl -po.gov.pl -psse.gov.pl -pup.gov.pl -rzgw.gov.pl -sa.gov.pl -so.gov.pl -sr.gov.pl -wsa.gov.pl -sko.gov.pl -uzs.gov.pl -wiih.gov.pl -winb.gov.pl -pinb.gov.pl -wios.gov.pl -witd.gov.pl -wzmiuw.gov.pl -piw.gov.pl -wiw.gov.pl -griw.gov.pl -wif.gov.pl -oum.gov.pl -sdn.gov.pl -zp.gov.pl -uppo.gov.pl -mup.gov.pl -wuoz.gov.pl -konsulat.gov.pl -oirm.gov.pl augustow.pl babia-gora.pl bedzin.pl @@ -5209,15 +3225,11 @@ zagan.pl zarow.pl zgora.pl zgorzelec.pl -pm -pn gov.pn co.pn org.pn edu.pn net.pn -post -pr com.pr net.pr org.pr @@ -5231,7 +3243,6 @@ name.pr est.pr prof.pr ac.pr -pro aaa.pro aca.pro acct.pro @@ -5243,7 +3254,6 @@ jur.pro law.pro med.pro recht.pro -ps edu.ps gov.ps sec.ps @@ -5251,7 +3261,6 @@ plo.ps com.ps org.ps net.ps -pt net.pt gov.pt org.pt @@ -5260,14 +3269,12 @@ int.pt publ.pt com.pt nome.pt -pw co.pw ne.pw or.pw ed.pw go.pw belau.pw -py com.py coop.py edu.py @@ -5275,7 +3282,6 @@ gov.py mil.py net.py org.py -qa com.qa edu.qa gov.qa @@ -5284,11 +3290,9 @@ name.qa net.qa org.qa sch.qa -re asso.re com.re nom.re -ro arts.ro com.ro firm.ro @@ -5300,21 +3304,18 @@ rec.ro store.ro tm.ro www.ro -rs ac.rs co.rs edu.rs gov.rs in.rs org.rs -ru ac.ru edu.ru gov.ru int.ru mil.ru test.ru -rw gov.rw net.rw edu.rw @@ -5324,7 +3325,6 @@ co.rw int.rw mil.rw gouv.rw -sa com.sa net.sa org.sa @@ -5333,19 +3333,16 @@ med.sa pub.sa edu.sa sch.sa -sb com.sb edu.sb gov.sb net.sb org.sb -sc com.sc gov.sc net.sc org.sc edu.sc -sd com.sd net.sd org.sd @@ -5354,7 +3351,6 @@ med.sd tv.sd gov.sd info.sd -se a.se ac.se b.se @@ -5394,30 +3390,22 @@ w.se x.se y.se z.se -sg com.sg net.sg org.sg gov.sg edu.sg per.sg -sh com.sh net.sh gov.sh org.sh mil.sh -si -sj -sk -sl com.sl net.sl edu.sl gov.sl org.sl -sm -sn art.sn com.sn edu.sn @@ -5425,12 +3413,9 @@ gouv.sn org.sn perso.sn univ.sn -so com.so net.so org.so -sr -st co.st com.st consulado.st @@ -5443,32 +3428,21 @@ org.st principe.st saotome.st store.st -su -sv com.sv edu.sv gob.sv org.sv red.sv -sx gov.sx -sy edu.sy gov.sy net.sy mil.sy com.sy org.sy -sz co.sz ac.sz org.sz -tc -td -tel -tf -tg -th ac.th co.th go.th @@ -5476,7 +3450,6 @@ in.th mi.th net.th or.th -tj ac.tj biz.tj co.tj @@ -5492,10 +3465,7 @@ nic.tj org.tj test.tj web.tj -tk -tl gov.tl -tm com.tm co.tm org.tm @@ -5504,7 +3474,6 @@ nom.tm gov.tm mil.tm edu.tm -tn com.tn ens.tn fin.tn @@ -5525,14 +3494,12 @@ mincom.tn agrinet.tn defense.tn turen.tn -to com.to gov.to net.to org.to edu.to mil.to -tr com.tr info.tr biz.tr @@ -5554,8 +3521,6 @@ k12.tr edu.tr kep.tr nc.tr -gov.nc.tr -tt co.tt com.tt org.tt @@ -5573,8 +3538,6 @@ aero.tt name.tt gov.tt edu.tt -tv -tw edu.tw gov.tw mil.tw @@ -5588,7 +3551,6 @@ club.tw 網路.tw 組織.tw 商業.tw -tz ac.tz co.tz go.tz @@ -5601,7 +3563,6 @@ ne.tz or.tz sc.tz tv.tz -ua com.ua edu.ua gov.ua @@ -5678,7 +3639,6 @@ zhitomir.ua zhytomyr.ua zp.ua zt.ua -ug co.ug or.ug ac.ug @@ -5687,7 +3647,6 @@ go.ug ne.ug com.ug org.ug -uk ac.uk co.uk gov.uk @@ -5698,7 +3657,6 @@ nhs.uk org.uk plc.uk police.uk -sus dni.us fed.us isa.us @@ -5759,197 +3717,22 @@ wa.us wi.us wv.us wy.us -k12.ak.us -k12.al.us -k12.ar.us -k12.as.us -k12.az.us -k12.ca.us -k12.co.us -k12.ct.us -k12.dc.us -k12.de.us -k12.fl.us -k12.ga.us -k12.gu.us -k12.ia.us -k12.id.us -k12.il.us -k12.in.us -k12.ks.us -k12.ky.us -k12.la.us -k12.ma.us -k12.md.us -k12.me.us -k12.mi.us -k12.mn.us -k12.mo.us -k12.ms.us -k12.mt.us -k12.nc.us -k12.ne.us -k12.nh.us -k12.nj.us -k12.nm.us -k12.nv.us -k12.ny.us -k12.oh.us -k12.ok.us -k12.or.us -k12.pa.us -k12.pr.us -k12.ri.us -k12.sc.us -k12.tn.us -k12.tx.us -k12.ut.us -k12.vi.us -k12.vt.us -k12.va.us -k12.wa.us -k12.wi.us -k12.wy.us -cc.ak.us -cc.al.us -cc.ar.us -cc.as.us -cc.az.us -cc.ca.us -cc.co.us -cc.ct.us -cc.dc.us -cc.de.us -cc.fl.us -cc.ga.us -cc.gu.us -cc.hi.us -cc.ia.us -cc.id.us -cc.il.us -cc.in.us -cc.ks.us -cc.ky.us -cc.la.us -cc.ma.us -cc.md.us -cc.me.us -cc.mi.us -cc.mn.us -cc.mo.us -cc.ms.us -cc.mt.us -cc.nc.us -cc.nd.us -cc.ne.us -cc.nh.us -cc.nj.us -cc.nm.us -cc.nv.us -cc.ny.us -cc.oh.us -cc.ok.us -cc.or.us -cc.pa.us -cc.pr.us -cc.ri.us -cc.sc.us -cc.sd.us -cc.tn.us -cc.tx.us -cc.ut.us -cc.vi.us -cc.vt.us -cc.va.us -cc.wa.us -cc.wi.us -cc.wv.us -cc.wy.us -lib.ak.us -lib.al.us -lib.ar.us -lib.as.us -lib.az.us -lib.ca.us -lib.co.us -lib.ct.us -lib.dc.us -lib.fl.us -lib.ga.us -lib.gu.us -lib.hi.us -lib.ia.us -lib.id.us -lib.il.us -lib.in.us -lib.ks.us -lib.ky.us -lib.la.us -lib.ma.us -lib.md.us -lib.me.us -lib.mi.us -lib.mn.us -lib.mo.us -lib.ms.us -lib.mt.us -lib.nc.us -lib.nd.us -lib.ne.us -lib.nh.us -lib.nj.us -lib.nm.us -lib.nv.us -lib.ny.us -lib.oh.us -lib.ok.us -lib.or.us -lib.pa.us -lib.pr.us -lib.ri.us -lib.sc.us -lib.sd.us -lib.tn.us -lib.tx.us -lib.ut.us -lib.vi.us -lib.vt.us -lib.va.us -lib.wa.us -lib.wi.us -lib.wy.us -pvt.k12.ma.us -chtr.k12.ma.us -paroch.k12.ma.us -ann-arbor.mi.us -cog.mi.us -dst.mi.us -eaton.mi.us -gen.mi.us -mus.mi.us -tec.mi.us -washtenaw.mi.us -uy com.uy edu.uy gub.uy mil.uy net.uy org.uy -uz co.uz com.uz net.uz org.uz -va -vc com.vc net.vc org.vc gov.vc mil.vc edu.vc -ve arts.ve co.ve com.ve @@ -5967,14 +3750,11 @@ rec.ve store.ve tec.ve web.ve -vg -vi co.vi com.vi k12.vi net.vi org.vi -vn com.vn net.vn org.vn @@ -5987,104 +3767,35 @@ info.vn name.vn pro.vn health.vn -vu com.vu edu.vu net.vu org.vu -wf -ws com.ws net.ws org.ws gov.ws edu.ws -yt -امارات -հայ -বাংলা -бг -бел -中国 -中國 -الجزائر -مصر -ею -გე -ελ -香港 公司.香港 教育.香港 政府.香港 個人.香港 網絡.香港 組織.香港 -ಭಾರತ -ଭାରତ -ভাৰত -भारतम् -भारोत -ڀارت -ഭാരതം -भारत -بارت -بھارت -భారత్ -ભારત -ਭਾਰਤ -ভারত -இந்தியா -ایران -ايران -عراق -الاردن -한국 -қаз -ලංකා -இலங்கை -المغرب -мкд -мон -澳門 -澳门 -مليسيا -عمان -پاکستان -پاكستان -فلسطين -срб пр.срб орг.срб обр.срб од.срб упр.срб ак.срб -рф -قطر -السعودية -السعودیة -السعودیۃ -السعوديه -سودان -新加坡 -சிங்கப்பூர் -سورية -سوريا -ไทย ศึกษา.ไทย ธุรกิจ.ไทย รัฐบาล.ไทย ทหาร.ไทย เน็ต.ไทย องค์กร.ไทย -تونس -台灣 -台湾 -臺灣 -укр -اليمن -xxx -yac.za +*.ye +ac.za agric.za alt.za co.za @@ -6101,7 +3812,6 @@ org.za school.za tm.za web.za -zm ac.zm biz.zm co.zm @@ -6113,1303 +3823,21 @@ mil.zm net.zm org.zm sch.zm -zw ac.zw co.zw gov.zw mil.zw org.zw -aaa -aarp -abarth -abb -abbott -abbvie -abc -able -abogado -abudhabi -academy -accenture -accountant -accountants -aco -actor -adac -ads -adult -aeg -aetna -afamilycompany -afl -africa -agakhan -agency -aig -aigo -airbus -airforce -airtel -akdn -alfaromeo -alibaba -alipay -allfinanz -allstate -ally -alsace -alstom -americanexpress -americanfamily -amex -amfam -amica -amsterdam -analytics -android -anquan -anz -aol -apartments -app -apple -aquarelle -arab -aramco -archi -army -art -arte -asda -associates -athleta -attorney -auction -audi -audible -audio -auspost -author -auto -autos -avianca -aws -axa -azure -baby -baidu -banamex -bananarepublic -band -bank -bar -barcelona -barclaycard -barclays -barefoot -bargains -baseball -basketball -bauhaus -bayern -bbc -bbt -bbva -bcg -bcn -beats -beauty -beer -bentley -berlin -best -bestbuy -bet -bharti -bible -bid -bike -bing -bingo -bio -black -blackfriday -blockbuster -blog -bloomberg -blue -bms -bmw -bnl -bnpparibas -boats -boehringer -bofa -bom -bond -boo -book -booking -bosch -bostik -boston -bot -boutique -box -bradesco -bridgestone -broadway -broker -brother -brussels -budapest -bugatti -build -builders -business -buy -buzz -bzh -cab -cafe -cal -call -calvinklein -cam -camera -camp -cancerresearch -canon -capetown -capital -capitalone -car -caravan -cards -care -career -careers -cars -cartier -casa -case -caseih -cash -casino -catering -catholic -cba -cbn -cbre -cbs -ceb -center -ceo -cern -cfa -cfd -chanel -channel -charity -chase -chat -cheap -chintai -christmas -chrome -chrysler -church -cipriani -circle -cisco -citadel -citi -citic -city -cityeats -claims -cleaning -click -clinic -clinique -clothing -cloud -club -clubmed -coach -codes -coffee -college -cologne -comcast -commbank -community -company -compare -computer -comsec -condos -construction -consulting -contact -contractors -cooking -cookingchannel -cool -corsica -country -coupon -coupons -courses -credit -creditcard -creditunion -cricket -crown -crs -cruise -cruises -csc -cuisinella -cymru -cyou -dabur -dad -dance -data -date -dating -datsun -day -dclk -dds -deal -dealer -deals -degree -delivery -dell -deloitte -delta -democrat -dental -dentist -desi -design -dev -dhl -diamonds -diet -digital -direct -directory -discount -discover -dish -diy -dnp -docs -doctor -dodge -dog -doha -domains -dot -download -drive -dtv -dubai -duck -dunlop -duns -dupont -durban -dvag -dvr -earth -eat -eco -edeka -education -email -emerck -energy -engineer -engineering -enterprises -epson -equipment -ericsson -erni -esq -estate -esurance -etisalat -eurovision -eus -events -everbank -exchange -expert -exposed -express -extraspace -fage -fail -fairwinds -faith -family -fan -fans -farm -farmers -fashion -fast -fedex -feedback -ferrari -ferrero -fiat -fidelity -fido -film -final -finance -financial -fire -firestone -firmdale -fish -fishing -fit -fitness -flickr -flights -flir -florist -flowers -fly -foo -food -foodnetwork -football -ford -forex -forsale -forum -foundation -fox -free -fresenius -frl -frogans -frontdoor -frontier -ftr -fujitsu -fujixerox -fun -fund -furniture -futbol -fyi -gal -gallery -gallo -gallup -game -games -gap -garden -gbiz -gdn -gea -gent -genting -george -ggee -gift -gifts -gives -giving -glade -glass -gle -global -globo -gmail -gmbh -gmo -gmx -godaddy -gold -goldpoint -golf -goo -goodyear -goog -google -gop -got -grainger -graphics -gratis -green -gripe -grocery -group -guardian -gucci -guge -guide -guitars -guru -hair -hamburg -hangout -haus -hbo -hdfc -hdfcbank -health -healthcare -help -helsinki -here -hermes -hgtv -hiphop -hisamitsu -hitachi -hiv -hkt -hockey -holdings -holiday -homedepot -homegoods -homes -homesense -honda -honeywell -horse -hospital -host -hosting -hot -hoteles -hotels -hotmail -house -how -hsbc -hughes -hyatt -hyundai -ibm -icbc -ice -icu -ieee -ifm -ikano -imamat -imdb -immo -immobilien -inc -industries -infiniti -ing -ink -institute -insurance -insure -intel -international -intuit -investments -ipiranga -irish -iselect -ismaili -ist -istanbul -itau -itv -iveco -jaguar -java -jcb -jcp -jeep -jetzt -jewelry -jio -jll -jmp -jnj -joburg -jot -joy -jpmorgan -jprs -juegos -juniper -kaufen -kddi -kerryhotels -kerrylogistics -kerryproperties -kfh -kia -kim -kinder -kindle -kitchen -kiwi -koeln -komatsu -kosher -kpmg -kpn -krd -kred -kuokgroup -kyoto -lacaixa -ladbrokes -lamborghini -lamer -lancaster -lancia -lancome -land -landrover -lanxess -lasalle -lat -latino -latrobe -law -lawyer -lds -lease -leclerc -lefrak -legal -lego -lexus -lgbt -liaison -lidl -life -lifeinsurance -lifestyle -lighting -like -lilly -limited -limo -lincoln -linde -link -lipsy -live -living -lixil -llc -loan -loans -locker -locus -loft -lol -london -lotte -lotto -love -lpl -lplfinancial -ltd -ltda -lundbeck -lupin -luxe -luxury -macys -madrid -maif -maison -makeup -man -management -mango -map -market -marketing -markets -marriott -marshalls -maserati -mattel -mba -mckinsey -med -media -meet -melbourne -meme -memorial -men -menu -merckmsd -metlife -miami -microsoft -mini -mint -mit -mitsubishi -mlb -mls -mma -mobile -mobily -moda -moe -moi -mom -monash -money -monster -mopar -mormon -mortgage -moscow -moto -motorcycles -mov -movie -movistar -msd -mtn -mtr -mutual -nab -nadex -nagoya -nationwide -natura -navy -nba -nec -netbank -netflix -network -neustar -new -newholland -news -next -nextdirect -nexus -nfl -ngo -nhk -nico -nike -nikon -ninja -nissan -nissay -nokia -northwesternmutual -norton -now -nowruz -nowtv -nra -nrw -ntt -nyc -obi -observer -off -office -okinawa -olayan -olayangroup -oldnavy -ollo -omega -one -ong -onl -online -onyourside -ooo -open -oracle -orange -organic -origins -osaka -otsuka -ott -ovh -page -panasonic -paris -pars -partners -parts -party -passagens -pay -pccw -pet -pfizer -pharmacy -phd -philips -phone -photo -photography -photos -physio -piaget -pics -pictet -pictures -pid -pin -ping -pink -pioneer -pizza -place -play -playstation -plumbing -plus -pnc -pohl -poker -politie -porn -pramerica -praxi -press -prime -prod -productions -prof -progressive -promo -properties -property -protection -pru -prudential -pub -pwc -qpon -quebec -quest -qvc -racing -radio -raid -read -realestate -realtor -realty -recipes -red -redstone -redumbrella -rehab -reise -reisen -reit -reliance -ren -rent -rentals -repair -report -republican -rest -restaurant -review -reviews -rexroth -rich -richardli -ricoh -rightathome -ril -rio -rip -rmit -rocher -rocks -rodeo -rogers -room -rsvp -rugby -ruhr -run -rwe -ryukyu -saarland -safe -safety -sakura -sale -salon -samsclub -samsung -sandvik -sandvikcoromant -sanofi -sap -sarl -sas -save -saxo -sbi -sbs -sca -scb -schaeffler -schmidt -scholarships -school -schule -schwarz -science -scjohnson -scor -scot -search -seat -secure -security -seek -select -sener -services -ses -seven -sew -sex -sexy -sfr -shangrila -sharp -shaw -shell -shia -shiksha -shoes -shop -shopping -shouji -show -showtime -shriram -silk -sina -singles -site -ski -skin -sky -skype -sling -smart -smile -sncf -soccer -social -softbank -software -sohu -solar -solutions -song -sony -soy -space -sport -spot -spreadbetting -srl -srt -stada -staples -star -starhub -statebank -statefarm -stc -stcgroup -stockholm -storage -store -stream -studio -study -style -sucks -supplies -supply -support -surf -surgery -suzuki -swatch -swiftcover -swiss -sydney -symantec -systems -tab -taipei -talk -taobao -target -tatamotors -tatar -tattoo -tax -taxi -tci -tdk -team -tech -technology -telefonica -temasek -tennis -teva -thd -theater -theatre -tiaa -tickets -tienda -tiffany -tips -tires -tirol -tjmaxx -tjx -tkmaxx -tmall -today -tokyo -tools -top -toray -toshiba -total -tours -town -toyota -toys -trade -trading -training -travel -travelchannel -travelers -travelersinsurance -trust -trv -tube -tui -tunes -tushu -tvs -ubank -ubs -uconnect -unicom -university -uno -uol -ups -vacations -vana -vanguard -vegas -ventures -verisign -versicherung -vet -viajes -video -vig -viking -villas -vin -vip -virgin -visa -vision -vistaprint -viva -vivo -vlaanderen -vodka -volkswagen -volvo -vote -voting -voto -voyage -vuelos -wales -walmart -walter -wang -wanggou -warman -watch -watches -weather -weatherchannel -webcam -weber -website -wed -wedding -weibo -weir -whoswho -wien -wiki -williamhill -win -windows -wine -winners -wme -wolterskluwer -woodside -work -works -world -wow -wtc -wtf -xbox -xerox -xfinity -xihuan -xin -कॉम -セール -佛山 -慈善 -集团 -在线 -大众汽车 -点看 -คอม -八卦 -موقع -公益 -公司 -香格里拉 -网站 -移动 -我爱你 -москва -католик -онлайн -сайт -联通 -קום -时尚 -微博 -淡马锡 -ファッション -орг -नेट -ストア -삼성 -商标 -商店 -商城 -дети -ポイント -新闻 -工行 -家電 -كوم -中文网 -中信 -娱乐 -谷歌 -電訊盈科 -购物 -クラウド -通販 -网店 -संगठन -餐厅 -网络 -ком -诺基亚 -食品 -飞利浦 -手表 -手机 -ارامكو -العليان -اتصالات -بازار -موبايلي -ابوظبي -كاثوليك -همراه -닷컴 -政府 -شبكة -بيتك -عرب -机构 -组织机构 -健康 -招聘 -рус -珠宝 -大拿 -みんな -グーグル -世界 -書籍 -网址 -닷넷 -コム -天主教 -游戏 -vermögensberater -vermögensberatung -企业 -信息 -嘉里大酒店 -嘉里 -广东 -政务 -xyz -yachts -yahoo -yamaxun -yandex -yodobashi -yoga -yokohama -you -youtube -yun -zappos -zara -zero -zip -zone -zuerich cc.ua inf.ua ltd.ua beep.pl -caalwaysdata.net +alwaysdata.net cloudfront.net -cccus-east-1.amazonaws.com -cn-north-1.eb.amazonaws.com.cn -cn-northwest-1.eb.amazonaws.com.cn elasticbeanstalk.com -ap-northeast-1.elasticbeanstalk.com -ap-northeast-2.elasticbeanstalk.com -ap-northeast-3.elasticbeanstalk.com -ap-south-1.elasticbeanstalk.com -ap-southeast-1.elasticbeanstalk.com -ap-southeast-2.elasticbeanstalk.com -ca-central-1.elasticbeanstalk.com -eu-central-1.elasticbeanstalk.com -eu-west-1.elasticbeanstalk.com -eu-west-2.elasticbeanstalk.com -eu-west-3.elasticbeanstalk.com -sa-east-1.elasticbeanstalk.com -us-east-1.elasticbeanstalk.com -us-east-2.elasticbeanstalk.com -us-gov-west-1.elasticbeanstalk.com -us-west-1.elasticbeanstalk.com -us-west-2.elasticbeanstalk.com -ees3.amazonaws.com -s3-ap-northeast-1.amazonaws.com -s3-ap-northeast-2.amazonaws.com -s3-ap-south-1.amazonaws.com -s3-ap-southeast-1.amazonaws.com -s3-ap-southeast-2.amazonaws.com -s3-ca-central-1.amazonaws.com -s3-eu-central-1.amazonaws.com -s3-eu-west-1.amazonaws.com -s3-eu-west-2.amazonaws.com -s3-eu-west-3.amazonaws.com -s3-external-1.amazonaws.com -s3-fips-us-gov-west-1.amazonaws.com -s3-sa-east-1.amazonaws.com -s3-us-gov-west-1.amazonaws.com -s3-us-east-2.amazonaws.com -s3-us-west-1.amazonaws.com -s3-us-west-2.amazonaws.com -s3.ap-northeast-2.amazonaws.com -s3.ap-south-1.amazonaws.com -s3.cn-north-1.amazonaws.com.cn -s3.ca-central-1.amazonaws.com -s3.eu-central-1.amazonaws.com -s3.eu-west-2.amazonaws.com -s3.eu-west-3.amazonaws.com -s3.us-east-2.amazonaws.com -s3.dualstack.ap-northeast-1.amazonaws.com -s3.dualstack.ap-northeast-2.amazonaws.com -s3.dualstack.ap-south-1.amazonaws.com -s3.dualstack.ap-southeast-1.amazonaws.com -s3.dualstack.ap-southeast-2.amazonaws.com -s3.dualstack.ca-central-1.amazonaws.com -s3.dualstack.eu-central-1.amazonaws.com -s3.dualstack.eu-west-1.amazonaws.com -s3.dualstack.eu-west-2.amazonaws.com -s3.dualstack.eu-west-3.amazonaws.com -s3.dualstack.sa-east-1.amazonaws.com -s3.dualstack.us-east-1.amazonaws.com -s3.dualstack.us-east-2.amazonaws.com -s3-website-us-east-1.amazonaws.com -s3-website-us-west-1.amazonaws.com -s3-website-us-west-2.amazonaws.com -s3-website-ap-northeast-1.amazonaws.com -s3-website-ap-southeast-1.amazonaws.com -s3-website-ap-southeast-2.amazonaws.com -s3-website-eu-west-1.amazonaws.com -s3-website-sa-east-1.amazonaws.com -s3-website.ap-northeast-2.amazonaws.com -s3-website.ap-south-1.amazonaws.com -s3-website.ca-central-1.amazonaws.com -s3-website.eu-central-1.amazonaws.com -s3-website.eu-west-2.amazonaws.com -s3-website.eu-west-3.amazonaws.com -s3-website.us-east-2.amazonaws.com t3l3p0rt.net -tele.amune.org apigee.io on-aptible.com -user.party.eus pimienta.org poivron.org potager.org @@ -7419,7 +3847,7 @@ go-vip.co go-vip.net wpcomstaging.com myfritz.net -aabackplaneapp.io +backplaneapp.io betainabox.com bnr.la blackbaudcdn.net @@ -7432,9 +3860,6 @@ square7.de bplaced.net square7.net browsersafetymark.io -uk0.bigv.io -dh.bytemark.co.uk -vm.bytemark.co.uk mycd.eu ae.org ar.com @@ -7485,12 +3910,8 @@ cloudcontrolled.com cloudcontrolapp.com workers.dev co.ca -oco.cz -c.cdn77.org +co.cz cdn77-ssl.net -r.cdn77.net -rsc.cdn77.org -ssl.origin.cdn77-secure.org cloudns.asia cloudns.biz cloudns.club @@ -7508,7 +3929,6 @@ co.nl co.no webhosting.be hosting-cluster.nl -dyn.cosidns.de dynamisches-dns.de dnsupdater.de internet-dns.de @@ -7518,11 +3938,10 @@ feste-ip.net knx-server.net static-access.net realm.cz -ccupcake.is +cupcake.is cyon.link cyon.site daplie.me -localhost.daplie.me dattolocal.com dattorelay.com dattoweb.com @@ -7534,7 +3953,7 @@ co.dk firm.dk reg.dk store.dk -dbdebian.net +debian.net dedyn.io dnshome.de online.th @@ -7611,8 +4030,6 @@ for-more.biz for-our.info for-some.biz for-the.biz -forgot.her.name -forgot.his.name from-ak.com from-al.com from-ar.com @@ -7671,7 +4088,6 @@ game-host.org game-server.cc getmyip.com gets-it.net -go.dyndns.org gotdns.com gotdns.org groks-the.info @@ -7680,7 +4096,6 @@ ham-radio-op.net here-for-more.info hobby-site.com hobby-site.org -home.dyndns.org homedns.org homeftp.net homeftp.org @@ -7827,17 +4242,13 @@ webhop.org worse-than.tv writesthisblog.com ddnss.de -dyn.ddnss.de -dyndns.ddnss.de dyndns1.de dyn-ip24.de home-webserver.de -dyn.home-webserver.de myhome-server.de ddnss.org definima.net definima.io -bci.dnstrace.pro ddnsfree.com ddnsgeek.com giize.com @@ -7859,77 +4270,11 @@ dynv6.net e4.cz mytuleap.com enonic.io -customer.enonic.io eu.org -al.eu.org -asso.eu.org -at.eu.org -au.eu.org -be.eu.org -bg.eu.org -ca.eu.org -cd.eu.org -ch.eu.org -cn.eu.org -cy.eu.org -cz.eu.org -de.eu.org -dk.eu.org -edu.eu.org -ee.eu.org -es.eu.org -fi.eu.org -fr.eu.org -gr.eu.org -hr.eu.org -hu.eu.org -ie.eu.org -il.eu.org -in.eu.org -int.eu.org -is.eu.org -it.eu.org -jp.eu.org -kr.eu.org -lt.eu.org -lu.eu.org -lv.eu.org -mc.eu.org -me.eu.org -mk.eu.org -mt.eu.org -my.eu.org -net.eu.org -ng.eu.org -nl.eu.org -no.eu.org -nz.eu.org -paris.eu.org -pl.eu.org -pt.eu.org -q-a.eu.org -ro.eu.org -ru.eu.org -se.eu.org -si.eu.org -sk.eu.org -tr.eu.org -uk.eu.org -us.eu.org -eu-1.evennode.com -eu-2.evennode.com -eu-3.evennode.com -eu-4.evennode.com -us-1.evennode.com -us-2.evennode.com -us-3.evennode.com -us-4.evennode.com twmail.cc twmail.net twmail.org -mymailer.com.tw url.tw -apps.fbsbx.com ru.net adygeya.ru bashkiria.ru @@ -8005,22 +4350,11 @@ vologda.su channelsdvr.net fastly-terrarium.com fastlylb.net -map.fastlylb.net -freetls.fastly.net -map.fastly.net -a.prod.fastly.net -global.prod.fastly.net -a.ssl.fastly.net -b.ssl.fastly.net -global.ssl.fastly.net fastpanel.direct fastvps-server.com fhapp.xyz fedorainfracloud.org fedorapeople.org -cloud.fedoraproject.org -app.os.fedoraproject.org -app.os.stg.fedoraproject.org mydobiss.com filegear.me filegear-au.me @@ -8039,21 +4373,17 @@ fbxos.fr freebox-os.fr freeboxos.fr freedesktop.org -feifuturehosting.at +futurehosting.at futuremailing.at -eksservice.gov.uk github.io githubusercontent.com gitlab.io cloudapps.digital -london.cloudapps.digital -homeoffice.gov.uk ro.im shop.ro goip.de run.app -a.run.app -0appspot.com +appspot.com blogspot.ae blogspot.al blogspot.am @@ -8065,27 +4395,7 @@ blogspot.ca blogspot.cf blogspot.ch blogspot.cl -blogspot.co.at -blogspot.co.id -blogspot.co.il -blogspot.co.ke -blogspot.co.nz -blogspot.co.uk -blogspot.co.za blogspot.com -blogspot.com.ar -blogspot.com.au -blogspot.com.br -blogspot.com.by -blogspot.com.co -blogspot.com.cy -blogspot.com.ee -blogspot.com.eg -blogspot.com.es -blogspot.com.mt -blogspot.com.ng -blogspot.com.tr -blogspot.com.uy blogspot.cv blogspot.cz blogspot.de @@ -8163,39 +4473,12 @@ in-vpn.org biz.at info.at info.cx -ac.leg.br -al.leg.br -am.leg.br -ap.leg.br -ba.leg.br -ce.leg.br -df.leg.br -es.leg.br -go.leg.br -ma.leg.br -mg.leg.br -ms.leg.br -mt.leg.br -pa.leg.br -pb.leg.br -pe.leg.br -pi.leg.br -pr.leg.br -rj.leg.br -rn.leg.br -ro.leg.br -rr.leg.br -rs.leg.br -sc.leg.br -se.leg.br -sp.leg.br -to.leg.br pixolino.com ipifony.net mein-iserv.de test-iserv.de myjino.ru -hlsvtcjs.org +js.org keymachine.de knightpoint.systems co.krd @@ -8213,7 +4496,6 @@ co.financial co.network co.place co.technology -app.lmpm.com linkitools.space linkyard.cloud linkyard-cloud.ch @@ -8225,12 +4507,7 @@ lublin.pl poniatowa.pl swidnik.pl uklugs.org -glug.org.uk -lug.org.uk -lugs.org.uk barsy.bg -barsy.co.uk -barsyonline.co.uk barsycenter.com barsyonline.com barsy.club @@ -8251,17 +4528,11 @@ barsy.shop barsy.site barsy.support barsy.uk -mmayfirst.info +mayfirst.info mayfirst.org -hb.cldmail.ru miniserver.com memset.net -cloud.metacentrum.cz -custom.metacentrum.cz -flt.cloud.muni.cz -usr.cloud.muni.cz meteorapp.com -eu.meteorapp.com co.pl azurecontainer.io azurewebsites.net @@ -8272,12 +4543,10 @@ bmoattachments.org net.ru org.ru pp.ru -ui.nabu.casa bitballoon.com netlify.com 4u.com ngrok.io -nh-serv.co.uk nfshost.com dnsking.ch mypi.co @@ -8343,7 +4612,6 @@ net-freaks.com nflfan.org nhlfan.net no-ip.ca -no-ip.co.uk no-ip.net noip.us onthewifi.com @@ -8391,7 +4659,6 @@ servequake.com sytes.net webhop.me zapto.org -stage.nodeart.io nodum.co nodum.io pcloud.host @@ -8465,7 +4732,6 @@ pantheonsite.io gotpantheon.com mypep.link on-web.fr -ppxen.prgmr.com priv.at protonet.io chirurgiens-dentistes-en-france.fr @@ -8476,19 +4742,16 @@ qa2.com dev-myqnapcloud.com alpha-myqnapcloud.com myqnapcloud.com -qvapor.cloud +vapor.cloud vaporcloud.io rackmaze.com rackmaze.net -ooreadthedocs.io +readthedocs.io rhcloud.com resindevice.io -devices.resinstaging.io hzc.io wellbeingzone.eu ptplus.fit -wellbeingzone.co.uk -git-pages.rit.edu sandcats.io logoip.de logoip.com @@ -8504,7 +4767,7 @@ firewall-gateway.net my-firewall.org myfirewall.org spdns.org -ssbiz.ua +biz.ua co.ua pp.ua shiftedit.io @@ -8516,15 +4779,8 @@ sinaapp.com vipsinaapp.com siteleaf.net bounty-full.com -alpha.bounty-full.com -beta.bounty-full.com static.land -dev.static.land -sites.static.land -apps.lair.io -sspacekit.io -customer.speedpartner.de -api.stdlib.com +spacekit.io storj.farm utwente.io temp-dns.com @@ -8553,11 +4809,6 @@ med.pl sopot.pl telebit.app telebit.io -tgwiddle.co.uk -cust.dev.thingdust.io -cust.disrec.thingdust.io -cust.prod.thingdust.io -cust.testing.thingdust.io bloxcms.com townnews-staging.com 12hp.at @@ -8579,7 +4830,7 @@ clan.rip lima-city.rocks webspace.rocks lima.zone -ttttuxfamily.org +tuxfamily.org dd-dns.de diskstation.eu diskstation.org @@ -8594,13 +4845,12 @@ syno-ds.de synology-diskstation.de synology-ds.de uber.space -uhk.com +hk.com hk.org ltd.hk inc.hk virtualuser.de virtual-user.de -lib.de.us 2038.io router.management v-info.info @@ -8611,8 +4861,6 @@ remotewd.com wmflabs.org half.host xnbay.com -u2.xnbay.com -u2-local.xnbay.com cistron.nl demon.nl xs4all.space @@ -8631,6 +4879,5 @@ za.net za.org now.sh bss.design -site.builder.nu zone.id %% From a904a4af7a106b8a3494b264c67d9e8c8306ee4f Mon Sep 17 00:00:00 2001 From: Guillaume Tassery Date: Wed, 17 Apr 2019 19:43:46 +0700 Subject: [PATCH 051/709] Remove useless file --- dbms/src/Functions/gperf/f.cpp | 41028 --------------------- dbms/src/Functions/gperf/tldLookup.gperf | 1 - 2 files changed, 41029 deletions(-) delete mode 100644 dbms/src/Functions/gperf/f.cpp diff --git a/dbms/src/Functions/gperf/f.cpp b/dbms/src/Functions/gperf/f.cpp deleted file mode 100644 index f31ff34f8bf..00000000000 --- a/dbms/src/Functions/gperf/f.cpp +++ /dev/null @@ -1,41028 +0,0 @@ -/* C++ code produced by gperf version 3.1 */ -/* Command-line: gperf --output-file=./f.cpp tldLookup.gperf */ -/* Computed positions: -k'1-15,17,20,22,25,27' */ - -#if !((' ' == 32) && ('!' == 33) && ('"' == 34) && ('#' == 35) \ - && ('%' == 37) && ('&' == 38) && ('\'' == 39) && ('(' == 40) \ - && (')' == 41) && ('*' == 42) && ('+' == 43) && (',' == 44) \ - && ('-' == 45) && ('.' == 46) && ('/' == 47) && ('0' == 48) \ - && ('1' == 49) && ('2' == 50) && ('3' == 51) && ('4' == 52) \ - && ('5' == 53) && ('6' == 54) && ('7' == 55) && ('8' == 56) \ - && ('9' == 57) && (':' == 58) && (';' == 59) && ('<' == 60) \ - && ('=' == 61) && ('>' == 62) && ('?' == 63) && ('A' == 65) \ - && ('B' == 66) && ('C' == 67) && ('D' == 68) && ('E' == 69) \ - && ('F' == 70) && ('G' == 71) && ('H' == 72) && ('I' == 73) \ - && ('J' == 74) && ('K' == 75) && ('L' == 76) && ('M' == 77) \ - && ('N' == 78) && ('O' == 79) && ('P' == 80) && ('Q' == 81) \ - && ('R' == 82) && ('S' == 83) && ('T' == 84) && ('U' == 85) \ - && ('V' == 86) && ('W' == 87) && ('X' == 88) && ('Y' == 89) \ - && ('Z' == 90) && ('[' == 91) && ('\\' == 92) && (']' == 93) \ - && ('^' == 94) && ('_' == 95) && ('a' == 97) && ('b' == 98) \ - && ('c' == 99) && ('d' == 100) && ('e' == 101) && ('f' == 102) \ - && ('g' == 103) && ('h' == 104) && ('i' == 105) && ('j' == 106) \ - && ('k' == 107) && ('l' == 108) && ('m' == 109) && ('n' == 110) \ - && ('o' == 111) && ('p' == 112) && ('q' == 113) && ('r' == 114) \ - && ('s' == 115) && ('t' == 116) && ('u' == 117) && ('v' == 118) \ - && ('w' == 119) && ('x' == 120) && ('y' == 121) && ('z' == 122) \ - && ('{' == 123) && ('|' == 124) && ('}' == 125) && ('~' == 126)) -/* The character set is not based on ISO-646. */ -#error "gperf generated tables don't work with this execution character set. Please report a bug to ." -#endif - -#line 6 "tldLookup.gperf" - -namespace DB -{ -#include - -#define TOTAL_KEYWORDS 8626 -#define MIN_WORD_LENGTH 2 -#define MAX_WORD_LENGTH 41 -#define MIN_HASH_VALUE 6 -#define MAX_HASH_VALUE 263036 -/* maximum key range = 263031, duplicates = 0 */ - -class ltdLookup -{ -private: - static inline unsigned int hash (const char *str, size_t len); -public: - static const char *is_valid (const char *str, size_t len); -}; - -inline unsigned int -ltdLookup::hash (const char *str, size_t len) -{ - static const unsigned int asso_values[] = - { - 263037, 263037, 263037, 263037, 263037, 263037, 263037, 263037, 263037, 263037, - 263037, 263037, 263037, 263037, 263037, 263037, 263037, 263037, 263037, 263037, - 263037, 263037, 263037, 263037, 263037, 263037, 263037, 263037, 263037, 263037, - 263037, 263037, 263037, 0, 263037, 0, 263037, 263037, 263037, 263037, - 263037, 263037, 263037, 263037, 263037, 1075, 120, 620, 31291, 505, - 7650, 185, 0, 0, 0, 5, 0, 0, 0, 45, - 0, 263037, 0, 15, 745, 0, 5, 0, 0, 4950, - 80, 0, 0, 0, 0, 263037, 0, 263037, 0, 0, - 263037, 263037, 75, 5, 15, 40, 35, 90, 60, 85, - 80, 45, 263037, 263037, 263037, 263037, 263037, 40, 5435, 235, - 1240, 90, 37658, 2335, 6995, 645, 3770, 5140, 765, 1685, - 2910, 10, 4145, 2030, 185, 15, 5, 485, 865, 0, - 29726, 340, 16025, 26869, 6770, 3715, 62293, 64003, 160, 345, - 955, 30, 620, 55, 265, 65, 970, 22284, 2040, 31804, - 51623, 4700, 85666, 10295, 10, 15310, 75051, 20, 30074, 300, - 52823, 13320, 5222, 9765, 0, 15115, 670, 0, 40, 5, - 25, 5, 5, 10, 0, 25, 5, 0, 20, 0, - 30, 70, 25, 35, 0, 5, 0, 5, 20, 5, - 0, 5, 10, 65, 0, 0, 0, 0, 0, 0, - 5, 10, 0, 50, 0, 0, 5, 0, 0, 5, - 25, 0, 45, 5, 10, 0, 90, 0, 0, 0, - 5, 0, 20, 45, 0, 5, 10, 0, 0, 5, - 0, 0, 263037, 263037, 0, 20, 263037, 30, 5, 0, - 5, 5, 40, 0, 0, 5, 0, 15, 35, 5, - 0, 0, 45, 5, 20, 0, 5, 5, 5, 10, - 0, 0, 0, 263037, 263037, 263037, 263037, 263037, 0, 0, - 263037, 0, 10, 10, 10, 0, 40, 0, 263037, 0, - 0, 0, 263037, 263037, 263037, 263037, 263037, 263037, 263037, 263037, - 263037, 263037, 263037, 263037, 263037, 263037, 263037, 263037, 263037, 263037 - }; - unsigned int hval = len; - - switch (hval) - { - default: - hval += asso_values[static_cast(str[26])]; - /*FALLTHROUGH*/ - case 26: - case 25: - hval += asso_values[static_cast(str[24])]; - /*FALLTHROUGH*/ - case 24: - case 23: - case 22: - hval += asso_values[static_cast(str[21])]; - /*FALLTHROUGH*/ - case 21: - case 20: - hval += asso_values[static_cast(str[19])]; - /*FALLTHROUGH*/ - case 19: - case 18: - case 17: - hval += asso_values[static_cast(str[16])]; - /*FALLTHROUGH*/ - case 16: - case 15: - hval += asso_values[static_cast(str[14])]; - /*FALLTHROUGH*/ - case 14: - hval += asso_values[static_cast(str[13])]; - /*FALLTHROUGH*/ - case 13: - hval += asso_values[static_cast(str[12]+1)]; - /*FALLTHROUGH*/ - case 12: - hval += asso_values[static_cast(str[11])]; - /*FALLTHROUGH*/ - case 11: - hval += asso_values[static_cast(str[10])]; - /*FALLTHROUGH*/ - case 10: - hval += asso_values[static_cast(str[9]+1)]; - /*FALLTHROUGH*/ - case 9: - hval += asso_values[static_cast(str[8])]; - /*FALLTHROUGH*/ - case 8: - hval += asso_values[static_cast(str[7]+2)]; - /*FALLTHROUGH*/ - case 7: - hval += asso_values[static_cast(str[6]+4)]; - /*FALLTHROUGH*/ - case 6: - hval += asso_values[static_cast(str[5]+24)]; - /*FALLTHROUGH*/ - case 5: - hval += asso_values[static_cast(str[4])]; - /*FALLTHROUGH*/ - case 4: - hval += asso_values[static_cast(str[3]+14)]; - /*FALLTHROUGH*/ - case 3: - hval += asso_values[static_cast(str[2]+19)]; - /*FALLTHROUGH*/ - case 2: - hval += asso_values[static_cast(str[1])]; - /*FALLTHROUGH*/ - case 1: - hval += asso_values[static_cast(str[0]+34)]; - break; - } - return hval; -} - -const char * -ltdLookup::is_valid (const char *str, size_t len) -{ - static const char * const wordlist[] = - { - "", "", "", "", "", "", - "\347\275\221\347\273\234", - "", "", "", "", "", "", "", "", "", - "\347\275\221\345\272\227", - "", "", "", "", "", - "no", - "", "", "", - "\344\275\233\345\261\261", - "", "", - "\316\265\316\273", - "no.it", - "\330\271\330\261\330\250", - "aw", - "", "", "", - "\327\247\327\225\327\235", - "at", - "", "", "", "", - "ao", - "", "", - "at.it", - "", - "as", - "", "", - "ao.it", - "", - "na", - "", "", "", "", - "cw", - "", - "asda", - "na.it", - "\351\246\231\346\270\257", - "qa", - "", "", "", - "\345\271\277\344\270\234", - "co", - "", "", - "ct.it", - "\344\270\255\344\277\241", - "et", - "\330\250\330\247\330\261\330\252", - "", - "co.it", - "\331\205\330\265\330\261", - "\340\244\255\340\244\276\340\244\260\340\244\244", - "aaa", - "", - "cs.it", - "\347\275\221\347\253\231", - "\345\244\247\344\274\227\346\261\275\350\275\246", - "ntt", - "", - "co.at", - "\320\261\320\265\320\273", - "\340\246\255\340\246\276\340\247\260\340\246\244", - "", - "\340\244\250\340\245\207\340\244\237", - "co.ao", - "\345\267\245\350\241\214", - "", "", "", - "as.us", - "", - "ca", - "", "", - "codes", - "\325\260\325\241\325\265", - "ne", - "\320\264\320\265\321\202\320\270", - "\340\244\225\340\245\211\340\244\256", - "ca.it", - "\345\250\261\344\271\220", - "\340\246\255\340\246\276\340\246\260\340\246\244", - "", - "\350\257\272\345\237\272\344\272\232", - "ct.us", - "\320\272\320\276\320\274", - "", "", - "\320\272\320\260\321\202\320\276\320\273\320\270\320\272", - "co.us", - "\320\274\320\272\320\264", - "", "", "", - "\330\247\333\214\330\261\330\247\331\206", - "\341\203\222\341\203\224", - "ae", - "", - "\330\247\330\252\330\265\330\247\331\204\330\247\330\252", - "\330\250\330\247\330\262\330\247\330\261", - "", - "\330\247\331\205\330\247\330\261\330\247\330\252", - "\340\244\255\340\244\276\340\244\260\340\244\244\340\244\256\340\245\215", - "", "", "", - "\340\262\255\340\262\276\340\262\260\340\262\244", - "", - "\320\261\320\263", - "", - "\320\274\320\276\320\275", - "\320\276\320\275\320\273\320\260\320\271\320\275", - "", "", - "co.ua", - "", "", "", "", - "ca.us", - "\350\260\267\346\255\214", - "\340\254\255\340\254\276\340\254\260\340\254\244", - "", "", - "ne.us", - "", "", - "car", - "", - "ce.it", - "", - "ee", - "", "", - "\330\250\332\276\330\247\330\261\330\252", - "", - "\340\250\255\340\250\276\340\250\260\340\250\244", - "cat", - "", "", "", "", - "net", - "care", - "co.ae", - "", "", - "eat", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "\340\252\255\340\252\276\340\252\260\340\252\244", - "", "", - "nt.ro", - "", "", "", "", "", "", "", "", "", - "", "", "", - "nra", - "", "", "", "", "", "", "", "", "", - "\332\200\330\247\330\261\330\252", - "", "", "", - "ar", - "", "", "", "", "", "", "", - "ar.it", - "", "", - "com", - "name", - "co.rw", - "net.tm", - "", "", "", "", - "net.om", - "", "", "", "", - "net.to", - "cr", - "", "", - "co.rs", - "nom.tm", - "nc", - "", "", - "cr.it", - "net.so", - "", "", "", - "co.ir", - "", "", - "cam", - "arpa", - "", "", "", "", "", - "ar.us", - "net.am", - "ac", - "", "", "", "", "", "", "", "", - "\351\200\232\350\262\251", - "do", - "", "", "", "", "", - "art", - "", - "ac.at", - "", "", "", "", "", - "com.tm", - "cc", - "", "", - "nc.us", - "com.om", - "", - "aws", - "arte", - "", - "com.to", - "ec", - "", "", "", "", - "st", - "dad", - "", "", - "com.so", - "so", - "", "", - "cr.ua", - "\344\270\226\347\225\214", - "", "", "", - "so.it", - "\355\225\234\352\265\255", - "", "", "", - "ss.it", - "com.am", - "", "", "", "", "", "", "", "", "", - "net.th", - "", "", "", "", "", - "sa", - "dot", - "", "", - "net.sh", - "", "", "", - "sa.it", - "", "", "", "", - "cards", - "", - "de", - "", "", "", "", "", "", "", - "cc.ua", - "\345\201\245\345\272\267", - "", "", "", - "ac.ae", - "", "", - "sap", - "casa", - "", "", "", "", - "case", - "", - "n4t.co", - "", "", - "data", - "", "", "", "", - "date", - "", - "nat.tn", - "se", - "", "", "", - "\344\277\241\346\201\257", - "cy", - "", "", - "ny.us", - "", "", "", - "x.se", - "de.us", - "com.sh", - "", "", "", "", "", "", "", - "n.se", - "", "", - "name.mk", - "", "", - "co.st", - "", "", - "ees", - "", "", "", "", "", "", - "ac.rw", - "\320\276\320\264.\321\201\321\200\320\261", - "", "", - "a.se", - "", - "nom.ro", - "", "", - "\331\276\330\247\332\251\330\263\330\252\330\247\331\206", - "", - "net.tn", - "", "", - "army", - "ac.rs", - "", "", "", "", "", - "\320\260\320\272.\321\201\321\200\320\261", - "", "", - "cafe", - "ac.ir", - "\350\207\272\347\201\243", - "", "", - "c.se", - "", - "net.cm", - "", "", "", "", "", "", "", - "e.se", - "", - "net.co", - "", "", - "star", - "", - "stream", - "", "", "", "", - "com.ro", - "", "", "", "", - "nom.co", - "sr", - "", "", "", "", "", "", "", - "sr.it", - "", - "nu", - "", - "cars", - "co.ke", - "com.tn", - "", "", "", - "nu.it", - "", "", - "crs", - "", "", - "com.sn", - "", "", "", - "nt.au", - "", - "au", - "", - "audi", - "", - "com.cm", - "", "", "", "", - "net.sa", - "", "", "", - "audio", - "com.co", - "", "", "", - "ne.ke", - "", - "sc", - "nab", - "", - "stada", - "nym.sx", - "cu", - "sca", - "", "", - "nom.si", - "", "", "", - "dc.us", - "", - "eu", - "srt", - "", "", - "net.ai", - "", "", "", "", - "nym.sk", - "", "", "", "", - "art.sn", - "", "", "", "", - "nom.ai", - "", "", "", "", - "\350\201\224\351\200\232", - "", "", "", "", "", "", - "cab", - "", - "sc.us", - "com.sa", - "", "", "", "", "", "", "", "", - "co.kr", - "", "", "", - "erni", - "", "", "", "", "", "", "", "", - "sas", - "", - "es.kr", - "", "", "", "", "", - "com.ai", - "", "", "", "", "", - "bw", - "", - "desi", - "", "", - "bt", - "", "", - "ne.kr", - "", - "bo", - "ceb", - "", - "bt.it", - "", - "bs", - "", "", - "bo.it", - "", - "sy", - "", "", - "bs.it", - "", "", "", "", "", "", "", "", "", - "", "", - "ni", - "ses", - "", "", "", - "ba", - "\330\271\330\261\330\247\331\202", - "", "", "", "", "", - "d.se", - "ba.it", - "net.cn", - "zw", - "", "", "", - "natura", - "ai", - "", "", "", "", "", "", "", "", - "net.uk", - "", "", "", "", - "\345\234\250\347\272\277", - "", "", "", "", "", "", - "bot", - "safe", - "ac.ke", - "\344\270\255\345\234\213", - "ci", - "esq", - "s.se", - "ac.se", - "", - "name.na", - "", "", - "ci.it", - "", "", "", "", "", "", "", - "bar", - "", "", "", "", "", - "sony", - "", "", "", "", - "\320\265\321\216", - "", - "com.cn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "zt.ua", - "net.ci", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "nym.ro", - "\340\270\227\340\270\253\340\270\262\340\270\243.\340\271\204\340\270\227\340\270\242", - "", - "citi", - "", "", "", "", "", "", "", - "nl", - "bet", - "zara", - "co.ve", - "", "", "", "", "", "", - "su", - "", "", "", "", "", - "bom", - "", - "ac.kr", - "", - "al", - "", "", "", - "camera", - "", "", "", - "al.it", - "net.sl", - "br", - "", "", "", - "com.ci", - "", "", "", - "br.it", - "", "", - "eus", - "", "", "", - "cl", - "", "", "", "", "", "", "", - "cl.it", - "net.al", - "", "", - "city", - "co.il", - "", - "etne.no", - "", "", - "sa.au", - "", "", "", "", - "al.us", - "nom.al", - "", "", - "surf", - "", "", "", "", "", - "dodge", - "", "", "", "", "", "", "", "", "", - "", - "com.sl", - "", "", "", "", - "net.im", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "nom.im", - "", "", "", "", - "com.al", - "", "", "", - "co.gy", - "", "", "", "", "", "", "", - "\330\247\333\214\330\261\330\247\331\206.ir", - "", - "av.it", - "", "", "", "", "", "", "", "", "", - "ac.ru", - "", "", "", "", "", "", - "cv", - "", "", - "nv.us", - "", "", "", "", "", - "com.im", - "", "", "", "", "", "", - "csc", - "", - "sener", - "com.io", - "", "", "", "", "", - "si", - "", "", "", "", "", "", "", - "si.it", - "search", - "", "", "", "", "", - "by", - "", "", "", - "net.lk", - "", - "nec", - "", - "sc.ke", - "", "", "", "", "", - "\331\202\330\267\330\261", - "arna.no", - "", "", "", "", - "fo", - "", - "bofa", - "", "", "", "", "", "", - "\343\202\263\343\203\240", - "aure.no", - "xin", - "", - "cv.ua", - "net.ua", - "", "", "", "", "", "", "", "", - "citic", - "", "", "", "", - "dabur", - "\346\270\270\346\210\217", - "", "", "", "", "", "", - "\330\271\331\205\330\247\331\206", - "", "", "", "", - "scb", - "b.se", - "", - "com.lk", - "", "", - "site", - "co.tt", - "", "", - "ftr", - "", - "ac.il", - "", "", "", "", - "co.zw", - "nom.cl", - "", "", - "zone", - "", "", "", "", "", "", "", "", - "sus", - "", "", - "com.ua", - "", - "\321\201\320\260\320\271\321\202", - "", - "\340\264\255\340\264\276\340\264\260\340\264\244\340\264\202", - "", "", "", "", - "sc.kr", - "", - "sl", - "", "", - "fe.it", - "", "", "", - "z.se", - "\331\207\331\205\330\261\330\247\331\207", - "", "", "", "", - "co.za", - "net.in", - "", "", "", "", "", "", "", "", "", - "", "", "", - "x.bg", - "", "", - "\340\271\200\340\270\231\340\271\207\340\270\225.\340\271\204\340\270\227\340\270\242", - "", - "1.bg", - "", "", "", - "ceo", - "n.bg", - "", "", "", "", - "2.bg", - "", "", "", "", - "q.bg", - "", "", "", "", - "\351\243\236\345\210\251\346\265\246", - "", "", "", "", - "a.bg", - "\340\246\254\340\246\276\340\246\202\340\246\262\340\246\276", - "", "", "", - "4.bg", - "", - "net.tj", - "", "", - "3.bg", - "", "", "", "", - "9.bg", - "", "", "", "", - "song", - "", - "nom.tj", - "", "", - "c.bg", - "", "", "", "", - "6.bg", - "", "", - "fr", - "", - "e.bg", - "", "", "", "", - "bond", - "fr.it", - "", - "sv", - "", - "0.bg", - "", "", "", - "stc", - "8.bg", - "sv.it", - "", "", "", - "7.bg", - "", "", "", "", - "5.bg", - "", - "caseih", - "", - "dvr", - "", "", - "com.tj", - "", "", - "band", - "", "", "", "", "", "", "", - "nara.jp", - "bcn", - "", - "cymru", - "", "", "", "", "", "", "", "", - "baby", - "fc.it", - "", "", - "nyc", - "", "", "", - "conf.au", - "aco", - "ford", - "", "", "", - "cc.as.us", - "cash", - "", "", "", "", - "\343\202\273\343\203\274\343\203\253", - "", "", "", - "cc.ut.us", - "", - "ac.zw", - "", "", - "cc.ia.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "eco", - "", - "dy.fi", - "", "", "", "", "", "", - "bi", - "bid", - "", "", "", - "ad", - "", "", - "bi.it", - "net.la", - "alta.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "nom.li", - "cd", - "cc.wa.us", - "", - "nd.us", - "net.vn", - "", "", - "sina", - "", "", "", "", "", - "co.id", - "norton", - "", "", "", "", "", "", "", "", - "co.gl", - "", - "name.jo", - "", "", "", "", "", "", "", - "ed.ao", - "", "", "", "", - "co.vi", - "com.la", - "", "", "", "", "", "", "", "", "", - "sorreisa.no", - "", - "zip", - "bank", - "", "", "", "", - "seat", - "", "", "", - "fan", - "d.bg", - "", - "com.vn", - "domains", - "", "", "", "", "", "", "", "", - "nid.io", - "", "", - "f.se", - "", "", - "name.hr", - "", "", "", - "net.vi", - "", "", - "cyou", - "", "", "", "", - "b.br", - "nc.tr", - "", "", "", - "s.bg", - "bl.it", - "", "", - "cc.ar.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "\346\234\272\346\236\204", - "", "", "", - "co.hu", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "net.il", - "", "", "", "", - "com.vi", - "", "", - "duns", - "", "", "", "", - "\343\201\277\343\202\223\343\201\252", - "", "", "", "", "", "", "", - "city.hu", - "", "", "", "", "", "", "", "", - "net.dm", - "", "", "", "", - "datsun", - "", "", "", "", - "net.do", - "", - "cc.de.us", - "", "", "", "", "", "", "", "", - "bv", - "", - "docs", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "barsy.pro", - "ac.id", - "", "", "", "", - "store", - "", "", "", "", "", "", "", "", "", - "", - "com.dm", - "", "", "", "", "", "", "", "", "", - "com.do", - "", - "ads", - "", "", "", - "sd", - "catering", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "caravan", - "cc.ks.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "nissan", - "", "", "", "", - "\354\202\274\354\204\261", - "", "", "", "", "", "", - "boo", - "", - "sd.us", - "art.do", - "", "", "", - "dr.tr", - "", "", - "cc.wy.us", - "", "", "", "", "", "", "", "", "", - "", "", - "boats", - "", "", "", "", "", - "noticias.bo", - "fi", - "", "", "", - "nym.la", - "", - "cc.dc.us", - "dvag", - "fi.it", - "nym.li", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "\347\202\271\347\234\213", - "", "", - "scor", - "", "", - "berg.no", - "", - "\343\202\271\343\203\210\343\202\242", - "", - "swatch", - "", "", "", "", "", "", "", "", "", - "", - "stat.no", - "", "", "", "", "", "", "", "", "", - "", - "fit", - "", "", "", "", "", - "fire", - "beats", - "", "", "", "", "", "", "", "", "", - "", "", - "\330\247\330\261\330\247\331\205\331\203\331\210", - "", - "fans", - "", "", "", "", "", "", "", "", "", - "b.bg", - "", "", - "am", - "", "", "", "", - "sund.no", - "", "", "", "", "", - "cc.ga.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "cm", - "", "", - "nm.us", - "", - "\343\202\260\343\203\274\343\202\260\343\203\253", - "", "", "", "", "", - "qvc", - "", - "co.im", - "", "", "", "", "", "", "", "", - "z.bg", - "co.am", - "", "", "", "", "", "", "", - "dds", - "", "", "", "", "", "", "", "", "", - "cc.sc.us", - "", - "fl.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "fun", - "", - "study", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "cc.vt.us", - "", "", "", "", "", "", "", "", "", - "", "", "", - "social", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "cc.va.us", - "", "", - "net.mx", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "cc.ky.us", - "", "", - "net.mk", - "", "", "", "", "", "", "", "", - "dubai", - "", "", "", "", "", - "nom.mk", - "", - "cc.wi.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "net.mo", - "", "", "", "", - "com.mx", - "", "", - "book", - "", "", "", "", - "best", - "", "", "", - "foo", - "", "", "", "", "", "", "", - "com.mk", - "", "", "", "", "", - "dm", - "", "", - "ac.im", - "", "", "", - "duck", - "", "", "", "", "", "", "", "", - "cc.il.us", - "", "", "", "", - "cc.fl.us", - "", "", - "soc.lk", - "", - "cc.al.us", - "", "", - "com.mo", - "", "", "", "", "", - "sm", - "", - "fund", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "cc.ri.us", - "", - "sucks", - "", - "systems", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "\346\210\221\347\210\261\344\275\240", - "", "", "", "", "", - "av.tr", - "", "", "", - "dish", - "", - "b\303\241id\303\241r.no", - "ht", - "", "", "", "", "", "", "", "", "", - "", "", "", - "sm.ua", - "", - "aq", - "now", - "f.bg", - "", "", - "\343\203\235\343\202\244\343\203\263\343\203\210", - "", "", - "aq.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "alstom", - "", "", "", - "nt.ca", - "", - "drud.io", - "", "", "", "", - "sandvik", - "", - "bing", - "ns.ca", - "", - "\330\247\330\250\331\210\330\270\330\250\331\212", - "", "", "", "", "", "", "", - "bingo", - "narviika.no", - "", "", "", "", "", "", - "hot", - "", "", - "no.com", - "", - "cc.wv.us", - "food", - "", "", "", "", "", "", - "boston", - "", - "barsy.eu", - "e164.arpa", - "", "", - "fusa.no", - "", "", - "co.ca", - "\347\247\273\345\212\250", - "", - "new", - "", "", "", - "fl\303\245.no", - "", "", "", "", "", "", "", "", "", - "", "", "", - "smart", - "", "", "", "", "", - "co.com", - "", "", "", "", "", "", - "cc.gu.us", - "", "", - "studio", - "", "", "", "", "", "", "", "", "", - "", - "name.pr", - "", "", "", "", "", "", "", "", - "net.ma", - "", "", "", "", "", "", - "\343\203\225\343\202\241\343\203\203\343\202\267\343\203\247\343\203\263", - "here", - "", "", "", "", "", "", - "nym.mx", - "", "", "", "", - "net.tr", - "", "", "", "", "", "", - "bio", - "", "", "", - "hr", - "", "", "", "", "", "", - "fast", - "", - "fin.tn", - "", - "nrw", - "", "", - "now.sh", - "", - "seoul.kr", - "", - "homes", - "", "", "", "", "", - "net.ar", - "", "", "", "", "", "", "", "", "", - "", "", - "bargains", - "", "", "", "", "", "", "", "", "", - "", "", "", - "com.tr", - "", - "edu", - "", "", "", "", "", "", - "co.cr", - "", - "network", - "", "", "", "", "", "", "", "", "", - "", "", "", - "bd.se", - "career", - "careers", - "", "", "", "", - "bm", - "", "", "", - "com.ar", - "", "", "", "", - "ar.com", - "", "", "", "", - "dental", - "", "", "", "", "", "", "", "", - "qc.ca", - "", "", "", "", "", "", "", "", "", - "", - "edu.tm", - "", "", "", "", - "edu.om", - "ng", - "", "", "", - "edu.to", - "", "", "", "", - "qc.com", - "zm", - "", "", "", "", "", "", "", "", "", - "ag", - "", "", "", "", "", "", - "blue", - "ag.it", - "sld.do", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "cg", - "", "", "", "", "", "", "", "", - "airtel", - "eg", - "", "", "", "", "", "", "", "", "", - "", "", "", - "co.ag", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "sew", - "", - "co.ug", - "nic.in", - "", - "stcgroup", - "", "", - "sa.com", - "", - "cc.id.us", - "h.se", - "", "", "", "", - "scot", - "", "", "", "", "", "", - "de.com", - "", "", "", "", "", "", - "store.st", - "", "", - "nym.mn", - "", - "cc.vi.us", - "", - "ne.ug", - "", "", "", "", "", - "net.ml", - "", "", "", "", "", "", "", "", - "ac.cr", - "nic.tj", - "", "", - "news", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "email", - "", - "hu", - "", "", "", - "bostik", - "", "", "", "", - "com.ml", - "", "", "", "", - "net.qa", - "", "", "", - "horse", - "", "", "", "", "", "", "", "", "", - "", - "nom.qa", - "", "", "", - "sa.cr", - "edu.sn", - "", "", "", "", "", "", "", "", - "nu.ca", - "", "", - "bms", - "", "", "", "", "", - "fiat", - "", - "edu.co", - "", "", "", - "hs.kr", - "", "", "", "", "", "", "", "", "", - "archi", - "", "", "", "", "", - "com.qa", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "4u.com", - "", "", "", - "honda", - "", "", "", "", "", "", - "neustar", - "", "", - "ac.ug", - "edu.sa", - "sg", - "", "", - "ac.cy", - "", "", "", "", "", "", "", "", "", - "", - "eu.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "fm.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "forsale", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "a\303\251roport.ci", - "", "", - "co.tm", - "", "", - "cc.hi.us", - "", "", "", "", "", "", "", "", "", - "asnes.no", - "", - "co.zm", - "com.gh", - "", "", "", "", "", "", "", "", - "hi.us", - "", "", "", "", - "final", - "", "", "", "", - "co.ci", - "", "", "", - "fish", - "", "", "", "", "", - "forum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "net.gn", - "", - "sochi.su", - "", - "dance", - "", "", "", "", "", - "edu.cn", - "", "", "", "", "", "", - "cc.sd.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "arts.ro", - "", "", "", - "za.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "blog", - "", - "com.gn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "nl.ca", - "", "", "", "", "", - "net.ir", - "", "", "", "", - "edu.ci", - "", "", "", - "co.cl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "dynalias.net", - "dynu.net", - "", "", "", "", "", "", - "co.gg", - "", "", "", "", "", - "academia.bo", - "", "", "", "", "", "", "", "", - "sc.ug", - "br.com", - "frogans", - "", "", "", - "com.gi", - "", "", "", "", - "edu.sl", - "", "", "", "", - "dyn-ip24.de", - "", "", "", - "ac.zm", - "", "", "", "", - "bc.ca", - "", "", - "bod\303\270.no", - "", "", "", "", "", "", "", - "edu.al", - "", "", "", - "ac.ci", - "", "", "", "", - "an.it", - "", "", "", "", "", "", - "bg", - "", "", "", "", "", "", - "no.eu.org", - "bg.it", - "", - "cn", - "", "", "", "", "", "", "", - "cn.it", - "net.lr", - "", - "nnr", - "at.eu.org", - "co.in", - "", "", "", "", - "en.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "cisco", - "", "", "", "", "", "", "", "", "", - "", "", - "ddns.me", - "", - "es.eu.org", - "", "", "", "", "", "", "", "", "", - "", "", - "com.lr", - "", "", - "ca.eu.org", - "cn.ua", - "", - "fashion", - "", "", "", "", "", "", "", - "cloud", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "edu.lk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "ee.eu.org", - "", "", "", "", "", "", - "edu.ua", - "", "", "", "", "", - "news.hu", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "net.gl", - "", "", "", "", "", "", "", - "h.bg", - "", "", "", "", "", "", - "nom.gl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "nyc.mn", - "", "", "", "", "", "", "", "", - "ac.in", - "", "", "", "", "", - "com.gl", - "", "", "", "", - "edu.in", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "dnp", - "", "", "", - "sn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "design", - "", "", "", "", "", "", "", "", "", - "", - "auction", - "cc.ct.us", - "", "", - "edu.tj", - "", - "cc.co.us", - "", "", "", "", "", "", - "dn.ua", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "\303\245s.no", - "", - "cc.ca.us", - "host", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "samsclub", - "", "", "", "", - "ardal.no", - "", "", - "birkenes.no", - "", "", - "de.eu.org", - "", "", "", - "ngo", - "", "", "", "", "", - "adac", - "", "", "", "", "", - "fg.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "se.eu.org", - "", "", "", "", - "cy.eu.org", - "", - "casino", - "", "", "", "", "", "", "", - "sytes.net", - "hyatt", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "dep.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "edu.la", - "", "", "", "", "", "", "", "", "", - "", "", "", - "haus", - "", "", "", "", "", "", "", "", "", - "", "", - "edu.vn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "net.ni", - "ferrero", - "", "", "", "", "", "", "", "", "", - "", - "catholic", - "", "", - "nom.ni", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "au.eu.org", - "house", - "", "", "", "", "", "", "", - "agrar.hu", - "", "", "", "", "", "", "", - "net.gp", - "", "", "", "", - "com.na", - "", "", "", "", - "com.ni", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "author", - "", "", "", "", "", "", "", "", "", - "", "", - "barsy.uk", - "", "", - "ens.tn", - "", "", "", "", "", "", "", "", - "ed.cr", - "", "", "", "", "", "", - "bn", - "", "", "", - "com.gp", - "", "", "", - "bn.it", - "", "", "", "", "", "", "", - "cuneo.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "edu.dm", - "", "", "", "", - "center", - "", "", "", "", - "edu.do", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "forum.hu", - "", "", "", "", "", "", "", "", "", - "forde.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "be.eu.org", - "", "", "", "", "", "", "", "", "", - "", - "ac.gn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "bardu.no", - "", "", - "eid.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "nl.eu.org", - "", "", "", "", "", "", "", - "hm", - "", "", "", "", "", "", "", "", "", - "", "", - "al.eu.org", - "", "", "", "", "", "", "", "", - "hotel.hu", - "", "", "", "", "", "", - "amfam", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "cody.museum", - "", "", "", - "co.cm", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "ac.vn", - "", "", "", "", "", "", "", "", "", - "", "", - "cloudapp.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "nj.us", - "", "", "", "", - "fi.cr", - "", "", - "sauda.no", - "", "", "", "", "", - "barsy.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "carraramassa.it", - "", "", "", "", "", - "estate", - "", "", "", - "nowtv", - "", "", "", - "si.eu.org", - "", "", "", "", - "aero", - "", "", "", "", "", "", - "anquan", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "net.ae", - "", "", "", "", "", "", "", "", "", - "", "", - "aosta.it", - "", "", - "nom.ae", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "com.se", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "edu.mx", - "", "", "", "", "", "", "", "", - "ed.ci", - "", "", - "aoste.it", - "", "", "", "", "", "", "", - "edu.mk", - "", "", "", "", "", "", "", "", "", - "net.jo", - "", "", "", "", "", "", "", - "barsy.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "edu.mo", - "amot.no", - "", "", "", - "com.ee", - "dj", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "com.jo", - "", "", "", "", "", - "sj", - "", "", "", "", "", "", "", "", "", - "", "", - "sncf", - "", - "nom.re", - "", "", "", "", "", "", - "how", - "", "", "", "", - "ddns.net", - "fr.eu.org", - "", - "ngo.lk", - "", "", "", "", - "fet.no", - "", "", "", "", "", "", - "cc.in.us", - "", "", "", "", "", "", "", "", - "name.my", - "", "", "", "", "", "", "", "", - "com.re", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "zapto.org", - "", - "doctor", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "crown", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "dynv6.net", - "ap.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "app", - "", "", "", "", "", "", - "co.bw", - "", "", "", "", "", - "coffee", - "", "", "", "", "", "", "", - "\331\203\330\247\330\253\331\210\331\204\331\212\331\203", - "", - "edu.mn", - "", "", "", - "actor", - "broker", - "", "", - "cd.eu.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "nuoro.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "arts.museum", - "", "", "", "", "", - "servemp3.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "astronomy.museum", - "", "", - "auto", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "autos", - "", "", "", "", "", - "satx.museum", - "academy", - "", "", "", - "edu.tr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "net.pk", - "", - "bmw", - "", "", "", "", "", "", "", "", "", - "", "", "", - "edu.ar", - "", "", "", "", "", "", "", - "arab", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "sorum.no", - "", "", "", "", "", "", "", "", - "bj", - "busan.kr", - "", "", "", "", "", "", "", "", "", - "", "", "", - "com.pk", - "", "", "", "", - "nyny.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "sp.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "net.ph", - "", "", "", "", "", "", "", "", - "dp.ua", - "", "", "", - "ambulance.aero", - "", "", "", - "store.ro", - "", "", "", "", "", "", "", "", "", - "", "", - "ac.be", - "", "", "", "", "", "", "", "", "", - "", - "aip.ee", - "", - "froya.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "zero", - "", - "com.ph", - "", "", "", "", "", "", "", "", "", - "net.gr", - "", "", "", "", "", "", "", "", "", - "", "", "", - "fi.eu.org", - "", "", "", "", "", "", - "hiphop", - "", "", "", "", "", "", "", - "hsbc", - "", "", "", "", "", "", - "net.pn", - "", "", "", "", - "edu.ml", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "dgca.aero", - "", - "com.gr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "capital", - "", "", "", - "hu.com", - "", "", "", "", "", - "netbank", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "edu.qa", - "", "", - "ddnss.org", - "", - "net.pa", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "nom.pa", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "bnr.la", - "", "", "", "", "", - "kw", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "com.pa", - "", "", "", "", - "fla.no", - "", "", "", "", "", "", "", "", "", - "", "", - "barum.no", - "", "", "", "", - "hamar.no", - "", "", "", "", "", "", "", "", "", - "", "", "", - "net.ve", - "bodo.no", - "", "", "", "", "", "", "", "", "", - "", "", "", - "ks.us", - "", "", "", "", "", "", "", "", "", - "", - "edu.gh", - "", "", "", "", "", "", "", "", "", - "\345\205\253\345\215\246", - "arts.nf", - "", "", - "ks.ua", - "", - "ke", - "", "", - "co.tj", - "\345\276\256\345\215\232", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "com.ve", - "", "", "", "", - "\340\256\207\340\256\250\340\257\215\340\256\244\340\256\277\340\256\257\340\256\276", - "", "", "", - "\340\260\255\340\260\276\340\260\260\340\260\244\340\261\215", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "blogspot.no", - "", "", "", "", - "blogspot.ro", - "hitachi", - "", "", "", - "blogspot.rs", - "", "", "", "", "", "", "", "", - "co.bi", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "nym.ie", - "", "", "", "", - "edu.gn", - "flowers", - "", "", "", "", - "kr", - "krd", - "", - "zp.ua", - "nym.gr", - "", "", "", - "kr.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "net.au", - "", "", "", "", - "blogspot.se", - "", "", "", "", "", "", "", "", "", - "blogspot.re", - "", "", "", "", "", - "courses", - "", "", "", - "net.pl", - "", "", "", "", "", "", "", "", "", - "cruise", - "cruises", - "", "", "", - "nom.pl", - "hn", - "", "", "", "", "", "", "", - "kr.ua", - "edu.gi", - "", - "stord.no", - "", "", - "atm.pl", - "", "", "", "", - "com.au", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "ac.tj", - "com.pl", - "", "", "", "", - "blogspot.de", - "", "", "", "", "", "", "", "", "", - "", - "codespot.com", - "", "", "", "", "", "", "", "", - "h\303\245.no", - "", "", "", "", - "alsace", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "ky", - "xyz", - "", "", - "blogspot.qa", - "ferrari", - "", "", "", - "art.pl", - "", "", "", "", - "net.ru", - "", "", "", "", "", "", "", - "hgtv", - "", - "cn.com", - "", - "cc.tn.us", - "", "", "", "", "", "", "", - "act.au", - "", "", "", "", "", "", "", "", "", - "edu.lr", - "", "", "", - "ky.us", - "", "", "", "", "", - "blogspot.ba", - "", "", "", "", "", "", - "cc.or.us", - "k.se", - "", - "net.cu", - "", "", "", "", "", "", "", "", "", - "com.ru", - "", "", "", "", - "net.nr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "asn.au", - "", "", "", "", - "contractors", - "", "", "", "", - "blogspot.be", - "", "", "", "", "", "", - "software", - "", "", "", "", "", "", "", "", "", - "floro.no", - "", "", - "com.cu", - "", "", - "hr.eu.org", - "", "", "", "", "", "", - "saogonca.br", - "", "", "", "", - "com.nr", - "", "", "", "", - "com.de", - "", "", "", "", - "secure", - "", - "flora.no", - "", "", "", "", "", "", "", "", "", - "barsy.io", - "", "", "", "", "", "", - "ac.cn", - "", "", "", "", "", "", "", "", "", - "ak.us", - "", "", "", "", "", "", "", "", "", - "", - "nym.su", - "", - "\347\275\221\345\235\200", - "", "", - "edu.gl", - "vt.it", - "", - "nico", - "co.uk", - "", "", "", "", "", "", - "vs.it", - "", "", "", "", "", - "hitra.no", - "", "", "", "", "", "", "", - "durban", - "", "", - "va", - "", "", "", "", "", - "ck.ua", - "", - "va.it", - "", "", "", "", - "vt.us", - "", "", "", "", "", "", - "sanfrancisco.museum", - "", "", "", "", - "ng.eu.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "blogspot.tw", - "\330\247\331\212\330\261\330\247\331\206", - "", "", "", "", - "va.us", - "", - "ve", - "\330\250\331\212\330\252\331\203", - "vote", - "", - "\321\203\320\272\321\200", - "", "", - "blogspot.ru", - "ve.it", - "", "", "", "", "", "", "", "", "", - "", "", - "fido", - "", "", "", "", "", "", - "soccer", - "", "", "", "", - "sos.pl", - "", "", "", "", - "fam.pk", - "", - "kia", - "", "", "", "", - "dynathome.net", - "", "", "", "", "", "", "", "", "", - "", "", "", - "hof.no", - "dnsalias.net", - "", "", "", "", - "servep2p.com", - "", "", - "vet", - "nom.km", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "co.dk", - "", "", "", "", "", "", "", "", "", - "", "", - "dk", - "", "", "", "", "", "", "", "", "", - "vr.it", - "", "", "", "", "", "", "", "", - "com.km", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "ac.uk", - "", - "sk", - "", "", "", - "aid.pl", - "", "", "", "", "", "", - "nba", - "", "", "", "", "", - "vc", - "", - "c66.me", - "", "", "", "", "", - "vc.it", - "", - "hu.eu.org", - "co.om", - "blogspot.si", - "", "", "", "", "", "", "", "", - "sc.cn", - "", "", "", "", "", "", "", "", - "hopto.org", - "", "", "", "", "", "", "", "", - "cba", - "", - "cb.it", - "", "", "", "", "", "", "", - "kim", - "", "", - "ass.km", - "", "", "", "", "", "", "", "", "", - "", - "serveirc.com", - "", "", "", "", "", "", "", "", - "qld.au", - "", "", "", "", - "edu.ni", - "", - "nodum.io", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "sld.pa", - "", "", "", "", "", "", "", - "cbre", - "", "", "", "", "", - "sport", - "net.me", - "", "", "", "", - "net.kn", - "", "", "", "", "", "", "", "", "", - "edu.gp", - "", "", "", "", - "eastcoast.museum", - "", "", "", "", - "blogspot.nl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "vodka", - "", "", "", - "vana", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "stryn.no", - "", - "kv.ua", - "", "", "", "", "", "", "", "", "", - "", - "blogspot.hr", - "", "", - "hdfc", - "", - "net.ki", - "", "", "", "", - "net.bm", - "", "", "", - "associates", - "", "", "", "", "", - "net.bo", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "vu", - "", "", - "dynalias.com", - "", "", "", - "com.ki", - "", "", "", "", - "com.bm", - "", "", "", "", "", "", "", "", "", - "com.bo", - "", "", - "co.events", - "", - "net.vu", - "sb", - "herad.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "name.ng", - "cbs", - "", "", "", "", "", "", "", - "net.bh", - "", "", "", "", - "blogspot.kr", - "", "", "", "", "", - "s\303\274dtirol.it", - "", - "alfaromeo", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "k.bg", - "servehumour.com", - "com.vu", - "", "", "", - "nes.akershus.no", - "abarth", - "", "", "", "", "", "", "", "", - "sb.ua", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "com.bh", - "", "", "", "", "", "", "", "", "", - "", "", - "cbn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "barsy.me", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "nysa.pl", - "", - "vi", - "", - "net.bn", - "", "", "", "", "", - "vi.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "video", - "", - "bg.eu.org", - "vip", - "", "", - "snasa.no", - "", "", "", "", "", - "cn.eu.org", - "", "", "", "", "", "", - "nym.me", - "vi.us", - "", "", "", "", "", "", "", "", "", - "sumy.ua", - "", "", "", - "com.bn", - "", "", "", "", "", "", "", - "club", - "", "", "", "", - "kddi", - "", - "net.ba", - "", "", "", "", - "blogspot.hu", - "", - "abb", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "biz", - "", "", "", "", "", "", "", "", "", - "\345\230\211\351\207\214", - "", "", - "nym.lu", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "sbs", - "", "", - "com.ba", - "", "", "", "", - "com.bi", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "am.br", - "", "", "", "", "", "", - "bb", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "sites.static.land", - "", "", "", - "kaufen", - "", - "acct.pro", - "", "", - "nordkapp.no", - "", "", "", "", - "edu.ee", - "", "", "", - "\330\247\331\212\330\261\330\247\331\206.ir", - "", "", "", "", "", "", - "vv.it", - "", "", "", - "blogspot.ca", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "edu.jo", - "", "", "", "", "", "", - "bbt", - "", "", "", "", "", "", "", "", "", - "haram.no", - "", "", "", "", "", "", "", "", "", - "", "", "", - "visa", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "cloudaccess.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "nodum.co", - "", "", "", "", - "esurance", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "\303\245mot.no", - "", "", - "bir.ru", - "asso.km", - "", "", - "vin", - "", "", "", "", "", - "net.ge", - "", "", "", "", "", "", "", "", "", - "", "", - "aichi.jp", - "", "", - "nom.ge", - "", "", "", "", "", "", "", "", "", - "frog.museum", - "", "", - "voss.no", - "", "", "", "", "", "", "", "", - "c!www.ck", - "", "", "", - "singles", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "com.ge", - "aaa.pro", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "futbol", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "v.bg", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "abc", - "", "", - "est.pr", - "cartier", - "", "", "", - "com.kp", - "", "", "", "", "", "", "", "", "", - "", "", - "cc.ak.us", - "", "", - "net.pr", - "", "", - "spot", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "km", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "vision", - "", "", - "com.pr", - "", - "sport.hu", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "drud.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "definima.net", - "", "", "", - "edu.pk", - "", "", "", - "km.ua", - "", "", - "naroy.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "aca.pro", - "", "", "", "", "", "", "", - "sd.cn", - "", "", "", "", "", - "notaires.km", - "", "", "", "", "", "", "", - "vang.no", - "", "", "", "", "", "", "", "", "", - "", "", - "blogspot.lt", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "asso.mc", - "", "", "", - "blogspot.td", - "", "", "", "", "", "", "", "", "", - "net.mu", - "", "", "", "", - "notaires.fr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "space", - "", "", "", "", "", "", "", "", "", - "", - "edu.ph", - "", "", "", "", "", "", "", "", "", - "", "", - "hurum.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "de.cool", - "", "", "", - "com.mu", - "hoteles", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "nm.cn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "edu.gr", - "", "", - "xbox", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "edu.pn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "homesense", - "", - "cloudaccess.host", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "samsung", - "", "", - "video.hu", - "", - "cartoonart.museum", - "", "", "", "", - "asso.nc", - "", "", "", "", "", - "caa.aero", - "", "", "", "", "", "", "", - "edu.pa", - "", "", "", "", "", "", "", "", "", - "", "", "", - "buzz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "nt.no", - "", "", "", "", "", "", "", "", "", - "", - "nsw.au", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "blogspot.cl", - "", "", - "asia", - "", "", "", "", "", "", "", - "asso.re", - "", "", "", "", "", "", "", "", "", - "", "", "", - "co.no", - "", "", "", "", - "aa.no", - "blogspot.pt", - "", "", "", "", - "edu.ve", - "", "", "", "", "", "", "", "", "", - "kep.tr", - "", "", "", "", "", "", "", "", - "co.na", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "ca.na", - "", "", "", "", "", "", "", "", "", - "", "", - "bar.pro", - "bbc", - "", "", - "blogspot.cv", - "", "", - "barsy.pub", - "", - "biz.tj", - "", "", "", "", "", "", "", "", "", - "blogspot.pe", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "net.sd", - "", "", "", "", "", "", "", "", - "kyoto", - "", "", "", "", "", "", "", "", - "cern", - "", "", "", "", "", "", "", "", "", - "", "", - "kr.com", - "", "", "", - "fm.br", - "blogspot.lu", - "", "", "", "", - "nom.ad", - "", "", "", - "aetna", - "", "", "", "", "", "", "", "", "", - "", "", "", - "hyogo.jp", - "", "", - "com.sd", - "", - "dyroy.no", - "", "", - "edu.au", - "", "", "", - "ha.cn", - "", "", "", "", - "cq.cn", - "", "", "", "", "", "", - "kg", - "", "", "", "", "", "", "", "", - "edu.pl", - "", "", - "blogspot.co.ke", - "", "", - "ch", - "", "", - "nh.us", - "", "", "", "", - "ch.it", - "", "", - "sopot.pl", - "club.aero", - "", "", "", "", "", - "canon", - "", "", "", "", - "he.cn", - "", "", "", "", "", "", "", "", "", - "", - "ambulance.museum", - "", "", "", - "st.no", - "", "", "", "", "", "", "", "", "", - "", - "biz.vn", - "", "", "", - "cc.na", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "dedyn.io", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "blogspot.li", - "", "", "", "", "", "", "", "", "", - "blogspot.sg", - "", - "zgora.pl", - "", "", - "edu.ru", - "", "", "", "", "", "", "", "", "", - "", - "surgery", - "", "", "", "", - "hk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "net.hk", - "", "", "", "", "", "", "", "", "", - "net.gu", - "", - "cipriani", - "", "", "", "", "", "", "", - "edu.cu", - "", "", "", "", "", - "audible", - "", "", "", "", "", "", "", "", - "edu.nr", - "", "", "", "", "", "", "", "", "", - "biz.dk", - "bauhaus", - "", "", "", "", "", - "hkt", - "", "", "", "", "", "", "", - "com.hk", - "", "", "", "", "", "", "", "", - "dr.na", - "com.gu", - "", "", "", "", - "circle", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "sh", - "", "", - "barsy.shop", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "sardinia.it", - "", - "barsy.in", - "", "", "", "", - "virgin", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "blogspot.fr", - "", "", "", "", "", - "qa2.com", - "", "", "", "", "", "", - "no-ip.org", - "", "", "", "", - "shaw", - "", "", "", "", "", "", - "co.krd", - "", "", "", "", "", "", "", "", "", - "kirkenes.no", - "", "", "", "", "", "", "", "", "", - "", "", "", - "kiwi", - "", - "blogspot.bg", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "cooking", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "net.hn", - "", "", "", - "swiss", - "", "", "", "", "", "", "", "", "", - "", - "nom.hn", - "", "", "", "", "", "", "", "", - "barsy.club", - "", "", "", "", "", "", "", - "airforce", - "", "", "", "", - "democrat", - "", "", - "brasilia.me", - "", "", "", "", - "edu.km", - "", "", "", "", "", "", - "zarow.pl", - "", - "co.ni", - "", "", "", "", - "cargo.aero", - "com.hn", - "", "", "", - "chase", - "", "", - "hopto.me", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "sk.ca", - "", "", "", "", - "nb.ca", - "", "", "", - "no-ip.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "ab.ca", - "", "", "", "", "", "", "", "", "", - "", - "ntr.br", - "", "", "", "", "", "", "", - "vg", - "nl.no", - "", "", "", "", - "kg.kr", - "", "", - "no-ip.ca", - "", "", "", "", "", "", "", "", "", - "", "", - "al.no", - "", "", "", "", "", - "net.id", - "", "", "", "", - "esp.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "co.nl", - "", "", "", "", "", - "ngo.ph", - "kn", - "", "", "", "", - "bh", - "", "", "", "", "", "", "", "", - "karasjok.no", - "", "", "", - "hi.cn", - "", "", "", "", "", "", "", - "dontexist.com", - "", "", "", "", - "anz", - "", "", - "net.br", - "", "", "", "", "", "", "", - "a.run.app", - "", - "net.je", - "", "", "", "", - "krager\303\270.no", - "", "", - "barcelona", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "edu.me", - "", "", "", - "ac.ni", - "edu.kn", - "", "", "", "", "", "", - "\347\266\262\347\265\241.\351\246\231\346\270\257", - "", "", "", "", "", "", "", "", "", - "servepics.com", - "", "", - "com.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "blogspot.vn", - "", "", "", "", - "blogspot.sn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "hl.cn", - "", "", "", "", "", "", - "blogspot.com", - "", "", "", - "art.br", - "", "", "", "", - "edu.ki", - "", "", "", "", - "edu.bm", - "", "", "", "", "", "", "", "", "", - "edu.bo", - "", "", "", "", "", "", "", "", "", - "nhs.uk", - "", "", "", "", - "nom.nu", - "", "", "", "", - "blogspot.fi", - "", "", "", "", "", "", - "frogn.no", - "", "", "", "", "", "", - "vardo.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "kr.eu.org", - "", "", "", "", "", "", "", - "assn.lk", - "", "", "", "", "", "", "", "", - "edu.vu", - "", "", "", "", "", "", "", "", "", - "", "", "", - "hicam.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "edu.bh", - "br\303\270nn\303\270y.no", - "", "", "", "", "", "", "", "", "", - "", "", "", - "bu.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "blogspot.mr", - "", "", "", - "vadso.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "drive", - "", "", - "\345\200\213\344\272\272.\351\246\231\346\270\257", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "dontexist.net", - "dyn.cosidns.de", - "", "", "", "", "", "", - "kosher", - "", "", "", "", - "edu.bn", - "booking", - "", "", "", "", "", "", "", "", "", - "benevento.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "kinder", - "", "", - "chat", - "", - "biz.tr", - "", "", "", - "co.th", - "blogspot.ug", - "", "", "", "", "", "", "", "", "", - "net.pe", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "nom.pe", - "", "", "", "", "", "", "", "", "", - "edu.ba", - "netflix", - "barclays", - "", "", - "edu.bi", - "", - "cc.ne.us", - "", "", "", "", "", "", "", - "blogspot.my", - "", "", - "aerodrome.aero", - "", "", "", "", "", "", "", "", - "fyi", - "", "", "", "", "", "", "", - "com.pe", - "", "", "", "", "", - "desa.id", - "", "", "", "", "", "", "", - "baidu", - "", - "app.lmpm.com", - "", "", "", "", "", "", "", - "earth", - "", "", "", "", "", "", "", "", "", - "", - "ecn.br", - "", "", "", "", "", "", "", - "vn", - "", - "bharti", - "", "", "", "", "", "", "", "", "", - "", - "est-le-patron.com", - "", "", "", "", "", "", "", - "sn.cn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "def.br", - "", "", "", "", "", "", "", "", "", - "kerryhotels", - "", "", "", "", "", - "alstahaug.no", - "", "", "", "", "", "", "", "", "", - "dnsalias.com", - "", "", "", "", - "vn.ua", - "cc.nc.us", - "", "", "", "", "", "", "", "", "", - "", "", - "ac.th", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "shoes", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "bo.telemark.no", - "", "", "", "", "", "", "", "", "", - "show", - "", "", "", - "cc.ny.us", - "", "", - "arq.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "edu.ge", - "", "", "", "", "", "", "", "", "", - "cim.br", - "", "", "", "", "", "", - "barsy.support", - "dk.eu.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "bbs.tr", - "", "", "", - "barsyonline.com", - "nym.pe", - "", "", "", "", "", "", "", - "sk.eu.org", - "", "", "", "", "", "", - "edu.kp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "fh.se", - "", "", "", "", "", "", "", "", "", - "", - "etc.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "hbo", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "chrysler", - "", "", - "edu.pr", - "", "", "", "", - "ato.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "blogspot.com.es", - "", "", - "business", - "", "", "", - "copenhagen.museum", - "", "", "", "", "", - "namsskogan.no", - "", "", "", "", "", "", "", "", - "zone.id", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "fot.br", - "", "", "", "", - "fst.br", - "", "", "", "", "", "", "", "", "", - "vestv\303\245g\303\270y.no", - "", "", - "hashikami.aomori.jp", - "", - "far.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "blogspot.com.ee", - "", "", "", "", - "black", - "", "", "", "", - "blogspot.com.tr", - "", "", "", "", "", "", "", "", "", - "", - "church", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "blogspot.it", - "", "", "", "", - "bsb.br", - "", "", "", - "blogspot.com.ar", - "blogspot.is", - "", "", - "\347\266\262\350\267\257.tw", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "blogspot.com.co", - "", "", "", "", "", "", - "\347\245\236\345\245\210\345\267\235.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "\351\271\277\345\205\220\345\263\266.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "flir", - "", "", "", "", "", "", "", "", "", - "", "", - "blogspot.ie", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "xj.cn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "eco.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "amusement.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "store.nf", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "fishing", - "", "", "", "", "", - "etisalat", - "", "", "", "", - "hotel.lk", - "", "", "", "", "", "", "", "", "", - "", "", "", - "blogspot.bj", - "", "", - "saobernardo.br", - "", "", "", "", "", "", "", "", - "cc.nv.us", - "", "", "", "", "", "", "", "", - "kp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "ha.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "frosinone.it", - "", "", "", "", "", "", "", - "blogspot.com.au", - "", "", "", "", "", - "adm.br", - "", "", "", "", "", "", "", - "encyclopedic.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "blogspot.com.cy", - "", "", "", "", "", - "barclaycard", - "", "", "", "", "", "", "", - "nichinan.tottori.jp", - "", - "blogspot.md", - "", - "discount", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "hair", - "", - "voto", - "", - "\346\225\231\350\202\262.\351\246\231\346\270\257", - "nordre-land.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "nom.ke", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "edu.sd", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "fortmissoula.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "coach", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "nara.nara.jp", - "", "", "", "", "", - "vladimir.su", - "", "", - "eidsvoll.no", - "", - "kpn", - "kerrylogistics", - "", "", "", - "vladimir.ru", - "", "", "", "", "", "", - "blogspot.com.uy", - "", - "name.eg", - "", "", - "apartments", - "", "", - "cc.nd.us", - "", "", "", "", "", "", "", "", "", - "", "", "", - "biz.ni", - "", "", - "homedepot", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "1337.pictures", - "", "", "", "", "", "", "", "", "", - "softbank", - "", "", - "emp.br", - "", "", "", "", - "com.hr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "nom.gd", - "", "", "", "", "", "", - "andoy.no", - "", "", "", "", "", "", "", - "edu.hk", - "", "", "", "", "", "", "", "", "", - "edu.gu", - "", - "hobol.no", - "", "", "", "", "", "", "", "", - "hosting", - "", "", "", "", "", "", "", - "bj.cn", - "", "", "", "", "", - "kids.museum", - "", "", "", "", - "dray-dns.de", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "zj.cn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "feste-ip.net", - "bytom.pl", - "", "", "", "", "", - "show.aero", - "", "", "", "", "", - "fm.no", - "", - "dynalias.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "svn-repos.de", - "", "", "", "", "", "", "", "", "", - "", - "nesna.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "kpmg", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "auto.pl", - "", "", "", - "edu.hn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "slask.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "betainabox.com", - "", "", "", "", "", "", "", "", - "somna.no", - "", "", "", "", "", "", - "hl.no", - "", "", "", "", "", "", "", "", - "sondre-land.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "nord-aurdal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "barsy.menu", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "co.bb", - "spb.su", - "", "", "", "", "", "", - "cc.nm.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "veterinaire.km", - "", "", "", "", "", "", "", "", - "fj.cn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "bio.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "soni.nara.jp", - "", "", "", "", "", "", "", "", "", - "", - "donna.no", - "", "", "", "", "", "", "", "", "", - "", "", "", - "veterinaire.fr", - "", "", "", "", "", "", "", "", "", - "edu.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "ws", - "", "", "", - "bmd.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "s\303\270r-aurdal.no", - "", - "spb.ru", - "", "", "", "", - "\351\243\237\345\223\201", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "budapest", - "", "", "", "", "", "", - "wa.us", - "", "", - "wed", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "citadel", - "", - "xnbay.com", - "", "", - "\320\274\320\276\321\201\320\272\320\262\320\260", - "frontier", - "", "", "", "", "", "", - "hn.cn", - "", "", "", "", "", - "agr.br", - "", "", "", "", "", "", "", "", "", - "", - "shriram", - "", "", "", "", "", "", "", "", "", - "nordreisa.no", - "", "", - "bosch", - "", - "broke-it.net", - "", "", "", "", "", "", "", "", "", - "construction", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "blogspot.sk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "dattolocal.com", - "", "", "", "", "", "", "", "", "", - "ch.eu.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "co.financial", - "", "", "", "", "", "", "", "", "", - "", "", - "dst.mi.us", - "", - "blogspot.dk", - "", "", "", "", "", "", - "cc.ok.us", - "", "", "", "", "", "", "", "", "", - "", "", - "blogspot.com.mt", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "siracusa.it", - "", "", "", "", - "\345\225\206\345\272\227", - "", "", "", "", - "\345\225\206\345\237\216", - "", "", "", "", "", "", "", "", "", - "e12.ve", - "", "", "", "", "", "", - "wtf", - "", "", "", "", "", "", "", "", "", - "", "", "", - "definima.io", - "s\303\270rreisa.no", - "", "", "", - "\345\225\206\346\240\207", - "", "", "", "", "", "", "", "", "", - "edu.pe", - "", - "kyoto.jp", - "", "", - "biz.pk", - "", "", "", "", "", "", "", "", - "wy.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "w.se", - "", "", "", "", - "work", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "works", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "bentley", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "dnsup.net", - "", "", "", "", "", "", "", - "agakhan", - "", "", "", "", "", "", "", "", "", - "aabackplaneapp.io", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "kochi.jp", - "", "", "", "", - "frana.no", - "", - "ventures", - "", "", - "store.dk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "mw", - "", "", "", "", - "mt", - "", "", - "wa.au", - "", - "mo", - "", "", - "mt.it", - "", - "ms", - "msd", - "", - "mo.it", - "\347\217\240\345\256\235", - "", "", - "moda", - "ms.it", - "", "", - "demon.nl", - "", "", "", "", "", - "andria-barletta-trani.it", - "", - "\345\217\260\346\271\276", - "", "", "", "", "", - "ma", - "", "", "", - "sor-odal.no", - "", "", "", "", - "blogspot.ae", - "", "", "", - "mt.us", - "", "", "", "", - "mo.us", - "", "", - "mtr", - "", - "ms.us", - "kindle", - "", "", "", "", "", "", - "map", - "", "", "", "", "", "", "", "", "", - "", "", "", - "\345\205\254\345\217\270", - "", "", "", - "ma.us", - "economia.bo", - "me", - "med", - "", - "nishikatsura.yamanashi.jp", - "", "", "", "", - "me.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "cpa.pro", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "media", - "", "", "", "", - "me.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "\340\266\275\340\266\202\340\266\232\340\267\217", - "", "", "", - "med.om", - "android", - "", "", - "wi.us", - "", "", "", "", "", "", "", - "mom", - "", "", - "net.tw", - "", "", "", "", "", "", "", "", "", - "", - "mr", - "", "", "", "", "", - "brussels", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "hm.no", - "cnt.br", - "", "", "", "", "", - "kids.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "com.tw", - "mc", - "", "", - "mopar", - "", "", "", "", - "mc.it", - "", "", "", "", - "weber", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "amica", - "", "", "", - "meme", - "", - "com.aw", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "blogspot.hk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "my", - "wtc", - "wang", - "", "", "", "", "", "", - "web.co", - "", - "mtn", - "", "", - "net.rw", - "", "", "", "", - "\345\217\260\347\201\243", - "", "", - "\347\275\221\347\273\234.cn", - "", "", "", "", "", "", "", - "vb.it", - "", "", "", - "vacations", - "", "", - "\347\266\262\347\265\241.cn", - "", "", "", "", "", - "wv.us", - "botanical.museum", - "", - "man", - "", "", "", "", - "skaun.no", - "", "", "", "", "", "", "", "", "", - "", - "m.se", - "eurovision", - "net.cw", - "", "", "", "", "", "", "", "", "", - "com.rw", - "", "", "", "", - "naturalhistory.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", - "blogspot.co.il", - "", "", "", - "men", - "", "", - "biz.pl", - "", "", "", "", "", "", "", "", "", - "med.sa", - "sspacekit.io", - "", "", "", "", "", "", "", "", "", - "", - "win", - "", "", - "com.cw", - "", "", - "menu", - "", "", "", "", "", "", "", "", "", - "wine", - "", "", "", "", "", "", "", - "mu", - "", "", "", "", "", "", "", "", "", - "", "", - "mobi", - "", "", "", "", "", "", "", "", - "vgs.no", - "", - "blogspot.com.eg", - "", "", "", "", "", "", - "agrigento.it", - "", "", "", - "nym.tw", - "", - "barsy.de", - "", - "me.ke", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "ms.kr", - "monash", - "", "", "", "", "", "", "", "", "", - "a.ssl.fastly.net", - "himeshima.oita.jp", - "", "", "", "", "", "", - "w.bg", - "", - "br\303\270nn\303\270ysund.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "bozen.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "clothing", - "", "", - "abo.pa", - "", "", "", "", "", "", "", "", "", - "biz.nr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "abbvie", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "mi.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "konin.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "mi.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "suzuki", - "", - "mit", - "", - "money", - "", - "heroy.nordland.no", - "", "", "", "", "", "", "", "", - "blogspot.al", - "", "", "", - "newholland", - "", - "dlugoleka.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "barcelona.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "bjugn.no", - "", "", "", - "ml", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "epson", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "web.lk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "mv", - "serveminecraft.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "mango", - "", "", "", "", "", - "bern.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", - "bedzin.pl", - "", "", "", "", - "blogspot.co.id", - "", "", "", "", "", - "vefsn.no", - "fhs.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "design.aero", - "", "", "", "", "", "", "", "", "", - "", "", - "brand.se", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "mobi.na", - "", "", "", - "nissedal.no", - "", - "media.hu", - "", "", "", "", "", "", - "macys", - "", "", "", - "mini", - "", - "naustdal.no", - "", "", "", "", - "mer\303\245ker.no", - "", "", "", "", "", "", "", "", "", - "web.tj", - "", - "basilicata.it", - "", "", "", "", - "namdalseid.no", - "", "", - "fyresdal.no", - "", "", "", "", "", - "moss.no", - "", "", "", "", "", - "mls", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "fnd.br", - "", "", "", "", - "fedorapeople.org", - "", "", "", "", - "k12.vi", - "", "", "", "", "", - "agro.pl", - "", "", "", "", "", "", "", "", "", - "", "", - "m.bg", - "", "", "", "", "", "", - "bonn.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "k12.il", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "b.ssl.fastly.net", - "", "", "", "", "", "", "", "", "", - "", "", - "hemne.no", - "", "", - "biz.ki", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "vic.au", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "blogspot.in", - "", "", "", "", - "author.aero", - "", "", - "chtr.k12.ma.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "catering.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "md", - "", "", "", - "mutual", - "", "", "", "", "", "", - "mlb", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "ddnsking.com", - "", "", "", "", "", "", "", - "md.us", - "", "", "", "", "", "", - "mobi.ke", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "museum", - "dyn.ddnss.de", - "", "", - "sharp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "ddnss.de", - "", "", "", "", - "clan.rip", - "blogspot.co.at", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "web.do", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "mytis.ru", - "", "", "", "", - "dontexist.org", - "", - "varoy.no", - "", "", "", "", "", "", "", "", "", - "", - "nittedal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "fortal.br", - "", "", "", "", "", "", "", "", - "cc.nj.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "medicina.bo", - "", "", "", "", "", "", "", "", - "kh.ua", - "", "", "", "", "", "", "", "", "", - "", - "florence.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "myds.me", - "", "", "", "", "", "", "", "", "", - "", - "wow", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "botanicgarden.museum", - "", "", "", "", "", - "eidsberg.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "my.id", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "qpon", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "cc.oh.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "dnsalias.org", - "", "", "", "", "", "", "", "", - "blogspot.am", - "", "", - "akdn", - "", "", "", "", "", "", "", - "barsyonline.co.uk", - "", "", "", "", "", "", "", - "qh.cn", - "", "", - "spdns.eu", - "hatoyama.saitama.jp", - "", "", "", "", "", - "ah.cn", - "", "", "", "", "", - "badaddja.no", - "", "", "", "", - "barsy.co.uk", - "", "", "", "", "", "", - "mma", - "", "", "", - "apps.lair.io", - "", "", "", "", "", "", "", "", - "blogspot.gr", - "", "", "", "", "", "", "", - "historisches.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "mine.nu", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "va.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "www.ro", - "", "", "", "", "", "", "", - "equipment", - "", - "mattel", - "", "", "", "", "", "", "", "", "", - "hashimoto.wakayama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "hk.cn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "net.mw", - "", "", "", "", - "biz.pr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "blogspot.co.uk", - "", "", "", "", "", "", - "k12.tr", - "", "", "", "", - "com.mw", - "", - "ski", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "sh.cn", - "broker.aero", - "", "", - "mint", - "", "", "", "", "", "", - "aju.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "sandvikcoromant", - "", - "drayddns.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "assisi.museum", - "", "", "", "", "", "", "", "", - "mq", - "mmn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "storj.farm", - "", "", "", "", "", "", "", "", "", - "", - "web.tr", - "", "", - "historicalsociety.museum", - "", "", "", "", "", "", - "shouji", - "", - "klabu.no", - "", - "art.museum", - "", "", "", "", "", "", "", "", "", - "", - "sjc.br", - "", "", "", - "hb.cn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "stavanger.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "webcam", - "", "", "", "", "", "", "", "", "", - "aeroport.fr", - "homelink.one", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "sbi", - "hachinohe.aomori.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "sanok.pl", - "", "", - "moskenes.no", - "", "", "", "", "", "", "", "", "", - "", "", "", - "\303\270rsta.no", - "", - "kustanai.su", - "", "", "", - "can.museum", - "", "", "", "", "", - "kustanai.ru", - "", "", - "fujimino.saitama.jp", - "", "", "", "", "", "", - "edu.tw", - "", "", "", "", "", "", "", - "contemporary.museum", - "", "", "", "", - "\345\261\261\345\275\242.jp", - "", "", "", "", - "\345\257\214\345\261\261.jp", - "", "", "", "", - "\347\246\217\345\262\241.jp", - "", "", "", "", - "\345\262\241\345\261\261.jp", - "", "", "", "", - "\345\261\261\346\242\250.jp", - "", "", "", "", - "\351\235\231\345\262\241.jp", - "", "", "", "", - "\351\235\222\346\243\256.jp", - "", "", "", "", - "\345\263\266\346\240\271.jp", - "", - "bruxelles.museum", - "mg", - "", - "\346\235\261\344\272\254.jp", - "", "", "", "", - "\345\256\256\345\264\216.jp", - "", "", "", "", - "\345\256\256\345\237\216.jp", - "", - "hemsedal.no", - "", "", - "\347\237\263\345\267\235.jp", - "", "", "", "", - "\347\276\244\351\246\254.jp", - "cesenaforl\303\254.it", - "", - "cincinnati.museum", - "", - "\347\246\217\344\272\225.jp", - "", "", "", "", - "\345\205\265\345\272\253.jp", - "", "", "", "", - "\344\272\254\351\203\275.jp", - "", "", "", "", - "\351\246\231\345\267\235.jp", - "", "", "", "", - "\347\246\217\345\263\266.jp", - "", "", "", "", - "\345\276\263\345\263\266.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "\351\253\230\347\237\245.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "\303\245rdal.no", - "", "", "", "", - "hara.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "edu.rw", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "cesena-forl\303\254.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "edu.cw", - "", "", "", "", "", "", "", - "s\303\270rum.no", - "", "", "", "", "", "", "", - "siteleaf.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "equipment.aero", - "", "", "", "", "", - "air.museum", - "", "", - "vet.br", - "", "", - "fastpanel.direct", - "", "", "", "", "", "", "", "", "", - "blogspot.mk", - "", "", "", "", "", "", "", "", "", - "newspaper.museum", - "", "", "", "", "", "", "", - "dyn-o-saur.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "\351\225\267\345\264\216.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "asaka.saitama.jp", - "", "", "", "", "", - "nord-odal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "\351\225\267\351\207\216.jp", - "", - "mod.gi", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "nishikawa.yamagata.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "showtime", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "blogspot.ch", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "austrheim.no", - "", "", "", "", "", "", - "naruto.tokushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "b\303\246rum.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "ama.shimane.jp", - "", "", - "s\303\270r-odal.no", - "", "", "", "", "", "", "", "", - "foz.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "barsy.online", - "", "", "", "", - "banamex", - "", "", "", "", "", "", - "hatsukaichi.hiroshima.jp", - "", "", "", "", - "\346\204\233\347\237\245.jp", - "", "", "", "", - "stockholm", - "", "", "", "", - "narvik.no", - "mn.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "sango.nara.jp", - "", "", "", "", "", - "\346\204\233\345\252\233.jp", - "", "", "", "", - "mt.eu.org", - "", - "slz.br", - "", "", "", "", "", "", "", - "dnsfor.me", - "mn.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "\346\262\226\347\270\204.jp", - "", "", "", "", - "nishi.osaka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "hdfcbank", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "me.eu.org", - "", "", "", "", "", "", "", "", "", - "", - "nyc.museum", - "", "", "", - "\344\270\211\351\207\215.jp", - "", - "\346\276\263\351\227\250", - "", "", "", - "bss.design", - "", "", "", "", "", "", "", "", "", - "", - "\346\227\266\345\260\232", - "ua", - "", "", "", "", "", "", "", "", "", - "", "", - "\340\270\204\340\270\255\340\270\241", - "ut.us", - "", "", "", - "\340\271\204\340\270\227\340\270\242", - "", "", - "wanggou", - "", "", "", - "biz.id", - "", "", "", "", "", - "hyundai", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "durham.museum", - "", "", "", "", "", - "bergen.no", - "", "", "", "", "", "", "", "", - "media.pl", - "", "", "", "", "", - "suwa.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "\340\244\270\340\244\202\340\244\227\340\244\240\340\244\250", - "", "", "", - "mc.eu.org", - "", "", "", "", "", - "\321\203\320\277\321\200.\321\201\321\200\320\261", - "", - "historisch.museum", - "", "", "", - "nore-og-uvdal.no", - "", "", "", "", "", "", - "santamaria.br", - "", - "bus.museum", - "", "", "", "", "", "", "", "", "", - "\320\276\320\261\321\200.\321\201\321\200\320\261", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "\347\206\212\346\234\254.jp", - "", "", "", "", "", "", "", "", "", - "", - "\303\270stre-toten.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "country", - "", "", "", "", "", "", - "my.eu.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "\345\244\247\345\210\206.jp", - "", "", "", "", "", "", - "web.ni", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "capebreton.museum", - "", "", - "blogspot.com.ng", - "", - "h\303\270yanger.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "ddnsgeek.com", - "", "", "", "", "", "", - "fr\303\270ya.no", - "", "", "", "", "", "", "", "", "", - "sirdal.no", - "", "", - "uy", - "", "", "", "", "", "", "", "", "", - "", "", - "spdns.org", - "", "", - "neat-url.com", - "canada.museum", - "", "", "", "", "", "", - "ddr.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "u.se", - "", "", "", "", "", "", "", "", "", - "", "", "", - "abogado", - "", "", "", "", "", - "bauern.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "cloudeity.net", - "", "", "", "", - "boston.museum", - "", "", "", "", - "baseball", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "ah.no", - "abc.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "sande.m\303\270re-og-romsdal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "dynns.com", - "", "", "", "", "", "", "", "", "", - "", - "\340\270\250\340\270\266\340\270\201\340\270\251\340\270\262.\340\271\204\340\270\227\340\270\242", - "", "", "", "", "", "", - "alaheadju.no", - "", "", - "cesena-forli.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "historical.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "satte.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "amsterdam", - "", "", "", "", "", "", "", "", "", - "", - "blogspot.com.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "we.bs", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "\347\273\204\347\273\207\346\234\272\346\236\204", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "hamburg", - "", "", "", "", "", "", "", "", "", - "", - "brasil.museum", - "", "", "", "", "", "", "", "", "", - "", - "shia", - "", "", - "hita.oita.jp", - "", "", "", "", "", - "\340\270\243\340\270\261\340\270\220\340\270\232\340\270\262\340\270\245.\340\271\204\340\270\227\340\270\242", - "moto", - "", "", "", "", - "aquarelle", - "", "", "", "", "", "", "", "", "", - "", "", - "blogspot.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "moma.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "francaise.museum", - "andasuolo.no", - "", "", - "blogspot.com.by", - "", "", "", "", "", "", "", "", "", - "", - "fortworth.museum", - "", - "krodsherad.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "med.ee", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "flatanger.no", - "", "", - "md.ci", - "", "", - "sejny.pl", - "komvux.se", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "fudai.iwate.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "edu.mw", - "", "", "", "", "", "", "", - "bindal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "austin.museum", - "", "", "", - "brother", - "monza.it", - "", "", "", - "kumiyama.kyoto.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "eti.br", - "", - "modum.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "nanae.hokkaido.jp", - "", "", "", "", "", "", - "nt.edu.au", - "", "", "", "", "", "", "", "", "", - "", - "nrw.museum", - "", "", "", "", "", - "merseine.nu", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "accident-prevention.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "u.bg", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "mp", - "", "", "", "", "", "", "", "", "", - "bashkiria.su", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "\340\270\230\340\270\270\340\270\243\340\270\201\340\270\264\340\270\210.\340\271\204\340\270\227\340\270\242", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "cri.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "web.pk", - "cloudapps.digital", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "chanel", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "ud.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "manx.museum", - "", "", "", "", "", "", - "kepno.pl", - "", "", "", "", "", "", "", "", "", - "", - "frosta.no", - "", "", "", "", "", "", "", - "bashkiria.ru", - "", "", "", - "nom.pw", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "kurgan.su", - "", "", "", "", - "flor\303\270.no", - "", "", "", "", "", "", "", "", "", - "sa.edu.au", - "", "", - "shiksha", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "kashihara.nara.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "cinema.museum", - "", "", "", "", - "hasura-app.io", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "barsy.mobi", - "", "", "", "", "", "", "", "", "", - "click", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "bridgestone", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "s3-fips-us-gov-west-1.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "design.museum", - "", "", "", "", "", "", "", - "med.pa", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "sandnessj\303\270en.no", - "", "", - "sm\303\270la.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "\340\256\207\340\256\262\340\256\231\340\257\215\340\256\225\340\257\210", - "", "", "", "", "", "", "", - "web.ve", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "hadsel.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "cc.nh.us", - "hob\303\270l.no", - "", - "australia.museum", - "", "", "", "", "", "", "", "", "", - "", - "scrapping.cc", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "homesecuritypc.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "verisign", - "", "", "", - "kuokgroup", - "", "", "", "", "", "", "", "", - "kutno.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "eaton.mi.us", - "", - "ngrok.io", - "", "", "", "", "", "", - "and.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "altoadige.it", - "", "", "", "", "", "", "", "", - "chocolate.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "yt", - "", "", "", "", "", "", "", "", "", - "", - "software.aero", - "", "", - "\345\256\266\351\233\273", - "", "", - "kumagaya.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "med.pl", - "", "", "", "", "", "", "", "", "", - "\346\233\270\347\261\215", - "", "", "", "", "", "", "", "", "", - "\322\233\320\260\320\267", - "", "", "", "", - "\344\270\255\345\233\275", - "", "", "", "", - "kushimoto.wakayama.jp", - "", "", "", "", - "ski.no", - "", "", "", "", "", - "virtual-user.de", - "", "", "", - "\345\205\254\347\233\212", - "", "", "", "", - "nomi.ishikawa.jp", - "", - "\330\264\330\250\331\203\330\251", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "center.museum", - "", "", "", "", "", - "horten.no", - "", "", "", "", "", "", - "nativeamerican.museum", - "", "", - "hurdal.no", - "", "", "", "", "", "", "", "", "", - "casino.hu", - "mo.cn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "mobile", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "namerikawa.toyama.jp", - "", "", "", "", "", "", - "co.education", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "ot.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "ott", - "sn\303\245sa.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "bozen-s\303\274dtirol.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "us.com", - "mk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "arao.kumamoto.jp", - "", "", - "hasvik.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "est-mon-blogueur.com", - "", "", "", "", "", "", "", "", "", - "", - "hanyu.saitama.jp", - "", - "bozen-suedtirol.it", - "naturhistorisches.museum", - "", - "no-ip.co.uk", - "", "", "", "", - "net.sy", - "", "", "", "", "", "", "", - "\331\276\330\247\331\203\330\263\330\252\330\247\331\206", - "or.it", - "", "", "", "", - "mk.ua", - "", "", "", "", - "or.at", - "", "", "", - "y.se", - "", "", "", - "estate.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "or.us", - "", "", "", "", "", "", "", "", "", - "", - "com.sy", - "", "", "", - "me.uk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "monster", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "net.kw", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "verbania.it", - "hatogaya.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "ug", - "", "", "", "", - "songdalen.no", - "", "", "", - "com.kw", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "nature.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "o.se", - "osaka", - "net.cy", - "", "", "", "", "", - "ando.nara.jp", - "", "", "", "", "", - "football", - "", "", "", "", "", "", - "faith", - "", "", - "mba", - "", - "mb.it", - "", - "muni.il", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "uy.com", - "", "", "", "", "", "", - "anthro.museum", - "", "", "", "", "", "", "", - "com.cy", - "", "", "", "", "", "", "", "", "", - "", - "bestbuy", - "", "", - "barrell-of-knowledge.info", - "yandex", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "carboniaiglesias.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "kamiamakusa.kumamoto.jp", - "", "", - "web.bo", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "mycd.eu", - "", "", "", "", "", "", "", - "s3-us-gov-west-1.amazonaws.com", - "", "", "", "", "", "", "", - "\340\256\232\340\256\277\340\256\231\340\257\215\340\256\225\340\256\252\340\257\215\340\256\252\340\257\202\340\256\260\340\257\215", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "cesenaforli.it", - "", - "hjartdal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "or.ke", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "yun", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "sasayama.hyogo.jp", - "", "", "", - "net.uy", - "dbdebian.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "nom.uy", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "swidnica.pl", - "", "", "", "", "", "", "", "", "", - "safety", - "", "", "", "", "", "", "", "", - "or.kr", - "com.uy", - "", "", - "homesecuritymac.com", - "", "", "", "", "", "", "", - "nz", - "", "", "", "", "", "", "", "", - "cambridge.museum", - "", - "hosting-cluster.nl", - "", "", "", "", "", "", "", "", - "az", - "", "", "", "", "", "", "", "", - "beauty", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "cz", - "", "", "", "", "", "", "", - "cz.it", - "", "", "", "", "", "", - "wedding", - "you", - "", "", "", "", "", "", - "az.us", - "", "", "", "", - "co.ls", - "", "", "", "", "", "", "", - "akita.jp", - "", "", "", "", "", "", - "co.uz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "aeg", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "urn.arpa", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "y.bg", - "", - "net.sb", - "", "", "", "", "", "", "", - "fr\303\246na.no", - "homeip.net", - "", "", - "kicks-ass.net", - "", "", - "chrome", - "", "", "", "", "", "", "", "", "", - "ascoli-piceno.it", - "", "", "", "", "", "", "", "", "", - "net.ly", - "", "", "", "", - "net.zm", - "bibai.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "com.sb", - "", "", "", "", "", "", - "ooo", - "us.eu.org", - "", "", "", "", "", "", "", "", "", - "", "", "", - "dz", - "", "", "", "", "", "", "", "", "", - "", - "dog", - "", "", - "com.ly", - "", "", "", - "ac.ls", - "com.zm", - "", - "aeroclub.aero", - "", "", "", "", "", "", "", "", - "mobi.ng", - "", "", "", "", - "sz", - "", - "kawajima.saitama.jp", - "co.lc", - "", "", "", "", "", - "katsuragi.wakayama.jp", - "", "", "", "", "", "", "", - "snoasa.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "futsu.nagasaki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "deal", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "o.bg", - "deals", - "", "", "", "", "", "", "", "", "", - "mymailer.com.tw", - "", "", "", "", "", "", "", "", - "sarl", - "", "", "", "", "", "", "", - "name.mv", - "", "", "", "", - "zachpomor.pl", - "", "", - "co.sz", - "", - "vlaanderen", - "", "", "", "", "", "", "", - "sor-varanger.no", - "", "", "", "", "", - "olayan", - "edu.krd", - "", "", "", - "katowice.pl", - "arte.bo", - "", "", "", - "carrara-massa.it", - "", "", "", "", "", "", "", "", "", - "", - "naturalhistorymuseum.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "net.za", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "nom.za", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "\347\275\221\347\273\234.hk", - "", "", "", "", - "\347\275\221\347\265\241.hk", - "", "", "", "", - "\347\266\262\347\273\234.hk", - "sc.ls", - "", - "dattoweb.com", - "", - "\347\266\262\347\265\241.hk", - "", - "stockholm.museum", - "", "", "", "", "", - "med.pro", - "", "", - "ws.na", - "", "", "", "", "", "", "", "", "", - "", "", "", - "skjak.no", - "", "", "", "", - "kki", - "", "", - "waw.pl", - "", "", - "\347\256\207\344\272\272.hk", - "", - "nissay", - "", "", "", - "od.ua", - "", "", "", - "\344\270\252\344\272\272.hk", - "", "", "", "", "", "", "", "", "", - "anthropology.museum", - "ac.sz", - "", "", "", "", "", "", - "bz", - "", "", "", "", "", "", "", - "bz.it", - "", "", "", "", "", "", "", "", - "kawahara.tottori.jp", - "", "", "", "", "", - "elasticbeanstalk.com", - "", "", "", "", "", "", - "sanagochi.tokushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "hamatama.saga.jp", - "marylhurst.museum", - "aig", - "", "", - "mo\303\245reke.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "or.id", - "", "", "", "", "", "", "", "", "", - "", - "notodden.no", - "", "", "", "", "", - "krasnodar.su", - "", "", "", "", "", "", "", "", "", - "", - "hawaii.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "ustka.pl", - "", "", "", "", "", - "weir", - "", "", "", "", "", "", "", "", "", - "", "", "", - "kusu.oita.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "\345\200\213\344\272\272.hk", - "withyoutube.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "shacknet.nu", - "", "", "", "", "", "", "", "", "", - "", "", - "bcg", - "", "", "", "", "", "", "", "", "", - "koryo.nara.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "hiroshima.jp", - "cdn77-ssl.net", - "", "", "", "", "", "", "", "", - "bounceme.net", - "", "", "", "", "", "", "", "", "", - "", - "kv\303\246nangen.no", - "", "", "", "", "", - "aquila.it", - "", "", "", "", "", - "sling", - "hashbang.sh", - "", "", "", "", "", "", "", "", "", - "", "", - "masoy.no", - "", "", - "net.lb", - "katsuragi.nara.jp", - "", "", "", "", - "odda.no", - "", "", - "hasura.app", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "agriculture.museum", - "", "", "", "", "", "", "", "", - "om", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "aomori.jp", - "", "", "", "", "", "", - "com.lb", - "", - "mymediapc.net", - "", "", "", "", "", "", - "works.aero", - "nesodden.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "cool", - "co.tz", - "", "", "", - "fage", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "moi", - "", "", "", "", "", "", - "ne.tz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "nowaruda.pl", - "", "", - "maif", - "", - "bando.ibaraki.jp", - "oita.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "naturalsciences.museum", - "", - "nombre.bo", - "", - "konyvelo.hu", - "", "", - "stpetersburg.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "net.my", - "", "", "", "", "", "", "", "", "", - "med.sd", - "", "", "", "", "", "", "", "", "", - "", - "conf.lv", - "uno", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "com.my", - "", - "nose.osaka.jp", - "", "", - "alt.za", - "", "", "", "", "", "", - "cc.az.us", - "", "", "", "", "", "", "", "", "", - "", "", - "ac.tz", - "family", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "mr.no", - "", "", - "cc.la.us", - "", - "media.aero", - "", "", "", "", "", "", "", "", "", - "azure", - "", "", - "wlocl.pl", - "", "", "", "", "", "", "", - "nis.za", - "mh", - "association.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "cloud.goog", - "", - "sera.hiroshima.jp", - "", "", "", - "vard\303\270.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "kyiv.ua", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "amsterdam.museum", - "", "", "", "", "", "", - "ulsan.kr", - "honeywell", - "", "", "", "", - "9guacu.br", - "", - "web.gu", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "nishihara.kumamoto.jp", - "ama.aichi.jp", - "", "", "", "", "", "", - "est-a-la-maison.com", - "", "", "", "", "", "", "", "", "", - "", "", - "vads\303\270.no", - "", "", "", "", "", "", "", "", "", - "", "", "", - "drobak.no", - "", "", "", - "skien.no", - "", "", "", "", - "castle.museum", - "", "", "", - "asahi.mie.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "saga.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "asahi.ibaraki.jp", - "", "", "", "", "", "", - "cloud.fedoraproject.org", - "", "", "", "", - "ssbiz.ua", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "vistaprint", - "", "", "", "", "", "", "", "", "", - "", "", "", - "sc.tz", - "v\303\245g\303\245.no", - "", "", "", "", "", "", "", - "newhampshire.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "nes.buskerud.no", - "surnadal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "bronnoysund.no", - "", "", "", "", "", "", "", "", "", - "", "", - "edu.sy", - "stj\303\270rdal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "verran.no", - "", "", "", "", "", "", "", "", - "og.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "og.ao", - "", "", "", "", "", - "emb.kw", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "asuke.aichi.jp", - "", "", "", "", "", "", - "berlin", - "", "", - "napoli.it", - "", "", "", "", "", - "or.cr", - "edu.kw", - "", "", "", "", - "flickr", - "hiji.oita.jp", - "", - "versailles.museum", - "", "", "", "", "", "", - "maison", - "", - "ups", - "shiraoka.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "homebuilt.aero", - "", "", "", "", "", "", "", "", "", - "", "", - "web.id", - "", "", "", "", "", "", "", "", "", - "", "", - "shiga.jp", - "", "", "", "", "", "", - "nishikata.tochigi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "memorial", - "", "", "", "", "", "", - "mb.ca", - "\345\244\247\351\230\252.jp", - "", - "aland.fi", - "", "", "", "", "", "", "", - "net.gy", - "", "", "", "", - "\344\275\220\350\263\200.jp", - "", "", "", "", - "v\303\245gan.no", - "", "", "", "", "", "", "", "", "", - "\345\262\220\351\230\234.jp", - "", "", "", "", - "stjordal.no", - "", "", - "k12.tx.us", - "", - "utah.museum", - "", "", - "aisai.aichi.jp", - "", - "\346\273\213\350\263\200.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "or.ug", - "med.br", - "", "", - "k12.ok.us", - "bible", - "", "", "", "", "", - "com.gy", - "", "", "", "", - "mat.br", - "", "", "", "", "", "", "", - "\346\225\216\350\202\262.hk", - "", "", "", "", - "frontdoor", - "", "", "", "", - "k12.ak.us", - "", "", "", "", - "f\303\270rde.no", - "", "", "", - "aircraft.aero", - "\346\225\231\350\202\262.hk", - "", "", "", "", "", "", - "madrid", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "aga.niigata.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "biz.mw", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "k12.oh.us", - "", "", - "sk\303\245nland.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "verdal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "\345\205\254\345\217\270.\351\246\231\346\270\257", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "edu.uy", - "", "", "", "", "", "", "", - "asahi.chiba.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "k12.tn.us", - "", "", "", "", "", "", - "dunlop", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "e4.cz", - "", - "settlement.museum", - "", - "k12.co.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "nym.gy", - "", - "kunitachi.tokyo.jp", - "", "", "", "", "", - "k12.wa.us", - "", "", "", "", - "k12.wi.us", - "or.ci", - "", - "wroc.pl", - "", "", "", - "zhitomir.ua", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "whoswho", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "crafting.xyz", - "", "", "", "", "", - "alaska.museum", - "", - "adult", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "edu.sb", - "", "", "", "", "", "", "", "", - "cuisinella", - "health", - "", "", "", "", "", - "clubmed", - "", "", "", "", - "kitchen", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "edu.ly", - "", "", - "k12.ri.us", - "", - "edu.zm", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "khmelnitskiy.ua", - "", "", "", - "mk.eu.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "hanamaki.iwate.jp", - "", - "arteducation.museum", - "", "", "", "", - "k12.ca.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "uk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "bungoono.oita.jp", - "", "", "", "", "", - "hepforge.org", - "", - "k12.al.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "myftp.org", - "", - "dealer", - "", "", "", "", - "mus.br", - "", "", - "bitballoon.com", - "", "", "", "", - "kyowa.akita.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "veneto.it", - "", "", "", "", "", - "mytuleap.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "chungnam.kr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "vantaa.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "beardu.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "\345\225\206\346\245\255.tw", - "", - "edu.za", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "hockey", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "s3.dualstack.ca-central-1.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "k12.in.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "snaase.no", - "", "", "", "", "", - "mp.br", - "", "", "", "", "", "", "", "", "", - "", "", - "samnanger.no", - "", "", "", "", "", "", "", "", "", - "contemporaryart.museum", - "", - "vestvagoy.no", - "", "", - "nanyo.yamagata.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "k12.ia.us", - "", "", "", "", "", "", "", "", "", - "", "", - "noto.ishikawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "ena.gifu.jp", - "", "", - "kanan.osaka.jp", - "", "", - "vestre-toten.no", - "", "", "", "", "", - "square.museum", - "", "", "", "", "", "", "", "", "", - "", - "huissier-justice.fr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "daito.osaka.jp", - "", "", "", "", "", "", "", "", - "osaka.jp", - "", - "mi.th", - "", "", "", "", - "watch", - "akrehamn.no", - "", "", - "handa.aichi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "k12.la.us", - "", "", "", "", "", "", "", "", "", - "", - "biratori.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "hamatonbetsu.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "nz.eu.org", - "", "", "", "", - "skin", - "", "", "", "", "", "", "", - "blog.bo", - "", "", "", "", "", "", - "s3.dualstack.eu-central-1.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "surgeonshall.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "ubs", - "cz.eu.org", - "", "", "", "", "", "", "", "", "", - "k12.va.us", - "", "", "", "", - "k12.vi.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "orsta.no", - "", "", "", "", "", "", "", "", "", - "", "", "", - "edu.lb", - "", "", "", "", "", "", "", "", - "firebaseapp.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "k12.il.us", - "", "", "", "", "", "", "", "", "", - "", "", - "association.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "bomlo.no", - "", "", "", "", "", "", "", "", "", - "maori.nz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "\303\245mli.no", - "", - "washtenaw.mi.us", - "", "", "", "", "", "", "", "", "", - "", - "york.museum", - "", "", "", "", "", "", - "olawa.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "s\303\270gne.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "kozow.com", - "", "", "", "", - "museum.mw", - "", "", "", "", "", "", - "edu.my", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "suita.osaka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "nishihara.okinawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "xs4all.space", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "kawai.nara.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "kawai.iwate.jp", - "", "", "", "", - "k12.mo.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "net.py", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "hzc.io", - "saintlouis.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "winners", - "", "", "", "", "", "", "", "", - "ngo.za", - "habikino.osaka.jp", - "", "", "", "", "", "", "", "", "", - "", - "zao.miyagi.jp", - "", "", - "com.py", - "", "", "", "", "", "", "", "", "", - "", "", "", - "musica.ar", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "kuriyama.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "coal.museum", - "", "", "", "", "", "", "", - "beiarn.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "casadelamoneda.museum", - "", "", - "k12.mn.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "bhz.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "katashina.gunma.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "cyon.link", - "", "", - "blog.br", - "", "", "", "", "", "", "", "", - "vipsinaapp.com", - "", "", - "k12.ma.us", - "", "", "", "", - "k12.mi.us", - "", - "own.pm", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "k12.or.us", - "", "", "", "", "", "", "", "", "", - "", "", "", - "asahi.yamagata.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "nachikatsuura.wakayama.jp", - "", "", "", - "k12.ar.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "kiso.nagano.jp", - "", - "edu.gy", - "", - "kicks-ass.org", - "", "", "", "", "", "", "", "", - "kyowa.hokkaido.jp", - "", "", "", "", "", "", - "webhop.me", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "store.ve", - "", - "furubira.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "adult.ht", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "archaeology.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "aioi.hyogo.jp", - "", "", "", "", "", "", - "numata.gunma.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "aero.mv", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "museum.tt", - "", "", "", "", - "museum.mv", - "", "", "", "", - "hisayama.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "kochi.kochi.jp", - "us.na", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "aejrie.no", - "", "", "", - "karate.museum", - "scjohnson", - "kameyama.mie.jp", - "", "", "", - "moroyama.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "flog.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "camdvr.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "miasta.pl", - "", "", "", "", "", "", "", - "kuju.oita.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "or.bi", - "", "", "", "", - "on.ca", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "hiroo.hokkaido.jp", - "", - "anan.nagano.jp", - "", "", "", "", "", - "niikappu.hokkaido.jp", - "", "", - "kamishihoro.hokkaido.jp", - "", - "apple", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "aizumi.tokushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "degree", - "", "", "", "", "", "", "", "", - "kawatana.nagasaki.jp", - "", "", "", "", "", "", "", "", "", - "nerima.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "bunkyo.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "khmelnytskyi.ua", - "", "", "", "", "", "", "", "", - "wada.nagano.jp", - "", "", "", "", - "aigo", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "kyotango.kyoto.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "nagoya", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "ok.us", - "", "", "", - "k12.ga.us", - "", "", "", "", "", "", "", "", "", - "", - "soja.okayama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "musica.bo", - "", "", "", "", "", "", "", "", "", - "", "", - "suzu.ishikawa.jp", - "", "", - "est-a-la-masion.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "nishiokoppe.hokkaido.jp", - "chiropractic.museum", - "", - "uk.com", - "", "", "", "", "", "", "", "", "", - "", "", - "east-kazakhstan.su", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "honai.ehime.jp", - "", "", "", - "woodside", - "", "", "", "", "", "", "", - "net.ky", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "spdns.de", - "", "", "", "", "", "", "", "", "", - "", - "modelling.aero", - "", - "asahikawa.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "com.ky", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "sumida.tokyo.jp", - "", "", "", "", "", "", "", - "meteorapp.com", - "", "", "", - "kz", - "", "", "", "", "", "", "", "", "", - "", "", - "deatnu.no", - "", "", "", "", "", "", "", "", "", - "mus.mi.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "futuremailing.at", - "", "", "", "", "", "", - "herokussl.com", - "", "", "", "", "", "", - "weibo", - "", "", "", "", "", "", "", "", - "k12.nm.us", - "", - "\327\231\327\250\327\225\327\251\327\234\327\231\327\235.museum", - "", "", - "bo.nordland.no", - "", "", "", "", "", "", "", "", "", - "", "", "", - "bozen-sudtirol.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "kumatori.osaka.jp", - "", "", "", "", "", "", - "sabae.fukui.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "yorkshire.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "za.bz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "k12.nh.us", - "", "", "", - "brunel.museum", - "", "", - "bci.dnstrace.pro", - "", "", - "vlaanderen.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", - "homeunix.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "niiza.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "xz.cn", - "", "", "", "", "", - "com.by", - "", "", "", "", "", "", "", "", - "hamura.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "konsulat.gov.pl", - "", "", "", "", "", "", "", "", "", - "", - "kiwa.mie.jp", - "", "", - "maceio.br", - "", "", "", "", - "webspace.rocks", - "", "", "", "", "", "", "", "", "", - "skj\303\245k.no", - "", "", "", - "\347\265\204\347\271\224.\351\246\231\346\270\257", - "", "", "", "", "", - "\345\205\254\345\217\270.cn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "bandai.fukushima.jp", - "", "", - "botanicalgarden.museum", - "", "", "", "", "", "", "", "", - "otsuka", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "andria-trani-barletta.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "yoshinogari.saga.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "chiba.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "windows", - "", "", "", "", "", "", - "bamble.no", - "", - "nym.by", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "discourse.group", - "", "", "", "", "", - "kamimine.saga.jp", - "", "", "", "", "", "", - "vercelli.it", - "", - "asahi.nagano.jp", - "", "", "", "", "", "", "", - "smola.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "nishinoomote.kagoshima.jp", - "", - "hornindal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "seranishi.hiroshima.jp", - "", "", "", "", "", "", "", "", - "dvrcam.info", - "vegas", - "", "", "", "", "", - "kirovograd.ua", - "", "", "", "", "", - "hareid.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "kita.kyoto.jp", - "", "", "", "", "", - "uk.eu.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "kanie.aichi.jp", - "", "", - "digital", - "", "", - "ac.lk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "musashimurayama.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "mortgage", - "", "", "", "", "", "", "", "", "", - "kitaakita.akita.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "ainan.ehime.jp", - "", "", "", "", "", "", "", "", "", - "baidar.no", - "", "", "", "", "", "", - "biz.cy", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "net.bb", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "chattanooga.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "zama.kanagawa.jp", - "", "", "", "", "", "", "", "", "", - "com.bb", - "", "", - "k12.nj.us", - "", "", "", "", "", "", "", "", "", - "vaga.no", - "", "", "", "", "", "", "", "", "", - "", "", - "hanno.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "edu.py", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "vega.no", - "", "", "", "", "", "", "", - "choyo.kumamoto.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "net.eu.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "shirahama.wakayama.jp", - "nnot.br", - "", "", "", "", "", - "kami.kochi.jp", - "", "", "", "", "", "", "", "", "", - "", - "strand.no", - "", - "varese.it", - "", "", "", "", "", "", "", - "\347\265\204\347\271\224.tw", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "vig", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "shari.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "kumejima.okinawa.jp", - "", "", "", "", "", - "war.museum", - "", "", "", "", "", "", - "mo-i-rana.no", - "", "", "", "", "", - "arita.saga.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "oracle", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "biz.zm", - "", "", - "better-than.tv", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "blogspot.cz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "d\303\270nna.no", - "", "", "", "", "", "", "", - "kure.hiroshima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "cuiaba.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "nagatoro.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "blogspot.co.nz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "washingtondc.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "stokke.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "hanawa.fukushima.jp", - "", - "gw", - "", "", "", "", - "gt", - "", "", "", "", "", "", "", "", "", - "gs", - "agro.bo", - "", - "go.it", - "", "", "", "", "", - "or.na", - "", "", "", - "k12.pa.us", - "", "", "", "", "", "", "", "", "", - "", "", - "ga", - "gop", - "", "", - "yk.ca", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "kita.osaka.jp", - "", - "\346\211\213\350\241\250", - "", "", "", "", - "oh.us", - "", - "gap", - "", "", "", "", - "got", - "", "", "", "", - "kawanishi.nara.jp", - "", "", "", "", "", "", - "ga.us", - "", - "ge", - "", "", "", - "\350\264\255\347\211\251", - "", - "gea", - "", - "ge.it", - "", "", "", "", "", "", "", "", "", - "", "", "", - "weather", - "", "", "", "", "", - "navy", - "", "", - "s3.dualstack.ap-southeast-1.amazonaws.com", - "", "", "", "", - "venice.it", - "", "", - "ownip.net", - "", "", "", - "modern.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "sandnessjoen.no", - "", "", "", "", "", "", "", "", "", - "mad.museum", - "", "", "", "", "", - "hitachiota.ibaraki.jp", - "", "", "", "", - "gr", - "", "", "", "", "", "", - "democracia.bo", - "gr.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "hanamigawa.chiba.jp", - "", "", "", "", "", "", "", "", - "game", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "games", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "dtv", - "", "", "", "", - "for-some.biz", - "", "", "", - "aguni.okinawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "uri.arpa", - "hirata.fukushima.jp", - "", "", "", - "musashino.tokyo.jp", - "", "", "", "", "", "", "", "", - "watches", - "", "", "", "", "", "", "", "", - "gy", - "chintai", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "dev", - "save", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "zagan.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "stathelle.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "seihi.nagasaki.jp", - "g.se", - "", "", "", "", "", - "bananarepublic", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "morena.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "kyotanabe.kyoto.jp", - "", "", - "name.qa", - "", "", - "go.ke", - "", - "edu.ky", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "q-a.eu.org", - "", "", "", - "aisho.shiga.jp", - "", "", "", "", "", "", - "gu", - "", "", "", "", "", "", "", "", "", - "", "", "", - "k12.de.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "sydney", - "", - "hb.cldmail.ru", - "gu.us", - "", "", "", "", - "go.kr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "museumcenter.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "guru", - "", - "ol.no", - "", "", "", "", - "co.nz", - "ham-radio-op.net", - "", "", "", "", "", "", "", - "\351\263\245\345\217\226.jp", - "", - "date.hokkaido.jp", - "kwpsp.gov.pl", - "", "", "", "", "", "", "", "", "", - "", "", - "\345\261\261\345\217\243.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "urbino-pesaro.it", - "", "", "", "", "", "", "", "", "", - "moscow", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "garden", - "", "", "", "", "", - "gi", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "!city.sendai.jp", - "", "", "", "", "", "", - "s3.dualstack.ap-south-1.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "", "", "", - "yn.cn", - "", "", "", - "museum.om", - "fastly-terrarium.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "fauske.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "stj\303\270rdalshalsen.no", - "", "", "", "", "", "", "", "", "", - "", - "\346\211\213\346\234\272", - "!city.sapporo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "gl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "ac.nz", - "", - "for-more.biz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "asso.bj", - "", - "shangrila", - "", "", "", "", "", "", "", "", "", - "", - "net.iq", - "", "", - "seto.aichi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "vibovalentia.it", - "", "", "", - "aomori.aomori.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "\345\244\251\344\270\273\346\225\231", - "", "", "", "", "", "", "", "", "", - "", - "com.iq", - "", "", "", "", "", "", "", "", - "gv.at", - "", "", "", "", - "gv.ao", - "", "", - "hasuda.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "k12.me.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "goo", - "", "", "", "", "", "", "", "", "", - "", "", "", - "hachirogata.akita.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "suisse.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "grp.lk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "glade", - "", "", "", "", - "mandal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "games.hu", - "", "", "", "", "", "", "", - "kitanakagusuku.okinawa.jp", - "", "", - "g.bg", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "museum.no", - "", "", "", "", - "glass", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "or.th", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "naoshima.kagawa.jp", - "", "", "", "", "", "", "", - "daigo.ibaraki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "flt.cloud.muni.cz", - "", "", "", "", - "hitachinaka.ibaraki.jp", - "aogashima.tokyo.jp", - "", "", - "gd", - "", "", "", "", "", "", "", "", "", - "", "", "", - "go.id", - "", "", "", "", "", "", "", "", "", - "kumano.hiroshima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "ancona.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "audnedaln.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "gen.in", - "", "", "", "", - "gob.cl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "origins", - "minamioguni.kumamoto.jp", - "", "", "", "", "", "", "", "", "", - "gent", - "mosvik.no", - "", "", - "mydobiss.com", - "", "", "", "", - "eniwa.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "kota.aichi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "motoyama.kochi.jp", - "", "", "", "", "", - "goog", - "", "", - "edu.bb", - "", "", - "matera.it", - "", "", "", "", "", "", "", - "homeunix.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "fail", - "", "", "", "", "", "", "", "", "", - "", "", - "archaeological.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "midatlantic.museum", - "", "", "", "", "", "", "", - "grue.no", - "", "", "", "", "", "", "", "", "", - "", - "gdn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "yombo.me", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "fastlylb.net", - "", "", "", "", "", "", "", - "edu.eu.org", - "", "", "", "", "", "", "", "", "", - "", "", "", - "herokuapp.com", - "", "", "", "", "", "", "", "", "", - "", "", "", - "suifu.ibaraki.jp", - "", "", "", "", "", "", "", "", "", - "gm", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "\343\202\257\343\203\251\343\202\246\343\203\211", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "k12.pr.us", - "", "", "", "", - "ueda.nagano.jp", - "", - "safety.aero", - "", "", "", "", "", "", - "hitachiomiya.ibaraki.jp", - "", "", "", "", - "atsugi.kanagawa.jp", - "", "", "", "", "", "", - "nantan.kyoto.jp", - "", "", "", "", "", - "southwest.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "gob.do", - "", - "ostroleka.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "servebeer.com", - "", "", "", "", "", - "wa.edu.au", - "", "", "", "", - "krakow.pl", - "", - "kurotaki.nara.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "!city.nagoya.jp", - "", "", "", "", - "fujishiro.ibaraki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "gift", - "konan.aichi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "gifts", - "", "", "", "", "", "", "", "", "", - "", "", "", - "cust.prod.thingdust.io", - "", "", "", "", "", "", "", "", "", - "", - "sodegaura.chiba.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "gq", - "", "", "", "", "", "", "", "", "", - "", "", - "hizen.saga.jp", - "", "", "", "", "", "", - "ski.museum", - "", "", "", "", "", "", "", - "kira.aichi.jp", - "", - "my-firewall.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "fuso.aichi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "gifu.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "vlog.br", - "", "", "", "", "", "", "", "", "", - "k12.ne.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "gob.mx", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "management", - "", "", "", - "go.cr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "kawanishi.yamagata.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "kmpsp.gov.pl", - "", "", - "webhop.net", - "", "", "", "", - "gr.com", - "slg.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "kamo.kyoto.jp", - "gc.ca", - "", "", "", "", "", "", "", - "channel", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "gg", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "nuremberg.museum", - "", "", - "hasama.oita.jp", - "", "", - "gs.aa.no", - "", "", "", "", "", "", "", "", "", - "", "", - "go.ug", - "", "", "", "", "", "", "", "", "", - "marker.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "saiki.oita.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "nishinomiya.hyogo.jp", - "", "", - "komagane.nagano.jp", - "", "", "", "", "", "", "", "", - "ddnslive.com", - "", "", "", "", "", "", "", "", "", - "", "", - "gmail", - "", "", "", "", "", "", "", - "kuchinotsu.nagasaki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "gen.tr", - "", "", "", "", "", "", "", "", - "macapa.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "seiyo.ehime.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "mincom.tn", - "", "", "", "", "", "", "", - "drangedal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "k12.gu.us", - "gob.ar", - "", "", "", "", - "minamiawaji.hyogo.jp", - "", - "ouda.nara.jp", - "", "", - "smile", - "", "", "", "", "", "", "", "", "", - "", "", "", - "babia-gora.pl", - "", "", "", "", "", "", "", "", - "unusualperson.com", - "", "", "", "", "", "", - "andebu.no", - "kunneppu.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "gmo", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "zlg.br", - "", "", - "stange.no", - "", "", "", "", "", "", "", - "gs.st.no", - "", "", "", "", "", "", "", "", "", - "familyds.net", - "", "", "", "", "", "", "", "", "", - "hiv", - "", - "go.ci", - "", - "brindisi.it", - "kawaminami.miyazaki.jp", - "", "", "", "", "", "", "", "", - "odo.br", - "", "", "", "", "", - "katsuura.chiba.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "home.dyndns.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "osasco.br", - "", - "cranbrook.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "b\303\241hcavuotna.no", - "", "", - "stjordalshalsen.no", - "", "", "", - "kamagaya.chiba.jp", - "", "", "", "", "", "", "", "", - "unicom", - "", "", "", "", "", "", "", "", "", - "", - "dovre.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "verona.it", - "", "", "", "", "", "", "", "", - "build", - "massa-carrara.it", - "", "", - "marshalls", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "marine.ru", - "", "", "", "", "", - "kristiansund.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "gn", - "", "", "", "", "", "", "", "", "", - "", - "eng.pro", - "", "", - "edu.iq", - "", "", "", "", "", "", "", "", "", - "", "", - "aurskog-holand.no", - "", "", "", "", "", "", "", - "kurashiki.okayama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "k12.id.us", - "", - "shizuoka.jp", - "", "", "", - "matsumae.hokkaido.jp", - "\321\200\321\203\321\201", - "", "", "", "", "", "", "", "", "", - "", - "gs.va.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "kunisaki.oita.jp", - "", "", "", "", "", "", "", "", "", - "s3.dualstack.ap-northeast-1.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "gmbh", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "akita.akita.jp", - "", "", "", "", - "matsukawa.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "gr.eu.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "usa.museum", - "", - "shirakawa.gifu.jp", - "", "", "", "", "", "", - "myjino.ru", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "sogne.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "usantiques.museum", - "", "", "", "", "", "", "", - "s\303\270ndre-land.no", - "", - "gs.rl.no", - "", "", "", "", "", "", "", "", "", - "misasa.tottori.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "kitaaiki.nagano.jp", - "seven", - "", "", "", "", "", "", "", "", "", - "kunigami.okinawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "kamigori.hyogo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "kamoenai.hokkaido.jp", - "", - "gs.tr.no", - "hazu.aichi.jp", - "", "", "", "", - "usdecorativearts.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "starnberg.museum", - "", "", "", "", "", "", "", - "kanra.gunma.jp", - "", "", "", "", "", "", "", "", "", - "cog.mi.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "matsumoto.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "kuzumaki.iwate.jp", - "", - "skodje.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "giske.no", - "", - "utsira.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "nishiarita.saga.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "h\303\246gebostad.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "gob.ni", - "", "", "", "", "", "", "", "", "", - "", "", "", - "kizu.kyoto.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "gouv.km", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "hadano.kanagawa.jp", - "", "", "", "", "", "", - "yoshikawa.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "urawa.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "midtre-gauldal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "minami.tokushima.jp", - "", "", - "gs.hl.no", - "", "", - "urbinopesaro.it", - "", "", "", "", "", "", "", "", "", - "", - "soo.kagoshima.jp", - "", "", "", "", "", "", "", "", - "kitadaito.okinawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "oe.yamagata.jp", - "", "", - "abira.hokkaido.jp", - "engineer", - "k12.md.us", - "", "", - "kofu.yamanashi.jp", - "", "", "", "", - "gs.fm.no", - "", "", "", "", "", "", - "shiwa.iwate.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "gucci", - "", "", "", "", "", "", "", - "mz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "bearalvahki.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "ulm.museum", - "", "", "", - "modena.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "cbg.ru", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "fujimi.saitama.jp", - "", "", "", "", "", "", "", "", - "gp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "namie.fukushima.jp", - "kiryu.gunma.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "med.ly", - "", "", "", "", - "cng.br", - "", "", "", "", "", "", "", "", "", - "eng.br", - "", "", "", "", "", "", "", "", "", - "furudono.fukushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "gop.pk", - "", "", "", "", - "vagan.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "ninomiya.kanagawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "kvanangen.no", - "", - "kosei.shiga.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "workinggroup.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "olayangroup", - "", "", "", "", "", "", "", "", "", - "uvic.museum", - "oppeg\303\245rd.no", - "", "", "", "", "", - "stjohn.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "kasumigaura.ibaraki.jp", - "", "", - "aosta-valley.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "web.za", - "", "", "", "", "", "", "", "", "", - "", "", - "nemuro.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "kautokeino.no", - "", "", "", "", "", "", - "gos.pk", - "", "", "", "", - "channelsdvr.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "bloomberg", - "", "", "", "", - "statebank", - "", "", "", "", "", "", "", "", "", - "", "", - "nishi.fukuoka.jp", - "", "", "", "", "", - "navoi.su", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "futaba.fukushima.jp", - "", "", "", "", "", - "gon.pk", - "", "", "", "", - "b\303\270.telemark.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "kitakami.iwate.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "mobily", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "oamishirasato.chiba.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "co.mw", - "", "", "", "", - "\345\205\254\345\217\270.hk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "gob.pk", - "", "", "", "", "", "", "", "", "", - "", - "forl\303\254-cesena.it", - "", "", "", "", "", "", "", - "co.ma", - "", "", "", "", "", "", "", "", "", - "chieti.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "narashino.chiba.jp", - "", "", "", "", "", "", "", "", - "kppsp.gov.pl", - "", - "go.tj", - "nov.su", - "", "", "", - "co.me", - "", "", "", "", "", "", "", "", - "nango.fukushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "glas.museum", - "", "", "", "", - "net.sc", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "kunimi.fukushima.jp", - "", "", "", "", "", "", "", "", "", - "", - "net.ac", - "", "", "", "", "", - "satsumasendai.kagoshima.jp", - "", "", "", "", "", "", "", "", - "graz.museum", - "", "", "", "", - "world", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "com.sc", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "net.ec", - "", "", - "sumoto.kumamoto.jp", - "", "", "", "", "", - "ac.mw", - "com.ac", - "", "", "", "", - "kisosaki.mie.jp", - "", "", "", - "development.run", - "", "", - "gs.hm.no", - "", "", - "ath.cx", - "", "", - "doha", - "", "", "", "", "", "", - "beta.bounty-full.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "ac.ma", - "", "", "", "", "", - "webredirect.org", - "", "", "", "", - "com.ec", - "", - "kasuya.fukuoka.jp", - "numata.hokkaido.jp", - "", - "nov.ru", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "sohu", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "ac.me", - "gsm.pl", - "", "", "", "", "", "", "", "", "", - "", "", - "gs.tm.no", - "", - "gs.cn", - "", "", "", "", "", "", "", - "cloudycluster.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "gob.pa", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "yufu.oita.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "karasjohka.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "zentsuji.kagawa.jp", - "", "", "", - "oita.oita.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "gob.ve", - "", "", "", "", - "me.tz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "aramco", - "", - "hidaka.saitama.jp", - "nasushiobara.tochigi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "kl\303\246bu.no", - "", "", "", "", "", "", "", "", "", - "co.mu", - "", "", "", "", "", "", - "biz.bb", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "sosnowiec.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "homeunix.org", - "", "", "", - "abu.yamaguchi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "aso.kumamoto.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "unj\303\241rga.no", - "", - "obi", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "comsec", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "bearalv\303\241hki.no", - "", "", "", "", "", "", "", "", "", - "", - "shiki.saitama.jp", - "", "", "", "", "", "", "", "", "", - "cccus-east-1.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "", "", - "doshi.yamanashi.jp", - "", "", "", "", "", "", "", "", - "goodyear", - "", "", "", "", "", "", "", "", "", - "", "", - "group", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "ac.mu", - "", "", "", "", "", - "sado.niigata.jp", - "", "", "", "", "", - "arts.co", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "gb", - "", - "hioki.kagoshima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "sch.sa", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "dyr\303\270y.no", - "", "", "", "", "", "", "", - "familyds.com", - "", "", "", "", "", "", "", "", "", - "", "", "", - "net.lc", - "", "", "", "", - "site.builder.nu", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "annaka.gunma.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "xihuan", - "", "", "", "", "", "", "", "", "", - "com.lc", - "", "", "", "", "", "", - "alibaba", - "", "", - "mypep.link", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "sasaguri.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "net.vc", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "nom.vc", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "farm", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "com.vc", - "x443.pw", - "", "", "", "", "", "", - "hirosaki.aomori.jp", - "", "", "", "", "", "", "", - "at-band-camp.net", - "", "", "", "", - "s3-sa-east-1.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "sandoy.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "apigee.io", - "", "", "", - "surrey.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "ybo.party", - "", "", "", "", "", "", - "corsica", - "cc.mt.us", - "", "", "", "", - "cc.mo.us", - "", "", "", "", - "cc.ms.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "cc.ma.us", - "", "", "", "", - "kongsberg.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "nym.lc", - "", "", "", "", "", "", "", - "shibukawa.gunma.jp", - "", - "sumita.iwate.jp", - "", - "cc.me.us", - "", - "globo", - "viva", - "", - "boutique", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "sch.lk", - "", "", "", "", "", - "gouv.ml", - "", "", "", "", "", "", "", "", - "google", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "gob.bo", - "", "", "", "", "", "", "", "", "", - "", "", "", - "hidaka.wakayama.jp", - "", - "gda.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "fujiidera.osaka.jp", - "", "", - "orange", - "", "", "", "", - "uda.nara.jp", - "", "", "", "", - "yorii.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "bbva", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "kamikoani.akita.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "osoyro.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "ohtawara.tochigi.jp", - "", "", "", "", "", "", "", "", "", - "", - "shoo.okayama.jp", - "", "", "", "", "", "", "", "", "", - "nishio.aichi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "gd.cn", - "", "", "", "", "", "", "", "", "", - "daplie.me", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "kawasaki.miyagi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "kariwa.niigata.jp", - "", "", "", "", "", "", "", "", "", - "", - "atsuma.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "moriyoshi.akita.jp", - "", "", "", "", "", "", "", "", - "artgallery.museum", - "", "", "", "", "", "", "", "", "", - "", - "kimino.wakayama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "chuo.osaka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "mozilla-iot.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "cc.mi.us", - "", "", "", "", "", "", "", - "mlbfan.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "guardian", - "", "", "", "", "", - "n\303\270tter\303\270y.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "kawara.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "udi.br", - "", "", "", - "global", - "otaki.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "adachi.tokyo.jp", - "", - "hamada.shimane.jp", - "evje-og-hornnes.no", - "", "", "", "", "", - "showa.gunma.jp", - "", "", "", "", "", "", "", "", - "oyodo.nara.jp", - "", "", "", - "oga.akita.jp", - "", "", "", "", "", "", "", "", "", - "manchester.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "nishinoshima.shimane.jp", - "", "", "", "", "", "", "", "", "", - "family.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "konan.shiga.jp", - "fin.ec", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "hirono.fukushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "swinoujscie.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "kanoya.kagoshima.jp", - "", "", "", "", - "yawatahama.ehime.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "aknoluokta.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "yodobashi", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "webhop.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "oristano.it", - "", "", "", "", "", - "gs.ol.no", - "", "", - "mutsu.aomori.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "abiko.chiba.jp", - "", "", - "genoa.it", - "", "", "", "", "", "", - "higashimurayama.tokyo.jp", - "", - "engerdal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "kawakami.nara.jp", - "", - "kinko.kagoshima.jp", - "", "", - "koriyama.fukushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "muncie.museum", - "", - "edu.sc", - "", - "yamatokoriyama.nara.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "kasuga.fukuoka.jp", - "", "", - "edu.ac", - "", "", "", - "dattorelay.com", - "", - "firm.in", - "", "", "", "", "", "", "", "", "", - "", "", "", - "franziskaner.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "gs.bu.no", - "", "", "", "", - "shishikui.tokushima.jp", - "", "", - "edu.ec", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "kawaguchi.saitama.jp", - "", "", "", - "co.mg", - "", - "engineering", - "", "", "", "", - "gh", - "", - "bushey.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "anjo.aichi.jp", - "", "", "", "", "", "", "", "", - "cc.md.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "naie.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "esan.hokkaido.jp", - "uz", - "berlin.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "virtueeldomein.nl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "otoyo.kochi.jp", - "", "", "", "", "", "", "", "", "", - "", - "uz.ua", - "", "", "", "", "", "", "", "", "", - "", "", "", - "aktyubinsk.su", - "", "", "", "", "", - "umbria.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "kotohira.kagawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "myqnapcloud.com", - "", "", "", "", "", "", "", "", "", - "", - "kaneyama.fukushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "hongo.hiroshima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "george", - "", "", "", "", "", - "s3.dualstack.ap-southeast-2.amazonaws.com", - "", "", "", - "minato.tokyo.jp", - "", "", - "madrid.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "sigdal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "gran.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "services", - "minamisanriku.miyagi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "genting", - "", "", "", "", "", "", "", "", - "kristiansand.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "ax", - "", "", - "seiro.niigata.jp", - "", "", - "axa", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "sch.qa", - "", "", - "cx", - "", "", "", "", "", "", "", "", "", - "", "", "", - "nadex", - "", "", "", "", "", "", "", "", "", - "", "", - "serveblog.net", - "", "", "", - "otaru.hokkaido.jp", - "", "", "", "", "", "", - "guide", - "gb.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "matsuura.nagasaki.jp", - "", "", "", "", "", "", - "environment.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "co.je", - "", "", "", - "hinode.tokyo.jp", - "", "", "", - "\347\273\204\347\273\207.hk", - "", "", "", "", - "\347\265\204\347\273\207.hk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "\347\273\204\347\271\224.hk", - "edu.lc", - "", "", "", - "\347\265\204\347\271\224.hk", - "", "", "", "", "", "", "", - "matsumoto.kagoshima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "nom.nc", - "", "", "", "", "", "", "", - "health.museum", - "", "", "", "", "", "", "", "", "", - "marugame.kagawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "edu.vc", - "", "", "", "", "", "", "", "", "", - "", "", "", - "sx", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "odate.akita.jp", - "gob.hn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "and\303\270y.no", - "", "", "", "", "", "", - "farmers", - "", "", "", "", - "rw", - "", "", "", "", - "eisenbahn.museum", - "", "", "", "", - "ro", - "", "", "", "", - "rs", - "", "", - "ro.it", - "sch.ir", - "", "", "", "", - "\346\224\277\345\272\234", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "rodeo", - "", "", "", "", "", "", "", "", "", - "ra.it", - "", "", "", "", - "radio", - "", - "from.hr", - "", "", "", "", "", "", "", "", "", - "", "", - "kvinnherad.no", - "", "", "", "", "", "", "", "", "", - "", "", - "\344\274\201\344\270\232", - "", "", "", "", "", "", "", "", - "higashihiroshima.hiroshima.jp", - "", - "re", - "red", - "", "", "", "", "", "", - "re.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "notteroy.no", - "", "", "", "", "", "", "", - "builders", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "misawa.aomori.jp", - "", "", "", "", "", "", "", "", "", - "webhop.info", - "", "", - "exnet.su", - "", "", "", "", - "go.th", - "srv.br", - "", "", "", "", "", - "ogawa.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "fuchu.hiroshima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "asti.it", - "", "", "", "", "", "", "", "", "", - "", - "rc.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "read", - "", "", "", "", "", "", "", - "ftpaccess.cc", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "kurate.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "seek", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "r.se", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "misato.saitama.jp", - "", "", "", "", - "ren", - "", "", "", "", "", "", "", - "shizukuishi.iwate.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "rade.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "nanbu.yamanashi.jp", - "", "", - "ru", - "", "", "", "", "", "", "", "", "", - "", "", - "botany.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", - "quest", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "beer", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "fermo.it", - "", "", "", "", "", "", "", "", "", - "", "", - "chikuhoku.nagano.jp", - "gob.pe", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "ubank", - "", "", - "furano.hokkaido.jp", - "", "", "", "", - "gs.svalbard.no", - "", "", "", "", "", - "sicily.it", - "", "", "", "", - "re.kr", - "", "", "", "", "", - "abashiri.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "firm.ro", - "", "", "", "", "", "", "", - "ri.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "community", - "", "", "", "", "", "", "", "", - "rip", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "ri.us", - "", - "ninja", - "", "", "", "", "", "", "", "", "", - "forex", - "", "", "", "", "", - "marnardal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "fedex", - "katagami.akita.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "udine.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "kashiwazaki.niigata.jp", - "", "", "", "", "", "", "", "", - "rana.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "kaminoyama.yamagata.jp", - "", "", "", "", "", "", "", - "free", - "", "", "", "", "", "", - "run", - "", "", "", "", "", - "bari.it", - "", "", "", "", "", "", - "gru.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "name.cy", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "git-repos.de", - "", "", "", "", "", "", "", "", - "harima.hyogo.jp", - "", "", "", "", "", - "horokanai.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "cc.mn.us", - "", "", "", "", - "shiroishi.saga.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "nagasaki.jp", - "", "", "", "", "", "", "", - "rv.ua", - "", "", "", - "nome.pt", - "", "", - "caalwaysdata.net", - "", "", "", "", "", "", "", "", "", - "", - "yusuhara.kochi.jp", - "", "", - "adv.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "chita.aichi.jp", - "miasa.nagano.jp", - "her\303\270y.m\303\270re-og-romsdal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "naturbruksgymn.se", - "", - "ogata.akita.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "daegu.kr", - "", "", "", "", "", "", "", "", - "uconnect", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "ota.gunma.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "crew.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "yoga", - "sch.ae", - "", "", - "r.bg", - "", "", "", "", "", "", "", "", "", - "", "", "", - "kaminokawa.tochigi.jp", - "", "", "", - "cloud.metacentrum.cz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "shiftedit.io", - "", "", "", "", "", "", "", "", "", - "", "", - "artanddesign.museum", - "", "", - "capetown", - "", "", "", "", "", "", "", "", "", - "", "", "", - "sch.jo", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "hofu.yamaguchi.jp", - "", - "foggia.it", - "", "", "", "", "", - "rec.ro", - "", "", - "frei.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "grocery", - "", "", - "rocks", - "", "", "", "", "", "", "", - "ora.gunma.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "rec.co", - "", "", "", "", "", "", "", "", "", - "res.in", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "gs.nt.no", - "", "", "", "", "", "", "", "", "", - "", - "rest", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "misato.wakayama.jp", - "", "", "", "", "", "", "", - "edeka", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "kariya.aichi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "rent", - "", - "utazu.kagawa.jp", - "", "", "", "", "", "", "", "", - "cityeats", - "", "", "", "", "", "", "", "", "", - "kainan.tokushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "familyds.org", - "org", - "", "", "", - "emilia-romagna.it", - "", "", - "sumoto.hyogo.jp", - "", "", "", "", "", "", - "yamanashi.jp", - "minamiuonuma.niigata.jp", - "", "", "", "", "", "", "", - "ogose.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "\351\233\273\350\250\212\347\233\210\347\247\221", - "", "", "", "", "", "", "", "", - "agano.niigata.jp", - "", "", "", - "farm.museum", - "org.tm", - "", "", "", "", - "org.om", - "", "", "", - "diet", - "org.to", - "", "", "", "", "", - "kawachinagano.osaka.jp", - "", "", "", - "org.so", - "gs.ah.no", - "", "", "", "", "", "", "", "", "", - "", "", "", - "onion", - "org.am", - "", "", "", "", "", "", "", - "nagano.jp", - "kawaba.gunma.jp", - "", "", "", "", "", "", - "grane.no", - "", "", "", - "gose.nara.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "rio", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "ovre-eiker.no", - "", - "kamakura.kanagawa.jp", - "org.sh", - "", "", "", "", "", "", "", "", - "amex", - "rost.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "school", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "rm.it", - "", "", "", "", - "ro.im", - "", - "org.ro", - "", "", "", "", "", "", "", "", "", - "", - "attorney", - "", "", "", "", "", "", - "santabarbara.museum", - "", - "org.tn", - "", "", "", "", "", "", - "hagebostad.no", - "", "", - "org.sn", - "", "", "", "", - "it", - "", "", "", "", - "io", - "", "", "", "", - "is", - "", "", "", "", - "org.co", - "", "", - "is.it", - "", "", "", "", - "it.ao", - "oz.au", - "", "", "", "", "", "", "", "", "", - "\345\244\247\346\213\277", - "", - "yonago.tottori.jp", - "itau", - "", "", "", "", "", "", "", "", "", - "koshu.yamanashi.jp", - "", "", "", "", "", "", - "\353\213\267\354\273\264", - "", "", "", "", - "vivo", - "", "", "", "", "", "", "", "", "", - "", - "org.sa", - "", "", - "cc.tx.us", - "", "", - "ist", - "", "", "", "", "", "", - "ia.us", - "", - "ie", - "", - "usuki.oita.jp", - "", "", "", "", "", "", "", "", - "emerck", - "", - "wajiki.tokushima.jp", - "", - "org.ai", - "", "", "", - "oy.lc", - "", "", "", "", - "schule", - "", "", "", "", "", - "run.app", - "", "", - "\340\244\255\340\244\276\340\244\260\340\245\213\340\244\244", - "", "", "", - "2000.hu", - "", - "communications.museum", - "", "", - "on-the-web.tv", - "", "", "", "", "", - "chirurgiens-dentistes.fr", - "", "", "", "", "", "", - "sanuki.kagawa.jp", - "", - "2038.io", - "nexus", - "", "", "", "", "", "", "", "", "", - "higashiomi.shiga.jp", - "", "", "", "", "", "", "", "", "", - "", - "net.ws", - "oarai.ibaraki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "ir", - "", - "kashiwara.osaka.jp", - "kamisunagawa.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "recht.pro", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "org.cn", - "", "", "", "", "", "", "", "", - "com.ws", - "", "", "", "", "", - "org.uk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "game-host.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "nom.es", - "", "", "", - "funahashi.toyama.jp", - "", "", "", "", "", "", "", "", "", - "murakami.niigata.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "org.ci", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "com.es", - "", "", "", "", "", - "rentals", - "", "", "", "", "", - "gs.nl.no", - "", "", - "\346\224\277\345\212\241", - "", "", "", - "oppdal.no", - "", "", - "kurume.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", - "aurskog-h\303\270land.no", - "", "", - "org.sl", - "", "", "", "", "", "", "", - "kawaue.gifu.jp", - "\346\213\233\350\201\230", - "", "", "", "", - "nom.rs", - "", "", "", "", "", "", - "omura.nagasaki.jp", - "", "", "", - "org.al", - "", - "ouchi.saga.jp", - "", - "kamo.niigata.jp", - "", "", "", "", "", "", - "sex", - "", "", "", "", "", "", "", "", "", - "", - "i.se", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "org.im", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "sexy", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "browsersafetymark.io", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "saroma.hokkaido.jp", - "", "", - "org.lk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "glug.org.uk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "org.ua", - "", "", "", "", "", "", "", - "yonabaru.okinawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "moriyama.shiga.jp", - "", "", "", - "yac.za", - "", "", - "kanna.gunma.jp", - "", "", "", "", "", "", - "finance", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "condos", - "", "", "", - "rg.it", - "", "", "", - "gen.mi.us", - "davvenj\303\241rga.no", - "", "", "", "", "", "", "", "", "", - "", "", - "org.in", - "box", - "", "", - "ggf.br", - "", - "aki.kochi.jp", - "", "", "", - "s3.dualstack.ap-northeast-2.amazonaws.com", - "", "", "", "", "", "", - "rich", - "", - "shintoku.hokkaido.jp", - "", "", "", "", "", "", "", "", - "!city.kitakyushu.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "or.tz", - "", "", "", "", - "\353\213\267\353\204\267", - "org.tj", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "medio-campidano.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "nagi.okayama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "il", - "", "", "", "", "", "", "", "", "", - "guitars", - "", "", "", "", "", "", "", "", "", - "", - "mov", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "koori.fukushima.jp", - "il.us", - "net.is", - "", "", "", "", "", "", "", "", "", - "", - "org.la", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "r\303\245de.no", - "", "", "", - "org.vn", - "", "", "", - "ru.com", - "", "", "", "", - "nsn.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "com.is", - "", "", "", - "movie", - "", "", "", "", "", "", "", "", - "kawanishi.hyogo.jp", - "", "", - "boehringer", - "", "", "", "", - "firm.nf", - "", "", "", "", - "asso.ci", - "", "", "", "", "", "", - "haboro.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "r\303\270st.no", - "", "", "", - "org.vi", - "", "", "", - "net.ls", - "", "", "", "", "", "", - "v\303\245gs\303\270y.no", - "", "", "", "", "", "", "", "", "", - "", - "i.ng", - "", "", "", "", "", "", "", "", - "embroidery.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "fox", - "", "", "", - "org.il", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "org.dm", - "", - "i.ph", - "", "", "", "", "", - "otaki.chiba.jp", - "", - "org.do", - "", "", "", "", "", "", "", - "minoh.osaka.jp", - "", "", "", "", "", "", - "kvam.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "next", - "", - "2ix.ch", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "hvaler.no", - "", "", "", - "funabashi.chiba.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "repair", - "", "", - "i.bg", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "romsa.no", - "", "", "", "", "", "", "", "", "", - "chuo.yamanashi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "swiebodzin.pl", - "", "", "", "", "", "", "", "", "", - "", "", - "narita.chiba.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "rn.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "icu", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "ro.eu.org", - "", "", "", "", - "go-vip.co", - "", "", "", "", "", "", "", "", "", - "", "", "", - "id", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "buzen.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "id.us", - "", "", "", "", "", "", "", "", - "blogspot.co.za", - "", "", "", - "redstone", - "", "", "", "", - "kurogi.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "meiwa.mie.jp", - "", - "k12.wy.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "setagaya.tokyo.jp", - "namegawa.saitama.jp", - "", - "daisen.akita.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "fedje.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "sveio.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "org.mx", - "", "", "", "", "", "", "", "", "", - "", "", "", - "id.ir", - "", "", "", "", "", "", - "org.mk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "hiraya.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "org.mo", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "fresenius", - "environmentalconservation.museum", - "", "", "", "", "", "", - "bifuka.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "kaisei.kanagawa.jp", - "", "", "", "", "", "", - "susaki.kochi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "fed.us", - "", "", "", "", "", "", "", "", "", - "", "", - "s3.ap-south-1.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "", - "nishiwaki.hyogo.jp", - "", "", "", - "akaiwa.okayama.jp", - "", "", "", - "minamiashigara.kanagawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "k\303\241r\303\241\305\241johka.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "mywire.org", - "", "", "", "", "", "", "", - "os.hedmark.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "org.mn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "im", - "minano.saitama.jp", - "", "", "", "", "", "", - "im.it", - "", "", "", - "ru.eu.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "hotmail", - "", "", "", - "rns.tn", - "", "", - "enna.it", - "", "", "", - "mamurogawa.yamagata.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "id.au", - "", "", "", "", "", "", - "org.ma", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "org.tr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "xerox", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "org.ar", - "", "", "", "", "", "", "", - "okawa.kochi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "kitami.hokkaido.jp", - "", "", - "engine.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "net.ms", - "ogawa.ibaraki.jp", - "", "", "", "", "", "", "", "", "", - "", - "rissa.no", - "", "", "", "", "", "", "", "", "", - "", "", - "kagawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "com.ms", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "naganohara.gunma.jp", - "", "", - "keisen.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "himeji.hyogo.jp", - "", "", - "daiwa.hiroshima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "bergamo.it", - "", - "name.et", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "sondrio.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "org.ml", - "", "", "", "", - "iq", - "", "", "", "", "", "", "", "", - "broadcast.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "showa.yamanashi.jp", - "", "", "", "", "", - "yotsukaido.chiba.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "org.qa", - "", "", "", "", "", "", "", "", - "roma.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "civilisation.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "co.jp", - "", "", "", "", "", "", "", "", - "rocher", - "", "", - "esashi.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "ne.jp", - "", "", "", "", "", "", "", "", - "fhv.se", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "ogasawara.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "org.gh", - "", "", "", "", "", "", "", "", "", - "", "", - "mj\303\270ndalen.no", - "", "", - "godaddy", - "", - "asso.ht", - "", - "s3.cn-north-1.amazonaws.com.cn", - "", "", "", "", "", - "s3.us-east-2.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "koshimizu.hokkaido.jp", - "", - "davvenjarga.no", - "", - "edu.ws", - "", "", - "kawakami.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "yabu.hyogo.jp", - "", "", "", - "s3-ap-south-1.amazonaws.com", - "", "", "", "", "", "", "", - "community.museum", - "", "", "", "", "", - "org.gn", - "", "", "", "", "", "", "", "", "", - "", "", - "como.it", - "", "", - "ac.jp", - "", "", "", - "manno.kagawa.jp", - "", "", "", "", "", "", - "yamanashi.yamanashi.jp", - "", "", "", - "static-access.net", - "", "", "", "", "", "", "", "", "", - "", "", "", - "chirurgiens-dentistes-en-france.fr", - "", "", "", "", "", - "edu.es", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "org.gi", - "", "", "", "", - "org.ir", - "youtube", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "rnu.tn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "ong", - "", - "midori.gunma.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "edu.rs", - "", "", "", "", "", "", - "higashimatsushima.miyagi.jp", - "", "", - "newmexico.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "claims", - "", "", "", "", "", "", "", "", "", - "", - "org.lr", - "", "", - "communication.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "cloud66.ws", - "otobe.hokkaido.jp", - "", "", "", "", "", - "hidaka.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "myoko.niigata.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "marumori.miyagi.jp", - "", - "nagasaki.nagasaki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "financial", - "group.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "sydney.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "org.gl", - "", "", "", "", "", "", "", "", "", - "", "", - "showa.fukushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "kasuga.hyogo.jp", - "", "", "", "", "", "", "", "", "", - "", - "kui.hiroshima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "moscow.museum", - "", "", "", "", - "icbc", - "", - "sannan.hyogo.jp", - "", "", "", "", "", "", - "garden.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "cleaning", - "", "", "", "", "", - "idf.il", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "nx.cn", - "", "", "", - "mitaka.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "hotels", - "", "", "", "", "", "", "", "", - "fjaler.no", - "", - "in", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "edu.is", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "commbank", - "", "", "", "", "", - "it.eu.org", - "", "", "", "", "", "", "", - "saotome.st", - "", - "is.eu.org", - "in.us", - "", "", "", - "county.museum", - "", "", "", "", "", "", "", - "org.na", - "", "", "", "", - "org.ni", - "int", - "", "", "", "", "", "", - "in.ua", - "", - "s3-us-east-2.amazonaws.com", - "", "", "", "", "", - "sagae.yamagata.jp", - "", "", - "kred", - "", - "minami.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "sch.id", - "", "", "", "", "", - "org.gp", - "grong.no", - "", "", "", "", "", - "ie.eu.org", - "", "", "", "", "", "", "", "", "", - "", "", - "edu.ls", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "friulivgiulia.it", - "warabi.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "in.rs", - "", - "higashine.yamagata.jp", - "", "", "", "", "", "", "", - "yamato.fukushima.jp", - "", "", "", "", "", "", "", "", - "\345\262\251\346\211\213.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "kagoshima.jp", - "", "", "", - "blackbaudcdn.net", - "", "", "", "", - "ismaili", - "", "", "", - "hidaka.kochi.jp", - "", - "yoshioka.gunma.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "sx.cn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "settsu.osaka.jp", - "", "", "", "", - "ind.tn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "nagai.yamagata.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "int.co", - "", "", "", "", "", "", "", - "16-b.it", - "", "", "", "", "", "", "", - "cloudns.us", - "", "", "", "", "", - "usr.cloud.muni.cz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "ad.jp", - "", - "64-b.it", - "", "", "", - "fie.ee", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "ed.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "shiranuka.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "g12.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "org.se", - "", "", "", "", "", "", "", "", "", - "cloudns.in", - "", "", "", - "ras.ru", - "", "", "", "", "", "", "", "", "", - "", - "org.ae", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "org.ee", - "", "", "", "", "", "", - "googleapis.com", - "", "", "", "", - "cloudns.asia", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "higashiagatsuma.gunma.jp", - "", - "org.jo", - "", "", "", - "int.ci", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "yamashina.kyoto.jp", - "", "", "", - "seirou.niigata.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "sicilia.it", - "", "", "", "", - "firm.dk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "gbiz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "minamiminowa.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "crotone.it", - "", "", "", "", "", "", "", "", "", - "", "", - "il.eu.org", - "", "", "", "", "", "", "", "", - "4lima.at", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "diamonds", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "intel", - "", - "cloudns.eu", - "sandcats.io", - "", "", "", "", "", "", "", "", "", - "", "", "", - "int.lk", - "", - "inc", - "", "", "", "", "", "", "", "", "", - "", - "gamvik.no", - "", "", "", "", "", - "algard.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "rec.ve", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "ind.in", - "", "", "", "", "", "", "", "", "", - "", "", "", - "novara.it", - "", "", "", "", "", "", "", "", - "ostrowiec.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "ilawa.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "hisamitsu", - "", "", "", "", "", - "org.pk", - "", "", "", "", "", "", "", "", - "minami.kyoto.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "alvdal.no", - "", "", "", "", "", "", - "int.tj", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "edu.ms", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "bbe", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "kaga.ishikawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "org.ph", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "kosaka.akita.jp", - "", "", "", "", "", "", "", - "saxo", - "finnoy.no", - "otari.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", - "ferrara.it", - "", "", "", "", "", "", "", "", - "inf.ua", - "", "", "", "", - "int.la", - "", "", "", "", "", "", "", "", "", - "", - "org.gr", - "", "", "", "", "", "", - "insurance", - "", "", "", "", "", "", - "int.vn", - "armenia.su", - "", "", "", "", "", "", "", "", "", - "", "", "", - "kibichuo.okayama.jp", - "", "", "", "", - "marche.it", - "", - "org.pn", - "", "", "", "", "", - "beauxarts.museum", - "", "", "", - "catania.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "s3.dualstack.sa-east-1.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "suedtirol.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "org.pa", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "iwate.jp", - "", "", "", "", "", "", "", - "otaki.nagano.jp", - "", "", "", - "k12.ny.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "s3.dualstack.eu-west-3.amazonaws.com", - "minamidaito.okinawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "cloudns.cc", - "", "", "", "", "", "", "", "", "", - "", "", - "akune.kagoshima.jp", - "", "", "", - "sugito.saitama.jp", - "", "", "", - "org.ve", - "", "", "", "", "", "", "", "", "", - "", - "zgorzelec.pl", - "", - "ami.ibaraki.jp", - "net.ps", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "roros.no", - "", "", "", "", "", "", "", - "com.ps", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "yashio.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "chungbuk.kr", - "", "", "", "", "", "", - "engineer.aero", - "", "", - "org.au", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "org.pl", - "misato.shimane.jp", - "", "", - "rendalen.no", - "", "", "", "", - "hirono.iwate.jp", - "", "", "", "", "", "", "", "", "", - "rep.kp", - "", - "mjondalen.no", - "", "", "", "", "", "", "", "", "", - "", "", "", - "komaki.aichi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "omiya.saitama.jp", - "", "", "", "", "", "", "", "", "", - "s3.dualstack.eu-west-1.amazonaws.com", - "azurewebsites.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "s3.dualstack.us-east-1.amazonaws.com", - "", "", "", "", - "org.ru", - "", "", "", "", "", "", - "yamato.kanagawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "rodoy.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "org.cu", - "", "", "", "", "", - "kanuma.tochigi.jp", - "", "", - "union.aero", - "", - "radoy.no", - "", "", "", - "org.nr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "ditchyourip.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "ribeirao.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "firmdale", - "", "", "", "", "", "", "", "", "", - "kasama.ibaraki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "assabu.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "katano.osaka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "sennan.osaka.jp", - "", "", "", "", - "misato.akita.jp", - "", "", "", - "dnsiskinky.com", - "", "", "", - "shinshiro.aichi.jp", - "", "", "", "", - "insurance.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "bjark\303\270y.no", - "org.km", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "s3.eu-central-1.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "ryukyu", - "", "", "", "", - "inf.mk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "mitsue.nara.jp", - "", "", "", "", "", - "int.ar", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "shonai.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "giize.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "org.me", - "", "", "", "", - "org.kn", - "", "", "", "", "", "", "", "", "", - "ogano.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "sex.pl", - "", "", "", "", "", "", - "cloudns.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "org.ki", - "", "", "", "", - "org.bm", - "friuliv-giulia.it", - "", "", "", "", "", "", "", "", - "org.bo", - "", "", "", "", - "fujimi.nagano.jp", - "", "", - "homelinux.com", - "", - "komatsu", - "", "", "", - "warman", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "raid", - "", "", "", "", - "yurihonjo.akita.jp", - "mizumaki.fukuoka.jp", - "", "", "", "", "", "", "", - "res.aero", - "", "", "", - "org.vu", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "k12.ec", - "org.bh", - "duckdns.org", - "", "", "", "", - "organic", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "sassari.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "airbus", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "risor.no", - "", "", - "bounty-full.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "sec.ps", - "", "", "", "", "", "", - "masuda.shimane.jp", - "", "", "", "", "", "", "", "", - "org.bn", - "", "", "", - "norfolk.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "bradesco", - "", "", "", - "roan.no", - "", "", "", "", "", - "now-dns.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "org.ba", - "", "", "", "", - "org.bi", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "fujitsu", - "iamallama.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "med.ec", - "", "", - "hangout", - "", "", "", "", "", "", "", "", "", - "", - "homelinux.net", - "", "", "", - "immo", - "", "", "", "", "", - "reise", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "homedns.org", - "", "", "", "", - "obu.aichi.jp", - "", "", "", "", - "ibm", - "", "", "", "", "", "", "", - "net.bs", - "", "", - "shichikashuku.miyagi.jp", - "", "", "", - "dsmynas.org", - "", "", "", "", "", "", "", - "2ix.de", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "blogspot.mx", - "", "", "", "", "", "", "", "", "", - "", "", "", - "com.bs", - "", "", "", "", "", "", "", - "itayanagi.aomori.jp", - "", - "its.me", - "", "", "", "", - "ogawa.nagano.jp", - "kai.yamanashi.jp", - "", "", - "s3-eu-central-1.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "higashiura.aichi.jp", - "", "", "", "", "", "", "", "", "", - "", - "mormon", - "", "", "", "", "", "", - "entomology.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "avianca", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "org.ge", - "", "", "", "", "", - "grandrapids.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "yuu.yamaguchi.jp", - "", "", - "rl.no", - "", "", "", "", "", "", "", "", "", - "", "", - "org.kp", - "", - "imdb", - "", - "reisen", - "", "", "", "", "", "", - "ako.hyogo.jp", - "", "", "", "", "", "", - "go-vip.net", - "", "", - "yamaguchi.jp", - "in.eu.org", - "", "", - "git-pages.rit.edu", - "", "", "", "", "", "", "", "", - "nf", - "gratangen.no", - "", "", "", "", - "mypi.co", - "!city.yokohama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "af", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "org.pr", - "", "", "", - "cf", - "cfd", - "", "", "", "", - "cfa", - "", "", "", "", "", "", "", "", "", - "", "", - "achi.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "meiwa.gunma.jp", - "", - "science", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "\346\224\277\345\272\234.\351\246\231\346\270\257", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "yamato.kumamoto.jp", - "", "", - "bizen.okayama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "kazuno.akita.jp", - "", "", "", "", "", "", - "c.cdn77.org", - "", "", - "stalowa-wola.pl", - "", "", "", "", "", "", "", "", - "ooguy.com", - "nichinan.miyazaki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "unzen.nagasaki.jp", - "", "", "", "", - "nogata.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "reit", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "org.mu", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "kaneyama.yamagata.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "hirado.nagasaki.jp", - "", - "bahn.museum", - "", "", "", "", "", "", "", "", "", - "", "", - "is-by.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "shinanomachi.nagano.jp", - "kumakogen.ehime.jp", - "", "", - "ringsaker.no", - "", "", "", "", "", - "blogdns.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "sfr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "fujiyoshida.yamanashi.jp", - "int.ni", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "yonaguni.okinawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "maintenance.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", - "republican", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "cloudcontrolled.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "ca-central-1.elasticbeanstalk.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "udono.mie.jp", - "", "", "", "", "", "", "", "", - "karelia.su", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "karasuyama.tochigi.jp", - "", "", "", - "veg\303\245rshei.no", - "", "", "", "", "", "", "", "", "", - "edu.ps", - "", "", "", "", "", "", "", "", "", - "even\303\241\305\241\305\241i.no", - "", "", "", "", "", "", "", "", "", - "", - "cistron.nl", - "", "", "", "", "", "", "", "", "", - "nyuzen.toyama.jp", - "", "", "", "", "", - "dnsdojo.org", - "", "", "", "", "", "", - "nagareyama.chiba.jp", - "", "", - "ip6.arpa", - "hasami.nagasaki.jp", - "k12.ky.us", - "bf", - "", "", "", "", "", "", "", "", "", - "", - "myactivedirectory.com", - "", "", "", "", "", - "artcenter.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "org.sd", - "", "", - "s3.ca-central-1.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "africa", - "", "", "", "", "", "", "", - "kujukuri.chiba.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "hannan.osaka.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "mail.pl", - "", - "nextdirect", - "", "", "", "", "", "", "", - "yamada.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "oirase.aomori.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "miami", - "", "", "", "", - "everbank", - "", "", "", "", "", "", - "oumu.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "rec.br", - "", "", "", "", "", "", - "radom.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "aarborte.no", - "", "", "", "", "", "", "", - "biz.ls", - "", "", "", "", "", "", "", "", "", - "", - "org.hk", - "", "", "", "", "", "", "", "", "", - "org.gu", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "b\303\241jddar.no", - "", "", "", "", "", "", "", "", "", - "", - "kazimierz-dolny.pl", - "", "", "", "", "", - "eu-central-1.elasticbeanstalk.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "natal.br", - "hachioji.tokyo.jp", - "n\303\241vuotna.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "hyuga.miyazaki.jp", - "", "", "", "", "", "", "", "", - "komoro.nagano.jp", - "", "", "", - "station.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "kainan.wakayama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "ethnology.museum", - "", "", "", "", "", "", - "friulivegiulia.it", - "", "", "", "", "", "", "", "", - "natori.miyagi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "owariasahi.aichi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "info", - "", "", "", "", "", "", "", "", - "cloudns.pro", - "", "", "", - "org.hn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "guge", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "maniwa.okayama.jp", - "", "", "", "", "", "", "", "", - "recipes", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "insure", - "", "", "", "", "", "", "", "", "", - "fredrikstad.no", - "", "", "", "", "", "", "", "", "", - "", "", "", - "shiogama.miyagi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "gdansk.pl", - "", "", "", "", "", "", "", - "accountant", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "accountants", - "", "", - "costume.museum", - "", "", "", "", - "is-a-liberal.com", - "servecounterstrike.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "org.br", - "", "", "", "", "", "", "", "", "", - "org.je", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "synology-ds.de", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "gub.uy", - "", "", "", - "s3-ca-central-1.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "emergency.aero", - "vestby.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "kaita.hiroshima.jp", - "", "", "", "", "", "", "", "", - "uonuma.niigata.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "soundcast.me", - "", "", "", "", "", "", "", "", - "rio.br", - "", "", "", "", "", "", "", "", "", - "", - "is-a-musician.com", - "", "", - "mazury.pl", - "sciencecenters.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "kamisu.ibaraki.jp", - "moriguchi.osaka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "oharu.aichi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "info.na", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "go.tz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "exchange", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "omasvuotna.no", - "", "", "", "", "", "", "", "", "", - "", - "omi.niigata.jp", - "", "", "", "", "", - "kadoma.osaka.jp", - "barefoot", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "int.ve", - "", "", "", "", "", "", "", "", "", - "os.hordaland.no", - "", "", "", "", "", "", "", "", "", - "handson.museum", - "org.pe", - "", "", - "curitiba.br", - "", "", "", "", "", "", - "info.hu", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "niteroi.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "square7.ch", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "saarland", - "", - "yachimata.chiba.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "hotel.tz", - "", "", "", "", "", "", "", "", - "rmit", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "minamimaki.nagano.jp", - "info.ls", - "", "", "", - "edu.bs", - "", "", "", "", "", "", "", - "opole.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "ogi.saga.jp", - "", "", "", "", "", "", "", "", "", - "info.ke", - "raisa.no", - "", "", "", - "info.au", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "info.la", - "", "", "", "", "", "", "", "", "", - "oji.nara.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "yusui.kagoshima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "friulive-giulia.it", - "", - "akashi.hyogo.jp", - "", "", "", "", "", "", "", "", "", - "int.ru", - "", "", "", "", "", "", "", "", "", - "", "", - "sinaapp.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "services.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "oguni.kumamoto.jp", - "", "", "", "", "", "", "", - "futtsu.chiba.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "act.edu.au", - "", "", "", "", "", "", - "nf.ca", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "nosegawa.nara.jp", - "", "", "", "", "", "", "", "", - "minamifurano.hokkaido.jp", - "", "", "", "", "", "", - "barsy.bg", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "starachowice.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "servehttp.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "steiermark.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "is-a-libertarian.com", - "", "", "", "", "", "", - "info.pk", - "", "", "", "", "", "", "", - "nom.fr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "com.fr", - "", "", "", "", "", - "yawata.kyoto.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "matsue.shimane.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "shinto.gunma.jp", - "dyndns-server.com", - "clinique", - "", "", "", "", "", "", - "motosu.gifu.jp", - "", - "azure-mobile.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "inf.cu", - "", "", "", "", "", "", "", "", "", - "", - "\351\233\206\345\233\242", - "", "", "", "", "", "", - "sasebo.nagasaki.jp", - "", "", "", "", "", "", "", "", "", - "mx", - "heguri.nara.jp", - "", - "info.nr", - "", "", "", "", "", "", "", - "moe", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "newjersey.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "goto.nagasaki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "gjovik.no", - "siena.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "b\303\270mlo.no", - "", - "owani.aomori.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "medizinhistorisches.museum", - "", "", "", "", "", "", "", "", - "kamisato.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "qld.edu.au", - "", "", "", "", "", "", "", "", "", - "", "", - "yamanakako.yamanashi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "minato.osaka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "bloxcms.com", - "", "", "", "", "", "", "", - "consulado.st", - "", - "broadway", - "", "", "", "", "", "", "", "", "", - "", "", "", - "int.bo", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "okaya.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "murmansk.su", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "kvits\303\270y.no", - "", "", "", "", "", "", "", - "mifune.kumamoto.jp", - "", - "chino.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", - "fitness", - "", "", "", "", "", "", "", "", "", - "muika.niigata.jp", - "", "", "", "", - "i234.me", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "yamaga.kumamoto.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "sortland.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "genova.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "ariake.saga.jp", - "", "", "", "", - "shiroishi.miyagi.jp", - "", - "isa-geek.net", - "", "", "", "", "", "", "", "", "", - "store.bb", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "axis.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "indianapolis.museum", - "", "", "", - "gmina.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "freeddns.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "kiev.ua", - "", "", - "info.ki", - "", "", "", "", "", - "moriya.ibaraki.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "restaurant", - "", "", "", "", "", "", "", "", "", - "", - "static.land", - "", "", - "kamikawa.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "minamiyamashiro.kyoto.jp", - "", "", "", - "iris.arpa", - "yabuki.fukushima.jp", - "", "", "", "", "", - "synology.me", - "", - "4lima.ch", - "", "", "", "", "", "", "", "", - "utashinai.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "ringerike.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "info.pr", - "", "", "", "", - "oiso.kanagawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "hlsvtcjs.org", - "", "", "", "", "", "", "", "", "", - "", "", "", - "honefoss.no", - "", "", "", "", - "feedback", - "newyork.museum", - "", "", "", "", - "uto.kumamoto.jp", - "", - "skedsmokorset.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "mitsubishi", - "suzaka.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "academy.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "onna.okinawa.jp", - "info.ni", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "osaki.miyagi.jp", - "", "", "", "", "", - "mitoyo.kagawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "mizuho.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "cheap", - "", "", - "hammarfeasta.no", - "", "", "", "", "", "", "", "", "", - "", "", - "info.ro", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "higashisumiyoshi.osaka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "mitake.gifu.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "homelinux.org", - "meet", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "is-slick.com", - "", "", "", "", "", "", "", "", "", - "", "", - "groundhandling.aero", - "", "", "", - "dsmynas.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "fhsk.se", - "", "", "", "", - "fuoisku.no", - "", "", "", "", "", "", "", "", - "kitahiroshima.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", - "fuossko.no", - "", "", "", "", "", "", "", - "wme", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "sibenik.museum", - "", "", "", "", "", "", "", - "indianmarket.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "hinohara.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "servesarcasm.com", - "floripa.br", - "", "", "", "", - "barueri.br", - "", "", "", - "chosei.chiba.jp", - "childrens.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "embaixada.st", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "muroto.kochi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "fujisawa.iwate.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "karacol.su", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "imb.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "nsw.edu.au", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "mysecuritycamera.net", - "", "", - "ayabe.kyoto.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "dyndns-pics.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "in.na", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "semine.miyagi.jp", - "", "", "", - "indigena.bo", - "", - "obira.hokkaido.jp", - "", "", "", "", "", "", - "sciencecenter.museum", - "", "", "", "", "", "", "", "", "", - "", - "katori.chiba.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "stavern.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "alabama.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "a.prod.fastly.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "githubusercontent.com", - "", - "minakami.gunma.jp", - "", "", "", "", "", "", "", "", "", - "blogdns.com", - "", "", "", "", "", "", "", - "is-a-patsfan.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "castres.museum", - "ong.br", - "", - "saikai.nagasaki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "oizumi.gunma.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "higashitsuno.kochi.jp", - "", "", "", "", - "asaminami.hiroshima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "dyndns-wiki.com", - "", "", "", "", "", "", - "org.tw", - "", "", "", "", "", "", - "intelligence.museum", - "", "", "", "", "", "", "", "", "", - "mitou.yamaguchi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "marriott", - "", "", - "asso.eu.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "clinic", - "", "", "", "", "", "", "", "", "", - "obuse.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", - "kitagawa.kochi.jp", - "", "", "", "", "", "", "", "", "", - "shingo.aomori.jp", - "", "", "", "", - "savannahga.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "boomla.net", - "", "", "", "", "", "", "", - "nanjo.okinawa.jp", - "", "", "", "", "", - "steinkjer.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "dnsdojo.com", - "", "", "", "", "", "", "", - "is-very-evil.org", - "", "", "", - "shinshinotsu.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "v\303\245ler.hedmark.no", - "", "", "", - "crimea.ua", - "", "", - "dnsking.ch", - "", "", - "gushikami.okinawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "dyndns-at-work.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "blogsite.org", - "", - "carrier.museum", - "", "", "", "", "", "", "", "", "", - "", - "org.cw", - "", "", "", - "nago.okinawa.jp", - "", - "go.dyndns.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "kitamoto.saitama.jp", - "erotika.hu", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "in.ni", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "aya.miyazaki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "otoineppu.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "ind.br", - "", "", "", "", "", "", "", "", - "sauherad.no", - "", "", "", "", "", "", "", "", "", - "sweden.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "s\303\270mna.no", - "", - "dni.us", - "n\303\246r\303\270y.no", - "", - "r\303\241isa.no", - "", "", "", "", "", - "freemasonry.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "ninohe.iwate.jp", - "", "", "", - "ricoh", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "riik.ee", - "", "", "", "", "", - "homegoods", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "is-a-hard-worker.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "otake.hiroshima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "ashikaga.tochigi.jp", - "", "", "", "", "", "", "", "", - "motegi.tochigi.jp", - "savona.it", - "", "", "", "", "", "", - "wazuka.kyoto.jp", - "", "", "", "", - "aseral.no", - "", "", "", - "sanofi", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "matsubara.osaka.jp", - "", "", "", "", "", "", "", - "suwalki.pl", - "", "", "", - "co.business", - "", "", - "cloudns.club", - "", "", "", "", "", - "sunagawa.hokkaido.jp", - "", "", "", "", "", - "stadt.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "minamiaiki.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "inf.br", - "", "", "", "", "", "", "", "", "", - "", "", "", - "shiojiri.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "cechire.com", - "", "", "", - "kosai.shizuoka.jp", - "", "", "", "", "", "", - "is-a-landscaper.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "inc.hk", - "", "", "", "", - "oster\303\270y.no", - "", - "flesberg.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "versicherung", - "", "", "", "", "", "", "", "", "", - "", - "cleverapps.io", - "", "", "", - "onthewifi.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "in.th", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "assassination.museum", - "", "", "", "", "", "", "", "", - "cyon.site", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "\347\247\213\347\224\260.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "32-b.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "is-a-linux-user.org", - "", "", "", "", "", "", "", - "is-an-actress.com", - "", "", "", "", "", "", "", - "internet-dns.de", - "", "", "", "", "", "", - "higashiosaka.osaka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "fujinomiya.shizuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "or.mu", - "", "", - "saito.miyazaki.jp", - "", "", - "3utilities.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "riobranco.br", - "", "", "", "", "", - "ozu.ehime.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "gamagori.aichi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "info.nf", - "", "", "", "", - "elvendrell.museum", - "", "", "", "", - "sand\303\270y.no", - "", "", "", "", - "gouv.bj", - "", "", "", "", "", "", "", "", "", - "", "", "", - "yaotsu.gifu.jp", - "", "", "", "", - "co.mz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "sagamihara.kanagawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "mitane.akita.jp", - "", "", "", "", "", "", "", "", "", - "", - "cagliari.it", - "", "", "", - "cyber.museum", - "", - "ovh", - "", "", "", "", "", "", "", "", - "is-a-rockstar.com", - "", - "iida.nagano.jp", - "", "", "", "", "", "", - "neues.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "rawa-maz.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", - "is-a-republican.com", - "", - "kunitomi.miyazaki.jp", - "", "", "", - "sorocaba.br", - "", "", "", "", "", "", "", "", "", - "", "", "", - "arboretum.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "yasugi.shimane.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "ac.mz", - "cymru.museum", - "", "", "", "", - "mysecuritycamera.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "nagasu.kumamoto.jp", - "", "", "", - "now-dns.top", - "", "", "", "", "", "", "", "", "", - "", - "dyndns-web.com", - "", "", - "org.hu", - "", "", - "eidfjord.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "dominic.ua", - "", "", "", "", "", "", "", - "gz.cn", - "", "", "", "", "", "", "", "", "", - "", "", - "nirasaki.yamanashi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "interactive.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "omuta.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "isa-geek.com", - "", "", "", - "state.museum", - "", "", "", "", "", "", "", "", "", - "", - "\303\245seral.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "mypsx.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "iron.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", - "habmer.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "school.museum", - "", "", "", "", "", - "glogow.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "watch-and-clock.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "hapmir.no", - "", "", "", "", "", "", - "sch.ly", - "", "", "", "", - "sch.zm", - "", "", "", "", "", "", "", - "\320\270\320\272\320\276\320\274.museum", - "", "", "", "", "", "", "", - "org.mw", - "", "", "", "", "", "", "", "", "", - "", - "bzh", - "", "", "", - "barreau.bj", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "s3.dualstack.eu-west-2.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "s3.dualstack.us-east-2.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "stage.nodeart.io", - "baths.museum", - "", - "karikatur.museum", - "", "", "", "", "", "", "", "", - "oygarden.no", - "", "", "", "", "", "", "", "", "", - "", "", - "school.na", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "is-a-anarchist.com", - "", "", "", "", "", "", "", "", "", - "", "", "", - "sciencehistory.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "basel.museum", - "", "", "", "", - "murayama.yamagata.jp", - "", "", "", "", "", - "iyo.ehime.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "crafts.museum", - "", "", "", "", "", "", "", "", "", - "", - "matsuyama.ehime.jp", - "blogspot.cf", - "", "", "", - "rindal.no", - "", "", "", "", "", "", "", "", "", - "", - "ikano", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "ogori.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "yamada.iwate.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "russia.museum", - "", "", - "yasuda.kochi.jp", - "", "", "", "", "", "", - "ulvik.no", - "", "", "", "", "", "", "", - "mysecuritycamera.org", - "", "", "", - "nagaokakyo.kyoto.jp", - "", "", "", "", "", "", "", "", - "her\303\270y.nordland.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "mobara.chiba.jp", - "", "", "", "", "", "", "", - "dyndns.ws", - "", "", "", "", "", "", "", "", "", - "", "", - "bergbau.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "sex.hu", - "", - "4lima.de", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "ehime.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "foodnetwork", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "dyndns-mail.com", - "", - "info.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "yuzawa.niigata.jp", - "wajima.ishikawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "s3-ap-northeast-1.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "scrysec.com", - "", "", "", "", "", - "riodejaneiro.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "kagoshima.kagoshima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "s3-ap-southeast-1.amazonaws.com", - "", "", "", "", "", "", - "namsos.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "g\303\241ivuotna.no", - "", "", "", "", "", - "exposed", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "kanagawa.jp", - "", "", - "barsy.site", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "synology-diskstation.de", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "norddal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "oguni.yamagata.jp", - "", "", - "amber.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "cherkassy.ua", - "", - "is-a-painter.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "sor-fron.no", - "", "", - "okinawa", - "seika.kyoto.jp", - "", "", - "messina.it", - "", "", "", "", "", "", "", "", "", - "", "", - "urausu.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "higashimatsuyama.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "dattolocal.net", - "", "", - "batsfjord.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "yamanouchi.nagano.jp", - "etnedal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "mex.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "budejju.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "misaki.okayama.jp", - "", "", "", - "hamaroy.no", - "", "", "", - "honjo.akita.jp", - "", "", "", "", "", - "gov", - "", "", "", "", "", "", - "shinonsen.hyogo.jp", - "", "", - "dr\303\270bak.no", - "", "", - "stargard.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "gov.sx", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "honjo.saitama.jp", - "", - "gov.tm", - "", "", "", "", - "gov.om", - "wedeploy.me", - "", "", "", - "gov.to", - "", "", "", "", "", - "andriabarlettatrani.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "asago.hyogo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "haugesund.no", - "", "", "", "", "", "", - "k12.sc.us", - "", "", "", "", "", "", "", "", "", - "", "", "", - "customer.enonic.io", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "sf.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "gov.sh", - "", "", "", "", "", "", "", - "nagahama.shiga.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "watari.miyagi.jp", - "", "", - "minami-alps.yamanashi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "gov.cx", - "", "", "", "", "", "", "", "", - "ris\303\270r.no", - "", "", "", "", "", "", - "storfjord.no", - "", "", "", "", "", "", "", "", - "gov.tn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "gov.cm", - "", "", "", "", "", - "meguro.tokyo.jp", - "", "", "", - "gov.co", - "", "", "", "", - "comunica\303\247\303\265es.museum", - "", "", "", "", "", "", - "okawa.fukuoka.jp", - "", "", "", - "friuli-ve-giulia.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "shiriuchi.hokkaido.jp", - "", "", "", "", "", "", "", - "dyndns-work.com", - "", "", "", "", "", "", "", "", "", - "gov.sa", - "", "", "", "", "", "", - "info.ec", - "", "", "", "", "", "", "", - "wegrow.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "chiryu.aichi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "iwate.iwate.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "hammerfest.no", - "", "", "", "", - "ericsson", - "", "", "", "", - "accesscam.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "sanda.hyogo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "massacarrara.it", - "", "", "", "", - "gov.cn", - "", "", "", - "richardli", - "", - "alpha-myqnapcloud.com", - "is-a-democrat.com", - "", "", "", "", "", "", "", - "gov.uk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "force.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "vix.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "minowa.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "foundation", - "", "", "", "", "", "", "", "", - "is-an-artist.com", - "", "", "", - "gov.tl", - "", "", "", "", "", "", - "ox.rs", - "", "", - "gov.sl", - "", "", - "nanbu.tottori.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "mosj\303\270en.no", - "dyndns.tv", - "", "", "", "", "", - "gov.al", - "", "", "", - "gives", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "int.rw", - "", "", "", "", - "guovdageaidnu.no", - "matta-varjjat.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "koebenhavn.museum", - "", "", "", "", "", "", "", "", "", - "", "", - "fitjar.no", - "", "", "", "", "", "", "", "", "", - "r\303\241hkker\303\241vju.no", - "", "", "", "", "", "", "", "", "", - "", - "yoita.niigata.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "is-a-personaltrainer.com", - "", "", "", "", "", "", "", - "saitama.jp", - "", "", "", "", "", "", "", "", "", - "bajddar.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "omi.nagano.jp", - "gov.lk", - "", "", "", "", "", "", "", "", - "humanities.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "gov.ua", - "", "", - "mie.jp", - "", "", "", "", "", "", "", - "house.museum", - "", "", "", "", "", "", "", "", "", - "wedeploy.io", - "", "", "", "", "", "", "", "", - "gov.cl", - "", "", "", "", "", "", "", "", - "vanguard", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "gov.in", - "", "", "", "", "", "", - "stordal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "gov.tj", - "", "", "", "", "", "", "", "", "", - "", - "aerobatic.aero", - "", "", "", "", - "misaki.osaka.jp", - "", "", "", "", "", "", "", "", "", - "", - "murata.miyagi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "kyonan.chiba.jp", - "", "", "", "", "", "", - "macerata.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "krasnik.pl", - "", "", "", "", "", - "international", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "asmatart.museum", - "", "", - "misato.miyagi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "gov.la", - "", "", "", "", "", "", - "natural.bo", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "gov.vn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "syncloud.it", - "", "", "", "", - "yahoo", - "", "", "", "", "", "", "", "", - "chihayaakasaka.osaka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "feira.br", - "", "", "", "", "", "", - "iwatsuki.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "fbxos.fr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "gov.il", - "", - "sandnes.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "kragero.no", - "", "", - "gov.dm", - "", "", "", "", "", "", "", "", "", - "gov.do", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "ayase.kanagawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "noshiro.akita.jp", - "k12.dc.us", - "", "", "", "", - "oyer.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "rsc.cdn77.org", - "", "", "", "", "", "", - "shinjo.nara.jp", - "", "", "", "", "", "", - "nagiso.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "maserati", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "nishiawakura.okayama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "myvnc.com", - "", "", "", "", "", "", - "depot.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "irish", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "vic.edu.au", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "fairwinds", - "", - "health.nz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "history.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "higashikagawa.kagawa.jp", - "dyndns-home.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "school.za", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "nagawa.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "gov.mk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "warmia.pl", - "", "", "", "", "", "", "", "", "", - "", - "gov.mo", - "", "", - "ozora.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "sorfold.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "freeddns.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "andriatranibarletta.it", - "", "", "", "", "", "", "", "", "", - "", "", - "karaganda.su", - "", "", "", "", "", "", "", "", "", - "brussel.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "gov.mn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "gov.ma", - "flekkefjord.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "gov.tr", - "", "", "", "", "", "", "", "", "", - "", "", - "consulting", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "\346\224\277\345\272\234.hk", - "gov.ar", - "", "", - "indian.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "mediocampidano.it", - "circus.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "national.museum", - "cci.fr", - "int.mw", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "civilaviation.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "kunohe.iwate.jp", - "", "", "", "", "", "", "", "", "", - "", - "mx.na", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "org.sy", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "florida.museum", - "", - "dyndns-at-home.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "gov.ml", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "wien", - "", "", "", "", "", "", "", "", "", - "", "", "", - "myfirewall.org", - "", - "yatomi.aichi.jp", - "", "", "", "", - "university", - "", "", "", "", "", "", "", - "rimini.it", - "", "", "", "", - "szex.hu", - "", "", "", "", "", "", "", "", "", - "rybnik.pl", - "gov.qa", - "", "", "", "", "", "", - "org.kw", - "hagi.yamaguchi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "nerdpol.ovh", - "", - "north-kazakhstan.su", - "", - "emiliaromagna.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "forsand.no", - "", "", "", "", "", "", "", "", "", - "isa-geek.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "org.cy", - "", "", "", "", "", "", "", - "gov.gh", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "shiroi.chiba.jp", - "", "", "", "", "", - "slattum.no", - "kamioka.akita.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "realtor", - "", "", "", "", "", "", "", "", "", - "nishimera.miyazaki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "semboku.akita.jp", - "", "", "", - "utsunomiya.tochigi.jp", - "", "", "", - "masaki.ehime.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "gov.gn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "k\303\245fjord.no", - "", "", "", "", "", "", "", "", - "capitalone", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "omega", - "", "", "", "", - "org.bw", - "", "", "", "", "", "", "", - "gov.gi", - "", "", "", "", - "gov.ir", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "aquarium.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "yawara.ibaraki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "org.uy", - "", "", - "odesa.ua", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "agdenes.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "spjelkavik.no", - "", "", "", "", - "gov.lr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "wf", - "", "", "", "", "", "", "", "", "", - "kozaki.chiba.jp", - "rebun.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "v\303\246r\303\270y.no", - "", "", "", "", "", "", "", "", "", - "", "", - "reg.dk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "is-very-nice.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "farsund.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "namegata.ibaraki.jp", - "", "", "", "", "", - "org.sb", - "", "", "", "", - "fetsund.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "kanegasaki.iwate.jp", - "", "", - "hirakata.osaka.jp", - "", "", - "org.ly", - "", "", "", "", - "org.zm", - "", - "k12.nc.us", - "", - "chonan.chiba.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "cricket", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "swidnik.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "download", - "", "", "", - "stor-elvdal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "satosho.okayama.jp", - "", "", "", "", "", "", "", "", "", - "", - "midori.chiba.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "vaporcloud.io", - "", "", "", "", "", "", "", "", "", - "", "", - "erimo.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "shisui.chiba.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "shioya.tochigi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "gemological.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "kunst.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "damnserver.com", - "", "", "", "", "", "", "", "", "", - "otsuki.kochi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "org.za", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "dyndns-blog.com", - "", "", "", "", - "enterprises", - "gosen.niigata.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "is-a-doctor.com", - "", "", "", "", "", "", "", "", "", - "", - "ddnsfree.com", - "", "", "", "", "", "", "", "", - "one", - "", "", "", "", "", "", "", "", "", - "", "", "", - "akishima.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "shingu.wakayama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "is-an-actor.com", - "", "", "", - "zushi.kanagawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "kr\303\270dsherad.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "genkai.saga.jp", - "", "", "", "", "", "", - "itako.ibaraki.jp", - "", "", "", - "kvafjord.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "anani.br", - "", "", "", "", "", "", - "chernihiv.ua", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "harstad.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "is-very-good.org", - "", "", "", "", "", "", "", "", "", - "choshi.chiba.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "kumamoto.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "gov.mr", - "", "", "", "", "", "", - "org.lb", - "imari.saga.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "fuel.aero", - "", "", "", - "gov.ae", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "virtual.museum", - "", "", - "aogaki.hyogo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "ojiya.niigata.jp", - "", "", - "gov.ee", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "gov.jo", - "", "", "", "", "", "", - "global.prod.fastly.net", - "", "", "", - "mansion.museum", - "", "", "", "", "", "", "", - "kasamatsu.gifu.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "fujisawa.kanagawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "stranda.no", - "", "", "", "", "", "", - "verm\303\266gensberater", - "", "", "", "", "", "", "", - "scholarships", - "", "", "", "", "", "", "", "", "", - "org.my", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "space.museum", - "", "", "", - "kasaoka.okayama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "ipiranga", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "webhop.biz", - "hiratsuka.kanagawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "avoues.fr", - "", "", "", - "research.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "bristol.museum", - "", "", "", "", - "wedeploy.sh", - "", "", "", "", "", "", "", "", - "in-dsl.net", - "", "", "", "", - "\304\215\303\241hcesuolo.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "yachts", - "", "", "", "", "", "", "", "", - "mmafan.biz", - "", "", "", "", "", "", "", "", "", - "scienceandindustry.museum", - "", "", "", - "kudamatsu.yamaguchi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "koza.wakayama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "gov.pk", - "", "", "", "", "", "", - "vagsoy.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "is-a-knight.org", - "", "", "", "", "", "", "", "", "", - "", "", - "championship.aero", - "mangyshlak.su", - "", "", - "scrapper-site.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "h\303\270ylandet.no", - "", "", "", - "santacruz.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "cloudcontrolapp.com", - "", "", "", - "vennesla.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "shinkamigoto.nagasaki.jp", - "", "", "", "", "", "", "", "", "", - "iz.hr", - "", "", "", "", - "gov.ph", - "", - "nagano.nagano.jp", - "", "", "", "", "", "", "", - "worse-than.tv", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "yugawara.kanagawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "gov.ie", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "gov.gr", - "", "", "", "", - "samukawa.kanagawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "burghof.museum", - "", "", - "africa.com", - "", - "kv\303\246fjord.no", - "", "", "", - "gov.pn", - "", "", "", "", - "freeboxos.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "kamikawa.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "dinosaur.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "ashiya.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "\303\270rskog.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "barsy.info", - "", "", "", "", "", "", "", - "ivgu.no", - "", "", "", "", "", "", "", "", - "nagara.chiba.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "czest.pl", - "", "", "", "", - "gov.ve", - "", "", "", "", "", "", - "org.gy", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "naha.okinawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "nanto.toyama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "exchange.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "rygge.no", - "", "", "", "", "", "", - "gov.au", - "", "", "", "", "", "", "", "", - "ujitawara.kyoto.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "shingu.fukuoka.jp", - "", - "gov.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "ann-arbor.mi.us", - "", "", - "or.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "chernigov.ua", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "b\303\245d\303\245ddj\303\245.no", - "", - "id.ly", - "", "", "", "", "", "", "", "", "", - "", "", "", - "dyndns-ip.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "asahi.toyama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "gov.ru", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "ikawa.akita.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "gov.cu", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "gov.nr", - "", "", "", "", "", - "kiho.mie.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "beskidy.pl", - "", - "scienceandhistory.museum", - "", - "kagami.kochi.jp", - "", "", "", "", "", "", "", "", "", - "", - "moareke.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "other.nf", - "", "", "", "", "", "", "", "", "", - "", - "foundation.museum", - "", - "vf.no", - "", "", "", "", "", "", "", - "k12.as.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "noheji.aomori.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "noda.chiba.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "gob.ec", - "", "", "", "", "", "", "", "", - "forlicesena.it", - "", "", - "eidskog.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "osakikamijima.hiroshima.jp", - "", "", "", "", "", "", "", - "gov.km", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "hiranai.aomori.jp", - "", "", "", "", "", "", "", "", "", - "kasai.hyogo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "starhub", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "kamikawa.hyogo.jp", - "", "", "", "", "", "", "", "", "", - "", - "kitagata.saga.jp", - "", "", - "western.museum", - "", "", "", "", "", "", "", - "space-to-rent.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "id.lv", - "", "", "", - "yamaxun", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "missile.museum", - "", "", "", - "on-web.fr", - "", "", "", "", "", "", "", "", "", - "gov.me", - "", "", "", "", - "gov.kn", - "north.museum", - "", "", "", "", "", "", "", "", "", - "freebox-os.com", - "", "", "", "", "", "", "", "", "", - "", "", "", - "\345\245\210\350\211\257.jp", - "", "", "", "", "", - "virtualuser.de", - "", - "monzaedellabrianza.it", - "", "", "", "", "", "", "", "", "", - "", "", - "ina.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "myhome-server.de", - "", "", "", "", "", "", "", "", - "gov.ki", - "", "", "", "", - "gov.bm", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "britishcolumbia.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "kamitonda.wakayama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "ind.kw", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "gov.bh", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "khakassia.su", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "kamiichi.toyama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "sosa.chiba.jp", - "", - "gov.bn", - "", "", "", "", "", "", "", "", "", - "", "", "", - "customer.speedpartner.de", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "dyn.home-webserver.de", - "", "", "", "", "", "", "", "", "", - "furukawa.miyagi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "gov.ba", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "air-surveillance.aero", - "", "", "", "", "", - "sannohe.aomori.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "in-the-band.net", - "", "", "", "", - "southcarolina.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "coastaldefence.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "my-router.de", - "", "", - "s3.ap-northeast-2.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "ukiha.fukuoka.jp", - "", - "hattfjelldal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "mypets.ws", - "", "", "", "", "", "", "", "", - "energy", - "", "", "", - "medecin.km", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "matsubushi.saitama.jp", - "", "", - "friuli-vegiulia.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "hamburg.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "friuli-vgiulia.it", - "", "", "", "", "", "", "", "", "", - "settlers.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "gov.ge", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "gov.kp", - "", "", - "ono.hyogo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "kami.miyagi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "yasaka.nagano.jp", - "ing", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "grozny.ru", - "", "", "", "", - "\303\245snes.no", - "gov.pr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "kin.okinawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "finn\303\270y.no", - "", - "microsoft", - "", "", - "h\303\241bmer.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "ota.tokyo.jp", - "", "", "", "", "", "", - "histoire.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "ap-southeast-1.elasticbeanstalk.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "clock.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "kyotamba.kyoto.jp", - "", "", "", "", "", - "ranzan.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "gov.mu", - "", "", "", "", "", "", "", "", "", - "", "", - "org.py", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "wzmiuw.gov.pl", - "omachi.saga.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "enonic.io", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "rugby", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "monzabrianza.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "clinton.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "s3-ap-northeast-2.amazonaws.com", - "", "", "", "", "", "", "", "", - "chimkent.su", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "verm\303\266gensberatung", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "grozny.su", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "skanland.no", - "hughes", - "", "", - "k12.ms.us", - "", "", - "s3-ap-southeast-2.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "cadaques.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "mydissent.net", - "", - "gov.sd", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "dynvpn.de", - "", "", "", "", "", "", "", "", "", - "university.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "qld.gov.au", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "sciencesnaturelles.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "zapto.xyz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "yugawa.fukushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "vestnes.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "friuli-v-giulia.it", - "", "", - "cust.dev.thingdust.io", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "fuchu.toyama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "gov.cd", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "gov.hk", - "", "", "", "", "", - "medical.museum", - "", "", "", - "gov.gu", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "stuff-4-sale.org", - "", "", "", "", - "custom.metacentrum.cz", - "", "", "", "", "", "", - "gs.mr.no", - "", "", "", "", "", "", "", "", "", - "", - "konskowola.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "dynamic-dns.info", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "jot", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "je", - "", "", "", "", "", "", - "childrensgarden.museum", - "fosnes.no", - "", - "samegawa.fukushima.jp", - "", "", "", "", - "uki.kumamoto.jp", - "", - "virtuel.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "net.tt", - "", "", "", "", "", "", "", "", "", - "net.st", - "", "", "", "", "", - "endofinternet.org", - "", "", "", "", "", "", "", "", - "nom.st", - "", "", "", "", "", "", - "bjarkoy.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "com.tt", - "", "", "", - "database.museum", - "", "", "", "", "", - "com.st", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "net.et", - "", "", "", "", "", "", - "jcp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "miniserver.com", - "", "", "", "", "", - "mizusawa.iwate.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "day", - "", "", "", "", - "soy", - "", "", "", "", "", "", "", - "com.et", - "", "", "", - "stuff-4-sale.us", - "", "", - "kamogawa.chiba.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "is-a-llama.com", - "", "", "", "", "", "", "", - "org.ky", - "", "", "", "", - "sunndal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "kamaishi.iwate.jp", - "", "", "", "", "", "", "", - "gov.br", - "", - "monticello.museum", - "", - "manaus.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "blogsite.xyz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "moonscale.net", - "", "", "", "", "", "", "", "", "", - "net-freaks.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "kumenan.okayama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "osen.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "hitachi.ibaraki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "yuza.yamagata.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "amami.kagoshima.jp", - "", "", "", "", "", "", - "reggioemilia.it", - "", "", "", "", "", "", - "jcb", - "", "", "", "", "", "", "", - "kagamino.okayama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "nationalheritage.museum", - "", "", "", "", "", "", "", "", - "endofinternet.net", - "001www.com", - "", "", "", - "media.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "jobs", - "", "", "", "", "", "", "", "", "", - "", - "bjerkreim.no", - "", "", "", "", "", "", - "higashikagura.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "yamada.toyama.jp", - "", "", "", "", "", "", "", - "cam.it", - "", "", "", "", "", "", - "diy", - "shinjo.okayama.jp", - "", - "immobilien", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "gouv.ci", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "arida.wakayama.jp", - "", "", "", "", - "sor-aurdal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "virginia.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "freedesktop.org", - "", - "no-ip.info", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "nanao.ishikawa.jp", - "", "", - "notogawa.shiga.jp", - "", "", "", "", "", "", "", - "sar.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "ritto.shiga.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "m\303\245s\303\270y.no", - "", "", "", "", "", - "j.bg", - "", - "dyndns.org", - "", "", "", "", "", "", "", "", "", - "", "", - "buy", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "bayern", - "", "", "", - "jetzt", - "", "", "", - "shimonita.gunma.jp", - "", "", "", "", "", - "hemnes.no", - "", "", "", "", "", "", "", "", "", - "gle", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "carbonia-iglesias.it", - "", - "ntdll.top", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "abeno.osaka.jp", - "", "", "", "", "", "", "", "", "", - "tw", - "", "", "", "", - "tt", - "", "", "", "", - "to", - "", "", "", "", - "name.tr", - "", "", - "to.it", - "direct", - "", "", "", - "ts.it", - "", "", "", - "sanjo.niigata.jp", - "", "", "", "", "", "", - "\331\203\331\210\331\205", - "", "", "", "", "", "", - "top", - "", "", - "in-vpn.net", - "", "", "", - "ta.it", - "", "", "", "", "", "", "", "", "", - "", "", "", - "\331\205\331\210\331\202\330\271", - "", - "airtraffic.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "nym.lt", - "", - "\330\252\331\210\331\206\330\263", - "", "", "", "", "", "", "", "", "", - "", "", - "\330\263\331\210\330\257\330\247\331\206", - "", - "gouv.rw", - "", "", - "te.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "\346\267\241\351\251\254\351\224\241", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "dvrdns.org", - "", "", "", "", "", "", "", "", "", - "", "", "", - "co.technology", - "", "", - "money.museum", - "nabari.mie.jp", - "", "", "", "", "", "", - "ascolipiceno.it", - "", "", "", "", "", "", "", - "org.bb", - "", - "te.ua", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "tr", - "", "", "", "", "", "", "", - "tr.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "nationalfirearms.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "tc", - "", "", "", "", "", "", "", "", "", - "", "", - "usa.oita.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "dynamisches-dns.de", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "dynserv.org", - "", "", "", - "wodzislaw.pl", - "", "", "", "", "", "", "", "", "", - "", "", - "tatar", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "in-dsl.org", - "", "", "", "", "", "", "", "", "", - "bahccavuotna.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "github.io", - "", "", "", "", "", "", "", "", "", - "today", - "", "", "", "", "", "", "", "", "", - "", - "bas.it", - "uruma.okinawa.jp", - "", "", "", "", "", - "gunma.jp", - "directory", - "", "", "", "", "", - "gaular.no", - "", "", "", "", "", "", "", - "kumamoto.kumamoto.jp", - "", "", "", "", - "jio", - "t.se", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "toray", - "", - "music.museum", - "randaberg.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "movimiento.bo", - "hirokawa.fukuoka.jp", - "", "", "", "", - "blogsyte.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "trade", - "", "", "", "", "", "", "", "", - "suginami.tokyo.jp", - "", "", "", "", "", "", "", "", - "off", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "couchpotatofries.org", - "", "", "", "", "", "", "", - "modalen.no", - "", "", "", "", - "jmp", - "", "", "", "", "", "", "", "", "", - "tab", - "", "", "", "", "", "", "", "", "", - "fly", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "koeln", - "", - "heritage.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "kitayama.wakayama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "fujisato.akita.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "net.mt", - "", "", - "biei.hokkaido.jp", - "", "", "", "", - "tiaa", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "dev-myqnapcloud.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "com.mt", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "tires", - "fjell.no", - "", "", "", - "mihara.hiroshima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "bronnoy.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "tl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "redumbrella", - "dyn-berlin.de", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "tana.no", - "", "", "", "", "", "", "", "", "", - "", - "shijonawate.osaka.jp", - "", "", "", - "kamitsue.oita.jp", - "", "", "", "", "", "", "", "", - "is-an-accountant.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "kasukabe.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", - "total", - "", "", "", "", "", "", "", "", "", - "tunes", - "", - "tv", - "", "", "", "", "", "", "", - "tv.it", - "off.ai", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "kurobe.toyama.jp", - "", "", "", "", "", - "fujioka.gunma.jp", - "", "", "", "", "", - "fedorainfracloud.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "uji.kyoto.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "tube", - "", "", "", - "shell", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "ohira.miyagi.jp", - "", - "ebino.miyazaki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "tips", - "", "", "", "", "", - "brussels.museum", - "", - "stateofdelaware.museum", - "higashichichibu.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "szczecin.pl", - "", - "avellino.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "kembuchi.hokkaido.jp", - "", "", - "gouv.ht", - "", - "m\303\241tta-v\303\241rjjat.no", - "", "", "", "", "", - "dyndns.info", - "", "", "", - "edu.tt", - "", "", "", "", "", "", "", - "t.bg", - "workshop.museum", - "edu.st", - "tcp4.me", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "oguchi.aichi.jp", - "", - "cancerresearch", - "", "", "", "", "", "", "", "", - "tvs", - "", "", "", "", "", "", "", - "tattoo", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "tours", - "", "", "", "", "", "", "", "", "", - "", - "edu.et", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "hanggliding.aero", - "", "", "", "", "", - "time.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "kashima.ibaraki.jp", - "td", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "emr.it", - "", "", "", "", - "sic.it", - "", "", - "istanbul", - "", "", "", "", "", "", "", "", - "itv", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "\303\270yer.no", - "", "", - "net.gt", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "nom.gt", - "", "", "", "", "", "", "", - "sande.more-og-romsdal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "com.gt", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "nedre-eiker.no", - "", "", "", "", "", "", "", "", "", - "", "", - "nahari.kochi.jp", - "", "", "", - "antiques.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "minnesota.museum", - "", "", "", "", "", - "is-a-designer.com", - "", "", "", "", "", "", "", "", "", - "kobayashi.miyazaki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "ap-northeast-3.elasticbeanstalk.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "kashima.saga.jp", - "", "", "", "", "", "", - "trust", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "travel", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "ggee", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "ashiya.hyogo.jp", - "", "", - "hachijo.tokyo.jp", - "", "", "", "", "", "", "", - "saijo.ehime.jp", - "", "", "", "", "", "", - "agency", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "org.iq", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "dnsupdater.de", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "wloclawek.pl", - "", "", "", - "tm", - "", "", "", "", "", "", "", - "tt.im", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "edu.it", - "", "", "", "", "", "", "", - "kitahata.saga.jp", - "", "", "", "", "", - "venezia.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "kouhoku.saga.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "viterbo.it", - "", "", "", - "soeda.fukuoka.jp", - "wpdevcloud.com", - "", "", "", "", "", "", "", "", "", - "", "", "", - "ap-northeast-1.elasticbeanstalk.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "tech", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "shingu.hyogo.jp", - "", "", "", "", - "odessa.ua", - "", "", "", - "gob.es", - "", "", "", - "tm.ro", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "amagasaki.hyogo.jp", - "tm.fr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "k12.ks.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "artsandcrafts.museum", - "", "", "", "", - "tv.tr", - "", "", "", "", "", "", "", - "inabe.mie.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "gov.tw", - "name.tj", - "", "", "", "", "", "", "", "", "", - "", "", - "\346\226\260\345\212\240\345\235\241", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "tushu", - "", "", "", "", "", "", "", - "info.bo", - "miners.museum", - "", "", "", "", "", "", "", "", "", - "", - "tm.se", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "info.mv", - "", "", "", "", "", "", "", "", "", - "yura.wakayama.jp", - "", "", "", "", "", "", "", "", "", - "noboribetsu.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "travelers", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "firewall-gateway.de", - "", "", "", "", "", - "firewall-gateway.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "gov.rw", - "", "", "", "", - "kunstsammlung.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "eu.int", - "", "", "", - "kerryproperties", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "green", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "tg", - "", "", "", - "shizuoka.shizuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "azerbaijan.su", - "ing.pa", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "magazine.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "tv.sd", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "kotoura.tottori.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "merckmsd", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "ontario.museum", - "", "", "", "", "", "", "", "", "", - "s3.eu-west-3.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "tv.im", - "", "", "", "", "", "", "", "", - "shinjuku.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "kvitsoy.no", - "", "", "", "", "", "", "", - "tur.ar", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "chizu.tottori.jp", - "", "", "", - "kanzaki.saga.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "ikata.ehime.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "tm.za", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "firm.co", - "", "", "", "", "", "", "", - "aviation.museum", - "", - "servebbs.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "edu.mt", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "kamikitayama.nara.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "nuernberg.museum", - "", "", "", "", "", "", "", "", - "tunk.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "tn", - "univ.sn", - "", "", "", - "gonohe.aomori.jp", - "", "", - "tn.it", - "", "", "", "", "", "", "", "", "", - "iitate.fukushima.jp", - "", "", "", "", "", - "annefrank.museum", - "", - "kviteseid.no", - "", "", "", "", "", "", "", "", - "jp", - "", "", - "sandiego.museum", - "", "", - "gmx", - "", - "mansions.museum", - "", "", "", "", - "tn.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "higashiyama.kyoto.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "tm.hu", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "gratis", - "", "", "", "", "", "", - "in-berlin.de", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "mashiki.kumamoto.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "net.pt", - "", "", "", "", "", "", - "shimoichi.nara.jp", - "", "", "", "", "", - "tr.eu.org", - "", "", - "open", - "", "", "", "", "", - "kawanehon.shizuoka.jp", - "", "", "", "", "", "", "", "", - "s3-us-west-1.amazonaws.com", - "", "", "", "", "", - "morimachi.shizuoka.jp", - "", "", - "komatsushima.tokushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "is-an-anarchist.com", - "com.pt", - "gouv.sn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "b\303\270.nordland.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "os\303\270yro.no", - "", "", "", "", "", "", "", "", "", - "symantec", - "", "", "", - "kawagoe.mie.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "s3-eu-west-3.amazonaws.com", - "", - "k12.fl.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "accenture", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "ees3.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "go.jp", - "ino.kochi.jp", - "jprs", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "omachi.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "edu.gt", - "", - "tydal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "susono.shizuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "nym.pt", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "ina.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "gr.jp", - "", "", "", "", "", - "jjo", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "s3-eu-west-1.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "int.eu.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "kodaira.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "jeju.kr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "kuromatsunai.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "tm.km", - "", "", "", - "reggio-calabria.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "oi.kanagawa.jp", - "", "", "", - "gov.mw", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "js.cn", - "", "", "", "", "", - "saitama.saitama.jp", - "", "", "", - "inzai.chiba.jp", - "", - "tj", - "", - "nankoku.kochi.jp", - "", "", - "warszawa.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "test.ru", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "ybo.science", - "", "", "", "", "", "", "", "", "", - "nishiaizu.fukushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "geisei.kochi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "firewall-gateway.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "abudhabi", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "isa.kagoshima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "temasek", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "shima.mie.jp", - "", "", "", "", "", "", "", "", - "ingatlan.hu", - "", "", "", "", "", "", "", "", "", - "", "", "", - "tm.cy", - "", "", "", "", "", "", "", - "kudoyama.wakayama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "ooreadthedocs.io", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "gx.cn", - "", - "usarts.museum", - "", "", "", "", "", "", "", "", "", - "shimamoto.osaka.jp", - "", "", "", "", "", "", "", "", "", - "", - "tp.it", - "", "", "", "", "", "", "", "", "", - "", "", - "birthplace.museum", - "vpndns.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "targi.pl", - "", - "greta.fr", - "", "", "", "", "", "", - "aizubange.fukushima.jp", - "", - "ashoro.hokkaido.jp", - "", "", "", - "sky", - "", "", "", "", "", - "realm.cz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "training", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "quicksytes.com", - "", "", "", "", "", "", "", "", - "yaese.okinawa.jp", - "", "", "", "", "", - "read-books.org", - "", "", "", "", - "baseball.museum", - "", "", "", - "my-wan.de", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "tank.museum", - "", "", "", - "miura.kanagawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "air-traffic-control.aero", - "", "", "", "", "", "", - "net.bt", - "", "", "", "", "", "", "", "", - "rad\303\270y.no", - "mesaverde.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "office", - "", "", - "hobby-site.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "com.bt", - "", "", "", "", - "time.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "jl.cn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "in-vpn.org", - "", "", "", - "vic.gov.au", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "yamagata.jp", - "", "", "", "", "", "", "", "", - "midsund.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "jewishart.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "sdn.gov.pl", - "", "", "", "", "", "", - "yoichi.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "of.by", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "higashiizumo.shimane.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "firestone", - "", "", "", "", "", "", "", "", "", - "ruhr", - "", "", "", "", "", "", - "biz.tt", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "saga.saga.jp", - "", "", "", "", "", "", - "countryestate.museum", - "oregon.museum", - "", "", "", "", - "biz.at", - "", "", "", "", "", "", - "minamata.kumamoto.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "biz.et", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "shibecha.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "osteroy.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "tw.cn", - "", "", "", "", "", "", "", "", "", - "", "", - "otago.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "abr.it", - "", "", "", "", "", "", "", "", "", - "r\303\270mskog.no", - "", - "okayama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "tiffany", - "", "", "", "", "", - "org.zw", - "", - "tv.bo", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "tas.au", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "room", - "", "", - "averoy.no", - "honjyo.akita.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "ven.it", - "", "", "", "", "", "", "", "", "", - "", - "mmayfirst.info", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "tk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "ap-southeast-2.elasticbeanstalk.com", - "", "", "", "", "", - "contact", - "tirol", - "", "", "", "", "", "", "", - "eigersund.no", - "", "", "", "", "", "", - "tv.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "edu.pt", - "", "", "", "", "", "", "", "", - "utazas.hu", - "", "", "", "", "", "", "", "", "", - "", "", "", - "\346\276\263\351\226\200", - "", "", - "taobao", - "", "", "", "", "", "", "", "", "", - "", "", - "vestre-slidre.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "jgora.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "historichouses.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "maritimo.museum", - "kawagoe.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "flanders.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "akagi.shimane.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "tychy.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "jnj", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "bihoro.hokkaido.jp", - "", "", "", - "yao.osaka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "watarai.mie.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "tec.ve", - "", "", "", "", "", - "jur.pro", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "servebbs.com", - "", "", "", "", "", "", "", "", "", - "shintomi.miyazaki.jp", - "", "", "", "", "", "", "", "", "", - "org.sc", - "", "", "", "", "", "", "", - "security", - "", "", - "mragowo.pl", - "for-the.biz", - "", "", "", "", "", "", "", "", "", - "", "", "", - "org.ac", - "", "", "", "", - "georgia.su", - "", "", "", "", - "umaji.kochi.jp", - "", "", "", "", - "jpn.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "maritime.museum", - "", "", "", "", "", "", - "org.ec", - "", "", "", "", "", - "vao.it", - "", "", "", "", "", "", - "zamami.okinawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "nesoddtangen.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "meraker.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "firm.ht", - "", "", "", "", "", "", - "is-very-bad.org", - "", "", "", "", "", "", "", "", - "shiso.hyogo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "health.vn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "marburg.museum", - "", - "jp.eu.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "vda.it", - "", "", "", "", "", "", - "healthcare", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "beeldengeluid.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "net.ht", - "", "", "", "", "", "", "", - "nisshin.aichi.jp", - "karmoy.no", - "", "", "", "", "", "", - "ozu.kumamoto.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "com.ht", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "hirara.okinawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "se.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "nesseby.no", - "", "", "", "", "", "", "", - "art.ht", - "", "", "", "", "", "", - "turin.it", - "kaizuka.osaka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "iwaki.fukushima.jp", - "", "", "", "", "", "", "", "", "", - "", - "applicationcloud.io", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "architecture.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "nozawaonsen.nagano.jp", - "", "", - "withgoogle.com", - "", "", "", "", "", "", "", "", "", - "", "", - "dupont", - "", "", "", "", "", "", "", "", - "bialowieza.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "minamiizu.shizuoka.jp", - "", "", "", "", "", "", "", "", - "\303\270ystre-slidre.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "tra.kp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "barrel-of-knowledge.info", - "", "", "", "", "", "", "", - "org.lc", - "", "", "", "", "", "", "", "", - "jor.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "za.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "rishirifuji.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "trading", - "", "", "", "", - "org.vc", - "", "", "", "", "", - "olbia-tempio.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "arakawa.saitama.jp", - "", "", - "zuerich", - "ragusa.it", - "", "", "", "", "", "", "", "", "", - "", - "edu.bt", - "", "", "", - "fidelity", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "ochi.kochi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "alto-adige.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "kasugai.aichi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "heroy.more-og-romsdal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "!city.kobe.jp", - "", "", "", - "accident-investigation.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "yanagawa.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "ostroda.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "higashiyoshino.nara.jp", - "", "", "", "", "", "", - "school.nz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "myddns.rocks", - "", "", "", "", "", "", "", "", "", - "tgory.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", - "jab.br", - "", "", "", "", "", "", "", - "cust.disrec.thingdust.io", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "ivano-frankivsk.ua", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "gjerdrum.no", - "", "", "", - "shirakawa.fukushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "of.no", - "ito.shizuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "inatsuki.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "tr.no", - "", "", "", "", "", "", "", "", "", - "rwe", - "", - "arezzo.it", - "klodzko.pl", - "", "", "", "", - "rovno.ua", - "", "", "", "", "", "", "", "", - "th", - "thd", - "", "", "", "", "", "", "", "", - "bible.museum", - "tci", - "", "", "", "", "", "", "", "", "", - "", - "cloudns.biz", - "", "", "", "", "", "", "", "", "", - "", "", - "jus.br", - "", "", "", "", "", - "gangwon.kr", - "", "", "", "", "", "", "", "", "", - "omaha.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "gov.sy", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "gf", - "", "", "", "", "", "", "", "", "", - "", "", "", - "arakawa.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "mihama.wakayama.jp", - "", - "okuizumo.shimane.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "gov.kw", - "", "", - "koto.shiga.jp", - "", "", "", "", "", "", "", "", "", - "", - "oseto.nagasaki.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "shimokawa.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "tui", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "minamiise.mie.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "gov.cy", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "kawamata.fukushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "kumano.mie.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "masfjorden.no", - "", "", "", "", - "cn-north-1.eb.amazonaws.com.cn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "kwp.gov.pl", - "", "", "", "", "", "", "", "", - "jewelry", - "rauma.no", - "", "", "", - "\345\214\227\346\265\267\351\201\223.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "moseushi.hokkaido.jp", - "", "", "", "", "", "", - "yaizu.shizuoka.jp", - "", - "horonobe.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "is-a-bookkeeper.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "microlight.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "roma.it", - "", "", "", "", - "rome.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "sebastopol.ua", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "trd.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "tv.na", - "", "", "", "", "", "", "", "", "", - "", - "gojome.akita.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "rivne.ua", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "chigasaki.kanagawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "bungotakada.oita.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "myshopblocks.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "gov.sb", - "", "", "", "", "", "", "", "", - "vegarshei.no", - "", "", "", "", "", "", - "sande.vestfold.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "gov.ly", - "", "", "", - "higashiyodogawa.osaka.jp", - "gov.zm", - "", "", "", "", "", "", "", "", - "sowa.ibaraki.jp", - "", "", "", "", "", "", "", "", "", - "", - "jdf.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "yomitan.okinawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "naples.it", - "", "", "", "", "", "", - "munakata.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "tur.br", - "", "", "", "", - "oppegard.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "is-a-photographer.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "edu.ht", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "biella.it", - "", "", "", "", "", "", "", "", - "soundandvision.museum", - "", "", "", "", "", "", "", "", "", - "", "", - "r\303\246lingen.no", - "", "", - "gov.za", - "", "", "", "", - "hermes", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "hobby-site.com", - "", "", "", "", "", "", "", "", "", - "", - "asakuchi.okayama.jp", - "", "", "", "", "", "", - "tinn.no", - "", - "furniture", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "hu.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "christmas", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "chikuma.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "memorial.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "juniper", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "tachikawa.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "tm.no", - "", "", "", "", "", - "abbott", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "quebec", - "", "", "", "", "", "", "", - "teo.br", - "", "", "", "", "", "", "", "", "", - "", "", - "yuasa.wakayama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "gov.lb", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "ybo.trade", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "chuo.chiba.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "realty", - "", "", "", "", "", - "turek.pl", - "", "", "", "", "", "", "", "", "", - "", "", - "xxx", - "", "", "", "", - "tj.cn", - "", - "user.party.eus", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "nonoichi.ishikawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "gov.my", - "", "", "", "", "", "", "", "", "", - "", "", - "bryne.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "ieee", - "", "", "", "", - "svalbard.no", - "olecko.pl", - "", - "town", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "fribourg.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", - "obama.nagasaki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "\303\270rland.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "ap-northeast-2.elasticbeanstalk.com", - "", - "ice", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "finland.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "higashikawa.hokkaido.jp", - "friuli-venezia-giulia.it", - "", "", "", "", "", "", - "akiruno.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "westfalen.museum", - "", "", "", - "kouzushima.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "montreal.museum", - "", "", "", - "express", - "", "", "", "", "", "", "", "", "", - "", - "yasuoka.nagano.jp", - "", "", "", "", "", "", "", "", - "shirako.chiba.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "inder\303\270y.no", - "", "", "", "", "", "", "", "", "", - "", "", - "sko.gov.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "fujikawaguchiko.yamanashi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "kouyama.kagoshima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "tmp.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "shimamaki.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "servebbs.org", - "", "", "", "", "", - "trana.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "edogawa.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "miharu.fukushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "gov.gy", - "", "", "", "", "", "", "", "", "", - "", "", "", - "twmail.cc", - "", "", "", "", "", "", "", "", - "aurland.no", - "", - "inashiki.ibaraki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "kitakata.fukushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "myravendb.com", - "", "", "", "", "", "", - "ina.ibaraki.jp", - "", "", "", "", - "nokia", - "idv.hk", - "", "", "", - "co.pw", - "", "", "", "", "", "", "", - "spreadbetting", - "", "", "", "", "", "", "", "", "", - "kuwana.mie.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "ne.pw", - "", "", "", "", "", "", "", "", "", - "", - "oshima.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "aarp", - "", "", "", "", "", "", "", "", "", - "", "", - "tingvoll.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "market", - "markets", - "", "", "", "", "", "", "", - "unazuki.toyama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "rehab", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "net.af", - "", "", "", "", "", "", "", "", "", - "jefferson.museum", - "", "", "", "", - "nom.af", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "juif.museum", - "", "", "", "", "", "", "", "", "", - "", "", - "kvinesdal.no", - "", "", "", "", "", - "camp", - "", "", "", "", "", "", "", "", "", - "", "", - "com.af", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "education", - "ac.pa", - "", - "gs.sf.no", - "", "", "", - "yamagata.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "baghdad.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "yamagata.ibaraki.jp", - "", "", "", - "mar.it", - "", "", "", "", "", "", "", "", "", - "yatsuka.shimane.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "mitsuke.niigata.jp", - "", "", "", "", - "is-a-caterer.com", - "", "", "", "", "", - "commune.am", - "", "", "", "", "", "", "", - "ac.pr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "georgia.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "s3.eu-west-2.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "review", - "reviews", - "", "", "", "", "", "", "", "", - "friuli-veneziagiulia.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "travel.tt", - "", "", "", "", "", "", "", - "gs.vf.no", - "", "", "", "", "", "", "", "", "", - "", - "suzuka.mie.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "voyage", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "uenohara.yamanashi.jp", - "", "", "", "", "", - "travel.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "nike", - "", - "gateway.museum", - "", - "karlsoy.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "name.az", - "", "", "", "", "", "", "", - "misconfused.org", - "", "", "", "", "", "", "", "", - "ap-south-1.elasticbeanstalk.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "uk0.bigv.io", - "", "", "", - "terni.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "ryuoh.shiga.jp", - "", "", - "travelersinsurance", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "uchinomi.kagawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "s3-us-west-2.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "", "", "", - "co.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "grosseto.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "sakura", - "", "", "", "", "", "", "", "", "", - "", - "charity", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "doomdns.org", - "", "", "", "", "", "", - "tv.bb", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "nh-serv.co.uk", - "reggio-emilia.it", - "", "", "", "", "", "", "", "", "", - "", "", - "coop", - "", "", "", "", - "kuroishi.aomori.jp", - "", "", "", "", "", "", "", - "org.ws", - "kaszuby.pl", - "", "", "", "", "", "", "", - "trader.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "windmill.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "shunan.yamaguchi.jp", - "", - "org.es", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "komono.mie.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "tec.mi.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "org.rs", - "", "", "", "", "", "", "", "", "", - "", "", "", - "ooshika.nagano.jp", - "", "", "", "", - "watchandclock.museum", - "", "", - "cc.pa.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "uchihara.ibaraki.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "s3-eu-west-2.amazonaws.com", - "", "", "", "", "", "", - "bike", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "tomi.nagano.jp", - "kadena.okinawa.jp", - "", "", "", "", "", "", "", "", "", - "ed.pw", - "", - "website", - "", "", "", - "coupon", - "coupons", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "shikama.miyagi.jp", - "kasahara.gifu.jp", - "", "", "", - "forl\303\254cesena.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "northwesternmutual", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "cc.pr.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "jerusalem.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "ogimi.okinawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "froland.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "swiftcover", - "", "", - "katsushika.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "no-ip.biz", - "", "", - "is-a-cpa.com", - "", "", "", "", "", "", - "comcast", - "", "", "", "", - "dentist", - "", "", "", "", "", "", "", "", "", - "", "", "", - "niimi.okayama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "afjord.no", - "", "", "", "", - "vladikavkaz.su", - "", "", "", "", "", "", "", "", "", - "vladikavkaz.ru", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "judygarland.museum", - "", "", - "artdeco.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "org.is", - "", - "brescia.it", - "", "", - "kamijima.ehime.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "chichibu.saitama.jp", - "", "", "", "", "", - "missoula.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "gov.py", - "", "", "", - "overhalla.no", - "", "", - "aol", - "", "", "", "", "", "", "", "", "", - "", "", - "kosuge.yamanashi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "m\303\245lselv.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "kr\303\245anghke.no", - "", "", "", - "org.ls", - "", "", "", - "okayama.okayama.jp", - "", - "cal", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "isa.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "iizuka.fukuoka.jp", - "", "", "", "", - "higashiyamato.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "ebina.kanagawa.jp", - "shirosato.ibaraki.jp", - "", "", "", "", - "transport.museum", - "", "", "", "", "", "", "", - "cookingchannel", - "", - "net.sg", - "", "", - "c.la", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "mydrobo.com", - "", - "net.ag", - "", - "boavista.br", - "", "", - "blockbuster", - "", "", "", "", "", "", "", "", "", - "nom.ag", - "", "", "", - "nagato.yamaguchi.jp", - "", "", "", - "nesset.no", - "", "", "", "", "", "", "", "", "", - "\350\214\250\345\237\216.jp", - "", - "com.sg", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "net.eg", - "", "", "", "", "", "", "", "", "", - "com.ag", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "figueres.museum", - "kvalsund.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "com.eg", - "", "", "", "", "", "", - "funagata.yamagata.jp", - "", "", - "tonsberg.no", - "onjuku.chiba.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "higashiizu.shizuoka.jp", - "", "", "", "", - "sale", - "", "", "", "", "", "", - "furniture.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "minamiboso.chiba.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "iide.yamagata.jp", - "from-me.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "iveco", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "skole.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "srl", - "kashiwa.chiba.jp", - "", "", "", "", "", "", "", - "atami.shizuoka.jp", - "", "", "", "", "", "", "", - "kitashiobara.fukushima.jp", - "", "", "", "", - "solar", - "", "", "", - "shonai.yamagata.jp", - "", - "tashkent.su", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "fussa.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "campinas.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "official.academy", - "", "", "", "", "", - "freesite.host", - "", "", "", "", "", "", "", - "app.os.fedoraproject.org", - "edu.af", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "narusawa.yamanashi.jp", - "", - "jondal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "nom.ug", - "", "", "", "", "", "", "", "", - "rieti.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "com.ug", - "", "", "", "", "", "", "", "", "", - "", - "sola.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "setouchi.okayama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "scientist.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "asker.no", - "", "", "", "", "", - "dclk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "ally", - "", "", "", "", "", "", "", "", "", - "", "", - "jessheim.no", - "", "", "", "", "", "", "", "", "", - "gorge.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "diskstation.me", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "yamatotakada.nara.jp", - "", - "oketo.hokkaido.jp", - "", "", "", "", "", - "eun.eg", - "", "", "", "", "", "", - "isa-hockeynut.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "org.ms", - "", "", "", "", - "gs.oslo.no", - "", "", "", "", "", "", "", "", "", - "", "", - "florist", - "", - "gov.ky", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "yamamoto.miyagi.jp", - "", "", "", "", - "nom.vg", - "", "", "", "", "", "", "", "", "", - "zhytomyr.ua", - "", "", "", "", "", "", "", "", "", - "naval.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "mihara.kochi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "iwanai.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "frl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "travelchannel", - "", "", "", "", "", "", "", "", - "sula.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "feifuturehosting.at", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "s3-website.ap-south-1.amazonaws.com", - "", - "compare", - "", "", "", "", "", "", "", "", "", - "uhren.museum", - "", "", "", "", "", "", "", "", - "myphotos.cc", - "", - "agric.za", - "", - "co.pn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "silk", - "", - "town.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "aukra.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "gov.by", - "", "", "", "", "", "", "", "", "", - "", "", - "wsa.gov.pl", - "", - "tcm.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", - "supplies", - "", - "delta", - "", "", "", "", "", - "mashiko.tochigi.jp", - "", "", "", "", "", "", "", "", "", - "net.nf", - "", "", "", "", - "glass.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "suli.hu", - "", "", "", - "mihama.fukui.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "com.nf", - "", "", - "statefarm", - "", "", "", "", "", "", "", "", - "ureshino.mie.jp", - "", "", "", "", "", "", - "americanantiques.museum", - "", "", "", "", "", "", "", "", "", - "", - "higashi.okinawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "\346\226\260\346\275\237.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "coop.km", - "", - "\345\272\203\345\263\266.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "wielun.pl", - "", "", "", - "kitagawa.miyazaki.jp", - "", "", "", "", "", "", - "katsuyama.fukui.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "jambyl.su", - "", "", "", "", "", "", "", "", "", - "kameoka.kyoto.jp", - "", "", "", "", "", "", "", "", - "jewish.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "yoshino.nara.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "matsudo.chiba.jp", - "", "", "", "", - "s3-website-ap-southeast-1.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "gj\303\270vik.no", - "", "", "", - "idv.tw", - "", "", "", "", "", "", - "belau.pw", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "reggiocalabria.it", - "", "", "", "", "", "", "", "", "", - "", "", "", - "ttttuxfamily.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "info.co", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "mihama.aichi.jp", - "", "", "", "", "", "", - "misugi.mie.jp", - "", "", "", - "gobo.wakayama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "fffm", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "nom.mg", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "com.mg", - "", "", "", "", "", "", "", "", "", - "shimodate.ibaraki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "gs.of.no", - "educator.aero", - "", "", - "education.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "youth.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "kazo.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "gov.bb", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "fuchu.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "storage", - "tenri.nara.jp", - "\346\240\203\346\234\250.jp", - "", "", "", "", "", "", "", - "amli.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "stalbans.museum", - "", "", "", "", "", "", "", "", "", - "", - "\346\226\260\351\227\273", - "", "", "", "", - "denmark.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "bolt.hu", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "for-better.biz", - "kawakita.ishikawa.jp", - "yaita.tochigi.jp", - "", "", "", "", "", "", - "edu.sg", - "", "", "", "", "", "", - "wif.gov.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "askim.no", - "", "", "", "", "", "", "", "", - "is-a-blogger.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "ternopil.ua", - "", "", "", "", "", - "ibara.okayama.jp", - "", "", "", "", "", "", "", "", "", - "", - "mup.gov.pl", - "", "", "", "", "", "", "", - "edu.eg", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "nagaoka.niigata.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "hole.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "net.gg", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "company", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "farmers.museum", - "", "", "", "", "", "", "", "", "", - "", - "imperia.it", - "", "", "", "", - "jan-mayen.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "contagem.br", - "", "", "", "", "", "", - "yamakita.kanagawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "twmail.net", - "", "", - "\340\270\255\340\270\207\340\270\204\340\271\214\340\270\201\340\270\243.\340\271\204\340\270\227\340\270\242", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "salat.no", - "", "", "", "", "", "", "", - "com.pf", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "shika.ishikawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "s3-website.eu-central-1.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "cya.gg", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "bel.tr", - "", "", "", "", "", "", "", "", "", - "", "", - "americana.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "matsushima.miyagi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "mimata.miyazaki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "half.host", - "", "", "", "", "", "", "", "", "", - "", "", "", - "fujieda.shizuoka.jp", - "mein-iserv.de", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "aizumisato.fukushima.jp", - "", "", - "chernivtsi.ua", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "chikusei.ibaraki.jp", - "", "", "", "", "", - "toba.mie.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "doomdns.com", - "", "", "", "", "", "", "", - "yoshimi.saitama.jp", - "", - "balat.no", - "yasu.shiga.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "\303\245l.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "ebetsu.hokkaido.jp", - "", "", "", "", - "net.ng", - "", "", "", "", "", - "staples", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "otsu.shiga.jp", - "", - "com.ng", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "detroit.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "sogndal.no", - "", "", "", "", "", "", "", "", "", - "", - "shitara.aichi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "int.is", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "dating", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "asso.fr", - "", "", "", "", "", "", "", "", "", - "", "", - "ujiie.tochigi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "oceanographique.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "0appspot.com", - "", "", "", - "sel.no", - "eu-3.evennode.com", - "", "", "", "", - "eu-4.evennode.com", - "", "", "", "", - "defense.tn", - "", "", "", "", - "eu-1.evennode.com", - "", "", "", "", "", "", "", "", "", - "komae.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "certification.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "americanart.museum", - "", "", "", "", "", "", "", - "from-ks.com", - "", "", "", "", "", "", "", "", "", - "", - "cooperativa.bo", - "", "", "", "", "", "", "", "", "", - "", "", "", - "org.ps", - "from-ms.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "from-mo.com", - "", "", "", "", - "from-ok.com", - "", - "viajes", - "", "", "", "", "", "", "", "", "", - "", "", "", - "torino.museum", - "", - "gov.iq", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "teramo.it", - "", "", "", - "bnl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "from-ma.com", - "", "", "", "", "", - "rovigo.it", - "", "", "", "", "", - "obama.fukui.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "fukui.jp", - "", "", "", "", "", "", "", "", - "flights", - "", "", "", "", "", - "convent.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "mishima.shizuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "from-mn.com", - "", "", "", "", "", - "kimobetsu.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "maibara.shiga.jp", - "", - "oxford.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "avocat.pro", - "", - "gausdal.no", - "", "", "", "", "", "", - "gaivuotna.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "umb.it", - "", "", "", "", "", "", - "from-ak.com", - "", "", "", "", - "oyabe.toyama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "tateyama.toyama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "flynnhub.com", - "", "", "", "", "", "", "", "", "", - "", - "from-ia.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "radio.br", - "oceanographic.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "gitlab.io", - "elk.pl", - "", "", "", "", "", "", "", "", - "cheltenham.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "gotdns.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "tysvar.no", - "", "", "", "", "", "", "", "", - "from-in.com", - "", "", "", "", "", "", "", - "dali.museum", - "", "", "", "", "", "", "", "", "", - "edu.mg", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "wiw.gov.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "iijima.nagano.jp", - "", "", "", "", "", "", "", "", - "ae.org", - "higashinaruse.akita.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "style", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "tr\303\246na.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "eu-2.evennode.com", - "", "", "", "", - "coop.py", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "co.place", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "asso.gp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "\344\270\255\346\226\207\347\275\221", - "spy.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "s3-website-ap-northeast-1.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "from-oh.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "mielno.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "bale.museum", - "", - "from-ne.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "from-or.com", - "", "", "", "", "", "", "", "", "", - "", "", "", - "securitytactics.com", - "", "", "", "", "", "", "", "", "", - "", "", "", - "otama.fukushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "elverum.no", - "", "", "", "", "", "", "", "", "", - "kannami.shizuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "oystre-slidre.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "from-nh.com", - "", "", "", "", "", "", "", - "eu.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "from-pa.com", - "cloudns.pw", - "", "", "", "", "", "", "", "", - "iwaizumi.iwate.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "machida.tokyo.jp", - "", "", - "is-a-cubicle-slave.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "kadogawa.miyazaki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "diskstation.org", - "", "", "", "", "", "", "", "", "", - "", - "za.org", - "", "", "", "", "", "", - "from-ar.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "shobara.hiroshima.jp", - "torino.it", - "", "", "", "", "", "", "", "", "", - "", "", - "campania.it", - "", "", "", "", - "\346\205\210\345\226\204", - "", "", "", "", "", "", "", "", "", - "", "", - "askoy.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "edu.pf", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "org.bs", - "", - "ostrowwlkp.pl", - "", "", "", - "halsa.no", - "", "", "", "", "", "", "", "", "", - "", - "info.ht", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "bmoattachments.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "groks-the.info", - "tz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "oto.fukuoka.jp", - "", "", "", "", - "solutions", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "bremanger.no", - "", "", "", "", "", - "ogawara.miyagi.jp", - "", - "erotica.hu", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "silk.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "info.at", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "balsan-sudtirol.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "granvin.no", - "", "", "", - "sardegna.it", - "", "", "", "", "", "", "", "", "", - "med.ht", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "ufcfan.org", - "", "", "", "", "", "", "", "", "", - "", - "hol.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "ybo.faith", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "serveexchange.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "servegame.com", - "", "", "", "", "", "", "", "", - "gwangju.kr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "from-mi.com", - "", "", "", "", "", "", "", "", - "goiania.br", - "", "", "", "", "", "", "", "", "", - "", "", - "chiyoda.gunma.jp", - "", "", - "kushiro.hokkaido.jp", - "", "", "", "", "", "", "", "", - "edu.ng", - "", "", "", "", - "voagat.no", - "", - "tobishima.aichi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "kfh", - "", "", - "forli-cesena.it", - "", "", "", "", "", "", "", - "events", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "from-pr.com", - "", "", "", "", "", "", "", "", "", - "from-hi.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "kita.tokyo.jp", - "", "", "", "", - "kisofukushima.nagano.jp", - "", "", "", - "\303\245krehamn.no", - "", "", "", "", "", "", "", "", "", - "", - "nhk", - "", "", "", "", "", "", "", "", "", - "", "", "", - "net.kg", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "com.kg", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "aizuwakamatsu.fukushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "bulsan-sudtirol.it", - "", "", "", - "arai.shizuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "tateyama.chiba.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "able", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "ube.yamaguchi.jp", - "", "", "", "", - "if.ua", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "nikon", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "starostwo.gov.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "ifm", - "", "", "", "", "", "", "", "", - "troandin.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "donetsk.ua", - "", "", "", "", "", "", "", "", "", - "", "", - "k12.ct.us", - "building.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "from-nm.com", - "", "", "", "", "", "", "", - "stuttgart.museum", - "", "", - "chiyoda.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "iwata.shizuoka.jp", - "", "", "", "", "", "", "", "", "", - "", - "entertainment.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "honbetsu.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", - "jaguar", - "", "", "", "", "", "", "", "", "", - "baltimore.museum", - "", "", "", "", "", "", - "birdart.museum", - "", "", "", "", "", "", "", "", "", - "", "", - "tools", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "farmequipment.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "volvo", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "noip.me", - "", "", - "numazu.shizuoka.jp", - "", "", "", "", "", "", "", "", "", - "", - "kawanabe.kagoshima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "k12.ut.us", - "", "", - "haibara.shizuoka.jp", - "olsztyn.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "nobeoka.miyazaki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "\303\270ygarden.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "from-nc.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "tosa.kochi.jp", - "", "", "", "", "", "", "", "", - "kiwi.nz", - "", "", "", "", "", "", "", "", "", - "matsuda.kanagawa.jp", - "", "", "", "", "", "", - "agrinet.tn", - "", "", "", "", "", "", "", "", "", - "", "", "", - "bokn.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "fvg.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "tado.mie.jp", - "", "", "", "", "", "", - "u2.xnbay.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "yatsushiro.kumamoto.jp", - "", "", "", "", "", "", "", "", "", - "divttasvuotna.no", - "", "", "", "", - "kishiwada.osaka.jp", - "", "", "", "", "", "", "", "", - "iizuna.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "fineart.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "kharkov.ua", - "", "", "", "", "", - "k12.vt.us", - "", "", "", - "cherkasy.ua", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "timekeeping.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "avocat.fr", - "", "", "", "", "", "", - "ccupcake.is", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "usculture.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "bugatti", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "shop", - "", "", "", "", "", - "shimonoseki.yamaguchi.jp", - "", "", "", "", "", "", - "oishida.yamagata.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "kharkiv.ua", - "", "", "", "", - "from-nj.com", - "", "", "", "", "", "", "", "", "", - "hino.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", - "marketing", - "", "", "", - "yahiko.niigata.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "tv.tz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "dielddanuorri.no", - "", "", "", "", "", "", "", - "toshiba", - "", "", "", "", - "ono.fukui.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "odawara.kanagawa.jp", - "", "", "", "", "", "", "", "", "", - "", - "scapp.io", - "higashishirakawa.gifu.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "gov.zw", - "", "", "", "", "", "", "", "", - "bnpparibas", - "", "", "", "", "", "", "", "", "", - "", "", - "chofu.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "salon", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "wassamu.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "cologne", - "", "", "", "", "", - "kashiba.nara.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "twmail.org", - "", "", "", "", "", "", "", "", - "k12.mt.us", - "", "", "", - "vik.no", - "itoigawa.niigata.jp", - "", "", "", - "from-ri.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "from-ky.com", - "", "", "", - "shop.hu", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "kitakata.miyazaki.jp", - "", "", "", "", "", "", - "oksnes.no", - "", - "noda.iwate.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "gorizia.it", - "fujixerox", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "drammen.no", - "dhl", - "", "", "", "", "", "", "", "", - "dreamhosters.com", - "", "", "", "", "", "", - "vinnytsia.ua", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "nationwide", - "tmall", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "selbu.no", - "", "", "", "", "", "", "", "", "", - "is-gone.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "holiday", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "sci.eg", - "", "", "", "", "", "", "", "", - "hayashima.okayama.jp", - "unnan.shimane.jp", - "", "", "", "", "", "", "", "", "", - "edu.kg", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "s3-website.ca-central-1.amazonaws.com", - "", "", "", "", "", - "cloudfunctions.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "gov.sc", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "augustow.pl", - "kommune.no", - "", "", - "gov.ac", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "oum.gov.pl", - "", "", "", "", "", "", "", - "qsl.br", - "", "", "", "", "", "", "", "", "", - "hjelmeland.no", - "", "", - "okutama.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", - "gov.ec", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "naamesjevuemie.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "indiana.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "balsan-s\303\274dtirol.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "valdaosta.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "volda.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "tendo.yamagata.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "hamamatsu.shizuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "from-al.com", - "", "", "", - "eu-west-3.elasticbeanstalk.com", - "from-il.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "sa-east-1.elasticbeanstalk.com", - "", "", "", "", "", "", "", "", "", - "", - "is-a-candidate.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "gotdns.ch", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "byen.site", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "essex.museum", - "", "", - "yono.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "dscloud.mobi", - "", "", "", "", "", "", "", "", - "bulsan-s\303\274dtirol.it", - "", - "yoshida.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "iki.nagasaki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "higashikurume.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "edunet.tn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "voting", - "", - "gov.lc", - "", "", "", "", "", - "draydns.de", - "", "", "", "", "", - "eu-west-1.elasticbeanstalk.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "dyndns.biz", - "", - "akabira.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "omitama.ibaraki.jp", - "mayfirst.org", - "", "", "", "", "", "", "", - "gov.vc", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "r\303\270d\303\270y.no", - "", - "info.et", - "", "", "", "", "", "", - "salvador.br", - "", "", "", "", "", "", - "koto.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "mihama.chiba.jp", - "", "", "", "", - "iruma.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "ginowan.okinawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "shikokuchuo.ehime.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "m\304\201ori.nz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "shinichi.hiroshima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "info.cx", - "", - "is-very-sweet.org", - "", "", "", "", "", "", "", "", - "helsinki", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "holtalen.no", - "", "", "", "", "", "", "", "", "", - "kanazawa.ishikawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "tateshina.nagano.jp", - "", "", "", "", - "ohira.tochigi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "journalism.museum", - "", - "berkeley.museum", - "", "", "", "", - "wiki", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "shop.ro", - "", "", "", "", "", "", - "analytics", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "s3-website-ap-southeast-2.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "holdings", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "educational.museum", - "caxias.br", - "", "", "", "", "", "", "", "", "", - "", "", - "dagestan.su", - "", "", "", "", "", "", "", "", "", - "dagestan.ru", - "", "", - "aver\303\270y.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "volyn.ua", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "hino.tottori.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "aoki.nagano.jp", - "", "", "", - "cloudns.info", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "mashike.hokkaido.jp", - "", "", "", - "christiansburg.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "slupsk.pl", - "quebec.museum", - "", - "nord-fron.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "servequake.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "nishitosa.kochi.jp", - "", - "mito.ibaraki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "rennes\303\270y.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "cable-modem.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "svizzera.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "miyashiro.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "trondheim.no", - "", "", "", "", "", "", "", "", "", - "", "", "", - "urasoe.okinawa.jp", - "", "", - "servegame.org", - "", "", "", "", "", "", "", "", "", - "", "", - "infiniti", - "", "", "", - "okazaki.aichi.jp", - "", "", - "s\303\270r-fron.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "is-a-socialist.com", - "", "", "", "", "", "", "", - "dyn-vpn.de", - "asso.dz", - "", "", "", "", - "sayama.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "incheon.kr", - "", "", "", - "consultant.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", - "onojo.fukuoka.jp", - "", "", "", "", - "saku.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "is-a-celticsfan.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "ogaki.gifu.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "tsuno.kochi.jp", - "", "", "", "", "", "", "", "", "", - "kahoku.ishikawa.jp", - "", "", "", - "ketrzyn.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "steam.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "karm\303\270y.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "shimokitayama.nara.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "ichinohe.iwate.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "shinjo.yamagata.jp", - "", "", "", "", "", "", "", "", "", - "skedsmo.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "tj\303\270me.no", - "", "", "", "", - "nannestad.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "wales", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "r\303\270ros.no", - "", "", "", "", "", "", - "ono.fukushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "noip.us", - "", "", "", "", "", "", "", "", "", - "", "", - "rahkkeravju.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "java", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "barsycenter.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "teaches-yoga.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "thruhere.net", - "", "", "", "", "", "", "", "", "", - "sn\303\245ase.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "teshikaga.hokkaido.jp", - "", "", "", - "otsuki.yamanashi.jp", - "", "", "", "", "", - "makeup", - "", "", "", "", "", "", "", "", "", - "", "", - "sayo.hyogo.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "gotdns.org", - "", "", "", - "sakai.osaka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "ui.nabu.casa", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "j\303\270rpeland.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "fukushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "exeter.museum", - "", "", "", - "science.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "tomigusuku.okinawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "umi.fukuoka.jp", - "", "", - "fuji.shizuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "s3-website.ap-northeast-2.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "museet.museum", - "", "", "", "", "", "", "", "", "", - "b\303\241hccavuotna.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "taiki.hokkaido.jp", - "", "", "", "", "", - "from-md.com", - "", "", "", "", "", - "okuma.fukushima.jp", - "", "", "", "", "", "", "", "", "", - "", - "nasu.tochigi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "federation.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "awaji.hyogo.jp", - "", "", "", "", "", "", - "evenassi.no", - "", "", "", "", "", "", - "navuotna.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "steigen.no", - "", "", - "sakaiminato.tottori.jp", - "", "", "", "", "", "", "", "", - "iwama.ibaraki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "yahaba.iwate.jp", - "", - "from-nd.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "cust.testing.thingdust.io", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "minokamo.gifu.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "tozsde.hu", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "from-id.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "fujikawa.yamanashi.jp", - "", "", "", "", "", "", "", "", "", - "empresa.bo", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "nieruchomosci.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "from-de.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "casacam.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "filegear.me", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "mobi.gp", - "", "", "", "", "", "", "", - "forgot.her.name", - "", "", "", "", "", "", "", "", "", - "", "", "", - "mil", - "", "", "", "", "", "", "", "", "", - "control.aero", - "", "", - "uchinada.ishikawa.jp", - "", "", "", "", "", "", "", "", "", - "", - "kutchan.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "memset.net", - "", "", "", - "myftp.biz", - "", "", "", "", "", "", "", - "egersund.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "mil.tm", - "", "", "", "", "", "", "", "", "", - "mil.to", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "shakotan.hokkaido.jp", - "", "", "", "", - "pw", - "", "", "", "", - "pt", - "", "", "", "", "", "", "", - "pt.it", - "", - "ps", - "", "", - "po.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "hk.org", - "", "", "", - "pa", - "", "", "", "", "", "", "", - "pa.it", - "", "", "", "", "", "", - "gotsu.shimane.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "\330\247\331\204\331\205\330\272\330\261\330\250", - "mil.sh", - "", "", "", "", "", - "\330\247\331\204\330\254\330\262\330\247\330\246\330\261", - "", "", "", "", "", "", "", "", - "towada.aomori.jp", - "", - "pa.us", - "", - "pe", - "", "", "", "", "", "", "", - "pe.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "paris", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "\330\247\331\204\331\212\331\205\331\206", - "", "", "", "", "", "", "", "", "", - "", "", "", - "pet", - "", - "teva", - "", "", - "dnshome.de", - "", "", "", "", "", "", "", "", "", - "", - "\321\200\321\204", - "", "", "", "", "", "", "", "", "", - "", "", "", - "pr", - "", "", "", "", - "shiiba.miyazaki.jp", - "", - "harvestcelebration.museum", - "pr.it", - "", "", - "mil.co", - "", "", "", "", "", "", "", "", "", - "", "", "", - "net.az", - "", - "szczytno.pl", - "h\303\270nefoss.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "enebakk.no", - "", "", "", - "pr.us", - "", "", "", "", "", - "v\303\241rgg\303\241t.no", - "", "", - "trv", - "pc.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "com.az", - "", "", "", "", "", "", - "calvinklein", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "whaling.museum", - "", "", "", "", "", - "cahcesuolo.no", - "", "", "", "", "", "", - "\330\247\331\204\330\247\330\261\330\257\331\206", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "py", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "muroran.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "mil.cn", - "", "", "", "", "", - "p.se", - "", "", "", "", "", "", "", "", "", - "gs.jan-mayen.no", - "", "", "", "", "", "", "", "", "", - "", "", "", - "forgot.his.name", - "", "", "", "", "", "", - "now-dns.net", - "", "", "", "", "", "", "", "", "", - "pars", - "", "", "", "", "", "", - "ciscofreak.com", - "", "", "", "", "", "", "", "", "", - "vm.bytemark.co.uk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "pu.it", - "", "", - "web.nf", - "", "", "", "", "", "", "", - "muosat.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "chuo.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "mil.al", - "", "", "", "", "", "", - "v-info.info", - "", "", - "flight.aero", - "", "", "", "", "", "", "", "", "", - "", - "dsmynas.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "sandefjord.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "pe.kr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "pid", - "", "", "", "", "", "", - "pi.it", - "net.uz", - "", "", "", "", "", "", "", "", "", - "", - "bolzano-altoadige.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "tsushima.aichi.jp", - "", - "com.uz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "shop.pl", - "", "", "", - "izu.shizuoka.jp", - "", - "davvesiida.no", - "", "", "", "", "", "", "", "", "", - "", "", "", - "mil.cl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "map.fastlylb.net", - "", "", "", "", - "mil.in", - "", "", "", "", "", - "dh.bytemark.co.uk", - "", "", "", "", "", - "shopping", - "", "", "", "", - "opoczno.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "play", - "pl.ua", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "mil.tj", - "", "", "", "", "", "", "", "", "", - "pwc", - "", "", "", "", "", "", - "pv.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "opencraft.hosting", - "", "", "", - "is-a-lawyer.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "fundacio.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "tsukui.kanagawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "pub", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "kawazu.shizuoka.jp", - "", "", "", "", "", - "pin", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "nanmoku.gunma.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "parts", - "", "", "", "", - "tawaramoto.nara.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "p.bg", - "", "", "", "", "", "", "", "", "", - "", - "praxi", - "", "", "", "", "", "", "", "", "", - "", - "filegear-de.me", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "shiraoi.hokkaido.jp", - "", "", "", "", "", "", "", "", - "pro", - "", "", "", "", "", - "prof", - "", "", "", "", - "blogdns.net", - "", - "nebraska.museum", - "", - "pru", - "pccw", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "mil.do", - "", "", "", "", "", - "ibaraki.jp", - "", - "pro.om", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "mizunami.gifu.jp", - "", - "for-our.info", - "", "", "", - "post", - "b\303\245tsfjord.no", - "", "", "", "", "", "", "", "", "", - "valer.ostfold.no", - "skanit.no", - "", "", "", - "pd.it", - "", "", "", "", "", - "per.la", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "flynnhosting.net", - "", "", "", "", "", "", "", "", "", - "", - "shikaoi.hokkaido.jp", - "", "", "", - "resindevice.io", - "", "", "", "", "", "", "", "", "", - "", - "prod", - "", - "pub.sa", - "", "", - "pink", - "", "", - "gov.ws", - "", "", "", "", "", "", "", - "ybo.review", - "", "", "", "", "", "", "", "", "", - "\303\270vre-eiker.no", - "", "", "", "", "", "", "", "", "", - "", "", "", - "kushima.miyazaki.jp", - "saves-the-whales.com", - "", "", "", "", "", "", "", - "gov.as", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "party", - "", "", "", "", "", - "simple-url.com", - "", "", "", "", "", "", "", "", "", - "net.dz", - "", "", "", "", "", "", "", - "instantcloud.cn", - "", "", "", "", "", "", "", "", "", - "dnsdojo.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "taiki.mie.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "com.dz", - "", - "amakusa.kumamoto.jp", - "", - "from-dc.com", - "", "", "", - "ping", - "", "", "", "", "", "", "", "", "", - "nakamura.kochi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "varggat.no", - "", "", "", - "tsushima.nagasaki.jp", - "", "", "", "", "", "", "", "", "", - "gov.rs", - "", - "schoenbrunn.museum", - "", - "art.dz", - "", "", - "ssl.origin.cdn77-secure.org", - "", "", "", - "penza.su", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "sklep.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "zakopane.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "selfip.com", - "", - "shimabara.nagasaki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "uchiko.ehime.jp", - "", "", "", "", "", - "g\303\241ls\303\241.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "pm", - "", "", "", "", - "gob.gt", - "", "", "", "", "", "", "", "", - "ishigaki.okinawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "knightpoint.systems", - "", "", "", "", "", "", "", "", "", - "\303\241lt\303\241.no", - "", "", "", "", - "sk\303\241nit.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "isumi.chiba.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "kihoku.ehime.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "ikoma.nara.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "molde.no", - "", "", "", "", "", "", "", "", "", - "", "", "", - "walter", - "", "", "", "", "", "", "", - "net.mz", - "", "", - "pics", - "", "", "", "", "", "", - "rifu.miyagi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "aparecida.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "uk.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "alesund.no", - "alessandria.it", - "", "", "", "", "", "", "", "", "", - "", - "my-vigor.de", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "mil.tr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "xenapponazure.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "mil.ar", - "", "", "", - "gov.is", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "inderoy.no", - "", - "fuefuki.yamanashi.jp", - "", "", "", "", "", "", "", "", "", - "", - "volkenkunde.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "fujikawa.shizuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "afamilycompany", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "plus", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "corporation.museum", - "", - "gov.ls", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "elburg.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "plc.uk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "pe.ca", - "", "", - "ushuaia.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "perso.ht", - "", "", "", - "vikna.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "mil.qa", - "", "", "", "", - "msk.su", - "", "", - "pro.vn", - "", "", "", "", "", "", "", "", - "uol", - "", "", "", "", "", "", "", "", "", - "", "", "", - "kitaura.miyazaki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "edu.az", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "miyawaka.fukuoka.jp", - "", "", "", - "pg.it", - "", "", "", "", "", "", "", "", "", - "", "", "", - "calabria.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "mil.gh", - "", "", - "suldal.no", - "", "", "", "", "", "", - "square7.de", - "iwade.wakayama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "\303\245fjord.no", - "", - "msk.ru", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "campidano-medio.it", - "civilwar.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "r\303\270yken.no", - "", - "wmflabs.org", - "", "", "", "", "", "", "", "", "", - "", "", - "komatsu.ishikawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "ichiba.tokushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "otofuke.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "tecnologia.bo", - "", "", "", "", "", "", "", - "finearts.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "googlecode.com", - "", "", "", "", "", "", "", "", "", - "", - "arkhangelsk.su", - "", "", "", "", "", "", "", - "info.sd", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "1kapp.com", - "", "", "", - "gamo.shiga.jp", - "", "", "", "", "", "", "", - "ikeda.osaka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "nowruz", - "", "", "", "", "", "", "", "", "", - "", - "v\303\245ler.\303\270stfold.no", - "", "", "", "", "", "", "", "", "", - "", - "shirataka.yamagata.jp", - "", "", "", "", "", "", "", "", - "or.pw", - "", "", "", "", "", - "padua.it", - "", "", "", "", "", "", - "from-wa.com", - "vinnica.ua", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "miyagi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "yamagata.yamagata.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "creation.museum", - "", "", "", - "mombetsu.hokkaido.jp", - "omaezaki.shizuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "kraanghke.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "mil.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "place", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "pn", - "", "", "", "", "", "", "", - "pn.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "pt.eu.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "koganei.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "wroclaw.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "trani-andria-barletta.it", - "", "", "", "", "", - "vald-aosta.it", - "", "", "", "", - "gov.ms", - "", - "shikatsu.aichi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "val-daosta.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "balsan.it", - "", - "rogers", - "", "", "", "", "", "", "", "", "", - "", "", - "is-a-nurse.com", - "net.nz", - "", "", "", - "geelvinck.museum", - "", - "minobu.yamanashi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "prof.pr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "onagawa.miyagi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "mil.ni", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "british.museum", - "", "", "", "", "", - "tamamura.gunma.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "filegear-sg.me", - "", "", "", - "cnpy.gdn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "selfip.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "halden.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "nym.nz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "anan.tokushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "yoshida.shizuoka.jp", - "", "", "", "", "", "", "", - "sano.tochigi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "bulsan.it", - "", "", "", "", "", "", "", "", "", - "edu.dz", - "", "", "", "", "", "", "", "", "", - "", - "bato.tochigi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "divtasvuodna.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "tochio.niigata.jp", - "bygland.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "agents.aero", - "", "", "", "", "", "", - "tatebayashi.gunma.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "mil.ae", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "ciencia.bo", - "", "", "", "", "", "", "", "", "", - "", "", "", - "pl.eu.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "mil.jo", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "ohda.shimane.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "pnc", - "", "", "", "", "", - "england.museum", - "", "", "", "", "", "", "", "", - "prato.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "chernovtsy.ua", - "", "", "", "", "", "", "", "", "", - "", - "spydeberg.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "aridagawa.wakayama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "shimane.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "myasustor.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "edu.mz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "koga.ibaraki.jp", - "", "", "", "", "", "", "", "", - "kherson.ua", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "dyndns-remote.com", - "", "", "", "", "", "", "", "", "", - "frankfurt.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "square7.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "weatherchannel", - "", - "parti.se", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "supply", - "", "", "", "", "", "", "", - "tgwiddle.co.uk", - "", "", "", "", "", "", - "sakai.ibaraki.jp", - "", "", "", "", "", - "naka.hiroshima.jp", - "", - "is-a-hunter.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "mil.ph", - "", "", - "sakae.chiba.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "pp.ua", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "romskog.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "eu-west-2.elasticbeanstalk.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "from-wi.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "omihachiman.shiga.jp", - "", "", - "pro.na", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "saka.hiroshima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "catanzaro.it", - "", - "coop.mv", - "", "", "", "", "", "", "", "", - "mil.ve", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "api.stdlib.com", - "", "", "", "", "", "", "", "", "", - "", - "jinsekikogen.hiroshima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "qvapor.cloud", - "ushiku.ibaraki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "pp.se", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "tomika.gifu.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "mil.pl", - "", - "tomari.hokkaido.jp", - "", "", - "tomakomai.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "eksservice.gov.uk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "joinville.br", - "", "", "", - "perso.sn", - "", "", - "tajimi.gifu.jp", - "", "", "", - "team", - "", "", "", "", "", "", "", "", "", - "", - "s\303\241lat.no", - "", "", "", "", - "shinyoshitomi.fukuoka.jp", - "motobu.okinawa.jp", - "", - "eastafrica.museum", - "", "", "", "", "", "", "", "", "", - "", "", - "oki.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "mil.ru", - "", "", "", "", "", "", "", "", "", - "", "", - "pp.ru", - "filegear-ie.me", - "", - "knowsitall.info", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "in-addr.arpa", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "mima.tokushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "holt\303\245len.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "tsuru.yamanashi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "rankoshi.hokkaido.jp", - "", "", "", "", "", "", - "kuji.iwate.jp", - "tenei.fukushima.jp", - "", "", "", "", "", "", "", "", "", - "", - "kaluga.su", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "beppu.oita.jp", - "call", - "", "", "", "", "", "", "", "", "", - "", "", - "medecin.fr", - "", "", - "s\303\270rfold.no", - "", - "mil.km", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "us-3.evennode.com", - "", - "muos\303\241t.no", - "", "", - "us-4.evennode.com", - "", "", "", "", - "isteingeek.de", - "", "", "", "", - "us-1.evennode.com", - "", "", "", "", "", "", "", "", "", - "date.fukushima.jp", - "", "", "", "", "", "", "", - "pk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "is-a-player.com", - "", "", "", "", "", "", - "yachiyo.ibaraki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "soma.fukushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "wolterskluwer", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "coop.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "net.kz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "dell", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "com.kz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "prd.km", - "", "", "", "", "", "", "", "", - "iheya.okinawa.jp", - "yachiyo.chiba.jp", - "", - "mil.bo", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "yamazoe.nara.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "milan.it", - "", "", "", "", "", "", "", "", "", - "pb.ao", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "gov.ps", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "sweetpepper.org", - "ohi.fukui.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "net.bz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "decorativearts.museum", - "", "", - "nakadomari.aomori.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "nym.kz", - "", "", "", "", - "olbiatempio.it", - "", "", "", "", - "com.bz", - "", "", "", "", "", "", - "mil.ba", - "", "", "", "", "", - "volkswagen", - "", "", - "tsuchiura.ibaraki.jp", - "", "", "", "", "", "", "", "", - "ikeda.hokkaido.jp", - "", "", "", - "meloy.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "tsuiki.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "arendal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "yalta.ua", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "valer.hedmark.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "ichihara.chiba.jp", - "", "", "", "", - "us-2.evennode.com", - "", "", "", "", "", "", "", "", "", - "", "", - "nakatombetsu.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "charter.aero", - "", "", - "mil.ge", - "", "", - "nym.bz", - "", "", "", "", "", "", "", - "ginan.gifu.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "dnipropetrovsk.ua", - "", "", "", "", "", "", "", "", "", - "", "", - "porsangu.no", - "", "", "", "", - "biz.az", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "panasonic", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "shichinohe.aomori.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "vindafjord.no", - "evenes.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "bilbao.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", - "pictures", - "", "", "", "", "", "", "", "", - "pordenone.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "us.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "kijo.miyazaki.jp", - "", "", "", "", "", "", "", "", "", - "", - "hirogawa.wakayama.jp", - "", "", "", "", "", "", "", - "children.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "schlesisches.museum", - "", "", "", - "naklo.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "alpha.bounty-full.com", - "", - "fastvps-server.com", - "", "", "", "", "", "", "", "", "", - "", "", - "pizza", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "from-wy.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "maizuru.kyoto.jp", - "shibetsu.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "recife.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "okinawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "s3-website.eu-west-3.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "sciences.museum", - "", "", "", "", - "freebox-os.fr", - "", "", "", "", "", "", "", "", "", - "tm.mc", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "jevnaker.no", - "", "", "", "", "", "", "", "", "", - "", "", - "expert", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "bykle.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "fukusaki.hyogo.jp", - "in-dsl.de", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "name.tt", - "", "", "", "", "", "", "", "", "", - "", "", - "ishikari.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "iki.fi", - "", "", - "council.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "progressive", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "nayoro.hokkaido.jp", - "", - "gov.bs", - "", "", "", "", - "ryokami.saitama.jp", - "", "", "", "", - "ashgabad.su", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "kusatsu.shiga.jp", - "", "", "", - "kamifurano.hokkaido.jp", - "", "", "", "", - "porn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "filegear-au.me", - "", "", "", "", "", "", "", "", "", - "", "", - "is-found.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "kisarazu.chiba.jp", - "", "", "", "", "", "", - "research.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "horology.museum", - "", "", "", "", - "pvt.ge", - "", "", "", "", "", "", "", "", "", - "ichinomiya.chiba.jp", - "", - "phd", - "", "", "", "", "", "", "", "", "", - "filatelia.museum", - "", "", "", "", "", "", "", "", "", - "val-d-aosta.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "kanmaki.nara.jp", - "", "", "", "", "", "", "", "", - "mil.kr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "technology", - "", "", "", "", "", "", "", "", "", - "pisz.pl", - "", - "t\303\270nsberg.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "kafjord.no", - "", - "mil.hn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "onl", - "ome.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "omigawa.chiba.jp", - "", "", - "sevastopol.ua", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "nakamichi.yamanashi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "global.ssl.fastly.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "u2-local.xnbay.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "mil.id", - "", "", "", "", "", - "campidanomedio.it", - "", - "s3-website-us-west-1.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "pro.pr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "mil.br", - "credit", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "s3-website-us-east-1.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "edu.kz", - "sakae.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "tanabe.wakayama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "poa.br", - "", "", "", - "museumvereniging.museum", - "", "", "", "", - "dd-dns.de", - "", "", "", "", "", - "mosjoen.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "tx.us", - "", "", "", - "kiyose.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "paris.eu.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "correios-e-telecomunica\303\247\303\265es.museum", - "", "", "", "", "", "", - "syno-ds.de", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "edu.bz", - "", "", "", "", "", "", "", "", "", - "salvadordali.museum", - "", "", "", "", "", "", - "tanagura.fukushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "mil.pe", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "s3-website-eu-west-1.amazonaws.com", - "", "", "", "", - "protonet.io", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "sayama.osaka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "selfip.org", - "", "", "", "", "", "", - "hoylandet.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "naumburg.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "brumunddal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "priv.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "gov.nc.tr", - "shibuya.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "tamayu.shimane.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "sue.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "org.tt", - "", "", "", "", "", "", "", "", "", - "org.st", - "", "", "", "", "", - "sakado.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "itakura.gunma.jp", - "", "", "", - "gleeze.com", - "", "", "", "", "", "", - "sakai.fukui.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "tsukiyono.gunma.jp", - "", "", - "org.et", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "priv.hu", - "", - "haebaru.okinawa.jp", - "conference.aero", - "", "", - "santoandre.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "vuelos", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "ryugasaki.ibaraki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "workers.dev", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "motorcycles", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "psc.br", - "", "", "", "", "", "", "", "", "", - "imageandsound.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "oslo.no", - "", "", - "priv.me", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "nishiazai.shiga.jp", - "", "", - "hokkaido.jp", - "", "", "", "", "", "", "", "", - "nakano.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "ecologia.bo", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "ishinomaki.miyagi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "kiyama.saga.jp", - "", - "nakagusuku.okinawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "fukaya.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "pro.br", - "", "", "", "", "", - "\345\222\214\346\255\214\345\261\261.jp", - "router.management", - "", "", "", "", "", - "torahime.shiga.jp", - "freeboxos.fr", - "", "", "", "", "", - "yashiro.hyogo.jp", - "", "", "", "", "", - "nhlfan.net", - "", "", "", "", "", "", "", "", "", - "", "", "", - "from-nv.com", - "", "", "", "", "", - "tm.mg", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "ollo", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "meeres.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "tamano.okayama.jp", - "", "", "", "", "", "", "", "", - "blackfriday", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "automotive.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "airguard.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "chambagri.fr", - "", "", "", "", "", "", - "photo", - "", "", "", "", "", "", "", "", "", - "eating-organic.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "selfip.info", - "", "", "", "", "", - "appchizi.com", - "", "", "", "", "", "", "", "", - "partners", - "", "", - "isen.kagoshima.jp", - "", "", "", "", "", "", - "fukudomi.saga.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "n\303\245\303\245mesjevuemie.no", - "", "", "", "", "", "", "", - "2ix.at", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "sakuragawa.ibaraki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "kozagawa.wakayama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "monzaebrianza.it", - "", "", "", "", "", - "tsunan.niigata.jp", - "", "", "", "", "", "", "", - "taiwa.miyagi.jp", - "", "", "", "", "", - "fukushima.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "kokubunji.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "oregontrail.museum", - "", "", "", "", "", "", "", "", "", - "movistar", - "", "", "", "", "", "", "", "", "", - "", - "aikawa.kanagawa.jp", - "fukui.fukui.jp", - "", "", "", "", "", "", "", "", "", - "dyndns-free.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "niihama.ehime.jp", - "", "", "", "", "", "", - "dyndns.ddnss.de", - "", "", "", "", - "s\303\241l\303\241t.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "urakawa.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "wakayama.jp", - "", - "rightathome", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "usgarden.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "schokokeks.net", - "passenger-association.aero", - "", "", "", "", "", "", "", - "hida.gifu.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "club.tw", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "campobasso.it", - "", "", "", "", "", "", "", "", "", - "", - "go.pw", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "karatsu.saga.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "sarpsborg.no", - "", "", "", "", "", "", "", "", "", - "", "", "", - "tsuruoka.yamagata.jp", - "", "", "", "", "", "", "", "", "", - "", - "consulting.aero", - "", "", "", "", "", "", "", "", "", - "", - "tax", - "taxi", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "etajima.hiroshima.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "caserta.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "b\303\241l\303\241t.no", - "", "", "", "", - "ikusaka.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "tanabe.kyoto.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "scotland.museum", - "", "", "", "", - "iwakura.aichi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "portlligat.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "org.mt", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "niyodogawa.kochi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "fbx-os.fr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "us-east-1.elasticbeanstalk.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "bill.museum", - "uhk.com", - "", "", "", - "fukuyama.hiroshima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "cri.nz", - "", "", "", "", "", "", "", "", - "ibaraki.osaka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "us-west-1.elasticbeanstalk.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "pesaro-urbino.it", - "", "", "", "", "", - "farmstead.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "nakatane.kagoshima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "uzs.gov.pl", - "", "", "", "", "", "", "", "", "", - "myeffect.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "patria.bo", - "", "", "", - "alipay", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "kimitsu.chiba.jp", - "", "", - "mil.tw", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "filegear-jp.me", - "", - "creditcard", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "isshiki.aichi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "ashibetsu.hokkaido.jp", - "", "", "", "", - "aero.tt", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "grondar.za", - "", "", "", "", "", "", - "dscloud.biz", - "", "", "", "", "", "", "", - "gniezno.pl", - "", "", "", "", "", "", - "\345\215\203\350\221\211.jp", - "", "", "", "", "", "", - "mil.rw", - "", "", "", "", "", "", "", "", "", - "niki.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "org.gt", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "monza-brianza.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "parachuting.aero", - "", "", "", "", "", - "mibu.tochigi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "lt", - "ltd", - "", "", "", "", "", "", - "lt.it", - "", - "ls", - "", - "ltda", - "lo.it", - "\351\244\220\345\216\205", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "la", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "report", - "", "", "", "", "", "", "", "", - "\320\276\321\200\320\263", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "lt.ua", - "", "", "", "", "", "", "", "", "", - "la.us", - "", "", "", "", "", "", "", "", "", - "le.it", - "", "", "", "", "", "", "", - "lat", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "pri.ee", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "solund.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "lr", - "", - "nakama.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "in-vpn.de", - "", "", - "freiburg.museum", - "iwakuni.yamaguchi.jp", - "", "", - "lc", - "", "", "", "", "", "", "", - "lc.it", - "com.sv", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "rnrt.tn", - "", "", "", "", "", "", - "oyama.tochigi.jp", - "", "", "", "", - "inuyama.aichi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "tajiri.osaka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "allfinanz", - "", "", "", "", "", - "osakasayama.osaka.jp", - "", "", "", "", "", "", "", "", "", - "natuurwetenschappen.museum", - "", "", "", "", "", "", "", "", "", - "ly", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "\321\201\321\200\320\261", - "", "", "", "", "", "", "", "", - "kusatsu.gunma.jp", - "", - "yazu.tottori.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "l.se", - "lamer", - "", "", "", - "miyama.fukuoka.jp", - "", - "\320\277\321\200.\321\201\321\200\320\261", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "ichinomiya.aichi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "lu", - "", "", "", "", "", "", "", - "lu.it", - "", "", "", "", "", - "siellak.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "ltd.uk", - "", "", "", "", "", "", "", "", - "lease", - "", - "name.vn", - "", - "hakata.fukuoka.jp", - "", "", - "gb.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "land", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "jx.cn", - "", "", "", "", "", "", "", "", "", - "", "", - "golf", - "", "", "", "", "", "", - "li", - "", "", "", "", "", "", "", - "li.it", - "", "", "", "", "", "", "", "", - "gal", - "", - "lefrak", - "", "", "", "", "", "", "", "", "", - "is-uberleet.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "ringebu.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "tree.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", - "int.tt", - "", "", "", "", - "iwafune.tochigi.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "wakasa.tottori.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "ltd.lk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "gold", - "london", - "", "", "", "", - "svelvik.no", - "", "", - "is-a-nascarfan.com", - "", "", "", "", "", "", - "ltd.ua", - "", "", - "tjmaxx", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "lv", - "", "", "", "", "", "", "", "", "", - "", "", - "schokoladen.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "ibaraki.ibaraki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "liaison", - "", "", - "locus", - "", "", "", "", "", "", "", "", "", - "", - "net.lv", - "", "", "", - "lv.ua", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "technology.museum", - "", "", "", "", - "ikeda.nagano.jp", - "", "", "", "", "", "", "", "", - "tatamotors", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "com.lv", - "", "", "", "", "", "", "", - "life", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "lotto", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "giehtavuoatna.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "l.bg", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "lotte", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "tjome.no", - "", "", "", - "ikeda.fukui.jp", - "", "", "", - "joboji.iwate.jp", - "", "", "", "", "", "", "", "", - "asn.lv", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "koge.tottori.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "tranoy.no", - "", "", - "kani.gifu.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "linde", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "loft", - "", "", - "porsanger.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "link", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "lipsy", - "", "", "", - "kinokawa.wakayama.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "meldal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "monza-e-della-brianza.it", - "arts.ve", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "intuit", - "", "", "", "", - "lund.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "shimosuwa.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "fantasyleague.cc", - "", "", "", - "izumi.osaka.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "gouv.fr", - "", "", "", "", - "lds", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "org.pt", - "", "", "", "", - "llc", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "lacaixa", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "getmyip.com", - "\331\205\331\210\330\250\330\247\331\212\331\204\331\212", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "toride.ibaraki.jp", - "", - "s3-website-sa-east-1.amazonaws.com", - "", "", "", "", "", "", "", - "matsuno.ehime.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "malvik.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "airline.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "net.mv", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "com.mv", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "dev.static.land", - "", "", "", "", "", "", "", "", "", - "", "", "", - "vall\303\251eaoste.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "uryu.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "valle.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "londrina.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "law", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "url.tw", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "motorcycle.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "priv.pl", - "", "", "", "", "", "", - "tkmaxx", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "toscana.it", - "", "", "", "", "", - "kommunalforbund.se", - "", - "edu.sv", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "obninsk.su", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "nakanojo.gunma.jp", - "", "", "", "", "", "", "", - "lasalle", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "tomiya.miyagi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "lg.ua", - "", "", "", "", "", "", "", "", "", - "", "", "", - "hashima.gifu.jp", - "", "", "", "", "", "", "", "", - "pioneer", - "", "", "", "", "", "", "", "", "", - "", - "ravenna.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "minamiechizen.fukui.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "sells-it.net", - "", "", "", "", "", "", "", - "yamanobe.yamagata.jp", - "", "", "", "", "", "", "", "", "", - "is-a-teacher.com", - "", - "miyakonojo.miyazaki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "kitagata.gifu.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "iwanuma.miyagi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "krym.ua", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "namikata.ehime.jp", - "melbourne", - "", "", "", "", - "ltd.gi", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "portal.museum", - "", "", "", "", "", "", "", "", - "shimane.shimane.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "tjx", - "", "", "", "", "", "", - "co.network", - "", "", "", "", "", "", "", "", "", - "filegear-gb.me", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "shimoji.okinawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "skoczow.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "lenug.su", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "org.bt", - "", "", "", "", "", "", "", "", - "wake.okayama.jp", - "", "", "", "", - "jamison.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "lt.eu.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "okinoshima.shimane.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "s3-website.us-east-2.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "ind.gt", - "", - "folkebibl.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "edu.lv", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "latino", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "gok.pk", - "", "", "", "", "", "", "", "", "", - "vall\303\251e-d-aoste.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "lancome", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "lom.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "yonezawa.yamagata.jp", - "", "", "", "", "", "", "", - "zaporizhzhe.ua", - "", "", "", "", "", "", - "online", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "wiki.bo", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "tosashimizu.kochi.jp", - "", "", "", "", - "kakinoki.shimane.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "galsa.no", - "", - "locker", - "", "", "", "", "", "", "", "", "", - "s3-website.eu-west-2.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "ru.net", - "", "", "", "", "", "", - "sykkylven.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "lancia", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "lu.eu.org", - "lupin", - "", "", "", "", "", "", "", "", "", - "", - "jdevcloud.com", - "", "", "", "", "", "", "", "", "", - "", "", - "panama.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "anpachi.gifu.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "outsystemscloud.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "miyako.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "gol.no", - "", "", "", - "es.leg.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "okinawa.okinawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "psi.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "ce.leg.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "matsusaka.mie.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "pesarourbino.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "lgbt", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "ask\303\270y.no", - "", "", "", "", - "ac.leg.br", - "", "", "", "", "", "", "", - "lv.eu.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "institute", - "", - "lincoln", - "", "", "", "", - "wakkanai.hokkaido.jp", - "", "", "", - "s3-website-us-west-2.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "discover", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "zaporizhzhia.ua", - "", "", "", "", "", "", "", "", "", - "", - "ayagawa.kagawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "se.leg.br", - "", "", "", "", "", "", "", - "imizu.toyama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "cremona.it", - "edu.mv", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "zoological.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "wiki.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "sc.leg.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "sakawa.kochi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "mining.museum", - "", "", - "lomza.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", - "ba.leg.br", - "", "", "", - "phone", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "pgfog.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "lawyer", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "elblag.pl", - "", "", "", "", - "al.leg.br", - "", "", "", - "nohost.me", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "hiraizumi.iwate.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "grainger", - "", - "lans.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "metlife", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "pgafan.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "org.ht", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "tainai.niigata.jp", - "", "", "", "", "", "", "", - "nogi.tochigi.jp", - "", - "limo", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "science-fiction.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "turen.tn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "mil.sy", - "", "", "", "", "", "", "", "", "", - "", "", - "kamiizumi.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "hikawa.shimane.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "coop.mw", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "orkdal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "tf", - "", "", "", "", "", "", "", - "goshiki.hyogo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "pors\303\241\305\213gu.no", - "", "", "", - "int.pt", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "field.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "lib.ee", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "hokuto.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "myiphost.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "info.tn", - "", "", "", "", "", "", "", "", "", - "", - "tagawa.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "milano.it", - "", "", "", "", "", "", "", "", - "yokohama", - "", "", - "mil.uy", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "porsgrunn.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "lk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "government.aero", - "", "", - "tonami.toyama.jp", - "", - "kagamiishi.fukushima.jp", - "", "", "", "", "", - "molise.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "shinagawa.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "am.leg.br", - "", - "neyagawa.osaka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "loten.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "mil.zm", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "lapy.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "pz.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "lb", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "land-4-sale.us", - "", - "azumino.nagano.jp", - "", "", - "page", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "vallee-aoste.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "obihiro.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "linz.museum", - "", "", "", "", "", "", "", - "shikabe.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "lecco.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "mil.za", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "kiyosu.aichi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "lecce.it", - "", "", "", "", - "info.tr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "schmidt", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "plc.co.im", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "togo.aichi.jp", - "", "", "", "", - "gdynia.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "tienda", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "flakstad.no", - "", "", "", "", "", "", "", "", "", - "gripe", - "", "", "", "", "", - "sukumo.kochi.jp", - "", "", "", "", "", "", - "applinzi.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "miki.hyogo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "historyofscience.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "kayabe.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "lucca.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "mihama.mie.jp", - "", - "pro.cy", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "oco.cz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "principe.st", - "", - "schwarz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "ebiz.tw", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "bialystok.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "morotsuka.miyazaki.jp", - "", "", "", "", "", "", - "orskog.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "mil.my", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "gulen.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "hikimi.shimane.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "szkola.pl", - "przeworsk.pl", - "", "", "", "", "", - "tuscany.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "us-east-2.elasticbeanstalk.com", - "", "", "", "", "", "", "", "", "", - "sarufutsu.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "rennebu.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "us-west-2.elasticbeanstalk.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "theatre", - "", "", "", "", "", "", - "haga.tochigi.jp", - "mielec.pl", - "", - "noho.st", - "", "", "", "", - "mobi.tt", - "", "", "", "", "", "", - "home-webserver.de", - "", "", "", "", "", "", "", "", "", - "is-an-entertainer.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "oshima.yamaguchi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "is-an-engineer.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "tranby.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "lutsk.ua", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "workisboring.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "loan", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "ladbrokes", - "loans", - "", "", "", "", "", "", "", "", "", - "", "", - "tennis", - "", "", "", - "undersea.museum", - "", "", "", - "film", - "industries", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "sells-for-less.com", - "", "", "", - "sakura.tochigi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "tas.edu.au", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "lubin.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "luroy.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "info.bb", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "kanonji.kagawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "ide.kyoto.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "ltd.hk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "tromso.no", - "", - "itano.tokushima.jp", - "", "", "", "", "", "", "", "", - "miyake.nara.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "plc.ly", - "", "", "", - "muko.kyoto.jp", - "", "", "", "", "", "", "", "", "", - "maryland.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "padova.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "s\303\270r-varanger.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "yosemite.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "k12.az.us", - "", "", - "valleaosta.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "kounosu.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "tromsa.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "plurinacional.bo", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "lazio.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "ostre-toten.no", - "", "", "", "", "", "", "", "", "", - "", - "yamatsuri.fukushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "society.museum", - "film.hu", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "sobetsu.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "trentinsudtirol.it", - "in.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "discovery.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "tysv\303\246r.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "biz.mv", - "", "", "", - "coop.ht", - "", "", "", "", - "basketball", - "", "", "", "", "", "", "", "", "", - "", "", "", - "tabayama.yamanashi.jp", - "", "", "", "", "", "", - "urayasu.chiba.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "trentin-s\303\274d-tirol.it", - "", "", "", "", "", "", "", "", "", - "", "", - "ap.leg.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "giessen.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "localhost.daplie.me", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "railway.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "aibetsu.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "miyazaki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "ln.cn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "tsu.mie.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "serveftp.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "sp.leg.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "openair.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "from-wv.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "org.af", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "himi.toyama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "\320\276\321\200\320\263.\321\201\321\200\320\261", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "law.pro", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "sherbrooke.museum", - "", "", "", "", "", "", "", - "miyada.nagano.jp", - "", "", "", "", "", - "friuliveneziagiulia.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "trentin-s\303\274dtirol.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "taishi.hyogo.jp", - "", "", "", "", "", "", "", "", - "kopervik.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "theater", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "wpcomstaging.com", - "", "", - "tara.saga.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "royken.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "valled-aosta.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "kahoku.yamagata.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "trentinos-tirol.it", - "", "", "", "", "", "", "", - "trentin-sued-tirol.it", - "", "", "", "", - "tagami.niigata.jp", - "", "", - "sch.ng", - "", "", "", - "ine.kyoto.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "tosu.saga.jp", - "", "", "", - "saskatchewan.museum", - "", - "from-ca.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "mil.py", - "", "", "", "", "", - "pharmaciens.km", - "", "", "", "", "", "", "", "", "", - "", "", "", - "\345\230\211\351\207\214\345\244\247\351\205\222\345\272\227", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "is-into-cars.com", - "", - "lib.tx.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "happou.akita.jp", - "", "", "", "", "", "", - "lib.ok.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "chuo.fukuoka.jp", - "", "", "", "", "", "", - "lib.ak.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "trentino-s\303\274dtirol.it", - "", "", "", - "embetsu.hokkaido.jp", - "", "", - "bielawa.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "creditunion", - "", "", "", - "mill.museum", - "", "", "", "", "", "", "", "", - "kuroiso.tochigi.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "lib.oh.us", - "", "", "", "", - "karuizawa.nagano.jp", - "", "", - "miyako.iwate.jp", - "", "", - "trentino-s\303\274d-tirol.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "tottori.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "friulivenezia-giulia.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "ril", - "", "", "", "", "", "", "", - "austevoll.no", - "", "", "", "", "", - "athleta", - "lib.tn.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "lib.co.us", - "", "", "", "", - "trentinos\303\274d-tirol.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "lib.wa.us", - "", "", "", "", - "lib.wi.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "zappos", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "sa.gov.au", - "", "", "", "", "", "", "", "", "", - "", - "support", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "ballangen.no", - "", "", - "vevelstad.no", - "", - "graphics", - "", "", "", "", "", "", "", "", - "trentins\303\274d-tirol.it", - "", "", "", "", - "gotemba.shizuoka.jp", - "", "", "", "", - "imakane.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "trentin-suedtirol.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "lib.ri.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "sells-for-u.com", - "", - "lib.ca.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "so.gov.pl", - "", "", "", "", "", "", "", - "bievat.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "sa.gov.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "lib.al.us", - "", "", "", "", "", "", "", "", "", - "trentino-suedtirol.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "nakano.nagano.jp", - "", "", "", "", - "gliwice.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "nakayama.yamagata.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "trustee.museum", - "", "", "", "", "", "", "", "", "", - "", "", - "balashov.su", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "trentino-sued-tirol.it", - "", "", "", "", "", "", "", "", "", - "pp.az", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "trentino-stirol.it", - "", "", - "sr.gov.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "azurecontainer.io", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "es.gov.br", - "", "", "", "", "", "", "", "", "", - "", - "koeln.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "kakamigahara.gifu.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "tsuno.miyazaki.jp", - "", "", "", "", "", "", "", "", "", - "lib.in.us", - "", "", "", "", "", "", "", "", "", - "ce.gov.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "nikaho.akita.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "uscountryestate.museum", - "", "", "", "", "", "", "", - "trentinos\303\274dtirol.it", - "tomobe.ibaraki.jp", - "", "", "", "", "", "", "", "", "", - "poznan.pl", - "", "", "", "", "", "", "", "", "", - "lib.ia.us", - "", "", "", "", "", "", "", "", - "isahaya.nagasaki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "ac.gov.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "org.sg", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "org.ag", - "", "", "", "", "", - "lib.la.us", - "", "", "", "", - "loseyourip.com", - "", "", "", "", "", "", "", - "ushistory.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "mugi.tokushima.jp", - "ruovat.no", - "", "", "", "", "", "", "", - "org.eg", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "se.gov.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "koya.wakayama.jp", - "", "", "", "", "", "", "", "", "", - "", - "lib.va.us", - "", "", "", "", - "lib.vi.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "mil.by", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "valleeaoste.it", - "", "", "", - "sakura.chiba.jp", - "", "", "", "", "", "", - "trentinosued-tirol.it", - "", "", "", "", "", "", "", "", "", - "lib.il.us", - "hakone.kanagawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "shell.museum", - "", "", "", - "sc.gov.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "muenchen.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "forumz.info", - "", "", "", "", "", "", "", "", - "yoka.hyogo.jp", - "theworkpc.com", - "", "", - "dell-ogliastra.it", - "", "", - "trentins\303\274dtirol.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "pruszkow.pl", - "", "", "", "", - "meland.no", - "", "", "", "", "", "", "", "", "", - "", "", "", - "ba.gov.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "tysfjord.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "trentin-sud-tirol.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "trentino.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "org.ug", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "al.gov.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "colonialwilliamsburg.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "inazawa.aichi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "film.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "taishi.osaka.jp", - "", "", - "izena.okinawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "rennesoy.no", - "", "", "", - "gov.tt", - "", "", "", - "civilization.museum", - "", "", "", - "lib.mo.us", - "", - "gov.st", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "rec.nf", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "trentinsud-tirol.it", - "", "", "", "", "", "", "", "", - "health-carereform.com", - "trust.museum", - "", "", "", - "gov.et", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "trentino-sud-tirol.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "game-server.cc", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "trentinosuedtirol.it", - "", "", "", "", - "rishiri.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "tarnobrzeg.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "lib.mn.us", - "", "", "", "", "", - "serveftp.com", - "", "", "", "", - "pantheonsite.io", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "miyota.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "lib.ma.us", - "", "", "", "", - "lib.mi.us", - "", "", "", "", "", "", "", "", "", - "", "", - "selje.no", - "", "", "", "", "", "", "", - "lib.or.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "goldpoint", - "", "", "", "", "", "", - "writesthisblog.com", - "", "", "", "", "", "", - "lib.ar.us", - "", "", - "daejeon.kr", - "", "", - "idrett.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "schaeffler", - "", "", "", "", "", - "eu.meteorapp.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "delivery", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "niigata.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "togakushi.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "jewelry.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "mino.gifu.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "gov.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "trentin-sudtirol.it", - "", "", "", "", "", "", "", "", "", - "", - "valle-aosta.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "am.gov.br", - "", "", "", "", "", "", "", "", "", - "", "", - "gov.lt", - "", "", "", "", "", "", - "trentino-sudtirol.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "ink", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "the.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "vanylven.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "usui.fukuoka.jp", - "test-iserv.de", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "paroch.k12.ma.us", - "", "", - "lib.ga.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "limited", - "", "", "", "", "", "", "", "", - "from-mt.com", - "", "", "", "", "", "", "", "", "", - "is-not-certified.com", - "", - "org.mg", - "", "", "", "", "", - "localhistory.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "salerno.it", - "", - "aremark.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "wanouchi.gifu.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "posts-and-telecommunications.museum", - "", "", - "trentinosud-tirol.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "readmyblog.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "deporte.bo", - "lib.nm.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "tsuyama.okayama.jp", - "", "", "", "", "", - "uzhgorod.ua", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "isernia.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "is-a-bruinsfan.org", - "", "", "", "", - "lib.nh.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "allstate", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "izunokuni.shizuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "paderborn.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "onomichi.hiroshima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "tsuga.tochigi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "valleedaoste.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "isla.pr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "org.gg", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "mil.iq", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "racing", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "navigation.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "sakaki.nagano.jp", - "", "", "", "", - "org.pf", - "", "", "", "", "", "", - "beep.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "tksat.bo", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "wakasa.fukui.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "asakawa.fukushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "yame.fukuoka.jp", - "london.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "yamagata.gifu.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "oshino.yamanashi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "rackmaze.net", - "trentinoalto-adige.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "skierv\303\241.no", - "", "", "", "", "", "", "", "", "", - "", "", "", - "\345\237\274\347\216\211.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "inagi.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "trentinosudtirol.it", - "", "", "", "", "", "", "", "", - "epilepsy.museum", - "", "", "", "", "", "", "", - "uslivinghistory.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "trentino-s-tirol.it", - "", - "lib.nj.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "bolzano.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "lardal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "org.ng", - "", "", "", "", "", "", "", "", "", - "", "", - "trentinostirol.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "lerdal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "industria.bo", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "kalmykia.su", - "", "", "", "", "", "", "", "", "", - "kalmykia.ru", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "delmenhorst.museum", - "", "", "", "", "", "", "", "", - "bukhara.su", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "tomisato.chiba.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "valledaosta.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "mordovia.su", - "", "", "", "", "", "", "", "", "", - "mordovia.ru", - "", "", "", "", "", "", "", - "lebork.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "l\303\270ten.no", - "", "", - "leadpages.co", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "tsugaru.aomori.jp", - "", "", "", - "tadaoka.osaka.jp", - "", "", "", "", "", - "tome.miyagi.jp", - "", - "lviv.ua", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "larvik.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "goip.de", - "", "", "", "", "", - "valle-daosta.it", - "", "", "", "", "", "", "", "", "", - "", "", "", - "skjerv\303\270y.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "rel.pl", - "", - "is-a-therapist.com", - "", - "ginoza.okinawa.jp", - "", "", - "ap.gov.pl", - "", "", "", "", "", "", "", "", "", - "lib.pa.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "kunstunddesign.museum", - "", "", "", "", "", "", "", - "lyngen.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "ueno.gunma.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "reliance", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "nikolaev.ua", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "lenvik.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "togura.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "is-into-games.com", - "rochester.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "izumi.kagoshima.jp", - "", "", "", "", "", "", "", "", - "ap.gov.br", - "\330\247\331\204\330\263\330\271\331\210\330\257\331\212\331\207", - "cieszyn.pl", - "", "", - "lib.de.us", - "", "", "", "", "", - "\330\247\331\204\330\263\330\271\331\210\330\257\331\212\330\251", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "leczna.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "mt.leg.br", - "", "", "", "", "", "", "", "", "", - "ms.leg.br", - "", "", "", "", "", "", - "dscloud.me", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "ma.leg.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "sakuho.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "zp.gov.pl", - "", "", "", "", "", - "sakyo.kyoto.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "rockart.museum", - "mukawa.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "iraq.museum", - "", "", - "r\303\245holt.no", - "", "", "", - "mydatto.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "sp.gov.br", - "", "", - "biev\303\241t.no", - "", "", "", - "maebashi.gunma.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "grajewo.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "itabashi.tokyo.jp", - "mikasa.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "miho.ibaraki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "lundbeck", - "", "", "", "", "", "", "", "", "", - "", - "lib.me.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "is-a-techie.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "extraspace", - "", "", "", "", "", - "hakuba.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "tsukumi.oita.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "pavia.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "diskstation.eu", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "mishima.fukushima.jp", - "", "", "", "", "", "", - "serveftp.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "gjesdal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "adv.mz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "williamhill", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "tatsuno.nagano.jp", - "gov.pt", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "trentinoa-adige.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "stufftoread.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "ltd.co.im", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "online.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "shop.ht", - "", - "pittsburgh.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "sampa.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "torsken.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "lib.pr.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "org.kg", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "gen.nz", - "tsuwano.shimane.jp", - "ishikawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "l\303\270dingen.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "yoro.gifu.jp", - "", "", "", "", "", "", - "student.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "brandywinevalley.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "lcube-server.de", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "is-a-bulls-fan.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "orland.no", - "", "", "", "", "", "", - "fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "rackmaze.com", - "", "", "", "", "", "", "", "", "", - "adygeya.su", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "lib.ne.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "game.tw", - "", "", "", "", "", "", "", "", - "fukuchiyama.kyoto.jp", - "santafe.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "jeonnam.kr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "adygeya.ru", - "", - "in-brb.de", - "ltd.cy", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "trentinoaltoadige.it", - "", "", "", "", "", "", "", "", "", - "", - "lib.sd.us", - "", "", "", "", "", "", "", "", "", - "", - "donostia.museum", - "", "", - "mil.zw", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "luster.no", - "", "", "", "", "", - "ise.mie.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "groks-this.info", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "tamba.hyogo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "certmgr.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "boxfuse.io", - "", - "snillfjord.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "toei.aichi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "lib.gu.us", - "", "", "", "", "", - "ishikawa.okinawa.jp", - "mel\303\270y.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "info.az", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "tomioka.gunma.jp", - "tachiarai.fukuoka.jp", - "", "", "", "", "", "", "", "", - "from-sc.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "gov.bt", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "nfl", - "", "", "", "", "", "", "", "", "", - "taxi.br", - "", "", "", "", "", "", "", "", "", - "afl", - "", "", "", "", "", "", "", "", "", - "tamatsukuri.ibaraki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "devices.resinstaging.io", - "", "", "", "", "", "", "", "", - "buyshouses.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "krokstadelva.no", - "tottori.tottori.jp", - "exhibition.museum", - "", "", "", "", "", "", - "lib.hi.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "latina.it", - "", "", "", "", "", "", - "mg.leg.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "from-ut.com", - "", "", "", "", "", "", - "tran\303\270y.no", - "", "", "", - "mil.ac", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "lib.id.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "mil.ec", - "", "", - "chijiwa.nagasaki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "m\303\241latvuopmi.no", - "", "", "", "", "", "", "", "", "", - "yokosuka.kanagawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "coldwar.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "l\303\270renskog.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "fuettertdasnetz.de", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "l-o-g-i-n.de", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "is-a-guru.com", - "", "", "", "", "", "", "", "", "", - "", "", - "lamborghini", - "", "", "", - "is-with-theband.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "lidl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "gallo", - "", "", "", "", "", "", "", "", "", - "", - "trento.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "selfip.biz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "is-into-cartoons.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "legal", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "shimoda.shizuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "shimada.shizuoka.jp", - "", "", "", "", "", "", "", "", - "latrobe", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "from-la.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "mil.vc", - "", "", "", - "\303\241k\305\213oluokta.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "ppg.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "intl.tn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "yokoshibahikari.chiba.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "louvre.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "trentino-a-adige.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "lib.md.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "luzern.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "issmarterthanyou.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "tanohata.iwate.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "kakuda.miyagi.jp", - "", "", "", "", "", "", - "rhcloud.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "promo", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "pro.ec", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "\303\245lg\303\245rd.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "info.gu", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "joy", - "", "", "", "", "", "", "", "", - "operaunite.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "badajoz.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "chikuho.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "malopolska.pl", - "berlevag.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "bologna.it", - "", "", "", "", "", "", - "itami.hyogo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "koga.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "gorlice.pl", - "", "", "", "", "", "", "", - "nakagawa.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "toshima.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "tas.gov.au", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "ichinoseki.iwate.jp", - "", "", "", "", "", "", "", "", "", - "gallup", - "", "", "", "", "", "", "", "", "", - "", "", "", - "journalist.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "sekikawa.niigata.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "ichikawa.hyogo.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "tysnes.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "klepp.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "makinohara.shizuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "dnepropetrovsk.ua", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "mochizuki.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "labour.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "law.za", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "lib.nd.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "belem.br", - "", "", - "chikujo.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "yakumo.shimane.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "celtic.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "kiyosato.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", - "wa.gov.au", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "12hp.de", - "", "", "", "", "", "", "", - "online.th", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "leikanger.no", - "", "", "", "", "", - "lighting", - "", "", "", "", "", "", "", "", "", - "", "", "", - "nishiizu.shizuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "\330\263\331\210\330\261\331\212\330\247", - "", "", "", "", "", "", "", "", "", - "\330\263\331\210\330\261\331\212\330\251", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "recreation.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "yokawa.hyogo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "parma.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "touch.museum", - "", "", "", "", "", "", "", "", "", - "", "", - "toys", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "iglesias-carbonia.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "ichikawamisato.yamanashi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "landrover", - "", "", "", "", "", "", "", "", - "ichikawa.chiba.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "is-a-chef.com", - "mw.gov.pl", - "", "", "", "", "", "", "", "", "", - "", "", - "fukagawa.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "target", - "", "", "", "", "", "", "", "", "", - "", "", - "gifu.gifu.jp", - "", "", "", "", "", "", "", - "taa.it", - "hikone.shiga.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "culture.museum", - "", "", "", "", "", "", "", - "tabuse.yamaguchi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "nakaniikawa.toyama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "gliding.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "doesntexist.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "endoftheinternet.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "press", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "remotewd.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "tos.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "salud.bo", - "", "", "", "", - "is-a-chef.net", - "", "", "", "", "", "", - "trentino-alto-adige.it", - "", "", "", "", "", "", "", "", "", - "yakumo.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "hakusan.ishikawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "lego", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "lombardia.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "mt.gov.br", - "", "", "", "", "", "", "", "", "", - "ms.gov.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "ma.gov.br", - "", "", "", - "h\303\241pmir.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "nalchik.su", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "barletta-trani-andria.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "williamsburg.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "miyazu.kyoto.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "toda.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "nalchik.ru", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "americanexpress", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "from-ny.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "jeonbuk.kr", - "", "", "", "", "", "", "", "", - "dyndns1.de", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "pramerica", - "", "", "", - "pph", - "", "", "", "", "", - "r.cdn77.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "askvoll.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "s3-external-1.amazonaws.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "pisa.it", - "", "", "", "", "", "", "", "", "", - "", "", "", - "koshigaya.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "from-sd.com", - "", "", "", "", "", "", - "tahara.aichi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "nakagawa.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "tickets", - "", "", "", "", "", "", "", "", "", - "", "", - "k12.nv.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "philips", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "lpusercontent.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "saigawa.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "org.sz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "org.az", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "utwente.io", - "", "", "", "", "", "", - "trentinoaadige.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "nikko.tochigi.jp", - "", - "h\303\241mm\303\241rfeasta.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "trentino-aadige.it", - "", "", "", "", "", - "american.museum", - "", - "map.fastly.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "\303\245lesund.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "vibo-valentia.it", - "", "", "", "", "", - "nakagawa.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "siljan.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "bolivia.bo", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "chesapeakebay.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "gov.af", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "\331\205\331\204\331\212\330\263\331\212\330\247", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "tozawa.yamagata.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "tamakawa.fukushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "org.uz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "tagajo.miyagi.jp", - "", "", "", - "leclerc", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "is-a-green.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "boleslawiec.pl", - "", "", "", "", "", "", "", - "xfinity", - "wakuya.miyagi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "lunner.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "hokksund.no", - "", "", "", "", "", "", "", "", "", - "", "", - "chitose.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "\330\247\331\204\330\271\331\204\331\212\330\247\331\206", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "witd.gov.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "\331\201\331\204\330\263\330\267\331\212\331\206", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "observer", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "inami.wakayama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "\303\270ksnes.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "tselinograd.su", - "", "", "", "", "", "", "", "", "", - "", "", - "boldlygoingnowhere.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "press.ma", - "", "", "", "", "", "", "", - "cn-northwest-1.eb.amazonaws.com.cn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "taira.toyama.jp", - "", "", - "minamitane.kagoshima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "press.se", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "trentino-altoadige.it", - "", "", "", "", "", "", "", - "sologne.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "ookuwa.nagano.jp", - "", "", - "org.dz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "godo.gifu.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "higashi.fukushima.jp", - "", "", "", - "tuva.su", - "", - "mg.gov.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "love", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "salem.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "togane.chiba.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "mutsuzawa.chiba.jp", - "", "", "", "", "", "", "", "", "", - "", - "uw.gov.pl", - "nakai.kanagawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "us.gov.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "transporte.bo", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "freetls.fastly.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "gallery", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "govt.nz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "nakasatsunai.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "org.mz", - "", "", "", "", "", "", "", "", "", - "niepce.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "tobe.ehime.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "valle-d-aosta.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "tarui.gifu.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "balsfjord.no", - "", "", - "barlettatraniandria.it", - "", - "berlev\303\245g.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "gob.sv", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "wios.gov.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "toyota", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "gov.sg", - "", "", "", "", "", "", "", "", "", - "", "", - "live", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "gov.eg", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "chikuzen.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "test.tj", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "tsubame.niigata.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "wuoz.gov.pl", - "", "", "", "", - "prime", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "doesntexist.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "ilovecollege.info", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "uozu.toyama.jp", - "", "", - "is-a-chef.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "kiyokawa.kanagawa.jp", - "", "", "", "", - "townnews-staging.com", - "", "", "", "", "", "", "", "", "", - "higashi.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "leg.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "saltdal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "okegawa.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "org.nz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "perso.tn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "is-a-geek.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "is-a-conservative.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "matsushige.tokushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "um.gov.pl", - "", "", "", "", - "lib.wy.us", - "", "", "", "", "", "", "", "", "", - "", "", - "pistoia.it", - "", "", - "balsan-suedtirol.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "shimotsuma.ibaraki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "int.az", - "", "", "", "", "", - "niigata.niigata.jp", - "", "", "", "", "", "", "", - "is-a-geek.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "inami.toyama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "mykolaiv.ua", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "bulsan-suedtirol.it", - "", "", - "yokote.akita.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "pvh.br", - "", "", "", "", "", - "gov.mg", - "plumbing", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "inagawa.hyogo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "lugs.org.uk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "tamaki.mie.jp", - "", "", "", "", "", "", - "joetsu.niigata.jp", - "", "", "", - "ug.gov.pl", - "", - "perugia.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "office-on-the.net", - "", - "trani-barletta-andria.it", - "", "", "", "", "", - "tarama.okinawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "podzone.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "fukushima.fukushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "americanfamily", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "cosenza.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "nakagawa.tokushima.jp", - "", "", "", "", "", "", "", "", - "okagaki.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "delaware.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "yakage.okayama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "caltanissetta.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "geekgalaxy.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "go.leg.br", - "gov.ng", - "", "", "", "", "", "", "", "", - "tone.ibaraki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "nakijin.okinawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "is-a-financialadvisor.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "winb.gov.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "org.kz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "karumai.iwate.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "kikuchi.kumamoto.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "pagespeedmobilizer.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "vaksdal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "org.bz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "imamat", - "", - "gujo.gifu.jp", - "", "", - "pescara.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "isesaki.gunma.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "sakata.yamagata.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "giving", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "press.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", - "lublin.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "oldnavy", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "gov.bf", - "piedmont.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "cloudfront.net", - "", "", - "valley.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "tenkawa.nara.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "chikushino.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "lib.ny.us", - "", "", "", "", "", "", "", "", "", - "", "", "", - "ishikawa.fukushima.jp", - "", "", "", "", "", "", "", - "pf", - "", "", "", "", "", "", "", "", "", - "", - "firenze.it", - "", "", "", - "plo.ps", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "priv.at", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "vpnplus.to", - "", "", "", "", "", "", "", - "kakogawa.hyogo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "pimienta.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "ibestad.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "obanazawa.yamagata.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "hakodate.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "sakurai.nara.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "lur\303\270y.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "prudential", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "oshu.iwate.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "pharmacy", - "", "", "", "", "", - "sokndal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "komforb.se", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "is-a-geek.org", - "hikari.yamaguchi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "tondabayashi.osaka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "gov.kg", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "morioka.iwate.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "joso.ibaraki.jp", - "", "", "", "", "", "", "", - "belluno.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "eiheiji.fukui.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "repbody.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "guam.gu", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "juegos", - "", "", "", "", - "maringa.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "jp.net", - "", "", "", - "tonaki.okinawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "sukagawa.fukushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "vologda.su", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "podhale.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "cultural.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "miyazaki.miyazaki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "rokunohe.aomori.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "rexroth", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "traniandriabarletta.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "knx-server.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "yolasite.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "rsvp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "trolley.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "wiih.gov.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "lib.ky.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "prd.fr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "firm.ve", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "fukumitsu.toyama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "lanbib.se", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "geek.nz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "tokyo", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "is-certified.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "upow.gov.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "computer", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "soka.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "itoman.okinawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "toon.ehime.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "potager.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "photos", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "wales.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "red.sv", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "lodi.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "helsinki.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "iiyama.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "info.zm", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "turystyka.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "judaica.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "select", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "parliament.cy", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "joburg", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "tdk", - "", "", "", "", "", "", "", "", "", - "", "", "", - "cal.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "jll", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "chicago.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "investments", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "miyoshi.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "miyama.mie.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "iwi.nz", - "", "", "", "", "", "", - "poivron.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "isehara.kanagawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "lier.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "wolomin.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "tama.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "tel", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "onga.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", - "london.cloudapps.digital", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "apps.fbsbx.com", - "", "", "", "", "", "", "", "", "", - "bplaced.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "paris.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "campinagrande.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "org.sv", - "", - "bydgoszcz.pl", - "talk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "vicenza.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "hakui.ishikawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "redirectme.net", - "", "", "", "", "", "", "", "", "", - "imabari.ehime.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "johana.toyama.jp", - "", - "tynset.no", - "", "", "", "", "", "", "", - "california.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "presse.ci", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "hokuto.yamanashi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "presse.ml", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "go.gov.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "tm.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "pixolino.com", - "", "", - "lexus", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "malbork.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "logoip.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "okoppe.hokkaido.jp", - "", "", "", - "villas", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "bahcavuotna.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "tokke.no", - "", "", "", "", "", - "hekinan.aichi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "org.lv", - "", - "pohl", - "", "", "", - "troitsk.su", - "", "", "", "", "", "", "", "", "", - "", - "luxe", - "leangaviika.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "lima-city.at", - "", "", "", "", "", "", "", - "uppo.gov.pl", - "", "", "", - "kokonoe.oita.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "trysil.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "lesja.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "mazowsze.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "kaho.fukuoka.jp", - "", "", "", "", - "gyokuto.kumamoto.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "miyoshi.aichi.jp", - "", "", "", "", "", "", - "tsukuba.ibaraki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "lanxess", - "", "", "", - "iglesiascarbonia.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "togliatti.su", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "koka.shiga.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "ipifony.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "uber.space", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "tatsuno.hyogo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "plaza.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "nflfan.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "org.mv", - "", "", "", "", "", "", "", - "lixil", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "tel.tr", - "", "", "", "", - "dyndns-office.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "shibata.miyagi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "umig.gov.pl", - "", "", "", "", "", "", "", "", "", - "toyama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "monmouth.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "pueblo.bo", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "us-gov-west-1.elasticbeanstalk.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "troms\303\270.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "from-tn.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "lima-city.de", - "", "", "", "", - "ichikai.tochigi.jp", - "", "", "", - "ro.leg.br", - "", "", "", "", - "rs.leg.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "bryansk.su", - "", "", "", "", "", "", "", "", "", - "", "", "", - "melhus.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "skype", - "", "", "", "", "", "", "", "", "", - "rr.leg.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "limanowa.pl", - "is-leet.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "r\303\270yrvik.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "kyuragi.saga.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "my-gateway.de", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "tolga.no", - "", "", "", "", "", "", "", "", "", - "", - "gov.az", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "tourism.tn", - "", "", - "uwajima.ehime.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "hospital", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "presse.km", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "j\303\270lster.no", - "", "", - "yokoze.saitama.jp", - "", "", "", - "wakayama.wakayama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "onyourside", - "", "", - "sekigahara.gifu.jp", - "", "", "", "", "", "", "", - "laquila.it", - "", "", "", "", "", "", "", "", "", - "", "", "", - "pvt.k12.ma.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "shibata.niigata.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "netlify.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "info.tt", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "salzburg.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "kuki.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "tohma.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "fukuroi.shizuoka.jp", - "", "", - "reklam.hu", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "naka.ibaraki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "gov.dz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "tananger.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "otsuchi.iwate.jp", - "", "", "", "", "", "", - "hichiso.gifu.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "miyoshi.tokushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "toyonaka.osaka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "nakanoto.ishikawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "tsubetsu.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "profesional.bo", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "gov.mz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "lib.sc.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "puglia.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "hoyanger.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "royrvik.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "tempio-olbia.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "servehalflife.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "pomorskie.pl", - "", "", "", - "ikeda.gifu.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "lg.jp", - "", "", "", "", "", "", "", - "ullensaker.no", - "", "", "", "", "", "", "", "", "", - "", "", "", - "zoology.museum", - "", - "tr\303\270gstad.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "skjervoy.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "izumiotsu.osaka.jp", - "", "", "", "", "", "", "", "", "", - "kartuzy.pl", - "", "", "", - "int.mv", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "rn.leg.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "miyoshi.hiroshima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "dolls.museum", - "", "", "", "", "", "", - "on-aptible.com", - "", "", "", "", "", "", "", "", - "plantation.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", - "sakegawa.yamagata.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "taipei", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "pubol.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "ppxen.prgmr.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "lib.dc.us", - "", "", "", "", "", - "pfizer", - "", "", "", - "unjarga.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "mikawa.yamagata.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "lucania.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "publ.pt", - "", "", "", "", "", "", "", "", "", - "", "", - "larsson.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "joyo.kyoto.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "taito.tokyo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "rj.leg.br", - "", "", "", "", "", "", "", "", "", - "", "", - "shop.th", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "t3l3p0rt.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "hayakawa.yamanashi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "gildeskal.no", - "", "", "", "", "", "", - "philadelphia.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "tranibarlettaandria.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "jorpeland.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "dallas.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "tokushima.tokushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "from-ct.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "homeoffice.gov.uk", - "", "", - "iveland.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "textile.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "pasadena.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "fhapp.xyz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "lib.nc.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "\303\241laheadju.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "traeumtgerade.de", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "lima-city.rocks", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "12hp.ch", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "auspost", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "lucerne.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "info.vn", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "gov.kz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "lindesnes.no", - "", "", "", "", "", "", "", "", "", - "", - "mobi.tz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "coloradoplateau.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "raholt.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "nanporo.hokkaido.jp", - "", "", - "michigan.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "shimofusa.chiba.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "gov.bz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "folldal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "toyo.kochi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "juedisches.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "homeftp.org", - "", "", "", - "lima-city.ch", - "", "", "", "", "", "", "", "", - "wildlife.museum", - "", "", "", "", "", "", "", "", "", - "", - "lind\303\245s.no", - "", "", "", "", "", "", "", "", "", - "info.ve", - "", - "rikuzentakata.iwate.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "agematsu.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "ro.gov.br", - "", "", "", "", - "rs.gov.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "rr.gov.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "matsuzaki.shizuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "tourism.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "tokushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "hellas.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "gets-it.net", - "", "", "", "", "", "", "", "", - "from-tx.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "in-butter.de", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "columbus.museum", - "", "", "", "", - "lincoln.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "plants.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "mulhouse.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "griw.gov.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "paragliding.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "lib.as.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "ekloges.cy", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "mol.it", - "", "", "", "", - "mil.st", - "", - "is.gov.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "schweiz.museum", - "", "", "", "", "", "", "", "", "", - "texas.museum", - "", "", "", "", "", "", "", "", "", - "pay", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "ic.gov.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "temp-dns.com", - "", "", - "toyotomi.hokkaido.jp", - "", "", "", "", "", - "toya.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "12hp.at", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "philadelphiaarea.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "columbia.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "df.leg.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "izumisano.osaka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "izumo.shimane.jp", - "", "", "", "", "", "", - "balestrand.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "gjemnes.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "television.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "pro.tt", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "corvette.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "piaget", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "gildesk\303\245l.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "lib.ms.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "tono.iwate.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "jpmorgan", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "\351\246\231\346\240\274\351\207\214\346\213\211", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "rn.gov.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "app.os.stg.fedoraproject.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "lorenskog.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "help", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "trading.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "gotpantheon.com", - "", "", "", - "resistance.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "taki.mie.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "from-co.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "mil.gt", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "yokaichiba.chiba.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "point2this.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "abruzzo.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "rj.gov.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "pictet", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "vall\303\251e-aoste.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "journal.aero", - "pmn.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "yokkaichi.mie.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "akkeshi.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "phoenix.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "istmein.de", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "pharmacien.fr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "trainer.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "malselv.no", - "", "", "", - "landes.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "is-into-anime.com", - "parliament.nz", - "", "", - "lombardy.it", - "mantova.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "podlasie.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "l\303\246rdal.no", - "", "", "", - "kkknssy!city.kawasaki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "lpages.co", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "sakahogi.gifu.jp", - "", - "riopreto.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "echizen.fukui.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "linkyard.cloud", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "lindas.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "theater.museum", - "", "", - "psp.gov.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "lyngdal.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "takatori.nara.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "seaport.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "gov.lv", - "webhosting.be", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "gyeongnam.kr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "express.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "lajolla.museum", - "pup.gov.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "public.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "lib.ks.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "from-ga.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "l\303\241hppi.no", - "", "", "", "", "", "", "", "", "", - "tokai.ibaraki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "gov.mv", - "", "", "", "", "", "", "", "", "", - "", - "jelenia-gora.pl", - "", "", - "inawashiro.fukushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "tokai.aichi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "labor.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "tempioolbia.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "leirvik.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "freight.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "takinoue.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "walmart", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "aostavalley.it", - "", "", "", "", "", "", "", "", "", - "", "", - "taketomi.okinawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "gloppen.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "newport.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "lib.fl.us", - "", "", "", "", "", "", "", "", "", - "", - "takayama.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "topology.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "takko.aomori.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "poniatowa.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "trentinsued-tirol.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "df.gov.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "preservation.museum", - "piw.gov.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "does-it.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "gangaviika.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "luxury", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "uklugs.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "taka.hyogo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "from-fl.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "toyohashi.aichi.jp", - "", "", "", "", "", "", - "yukuhashi.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "jobs.tt", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "lifeinsurance", - "", "", "", - "trentinsuedtirol.it", - "", "", "", "", - "ballooning.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "oyamazaki.kyoto.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "mydatto.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "hembygdsforbund.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "computerhistory.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "iselect", - "", "", - "ohkura.yamagata.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "railroad.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "is-a-soxfan.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "gyeonggi.kr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "toyota.aichi.jp", - "", "", "", "", - "l\303\244ns.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "vallee-d-aoste.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "press.cy", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "lierne.no", - "", - "tohnosho.chiba.jp", - "takashima.shiga.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "physio", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "pro.ht", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "ravendb.run", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "mckinsey", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "viking", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "takasago.hyogo.jp", - "", "", "", "", "", "", "", "", - "lewismiller.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "chippubetsu.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "tonosho.kagawa.jp", - "", "", - "taiji.wakayama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "liguria.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "taketa.oita.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "takayama.gunma.jp", - "toyako.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "tokashiki.okinawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", - "tsurugashima.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "leirfjord.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "kakegawa.shizuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "playstation", - "", "", "", "", "", "", "", "", "", - "", "", "", - "experts-comptables.fr", - "", "", - "yuki.ibaraki.jp", - "salangen.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "kikonai.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "skierva.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "takahama.aichi.jp", - "", "", "", "", "", "", "", - "kikugawa.shizuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "takata.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "tarumizu.kagoshima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "takamori.kumamoto.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "powiat.pl", - "", "", "", "", "", "", "", "", "", - "kongsvinger.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "wallonie.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "poker", - "", "", "", "", "", "", "", "", "", - "takamori.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "nfshost.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "jaworzno.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "is-a-student.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "lom.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "rotorcraft.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "pc.pl", - "", "", "", "", "", "", - "mallorca.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "tsukigata.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "takasaki.gunma.jp", - "", "", "", "", "", "", "", "", "", - "sellsyourhome.org", - "", "", "", "", "", "", "", "", "", - "", "", "", - "tokamachi.niigata.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "tokoname.aichi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "linkyard-cloud.ch", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "takahama.fukui.jp", - "", "", "", - "productions", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "vossevangen.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "leitungsen.de", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "protection", - "", "", "", "", "", "", - "ibigawa.gifu.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "mil.eg", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "ptplus.fit", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "per.sg", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "port.fr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "oirm.gov.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "taranto.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "toyono.osaka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "telekommunikation.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "politie", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "kobierzyce.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "hokuryu.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "per.nf", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "taifun-dns.de", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "nakagyo.kyoto.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "mil.mg", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "toyone.aichi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "prd.mg", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "pol.tr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "laakesvuemie.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "ownprovider.com", - "", "", "", - "seljord.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "planetarium.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "lubartow.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "takehara.hiroshima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "mil.ng", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "lug.org.uk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "to.leg.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "toyama.toyama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "politica.bo", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "laz.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "takahashi.okayama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "heimatunduhren.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "muenster.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "pyatigorsk.ru", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "ravendb.community", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "geology.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "gokase.miyazaki.jp", - "", "", "", "", "", - "jeep", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "is-lost.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "pug.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "trogstad.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "mil.kg", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "lebesby.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "trieste.it", - "", "", "", "", "", "", "", "", "", - "", - "seki.gifu.jp", - "", - "piacenza.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "linkitools.space", - "", "", "", "", "", "", "", "", "", - "ogliastra.it", - "", "", "", "", "", "", "", "", "", - "", "", "", - "passagens", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "tjeldsund.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "gallery.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "coop.tt", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "college", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "takino.hyogo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "pila.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "lifestyle", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "revista.bo", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "livorno.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "gjerstad.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "orkanger.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "nsupdate.info", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "grimstad.no", - "", "", "", "", "", "", - "tobetsu.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "realestate", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "here-for-more.info", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "takasu.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "ugim.gov.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "ullensvang.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "abkhazia.su", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "lib.ct.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "anamizu.ishikawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "military.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "collection.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "lib.ut.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "tvedestrand.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "viking.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "moka.tochigi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "lib.vt.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "press.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "luxembourg.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "takahagi.ibaraki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "takagi.nagano.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "lib.mt.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "tokigawa.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "to.gov.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "treviso.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "tsuruta.aomori.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "togitsu.nagasaki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "leka.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "like", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "podzone.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "lakas.hu", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "\330\247\331\204\330\263\330\271\331\210\330\257\333\214\333\203", - "", "", "", "", - "\330\247\331\204\330\263\330\271\331\210\330\257\333\214\330\251", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "lavagis.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "hyllestad.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "tula.su", - "", "", "", "", "", "", "", - "pagefrontapp.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "lol", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "trapani.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "bplaced.de", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "mil.tz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "mil.az", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "ikaruga.nara.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "tsubata.ishikawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "pilot.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "loppa.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "culturalcenter.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "pro.az", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "rikubetsu.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "bplaced.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "realestate.pl", - "", "", "", "", "", "", "", "", "", - "mil.mz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "jampa.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "mein-vigor.de", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "lancaster", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "pippu.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "kolobrzeg.pl", - "", - "deloitte", - "", "", "", "", "", "", "", - "kalisz.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "logoip.de", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "skydiving.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "toyokawa.aichi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "rel.ht", - "", "", "", "", "", "", "", "", "", - "", "", "", - "pacific.museum", - "", "", "", "", "", "", "", - "info.tz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "mil.nz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "shimotsuke.tochigi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "from-va.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "loabat.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "iwamizawa.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "takaharu.miyazaki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "nishigo.fukushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "lpl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "photography", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "collegefan.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "fukuchi.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "lig.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "jogasz.hu", - "", "", "", "", - "fylkesbibl.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "palace.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "taishin.fukushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "tokuyama.yamaguchi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "mil.kz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "lukow.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "atlanta.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "police.uk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "logistics.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "holmestrand.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "rzeszow.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "golffan.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "lebtimnetz.de", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "taku.saga.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "toyota.yamaguchi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "pharmacy.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "dazaifu.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "polkowice.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "lel.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "ivanovo.su", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "lodingen.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "loab\303\241t.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "tochigi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "vaapste.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "photography.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "guernsey.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "takaoka.toyama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "portland.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "privatizehealthinsurance.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "computer.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "toyoake.aichi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "jolster.no", - "", "", "", "", "", "", "", "", "", - "", "", - "illustration.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "rzgw.gov.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "takikawa.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "toyosato.shiga.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "rakkestad.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "presidio.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "toga.toyama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "bieszczady.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "dellogliastra.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "tsurugi.ishikawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "publishproxy.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "takamatsu.kagawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "losangeles.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "g\303\241\305\213gaviika.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "prochowice.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "leasing.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "mil.lv", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "pcloud.host", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "skiptvet.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "olkusz.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "mil.mv", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "tele.amune.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "likes-pie.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "takaishi.osaka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "lezajsk.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "homeftp.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "la-spezia.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "pulawy.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "pro.mv", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "termez.su", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "jfk.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "is-saved.org", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "philately.museum", - "lplfinancial", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "airport.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "egyptian.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "pa.leg.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "pe.leg.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "pr.leg.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "from-az.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "takatsuki.osaka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "pi.leg.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "trafficplex.cloud", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "telefonica", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "lima.zone", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "ralingen.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "toho.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "vall\303\251edaoste.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "lilly", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "isleofman.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "takazaki.miyazaki.jp", - "", "", "", "", "", "", "", "", "", - "tadotsu.kagawa.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "takatsuki.shiga.jp", - "", "", "", "", "", "", - "chikugo.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "tsumagoi.gunma.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "izumozaki.niigata.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "czeladz.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "lancashire.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "takayama.gifu.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "makurazaki.kagoshima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "piemonte.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "tako.chiba.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "wskr.gov.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "walbrzych.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "lib.az.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "pb.leg.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "po.gov.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "pa.gov.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "malatvuopmi.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "omotego.fukushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "pa.gov.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "pe.gov.br", - "", "", "", "", "", "", "", "", - "ravendb.me", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "pr.gov.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "nakatsugawa.gifu.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "pi.gov.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "toyoura.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "lowicz.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "gyeongbuk.kr", - "", "", "", "", "", "", "", "", "", - "", "", - "shimizu.shizuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "palermo.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "pointto.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "psse.gov.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "toyooka.hyogo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "langevag.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "legnica.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "tochigi.tochigi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "lugansk.ua", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "wellbeingzone.eu", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "wellbeingzone.co.uk", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "living", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "properties", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "pb.gov.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "levanger.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "production.aero", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "pinb.gov.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "shimizu.hokkaido.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "langev\303\245g.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "yanaizu.fukushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "lavangen.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "paleo.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "takahata.yamagata.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "loyalist.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "from-vt.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "lib.nv.us", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "ponpes.id", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "potenza.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "rollag.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "pilots.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "palmsprings.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "village.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "living.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "leksvik.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "telebit.io", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "takanabe.miyazaki.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "telebit.app", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "lahppi.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "pomorze.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "halloffame.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "shimogo.fukushima.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "karpacz.pl", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "keymachine.de", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", - "toki.gifu.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", - "property", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "myfritz.net", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "pol.ht", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "izumizaki.fukushima.jp", - "", "", "", "", "", - "tokorozawa.saitama.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "project.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "livinghistory.museum", - "", "", - "tsuruga.fukui.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "likescandy.com", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "lillehammer.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", - "palmas.br", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", - "lillesand.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "takanezawa.tochigi.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "bellevue.museum", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "takarazuka.hyogo.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "pol.dz", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "ofunato.iwate.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", - "lea\305\213gaviika.no", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "pokrovsk.su", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", - "loginto.me", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "toyotsu.fukuoka.jp", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", - "laspezia.it", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "geometre-expert.fr", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", "", "", "", "", "", - "", "", "", "", - "poltava.ua" - }; - - if (len <= MAX_WORD_LENGTH && len >= MIN_WORD_LENGTH) - { - unsigned int key = hash (str, len); - - if (key <= MAX_HASH_VALUE) - { - const char *s = wordlist[key]; - - if (*str == *s && !strcmp (str + 1, s + 1)) - return s; - } - } - return 0; -} -#line 8638 "tldLookup.gperf" - -%{ -} -%} diff --git a/dbms/src/Functions/gperf/tldLookup.gperf b/dbms/src/Functions/gperf/tldLookup.gperf index 0c6dd47f221..9816a4f86e2 100644 --- a/dbms/src/Functions/gperf/tldLookup.gperf +++ b/dbms/src/Functions/gperf/tldLookup.gperf @@ -7,7 +7,6 @@ # List generated using https://publicsuffix.org/list/public_suffix_list.dat %% - com.ac edu.ac gov.ac From bd9a5838695a140d5e18eaff054438a2348b08b3 Mon Sep 17 00:00:00 2001 From: Guillaume Tassery Date: Thu, 18 Apr 2019 10:49:24 +0700 Subject: [PATCH 052/709] Adapt coding style top level domain lookup --- .../src/Functions/firstSignificantSubdomain.h | 20 ++++++++++--------- 1 file changed, 11 insertions(+), 9 deletions(-) diff --git a/dbms/src/Functions/firstSignificantSubdomain.h b/dbms/src/Functions/firstSignificantSubdomain.h index 7ba6ea36905..ddc056df9f9 100644 --- a/dbms/src/Functions/firstSignificantSubdomain.h +++ b/dbms/src/Functions/firstSignificantSubdomain.h @@ -58,20 +58,22 @@ struct ExtractFirstSignificantSubdomain if (!last_3_periods[2]) last_3_periods[2] = begin - 1; - auto end_of_level_domain = find_first_symbols<'/'>(last_3_periods[0], end); - if (!end_of_level_domain) - { - end_of_level_domain = end; - } + auto end_of_level_domain = find_first_symbols<'/'>(last_3_periods[0], end); + if (!end_of_level_domain) + { + end_of_level_domain = end; + } - if (tldLookup::is_valid(last_3_periods[1] + 1, end_of_level_domain - last_3_periods[1] - 1) != nullptr) - { + if (tldLookup::is_valid(last_3_periods[1] + 1, end_of_level_domain - last_3_periods[1] - 1) != nullptr) + { res_data += last_3_periods[2] + 1 - begin; res_size = last_3_periods[1] - last_3_periods[2] - 1; - } else { + } + else + { res_data += last_3_periods[1] + 1 - begin; res_size = last_3_periods[0] - last_3_periods[1] - 1; - } + } } }; From 5c67ecd46d803f97908563b27fc9cf9a95f7b393 Mon Sep 17 00:00:00 2001 From: Guillaume Tassery Date: Thu, 18 Apr 2019 17:20:31 +0700 Subject: [PATCH 053/709] Add gperf dependency --- docker/builder/Dockerfile | 3 ++- 1 file changed, 2 insertions(+), 1 deletion(-) diff --git a/docker/builder/Dockerfile b/docker/builder/Dockerfile index 024803e6e6c..31b73b63008 100644 --- a/docker/builder/Dockerfile +++ b/docker/builder/Dockerfile @@ -22,7 +22,8 @@ RUN apt-get update -y \ python-requests \ python-termcolor \ sudo \ - tzdata + tzdata \ + gperf COPY build.sh / From 90f5cc569d5b449c305939e79da5d85a585b99e8 Mon Sep 17 00:00:00 2001 From: Guillaume Tassery Date: Fri, 19 Apr 2019 10:02:13 +0700 Subject: [PATCH 054/709] Add gperf dependency for packager dockerfile --- docker/packager/deb/Dockerfile | 3 ++- 1 file changed, 2 insertions(+), 1 deletion(-) diff --git a/docker/packager/deb/Dockerfile b/docker/packager/deb/Dockerfile index 6a7f7325122..b314c27780b 100644 --- a/docker/packager/deb/Dockerfile +++ b/docker/packager/deb/Dockerfile @@ -58,7 +58,8 @@ RUN apt-get --allow-unauthenticated update -y \ libjemalloc-dev \ unixodbc-dev \ odbcinst \ - tzdata + tzdata \ + gperf From 0d931918ce1ac188ae8973bf03ca80c4b6311aca Mon Sep 17 00:00:00 2001 From: Guillaume Tassery Date: Fri, 19 Apr 2019 11:07:15 +0700 Subject: [PATCH 055/709] Add gperf dependency for binary packager dockerfile --- docker/packager/binary/Dockerfile | 3 ++- 1 file changed, 2 insertions(+), 1 deletion(-) diff --git a/docker/packager/binary/Dockerfile b/docker/packager/binary/Dockerfile index 5b32abfb7ef..be393661d23 100644 --- a/docker/packager/binary/Dockerfile +++ b/docker/packager/binary/Dockerfile @@ -32,6 +32,7 @@ RUN apt-get update -y \ libreadline-dev \ ninja-build \ git \ - tzdata + tzdata \ + gperf CMD mkdir -p build/build_result && cd build/build_result && cmake .. -DCMAKE_BUILD_TYPE=$BUILD_TYPE -DSANITIZE=$SANITIZER $CMAKE_FLAGS && ninja && mv ./dbms/programs/clickhouse* /output && mv ./dbms/unit_tests_dbms /output From 7a75003d2664dba575d94808abe072a99f89c3c9 Mon Sep 17 00:00:00 2001 From: Guillaume Tassery Date: Fri, 19 Apr 2019 19:14:10 +0700 Subject: [PATCH 056/709] Send X-ClickHouse-Progress header in the end of a query execution --- .../IO/WriteBufferFromHTTPServerResponse.cpp | 21 ++++++++++++------- .../IO/WriteBufferFromHTTPServerResponse.h | 3 +++ 2 files changed, 17 insertions(+), 7 deletions(-) diff --git a/dbms/src/IO/WriteBufferFromHTTPServerResponse.cpp b/dbms/src/IO/WriteBufferFromHTTPServerResponse.cpp index e3faf942943..707ba8db1c2 100644 --- a/dbms/src/IO/WriteBufferFromHTTPServerResponse.cpp +++ b/dbms/src/IO/WriteBufferFromHTTPServerResponse.cpp @@ -36,11 +36,24 @@ void WriteBufferFromHTTPServerResponse::startSendHeaders() } } +void WriteBufferFromHTTPServerResponse::writeHeaderProgress() +{ + if (headers_finished_sending) + return; + + WriteBufferFromOwnString progress_string_writer; + accumulated_progress.writeJSON(progress_string_writer); + +#if defined(POCO_CLICKHOUSE_PATCH) + *response_header_ostr << "X-ClickHouse-Progress: " << progress_string_writer.str() << "\r\n" << std::flush; +#endif +} void WriteBufferFromHTTPServerResponse::finishSendHeaders() { if (!headers_finished_sending) { + writeHeaderProgress(); headers_finished_sending = true; if (request.getMethod() != Poco::Net::HTTPRequest::HTTP_HEAD) @@ -174,13 +187,7 @@ void WriteBufferFromHTTPServerResponse::onProgress(const Progress & progress) /// Send all common headers before our special progress headers. startSendHeaders(); - - WriteBufferFromOwnString progress_string_writer; - accumulated_progress.writeJSON(progress_string_writer); - -#if defined(POCO_CLICKHOUSE_PATCH) - *response_header_ostr << "X-ClickHouse-Progress: " << progress_string_writer.str() << "\r\n" << std::flush; -#endif + writeHeaderProgress(); } } diff --git a/dbms/src/IO/WriteBufferFromHTTPServerResponse.h b/dbms/src/IO/WriteBufferFromHTTPServerResponse.h index f82e5828694..447a376dda7 100644 --- a/dbms/src/IO/WriteBufferFromHTTPServerResponse.h +++ b/dbms/src/IO/WriteBufferFromHTTPServerResponse.h @@ -80,6 +80,9 @@ private: /// but not finish them with \r\n, allowing to send more headers subsequently. void startSendHeaders(); + // Used for write the header X-ClickHouse-progress + void writeHeaderProgress(); + /// This method finish headers with \r\n, allowing to start to send body. void finishSendHeaders(); From b6d2c9f4d296483533ae982e4bcb3a821a14bd7a Mon Sep 17 00:00:00 2001 From: Alexander Kozhikhov Date: Sun, 21 Apr 2019 02:22:42 +0300 Subject: [PATCH 057/709] some review fixes --- .../AggregateFunctionMLMethod.cpp | 43 ++++--- .../AggregateFunctionMLMethod.h | 115 ++++++++++-------- .../AggregateFunctions/IAggregateFunction.h | 7 ++ dbms/src/Columns/ColumnAggregateFunction.cpp | 29 +++-- dbms/src/Core/Field.h | 1 + 5 files changed, 113 insertions(+), 82 deletions(-) diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp index d217511b2bc..2e863134984 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp @@ -17,23 +17,28 @@ AggregateFunctionPtr createAggregateFunctionMLMethod( const std::string & name, const DataTypes & argument_types, const Array & parameters) { if (parameters.size() > 4) - throw Exception("Aggregate function " + name + " requires at most four parameters", ErrorCodes::NUMBER_OF_ARGUMENTS_DOESNT_MATCH); + throw Exception("Aggregate function " + name + " requires at most four parameters: learning_rate, l2_regularization_coef, mini-batch size and weights_updater method", ErrorCodes::NUMBER_OF_ARGUMENTS_DOESNT_MATCH); if (argument_types.size() < 2) - throw Exception("Aggregate function " + name + " requires at least two arguments", ErrorCodes::NUMBER_OF_ARGUMENTS_DOESNT_MATCH); + throw Exception("Aggregate function " + name + " requires at least two arguments: target and model's parameters", ErrorCodes::NUMBER_OF_ARGUMENTS_DOESNT_MATCH); for (size_t i = 0; i < argument_types.size(); ++i) { - if (!WhichDataType(argument_types[i]).isFloat64()) - throw Exception("Illegal type " + argument_types[i]->getName() + " of argument " + std::to_string(i) + "for aggregate function " + name, ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT); +// if (!WhichDataType(argument_types[i]).isFloat64()) +// throw Exception("Illegal type " + argument_types[i]->getName() + " of argument " + std::to_string(i) + "for aggregate function " + name, ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT); +// if (!WhichDataType(argument_types[i]).isNumeric()) + if (!isNumber(argument_types[i])) + throw Exception("Argument " + std::to_string(i) + " of type " + argument_types[i]->getName() + " must be numeric for aggregate function " + name, ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT); } - Float64 learning_rate = Float64(0.01); - Float64 l2_reg_coef = Float64(0.01); + /// Such default parameters were picked because they did good on some tests, + /// though it still requires to fit parameters to achieve better result + auto learning_rate = Float64(0.01); + auto l2_reg_coef = Float64(0.01); UInt32 batch_size = 1; - std::shared_ptr wu; - std::shared_ptr gc; + std::shared_ptr weights_updater = std::make_unique(); + std::shared_ptr gradient_computer; if (!parameters.empty()) { @@ -52,15 +57,15 @@ AggregateFunctionPtr createAggregateFunctionMLMethod( { if (applyVisitor(FieldVisitorConvertToNumber(), parameters[3]) == Float64{1.0}) { - wu = std::make_shared(); + weights_updater = std::make_shared(); } else if (applyVisitor(FieldVisitorConvertToNumber(), parameters[3]) == Float64{2.0}) { - wu = std::make_shared(); + weights_updater = std::make_shared(); } else if (applyVisitor(FieldVisitorConvertToNumber(), parameters[3]) == Float64{3.0}) { - wu = std::make_shared(); + weights_updater = std::make_shared(); } else @@ -68,18 +73,18 @@ AggregateFunctionPtr createAggregateFunctionMLMethod( throw Exception("Invalid parameter for weights updater", ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT); } } - else - { - wu = std::make_unique(); - } +// else +// { +// weights_updater = std::make_unique(); +// } if (std::is_same::value) { - gc = std::make_shared(); + gradient_computer = std::make_shared(); } else if (std::is_same::value) { - gc = std::make_shared(); + gradient_computer = std::make_shared(); } else { @@ -87,7 +92,9 @@ AggregateFunctionPtr createAggregateFunctionMLMethod( } - return std::make_shared(argument_types.size() - 1, gc, wu, learning_rate, l2_reg_coef, batch_size, argument_types, parameters); + return std::make_shared(argument_types.size() - 1, + gradient_computer, weights_updater, + learning_rate, l2_reg_coef, batch_size, argument_types, parameters); } } diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h index a7d2837abfa..5e022ec410a 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h @@ -39,14 +39,13 @@ public: virtual ~IGradientComputer() = default; /// Adds computed gradient in new point (weights, bias) to batch_gradient - virtual void compute(std::vector * batch_gradient, const std::vector &weights, Float64 bias, + virtual void compute(std::vector & batch_gradient, const std::vector &weights, Float64 bias, Float64 learning_rate, Float64 l2_reg_coef, Float64 target, const IColumn **columns, size_t row_num) = 0; - /// Now we should use predict_block function instead of predict - virtual void predict_block(ColumnVector::Container &container, - Block &block, const ColumnNumbers &arguments, - const std::vector &weights, - Float64 bias) const = 0; + virtual void predict(ColumnVector::Container &container, + Block &block, const ColumnNumbers &arguments, + const std::vector &weights, + Float64 bias) const = 0; }; @@ -56,48 +55,55 @@ public: LinearRegression() {} - void compute(std::vector * batch_gradient, const std::vector &weights, Float64 bias, + void compute(std::vector & batch_gradient, const std::vector &weights, Float64 bias, Float64 learning_rate, Float64 l2_reg_coef, Float64 target, const IColumn **columns, size_t row_num) override { Float64 derivative = (target - bias); for (size_t i = 0; i < weights.size(); ++i) { - derivative -= weights[i] * static_cast &>(*columns[i]).getData()[row_num]; +// auto value = static_cast &>(*columns[i]).getData()[row_num]; + auto value = (*columns[i])[row_num].get(); +// if ((*columns[i])[row_num].getType() == Field::Types::Float64) + derivative -= weights[i] * value; +// else +// derivative -= weights[i] * (*columns[i])[row_num].get(); } derivative *= (2 * learning_rate); - (*batch_gradient)[weights.size()] += derivative; + batch_gradient[weights.size()] += derivative; for (size_t i = 0; i < weights.size(); ++i) { - (*batch_gradient)[i] += - derivative * static_cast &>(*columns[i]).getData()[row_num] - - 2 * l2_reg_coef * weights[i]; +// auto value = static_cast &>(*columns[i]).getData()[row_num]; + auto value = (*columns[i])[row_num].get(); + batch_gradient[i] += derivative * value - 2 * l2_reg_coef * weights[i]; } } - void predict_block(ColumnVector::Container &container, - Block &block, - const ColumnNumbers &arguments, - const std::vector &weights, Float64 bias) const override + void predict(ColumnVector::Container &container, + Block &block, + const ColumnNumbers &arguments, + const std::vector &weights, Float64 bias) const override { size_t rows_num = block.rows(); std::vector results(rows_num, bias); for (size_t i = 1; i < arguments.size(); ++i) { - ColumnPtr cur_col = block.getByPosition(arguments[i]).column; + ColumnPtr cur_col = block.safeGetByPosition(arguments[i]).column; for (size_t row_num = 0; row_num != rows_num; ++row_num) { const auto &element = (*cur_col)[row_num]; - if (element.getType() != Field::Types::Float64) - throw Exception("Prediction arguments must be values of type Float", +// if (element.getType() != Field::Types::Float64) + if (!DB::Field::isSimpleNumeric(element.getType())) + throw Exception("Prediction arguments must be have numeric type", ErrorCodes::BAD_ARGUMENTS); results[row_num] += weights[i - 1] * element.get(); } } + container.reserve(rows_num); for (size_t row_num = 0; row_num != rows_num; ++row_num) { container.emplace_back(results[row_num]); @@ -112,28 +118,28 @@ public: LogisticRegression() {} - void compute(std::vector * batch_gradient, const std::vector &weights, Float64 bias, + void compute(std::vector & batch_gradient, const std::vector & weights, Float64 bias, Float64 learning_rate, Float64 l2_reg_coef, Float64 target, const IColumn **columns, size_t row_num) override { Float64 derivative = bias; for (size_t i = 0; i < weights.size(); ++i) { - derivative += weights[i] * static_cast &>(*columns[i]).getData()[row_num]; + auto value = static_cast &>(*columns[i]).getData()[row_num]; + derivative += weights[i] * value; } derivative *= target; derivative = exp(derivative); - (*batch_gradient)[weights.size()] += learning_rate * target / (derivative + 1); + batch_gradient[weights.size()] += learning_rate * target / (derivative + 1); for (size_t i = 0; i < weights.size(); ++i) { - (*batch_gradient)[i] += - learning_rate * target * - static_cast &>(*columns[i]).getData()[row_num] / (derivative + 1) - - 2 * l2_reg_coef * weights[i]; + auto value = static_cast &>(*columns[i]).getData()[row_num]; + batch_gradient[i] += learning_rate * target * value / (derivative + 1) + - 2 * l2_reg_coef * weights[i]; } } - void predict_block(ColumnVector::Container & container, + void predict(ColumnVector::Container & container, Block & block, const ColumnNumbers & arguments, const std::vector & weights, Float64 bias) const override @@ -143,17 +149,19 @@ public: for (size_t i = 1; i < arguments.size(); ++i) { - ColumnPtr cur_col = block.getByPosition(arguments[i]).column; + ColumnPtr cur_col = block.safeGetByPosition(arguments[i]).column; for (size_t row_num = 0; row_num != rows_num; ++row_num) { const auto &element = (*cur_col)[row_num]; - if (element.getType() != Field::Types::Float64) - throw Exception("Prediction arguments must be values of type Float", - ErrorCodes::BAD_ARGUMENTS); +// if (element.getType() != Field::Types::Float64) + if (!DB::Field::isSimpleNumeric(element.getType())) + throw Exception("Prediction arguments must have numeric type", ErrorCodes::BAD_ARGUMENTS); results[row_num] += weights[i - 1] * element.get(); } } + + container.reserve(rows_num); for (size_t row_num = 0; row_num != rows_num; ++row_num) { container.emplace_back(1 / (1 + exp(-results[row_num]))); @@ -164,30 +172,35 @@ public: /** * IWeightsUpdater class defines the way to update current weights -* and uses class GradientComputer on each iteration +* and uses GradientComputer class on each iteration */ class IWeightsUpdater { public: virtual ~IWeightsUpdater() = default; - virtual void add_to_batch(std::vector * batch_gradient, std::shared_ptr gc, + /// Calls GradientComputer to update current mini-batch + virtual void add_to_batch(std::vector & batch_gradient, IGradientComputer & gradient_computer, const std::vector & weights, Float64 bias, Float64 learning_rate, Float64 l2_reg_coef, Float64 target, const IColumn **columns, size_t row_num) { - gc->compute(batch_gradient, weights, bias, learning_rate, l2_reg_coef, target, columns, row_num); + gradient_computer.compute(batch_gradient, weights, bias, learning_rate, l2_reg_coef, target, columns, row_num); } + /// Updates current weights according to the gradient from the last mini-batch virtual void update(UInt32 batch_size, std::vector & weights, Float64 & bias, const std::vector & gradient) = 0; + /// Used during the merge of two states virtual void merge(const IWeightsUpdater &, Float64, Float64) {} + /// Used for serialization when necessary virtual void write(WriteBuffer &) const {} + /// Used for serialization when necessary virtual void read(ReadBuffer &) {} }; @@ -275,13 +288,13 @@ public: Nesterov(Float64 alpha) : alpha_(alpha) {} - void add_to_batch(std::vector * batch_gradient, std::shared_ptr gc, + void add_to_batch(std::vector & batch_gradient, IGradientComputer & gradient_computer, const std::vector & weights, Float64 bias, Float64 learning_rate, Float64 l2_reg_coef, Float64 target, const IColumn ** columns, size_t row_num) override { if (accumulated_gradient.empty()) { - accumulated_gradient.resize(batch_gradient->size(), Float64{0.0}); + accumulated_gradient.resize(batch_gradient.size(), Float64{0.0}); } std::vector shifted_weights(weights.size()); @@ -291,7 +304,7 @@ public: } auto shifted_bias = bias + accumulated_gradient[weights.size()] * alpha_; - gc->compute(batch_gradient, shifted_weights, shifted_bias, learning_rate, l2_reg_coef, target, columns, row_num); + gradient_computer.compute(batch_gradient, shifted_weights, shifted_bias, learning_rate, l2_reg_coef, target, columns, row_num); } void update(UInt32 batch_size, @@ -353,14 +366,14 @@ public: Float64 l2_reg_coef, UInt32 param_num, UInt32 batch_capacity, - std::shared_ptr gc, - std::shared_ptr wu) + std::shared_ptr gradient_computer, + std::shared_ptr weights_updater) : learning_rate(learning_rate), l2_reg_coef(l2_reg_coef), batch_capacity(batch_capacity), batch_size(0), - gradient_computer(std::move(gc)), - weights_updater(std::move(wu)) + gradient_computer(std::move(gradient_computer)), + weights_updater(std::move(weights_updater)) { weights.resize(param_num, Float64{0.0}); gradient_batch.resize(param_num + 1, Float64{0.0}); @@ -372,7 +385,7 @@ public: const auto &target = static_cast &>(*columns[0]).getData()[row_num]; /// Here we have columns + 1 as first column corresponds to target value, and others - to features - weights_updater->add_to_batch(&gradient_batch, gradient_computer, + weights_updater->add_to_batch(gradient_batch, *gradient_computer, weights, bias, learning_rate, l2_reg_coef, target, columns + 1, row_num); ++batch_size; @@ -422,9 +435,9 @@ public: weights_updater->read(buf); } - void predict_block(ColumnVector::Container &container, Block &block, const ColumnNumbers &arguments) const + void predict(ColumnVector::Container &container, Block &block, const ColumnNumbers &arguments) const { - gradient_computer->predict_block(container, block, arguments, weights, bias); + gradient_computer->predict(container, block, arguments, weights, bias); } private: @@ -482,8 +495,8 @@ public: learning_rate(learning_rate), l2_reg_coef(l2_reg_coef), batch_size(batch_size), - gc(std::move(gradient_computer)), - wu(std::move(weights_updater)) + gradient_computer(std::move(gradient_computer)), + weights_updater(std::move(weights_updater)) {} DataTypePtr getReturnType() const override @@ -493,7 +506,7 @@ public: void create(AggregateDataPtr place) const override { - new (place) Data(learning_rate, l2_reg_coef, param_num, batch_size, gc, wu); + new (place) Data(learning_rate, l2_reg_coef, param_num, batch_size, gradient_computer, weights_updater); } void add(AggregateDataPtr place, const IColumn ** columns, size_t row_num, Arena *) const override @@ -516,7 +529,7 @@ public: this->data(place).read(buf); } - void predictResultInto(ConstAggregateDataPtr place, IColumn & to, Block & block, const ColumnNumbers & arguments) const + void predictValues(ConstAggregateDataPtr place, IColumn & to, Block & block, const ColumnNumbers & arguments) const override { if (arguments.size() != param_num + 1) throw Exception("Predict got incorrect number of arguments. Got: " + @@ -525,7 +538,7 @@ public: auto &column = dynamic_cast &>(to); - this->data(place).predict_block(column.getData(), block, arguments); + this->data(place).predict(column.getData(), block, arguments); } void insertResultInto(ConstAggregateDataPtr place, IColumn & to) const override @@ -542,8 +555,8 @@ private: Float64 learning_rate; Float64 l2_reg_coef; UInt32 batch_size; - std::shared_ptr gc; - std::shared_ptr wu; + std::shared_ptr gradient_computer; + std::shared_ptr weights_updater; }; struct NameLinearRegression { static constexpr auto name = "LinearRegression"; }; diff --git a/dbms/src/AggregateFunctions/IAggregateFunction.h b/dbms/src/AggregateFunctions/IAggregateFunction.h index 694a5955310..5737ec21300 100644 --- a/dbms/src/AggregateFunctions/IAggregateFunction.h +++ b/dbms/src/AggregateFunctions/IAggregateFunction.h @@ -7,6 +7,8 @@ #include #include +#include +#include #include @@ -92,6 +94,11 @@ public: /// Inserts results into a column. virtual void insertResultInto(ConstAggregateDataPtr place, IColumn & to) const = 0; + /// This function is used for machine learning methods + virtual void predictValues(ConstAggregateDataPtr /* place */, IColumn & /*to*/, + Block & /*block*/, const ColumnNumbers & /*arguments*/) const + {} + /** Returns true for aggregate functions of type -State. * They are executed as other aggregate functions, but not finalized (return an aggregation state that can be combined with another). */ diff --git a/dbms/src/Columns/ColumnAggregateFunction.cpp b/dbms/src/Columns/ColumnAggregateFunction.cpp index 8f92ccbd96a..19fff914cb9 100644 --- a/dbms/src/Columns/ColumnAggregateFunction.cpp +++ b/dbms/src/Columns/ColumnAggregateFunction.cpp @@ -35,6 +35,8 @@ void ColumnAggregateFunction::addArena(ArenaPtr arena_) arenas.push_back(arena_); } +/// This function is used in convertToValues() and predictValues() +/// and is written here to avoid repetitions bool ColumnAggregateFunction::convertion(MutableColumnPtr *res_) const { if (const AggregateFunctionState *function_state = typeid_cast(func.get())) @@ -109,27 +111,28 @@ MutableColumnPtr ColumnAggregateFunction::predictValues(Block & block, const Col return res; } - auto ML_function_Linear = typeid_cast *>(func.get()); - auto ML_function_Logistic = typeid_cast *>(func.get()); - if (ML_function_Linear) +// auto ML_function_Linear = typeid_cast *>(func.get()); +// auto ML_function_Logistic = typeid_cast *>(func.get()); + auto ML_function = func.get(); + if (ML_function) { size_t row_num = 0; for (auto val : data) { - ML_function_Linear->predictResultInto(val, *res, block, arguments); + ML_function->predictValues(val, *res, block, arguments); ++row_num; } } - else if (ML_function_Logistic) - { - size_t row_num = 0; - for (auto val : data) - { - ML_function_Logistic->predictResultInto(val, *res, block, arguments); - ++row_num; - } - } +// else if (ML_function_Logistic) +// { +// size_t row_num = 0; +// for (auto val : data) +// { +// ML_function_Logistic->predictValues(val, *res, block, arguments); +// ++row_num; +// } +// } else { throw Exception("Illegal aggregate function is passed", diff --git a/dbms/src/Core/Field.h b/dbms/src/Core/Field.h index 7afa1395710..9208a53a7d6 100644 --- a/dbms/src/Core/Field.h +++ b/dbms/src/Core/Field.h @@ -200,6 +200,7 @@ public: template struct TypeToEnum; template struct EnumToType; + static bool isSimpleNumeric(Types::Which which) { return which >= Types::UInt64 && which <= Types::Int128; } static bool IsDecimal(Types::Which which) { return which >= Types::Decimal32 && which <= Types::Decimal128; } Field() From daf4690d37d0a33b08ddb89f97a158b74b504205 Mon Sep 17 00:00:00 2001 From: Alexander Kozhikhov Date: Sun, 21 Apr 2019 17:32:42 +0300 Subject: [PATCH 058/709] review fixes --- .../AggregateFunctionMLMethod.cpp | 18 +--- .../AggregateFunctionMLMethod.h | 93 ++++++++++--------- .../AggregateFunctions/IAggregateFunction.h | 6 +- dbms/src/Columns/ColumnAggregateFunction.cpp | 20 +--- dbms/src/Columns/ColumnAggregateFunction.h | 2 +- dbms/src/Core/Field.h | 1 - dbms/src/Functions/evalMLMethod.cpp | 13 +-- .../queries/0_stateless/00935_ml_test.sql | 2 +- .../queries/0_stateless/00936_ml_test.sql | 2 +- .../queries/0_stateless/00937_ml_test.sql | 2 +- .../0_stateless/00938_dataset_test.sql | 2 +- .../queries/0_stateless/00939_ml_test.sql | 2 +- 12 files changed, 74 insertions(+), 89 deletions(-) diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp index 2e863134984..67a361d73c8 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp @@ -24,9 +24,6 @@ AggregateFunctionPtr createAggregateFunctionMLMethod( for (size_t i = 0; i < argument_types.size(); ++i) { -// if (!WhichDataType(argument_types[i]).isFloat64()) -// throw Exception("Illegal type " + argument_types[i]->getName() + " of argument " + std::to_string(i) + "for aggregate function " + name, ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT); -// if (!WhichDataType(argument_types[i]).isNumeric()) if (!isNumber(argument_types[i])) throw Exception("Argument " + std::to_string(i) + " of type " + argument_types[i]->getName() + " must be numeric for aggregate function " + name, ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT); } @@ -55,28 +52,20 @@ AggregateFunctionPtr createAggregateFunctionMLMethod( } if (parameters.size() > 3) { - if (applyVisitor(FieldVisitorConvertToNumber(), parameters[3]) == Float64{1.0}) - { + if (applyVisitor(FieldVisitorToString(), parameters[3]) == "\'SGD\'") { weights_updater = std::make_shared(); } - else if (applyVisitor(FieldVisitorConvertToNumber(), parameters[3]) == Float64{2.0}) - { + else if (applyVisitor(FieldVisitorToString(), parameters[3]) == "\'Momentum\'") { weights_updater = std::make_shared(); } - else if (applyVisitor(FieldVisitorConvertToNumber(), parameters[3]) == Float64{3.0}) - { + else if (applyVisitor(FieldVisitorToString(), parameters[3]) == "\'Nesterov\'") { weights_updater = std::make_shared(); - } else { throw Exception("Invalid parameter for weights updater", ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT); } } -// else -// { -// weights_updater = std::make_unique(); -// } if (std::is_same::value) { @@ -91,7 +80,6 @@ AggregateFunctionPtr createAggregateFunctionMLMethod( throw Exception("Such gradient computer is not implemented yet", ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT); } - return std::make_shared(argument_types.size() - 1, gradient_computer, weights_updater, learning_rate, l2_reg_coef, batch_size, argument_types, parameters); diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h index 5e022ec410a..d535a27adaa 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h @@ -14,6 +14,7 @@ #include #include #include +#include #include #include @@ -45,7 +46,7 @@ public: virtual void predict(ColumnVector::Container &container, Block &block, const ColumnNumbers &arguments, const std::vector &weights, - Float64 bias) const = 0; + Float64 bias, const Context & context) const = 0; }; @@ -61,19 +62,14 @@ public: Float64 derivative = (target - bias); for (size_t i = 0; i < weights.size(); ++i) { -// auto value = static_cast &>(*columns[i]).getData()[row_num]; - auto value = (*columns[i])[row_num].get(); -// if ((*columns[i])[row_num].getType() == Field::Types::Float64) - derivative -= weights[i] * value; -// else -// derivative -= weights[i] * (*columns[i])[row_num].get(); + auto value = (*columns[i])[row_num].get(); + derivative -= weights[i] * value; } derivative *= (2 * learning_rate); batch_gradient[weights.size()] += derivative; for (size_t i = 0; i < weights.size(); ++i) { -// auto value = static_cast &>(*columns[i]).getData()[row_num]; auto value = (*columns[i])[row_num].get(); batch_gradient[i] += derivative * value - 2 * l2_reg_coef * weights[i]; } @@ -82,24 +78,30 @@ public: void predict(ColumnVector::Container &container, Block &block, const ColumnNumbers &arguments, - const std::vector &weights, Float64 bias) const override + const std::vector &weights, Float64 bias, const Context & context) const override { size_t rows_num = block.rows(); std::vector results(rows_num, bias); for (size_t i = 1; i < arguments.size(); ++i) { - ColumnPtr cur_col = block.safeGetByPosition(arguments[i]).column; + const ColumnWithTypeAndName & cur_col = block.getByPosition(arguments[i]); + if (!isNumber(cur_col.type)) { + throw Exception("Prediction arguments must be have numeric type", ErrorCodes::BAD_ARGUMENTS); + } + + /// If column type is already Float64 then castColumn simply returns it + auto features_col_ptr = castColumn(cur_col, std::make_shared(), context); + auto features_column = typeid_cast(features_col_ptr.get()); + + if (!features_column) + { + throw Exception("Unexpectedly cannot dynamically cast features column " + std::to_string(i), ErrorCodes::LOGICAL_ERROR); + } + for (size_t row_num = 0; row_num != rows_num; ++row_num) { - - const auto &element = (*cur_col)[row_num]; -// if (element.getType() != Field::Types::Float64) - if (!DB::Field::isSimpleNumeric(element.getType())) - throw Exception("Prediction arguments must be have numeric type", - ErrorCodes::BAD_ARGUMENTS); - - results[row_num] += weights[i - 1] * element.get(); + results[row_num] += weights[i - 1] * features_column->getElement(row_num); } } @@ -124,7 +126,7 @@ public: Float64 derivative = bias; for (size_t i = 0; i < weights.size(); ++i) { - auto value = static_cast &>(*columns[i]).getData()[row_num]; + auto value = (*columns[i])[row_num].get(); derivative += weights[i] * value; } derivative *= target; @@ -133,7 +135,7 @@ public: batch_gradient[weights.size()] += learning_rate * target / (derivative + 1); for (size_t i = 0; i < weights.size(); ++i) { - auto value = static_cast &>(*columns[i]).getData()[row_num]; + auto value = (*columns[i])[row_num].get(); batch_gradient[i] += learning_rate * target * value / (derivative + 1) - 2 * l2_reg_coef * weights[i]; } @@ -142,22 +144,30 @@ public: void predict(ColumnVector::Container & container, Block & block, const ColumnNumbers & arguments, - const std::vector & weights, Float64 bias) const override + const std::vector & weights, Float64 bias, const Context & context) const override { size_t rows_num = block.rows(); std::vector results(rows_num, bias); for (size_t i = 1; i < arguments.size(); ++i) { - ColumnPtr cur_col = block.safeGetByPosition(arguments[i]).column; + const ColumnWithTypeAndName & cur_col = block.getByPosition(arguments[i]); + if (!isNumber(cur_col.type)) { + throw Exception("Prediction arguments must be have numeric type", ErrorCodes::BAD_ARGUMENTS); + } + + /// If column type is already Float64 then castColumn simply returns it + auto features_col_ptr = castColumn(cur_col, std::make_shared(), context); + auto features_column = typeid_cast(features_col_ptr.get()); + + if (!features_column) + { + throw Exception("Unexpectedly cannot dynamically cast features column " + std::to_string(i), ErrorCodes::LOGICAL_ERROR); + } + for (size_t row_num = 0; row_num != rows_num; ++row_num) { - const auto &element = (*cur_col)[row_num]; -// if (element.getType() != Field::Types::Float64) - if (!DB::Field::isSimpleNumeric(element.getType())) - throw Exception("Prediction arguments must have numeric type", ErrorCodes::BAD_ARGUMENTS); - - results[row_num] += weights[i - 1] * element.get(); + results[row_num] += weights[i - 1] * features_column->getElement(row_num); } } @@ -382,8 +392,7 @@ public: void add(const IColumn **columns, size_t row_num) { /// first column stores target; features start from (columns + 1) - const auto &target = static_cast &>(*columns[0]).getData()[row_num]; - + const auto &target = (*columns[0])[row_num].get(); /// Here we have columns + 1 as first column corresponds to target value, and others - to features weights_updater->add_to_batch(gradient_batch, *gradient_computer, weights, bias, learning_rate, l2_reg_coef, target, columns + 1, row_num); @@ -435,9 +444,9 @@ public: weights_updater->read(buf); } - void predict(ColumnVector::Container &container, Block &block, const ColumnNumbers &arguments) const + void predict(ColumnVector::Container &container, Block &block, const ColumnNumbers &arguments, const Context & context) const { - gradient_computer->predict(container, block, arguments, weights, bias); + gradient_computer->predict(container, block, arguments, weights, bias, context); } private: @@ -490,14 +499,14 @@ public: UInt32 batch_size, const DataTypes & arguments_types, const Array & params) - : IAggregateFunctionDataHelper>(arguments_types, params), - param_num(param_num), - learning_rate(learning_rate), - l2_reg_coef(l2_reg_coef), - batch_size(batch_size), - gradient_computer(std::move(gradient_computer)), - weights_updater(std::move(weights_updater)) - {} + : IAggregateFunctionDataHelper>(arguments_types, params), + param_num(param_num), + learning_rate(learning_rate), + l2_reg_coef(l2_reg_coef), + batch_size(batch_size), + gradient_computer(std::move(gradient_computer)), + weights_updater(std::move(weights_updater)) + {} DataTypePtr getReturnType() const override { @@ -529,7 +538,7 @@ public: this->data(place).read(buf); } - void predictValues(ConstAggregateDataPtr place, IColumn & to, Block & block, const ColumnNumbers & arguments) const override + void predictValues(ConstAggregateDataPtr place, IColumn & to, Block & block, const ColumnNumbers & arguments, const Context & context) const override { if (arguments.size() != param_num + 1) throw Exception("Predict got incorrect number of arguments. Got: " + @@ -538,7 +547,7 @@ public: auto &column = dynamic_cast &>(to); - this->data(place).predict(column.getData(), block, arguments); + this->data(place).predict(column.getData(), block, arguments, context); } void insertResultInto(ConstAggregateDataPtr place, IColumn & to) const override diff --git a/dbms/src/AggregateFunctions/IAggregateFunction.h b/dbms/src/AggregateFunctions/IAggregateFunction.h index 5737ec21300..b4456163fee 100644 --- a/dbms/src/AggregateFunctions/IAggregateFunction.h +++ b/dbms/src/AggregateFunctions/IAggregateFunction.h @@ -96,8 +96,10 @@ public: /// This function is used for machine learning methods virtual void predictValues(ConstAggregateDataPtr /* place */, IColumn & /*to*/, - Block & /*block*/, const ColumnNumbers & /*arguments*/) const - {} + Block & /*block*/, const ColumnNumbers & /*arguments*/, const Context & /*context*/) const + { + throw Exception("Method predictValues is not supported for " + getName(), ErrorCodes::NOT_IMPLEMENTED); + } /** Returns true for aggregate functions of type -State. * They are executed as other aggregate functions, but not finalized (return an aggregation state that can be combined with another). diff --git a/dbms/src/Columns/ColumnAggregateFunction.cpp b/dbms/src/Columns/ColumnAggregateFunction.cpp index 19fff914cb9..451b4377130 100644 --- a/dbms/src/Columns/ColumnAggregateFunction.cpp +++ b/dbms/src/Columns/ColumnAggregateFunction.cpp @@ -103,36 +103,22 @@ MutableColumnPtr ColumnAggregateFunction::convertToValues() const return res; } -MutableColumnPtr ColumnAggregateFunction::predictValues(Block & block, const ColumnNumbers & arguments) const +MutableColumnPtr ColumnAggregateFunction::predictValues(Block & block, const ColumnNumbers & arguments, const Context & context) const { MutableColumnPtr res; - if (convertion(&res)) - { - return res; - } + convertion(&res); -// auto ML_function_Linear = typeid_cast *>(func.get()); -// auto ML_function_Logistic = typeid_cast *>(func.get()); auto ML_function = func.get(); if (ML_function) { size_t row_num = 0; for (auto val : data) { - ML_function->predictValues(val, *res, block, arguments); + ML_function->predictValues(val, *res, block, arguments, context); ++row_num; } } -// else if (ML_function_Logistic) -// { -// size_t row_num = 0; -// for (auto val : data) -// { -// ML_function_Logistic->predictValues(val, *res, block, arguments); -// ++row_num; -// } -// } else { throw Exception("Illegal aggregate function is passed", diff --git a/dbms/src/Columns/ColumnAggregateFunction.h b/dbms/src/Columns/ColumnAggregateFunction.h index b7855cf2b37..a0bdfe4d88c 100644 --- a/dbms/src/Columns/ColumnAggregateFunction.h +++ b/dbms/src/Columns/ColumnAggregateFunction.h @@ -119,7 +119,7 @@ public: const char * getFamilyName() const override { return "AggregateFunction"; } bool convertion(MutableColumnPtr* res_) const; - MutableColumnPtr predictValues(Block & block, const ColumnNumbers & arguments) const; + MutableColumnPtr predictValues(Block & block, const ColumnNumbers & arguments, const Context & context) const; size_t size() const override { diff --git a/dbms/src/Core/Field.h b/dbms/src/Core/Field.h index 9208a53a7d6..7afa1395710 100644 --- a/dbms/src/Core/Field.h +++ b/dbms/src/Core/Field.h @@ -200,7 +200,6 @@ public: template struct TypeToEnum; template struct EnumToType; - static bool isSimpleNumeric(Types::Which which) { return which >= Types::UInt64 && which <= Types::Int128; } static bool IsDecimal(Types::Which which) { return which >= Types::Decimal32 && which <= Types::Decimal128; } Field() diff --git a/dbms/src/Functions/evalMLMethod.cpp b/dbms/src/Functions/evalMLMethod.cpp index ffdad6cf26e..a83bc717596 100644 --- a/dbms/src/Functions/evalMLMethod.cpp +++ b/dbms/src/Functions/evalMLMethod.cpp @@ -29,10 +29,12 @@ class FunctionEvalMLMethod : public IFunction { public: static constexpr auto name = "evalMLMethod"; - static FunctionPtr create(const Context &) + static FunctionPtr create(const Context & context) { - return std::make_shared(); + return std::make_shared(context); } + FunctionEvalMLMethod(const Context & context) : context(context) + {} String getName() const override { @@ -72,14 +74,13 @@ public: if (!column_with_states) throw Exception("Illegal column " + block.getByPosition(arguments[0]).column->getName() - + " of first argument of function " - + getName(), - ErrorCodes::ILLEGAL_COLUMN); + + " of first argument of function " + getName(), ErrorCodes::ILLEGAL_COLUMN); block.getByPosition(result).column = - typeid_cast(&*column_with_states->getDataColumnPtr())->predictValues(block, arguments); + typeid_cast(&*column_with_states->getDataColumnPtr())->predictValues(block, arguments, context); } + const Context & context; }; void registerFunctionEvalMLMethod(FunctionFactory & factory) diff --git a/dbms/tests/queries/0_stateless/00935_ml_test.sql b/dbms/tests/queries/0_stateless/00935_ml_test.sql index b6a02893840..ab6a033e941 100644 --- a/dbms/tests/queries/0_stateless/00935_ml_test.sql +++ b/dbms/tests/queries/0_stateless/00935_ml_test.sql @@ -11,7 +11,7 @@ CREATE TABLE IF NOT EXISTS test.defaults insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0); DROP TABLE IF EXISTS test.model; -create table test.model engine = Memory as select LinearRegressionState(0.1, 0.0, 2, 1.0)(target, param1, param2) as state from test.defaults; +create table test.model engine = Memory as select LinearRegressionState(0.1, 0.0, 2, 'SGD')(target, param1, param2) as state from test.defaults; select ans < -61.374 and ans > -61.375 from (with (select state from remote('127.0.0.1', test.model)) as model select evalMLMethod(model, predict1, predict2) as ans from remote('127.0.0.1', test.defaults)); diff --git a/dbms/tests/queries/0_stateless/00936_ml_test.sql b/dbms/tests/queries/0_stateless/00936_ml_test.sql index 9dbb7ece7fe..c03aba972e7 100644 --- a/dbms/tests/queries/0_stateless/00936_ml_test.sql +++ b/dbms/tests/queries/0_stateless/00936_ml_test.sql @@ -10,7 +10,7 @@ CREATE TABLE IF NOT EXISTS test.defaults ) ENGINE = Memory; insert into test.defaults values (1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2),(1,2,1,-1,-2),(-1,-2,-1,1,2) DROP TABLE IF EXISTS test.model; -create table test.model engine = Memory as select LogisticRegressionState(0.1, 0.0, 1.0, 1)(target, param1, param2) as state from test.defaults; +create table test.model engine = Memory as select LogisticRegressionState(0.1, 0.0, 1.0, 'SGD')(target, param1, param2) as state from test.defaults; select ans < 1.1 and ans > 0.9 from (with (select state from test.model) as model select evalMLMethod(model, predict1, predict2) as ans from test.defaults limit 2); diff --git a/dbms/tests/queries/0_stateless/00937_ml_test.sql b/dbms/tests/queries/0_stateless/00937_ml_test.sql index 94dea65ed55..465be25acb5 100644 --- a/dbms/tests/queries/0_stateless/00937_ml_test.sql +++ b/dbms/tests/queries/0_stateless/00937_ml_test.sql @@ -21,5 +21,5 @@ CREATE TABLE IF NOT EXISTS test.defaults ) ENGINE = Memory; insert into test.defaults values (1.76210664421617,1.7469706406568504,0.7988286239230257,1.0938642223599824,1.167321139201246,1.7648182796261376,0.909111664354187,0.92,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.6276564089897139,-0.06763531281107672,0.7988286239230257,0.5966532121963541,1.167321139201246,0.4551512643242912,0.909111664354187,0.76,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(-0.07046681268810527,-0.5625278455750569,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-1.0056311758200724,0.909111664354187,0.72,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.4531256035702591,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-1.0614543055744028,0.11933920911869125,0.909111664354187,0.8,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(-0.24499761810756004,-0.7274920231630502,-0.952028633990455,-1.3921908284581592,-0.5042604443804907,-0.6530285178541898,-1.0999748867047898,0.65,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(1.1512488252480781,1.2520781078928702,1.674257252879766,1.0938642223599824,-0.5042604443804907,1.244309594057455,0.909111664354187,0.9,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,0.6101272780073337,-0.6698191206144725,0.909111664354187,0.75,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(-0.7685900343659244,-1.057420378339037,-0.952028633990455,-0.3977688081309026,0.6101272780073337,-1.1735372034228724,-1.0999748867047898,0.68,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(-1.2921824506242887,-0.8924562007510436,-1.8274572629471952,-1.3921908284581592,-2.175842027962227,-1.0056311758200724,-1.0999748867047898,0.5,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.5403910062799865,0.09732886477691666,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,0.0018049897967303734,-1.0999748867047898,0.45,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.7149218116994412,-0.2325994903990701,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.3340070654088696,0.909111664354187,0.52,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.889452617118896,0.5922213975408968,0.7988286239230257,0.5966532121963541,1.167321139201246,0.6734291002079332,0.909111664354187,0.84,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.9767180198286235,0.7571855751288902,0.7988286239230257,0.5966532121963541,1.167321139201246,0.8413351278107333,0.909111664354187,0.78,-0.5940592289464697,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(-0.8558554370756518,0.26229304236491,-0.0766000050337147,0.5966532121963541,-0.5042604443804907,-1.0056311758200724,0.909111664354187,0.62,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(-0.5067938262367422,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,-1.618648166768315,-0.6698191206144725,0.909111664354187,0.61,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(-0.24499761810756004,-0.39756366798706344,-0.0766000050337147,0.09944220203272576,-1.0614543055744028,-0.5019130930116695,-1.0999748867047898,0.54,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(0.016798590021622126,-0.06763531281107672,-0.0766000050337147,0.5966532121963541,-0.5042604443804907,0.16971101739953035,-1.0999748867047898,0.66,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(0.1913293954410769,-0.2325994903990701,-0.0766000050337147,0.5966532121963541,-0.5042604443804907,-1.0056311758200724,0.909111664354187,0.65,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(0.10406399273134952,0.4272572199529034,-0.0766000050337147,0.5966532121963541,-0.5042604443804907,0.3376170450023333,-1.0999748867047898,0.63,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(-1.2049170479145614,-0.8924562007510436,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,-0.1661010378060696,-1.0999748867047898,0.62,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(-0.41952842352701486,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,-1.618648166768315,-1.1735372034228724,0.909111664354187,0.64,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(0.7149218116994412,1.087113930304877,0.7988286239230257,-0.3977688081309026,-1.618648166768315,-0.3340070654088696,-1.0999748867047898,0.7,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(0.9767180198286235,1.4170422854808635,1.674257252879766,1.5910752325236108,1.724515000395158,1.5129592382219361,0.909111664354187,0.94,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(1.5003104360869879,1.9119348182448437,1.674257252879766,1.5910752325236108,1.167321139201246,1.848771293427536,0.909111664354187,0.95,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(1.6748412415064426,1.9119348182448437,1.674257252879766,0.5966532121963541,0.052933416813421515,2.016677321030339,0.909111664354187,0.97,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,1.0428223609340956,0.909111664354187),(2.023902852345352,2.076898995832837,1.674257252879766,1.0938642223599824,1.167321139201246,1.680865265824736,0.909111664354187,0.94,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(0.4531256035702591,0.26229304236491,1.674257252879766,1.0938642223599824,0.052933416813421515,0.3376170450023333,-1.0999748867047898,0.76,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(-1.6412440614631982,-1.5523129111030172,-0.952028633990455,-1.8894018386217877,-1.0614543055744028,-1.8451613138340752,0.909111664354187,0.44,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(-1.9030402695923805,-2.377133799042984,-1.8274572629471952,-1.3921908284581592,-1.618648166768315,-2.348879396642477,-1.0999748867047898,0.46,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(-0.5940592289464697,-1.3873487335150236,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-2.180973369039677,-1.0999748867047898,0.54,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(-1.4667132560437435,-1.7172770886910105,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,-0.8377251482172725,0.909111664354187,0.65,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(0.889452617118896,-0.7274920231630502,-0.0766000050337147,0.5966532121963541,0.6101272780073337,-0.5019130930116695,0.909111664354187,0.74,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(1.8493720469258974,1.7469706406568504,0.7988286239230257,-0.3977688081309026,1.167321139201246,1.3450532106191362,0.909111664354187,0.91,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(2.023902852345352,1.087113930304877,1.674257252879766,0.5966532121963541,0.6101272780073337,1.680865265824736,0.909111664354187,0.9,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(1.2385142279578056,0.7571855751288902,1.674257252879766,0.5966532121963541,1.724515000395158,2.016677321030339,0.909111664354187,0.94,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(0.2785947981508043,0.4272572199529034,1.674257252879766,1.5910752325236108,1.724515000395158,1.0092411554135332,0.909111664354187,0.88,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(-1.553978658753471,-0.2325994903990701,-0.952028633990455,0.5966532121963541,0.6101272780073337,-0.3340070654088696,-1.0999748867047898,0.64,1.6748412415064426,1.9119348182448437,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.7144464713452956,0.909111664354187),(-1.4667132560437435,-0.39756366798706344,-1.8274572629471952,-2.386612848785416,-1.618648166768315,-1.3414432310256739,-1.0999748867047898,0.58,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(-1.117651645204834,-0.39756366798706344,-1.8274572629471952,-0.3977688081309026,-2.175842027962227,-1.8451613138340752,-1.0999748867047898,0.52,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(-0.8558554370756518,0.09732886477691666,-0.952028633990455,0.5966532121963541,0.052933416813421515,-1.5093492586284738,-1.0999748867047898,0.48,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(-0.7685900343659244,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,-1.0056311758200724,0.909111664354187,0.46,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(-0.07046681268810527,-0.39756366798706344,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.6698191206144725,0.909111664354187,0.49,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(-0.3322630208172874,-0.06763531281107672,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-0.1661010378060696,0.909111664354187,0.53,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(1.3257796306675331,1.582006463068857,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.8413351278107333,-1.0999748867047898,0.87,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(0.8021872144091686,0.9221497527168835,1.674257252879766,1.0938642223599824,0.6101272780073337,1.3450532106191362,0.909111664354187,0.91,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(0.4531256035702591,0.4272572199529034,1.674257252879766,1.5910752325236108,0.6101272780073337,0.8413351278107333,0.909111664354187,0.88,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(1.0639834225383509,1.087113930304877,1.674257252879766,0.5966532121963541,1.724515000395158,1.1771471830163363,0.909111664354187,0.86,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(1.9366374496356247,1.9119348182448437,1.674257252879766,1.0938642223599824,0.6101272780073337,1.848771293427536,-1.0999748867047898,0.89,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(0.36586020086053167,0.4272572199529034,-0.0766000050337147,0.09944220203272576,1.724515000395158,0.42157005880373183,0.909111664354187,0.82,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(0.889452617118896,0.5922213975408968,0.7988286239230257,-0.3977688081309026,0.6101272780073337,-0.3340070654088696,0.909111664354187,0.78,0.36586020086053167,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.0989386267649508,0.909111664354187),(-0.3322630208172874,-1.5523129111030172,-0.0766000050337147,-0.8949798182945309,1.167321139201246,-0.5019130930116695,0.909111664354187,0.76,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-0.41952842352701486,-1.2223845559270303,-0.952028633990455,-1.8894018386217877,0.052933416813421515,-1.1735372034228724,0.909111664354187,0.56,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(1.5003104360869879,1.4170422854808635,0.7988286239230257,0.5966532121963541,-0.5042604443804907,-1.0056311758200724,0.909111664354187,0.78,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(0.6276564089897139,0.7571855751288902,0.7988286239230257,0.5966532121963541,-1.0614543055744028,-0.8377251482172725,0.909111664354187,0.72,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(0.4531256035702591,0.4272572199529034,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-1.0056311758200724,-1.0999748867047898,0.7,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(0.2785947981508043,-0.7274920231630502,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-1.5093492586284738,-1.0999748867047898,0.64,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-0.07046681268810527,-0.8924562007510436,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,-2.013067341436875,-1.0999748867047898,0.64,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-1.6412440614631982,-1.3873487335150236,-0.952028633990455,0.5966532121963541,-1.618648166768315,-1.6772552862312753,-1.0999748867047898,0.46,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-1.4667132560437435,-1.3873487335150236,-1.8274572629471952,-0.3977688081309026,-1.618648166768315,-3.0205035070536796,0.909111664354187,0.36,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-0.5067938262367422,-0.5625278455750569,-0.952028633990455,-1.3921908284581592,-1.618648166768315,-0.5019130930116695,-1.0999748867047898,0.42,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-0.681324631656197,-1.2223845559270303,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,-0.8377251482172725,-1.0999748867047898,0.48,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-0.8558554370756518,-1.057420378339037,-0.0766000050337147,0.5966532121963541,-0.5042604443804907,-0.6698191206144725,-1.0999748867047898,0.47,-0.15773221539783266,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-1.117651645204834,-0.39756366798706344,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,-0.6698191206144725,0.909111664354187,0.54,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(-0.15773221539783266,-0.06763531281107672,-0.952028633990455,0.5966532121963541,-0.5042604443804907,-0.1661010378060696,0.909111664354187,0.56,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(0.7149218116994412,0.5922213975408968,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.16971101739953035,-1.0999748867047898,0.52,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(0.7149218116994412,0.7571855751288902,0.7988286239230257,0.09944220203272576,0.052933416813421515,0.5391042781256927,-1.0999748867047898,0.55,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(0.889452617118896,1.087113930304877,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,0.7070103057284927,-1.0999748867047898,0.61,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(-0.07046681268810527,-0.06763531281107672,-0.952028633990455,0.09944220203272576,0.052933416813421515,0.06896740083785215,0.909111664354187,0.57,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(0.10406399273134952,0.26229304236491,-0.0766000050337147,0.09944220203272576,0.6101272780073337,1.0428223609340956,0.909111664354187,0.68,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(0.9767180198286235,1.2520781078928702,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9420787443724145,0.909111664354187,0.78,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(1.3257796306675331,1.7469706406568504,1.674257252879766,1.5910752325236108,1.724515000395158,1.7480276768658578,0.909111664354187,0.94,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(1.6748412415064426,0.7571855751288902,1.674257252879766,1.5910752325236108,1.724515000395158,1.9495149099892173,0.909111664354187,0.96,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(0.36586020086053167,0.5922213975408968,1.674257252879766,1.5910752325236108,1.724515000395158,1.4290062244205346,0.909111664354187,0.93,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(-0.24499761810756004,0.09732886477691666,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.7405915112490521,0.909111664354187,0.84,-1.117651645204834,-1.057420378339037,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898),(-0.24499761810756004,-0.2325994903990701,-0.0766000050337147,-0.3977688081309026,1.724515000395158,0.5055230726051333,-1.0999748867047898,0.74,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(1.0639834225383509,1.087113930304877,-0.952028633990455,-1.3921908284581592,0.6101272780073337,-0.06535742124438843,0.909111664354187,0.72,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(0.889452617118896,0.7571855751288902,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,0.20329222292009272,0.909111664354187,0.74,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(-1.3794478533340162,-1.3873487335150236,-0.952028633990455,-0.3977688081309026,-1.618648166768315,-0.6362379150939101,-1.0999748867047898,0.64,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(-1.8157748668826532,-2.0472054438669973,-0.952028633990455,-0.3977688081309026,-1.618648166768315,-1.777998902792955,0.909111664354187,0.44,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(-1.990305672302108,-2.377133799042984,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-2.0802297524779956,-1.0999748867047898,0.46,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(-0.41952842352701486,-0.39756366798706344,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,-0.972049970299513,0.909111664354187,0.5,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(2.023902852345352,2.076898995832837,0.7988286239230257,1.5910752325236108,1.724515000395158,1.5129592382219361,0.909111664354187,0.96,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(0.2785947981508043,0.4272572199529034,1.674257252879766,1.5910752325236108,1.167321139201246,1.0428223609340956,0.909111664354187,0.92,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(0.4531256035702591,1.2520781078928702,1.674257252879766,0.5966532121963541,1.167321139201246,1.2778907995780144,0.909111664354187,0.92,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(2.023902852345352,1.2520781078928702,1.674257252879766,1.0938642223599824,1.167321139201246,1.4290062244205346,0.909111664354187,0.94,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(0.1913293954410769,-0.7274920231630502,0.7988286239230257,1.0938642223599824,0.052933416813421515,0.10254860635841155,-1.0999748867047898,0.76,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(-0.15773221539783266,-0.2325994903990701,-0.0766000050337147,1.0938642223599824,0.052933416813421515,-0.30042585988831016,-1.0999748867047898,0.72,-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.9626955331560363,-1.0999748867047898),(0.016798590021622126,-0.06763531281107672,-0.952028633990455,0.09944220203272576,-0.5042604443804907,-0.535494298532232,-1.0999748867047898,0.66,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(-0.24499761810756004,0.09732886477691666,-0.0766000050337147,1.0938642223599824,0.052933416813421515,-0.7705627371761508,-1.0999748867047898,0.64,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(-0.07046681268810527,0.26229304236491,0.7988286239230257,1.0938642223599824,0.052933416813421515,0.27045463396121155,0.909111664354187,0.74,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(0.10406399273134952,-0.2325994903990701,-0.952028633990455,0.5966532121963541,0.6101272780073337,-1.139955997902313,0.909111664354187,0.64,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(-1.553978658753471,-1.7172770886910105,-0.0766000050337147,1.5910752325236108,0.052933416813421515,-1.5765116696695942,-1.0999748867047898,0.38,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(-1.6412440614631982,-1.5523129111030172,-0.952028633990455,0.5966532121963541,-0.5042604443804907,-0.9552593675392334,-1.0999748867047898,0.34,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(-1.3794478533340162,-1.7172770886910105,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,-1.2071184089434333,0.909111664354187,0.44,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(-1.2049170479145614,-1.3873487335150236,-0.0766000050337147,-1.3921908284581592,-1.0614543055744028,-1.5765116696695942,-1.0999748867047898,0.36,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(-1.117651645204834,-1.2223845559270303,0.7988286239230257,-1.8894018386217877,-1.0614543055744028,-1.2742808199845537,-1.0999748867047898,0.42,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(-0.9431208397853792,-1.2223845559270303,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,-1.0056311758200724,-1.0999748867047898,0.48,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(1.2385142279578056,2.076898995832837,-0.0766000050337147,0.5966532121963541,0.6101272780073337,0.6062666891668145,0.909111664354187,0.86,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(1.3257796306675331,1.9119348182448437,0.7988286239230257,1.5910752325236108,1.167321139201246,1.076403566454655,0.909111664354187,0.9,-2.3393672831410175,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.7444176972723957,-1.0999748867047898),(0.5403910062799865,0.9221497527168835,-0.0766000050337147,0.5966532121963541,0.6101272780073337,0.47194186708457386,0.909111664354187,0.79,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(0.4531256035702591,-0.06763531281107672,-0.0766000050337147,0.09944220203272576,0.052933416813421515,-0.2332634488471884,0.909111664354187,0.71,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-0.41952842352701486,-0.39756366798706344,-0.952028633990455,-0.8949798182945309,-0.5042604443804907,-0.8041439426967131,-1.0999748867047898,0.64,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-0.24499761810756004,-0.2325994903990701,-0.952028633990455,0.5966532121963541,0.052933416813421515,-0.585866106813071,-1.0999748867047898,0.62,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(0.016798590021622126,-0.5625278455750569,-0.952028633990455,1.0938642223599824,0.6101272780073337,-0.2164728460869087,-1.0999748867047898,0.57,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(0.8021872144091686,0.7571855751288902,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,0.7573821140093348,0.909111664354187,0.74,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-0.07046681268810527,0.4272572199529034,-0.0766000050337147,0.5966532121963541,1.167321139201246,0.30403583948177093,0.909111664354187,0.69,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,1.167321139201246,0.9756599498929738,0.909111664354187,0.87,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(1.8493720469258974,1.582006463068857,0.7988286239230257,0.09944220203272576,1.167321139201246,1.4457968271808173,0.909111664354187,0.91,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(1.2385142279578056,1.4170422854808635,1.674257252879766,1.5910752325236108,1.724515000395158,1.3114720050985766,0.909111664354187,0.93,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-1.117651645204834,-0.7274920231630502,1.674257252879766,1.5910752325236108,0.6101272780073337,0.06896740083785215,-1.0999748867047898,0.68,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(-1.0303862424951067,0.09732886477691666,1.674257252879766,-0.3977688081309026,-0.5042604443804907,-0.199682243326629,-1.0999748867047898,0.61,-1.2049170479145614,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.5933022724298738,-1.0999748867047898),(0.36586020086053167,0.26229304236491,0.7988286239230257,0.5966532121963541,0.6101272780073337,0.13612981187897094,0.909111664354187,0.69,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(-1.3794478533340162,-0.06763531281107672,-0.0766000050337147,0.09944220203272576,0.052933416813421515,-0.4347506819705508,0.909111664354187,0.62,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(0.2785947981508043,0.4272572199529034,-0.952028633990455,0.5966532121963541,0.052933416813421515,-0.06535742124438843,-1.0999748867047898,0.72,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(-0.5067938262367422,-0.39756366798706344,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,-0.2500540516074711,0.909111664354187,0.59,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(-0.5940592289464697,-0.2325994903990701,0.7988286239230257,1.0938642223599824,1.167321139201246,0.7405915112490521,0.909111664354187,0.66,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(-1.553978658753471,-0.8924562007510436,-0.0766000050337147,0.5966532121963541,0.052933416813421515,0.03538619531728977,-1.0999748867047898,0.56,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(-2.3393672831410175,-0.5625278455750569,0.7988286239230257,-1.3921908284581592,-1.0614543055744028,-1.9123237248751956,-1.0999748867047898,0.45,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(-1.8157748668826532,-1.3873487335150236,-0.952028633990455,-0.3977688081309026,0.052933416813421515,-2.214554574560236,-1.0999748867047898,0.47,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(0.889452617118896,-0.5625278455750569,1.674257252879766,-0.3977688081309026,0.052933416813421515,0.4047794560434521,0.909111664354187,0.71,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,1.6137028547836172,0.909111664354187,0.94,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(1.5003104360869879,1.9119348182448437,1.674257252879766,1.0938642223599824,1.167321139201246,1.4793780327013768,0.909111664354187,0.94,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(-0.5940592289464697,-0.2325994903990701,0.7988286239230257,-1.8894018386217877,-1.0614543055744028,-0.40116947644999135,-1.0999748867047898,0.57,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(-0.7685900343659244,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.052933416813421515,-0.6362379150939101,-1.0999748867047898,0.61,-0.5067938262367422,-1.3873487335150236,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-0.2836352571280305,0.909111664354187),(-1.3794478533340162,-0.2325994903990701,0.7988286239230257,-0.8949798182945309,-0.5042604443804907,-0.2164728460869087,-1.0999748867047898,0.57,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.10254860635841155,0.909111664354187,0.64,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(0.5403910062799865,0.9221497527168835,-0.0766000050337147,0.5966532121963541,-0.5042604443804907,1.2107283885368956,0.909111664354187,0.85,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(0.1913293954410769,0.7571855751288902,-0.0766000050337147,-0.8949798182945309,-1.618648166768315,0.18650162015981303,0.909111664354187,0.78,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(0.8021872144091686,0.7571855751288902,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,0.8413351278107333,0.909111664354187,0.84,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(1.4130450333772604,1.7469706406568504,1.674257252879766,1.5910752325236108,1.724515000395158,1.2611001968177347,0.909111664354187,0.92,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(1.9366374496356247,1.087113930304877,1.674257252879766,0.5966532121963541,1.167321139201246,1.9495149099892173,0.909111664354187,0.96,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(-1.2049170479145614,-0.39756366798706344,1.674257252879766,1.5910752325236108,1.167321139201246,0.08575800359813185,-1.0999748867047898,0.77,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(-0.681324631656197,-0.39756366798706344,1.674257252879766,0.09944220203272576,0.052933416813421515,-0.06535742124438843,-1.0999748867047898,0.71,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(0.5403910062799865,0.7571855751288902,1.674257252879766,0.5966532121963541,1.167321139201246,0.30403583948177093,-1.0999748867047898,0.79,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(1.4130450333772604,0.9221497527168835,1.674257252879766,0.5966532121963541,0.6101272780073337,1.1435659774957738,0.909111664354187,0.89,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(-0.24499761810756004,0.26229304236491,0.7988286239230257,0.09944220203272576,0.6101272780073337,0.2872452367214912,0.909111664354187,0.82,0.4531256035702591,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4047794560434521,0.909111664354187),(-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,1.5910752325236108,0.6101272780073337,-0.2500540516074711,-1.0999748867047898,0.76,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(-0.07046681268810527,-1.2223845559270303,-0.952028633990455,-1.8894018386217877,-0.5042604443804907,-0.7369815316555913,0.909111664354187,0.71,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(0.8021872144091686,1.4170422854808635,-0.952028633990455,1.0938642223599824,-0.5042604443804907,0.8077539222901738,0.909111664354187,0.8,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(0.10406399273134952,0.26229304236491,-1.8274572629471952,0.09944220203272576,0.052933416813421515,0.8749163333312926,-1.0999748867047898,0.78,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(1.0639834225383509,0.4272572199529034,-0.952028633990455,0.5966532121963541,-0.5042604443804907,0.9252881416121347,0.909111664354187,0.84,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(1.3257796306675331,1.7469706406568504,-0.952028633990455,1.0938642223599824,0.052933416813421515,1.2778907995780144,0.909111664354187,0.9,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(1.2385142279578056,1.2520781078928702,1.674257252879766,0.5966532121963541,0.052933416813421515,1.412215621660255,0.909111664354187,0.92,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(2.023902852345352,2.076898995832837,0.7988286239230257,1.0938642223599824,0.6101272780073337,2.2181645541536983,0.909111664354187,0.97,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(0.7149218116994412,0.7571855751288902,-0.952028633990455,-0.3977688081309026,0.052933416813421515,0.6062666891668145,0.909111664354187,0.8,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(0.2785947981508043,0.9221497527168835,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,0.06896740083785215,0.909111664354187,0.81,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(-0.15773221539783266,-0.39756366798706344,-0.0766000050337147,-1.3921908284581592,-1.0614543055744028,-0.199682243326629,-1.0999748867047898,0.75,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(0.8021872144091686,1.087113930304877,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,0.8581257305710129,0.909111664354187,0.83,0.1913293954410769,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.11933920911869125,0.909111664354187),(1.9366374496356247,1.4170422854808635,0.7988286239230257,0.5966532121963541,0.052933416813421515,2.016677321030339,0.909111664354187,0.96,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(-0.5067938262367422,-0.2325994903990701,-0.952028633990455,0.09944220203272576,-0.5042604443804907,-0.5690755040527913,0.909111664354187,0.79,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(1.5003104360869879,1.087113930304877,0.7988286239230257,0.5966532121963541,0.6101272780073337,1.3954250188999753,0.909111664354187,0.93,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(1.3257796306675331,1.4170422854808635,1.674257252879766,1.5910752325236108,1.724515000395158,1.1435659774957738,0.909111664354187,0.94,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(0.36586020086053167,0.7571855751288902,1.674257252879766,1.5910752325236108,1.724515000395158,0.7741727167696144,0.909111664354187,0.86,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(0.6276564089897139,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.6101272780073337,0.25366403120093184,-1.0999748867047898,0.79,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(0.8021872144091686,0.09732886477691666,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.4887324698448536,-1.0999748867047898,0.8,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(-0.41952842352701486,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,0.15292041463925066,-1.0999748867047898,0.77,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(-0.15773221539783266,-0.39756366798706344,-0.0766000050337147,-1.3921908284581592,-1.0614543055744028,-0.4347506819705508,-1.0999748867047898,0.7,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(-0.681324631656197,-0.5625278455750569,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.5690755040527913,-1.0999748867047898,0.65,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(-0.9431208397853792,-0.2325994903990701,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.7705627371761508,-1.0999748867047898,0.61,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(-1.7285094641729257,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.1735372034228724,-1.0999748867047898,0.52,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(-0.15773221539783266,-0.7274920231630502,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.2406996144639928,-1.0999748867047898,0.57,0.6276564089897139,0.4272572199529034,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9252881416121347,0.909111664354187),(-1.6412440614631982,-1.3873487335150236,-1.8274572629471952,-1.8894018386217877,-0.5042604443804907,-1.9123237248751956,-1.0999748867047898,0.53,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(0.10406399273134952,0.26229304236491,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.1661010378060696,-1.0999748867047898,0.67,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(0.016798590021622126,-0.39756366798706344,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,-0.06535742124438843,-1.0999748867047898,0.68,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.690219702968213,0.909111664354187,0.81,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(0.4531256035702591,0.4272572199529034,1.674257252879766,1.0938642223599824,0.6101272780073337,0.6230572919270941,-1.0999748867047898,0.78,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(-1.2921824506242887,-0.8924562007510436,-0.0766000050337147,0.09944220203272576,1.724515000395158,-0.45154128473083044,-1.0999748867047898,0.65,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(-0.3322630208172874,-0.8924562007510436,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,-0.5522849012925116,-1.0999748867047898,0.64,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(-2.0775710750118352,-1.7172770886910105,-0.952028633990455,-1.3921908284581592,0.6101272780073337,-1.3414432310256739,0.909111664354187,0.64,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(-0.5067938262367422,-1.3873487335150236,-0.952028633990455,-0.8949798182945309,-0.5042604443804907,-1.0392123813406318,-1.0999748867047898,0.65,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(-0.41952842352701486,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-0.9384687647789537,0.909111664354187,0.68,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(1.5003104360869879,1.582006463068857,1.674257252879766,0.5966532121963541,1.167321139201246,0.7909633195298942,0.909111664354187,0.89,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(0.4531256035702591,0.4272572199529034,0.7988286239230257,0.5966532121963541,1.724515000395158,0.8917069360915754,0.909111664354187,0.86,-1.4667132560437435,-1.2223845559270303,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5690755040527913,-1.0999748867047898),(0.5403910062799865,0.9221497527168835,0.7988286239230257,0.5966532121963541,1.167321139201246,1.0596129636943752,0.909111664354187,0.89,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(0.36586020086053167,0.5922213975408968,0.7988286239230257,0.5966532121963541,0.6101272780073337,0.6230572919270941,0.909111664354187,0.87,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(0.2785947981508043,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.052933416813421515,0.4551512643242912,0.909111664354187,0.85,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(1.0639834225383509,1.9119348182448437,0.7988286239230257,1.0938642223599824,1.167321139201246,0.9420787443724145,0.909111664354187,0.9,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(0.1913293954410769,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,-1.0999748867047898,0.82,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(-0.681324631656197,0.09732886477691666,-0.0766000050337147,-0.8949798182945309,-0.5042604443804907,-0.8041439426967131,-1.0999748867047898,0.72,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(-0.8558554370756518,-0.8924562007510436,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.5522849012925116,-1.0999748867047898,0.73,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(-1.4667132560437435,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,-0.7369815316555913,-1.0999748867047898,0.71,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(-1.0303862424951067,-0.06763531281107672,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.30042585988831016,-1.0999748867047898,0.71,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(-1.553978658753471,-1.2223845559270303,-0.952028633990455,-0.3977688081309026,0.052933416813421515,-1.2071184089434333,-1.0999748867047898,0.68,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(-0.24499761810756004,0.4272572199529034,-0.0766000050337147,0.5966532121963541,0.6101272780073337,0.3376170450023333,-1.0999748867047898,0.75,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(-0.07046681268810527,-0.2325994903990701,-0.952028633990455,-0.8949798182945309,0.6101272780073337,-0.46833188749111015,-1.0999748867047898,0.72,2.023902852345352,0.9221497527168835,0.7988286239230257,1.5910752325236108,1.724515000395158,1.915933704468658,0.909111664354187),(0.889452617118896,0.9221497527168835,0.7988286239230257,1.0938642223599824,1.167321139201246,0.8581257305710129,0.909111664354187,0.89,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(0.016798590021622126,-0.06763531281107672,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,0.13612981187897094,0.909111664354187,0.84,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(1.5875758387967152,1.7469706406568504,1.674257252879766,1.0938642223599824,0.052933416813421515,1.412215621660255,0.909111664354187,0.93,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(1.2385142279578056,1.2520781078928702,1.674257252879766,1.0938642223599824,0.052933416813421515,1.2778907995780144,0.909111664354187,0.93,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(0.6276564089897139,0.7571855751288902,1.674257252879766,1.5910752325236108,1.724515000395158,0.8077539222901738,0.909111664354187,0.88,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(0.6276564089897139,0.5922213975408968,1.674257252879766,1.0938642223599824,0.6101272780073337,0.9420787443724145,0.909111664354187,0.9,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(0.5403910062799865,0.4272572199529034,1.674257252879766,0.5966532121963541,1.724515000395158,0.6398478946873739,0.909111664354187,0.87,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(0.4531256035702591,1.087113930304877,1.674257252879766,1.0938642223599824,0.6101272780073337,0.572685483646252,0.909111664354187,0.86,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(1.6748412415064426,1.7469706406568504,1.674257252879766,1.0938642223599824,1.724515000395158,1.5633310465027752,0.909111664354187,0.94,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(-0.07046681268810527,0.26229304236491,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,0.27045463396121155,-1.0999748867047898,0.77,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(-0.8558554370756518,-0.06763531281107672,-0.952028633990455,-0.3977688081309026,0.052933416813421515,-0.1325198322855102,0.909111664354187,0.78,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(-0.9431208397853792,-0.39756366798706344,-0.952028633990455,-0.3977688081309026,-1.0614543055744028,-0.5690755040527913,-1.0999748867047898,0.73,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(-0.5940592289464697,-0.2325994903990701,-0.952028633990455,0.09944220203272576,-1.0614543055744028,-0.45154128473083044,-1.0999748867047898,0.73,1.5875758387967152,1.582006463068857,1.674257252879766,1.5910752325236108,1.724515000395158,2.0502585265508984,0.909111664354187),(-0.5067938262367422,-0.5625278455750569,-0.0766000050337147,1.0938642223599824,1.167321139201246,-0.2836352571280305,-1.0999748867047898,0.7,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(-0.3322630208172874,-0.06763531281107672,-0.0766000050337147,0.5966532121963541,1.167321139201246,0.15292041463925066,-1.0999748867047898,0.72,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(0.016798590021622126,-0.7274920231630502,-0.0766000050337147,-0.8949798182945309,-0.5042604443804907,-0.0989386267649508,0.909111664354187,0.73,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(-0.15773221539783266,0.4272572199529034,-0.952028633990455,0.09944220203272576,-0.5042604443804907,-0.2332634488471884,0.909111664354187,0.72,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(2.023902852345352,2.076898995832837,1.674257252879766,1.0938642223599824,1.167321139201246,2.2013739513934185,0.909111664354187,0.97,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(1.5003104360869879,2.076898995832837,1.674257252879766,0.5966532121963541,1.724515000395158,2.1342115403522968,0.909111664354187,0.97,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(-1.6412440614631982,-0.39756366798706344,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.0989386267649508,-1.0999748867047898,0.69,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(-1.9030402695923805,-1.3873487335150236,-0.952028633990455,-0.8949798182945309,-0.5042604443804907,-1.5933022724298738,-1.0999748867047898,0.57,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(-0.15773221539783266,-1.3873487335150236,-0.952028633990455,0.09944220203272576,-0.5042604443804907,-1.1903278061831537,-1.0999748867047898,0.63,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(-0.5940592289464697,-0.8924562007510436,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.972049970299513,0.909111664354187,0.66,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(-1.0303862424951067,-0.2325994903990701,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,-0.7369815316555913,-1.0999748867047898,0.64,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(-1.3794478533340162,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.8041439426967131,0.909111664354187,0.68,-1.2921824506242887,-1.057420378339037,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-1.0727935868611929,-1.0999748867047898),(0.7149218116994412,0.09732886477691666,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.7741727167696144,0.909111664354187,0.79,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(0.9767180198286235,0.4272572199529034,0.7988286239230257,1.5910752325236108,0.6101272780073337,0.908497538851855,0.909111664354187,0.82,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(1.8493720469258974,2.076898995832837,0.7988286239230257,1.5910752325236108,1.724515000395158,1.7816088823864173,0.909111664354187,0.95,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(1.4130450333772604,1.9119348182448437,1.674257252879766,1.5910752325236108,1.167321139201246,1.9830961155097766,0.909111664354187,0.96,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(1.2385142279578056,1.582006463068857,0.7988286239230257,1.0938642223599824,1.724515000395158,1.3786344161396955,0.909111664354187,0.94,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(1.1512488252480781,1.4170422854808635,1.674257252879766,1.5910752325236108,1.167321139201246,1.2778907995780144,0.909111664354187,0.93,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(0.4531256035702591,0.7571855751288902,0.7988286239230257,1.0938642223599824,1.167321139201246,1.1099847719752143,0.909111664354187,0.91,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(0.36586020086053167,0.26229304236491,0.7988286239230257,0.5966532121963541,0.6101272780073337,0.8917069360915754,0.909111664354187,0.85,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(0.6276564089897139,0.4272572199529034,0.7988286239230257,-0.3977688081309026,0.052933416813421515,0.6230572919270941,0.909111664354187,0.84,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(-0.41952842352701486,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.052933416813421515,-0.30042585988831016,-1.0999748867047898,0.74,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(-0.3322630208172874,-0.7274920231630502,-0.0766000050337147,0.5966532121963541,0.6101272780073337,0.25366403120093184,-1.0999748867047898,0.76,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(-0.07046681268810527,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.06535742124438843,-1.0999748867047898,0.75,-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8377251482172725,-1.0999748867047898),(0.6276564089897139,0.9221497527168835,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.32082644224205065,-1.0999748867047898,0.76,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(-0.7685900343659244,0.26229304236491,-0.952028633990455,-0.3977688081309026,0.6101272780073337,-0.2500540516074711,-1.0999748867047898,0.71,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(-1.0303862424951067,-0.39756366798706344,-0.952028633990455,-0.3977688081309026,-1.618648166768315,-0.6194473123336305,-1.0999748867047898,0.67,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(-1.8157748668826532,-1.3873487335150236,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-0.9552593675392334,-1.0999748867047898,0.61,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(-0.9431208397853792,0.4272572199529034,-0.952028633990455,0.09944220203272576,0.6101272780073337,-0.2500540516074711,-1.0999748867047898,0.63,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(-0.41952842352701486,0.4272572199529034,-0.952028633990455,0.09944220203272576,-0.5042604443804907,-0.1157292295252305,-1.0999748867047898,0.64,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(0.10406399273134952,0.7571855751288902,-0.0766000050337147,0.5966532121963541,0.052933416813421515,0.11933920911869125,-1.0999748867047898,0.71,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(0.6276564089897139,0.5922213975408968,0.7988286239230257,-0.3977688081309026,-0.5042604443804907,0.690219702968213,0.909111664354187,0.82,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(-0.3322630208172874,-0.5625278455750569,-0.0766000050337147,0.5966532121963541,1.167321139201246,0.08575800359813185,-1.0999748867047898,0.73,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(0.1913293954410769,-0.2325994903990701,-0.0766000050337147,0.09944220203272576,-1.0614543055744028,-0.45154128473083044,0.909111664354187,0.74,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(-0.41952842352701486,-0.06763531281107672,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-0.5522849012925116,-1.0999748867047898,0.69,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(-1.117651645204834,-1.2223845559270303,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-0.8880969564981116,-1.0999748867047898,0.64,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(1.1512488252480781,0.9221497527168835,1.674257252879766,1.5910752325236108,0.6101272780073337,1.1939377857766158,0.909111664354187,0.91,-1.8157748668826532,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.3414432310256739,-1.0999748867047898),(0.8021872144091686,0.5922213975408968,1.674257252879766,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187,0.88,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(0.7149218116994412,0.7571855751288902,0.7988286239230257,0.5966532121963541,1.167321139201246,0.9588693471326941,0.909111664354187,0.85,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(1.0639834225383509,1.087113930304877,1.674257252879766,1.0938642223599824,1.724515000395158,0.9924505526532535,0.909111664354187,0.86,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(-0.5940592289464697,-0.5625278455750569,-0.0766000050337147,-1.3921908284581592,0.052933416813421515,-0.3843788736897117,-1.0999748867047898,0.7,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(-1.553978658753471,-1.2223845559270303,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.1903278061831537,-1.0999748867047898,0.59,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(-1.8157748668826532,-1.057420378339037,-1.8274572629471952,-0.8949798182945309,-0.5042604443804907,-1.5429304641490347,-1.0999748867047898,0.6,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(0.016798590021622126,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-0.753772134415871,-1.0999748867047898,0.65,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(0.6276564089897139,1.2520781078928702,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,0.27045463396121155,0.909111664354187,0.7,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(0.7149218116994412,1.087113930304877,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,0.7405915112490521,0.909111664354187,0.76,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(-0.24499761810756004,-0.06763531281107672,-0.952028633990455,-0.8949798182945309,0.6101272780073337,-0.06535742124438843,-1.0999748867047898,0.63,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(0.9767180198286235,0.4272572199529034,0.7988286239230257,0.5966532121963541,-1.0614543055744028,0.7070103057284927,0.909111664354187,0.81,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(-0.07046681268810527,-0.39756366798706344,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.22008282568037243,-1.0999748867047898,0.72,0.2785947981508043,0.09732886477691666,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.2668446543677508,0.909111664354187),(-0.5067938262367422,-0.5625278455750569,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-0.199682243326629,-1.0999748867047898,0.71,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.4551512643242912,0.909111664354187,0.8,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.36586020086053167,0.5922213975408968,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.3879888532831724,0.909111664354187,0.77,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.2785947981508043,-0.5625278455750569,-0.0766000050337147,-0.3977688081309026,-1.0614543055744028,-0.04856681848410872,0.909111664354187,0.74,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(-0.07046681268810527,-1.3873487335150236,-0.952028633990455,-0.8949798182945309,-0.5042604443804907,0.6734291002079332,-1.0999748867047898,0.7,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.10406399273134952,-1.2223845559270303,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-0.0989386267649508,0.909111664354187,0.71,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(1.5875758387967152,1.2520781078928702,0.7988286239230257,1.0938642223599824,1.167321139201246,1.8151900879069767,0.909111664354187,0.93,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.36586020086053167,1.087113930304877,0.7988286239230257,0.5966532121963541,1.724515000395158,0.8749163333312926,-1.0999748867047898,0.85,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(-0.8558554370756518,0.4272572199529034,0.7988286239230257,0.5966532121963541,1.167321139201246,-0.3843788736897117,-1.0999748867047898,0.79,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(-0.681324631656197,-1.3873487335150236,-0.0766000050337147,0.5966532121963541,0.6101272780073337,-0.06535742124438843,-1.0999748867047898,0.76,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.6276564089897139,-1.2223845559270303,-0.0766000050337147,0.5966532121963541,1.724515000395158,0.06896740083785215,0.909111664354187,0.78,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(0.8021872144091686,-0.8924562007510436,0.7988286239230257,1.5910752325236108,1.724515000395158,0.27045463396121155,0.909111664354187,0.77,-0.24499761810756004,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.6026567095733507,-1.0999748867047898),(1.2385142279578056,1.9119348182448437,0.7988286239230257,1.5910752325236108,1.167321139201246,1.244309594057455,0.909111664354187,0.9,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(0.889452617118896,0.09732886477691666,1.674257252879766,1.5910752325236108,0.052933416813421515,0.8917069360915754,0.909111664354187,0.87,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(-0.41952842352701486,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,0.6101272780073337,-0.8545157509775522,-1.0999748867047898,0.71,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(-0.7685900343659244,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,0.6101272780073337,-0.40116947644999135,0.909111664354187,0.7,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(0.6276564089897139,0.5922213975408968,-0.0766000050337147,-0.8949798182945309,-2.175842027962227,0.32082644224205065,0.909111664354187,0.7,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(0.7149218116994412,0.4272572199529034,-0.952028633990455,-0.3977688081309026,-1.0614543055744028,0.27045463396121155,0.909111664354187,0.75,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(-0.3322630208172874,-0.8924562007510436,-0.0766000050337147,-0.8949798182945309,-1.0614543055744028,0.13612981187897094,-1.0999748867047898,0.71,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(-0.41952842352701486,-0.39756366798706344,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.2500540516074711,-1.0999748867047898,0.72,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(-0.24499761810756004,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.7201909288953117,0.909111664354187,0.73,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(0.889452617118896,0.9221497527168835,0.7988286239230257,1.0938642223599824,1.724515000395158,0.908497538851855,-1.0999748867047898,0.83,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(-0.7685900343659244,0.09732886477691666,0.7988286239230257,1.0938642223599824,1.724515000395158,-0.4347506819705508,-1.0999748867047898,0.77,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(-0.9431208397853792,-0.39756366798706344,-0.952028633990455,-0.8949798182945309,-0.5042604443804907,-0.6362379150939101,0.909111664354187,0.72,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(-1.553978658753471,-1.8822412662790038,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.2406996144639928,-1.0999748867047898,0.54,0.10406399273134952,-0.2325994903990701,-0.0766000050337147,-1.3921908284581592,-0.5042604443804907,0.08575800359813185,-1.0999748867047898),(-1.990305672302108,-2.0472054438669973,-1.8274572629471952,-1.8894018386217877,-2.175842027962227,-1.610092875190155,-1.0999748867047898,0.49,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(-0.41952842352701486,-1.3873487335150236,-1.8274572629471952,-2.386612848785416,-2.175842027962227,-0.9888405730597928,0.909111664354187,0.52,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(-0.15773221539783266,-1.2223845559270303,-1.8274572629471952,-1.3921908284581592,-1.0614543055744028,-1.0895841896214724,-1.0999748867047898,0.58,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(0.4531256035702591,0.4272572199529034,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,0.6062666891668145,0.909111664354187,0.78,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(1.0639834225383509,0.9221497527168835,1.674257252879766,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187,0.89,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(0.2785947981508043,-1.057420378339037,-0.952028633990455,-0.8949798182945309,-0.5042604443804907,0.03538619531728977,-1.0999748867047898,0.7,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(-0.7685900343659244,-0.7274920231630502,-0.952028633990455,-0.3977688081309026,0.052933416813421515,-0.1828916405663493,-1.0999748867047898,0.66,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(-1.117651645204834,-0.8924562007510436,-0.952028633990455,-0.3977688081309026,0.6101272780073337,0.22008282568037243,-1.0999748867047898,0.67,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(-0.5067938262367422,-0.8924562007510436,-0.0766000050337147,1.0938642223599824,0.6101272780073337,0.06896740083785215,0.909111664354187,0.68,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(0.016798590021622126,0.4272572199529034,-0.0766000050337147,0.5966532121963541,1.167321139201246,0.8581257305710129,0.909111664354187,0.8,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(-0.41952842352701486,-0.2325994903990701,-0.0766000050337147,0.5966532121963541,0.052933416813421515,0.32082644224205065,0.909111664354187,0.81,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(0.36586020086053167,0.5922213975408968,-0.0766000050337147,-0.8949798182945309,-0.5042604443804907,0.5055230726051333,0.909111664354187,0.8,0.8021872144091686,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.8749163333312926,0.909111664354187),(2.023902852345352,0.7571855751288902,0.7988286239230257,1.5910752325236108,1.167321139201246,1.7816088823864173,0.909111664354187,0.94,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(1.2385142279578056,1.4170422854808635,1.674257252879766,0.5966532121963541,0.6101272780073337,1.1099847719752143,0.909111664354187,0.93,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(1.6748412415064426,1.7469706406568504,1.674257252879766,1.0938642223599824,0.6101272780073337,0.9924505526532535,0.909111664354187,0.92,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(0.6276564089897139,1.087113930304877,1.674257252879766,1.5910752325236108,1.167321139201246,0.8077539222901738,0.909111664354187,0.89,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(-0.24499761810756004,-0.5625278455750569,0.7988286239230257,1.5910752325236108,1.724515000395158,0.7070103057284927,-1.0999748867047898,0.82,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(-0.3322630208172874,0.26229304236491,-0.0766000050337147,0.5966532121963541,0.052933416813421515,0.6734291002079332,-1.0999748867047898,0.79,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(-0.8558554370756518,-0.39756366798706344,-0.952028633990455,-0.8949798182945309,-0.5042604443804907,-1.5933022724298738,-1.0999748867047898,0.58,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(-1.4667132560437435,-0.8924562007510436,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.223909011703713,-1.0999748867047898,0.56,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(-1.2921824506242887,-1.3873487335150236,-0.952028633990455,-2.386612848785416,-1.618648166768315,-1.056002984100913,-1.0999748867047898,0.56,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(-0.41952842352701486,-1.5523129111030172,-1.8274572629471952,0.09944220203272576,-0.5042604443804907,-0.7034003261350319,0.909111664354187,0.64,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(-0.07046681268810527,-1.057420378339037,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-0.46833188749111015,0.909111664354187,0.61,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(0.016798590021622126,-1.2223845559270303,-0.952028633990455,-0.3977688081309026,-1.0614543055744028,-0.04856681848410872,-1.0999748867047898,0.68,0.016798590021622126,-0.5625278455750569,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,0.27045463396121155,-1.0999748867047898),(-0.5940592289464697,-0.06763531281107672,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.11933920911869125,-1.0999748867047898,0.76,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(0.2785947981508043,2.076898995832837,-0.0766000050337147,0.5966532121963541,1.167321139201246,0.8581257305710129,-1.0999748867047898,0.86,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(1.1512488252480781,1.087113930304877,-0.0766000050337147,1.0938642223599824,1.167321139201246,1.076403566454655,0.909111664354187,0.9,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(-1.0303862424951067,0.7571855751288902,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.08575800359813185,-1.0999748867047898,0.71,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(-0.681324631656197,-0.2325994903990701,-0.952028633990455,-0.8949798182945309,-1.0614543055744028,-1.0056311758200724,-1.0999748867047898,0.62,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(0.1913293954410769,0.09732886477691666,-0.952028633990455,-0.8949798182945309,-0.5042604443804907,0.27045463396121155,-1.0999748867047898,0.66,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(0.4531256035702591,-0.39756366798706344,-0.952028633990455,-0.3977688081309026,-0.5042604443804907,-0.2500540516074711,0.909111664354187,0.65,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(0.5403910062799865,-0.06763531281107672,-0.0766000050337147,0.09944220203272576,0.052933416813421515,-0.08214802400466813,0.909111664354187,0.73,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(-0.3322630208172874,-0.2325994903990701,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-0.2836352571280305,-1.0999748867047898,0.62,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(0.36586020086053167,0.26229304236491,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.3376170450023333,0.909111664354187,0.74,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(0.5403910062799865,0.4272572199529034,-0.0766000050337147,0.5966532121963541,0.052933416813421515,0.8413351278107333,0.909111664354187,0.79,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(0.7149218116994412,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.6101272780073337,0.6734291002079332,0.909111664354187,0.8,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(-0.41952842352701486,0.09732886477691666,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,-0.1157292295252305,-1.0999748867047898,0.69,1.0639834225383509,0.5922213975408968,0.7988286239230257,1.0938642223599824,0.6101272780073337,1.0596129636943752,0.909111664354187),(-0.7685900343659244,0.4272572199529034,0.7988286239230257,0.09944220203272576,-0.5042604443804907,0.0018049897967303734,-1.0999748867047898,0.7,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(0.2785947981508043,-0.5625278455750569,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.23687342844065212,0.909111664354187,0.76,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(0.9767180198286235,0.09732886477691666,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.9756599498929738,0.909111664354187,0.84,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(-0.5067938262367422,-0.06763531281107672,0.7988286239230257,1.0938642223599824,1.167321139201246,0.6734291002079332,0.909111664354187,0.78,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(-1.3794478533340162,-1.2223845559270303,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,-0.9384687647789537,-1.0999748867047898,0.67,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(-1.0303862424951067,-0.39756366798706344,-0.952028633990455,-0.3977688081309026,0.6101272780073337,-0.7873533399364304,-1.0999748867047898,0.66,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(-0.7685900343659244,-0.5625278455750569,-0.952028633990455,-0.8949798182945309,-0.5042604443804907,-0.8880969564981116,-1.0999748867047898,0.65,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(-1.6412440614631982,-1.057420378339037,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.2406996144639928,-1.0999748867047898,0.54,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(-1.4667132560437435,-1.3873487335150236,-1.8274572629471952,-2.386612848785416,-1.0614543055744028,-0.9888405730597928,-1.0999748867047898,0.58,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(0.6276564089897139,0.5922213975408968,-0.0766000050337147,-0.8949798182945309,-1.618648166768315,0.3376170450023333,0.909111664354187,0.79,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(0.889452617118896,0.9221497527168835,0.7988286239230257,0.09944220203272576,-0.5042604443804907,0.15292041463925066,0.909111664354187,0.8,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(0.016798590021622126,-0.2325994903990701,-0.0766000050337147,0.5966532121963541,0.052933416813421515,-0.1661010378060696,0.909111664354187,0.75,0.6276564089897139,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.7405915112490521,0.909111664354187),(0.5403910062799865,-0.5625278455750569,-0.0766000050337147,0.5966532121963541,0.6101272780073337,-0.2668446543677508,0.909111664354187,0.73,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(-0.24499761810756004,-0.06763531281107672,-0.952028633990455,-0.8949798182945309,0.6101272780073337,-0.5522849012925116,-1.0999748867047898,0.72,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(-1.0303862424951067,-0.8924562007510436,-0.952028633990455,-1.3921908284581592,-1.0614543055744028,-0.7034003261350319,-1.0999748867047898,0.62,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(-0.15773221539783266,-0.5625278455750569,-0.0766000050337147,-0.3977688081309026,-1.0614543055744028,-0.45154128473083044,-1.0999748867047898,0.67,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(0.8021872144091686,1.4170422854808635,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.908497538851855,0.909111664354187,0.81,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(-1.553978658753471,-1.2223845559270303,-0.0766000050337147,-1.3921908284581592,-1.618648166768315,-0.972049970299513,-1.0999748867047898,0.63,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(-1.9030402695923805,-1.057420378339037,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.2406996144639928,-1.0999748867047898,0.69,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(0.6276564089897139,0.7571855751288902,0.7988286239230257,0.5966532121963541,0.052933416813421515,0.2872452367214912,0.909111664354187,0.8,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(-1.7285094641729257,-1.8822412662790038,-0.952028633990455,-0.8949798182945309,-2.175842027962227,-1.1903278061831537,-1.0999748867047898,0.43,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(0.889452617118896,0.9221497527168835,-0.0766000050337147,0.09944220203272576,-0.5042604443804907,0.10254860635841155,0.909111664354187,0.8,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(-0.5067938262367422,-0.39756366798706344,-0.952028633990455,-0.3977688081309026,-1.618648166768315,-0.8041439426967131,0.909111664354187,0.73,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(-0.7685900343659244,-0.2325994903990701,-0.0766000050337147,0.09944220203272576,-1.0614543055744028,-0.6530285178541898,0.909111664354187,0.75,0.7149218116994412,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,0.8581257305710129,0.909111664354187),(0.1913293954410769,0.09732886477691666,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.0989386267649508,0.909111664354187,0.71,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(-0.41952842352701486,-0.06763531281107672,0.7988286239230257,1.0938642223599824,0.6101272780073337,0.08575800359813185,0.909111664354187,0.73,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(0.7149218116994412,0.5922213975408968,0.7988286239230257,0.5966532121963541,1.167321139201246,0.8581257305710129,0.909111664354187,0.83,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(0.1913293954410769,0.4272572199529034,-0.0766000050337147,-0.3977688081309026,-1.0614543055744028,0.32082644224205065,-1.0999748867047898,0.72,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(1.3257796306675331,1.7469706406568504,1.674257252879766,1.5910752325236108,1.724515000395158,1.462587429941097,0.909111664354187,0.94,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(0.5403910062799865,0.09732886477691666,1.674257252879766,0.5966532121963541,0.6101272780073337,0.23687342844065212,0.909111664354187,0.81,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(0.6276564089897139,-0.06763531281107672,1.674257252879766,0.09944220203272576,0.6101272780073337,0.10254860635841155,0.909111664354187,0.81,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(-0.41952842352701486,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.2332634488471884,0.909111664354187,0.75,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(0.8021872144091686,0.4272572199529034,-0.0766000050337147,0.09944220203272576,0.052933416813421515,0.27045463396121155,0.909111664354187,0.79,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(-0.7685900343659244,-0.2325994903990701,-0.0766000050337147,-0.3977688081309026,-0.5042604443804907,-0.6026567095733507,-1.0999748867047898,0.58,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(-1.0303862424951067,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,0.052933416813421515,-0.7873533399364304,-1.0999748867047898,0.59,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(-1.9030402695923805,-1.8822412662790038,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-2.1138109579985565,-1.0999748867047898,0.47,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(-0.07046681268810527,-1.5523129111030172,-1.8274572629471952,-1.8894018386217877,-1.618648166768315,-1.9626955331560363,-1.0999748867047898,0.49,1.1512488252480781,1.4170422854808635,0.7988286239230257,1.5910752325236108,1.167321139201246,1.4290062244205346,0.909111664354187),(-1.117651645204834,-1.7172770886910105,-0.952028633990455,-1.8894018386217877,-1.618648166768315,-1.610092875190155,-1.0999748867047898,0.47,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(-1.553978658753471,-2.2121696214549904,-1.8274572629471952,-2.386612848785416,-2.7330358891561395,-2.1138109579985565,-1.0999748867047898,0.42,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(-1.2921824506242887,-1.3873487335150236,-1.8274572629471952,-1.3921908284581592,-1.618648166768315,-2.2649263828410766,-1.0999748867047898,0.57,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(-0.3322630208172874,-1.057420378339037,-0.0766000050337147,-0.8949798182945309,-0.5042604443804907,-0.9384687647789537,-1.0999748867047898,0.62,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(0.10406399273134952,-0.06763531281107672,-0.0766000050337147,-0.3977688081309026,0.052933416813421515,-0.5522849012925116,0.909111664354187,0.74,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(0.7149218116994412,0.4272572199529034,0.7988286239230257,0.09944220203272576,0.6101272780073337,0.11933920911869125,0.909111664354187,0.73,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(-1.2049170479145614,-1.2223845559270303,-0.952028633990455,-0.3977688081309026,0.052933416813421515,-0.9048875592583913,0.909111664354187,0.64,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(-1.4667132560437435,-0.8924562007510436,-0.0766000050337147,0.09944220203272576,-1.0614543055744028,-0.7201909288953117,-1.0999748867047898,0.63,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(-1.7285094641729257,-1.5523129111030172,-0.952028633990455,-0.8949798182945309,-0.5042604443804907,-1.5597210669093144,-1.0999748867047898,0.59,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(0.016798590021622126,-0.2325994903990701,-0.952028633990455,-1.3921908284581592,0.052933416813421515,-0.8041439426967131,-1.0999748867047898,0.73,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(0.889452617118896,0.26229304236491,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.2872452367214912,0.909111664354187,0.79,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(-1.3794478533340162,-0.5625278455750569,-0.952028633990455,0.09944220203272576,0.052933416813421515,-1.1903278061831537,0.909111664354187,0.68,-0.41952842352701486,-0.7274920231630502,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.30403583948177093,-1.0999748867047898),(-0.24499761810756004,-0.39756366798706344,-0.952028633990455,-0.8949798182945309,-1.618648166768315,-1.610092875190155,-1.0999748867047898,0.7,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187),(0.36586020086053167,-0.06763531281107672,-0.952028633990455,-1.3921908284581592,-2.175842027962227,-0.2668446543677508,-1.0999748867047898,0.81,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187),(0.4531256035702591,0.4272572199529034,-0.0766000050337147,0.5966532121963541,1.724515000395158,0.06896740083785215,0.909111664354187,0.85,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187),(1.5003104360869879,1.4170422854808635,0.7988286239230257,0.5966532121963541,0.052933416813421515,1.580121649263055,0.909111664354187,0.93,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187),(1.8493720469258974,1.2520781078928702,1.674257252879766,1.0938642223599824,1.724515000395158,1.0596129636943752,0.909111664354187,0.91,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187),(-0.9431208397853792,-0.7274920231630502,-0.952028633990455,-0.8949798182945309,-0.5042604443804907,-0.40116947644999135,-1.0999748867047898,0.69,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187),(-0.3322630208172874,-0.8924562007510436,-0.0766000050337147,0.09944220203272576,0.6101272780073337,0.5055230726051333,0.909111664354187,0.77,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187),(1.1512488252480781,1.087113930304877,0.7988286239230257,1.0938642223599824,-0.5042604443804907,0.9588693471326941,0.909111664354187,0.86,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187),(0.2785947981508043,-0.5625278455750569,-0.0766000050337147,0.09944220203272576,1.167321139201246,-0.4347506819705508,0.909111664354187,0.74,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187),(-0.5067938262367422,-1.5523129111030172,-1.8274572629471952,-2.386612848785416,-1.0614543055744028,-1.9123237248751956,-1.0999748867047898,0.57,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187),(-1.6412440614631982,-2.5420979766309775,-1.8274572629471952,-1.3921908284581592,-1.618648166768315,-1.2071184089434333,-1.0999748867047898,0.51,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187),(-1.3794478533340162,-1.5523129111030172,-1.8274572629471952,-1.3921908284581592,-0.5042604443804907,-0.9552593675392334,0.909111664354187,0.67,1.4130450333772604,1.582006463068857,0.7988286239230257,1.5910752325236108,0.6101272780073337,1.7816088823864173,0.909111664354187) DROP TABLE IF EXISTS test.model; -create table test.model engine = Memory as select LinearRegressionState(0.1, 0.0, 5, 1.0)(target, param1, param2, param3, param4, param5, param6, param7) as state from test.defaults; +create table test.model engine = Memory as select LinearRegressionState(0.1, 0.0, 5, 'SGD')(target, param1, param2, param3, param4, param5, param6, param7) as state from test.defaults; with (select state from test.model) as model select evalMLMethod(model, predict1, predict2, predict3, predict4, predict5, predict6, predict7) from test.defaults; diff --git a/dbms/tests/queries/0_stateless/00938_dataset_test.sql b/dbms/tests/queries/0_stateless/00938_dataset_test.sql index 2ade0fc412c..bb71b49379c 100644 --- a/dbms/tests/queries/0_stateless/00938_dataset_test.sql +++ b/dbms/tests/queries/0_stateless/00938_dataset_test.sql @@ -11,7 +11,7 @@ CREATE TABLE IF NOT EXISTS test.defaults insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0), (-1.099, 2.755, -3.060, 20.0, 40.0), (1.090, 2.945, -2.346, 20.0, 40.0), (0.305, 2.179, -1.205, 20.0, 40.0), (-0.925, 0.702, 1.134, 20.0, 40.0), (3.178, -1.316, 7.221, 20.0, 40.0), (-2.756, -0.473, 2.569, 20.0, 40.0), (3.665, 2.303, 0.226, 20.0, 40.0), (1.662, 1.951, -0.070, 20.0, 40.0), (2.869, 0.593, 3.249, 20.0, 40.0), (0.818, -0.593, 4.594, 20.0, 40.0), (-1.917, 0.916, 0.209, 20.0, 40.0), (2.706, 1.523, 1.307, 20.0, 40.0), (0.219, 2.162, -1.214, 20.0, 40.0), (-4.510, 1.376, -2.007, 20.0, 40.0), (4.284, -0.515, 6.173, 20.0, 40.0), (-1.101, 2.810, -3.170, 20.0, 40.0), (-1.810, -1.117, 4.329, 20.0, 40.0), (0.055, 1.115, 0.797, 20.0, 40.0), (-2.178, 2.904, -3.898, 20.0, 40.0), (-3.494, -1.814, 4.882, 20.0, 40.0), (3.027, 0.476, 3.562, 20.0, 40.0), (-1.434, 1.151, -0.018, 20.0, 40.0), (1.180, 0.992, 1.606, 20.0, 40.0), (0.015, 0.971, 1.067, 20.0, 40.0), (-0.511, -0.875, 4.495, 20.0, 40.0), (0.961, 2.348, -1.216, 20.0, 40.0), (-2.279, 0.038, 1.785, 20.0, 40.0), (-1.568, -0.248, 2.712, 20.0, 40.0), (-0.496, 0.366, 2.020, 20.0, 40.0), (1.177, -1.401, 6.390, 20.0, 40.0), (2.882, -1.442, 7.325, 20.0, 40.0), (-1.066, 1.817, -1.167, 20.0, 40.0), (-2.144, 2.791, -3.655, 20.0, 40.0), (-4.370, 2.228, -3.642, 20.0, 40.0), (3.996, 2.775, -0.553, 20.0, 40.0), (0.289, 2.055, -0.965, 20.0, 40.0), (-0.588, -1.601, 5.908, 20.0, 40.0), (-1.801, 0.417, 1.265, 20.0, 40.0), (4.375, -1.499, 8.186, 20.0, 40.0), (-2.618, 0.038, 1.615, 20.0, 40.0), (3.616, -0.833, 6.475, 20.0, 40.0), (-4.045, -1.558, 4.094, 20.0, 40.0), (-3.962, 0.636, -0.253, 20.0, 40.0), (3.505, 2.625, -0.497, 20.0, 40.0), (3.029, -0.523, 5.560, 20.0, 40.0), (-3.520, -0.474, 2.188, 20.0, 40.0), (2.430, -1.469, 7.154, 20.0, 40.0), (1.547, -1.654, 7.082, 20.0, 40.0), (-1.370, 0.575, 1.165, 20.0, 40.0), (-1.869, -1.555, 5.176, 20.0, 40.0), (3.536, 2.841, -0.913, 20.0, 40.0), (-3.810, 1.220, -1.344, 20.0, 40.0), (-1.971, 1.462, -0.910, 20.0, 40.0), (-0.243, 0.167, 2.545, 20.0, 40.0), (-1.403, 2.645, -2.991, 20.0, 40.0), (0.532, -0.114, 3.494, 20.0, 40.0), (-1.678, 0.975, 0.212, 20.0, 40.0), (-0.656, 2.140, -1.609, 20.0, 40.0), (1.743, 2.631, -1.390, 20.0, 40.0), (2.586, 2.943, -1.593, 20.0, 40.0), (-0.512, 2.969, -3.195, 20.0, 40.0), (2.283, -0.100, 4.342, 20.0, 40.0), (-4.293, 0.872, -0.890, 20.0, 40.0), (3.411, 1.300, 2.106, 20.0, 40.0), (-0.281, 2.951, -3.042, 20.0, 40.0), (-4.442, 0.384, 0.012, 20.0, 40.0), (1.194, 1.746, 0.104, 20.0, 40.0), (-1.152, 1.862, -1.300, 20.0, 40.0), (1.362, -1.341, 6.363, 20.0, 40.0), (-4.488, 2.618, -4.481, 20.0, 40.0), (3.419, -0.564, 5.837, 20.0, 40.0), (-3.392, 0.396, 0.512, 20.0, 40.0), (-1.629, -0.909, 4.003, 20.0, 40.0), (4.447, -1.088, 7.399, 20.0, 40.0), (-1.232, 1.699, -1.014, 20.0, 40.0), (-1.286, -0.609, 3.575, 20.0, 40.0), (2.437, 2.796, -1.374, 20.0, 40.0), (-4.864, 1.989, -3.410, 20.0, 40.0), (-1.716, -1.399, 4.940, 20.0, 40.0), (-3.084, 1.858, -2.259, 20.0, 40.0), (2.828, -0.319, 5.053, 20.0, 40.0), (-1.226, 2.586, -2.786, 20.0, 40.0), (2.456, 0.092, 4.044, 20.0, 40.0), (-0.989, 2.375, -2.245, 20.0, 40.0), (3.268, 0.935, 2.765, 20.0, 40.0), (-4.128, -1.995, 4.927, 20.0, 40.0), (-1.083, 2.197, -1.935, 20.0, 40.0), (-3.471, -1.198, 3.660, 20.0, 40.0), (4.617, -1.136, 7.579, 20.0, 40.0), (2.054, -1.675, 7.378, 20.0, 40.0), (4.106, 2.326, 0.402, 20.0, 40.0), (1.558, 0.310, 3.158, 20.0, 40.0), (0.792, 0.900, 1.596, 20.0, 40.0), (-3.229, 0.300, 0.785, 20.0, 40.0), (3.787, -0.793, 6.479, 20.0, 40.0), (1.786, 2.288, -0.684, 20.0, 40.0), (2.643, 0.223, 3.875, 20.0, 40.0), (-3.592, 2.122, -3.040, 20.0, 40.0), (4.519, -1.760, 8.779, 20.0, 40.0), (3.221, 2.255, 0.101, 20.0, 40.0), (4.151, 1.788, 1.500, 20.0, 40.0), (-1.033, -1.195, 4.874, 20.0, 40.0), (-1.636, -1.037, 4.257, 20.0, 40.0), (-3.548, 1.911, -2.596, 20.0, 40.0), (4.829, -0.293, 6.001, 20.0, 40.0), (-4.684, -1.664, 3.986, 20.0, 40.0), (4.531, -0.503, 6.271, 20.0, 40.0), (-3.503, -1.606, 4.460, 20.0, 40.0), (-2.036, -1.522, 5.027, 20.0, 40.0), (-0.473, -0.617, 3.997, 20.0, 40.0), (-1.554, -1.630, 5.483, 20.0, 40.0), (-3.567, -1.043, 3.302, 20.0, 40.0), (-2.038, 0.579, 0.823, 20.0, 40.0), (-3.040, 0.857, -0.233, 20.0, 40.0), (4.610, 0.562, 4.181, 20.0, 40.0), (-3.323, -1.938, 5.215, 20.0, 40.0), (4.314, 1.720, 1.717, 20.0, 40.0), (-1.220, 0.615, 1.161, 20.0, 40.0), (-2.556, 1.120, -0.519, 20.0, 40.0), (-3.717, -0.108, 1.358, 20.0, 40.0), (4.689, -1.826, 8.996, 20.0, 40.0), (3.452, 0.506, 3.713, 20.0, 40.0), (2.472, 0.612, 3.012, 20.0, 40.0), (3.452, 0.450, 3.826, 20.0, 40.0), (1.207, 2.585, -1.567, 20.0, 40.0), (-4.826, 1.090, -1.593, 20.0, 40.0), (3.116, -1.118, 6.794, 20.0, 40.0), (0.448, 2.732, -2.240, 20.0, 40.0), (-1.096, -0.525, 3.503, 20.0, 40.0), (-4.680, -0.238, 1.137, 20.0, 40.0), (2.552, -1.403, 7.082, 20.0, 40.0), (0.719, 2.997, -2.635, 20.0, 40.0), (0.347, -1.966, 7.105, 20.0, 40.0), (2.958, -0.404, 5.288, 20.0, 40.0), (0.722, -1.950, 7.261, 20.0, 40.0), (-2.851, -0.986, 3.546, 20.0, 40.0), (-4.316, -0.439, 1.721, 20.0, 40.0), (-1.685, -0.201, 2.560, 20.0, 40.0), (1.856, 0.190, 3.549, 20.0, 40.0), (-2.052, 0.206, 1.562, 20.0, 40.0), (-2.504, -0.646, 3.041, 20.0, 40.0), (3.235, 0.882, 2.854, 20.0, 40.0), (-1.366, -1.573, 5.463, 20.0, 40.0), (-3.447, 2.419, -3.562, 20.0, 40.0), (4.155, 2.092, 0.893, 20.0, 40.0), (-0.935, 0.209, 2.116, 20.0, 40.0), (3.117, -1.821, 8.201, 20.0, 40.0), (3.759, 0.577, 3.725, 20.0, 40.0), (-0.938, 2.992, -3.453, 20.0, 40.0), (-0.525, 2.341, -1.945, 20.0, 40.0), (4.540, 2.625, 0.019, 20.0, 40.0), (-2.097, 1.190, -0.429, 20.0, 40.0), (-2.672, 1.983, -2.302, 20.0, 40.0), (-3.038, -1.490, 4.460, 20.0, 40.0), (-0.943, 2.149, -1.770, 20.0, 40.0), (0.739, 1.598, 0.174, 20.0, 40.0), (1.828, 1.853, 0.208, 20.0, 40.0), (4.856, 0.137, 5.153, 20.0, 40.0), (-1.617, 0.468, 1.255, 20.0, 40.0), (-1.972, 2.053, -2.092, 20.0, 40.0), (-4.633, 1.389, -2.094, 20.0, 40.0), (-3.628, -1.156, 3.498, 20.0, 40.0), (3.597, 1.034, 2.731, 20.0, 40.0), (-1.488, -0.002, 2.261, 20.0, 40.0), (0.749, 1.921, -0.468, 20.0, 40.0), (1.304, -1.371, 6.394, 20.0, 40.0), (4.587, 2.936, -0.579, 20.0, 40.0), (-2.241, 1.791, -1.703, 20.0, 40.0), (-2.945, 1.372, -1.216, 20.0, 40.0), (1.375, 0.395, 2.898, 20.0, 40.0), (-1.281, -0.641, 3.642, 20.0, 40.0), (2.178, 0.895, 2.299, 20.0, 40.0), (3.031, -0.786, 6.087, 20.0, 40.0), (-1.385, -0.375, 3.058, 20.0, 40.0), (4.041, -0.431, 5.882, 20.0, 40.0), (0.480, -0.507, 4.254, 20.0, 40.0), (-3.797, 0.140, 0.822, 20.0, 40.0), (2.355, 2.502, -0.827, 20.0, 40.0), (1.376, -1.583, 6.854, 20.0, 40.0), (0.164, 1.405, 0.273, 20.0, 40.0), (-1.273, 1.471, -0.579, 20.0, 40.0), (0.770, 2.246, -1.107, 20.0, 40.0), (4.552, 2.904, -0.533, 20.0, 40.0), (4.259, -1.772, 8.674, 20.0, 40.0), (-0.309, 1.159, 0.528, 20.0, 40.0), (3.581, 2.700, -0.610, 20.0, 40.0), (-3.202, 0.346, 0.707, 20.0, 40.0), (-1.575, 1.242, -0.271, 20.0, 40.0), (-1.584, -0.493, 3.194, 20.0, 40.0), (-3.778, 0.150, 0.810, 20.0, 40.0), (-4.675, 1.749, -2.835, 20.0, 40.0), (3.567, -0.792, 6.367, 20.0, 40.0), (-0.417, 1.399, -0.006, 20.0, 40.0), (-4.672, 2.007, -3.349, 20.0, 40.0), (-1.034, 0.196, 2.090, 20.0, 40.0), (-3.796, 2.496, -3.890, 20.0, 40.0), (3.532, -0.497, 5.759, 20.0, 40.0), (4.868, -1.359, 8.151, 20.0, 40.0), (-0.769, 0.302, 2.011, 20.0, 40.0), (4.475, 2.612, 0.014, 20.0, 40.0), (-3.532, -0.395, 2.024, 20.0, 40.0), (0.322, 0.675, 1.812, 20.0, 40.0), (-2.028, -1.942, 5.870, 20.0, 40.0), (1.810, -1.244, 6.392, 20.0, 40.0), (-0.783, 1.242, 0.124, 20.0, 40.0), (-4.745, -1.300, 3.227, 20.0, 40.0), (1.902, 1.973, 0.005, 20.0, 40.0), (-3.453, -1.429, 4.132, 20.0, 40.0), (1.559, 0.986, 1.808, 20.0, 40.0), (0.128, 2.754, -2.443, 20.0, 40.0), (2.759, 1.727, 0.926, 20.0, 40.0), (-4.468, 1.690, -2.614, 20.0, 40.0), (-2.368, -1.922, 5.659, 20.0, 40.0), (-2.766, 2.128, -2.640, 20.0, 40.0), (0.967, -1.825, 7.133, 20.0, 40.0), (-2.854, 2.855, -4.136, 20.0, 40.0), (-2.944, 1.875, -2.222, 20.0, 40.0), (-2.632, -0.983, 3.649, 20.0, 40.0), (2.427, 2.239, -0.266, 20.0, 40.0), (-1.726, -0.838, 3.812, 20.0, 40.0), (0.007, -0.903, 4.809, 20.0, 40.0), (-2.013, 1.092, -0.191, 20.0, 40.0), (-0.449, 0.970, 0.836, 20.0, 40.0), (1.396, 0.411, 2.876, 20.0, 40.0), (-1.115, -1.790, 6.023, 20.0, 40.0), (3.748, 1.917, 1.039, 20.0, 40.0), (2.978, 1.043, 2.404, 20.0, 40.0), (-3.969, 2.514, -4.013, 20.0, 40.0), (4.455, -0.050, 5.328, 20.0, 40.0), (-3.065, -0.846, 3.160, 20.0, 40.0), (-1.069, 2.167, -1.869, 20.0, 40.0), (3.016, -1.393, 7.294, 20.0, 40.0), (0.045, -1.928, 6.879, 20.0, 40.0), (-2.555, -0.984, 3.690, 20.0, 40.0), (-1.995, -0.054, 2.111, 20.0, 40.0), (4.600, -0.509, 6.318, 20.0, 40.0), (-1.942, 1.215, -0.402, 20.0, 40.0), (1.262, 2.765, -1.899, 20.0, 40.0), (2.617, -1.106, 6.521, 20.0, 40.0), (1.737, 0.554, 2.761, 20.0, 40.0), (-2.197, 0.632, 0.638, 20.0, 40.0), (4.768, 2.618, 0.147, 20.0, 40.0), (-3.737, -0.939, 3.010, 20.0, 40.0), (-2.623, 0.595, 0.499, 20.0, 40.0), (4.752, -0.340, 6.057, 20.0, 40.0), (2.333, -1.037, 6.240, 20.0, 40.0), (4.234, -1.882, 8.881, 20.0, 40.0), (-3.393, -0.812, 2.927, 20.0, 40.0), (0.885, 1.383, 0.678, 20.0, 40.0), (0.123, 2.937, -2.812, 20.0, 40.0), (2.969, 0.760, 2.964, 20.0, 40.0), (-4.929, 1.251, -1.967, 20.0, 40.0), (1.916, 2.223, -0.488, 20.0, 40.0), (-0.020, -1.740, 6.469, 20.0, 40.0), (0.702, -1.272, 5.895, 20.0, 40.0), (2.496, 2.648, -1.048, 20.0, 40.0), (4.067, -1.475, 7.984, 20.0, 40.0), (-3.717, 1.851, -2.561, 20.0, 40.0), (1.678, -0.624, 5.088, 20.0, 40.0), (1.073, 0.695, 2.146, 20.0, 40.0), (1.842, -0.749, 5.419, 20.0, 40.0), (-3.518, 1.909, -2.578, 20.0, 40.0), (2.229, 1.189, 1.737, 20.0, 40.0), (4.987, 2.893, -0.292, 20.0, 40.0), (-4.809, 1.043, -1.490, 20.0, 40.0), (-0.241, -0.728, 4.334, 20.0, 40.0), (-3.331, 0.590, 0.156, 20.0, 40.0), (-0.455, 2.621, -2.470, 20.0, 40.0), (1.492, 1.223, 1.301, 20.0, 40.0), (3.948, 2.841, -0.709, 20.0, 40.0), (0.732, 0.446, 2.475, 20.0, 40.0), (2.400, 2.390, -0.579, 20.0, 40.0), (-2.718, 1.427, -1.213, 20.0, 40.0), (-1.826, 1.451, -0.815, 20.0, 40.0), (1.125, 0.438, 2.686, 20.0, 40.0), (-4.918, 1.880, -3.219, 20.0, 40.0), (3.068, -0.442, 5.418, 20.0, 40.0), (1.982, 1.201, 1.589, 20.0, 40.0), (0.701, -1.709, 6.768, 20.0, 40.0), (-1.496, 2.564, -2.877, 20.0, 40.0), (-3.812, 0.974, -0.853, 20.0, 40.0), (-3.405, 2.018, -2.739, 20.0, 40.0), (2.211, 2.889, -1.674, 20.0, 40.0), (-2.481, 2.931, -4.103, 20.0, 40.0), (-3.721, 2.765, -4.391, 20.0, 40.0), (-1.768, -1.292, 4.699, 20.0, 40.0), (-4.462, 1.058, -1.347, 20.0, 40.0), (-3.516, -1.942, 5.126, 20.0, 40.0), (0.485, 2.420, -1.597, 20.0, 40.0), (-0.492, 0.242, 2.270, 20.0, 40.0), (4.245, 1.689, 1.744, 20.0, 40.0), (2.234, 0.364, 3.389, 20.0, 40.0), (2.629, 2.224, -0.134, 20.0, 40.0), (-4.375, 1.221, -1.630, 20.0, 40.0), (-0.618, 1.374, -0.057, 20.0, 40.0), (-2.580, -1.604, 4.918, 20.0, 40.0), (0.159, 1.104, 0.871, 20.0, 40.0), (-3.597, 0.975, -0.749, 20.0, 40.0); DROP TABLE IF EXISTS test.model; -create table test.model engine = Memory as select LinearRegressionState(0.03, 0.00001, 2, 2.0)(target, param1, param2) as state from test.defaults; +create table test.model engine = Memory as select LinearRegressionState(0.03, 0.00001, 2, 'Momentum')(target, param1, param2) as state from test.defaults; select ans > -67.0 and ans < -66.9 from (with (select state + state + state from test.model) as model select evalMLMethod(model, predict1, predict2) as ans from test.defaults limit 1); diff --git a/dbms/tests/queries/0_stateless/00939_ml_test.sql b/dbms/tests/queries/0_stateless/00939_ml_test.sql index 6152053f17a..166b3ae0d85 100644 --- a/dbms/tests/queries/0_stateless/00939_ml_test.sql +++ b/dbms/tests/queries/0_stateless/00939_ml_test.sql @@ -11,7 +11,7 @@ CREATE TABLE IF NOT EXISTS test.defaults insert into test.defaults values (-3.273, -1.452, 4.267, 20.0, 40.0), (0.121, -0.615, 4.290, 20.0, 40.0), (-1.099, 2.755, -3.060, 20.0, 40.0), (1.090, 2.945, -2.346, 20.0, 40.0), (0.305, 2.179, -1.205, 20.0, 40.0), (-0.925, 0.702, 1.134, 20.0, 40.0), (3.178, -1.316, 7.221, 20.0, 40.0), (-2.756, -0.473, 2.569, 20.0, 40.0), (3.665, 2.303, 0.226, 20.0, 40.0), (1.662, 1.951, -0.070, 20.0, 40.0), (2.869, 0.593, 3.249, 20.0, 40.0), (0.818, -0.593, 4.594, 20.0, 40.0), (-1.917, 0.916, 0.209, 20.0, 40.0), (2.706, 1.523, 1.307, 20.0, 40.0), (0.219, 2.162, -1.214, 20.0, 40.0), (-4.510, 1.376, -2.007, 20.0, 40.0), (4.284, -0.515, 6.173, 20.0, 40.0), (-1.101, 2.810, -3.170, 20.0, 40.0), (-1.810, -1.117, 4.329, 20.0, 40.0), (0.055, 1.115, 0.797, 20.0, 40.0), (-2.178, 2.904, -3.898, 20.0, 40.0), (-3.494, -1.814, 4.882, 20.0, 40.0), (3.027, 0.476, 3.562, 20.0, 40.0), (-1.434, 1.151, -0.018, 20.0, 40.0), (1.180, 0.992, 1.606, 20.0, 40.0), (0.015, 0.971, 1.067, 20.0, 40.0), (-0.511, -0.875, 4.495, 20.0, 40.0), (0.961, 2.348, -1.216, 20.0, 40.0), (-2.279, 0.038, 1.785, 20.0, 40.0), (-1.568, -0.248, 2.712, 20.0, 40.0), (-0.496, 0.366, 2.020, 20.0, 40.0), (1.177, -1.401, 6.390, 20.0, 40.0), (2.882, -1.442, 7.325, 20.0, 40.0), (-1.066, 1.817, -1.167, 20.0, 40.0), (-2.144, 2.791, -3.655, 20.0, 40.0), (-4.370, 2.228, -3.642, 20.0, 40.0), (3.996, 2.775, -0.553, 20.0, 40.0), (0.289, 2.055, -0.965, 20.0, 40.0), (-0.588, -1.601, 5.908, 20.0, 40.0), (-1.801, 0.417, 1.265, 20.0, 40.0), (4.375, -1.499, 8.186, 20.0, 40.0), (-2.618, 0.038, 1.615, 20.0, 40.0), (3.616, -0.833, 6.475, 20.0, 40.0), (-4.045, -1.558, 4.094, 20.0, 40.0), (-3.962, 0.636, -0.253, 20.0, 40.0), (3.505, 2.625, -0.497, 20.0, 40.0), (3.029, -0.523, 5.560, 20.0, 40.0), (-3.520, -0.474, 2.188, 20.0, 40.0), (2.430, -1.469, 7.154, 20.0, 40.0), (1.547, -1.654, 7.082, 20.0, 40.0), (-1.370, 0.575, 1.165, 20.0, 40.0), (-1.869, -1.555, 5.176, 20.0, 40.0), (3.536, 2.841, -0.913, 20.0, 40.0), (-3.810, 1.220, -1.344, 20.0, 40.0), (-1.971, 1.462, -0.910, 20.0, 40.0), (-0.243, 0.167, 2.545, 20.0, 40.0), (-1.403, 2.645, -2.991, 20.0, 40.0), (0.532, -0.114, 3.494, 20.0, 40.0), (-1.678, 0.975, 0.212, 20.0, 40.0), (-0.656, 2.140, -1.609, 20.0, 40.0), (1.743, 2.631, -1.390, 20.0, 40.0), (2.586, 2.943, -1.593, 20.0, 40.0), (-0.512, 2.969, -3.195, 20.0, 40.0), (2.283, -0.100, 4.342, 20.0, 40.0), (-4.293, 0.872, -0.890, 20.0, 40.0), (3.411, 1.300, 2.106, 20.0, 40.0), (-0.281, 2.951, -3.042, 20.0, 40.0), (-4.442, 0.384, 0.012, 20.0, 40.0), (1.194, 1.746, 0.104, 20.0, 40.0), (-1.152, 1.862, -1.300, 20.0, 40.0), (1.362, -1.341, 6.363, 20.0, 40.0), (-4.488, 2.618, -4.481, 20.0, 40.0), (3.419, -0.564, 5.837, 20.0, 40.0), (-3.392, 0.396, 0.512, 20.0, 40.0), (-1.629, -0.909, 4.003, 20.0, 40.0), (4.447, -1.088, 7.399, 20.0, 40.0), (-1.232, 1.699, -1.014, 20.0, 40.0), (-1.286, -0.609, 3.575, 20.0, 40.0), (2.437, 2.796, -1.374, 20.0, 40.0), (-4.864, 1.989, -3.410, 20.0, 40.0), (-1.716, -1.399, 4.940, 20.0, 40.0), (-3.084, 1.858, -2.259, 20.0, 40.0), (2.828, -0.319, 5.053, 20.0, 40.0), (-1.226, 2.586, -2.786, 20.0, 40.0), (2.456, 0.092, 4.044, 20.0, 40.0), (-0.989, 2.375, -2.245, 20.0, 40.0), (3.268, 0.935, 2.765, 20.0, 40.0), (-4.128, -1.995, 4.927, 20.0, 40.0), (-1.083, 2.197, -1.935, 20.0, 40.0), (-3.471, -1.198, 3.660, 20.0, 40.0), (4.617, -1.136, 7.579, 20.0, 40.0), (2.054, -1.675, 7.378, 20.0, 40.0), (4.106, 2.326, 0.402, 20.0, 40.0), (1.558, 0.310, 3.158, 20.0, 40.0), (0.792, 0.900, 1.596, 20.0, 40.0), (-3.229, 0.300, 0.785, 20.0, 40.0), (3.787, -0.793, 6.479, 20.0, 40.0), (1.786, 2.288, -0.684, 20.0, 40.0), (2.643, 0.223, 3.875, 20.0, 40.0), (-3.592, 2.122, -3.040, 20.0, 40.0), (4.519, -1.760, 8.779, 20.0, 40.0), (3.221, 2.255, 0.101, 20.0, 40.0), (4.151, 1.788, 1.500, 20.0, 40.0), (-1.033, -1.195, 4.874, 20.0, 40.0), (-1.636, -1.037, 4.257, 20.0, 40.0), (-3.548, 1.911, -2.596, 20.0, 40.0), (4.829, -0.293, 6.001, 20.0, 40.0), (-4.684, -1.664, 3.986, 20.0, 40.0), (4.531, -0.503, 6.271, 20.0, 40.0), (-3.503, -1.606, 4.460, 20.0, 40.0), (-2.036, -1.522, 5.027, 20.0, 40.0), (-0.473, -0.617, 3.997, 20.0, 40.0), (-1.554, -1.630, 5.483, 20.0, 40.0), (-3.567, -1.043, 3.302, 20.0, 40.0), (-2.038, 0.579, 0.823, 20.0, 40.0), (-3.040, 0.857, -0.233, 20.0, 40.0), (4.610, 0.562, 4.181, 20.0, 40.0), (-3.323, -1.938, 5.215, 20.0, 40.0), (4.314, 1.720, 1.717, 20.0, 40.0), (-1.220, 0.615, 1.161, 20.0, 40.0), (-2.556, 1.120, -0.519, 20.0, 40.0), (-3.717, -0.108, 1.358, 20.0, 40.0), (4.689, -1.826, 8.996, 20.0, 40.0), (3.452, 0.506, 3.713, 20.0, 40.0), (2.472, 0.612, 3.012, 20.0, 40.0), (3.452, 0.450, 3.826, 20.0, 40.0), (1.207, 2.585, -1.567, 20.0, 40.0), (-4.826, 1.090, -1.593, 20.0, 40.0), (3.116, -1.118, 6.794, 20.0, 40.0), (0.448, 2.732, -2.240, 20.0, 40.0), (-1.096, -0.525, 3.503, 20.0, 40.0), (-4.680, -0.238, 1.137, 20.0, 40.0), (2.552, -1.403, 7.082, 20.0, 40.0), (0.719, 2.997, -2.635, 20.0, 40.0), (0.347, -1.966, 7.105, 20.0, 40.0), (2.958, -0.404, 5.288, 20.0, 40.0), (0.722, -1.950, 7.261, 20.0, 40.0), (-2.851, -0.986, 3.546, 20.0, 40.0), (-4.316, -0.439, 1.721, 20.0, 40.0), (-1.685, -0.201, 2.560, 20.0, 40.0), (1.856, 0.190, 3.549, 20.0, 40.0), (-2.052, 0.206, 1.562, 20.0, 40.0), (-2.504, -0.646, 3.041, 20.0, 40.0), (3.235, 0.882, 2.854, 20.0, 40.0), (-1.366, -1.573, 5.463, 20.0, 40.0), (-3.447, 2.419, -3.562, 20.0, 40.0), (4.155, 2.092, 0.893, 20.0, 40.0), (-0.935, 0.209, 2.116, 20.0, 40.0), (3.117, -1.821, 8.201, 20.0, 40.0), (3.759, 0.577, 3.725, 20.0, 40.0), (-0.938, 2.992, -3.453, 20.0, 40.0), (-0.525, 2.341, -1.945, 20.0, 40.0), (4.540, 2.625, 0.019, 20.0, 40.0), (-2.097, 1.190, -0.429, 20.0, 40.0), (-2.672, 1.983, -2.302, 20.0, 40.0), (-3.038, -1.490, 4.460, 20.0, 40.0), (-0.943, 2.149, -1.770, 20.0, 40.0), (0.739, 1.598, 0.174, 20.0, 40.0), (1.828, 1.853, 0.208, 20.0, 40.0), (4.856, 0.137, 5.153, 20.0, 40.0), (-1.617, 0.468, 1.255, 20.0, 40.0), (-1.972, 2.053, -2.092, 20.0, 40.0), (-4.633, 1.389, -2.094, 20.0, 40.0), (-3.628, -1.156, 3.498, 20.0, 40.0), (3.597, 1.034, 2.731, 20.0, 40.0), (-1.488, -0.002, 2.261, 20.0, 40.0), (0.749, 1.921, -0.468, 20.0, 40.0), (1.304, -1.371, 6.394, 20.0, 40.0), (4.587, 2.936, -0.579, 20.0, 40.0), (-2.241, 1.791, -1.703, 20.0, 40.0), (-2.945, 1.372, -1.216, 20.0, 40.0), (1.375, 0.395, 2.898, 20.0, 40.0), (-1.281, -0.641, 3.642, 20.0, 40.0), (2.178, 0.895, 2.299, 20.0, 40.0), (3.031, -0.786, 6.087, 20.0, 40.0), (-1.385, -0.375, 3.058, 20.0, 40.0), (4.041, -0.431, 5.882, 20.0, 40.0), (0.480, -0.507, 4.254, 20.0, 40.0), (-3.797, 0.140, 0.822, 20.0, 40.0), (2.355, 2.502, -0.827, 20.0, 40.0), (1.376, -1.583, 6.854, 20.0, 40.0), (0.164, 1.405, 0.273, 20.0, 40.0), (-1.273, 1.471, -0.579, 20.0, 40.0), (0.770, 2.246, -1.107, 20.0, 40.0), (4.552, 2.904, -0.533, 20.0, 40.0), (4.259, -1.772, 8.674, 20.0, 40.0), (-0.309, 1.159, 0.528, 20.0, 40.0), (3.581, 2.700, -0.610, 20.0, 40.0), (-3.202, 0.346, 0.707, 20.0, 40.0), (-1.575, 1.242, -0.271, 20.0, 40.0), (-1.584, -0.493, 3.194, 20.0, 40.0), (-3.778, 0.150, 0.810, 20.0, 40.0), (-4.675, 1.749, -2.835, 20.0, 40.0), (3.567, -0.792, 6.367, 20.0, 40.0), (-0.417, 1.399, -0.006, 20.0, 40.0), (-4.672, 2.007, -3.349, 20.0, 40.0), (-1.034, 0.196, 2.090, 20.0, 40.0), (-3.796, 2.496, -3.890, 20.0, 40.0), (3.532, -0.497, 5.759, 20.0, 40.0), (4.868, -1.359, 8.151, 20.0, 40.0), (-0.769, 0.302, 2.011, 20.0, 40.0), (4.475, 2.612, 0.014, 20.0, 40.0), (-3.532, -0.395, 2.024, 20.0, 40.0), (0.322, 0.675, 1.812, 20.0, 40.0), (-2.028, -1.942, 5.870, 20.0, 40.0), (1.810, -1.244, 6.392, 20.0, 40.0), (-0.783, 1.242, 0.124, 20.0, 40.0), (-4.745, -1.300, 3.227, 20.0, 40.0), (1.902, 1.973, 0.005, 20.0, 40.0), (-3.453, -1.429, 4.132, 20.0, 40.0), (1.559, 0.986, 1.808, 20.0, 40.0), (0.128, 2.754, -2.443, 20.0, 40.0), (2.759, 1.727, 0.926, 20.0, 40.0), (-4.468, 1.690, -2.614, 20.0, 40.0), (-2.368, -1.922, 5.659, 20.0, 40.0), (-2.766, 2.128, -2.640, 20.0, 40.0), (0.967, -1.825, 7.133, 20.0, 40.0), (-2.854, 2.855, -4.136, 20.0, 40.0), (-2.944, 1.875, -2.222, 20.0, 40.0), (-2.632, -0.983, 3.649, 20.0, 40.0), (2.427, 2.239, -0.266, 20.0, 40.0), (-1.726, -0.838, 3.812, 20.0, 40.0), (0.007, -0.903, 4.809, 20.0, 40.0), (-2.013, 1.092, -0.191, 20.0, 40.0), (-0.449, 0.970, 0.836, 20.0, 40.0), (1.396, 0.411, 2.876, 20.0, 40.0), (-1.115, -1.790, 6.023, 20.0, 40.0), (3.748, 1.917, 1.039, 20.0, 40.0), (2.978, 1.043, 2.404, 20.0, 40.0), (-3.969, 2.514, -4.013, 20.0, 40.0), (4.455, -0.050, 5.328, 20.0, 40.0), (-3.065, -0.846, 3.160, 20.0, 40.0), (-1.069, 2.167, -1.869, 20.0, 40.0), (3.016, -1.393, 7.294, 20.0, 40.0), (0.045, -1.928, 6.879, 20.0, 40.0), (-2.555, -0.984, 3.690, 20.0, 40.0), (-1.995, -0.054, 2.111, 20.0, 40.0), (4.600, -0.509, 6.318, 20.0, 40.0), (-1.942, 1.215, -0.402, 20.0, 40.0), (1.262, 2.765, -1.899, 20.0, 40.0), (2.617, -1.106, 6.521, 20.0, 40.0), (1.737, 0.554, 2.761, 20.0, 40.0), (-2.197, 0.632, 0.638, 20.0, 40.0), (4.768, 2.618, 0.147, 20.0, 40.0), (-3.737, -0.939, 3.010, 20.0, 40.0), (-2.623, 0.595, 0.499, 20.0, 40.0), (4.752, -0.340, 6.057, 20.0, 40.0), (2.333, -1.037, 6.240, 20.0, 40.0), (4.234, -1.882, 8.881, 20.0, 40.0), (-3.393, -0.812, 2.927, 20.0, 40.0), (0.885, 1.383, 0.678, 20.0, 40.0), (0.123, 2.937, -2.812, 20.0, 40.0), (2.969, 0.760, 2.964, 20.0, 40.0), (-4.929, 1.251, -1.967, 20.0, 40.0), (1.916, 2.223, -0.488, 20.0, 40.0), (-0.020, -1.740, 6.469, 20.0, 40.0), (0.702, -1.272, 5.895, 20.0, 40.0), (2.496, 2.648, -1.048, 20.0, 40.0), (4.067, -1.475, 7.984, 20.0, 40.0), (-3.717, 1.851, -2.561, 20.0, 40.0), (1.678, -0.624, 5.088, 20.0, 40.0), (1.073, 0.695, 2.146, 20.0, 40.0), (1.842, -0.749, 5.419, 20.0, 40.0), (-3.518, 1.909, -2.578, 20.0, 40.0), (2.229, 1.189, 1.737, 20.0, 40.0), (4.987, 2.893, -0.292, 20.0, 40.0), (-4.809, 1.043, -1.490, 20.0, 40.0), (-0.241, -0.728, 4.334, 20.0, 40.0), (-3.331, 0.590, 0.156, 20.0, 40.0), (-0.455, 2.621, -2.470, 20.0, 40.0), (1.492, 1.223, 1.301, 20.0, 40.0), (3.948, 2.841, -0.709, 20.0, 40.0), (0.732, 0.446, 2.475, 20.0, 40.0), (2.400, 2.390, -0.579, 20.0, 40.0), (-2.718, 1.427, -1.213, 20.0, 40.0), (-1.826, 1.451, -0.815, 20.0, 40.0), (1.125, 0.438, 2.686, 20.0, 40.0), (-4.918, 1.880, -3.219, 20.0, 40.0), (3.068, -0.442, 5.418, 20.0, 40.0), (1.982, 1.201, 1.589, 20.0, 40.0), (0.701, -1.709, 6.768, 20.0, 40.0), (-1.496, 2.564, -2.877, 20.0, 40.0), (-3.812, 0.974, -0.853, 20.0, 40.0), (-3.405, 2.018, -2.739, 20.0, 40.0), (2.211, 2.889, -1.674, 20.0, 40.0), (-2.481, 2.931, -4.103, 20.0, 40.0), (-3.721, 2.765, -4.391, 20.0, 40.0), (-1.768, -1.292, 4.699, 20.0, 40.0), (-4.462, 1.058, -1.347, 20.0, 40.0), (-3.516, -1.942, 5.126, 20.0, 40.0), (0.485, 2.420, -1.597, 20.0, 40.0), (-0.492, 0.242, 2.270, 20.0, 40.0), (4.245, 1.689, 1.744, 20.0, 40.0), (2.234, 0.364, 3.389, 20.0, 40.0), (2.629, 2.224, -0.134, 20.0, 40.0), (-4.375, 1.221, -1.630, 20.0, 40.0), (-0.618, 1.374, -0.057, 20.0, 40.0), (-2.580, -1.604, 4.918, 20.0, 40.0), (0.159, 1.104, 0.871, 20.0, 40.0), (-3.597, 0.975, -0.749, 20.0, 40.0); DROP TABLE IF EXISTS test.model; -create table test.model engine = Memory as select LinearRegressionState(0.03, 0.00001, 2, 2.0)(target, param1, param2) as state from test.defaults; +create table test.model engine = Memory as select LinearRegressionState(0.03, 0.00001, 2, 'Nesterov')(target, param1, param2) as state from test.defaults; select ans > -67.0 and ans < -66.9 from (with (select state from test.model) as model select evalMLMethod(model, predict1, predict2) as ans from test.defaults limit 1); From ef98afb6a610ddb1d873b8ca7389ad318fec6fd8 Mon Sep 17 00:00:00 2001 From: Alexander Kozhikhov Date: Sun, 21 Apr 2019 17:42:37 +0300 Subject: [PATCH 059/709] review fixes --- dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp | 2 +- dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h | 4 ++-- 2 files changed, 3 insertions(+), 3 deletions(-) diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp index 67a361d73c8..bfd87f28821 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp @@ -34,7 +34,7 @@ AggregateFunctionPtr createAggregateFunctionMLMethod( auto l2_reg_coef = Float64(0.01); UInt32 batch_size = 1; - std::shared_ptr weights_updater = std::make_unique(); + std::shared_ptr weights_updater = std::make_shared(); std::shared_ptr gradient_computer; if (!parameters.empty()) diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h index d535a27adaa..88d869f022a 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h @@ -87,7 +87,7 @@ public: { const ColumnWithTypeAndName & cur_col = block.getByPosition(arguments[i]); if (!isNumber(cur_col.type)) { - throw Exception("Prediction arguments must be have numeric type", ErrorCodes::BAD_ARGUMENTS); + throw Exception("Prediction arguments must have numeric type", ErrorCodes::BAD_ARGUMENTS); } /// If column type is already Float64 then castColumn simply returns it @@ -153,7 +153,7 @@ public: { const ColumnWithTypeAndName & cur_col = block.getByPosition(arguments[i]); if (!isNumber(cur_col.type)) { - throw Exception("Prediction arguments must be have numeric type", ErrorCodes::BAD_ARGUMENTS); + throw Exception("Prediction arguments must have numeric type", ErrorCodes::BAD_ARGUMENTS); } /// If column type is already Float64 then castColumn simply returns it From 0bedabb5e45431ba83c44a81e7f5a57731b14510 Mon Sep 17 00:00:00 2001 From: Alexander Kozhikhov Date: Sun, 21 Apr 2019 17:44:39 +0300 Subject: [PATCH 060/709] review fixes --- .../src/AggregateFunctions/AggregateFunctionMLMethod.cpp | 9 ++++++--- dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h | 6 ++++-- 2 files changed, 10 insertions(+), 5 deletions(-) diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp index bfd87f28821..cbfd4c69723 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.cpp @@ -52,13 +52,16 @@ AggregateFunctionPtr createAggregateFunctionMLMethod( } if (parameters.size() > 3) { - if (applyVisitor(FieldVisitorToString(), parameters[3]) == "\'SGD\'") { + if (applyVisitor(FieldVisitorToString(), parameters[3]) == "\'SGD\'") + { weights_updater = std::make_shared(); } - else if (applyVisitor(FieldVisitorToString(), parameters[3]) == "\'Momentum\'") { + else if (applyVisitor(FieldVisitorToString(), parameters[3]) == "\'Momentum\'") + { weights_updater = std::make_shared(); } - else if (applyVisitor(FieldVisitorToString(), parameters[3]) == "\'Nesterov\'") { + else if (applyVisitor(FieldVisitorToString(), parameters[3]) == "\'Nesterov\'") + { weights_updater = std::make_shared(); } else diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h index 88d869f022a..649101763f9 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h @@ -86,7 +86,8 @@ public: for (size_t i = 1; i < arguments.size(); ++i) { const ColumnWithTypeAndName & cur_col = block.getByPosition(arguments[i]); - if (!isNumber(cur_col.type)) { + if (!isNumber(cur_col.type)) + { throw Exception("Prediction arguments must have numeric type", ErrorCodes::BAD_ARGUMENTS); } @@ -152,7 +153,8 @@ public: for (size_t i = 1; i < arguments.size(); ++i) { const ColumnWithTypeAndName & cur_col = block.getByPosition(arguments[i]); - if (!isNumber(cur_col.type)) { + if (!isNumber(cur_col.type)) + { throw Exception("Prediction arguments must have numeric type", ErrorCodes::BAD_ARGUMENTS); } From 6c7f2cbc377d99741fa7dd0ca1853952a7d7f8ad Mon Sep 17 00:00:00 2001 From: Alexander Kozhikhov Date: Sun, 21 Apr 2019 19:08:55 +0300 Subject: [PATCH 061/709] asan --- dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h index 649101763f9..7fe1d9b8cab 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h +++ b/dbms/src/AggregateFunctions/AggregateFunctionMLMethod.h @@ -394,7 +394,7 @@ public: void add(const IColumn **columns, size_t row_num) { /// first column stores target; features start from (columns + 1) - const auto &target = (*columns[0])[row_num].get(); + const auto target = (*columns[0])[row_num].get(); /// Here we have columns + 1 as first column corresponds to target value, and others - to features weights_updater->add_to_batch(gradient_batch, *gradient_computer, weights, bias, learning_rate, l2_reg_coef, target, columns + 1, row_num); From e4766a4ef9117725c51a98e037a483fc0d43a79b Mon Sep 17 00:00:00 2001 From: Yuriy Date: Mon, 22 Apr 2019 13:57:50 +0300 Subject: [PATCH 062/709] caching_sha2_password authentication plugin --- dbms/programs/server/MySQLHandler.cpp | 171 ++++++++++++++---- dbms/programs/server/MySQLHandler.h | 24 ++- dbms/programs/server/MySQLHandlerFactory.h | 73 +++++++- dbms/src/Core/MySQLProtocol.h | 54 ++++-- dbms/tests/integration/helpers/cluster.py | 2 + .../clients/golang/main.go | 11 +- .../integration/test_mysql_protocol/test.py | 8 +- 7 files changed, 278 insertions(+), 65 deletions(-) diff --git a/dbms/programs/server/MySQLHandler.cpp b/dbms/programs/server/MySQLHandler.cpp index f7ad2cf7c1f..e3a941206da 100644 --- a/dbms/programs/server/MySQLHandler.cpp +++ b/dbms/programs/server/MySQLHandler.cpp @@ -8,6 +8,8 @@ #include #include #include +#include +#include #include "MySQLHandler.h" #include @@ -19,6 +21,7 @@ using namespace MySQLProtocol; namespace ErrorCodes { extern const int MYSQL_CLIENT_INSUFFICIENT_CAPABILITIES; + extern const int UNKNOWN_EXCEPTION; } uint32_t MySQLHandler::last_connection_id = 0; @@ -36,7 +39,14 @@ void MySQLHandler::run() try { - Handshake handshake(connection_id, VERSION_STRING); + String scramble = generateScramble(); + + /** Native authentication sent 20 bytes + '\0' character = 21 bytes. + * This plugin must do the same to stay consistent with historical behavior if it is set to operate as a default plugin. + * https://github.com/mysql/mysql-server/blob/8.0/sql/auth/sql_authentication.cc#L3994 + */ + Handshake handshake(connection_id, VERSION_STRING, scramble + '\0'); + packet_sender.sendPacket(handshake, true); LOG_TRACE(log, "Sent handshake"); @@ -70,40 +80,7 @@ void MySQLHandler::run() throw Exception("Required capability: CLIENT_PLUGIN_AUTH.", ErrorCodes::MYSQL_CLIENT_INSUFFICIENT_CAPABILITIES); } - String password; - if (handshake_response.auth_plugin_name != Authentication::ClearText) - { - - packet_sender.sendPacket(AuthSwitchRequest(Authentication::ClearText, ""), true); - NullTerminatedString password_packet; - packet_sender.receivePacket(password_packet); - password = password_packet.value; - } - else - { - NullTerminatedString packet; - packet.readPayload(std::move(handshake_response.auth_response)); - password = packet.value; - } - LOG_TRACE(log, "password: " << password); - try - { - connection_context.setUser(handshake_response.username, password, socket().address(), ""); - connection_context.setCurrentDatabase(handshake_response.database); - connection_context.setCurrentQueryId(""); - LOG_ERROR(log, "Authentication for user " << handshake_response.username << " succeeded."); - } - catch (const NetException &) - { - throw; - } - catch (const Exception & exc) - { - LOG_ERROR(log, "Authentication for user " << handshake_response.username << " failed."); - packet_sender.sendPacket(ERR_Packet(exc.code(), "00000", exc.message()), true); - throw; - } - + authenticate(handshake_response, scramble); OK_Packet ok_packet(0, handshake_response.capability_flags, 0, 0, 0, 0, ""); packet_sender.sendPacket(ok_packet, true); @@ -153,6 +130,130 @@ void MySQLHandler::run() } } + +String MySQLHandler::generateScramble() +{ + String scramble(MySQLProtocol::SCRAMBLE_LENGTH, 0); + Poco::RandomInputStream generator; + for (size_t i = 0; i < scramble.size(); i++) { + generator >> scramble[i]; + } + return scramble; +} + +void MySQLHandler::authenticate(const HandshakeResponse & handshake_response, const String & scramble) { + + String auth_response; + AuthSwitchResponse response; + if (handshake_response.auth_plugin_name != Authentication::CachingSHA2) { + packet_sender.sendPacket(AuthSwitchRequest(Authentication::CachingSHA2, scramble + '\0'), true); + packet_sender.receivePacket(response); + auth_response = response.value; + LOG_TRACE(log, "Authentication method mismatch."); + } + else + { + auth_response = handshake_response.auth_response; + LOG_TRACE(log, "Authentication method match."); + } + + /// Caching SHA2 plugin is used instead of SHA256 only because it can work without OpenSLL. + /// Fast auth path is not used, because otherwise it would be possible to authenticate using data from users.xml. + packet_sender.sendPacket(AuthMoreData("\4"), true); + + packet_sender.receivePacket(response); + auth_response = response.value; + + auto getOpenSSLError = []() -> String { + BIO * mem = BIO_new(BIO_s_mem()); + ERR_print_errors(mem); + char * pem_buf = nullptr; + long pem_size = BIO_get_mem_data(mem, &pem_buf); + String pem(pem_buf, pem_size); + BIO_free(mem); + return pem; + }; + + if (auth_response == "\2") + { + LOG_TRACE(log, "Client requests public key."); + /// Client requests public key. + BIO * mem = BIO_new(BIO_s_mem()); + if (PEM_write_bio_RSA_PUBKEY(mem, public_key) != 1) + { + LOG_TRACE(log, "OpenSSL error:\n" << getOpenSSLError()); + throw Exception("Failed to write public key to memory.", ErrorCodes::UNKNOWN_EXCEPTION); + } + char * pem_buf = nullptr; + long pem_size = BIO_get_mem_data(mem, &pem_buf); + String pem(pem_buf, pem_size); + BIO_free(mem); + + LOG_TRACE(log, "Key: " << pem); + + AuthMoreData data(pem); + packet_sender.sendPacket(data, true); + packet_sender.receivePacket(response); + auth_response = response.value; + } + else + { + LOG_TRACE(log, "Client didn't request public key."); + } + + String password; + + LOG_TRACE(log, "auth response: " << auth_response); + + /** Decrypt password, if it's not empty. + * The original intention was that the password is a string[NUL] but this never got enforced properly so now we have to accept that + * an empty packet is a blank password, thus the check for auth_response.empty() has to be made too. + * https://github.com/mysql/mysql-server/blob/8.0/sql/auth/sql_authentication.cc#L4017 + */ + + if (!(auth_response.empty() || (auth_response.size() == 1 && auth_response[0] == '\0'))) + { + LOG_TRACE(log, "Received nonempty password"); + auto ciphertext = reinterpret_cast(auth_response.data()); + + unsigned char plaintext[RSA_size(private_key)]; + int plaintext_size = RSA_private_decrypt(auth_response.size(), ciphertext, plaintext, private_key, RSA_PKCS1_OAEP_PADDING); + if (plaintext_size == -1) + { + LOG_TRACE(log, "OpenSSL error:\n" << getOpenSSLError()); + throw Exception("Failed to decrypt.", ErrorCodes::UNKNOWN_EXCEPTION); + } + + password.resize(plaintext_size); + for (int i = 0; i < plaintext_size; i++) { + password[i] = plaintext[i] ^ static_cast(scramble[i % scramble.size()]); + } + } + else + { + LOG_TRACE(log, "Received empty password"); + } + + if (!password.empty()) { + /// remove terminating null byte + password.pop_back(); + } + + try + { + connection_context.setUser(handshake_response.username, password, socket().address(), ""); + connection_context.setCurrentDatabase(handshake_response.database); + connection_context.setCurrentQueryId(""); + LOG_ERROR(log, "Authentication for user " << handshake_response.username << " succeeded."); + } + catch (const Exception & exc) + { + LOG_ERROR(log, "Authentication for user " << handshake_response.username << " failed."); + packet_sender.sendPacket(ERR_Packet(exc.code(), "00000", exc.message()), true); + throw; + } +} + void MySQLHandler::comInitDB(String payload) { String database = payload.substr(1); diff --git a/dbms/programs/server/MySQLHandler.h b/dbms/programs/server/MySQLHandler.h index 0e1a73f0f24..71879353028 100644 --- a/dbms/programs/server/MySQLHandler.h +++ b/dbms/programs/server/MySQLHandler.h @@ -3,6 +3,7 @@ #include #include #include +#include #include "IServer.h" @@ -13,14 +14,24 @@ namespace DB class MySQLHandler : public Poco::Net::TCPServerConnection { public: - MySQLHandler(IServer & server_, const Poco::Net::StreamSocket & socket_) - : Poco::Net::TCPServerConnection(socket_), server(server_), log(&Poco::Logger::get("MySQLHandler")), - connection_context(server.context()), connection_id(last_connection_id++) + MySQLHandler( + IServer & server_, + const Poco::Net::StreamSocket & socket_, + RSA * public_key, + RSA * private_key) + : Poco::Net::TCPServerConnection(socket_) + , server(server_) + , log(&Poco::Logger::get("MySQLHandler")) + , connection_context(server.context()) + , connection_id(last_connection_id++) + , public_key(public_key) + , private_key(private_key) { } void run() final; +private: void comQuery(String payload); void comFieldList(String payload); @@ -29,7 +40,10 @@ public: void comInitDB(String payload); -private: + static String generateScramble(); + + void authenticate(const MySQLProtocol::HandshakeResponse &, const String & scramble); + IServer & server; Poco::Logger * log; Context connection_context; @@ -41,6 +55,8 @@ private: uint32_t capabilities; static uint32_t last_connection_id; + + RSA * public_key, * private_key; }; } diff --git a/dbms/programs/server/MySQLHandlerFactory.h b/dbms/programs/server/MySQLHandlerFactory.h index 5f081915778..459e3f4f5e3 100644 --- a/dbms/programs/server/MySQLHandlerFactory.h +++ b/dbms/programs/server/MySQLHandlerFactory.h @@ -1,6 +1,8 @@ #pragma once #include +#include +#include #include #include "IServer.h" #include "MySQLHandler.h" @@ -15,18 +17,87 @@ namespace DB private: IServer & server; Poco::Logger * log; + RSA * public_key = nullptr, * private_key = nullptr; public: explicit MySQLHandlerFactory(IServer & server_) : server(server_) , log(&Logger::get("MySQLHandlerFactory")) { + /// Reading rsa keys for SHA256 authentication plugin. + const Poco::Util::LayeredConfiguration & config = Poco::Util::Application::instance().config(); + String certificateFileProperty = "openSSL.server.certificateFile"; + String privateKeyFileProperty = "openSSL.server.privateKeyFile"; + + if (!config.has(certificateFileProperty)) + { + LOG_INFO(log, "Certificate file is not set."); + generateRSAKeys(); + return; + } + if (!config.has(privateKeyFileProperty)) { + LOG_INFO(log, "Private key file is not set."); + generateRSAKeys(); + return; + } + + String certificateFile = config.getString(certificateFileProperty); + FILE * fp = fopen(certificateFile.data(), "r"); + if (fp == nullptr) { + LOG_WARNING(log, "Cannot open certificate file: " << certificateFile << "."); + generateRSAKeys(); + return; + } + X509* x509 = PEM_read_X509(fp, nullptr, nullptr, nullptr); + EVP_PKEY* p = X509_get_pubkey(x509); + public_key = EVP_PKEY_get1_RSA(p); + X509_free(x509); + fclose(fp); + + String privateKeyFile = config.getString(privateKeyFileProperty); + fp = fopen(privateKeyFile.data(), "r"); + if (fp == nullptr) { + LOG_WARNING(log, "Cannot open private key file " << privateKeyFile << "."); + generateRSAKeys(); + return; + } + private_key = PEM_read_RSAPrivateKey(fp, nullptr, nullptr, nullptr); + fclose(fp); + } + + void generateRSAKeys() + { + LOG_INFO(log, "Generating new RSA key."); + RSA *rsa = RSA_new(); + if (rsa == nullptr) { + throw Exception("Failed to allocate RSA key.", 1002); + } + BIGNUM *e = BN_new(); + if (!e) { + RSA_free(rsa); + throw Exception("Failed to allocate BIGNUM.", 1002); + } + if (!BN_set_word(e, 65537) || !RSA_generate_key_ex(rsa, 2048, e, nullptr)) + { + RSA_free(rsa); + BN_free(e); + throw Exception("Failed to generate RSA key.", 1002); + } + BN_free(e); + + public_key = rsa; + private_key = RSAPrivateKey_dup(rsa); } Poco::Net::TCPServerConnection * createConnection(const Poco::Net::StreamSocket & socket) override { LOG_TRACE(log, "MySQL connection. Address: " << socket.peerAddress().toString()); - return new MySQLHandler(server, socket); + return new MySQLHandler(server, socket, public_key, private_key); + } + + ~MySQLHandlerFactory() override { + RSA_free(public_key); + RSA_free(private_key); } }; diff --git a/dbms/src/Core/MySQLProtocol.h b/dbms/src/Core/MySQLProtocol.h index c1cccd689b5..fb705635c69 100644 --- a/dbms/src/Core/MySQLProtocol.h +++ b/dbms/src/Core/MySQLProtocol.h @@ -4,6 +4,7 @@ #include #include #include +#include #include #include @@ -27,7 +28,7 @@ const size_t MYSQL_ERRMSG_SIZE = 512; namespace Authentication { - const String ClearText = "mysql_clear_password"; + const String CachingSHA2 = "caching_sha2_password"; } enum CharacterSet @@ -253,16 +254,16 @@ class Handshake : public WritePacket uint32_t status_flags; String auth_plugin_data; public: - explicit Handshake(uint32_t connection_id, String server_version) - : protocol_version(0xa), server_version(std::move(server_version)), connection_id(connection_id), capability_flags( - CLIENT_PROTOCOL_41 - | CLIENT_SECURE_CONNECTION - | CLIENT_PLUGIN_AUTH - | CLIENT_PLUGIN_AUTH_LENENC_CLIENT_DATA - | CLIENT_CONNECT_WITH_DB - | CLIENT_DEPRECATE_EOF), character_set(63), status_flags(0) + explicit Handshake(uint32_t connection_id, String server_version, String auth_plugin_data) + : protocol_version(0xa) + , server_version(std::move(server_version)) + , connection_id(connection_id) + , capability_flags(CLIENT_PROTOCOL_41 | CLIENT_SECURE_CONNECTION | CLIENT_PLUGIN_AUTH | CLIENT_PLUGIN_AUTH_LENENC_CLIENT_DATA + | CLIENT_CONNECT_WITH_DB | CLIENT_DEPRECATE_EOF) + , character_set(CharacterSet::utf8_general_ci) + , status_flags(0) + , auth_plugin_data(auth_plugin_data) { - auth_plugin_data.resize(SCRAMBLE_LENGTH); } String getPayload() const override @@ -276,11 +277,10 @@ public: result.append(reinterpret_cast(&character_set), 1); result.append(reinterpret_cast(&status_flags), 2); result.append((reinterpret_cast(&capability_flags)) + 2, 2); - result.append(1, SCRAMBLE_LENGTH + 1); - result.append(1, 0x0); + result.append(1, auth_plugin_data.size()); result.append(10, 0x0); - result.append(auth_plugin_data.substr(AUTH_PLUGIN_DATA_PART_1_LENGTH, SCRAMBLE_LENGTH - AUTH_PLUGIN_DATA_PART_1_LENGTH)); - result.append(Authentication::ClearText); + result.append(auth_plugin_data.substr(AUTH_PLUGIN_DATA_PART_1_LENGTH, auth_plugin_data.size() - AUTH_PLUGIN_DATA_PART_1_LENGTH)); + result.append(Authentication::CachingSHA2); result.append(1, 0x0); return result; } @@ -358,6 +358,32 @@ public: } }; +class AuthSwitchResponse : public ReadPacket +{ +public: + String value; + + void readPayload(String s) override + { + value = std::move(s); + } +}; + +class AuthMoreData : public WritePacket +{ + String data; +public: + AuthMoreData(String data): data(std::move(data)) {} + + String getPayload() const override + { + String result; + result.append(1, 0x01); + result.append(data); + return result; + } +}; + /// Packet with a single null-terminated string. Is used for clear text authentication. class NullTerminatedString : public ReadPacket { diff --git a/dbms/tests/integration/helpers/cluster.py b/dbms/tests/integration/helpers/cluster.py index 240cc2c8695..3758c157d50 100644 --- a/dbms/tests/integration/helpers/cluster.py +++ b/dbms/tests/integration/helpers/cluster.py @@ -316,6 +316,8 @@ class ClickHouseCluster: subprocess_check_call(self.base_mongo_cmd + ['up', '-d', '--force-recreate']) self.wait_mongo_to_start(30) + import pdb + pdb.set_trace() subprocess_check_call(self.base_cmd + ['up', '-d', '--no-recreate']) start_deadline = time.time() + 20.0 # seconds diff --git a/dbms/tests/integration/test_mysql_protocol/clients/golang/main.go b/dbms/tests/integration/test_mysql_protocol/clients/golang/main.go index 70508334afb..7a09af14a31 100644 --- a/dbms/tests/integration/test_mysql_protocol/clients/golang/main.go +++ b/dbms/tests/integration/test_mysql_protocol/clients/golang/main.go @@ -18,7 +18,7 @@ func main() { flag.Parse() logger := log.New(os.Stderr, "", 0) - dataSource := fmt.Sprintf("%s:%s@tcp(%s:%d)/%s?allowCleartextPasswords=1", *user, *password, *host, *port, *database) + dataSource := fmt.Sprintf("%s:%s@tcp(%s:%d)/%s", *user, *password, *host, *port, *database) db, err := sql.Open("mysql", dataSource) if err != nil { @@ -50,11 +50,6 @@ func main() { logger.Fatal(err) } - err = rows.Err() - if err != nil { - logger.Fatal(err) - } - err = rows.Close() if err != nil { logger.Fatal(err) @@ -74,7 +69,7 @@ func main() { } fmt.Println(x) } - return nil + return rows.Err() } runQuery("select number as a from system.numbers limit 2", processRows) @@ -88,7 +83,7 @@ func main() { } fmt.Println(name, a) } - return nil + return rows.Err() } runQuery("select name, 1 as a from system.tables where name == 'tables'", processRows) diff --git a/dbms/tests/integration/test_mysql_protocol/test.py b/dbms/tests/integration/test_mysql_protocol/test.py index 1720fbdf786..dd2d7453a35 100644 --- a/dbms/tests/integration/test_mysql_protocol/test.py +++ b/dbms/tests/integration/test_mysql_protocol/test.py @@ -45,22 +45,24 @@ def golang_container(): def test_mysql_client(mysql_client, server_address): # type: (Container, str) -> None code, (stdout, stderr) = mysql_client.exec_run(''' - mysql --protocol tcp -h {host} -P {port} default -u default --enable-cleartext-plugin --password=123 + mysql --protocol tcp -h {host} -P {port} default -u default --password=123 -e "select 1 as a;" -e "select 'тест' as b;" '''.format(host=server_address, port=server_port), demux=True) + import pdb + pdb.set_trace() assert stdout == 'a\n1\nb\nтест\n' code, (stdout, stderr) = mysql_client.exec_run(''' - mysql --protocol tcp -h {host} -P {port} default -u default --enable-cleartext-plugin --password=abc -e "select 1 as a;" + mysql --protocol tcp -h {host} -P {port} default -u default --password=abc -e "select 1 as a;" '''.format(host=server_address, port=server_port), demux=True) assert stderr == 'mysql: [Warning] Using a password on the command line interface can be insecure.\n' \ 'ERROR 193 (00000): Wrong password for user default\n' code, (stdout, stderr) = mysql_client.exec_run(''' - mysql --protocol tcp -h {host} -P {port} default -u default --enable-cleartext-plugin --password=123 + mysql --protocol tcp -h {host} -P {port} default -u default --password=123 -e "use system;" -e "select count(*) from (select name from tables limit 1);" -e "use system2;" From 9fff48e01f09062243a26b9ff3cb6d903fb51a87 Mon Sep 17 00:00:00 2001 From: Yuriy Date: Mon, 22 Apr 2019 14:00:57 +0300 Subject: [PATCH 063/709] removed accidentally committed debug lines --- dbms/tests/integration/helpers/cluster.py | 2 -- 1 file changed, 2 deletions(-) diff --git a/dbms/tests/integration/helpers/cluster.py b/dbms/tests/integration/helpers/cluster.py index 3758c157d50..240cc2c8695 100644 --- a/dbms/tests/integration/helpers/cluster.py +++ b/dbms/tests/integration/helpers/cluster.py @@ -316,8 +316,6 @@ class ClickHouseCluster: subprocess_check_call(self.base_mongo_cmd + ['up', '-d', '--force-recreate']) self.wait_mongo_to_start(30) - import pdb - pdb.set_trace() subprocess_check_call(self.base_cmd + ['up', '-d', '--no-recreate']) start_deadline = time.time() + 20.0 # seconds From 80cc6de2d057524bfce778ab57787f4bc3fecab6 Mon Sep 17 00:00:00 2001 From: alexey-milovidov Date: Wed, 24 Apr 2019 01:59:17 +0300 Subject: [PATCH 064/709] Update CMakeLists.txt --- CMakeLists.txt | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/CMakeLists.txt b/CMakeLists.txt index 01506b6d9fc..5376314641e 100644 --- a/CMakeLists.txt +++ b/CMakeLists.txt @@ -250,7 +250,7 @@ if (USE_INCLUDE_WHAT_YOU_USE) endif() endif () -#Check if gperf was installed +# Check if gperf was installed option (USE_GPERF "Use gperf function hash generator tool" ON) if (USE_GPERF) find_program(GPERF gperf) From 05f615c171a0d4a834ed8174b4ca0e66b5e3d835 Mon Sep 17 00:00:00 2001 From: BayoNet Date: Wed, 24 Apr 2019 10:39:53 +0300 Subject: [PATCH 065/709] DOCAPI-3822: ZooKeeper settings. Oracle ODBC issue. --- docs/en/faq/general.md | 9 ++++ .../en/operations/server_settings/settings.md | 47 ++++++++++++++----- .../dicts/external_dicts_dict_sources.md | 2 + 3 files changed, 45 insertions(+), 13 deletions(-) diff --git a/docs/en/faq/general.md b/docs/en/faq/general.md index f5b9d29b5bd..49af0e55588 100644 --- a/docs/en/faq/general.md +++ b/docs/en/faq/general.md @@ -11,5 +11,14 @@ Distributed sorting is one of the main causes of reduced performance when runnin Most MapReduce implementations allow you to execute arbitrary code on a cluster. But a declarative query language is better suited to OLAP in order to run experiments quickly. For example, Hadoop has Hive and Pig. Also consider Cloudera Impala or Shark (outdated) for Spark, as well as Spark SQL, Presto, and Apache Drill. Performance when running such tasks is highly sub-optimal compared to specialized systems, but relatively high latency makes it unrealistic to use these systems as the backend for a web interface. +## What to do if I have a problem with encodings when using Oracle through ODBC? {#oracle-odbc-encodings} + +If you use Oracle through ODBC driver as a source of external dictionaries, you need to set up correctly value for the `NLS_LANG` variable in the `/etc/default/clickhouse`. For more details see the [Oracle NLS_LANG FAQ](https://www.oracle.com/technetwork/products/globalization/nls-lang-099431.html). + +**Example** + +``` +NLS_LANG=RUSSIAN_RUSSIA.UTF8 +``` [Original article](https://clickhouse.yandex/docs/en/faq/general/) diff --git a/docs/en/operations/server_settings/settings.md b/docs/en/operations/server_settings/settings.md index 52503478205..d73c7205293 100644 --- a/docs/en/operations/server_settings/settings.md +++ b/docs/en/operations/server_settings/settings.md @@ -537,7 +537,7 @@ Queries are logged in the [system.query_log](../system_tables.md#system_tables-q Use the following parameters to configure logging: - `database` – Name of the database. -- `table` – Name of the system table the queries will be logged in. +- `table` – Name of the system table the queries will be logged in. - `partition_by` – Sets a [custom partitioning key](../../operations/table_engines/custom_partitioning_key.md) for a system table. - `flush_interval_milliseconds` – Interval for flushing data from the buffer in memory to the table. @@ -664,35 +664,56 @@ Path to the file that contains: ``` -## zookeeper +## zookeeper {#server-settings_zookeeper} -Configuration of ZooKeeper servers. +Contains settings that allow ClickHouse to interact with [ZooKeeper](http://zookeeper.apache.org/) cluster. -ClickHouse uses ZooKeeper for storing replica metadata when using replicated tables. +ClickHouse uses ZooKeeper for storing replicas' metadata when using replicated tables. If replicated tables are not used, this parameter section can be omitted. -This parameter can be omitted if replicated tables are not used. +This parameter section contains the following parameters: -For more information, see the section "[Replication](../../operations/table_engines/replication.md)". +- `node` — ZooKeeper endpoint. You can set a few endpoints. -**Example** + For example: + + ```xml + + example_host + 2181 + + ``` + + The `index` attribute specify an order of node, when trying to connect to ZooKeeper cluster. + +- `session_timeout` — Maximum timeout for client session in milliseconds. +- `root` — ZNode, that is used as root for znodes used by ClickHouse server. Optional. +- `identity` — User and password, required by ZooKeeper to give access to requested znodes. Optional. + +**Example configuration** ```xml - + example1 2181 - + example2 2181 - - example3 - 2181 - + 30000 + + /path/to/zookeeper/node + + user:password ``` +**See Also** + +- [Replication](../../operations/table_engines/replication.md) +- [ZooKeeper Programmer's Guide](http://zookeeper.apache.org/doc/r3.3.4/zookeeperProgrammers.html) + ## use_minimalistic_part_header_in_zookeeper {#server-settings-use_minimalistic_part_header_in_zookeeper} Storage method for data part headers in ZooKeeper. diff --git a/docs/en/query_language/dicts/external_dicts_dict_sources.md b/docs/en/query_language/dicts/external_dicts_dict_sources.md index 8fb2145ecaf..646097d26eb 100644 --- a/docs/en/query_language/dicts/external_dicts_dict_sources.md +++ b/docs/en/query_language/dicts/external_dicts_dict_sources.md @@ -120,6 +120,8 @@ Setting fields: ClickHouse receives quoting symbols from ODBC-driver and quote all settings in queries to driver, so it's necessary to set table name accordingly to table name case in database. +If you have a problems with encodings when using Oracle, see the corresponding [FAQ](../../faq/general.md#oracle-odbc-encodings) article. + ### Known vulnerability of the ODBC dictionary functionality !!! attention From 281fde84149edea6572c64154a3202af89c34259 Mon Sep 17 00:00:00 2001 From: BayoNet Date: Wed, 24 Apr 2019 11:30:08 +0300 Subject: [PATCH 066/709] DOCAPI-3822: Added faq article into the chinese version. --- docs/zh/faq/general.md | 10 ++++++++++ 1 file changed, 10 insertions(+) diff --git a/docs/zh/faq/general.md b/docs/zh/faq/general.md index 9a1aef5dde6..1f0121133f7 100644 --- a/docs/zh/faq/general.md +++ b/docs/zh/faq/general.md @@ -9,4 +9,14 @@ 大多数MapReduce系统允许您在集群上执行任意代码。但是,声明性查询语言更适合OLAP,以便快速运行实验。例如,Hadoop包含Hive和Pig,Cloudera Impala或Shark(过时)for Spark,以及Spark SQL、Presto和Apache Drill。与专业系统相比,运行此类任务时的性能非常不理想,所以将这些系统用作Web接口的后端服务是不现实的,因为延迟相对较高。 +## What to do if I have a problem with encodings when using Oracle through ODBC? {#oracle-odbc-encodings} + +If you use Oracle through ODBC driver as a source of external dictionaries, you need to set up correctly value for the `NLS_LANG` variable in the `/etc/default/clickhouse`. For more details see the [Oracle NLS_LANG FAQ](https://www.oracle.com/technetwork/products/globalization/nls-lang-099431.html). + +**Example** + +``` +NLS_LANG=RUSSIAN_RUSSIA.UTF8 +``` + [来源文章](https://clickhouse.yandex/docs/zh/faq/general/) From 2640a0716cc0b0090cf06b5bca16b4242e93dcd7 Mon Sep 17 00:00:00 2001 From: Guillaume Tassery Date: Wed, 24 Apr 2019 17:09:46 +0700 Subject: [PATCH 067/709] Add some pragma for ignoring some compilation flags for file generated by gperf --- dbms/src/Functions/gperf/tldLookup.gperf | 7 ++++++- 1 file changed, 6 insertions(+), 1 deletion(-) diff --git a/dbms/src/Functions/gperf/tldLookup.gperf b/dbms/src/Functions/gperf/tldLookup.gperf index 9816a4f86e2..fc14d7574bf 100644 --- a/dbms/src/Functions/gperf/tldLookup.gperf +++ b/dbms/src/Functions/gperf/tldLookup.gperf @@ -4,7 +4,12 @@ %readonly-tables %includes %compare-strncmp - +%{ +#pragma GCC diagnostic push +#pragma GCC diagnostic ignored "-Wimplicit-fallthrough" +#pragma GCC diagnostic ignored "-Wzero-as-null-pointer-constant" +#pragma GCC diagnostic ignored "-Wunused-macros" +%} # List generated using https://publicsuffix.org/list/public_suffix_list.dat %% com.ac From a2bf29a2b184b61919172aa60826d5bc5fb7225a Mon Sep 17 00:00:00 2001 From: ogorbacheva Date: Wed, 24 Apr 2019 17:35:52 +0300 Subject: [PATCH 068/709] Edit higher order --- .../functions/higher_order_functions.md | 75 ++++++++++------- .../functions/higher_order_functions.md | 81 ++++++++++++------- 2 files changed, 96 insertions(+), 60 deletions(-) diff --git a/docs/en/query_language/functions/higher_order_functions.md b/docs/en/query_language/functions/higher_order_functions.md index ca8612ddab5..fc88c21a06a 100644 --- a/docs/en/query_language/functions/higher_order_functions.md +++ b/docs/en/query_language/functions/higher_order_functions.md @@ -10,15 +10,40 @@ Higher-order functions can only accept lambda functions as their functional argu A lambda function that accepts multiple arguments can be passed to a higher-order function. In this case, the higher-order function is passed several arrays of identical length that these arguments will correspond to. -For all functions other than 'arrayMap' and 'arrayFilter', the first argument (the lambda function) can be omitted. In this case, identical mapping is assumed. +For some functions, such as [arrayCount](#higher_order_functions-array-count) or [arraySum](#higher_order_functions-array-count), the first argument (the lambda function) can be omitted. In this case, identical mapping is assumed. -### arrayMap(func, arr1, ...) +A lamdba function can't be omitted for the following functions: -Returns an array obtained from the original application of the 'func' function to each element in the 'arr' array. +- [arrayMap](#higher_order_functions-array-count) +- [arrayFilter](#higher_order_functions-array-filter) +- [arrayFirst](#higher_order_functions-array-first) +- [arrayFirstIndex](#higher_order_functions-array-first-index) -### arrayFilter(func, arr1, ...) +### arrayMap(func, arr1, ...) {#higher_order_functions-array-map} -Returns an array containing only the elements in 'arr1' for which 'func' returns something other than 0. +Returns an array obtained from the original application of the 'func' function to each element in the 'arr' array. + +Examples: + +``` sql +SELECT arrayMap(x -> (x + 2), [1, 2, 3]) as res; + +┌─res─────┐ +│ [3,4,5] │ +└─────────┘ +``` +The following example shows how to create a tuple of elements from different arrays: + +``` sql +SELECT arrayMap((x, y) -> (x, y), [1, 2, 3], [4, 5, 6]) AS res + +┌─res─────────────────┐ +│ [(1,4),(2,5),(3,6)] │ +└─────────────────────┘ +``` +### arrayFilter(func, arr1, ...) {#higher_order_functions-array-filter} + +Returns an array containing only the elements in `arr1` for which `func` returns something other than 0. Examples: @@ -47,7 +72,7 @@ SELECT └─────┘ ``` -### arrayCount(\[func,\] arr1, ...) +### arrayCount(\[func,\] arr1, ...) {#higher_order_functions-array-count} Returns the number of elements in the arr array for which func returns something other than 0. If 'func' is not specified, it returns the number of non-zero elements in the array. @@ -59,15 +84,15 @@ Returns 1 if there is at least one element in 'arr' for which 'func' returns som Returns 1 if 'func' returns something other than 0 for all the elements in 'arr'. Otherwise, it returns 0. -### arraySum(\[func,\] arr1, ...) +### arraySum(\[func,\] arr1, ...) {#higher_order_functions-array-sum} Returns the sum of the 'func' values. If the function is omitted, it just returns the sum of the array elements. -### arrayFirst(func, arr1, ...) +### arrayFirst(func, arr1, ...) {#higher_order_functions-array-first} Returns the first element in the 'arr1' array for which 'func' returns something other than 0. -### arrayFirstIndex(func, arr1, ...) +### arrayFirstIndex(func, arr1, ...) {#higher_order_functions-array-first-index} Returns the index of the first element in the 'arr1' array for which 'func' returns something other than 0. @@ -89,7 +114,7 @@ SELECT arrayCumSum([1, 1, 1, 1]) AS res ### arrayCumSumNonNegative(arr) -Same as arrayCumSum, returns an array of partial sums of elements in the source array (a running sum). Different arrayCumSum, when then returned value contains a value less than zero, the value is replace with zero and the subsequent calculation is performed with zero parameters. For example: +Same as `arrayCumSum`, returns an array of partial sums of elements in the source array (a running sum). Different `arrayCumSum`, when then returned value contains a value less than zero, the value is replace with zero and the subsequent calculation is performed with zero parameters. For example: ``` sql SELECT arrayCumSumNonNegative([1, 1, -4, 1]) AS res @@ -119,33 +144,23 @@ SELECT arraySort((x, y) -> y, ['hello', 'world'], [2, 1]); └────────────────────┘ ``` -Note that NULLs and NaNs go last (NaNs go before NULLs). For example: - -``` sql -SELECT arraySort([1, nan, 2, NULL, 3, nan, 4, NULL]) -``` -``` -┌─arraySort([1, nan, 2, NULL, 3, nan, 4, NULL])─┐ -│ [1,2,3,4,nan,nan,NULL,NULL] │ -└───────────────────────────────────────────────┘ -``` +For more information about the `arraySort` method, see the [Functions for Working With Arrays](array_functions.md#array_functions-sort) section. ### arrayReverseSort(\[func,\] arr1, ...) -Returns an array as result of sorting the elements of `arr1` in descending order. If the `func` function is specified, sorting order is determined by the result of the function `func` applied to the elements of array (arrays) +Returns an array as result of sorting the elements of `arr1` in descending order. If the `func` function is specified, sorting order is determined by the result of the function `func` applied to the elements of array (arrays). + +Example: -Note that NULLs and NaNs go last (NaNs go before NULLs). For example: - ``` sql -SELECT arrayReverseSort([1, nan, 2, NULL, 3, nan, 4, NULL]) +SELECT arrayReverseSort((x, y) -> y, ['hello', 'world'], [2, 1]) as res; ``` -``` -┌─arrayReverseSort([1, nan, 2, NULL, 3, nan, 4, NULL])─┐ -│ [4,3,2,1,nan,nan,NULL,NULL] │ -└──────────────────────────────────────────────────────┘ +``` sql +┌─res───────────────┐ +│ ['hello','world'] │ +└───────────────────┘ ``` - - +For more information about the `arrayReverseSort` method, see the [Functions for Working With Arrays](array_functions.md#array_functions-reverse-sort) section. [Original article](https://clickhouse.yandex/docs/en/query_language/functions/higher_order_functions/) diff --git a/docs/ru/query_language/functions/higher_order_functions.md b/docs/ru/query_language/functions/higher_order_functions.md index f5586cda6ab..7ca53212ee5 100644 --- a/docs/ru/query_language/functions/higher_order_functions.md +++ b/docs/ru/query_language/functions/higher_order_functions.md @@ -10,13 +10,42 @@ В функции высшего порядка может быть передана лямбда-функция, принимающая несколько аргументов. В этом случае, в функцию высшего порядка передаётся несколько массивов одинаковых длин, которым эти аргументы будут соответствовать. -Для всех функций кроме arrayMap, arrayFilter, первый аргумент (лямбда-функция) может отсутствовать. В этом случае, подразумевается тождественное отображение. +Для некоторых функций, например [arrayCount](#higher_order_functions-array-count) или [arraySum](#higher_order_functions-array-count), первый аргумент (лямбда-функция) может отсутствовать. В этом случае, подразумевается тождественное отображение. -### arrayMap(func, arr1, ...) -Вернуть массив, полученный из исходного применением функции func к каждому элементу массива arr. +Для функций, перечисленных ниже, лямбда-функцию должна быть указана всегда: -### arrayFilter(func, arr1, ...) -Вернуть массив, содержащий только те элементы массива arr1, для которых функция func возвращает не 0. +- [arrayMap](#higher_order_functions-array-count) +- [arrayFilter](#higher_order_functions-array-filter) +- [arrayFirst](#higher_order_functions-array-first) +- [arrayFirstIndex](#higher_order_functions-array-first-index) + +### arrayMap(func, arr1, ...) {#higher_order_functions-array-count} + +Вернуть массив, полученный на основе результатов применения функции `func` к каждому элементу массива `arr`. + +Примеры: + +``` sql +SELECT arrayMap(x -> (x + 2), [1, 2, 3]) as res; + +┌─res─────┐ +│ [3,4,5] │ +└─────────┘ +``` + +Следующий пример показывает, как создать кортежи из элементов разных массивов: + +``` sql +SELECT arrayMap((x, y) -> (x, y), [1, 2, 3], [4, 5, 6]) AS res + +┌─res─────────────────┐ +│ [(1,4),(2,5),(3,6)] │ +└─────────────────────┘ +``` + +### arrayFilter(func, arr1, ...) {#higher_order_functions-array-filter} + +Вернуть массив, содержащий только те элементы массива `arr1`, для которых функция `func` возвращает не 0. Примеры: @@ -46,23 +75,23 @@ SELECT ``` ### arrayCount(\[func,\] arr1, ...) -Вернуть количество элементов массива arr, для которых функция func возвращает не 0. Если func не указана - вернуть количество ненулевых элементов массива. +Вернуть количество элементов массива `arr`, для которых функция func возвращает не 0. Если func не указана - вернуть количество ненулевых элементов массива. ### arrayExists(\[func,\] arr1, ...) -Вернуть 1, если существует хотя бы один элемент массива arr, для которого функция func возвращает не 0. Иначе вернуть 0. +Вернуть 1, если существует хотя бы один элемент массива `arr`, для которого функция func возвращает не 0. Иначе вернуть 0. ### arrayAll(\[func,\] arr1, ...) -Вернуть 1, если для всех элементов массива arr, функция func возвращает не 0. Иначе вернуть 0. +Вернуть 1, если для всех элементов массива `arr`, функция `func` возвращает не 0. Иначе вернуть 0. ### arraySum(\[func,\] arr1, ...) -Вернуть сумму значений функции func. Если функция не указана - просто вернуть сумму элементов массива. +Вернуть сумму значений функции `func`. Если функция не указана - просто вернуть сумму элементов массива. -### arrayFirst(func, arr1, ...) -Вернуть первый элемент массива arr1, для которого функция func возвращает не 0. +### arrayFirst(func, arr1, ...) {#higher_order_functions-array-first} +Вернуть первый элемент массива `arr1`, для которого функция func возвращает не 0. -### arrayFirstIndex(func, arr1, ...) +### arrayFirstIndex(func, arr1, ...) {#higher_order_functions-array-first-index} -Вернуть индекс первого элемента массива arr1, для которого функция func возвращает не 0. +Вернуть индекс первого элемента массива `arr1`, для которого функция func возвращает не 0. ### arrayCumSum(\[func,\] arr1, ...) @@ -99,31 +128,23 @@ SELECT arraySort((x, y) -> y, ['hello', 'world'], [2, 1]); └────────────────────┘ ``` -`NULL` и `NaN` будут последними в массиве (при этом `NaN` будет перед `NULL`). Например: - -``` sql -SELECT arraySort([1, nan, 2, NULL, 3, nan, 4, NULL]) -``` -``` -┌─arraySort([1, nan, 2, NULL, 3, nan, 4, NULL])─┐ -│ [1,2,3,4,nan,nan,NULL,NULL] │ -└───────────────────────────────────────────────┘ -``` +Подробная информация о методе `arraySort` приведена в разделе [Функции по работе с массивами](array_functions.md#array_functions-sort). ### arrayReverseSort(\[func,\] arr1, ...) Возвращает отсортированный в нисходящем порядке массив `arr1`. Если задана функция `func`, то порядок сортировки определяется результатом применения функции `func` на элементы массива (массивов). -`NULL` и `NaN` будут последними в массиве (при этом `NaN` будет перед `NULL`). Например: - +Пример: + ``` sql -SELECT arrayReverseSort([1, nan, 2, NULL, 3, nan, 4, NULL]) +SELECT arrayReverseSort((x, y) -> y, ['hello', 'world'], [2, 1]) as res; ``` -``` -┌─arrayReverseSort([1, nan, 2, NULL, 3, nan, 4, NULL])─┐ -│ [4,3,2,1,nan,nan,NULL,NULL] │ -└──────────────────────────────────────────────────────┘ +``` sql +┌─res───────────────┐ +│ ['hello','world'] │ +└───────────────────┘ ``` +Подробная информация о методе `arrayReverseSort` приведена в разделе [Функции по работе с массивами](array_functions.md#array_functions-reverse-sort). [Оригинальная статья](https://clickhouse.yandex/docs/ru/query_language/functions/higher_order_functions/) From ced71ac9fd420b5f3a51f5441d5c01d39fe2c5e1 Mon Sep 17 00:00:00 2001 From: Guillaume Tassery Date: Thu, 25 Apr 2019 18:25:49 +0700 Subject: [PATCH 069/709] Send how many rows and bytes were written during the query --- .../DataStreams/CountingBlockOutputStream.h | 2 +- dbms/src/IO/Progress.cpp | 20 +++++++-- dbms/src/IO/Progress.h | 44 +++++++++++++++++-- .../IO/WriteBufferFromHTTPServerResponse.cpp | 6 ++- .../IO/WriteBufferFromHTTPServerResponse.h | 1 + dbms/src/Interpreters/executeQuery.cpp | 7 ++- ...0416_pocopatch_progress_in_http_headers.sh | 14 ++++++ 7 files changed, 84 insertions(+), 10 deletions(-) diff --git a/dbms/src/DataStreams/CountingBlockOutputStream.h b/dbms/src/DataStreams/CountingBlockOutputStream.h index 5c36c40c1ad..edcdee51948 100644 --- a/dbms/src/DataStreams/CountingBlockOutputStream.h +++ b/dbms/src/DataStreams/CountingBlockOutputStream.h @@ -39,7 +39,7 @@ public: void onProgress(const Progress & current_progress) override { stream->onProgress(current_progress); } String getContentType() const override { return stream->getContentType(); } -protected: +public: BlockOutputStreamPtr stream; Progress progress; ProgressCallback progress_callback; diff --git a/dbms/src/IO/Progress.cpp b/dbms/src/IO/Progress.cpp index 5788f817d36..5419a106fb0 100644 --- a/dbms/src/IO/Progress.cpp +++ b/dbms/src/IO/Progress.cpp @@ -14,15 +14,21 @@ void ProgressValues::read(ReadBuffer & in, UInt64 /*server_revision*/) size_t new_rows = 0; size_t new_bytes = 0; size_t new_total_rows = 0; - + size_t new_write_rows = 0; + size_t new_write_bytes = 0; + readVarUInt(new_rows, in); readVarUInt(new_bytes, in); readVarUInt(new_total_rows, in); - + readVarUInt(new_write_rows, in); + readVarUInt(new_write_bytes, in); + rows = new_rows; bytes = new_bytes; total_rows = new_total_rows; -} + write_rows = new_write_rows; + write_bytes = new_write_bytes; +} void ProgressValues::write(WriteBuffer & out, UInt64 /*client_revision*/) const @@ -30,6 +36,8 @@ void ProgressValues::write(WriteBuffer & out, UInt64 /*client_revision*/) const writeVarUInt(rows, out); writeVarUInt(bytes, out); writeVarUInt(total_rows, out); + writeVarUInt(write_rows, out); + writeVarUInt(write_bytes, out); } @@ -42,6 +50,10 @@ void ProgressValues::writeJSON(WriteBuffer & out) const writeText(rows, out); writeCString("\",\"read_bytes\":\"", out); writeText(bytes, out); + writeCString("\",\"write_rows\":\"", out); + writeText(write_rows, out); + writeCString("\",\"write_bytes\":\"", out); + writeText(write_bytes, out); writeCString("\",\"total_rows\":\"", out); writeText(total_rows, out); writeCString("\"}", out); @@ -56,6 +68,8 @@ void Progress::read(ReadBuffer & in, UInt64 server_revision) rows.store(values.rows, std::memory_order_relaxed); bytes.store(values.bytes, std::memory_order_relaxed); total_rows.store(values.total_rows, std::memory_order_relaxed); + write_rows.store(values.write_rows, std::memory_order_relaxed); + write_bytes.store(values.write_bytes, std::memory_order_relaxed); } diff --git a/dbms/src/IO/Progress.h b/dbms/src/IO/Progress.h index d7366d187aa..a88ee43bdab 100644 --- a/dbms/src/IO/Progress.h +++ b/dbms/src/IO/Progress.h @@ -20,12 +20,32 @@ struct ProgressValues size_t rows; size_t bytes; size_t total_rows; + size_t write_rows; + size_t write_bytes; void read(ReadBuffer & in, UInt64 server_revision); void write(WriteBuffer & out, UInt64 client_revision) const; void writeJSON(WriteBuffer & out) const; }; +struct ReadProgress +{ + size_t rows; + size_t bytes; + size_t total_rows; + + ReadProgress(size_t rows_, size_t bytes_, size_t total_rows_ = 0) + : rows(rows_), bytes(bytes_), total_rows(total_rows_) {} +}; + +struct WriteProgress +{ + size_t write_rows; + size_t write_bytes; + + WriteProgress(size_t write_rows_, size_t write_bytes_) + : write_rows(write_rows_), write_bytes(write_bytes_) {} +}; /** Progress of query execution. * Values, transferred over network are deltas - how much was done after previously sent value. @@ -42,9 +62,17 @@ struct Progress */ std::atomic total_rows {0}; + + std::atomic write_rows {0}; + std::atomic write_bytes {0}; + Progress() {} Progress(size_t rows_, size_t bytes_, size_t total_rows_ = 0) : rows(rows_), bytes(bytes_), total_rows(total_rows_) {} + Progress(ReadProgress read_progress) + : rows(read_progress.rows), bytes(read_progress.bytes), total_rows(read_progress.total_rows) {} + Progress(WriteProgress write_progress) + : write_rows(write_progress.write_rows), write_bytes(write_progress.write_bytes) {} void read(ReadBuffer & in, UInt64 server_revision); void write(WriteBuffer & out, UInt64 client_revision) const; @@ -58,8 +86,10 @@ struct Progress rows += rhs.rows; bytes += rhs.bytes; total_rows += rhs.total_rows; + write_rows += rhs.write_rows; + write_bytes += rhs.write_bytes; - return rhs.rows ? true : false; + return rhs.rows || rhs.write_rows ? true : false; } void reset() @@ -67,6 +97,8 @@ struct Progress rows = 0; bytes = 0; total_rows = 0; + write_rows = 0; + write_bytes = 0; } ProgressValues getValues() const @@ -76,6 +108,8 @@ struct Progress res.rows = rows.load(std::memory_order_relaxed); res.bytes = bytes.load(std::memory_order_relaxed); res.total_rows = total_rows.load(std::memory_order_relaxed); + res.write_rows = write_rows.load(std::memory_order_relaxed); + res.write_bytes = write_bytes.load(std::memory_order_relaxed); return res; } @@ -87,7 +121,9 @@ struct Progress res.rows = rows.fetch_and(0); res.bytes = bytes.fetch_and(0); res.total_rows = total_rows.fetch_and(0); - + res.write_rows = write_rows.fetch_and(0); + res.write_bytes = write_bytes.fetch_and(0); + return res; } @@ -96,7 +132,9 @@ struct Progress rows = other.rows.load(std::memory_order_relaxed); bytes = other.bytes.load(std::memory_order_relaxed); total_rows = other.total_rows.load(std::memory_order_relaxed); - + write_rows = other.write_rows.load(std::memory_order_relaxed); + write_bytes = other.write_bytes.load(std::memory_order_relaxed); + return *this; } diff --git a/dbms/src/IO/WriteBufferFromHTTPServerResponse.cpp b/dbms/src/IO/WriteBufferFromHTTPServerResponse.cpp index 707ba8db1c2..2da5bc89726 100644 --- a/dbms/src/IO/WriteBufferFromHTTPServerResponse.cpp +++ b/dbms/src/IO/WriteBufferFromHTTPServerResponse.cpp @@ -41,6 +41,7 @@ void WriteBufferFromHTTPServerResponse::writeHeaderProgress() if (headers_finished_sending) return; + had_update = false; WriteBufferFromOwnString progress_string_writer; accumulated_progress.writeJSON(progress_string_writer); @@ -53,7 +54,8 @@ void WriteBufferFromHTTPServerResponse::finishSendHeaders() { if (!headers_finished_sending) { - writeHeaderProgress(); + if (had_update) + writeHeaderProgress(); headers_finished_sending = true; if (request.getMethod() != Poco::Net::HTTPRequest::HTTP_HEAD) @@ -179,7 +181,7 @@ void WriteBufferFromHTTPServerResponse::onProgress(const Progress & progress) if (headers_finished_sending) return; - accumulated_progress.incrementPiecewiseAtomically(progress); + had_update = accumulated_progress.incrementPiecewiseAtomically(progress); if (progress_watch.elapsed() >= send_progress_interval_ms * 1000000) { diff --git a/dbms/src/IO/WriteBufferFromHTTPServerResponse.h b/dbms/src/IO/WriteBufferFromHTTPServerResponse.h index 447a376dda7..56fc07f2859 100644 --- a/dbms/src/IO/WriteBufferFromHTTPServerResponse.h +++ b/dbms/src/IO/WriteBufferFromHTTPServerResponse.h @@ -67,6 +67,7 @@ private: bool headers_started_sending = false; bool headers_finished_sending = false; /// If true, you could not add any headers. + bool had_update = false; Progress accumulated_progress; size_t send_progress_interval_ms = 100; diff --git a/dbms/src/Interpreters/executeQuery.cpp b/dbms/src/Interpreters/executeQuery.cpp index 93f6415d054..e77519c8e54 100644 --- a/dbms/src/Interpreters/executeQuery.cpp +++ b/dbms/src/Interpreters/executeQuery.cpp @@ -316,6 +316,11 @@ static std::tuple executeQueryImpl( elem.written_rows = info.written_rows; elem.written_bytes = info.written_bytes; + auto progress_callback = context.getProgressCallback(); + + if (progress_callback) + progress_callback(Progress(WriteProgress(info.written_rows, info.written_bytes))); + elem.memory_usage = info.peak_memory_usage > 0 ? info.peak_memory_usage : 0; if (stream_in) @@ -328,7 +333,7 @@ static std::tuple executeQueryImpl( } else if (stream_out) /// will be used only for ordinary INSERT queries { - if (auto counting_stream = dynamic_cast(stream_out)) + if (auto counting_stream = dynamic_cast(stream_out)) { /// NOTE: Redundancy. The same values could be extracted from process_list_elem->progress_out.query_settings = process_list_elem->progress_in elem.result_rows = counting_stream->getProgress().rows; diff --git a/dbms/tests/queries/0_stateless/00416_pocopatch_progress_in_http_headers.sh b/dbms/tests/queries/0_stateless/00416_pocopatch_progress_in_http_headers.sh index 4b1ca06aacc..83f15cfb248 100755 --- a/dbms/tests/queries/0_stateless/00416_pocopatch_progress_in_http_headers.sh +++ b/dbms/tests/queries/0_stateless/00416_pocopatch_progress_in_http_headers.sh @@ -17,3 +17,17 @@ ${CLICKHOUSE_CURL} -vsS "${CLICKHOUSE_URL}?max_block_size=1&send_progress_in_htt # nothing in body = no gzip ${CLICKHOUSE_CURL} -vsS "${CLICKHOUSE_URL}?max_block_size=1&send_progress_in_http_headers=1&http_headers_progress_interval_ms=0&enable_http_compression=1" -H 'Accept-Encoding: gzip' -d 'SELECT number FROM system.numbers LIMIT 0' 2>&1 | grep -q 'Content-Encoding: gzip' && echo 'Fail' || true + + +# test insertion stats +${CLICKHOUSE_CURL} -vsS "${CLICKHOUSE_URL}" -H 'Accept-Encoding: gzip' -d 'DROP TABLE IF EXISTS insert_number_query' > /dev/null 2>&1 +${CLICKHOUSE_CURL} -vsS "${CLICKHOUSE_URL}" -H 'Accept-Encoding: gzip' -d 'DROP TABLE IF EXISTS insert_number_query_2' > /dev/null 2>&1 + +${CLICKHOUSE_CURL} -vsS "${CLICKHOUSE_URL}" -H 'Accept-Encoding: gzip' -d 'CREATE TABLE insert_number_query (record UInt32) Engine = Memory' > /dev/null 2>&1 +${CLICKHOUSE_CURL} -vsS "${CLICKHOUSE_URL}" -H 'Accept-Encoding: gzip' -d 'CREATE TABLE insert_number_query_2 (record UInt32) Engine = Memory' > /dev/null 2>&1 + +${CLICKHOUSE_CURL} -vsS "${CLICKHOUSE_URL}?max_block_size=1&http_headers_progress_interval_ms=0&send_progress_in_http_headers=1" -d 'INSERT INTO insert_number_query (record) SELECT number FROM system.numbers LIMIT 10' 2>&1 | grep -E 'Content-Encoding|X-ClickHouse-Progress|^[0-9]' + +${CLICKHOUSE_CURL} -vsS "${CLICKHOUSE_URL}" -H 'Accept-Encoding: gzip' -d 'DROP TABLE insert_number_query' > /dev/null 2>&1 +${CLICKHOUSE_CURL} -vsS "${CLICKHOUSE_URL}" -H 'Accept-Encoding: gzip' -d 'DROP TABLE insert_number_query2' > /dev/null 2>&1 + From 33201fa9a80dbd6f90a207bb1aa66d25fe110037 Mon Sep 17 00:00:00 2001 From: ivan-kush Date: Thu, 25 Apr 2019 21:57:43 +0300 Subject: [PATCH 070/709] rev --- dbms/src/Interpreters/Settings.h | 1 + dbms/src/Interpreters/SettingsCommon.h | 6 ++++++ dbms/src/Storages/StorageMergeTree.cpp | 10 ++++++---- dbms/src/Storages/StorageMergeTree.h | 2 +- 4 files changed, 14 insertions(+), 5 deletions(-) diff --git a/dbms/src/Interpreters/Settings.h b/dbms/src/Interpreters/Settings.h index 20e07d15916..3121389a6db 100644 --- a/dbms/src/Interpreters/Settings.h +++ b/dbms/src/Interpreters/Settings.h @@ -41,6 +41,7 @@ struct Settings M(SettingUInt64, min_insert_block_size_rows, DEFAULT_INSERT_BLOCK_SIZE, "Squash blocks passed to INSERT query to specified size in rows, if blocks are not big enough.") \ M(SettingUInt64, min_insert_block_size_bytes, (DEFAULT_INSERT_BLOCK_SIZE * 256), "Squash blocks passed to INSERT query to specified size in bytes, if blocks are not big enough.") \ M(SettingMaxThreads, max_threads, 0, "The maximum number of threads to execute the request. By default, it is determined automatically.") \ + M(SettingMaxAlterThreads, max_alter_threads, 0, "The maximum number of threads to execute the ALTER requests. By default, it is determined automatically.") \ M(SettingUInt64, max_read_buffer_size, DBMS_DEFAULT_BUFFER_SIZE, "The maximum size of the buffer to read from the filesystem.") \ M(SettingUInt64, max_distributed_connections, 1024, "The maximum number of connections for distributed processing of one query (should be greater than max_threads).") \ M(SettingUInt64, max_query_size, 262144, "Which part of the query can be read into RAM for parsing (the remaining data for INSERT, if any, is read later)") \ diff --git a/dbms/src/Interpreters/SettingsCommon.h b/dbms/src/Interpreters/SettingsCommon.h index ff2c0cd9339..abe6e052fbc 100644 --- a/dbms/src/Interpreters/SettingsCommon.h +++ b/dbms/src/Interpreters/SettingsCommon.h @@ -87,6 +87,12 @@ struct SettingMaxThreads UInt64 getAutoValueImpl() const; }; +struct SettingMaxAlterThreads: public SettingMaxThreads +{ + SettingMaxAlterThreads(UInt64 x = 0): + SettingMaxThreads(x) + {} +}; struct SettingSeconds { diff --git a/dbms/src/Storages/StorageMergeTree.cpp b/dbms/src/Storages/StorageMergeTree.cpp index a7a618873a8..620afcb0f91 100644 --- a/dbms/src/Storages/StorageMergeTree.cpp +++ b/dbms/src/Storages/StorageMergeTree.cpp @@ -194,15 +194,17 @@ void StorageMergeTree::rename(const String & new_path_to_db, const String & /*ne std::vector StorageMergeTree::prepare_alter_transactions( - const ColumnsDescription& new_columns, const IndicesDescription& new_indices, const size_t thread_pool_size) + const ColumnsDescription& new_columns, const IndicesDescription& new_indices, const Context & context) { - ThreadPool thread_pool(thread_pool_size); - auto parts = data.getDataParts({MergeTreeDataPartState::PreCommitted, MergeTreeDataPartState::Committed, MergeTreeDataPartState::Outdated}); std::vector transactions(parts.size()); const auto& columns_for_parts = new_columns.getAllPhysical(); + const Settings & settings = context.getSettingsRef(); + size_t thread_pool_size = std::min(parts.size(), settings.max_alter_threads); + ThreadPool thread_pool(thread_pool_size); + size_t i = 0; for (const auto & part : parts) { @@ -259,7 +261,7 @@ void StorageMergeTree::alter( ASTPtr new_primary_key_ast = data.primary_key_ast; params.apply(new_columns, new_indices, new_order_by_ast, new_primary_key_ast); - auto transactions = prepare_alter_transactions(new_columns, new_indices, 2 * getNumberOfPhysicalCPUCores()); + auto transactions = prepare_alter_transactions(new_columns, new_indices, context); auto table_hard_lock = lockStructureForAlter(context.getCurrentQueryId()); diff --git a/dbms/src/Storages/StorageMergeTree.h b/dbms/src/Storages/StorageMergeTree.h index 36b6cb9fc36..0f34c71213c 100644 --- a/dbms/src/Storages/StorageMergeTree.h +++ b/dbms/src/Storages/StorageMergeTree.h @@ -133,7 +133,7 @@ private: BackgroundProcessingPool::TaskHandle background_task_handle; std::vector prepare_alter_transactions( - const ColumnsDescription& new_columns, const IndicesDescription& new_indices, const size_t thread_pool_size); + const ColumnsDescription& new_columns, const IndicesDescription& new_indices, const Context & context); void loadMutations(); From ba61e16093d460050265bf3d3fbe2d5ed72d9d0f Mon Sep 17 00:00:00 2001 From: ivan-kush Date: Fri, 26 Apr 2019 00:37:57 +0300 Subject: [PATCH 071/709] style --- dbms/src/Storages/StorageMergeTree.cpp | 1 - dbms/src/Storages/StorageMergeTree.h | 2 +- 2 files changed, 1 insertion(+), 2 deletions(-) diff --git a/dbms/src/Storages/StorageMergeTree.cpp b/dbms/src/Storages/StorageMergeTree.cpp index b88ca230d67..8f610bc7bdb 100644 --- a/dbms/src/Storages/StorageMergeTree.cpp +++ b/dbms/src/Storages/StorageMergeTree.cpp @@ -4,7 +4,6 @@ #include #include #include -#include #include #include diff --git a/dbms/src/Storages/StorageMergeTree.h b/dbms/src/Storages/StorageMergeTree.h index 54b0c651135..65bf12b0e93 100644 --- a/dbms/src/Storages/StorageMergeTree.h +++ b/dbms/src/Storages/StorageMergeTree.h @@ -132,7 +132,7 @@ private: BackgroundProcessingPool::TaskHandle background_task_handle; std::vector prepareAlterTransactions( - const ColumnsDescription & new_columns, const IndicesDescription& new_indices, const Context & context); + const ColumnsDescription & new_columns, const IndicesDescription & new_indices, const Context & context); void loadMutations(); From 3707f26edf9739600b951682e9cb3acc73937a3e Mon Sep 17 00:00:00 2001 From: Guillaume Tassery Date: Fri, 26 Apr 2019 10:38:39 +0700 Subject: [PATCH 072/709] Write number of rows written in a summary instead of progress header --- dbms/src/IO/Progress.cpp | 98 ++++++++++++------- dbms/src/IO/Progress.h | 69 ++++++++++++- .../IO/WriteBufferFromHTTPServerResponse.cpp | 21 +++- .../IO/WriteBufferFromHTTPServerResponse.h | 3 +- 4 files changed, 143 insertions(+), 48 deletions(-) diff --git a/dbms/src/IO/Progress.cpp b/dbms/src/IO/Progress.cpp index 5419a106fb0..38c324ece34 100644 --- a/dbms/src/IO/Progress.cpp +++ b/dbms/src/IO/Progress.cpp @@ -8,8 +8,7 @@ namespace DB { - -void ProgressValues::read(ReadBuffer & in, UInt64 /*server_revision*/) +void AllProgressValueImpl::read(ProgressValues & value, ReadBuffer & in, UInt64 /*server_revision*/) { size_t new_rows = 0; size_t new_bytes = 0; @@ -23,65 +22,88 @@ void ProgressValues::read(ReadBuffer & in, UInt64 /*server_revision*/) readVarUInt(new_write_rows, in); readVarUInt(new_write_bytes, in); - rows = new_rows; - bytes = new_bytes; - total_rows = new_total_rows; - write_rows = new_write_rows; - write_bytes = new_write_bytes; + value.rows = new_rows; + value.bytes = new_bytes; + value.total_rows = new_total_rows; + value.write_rows = new_write_rows; + value.write_bytes = new_write_bytes; } -void ProgressValues::write(WriteBuffer & out, UInt64 /*client_revision*/) const +void AllProgressValueImpl::write(const ProgressValues & value, WriteBuffer & out, UInt64 /*client_revision*/) { - writeVarUInt(rows, out); - writeVarUInt(bytes, out); - writeVarUInt(total_rows, out); - writeVarUInt(write_rows, out); - writeVarUInt(write_bytes, out); + writeVarUInt(value.rows, out); + writeVarUInt(value.bytes, out); + writeVarUInt(value.total_rows, out); + writeVarUInt(value.write_rows, out); + writeVarUInt(value.write_bytes, out); } - -void ProgressValues::writeJSON(WriteBuffer & out) const +void AllProgressValueImpl::writeJSON(const ProgressValues & value, WriteBuffer & out) { /// Numbers are written in double quotes (as strings) to avoid loss of precision /// of 64-bit integers after interpretation by JavaScript. writeCString("{\"read_rows\":\"", out); - writeText(rows, out); + writeText(value.rows, out); writeCString("\",\"read_bytes\":\"", out); - writeText(bytes, out); + writeText(value.bytes, out); writeCString("\",\"write_rows\":\"", out); - writeText(write_rows, out); + writeText(value.write_rows, out); writeCString("\",\"write_bytes\":\"", out); - writeText(write_bytes, out); + writeText(value.write_bytes, out); writeCString("\",\"total_rows\":\"", out); - writeText(total_rows, out); + writeText(value.total_rows, out); writeCString("\"}", out); } - -void Progress::read(ReadBuffer & in, UInt64 server_revision) +/* +void ReadProgressValueImpl::read(ProgressValues & value, ReadBuffer & in, UInt64 ) { - ProgressValues values; - values.read(in, server_revision); + size_t new_rows = 0; + size_t new_bytes = 0; + size_t new_total_rows = 0; + + readVarUInt(new_rows, in); + readVarUInt(new_bytes, in); + readVarUInt(new_total_rows, in); + + value.rows = new_rows; + value.bytes = new_bytes; + value.total_rows = new_total_rows; +} - rows.store(values.rows, std::memory_order_relaxed); - bytes.store(values.bytes, std::memory_order_relaxed); - total_rows.store(values.total_rows, std::memory_order_relaxed); - write_rows.store(values.write_rows, std::memory_order_relaxed); - write_bytes.store(values.write_bytes, std::memory_order_relaxed); -} - - -void Progress::write(WriteBuffer & out, UInt64 client_revision) const +void ReadProgressValueImpl::write(const ProgressValues & value, WriteBuffer & out, UInt64) { - getValues().write(out, client_revision); + writeVarUInt(value.rows, out); + writeVarUInt(value.bytes, out); + writeVarUInt(value.total_rows, out); } - - -void Progress::writeJSON(WriteBuffer & out) const +*/ +void ReadProgressValueImpl::writeJSON(const ProgressValues & value, WriteBuffer & out) { - getValues().writeJSON(out); + /// Numbers are written in double quotes (as strings) to avoid loss of precision + /// of 64-bit integers after interpretation by JavaScript. + + writeCString("{\"read_rows\":\"", out); + writeText(value.rows, out); + writeCString("\",\"read_bytes\":\"", out); + writeText(value.bytes, out); + writeCString("\",\"total_rows\":\"", out); + writeText(value.total_rows, out); + writeCString("\"}", out); +} + +void WriteProgressValueImpl::writeJSON(const ProgressValues & value, WriteBuffer & out) +{ + /// Numbers are written in double quotes (as strings) to avoid loss of precision + /// of 64-bit integers after interpretation by JavaScript. + + writeCString("{\"write_rows\":\"", out); + writeText(value.write_rows, out); + writeCString("\",\"write_bytes\":\"", out); + writeText(value.write_bytes, out); + writeCString("\"}", out); } } diff --git a/dbms/src/IO/Progress.h b/dbms/src/IO/Progress.h index a88ee43bdab..8065b4b5a44 100644 --- a/dbms/src/IO/Progress.h +++ b/dbms/src/IO/Progress.h @@ -6,13 +6,13 @@ #include - namespace DB { class ReadBuffer; class WriteBuffer; +struct AllProgressValueImpl; /// See Progress. struct ProgressValues @@ -23,9 +23,40 @@ struct ProgressValues size_t write_rows; size_t write_bytes; - void read(ReadBuffer & in, UInt64 server_revision); - void write(WriteBuffer & out, UInt64 client_revision) const; - void writeJSON(WriteBuffer & out) const; + template + void read(ReadBuffer & in, UInt64 server_revision) + { + ReadImpl::read(*this, in, server_revision); + } + + template + void write(WriteBuffer & out, UInt64 client_revision) const + { + WriteImpl::write(*this, out, client_revision); + } + + template + void writeJSON(WriteBuffer & out) const + { + WriteJSONImpl::writeJSON(*this, out); + } +}; + +struct AllProgressValueImpl +{ + static void read(ProgressValues & value, ReadBuffer & in, UInt64 server_revision); + static void write(const ProgressValues & value, WriteBuffer & out, UInt64 client_revision) ; + static void writeJSON(const ProgressValues & value, WriteBuffer & out); +}; + +struct ReadProgressValueImpl : public AllProgressValueImpl +{ + static void writeJSON(const ProgressValues & value, WriteBuffer & out); +}; + +struct WriteProgressValueImpl : public AllProgressValueImpl +{ + static void writeJSON(const ProgressValues & value, WriteBuffer & out); }; struct ReadProgress @@ -74,10 +105,14 @@ struct Progress Progress(WriteProgress write_progress) : write_rows(write_progress.write_rows), write_bytes(write_progress.write_bytes) {} + template void read(ReadBuffer & in, UInt64 server_revision); + + template void write(WriteBuffer & out, UInt64 client_revision) const; /// Progress in JSON format (single line, without whitespaces) is used in HTTP headers. + template void writeJSON(WriteBuffer & out) const; /// Each value separately is changed atomically (but not whole object). @@ -144,5 +179,31 @@ struct Progress } }; +template +void Progress::read(ReadBuffer & in, UInt64 server_revision) +{ + ProgressValues values; + values.read(in, server_revision); + + rows.store(values.rows, std::memory_order_relaxed); + bytes.store(values.bytes, std::memory_order_relaxed); + total_rows.store(values.total_rows, std::memory_order_relaxed); + write_rows.store(values.write_rows, std::memory_order_relaxed); + write_bytes.store(values.write_bytes, std::memory_order_relaxed); +} + +template +void Progress::write(WriteBuffer & out, UInt64 client_revision) const +{ + getValues().write(out, client_revision); +} + + +template +void Progress::writeJSON(WriteBuffer & out) const +{ + getValues().writeJSON(out); +} + } diff --git a/dbms/src/IO/WriteBufferFromHTTPServerResponse.cpp b/dbms/src/IO/WriteBufferFromHTTPServerResponse.cpp index 2da5bc89726..0f63eb68496 100644 --- a/dbms/src/IO/WriteBufferFromHTTPServerResponse.cpp +++ b/dbms/src/IO/WriteBufferFromHTTPServerResponse.cpp @@ -36,14 +36,26 @@ void WriteBufferFromHTTPServerResponse::startSendHeaders() } } +void WriteBufferFromHTTPServerResponse::writeHeaderSummary() +{ + if (headers_finished_sending) + return; + + WriteBufferFromOwnString progress_string_writer; + accumulated_progress.writeJSON(progress_string_writer); + +#if defined(POCO_CLICKHOUSE_PATCH) + *response_header_ostr << "X-ClickHouse-Summary: " << progress_string_writer.str() << "\r\n" << std::flush; +#endif +} + void WriteBufferFromHTTPServerResponse::writeHeaderProgress() { if (headers_finished_sending) return; - had_update = false; WriteBufferFromOwnString progress_string_writer; - accumulated_progress.writeJSON(progress_string_writer); + accumulated_progress.writeJSON(progress_string_writer); #if defined(POCO_CLICKHOUSE_PATCH) *response_header_ostr << "X-ClickHouse-Progress: " << progress_string_writer.str() << "\r\n" << std::flush; @@ -54,8 +66,7 @@ void WriteBufferFromHTTPServerResponse::finishSendHeaders() { if (!headers_finished_sending) { - if (had_update) - writeHeaderProgress(); + writeHeaderSummary(); headers_finished_sending = true; if (request.getMethod() != Poco::Net::HTTPRequest::HTTP_HEAD) @@ -181,7 +192,7 @@ void WriteBufferFromHTTPServerResponse::onProgress(const Progress & progress) if (headers_finished_sending) return; - had_update = accumulated_progress.incrementPiecewiseAtomically(progress); + accumulated_progress.incrementPiecewiseAtomically(progress); if (progress_watch.elapsed() >= send_progress_interval_ms * 1000000) { diff --git a/dbms/src/IO/WriteBufferFromHTTPServerResponse.h b/dbms/src/IO/WriteBufferFromHTTPServerResponse.h index 56fc07f2859..ac7794afd4e 100644 --- a/dbms/src/IO/WriteBufferFromHTTPServerResponse.h +++ b/dbms/src/IO/WriteBufferFromHTTPServerResponse.h @@ -67,7 +67,6 @@ private: bool headers_started_sending = false; bool headers_finished_sending = false; /// If true, you could not add any headers. - bool had_update = false; Progress accumulated_progress; size_t send_progress_interval_ms = 100; @@ -83,6 +82,8 @@ private: // Used for write the header X-ClickHouse-progress void writeHeaderProgress(); + // Used for write the header X-ClickHouse-summary + void writeHeaderSummary(); /// This method finish headers with \r\n, allowing to start to send body. void finishSendHeaders(); From 7b1be6efc4755d1deaf1d4f62110e676bd276690 Mon Sep 17 00:00:00 2001 From: Guillaume Tassery Date: Fri, 26 Apr 2019 10:46:52 +0700 Subject: [PATCH 073/709] Clode cleaning and add test for X-ClickHouse-Summary header --- .../DataStreams/CountingBlockOutputStream.h | 2 +- dbms/src/IO/Progress.cpp | 23 ------------------- dbms/src/Interpreters/executeQuery.cpp | 2 +- ...copatch_progress_in_http_headers.reference | 3 +++ ...0416_pocopatch_progress_in_http_headers.sh | 2 +- 5 files changed, 6 insertions(+), 26 deletions(-) diff --git a/dbms/src/DataStreams/CountingBlockOutputStream.h b/dbms/src/DataStreams/CountingBlockOutputStream.h index edcdee51948..5c36c40c1ad 100644 --- a/dbms/src/DataStreams/CountingBlockOutputStream.h +++ b/dbms/src/DataStreams/CountingBlockOutputStream.h @@ -39,7 +39,7 @@ public: void onProgress(const Progress & current_progress) override { stream->onProgress(current_progress); } String getContentType() const override { return stream->getContentType(); } -public: +protected: BlockOutputStreamPtr stream; Progress progress; ProgressCallback progress_callback; diff --git a/dbms/src/IO/Progress.cpp b/dbms/src/IO/Progress.cpp index 38c324ece34..74c01135181 100644 --- a/dbms/src/IO/Progress.cpp +++ b/dbms/src/IO/Progress.cpp @@ -57,29 +57,6 @@ void AllProgressValueImpl::writeJSON(const ProgressValues & value, WriteBuffer & writeCString("\"}", out); } -/* -void ReadProgressValueImpl::read(ProgressValues & value, ReadBuffer & in, UInt64 ) -{ - size_t new_rows = 0; - size_t new_bytes = 0; - size_t new_total_rows = 0; - - readVarUInt(new_rows, in); - readVarUInt(new_bytes, in); - readVarUInt(new_total_rows, in); - - value.rows = new_rows; - value.bytes = new_bytes; - value.total_rows = new_total_rows; -} - -void ReadProgressValueImpl::write(const ProgressValues & value, WriteBuffer & out, UInt64) -{ - writeVarUInt(value.rows, out); - writeVarUInt(value.bytes, out); - writeVarUInt(value.total_rows, out); -} -*/ void ReadProgressValueImpl::writeJSON(const ProgressValues & value, WriteBuffer & out) { /// Numbers are written in double quotes (as strings) to avoid loss of precision diff --git a/dbms/src/Interpreters/executeQuery.cpp b/dbms/src/Interpreters/executeQuery.cpp index e77519c8e54..b67ce8334f2 100644 --- a/dbms/src/Interpreters/executeQuery.cpp +++ b/dbms/src/Interpreters/executeQuery.cpp @@ -333,7 +333,7 @@ static std::tuple executeQueryImpl( } else if (stream_out) /// will be used only for ordinary INSERT queries { - if (auto counting_stream = dynamic_cast(stream_out)) + if (auto counting_stream = dynamic_cast(stream_out)) { /// NOTE: Redundancy. The same values could be extracted from process_list_elem->progress_out.query_settings = process_list_elem->progress_in elem.result_rows = counting_stream->getProgress().rows; diff --git a/dbms/tests/queries/0_stateless/00416_pocopatch_progress_in_http_headers.reference b/dbms/tests/queries/0_stateless/00416_pocopatch_progress_in_http_headers.reference index 42036e1a81f..673feb24753 100644 --- a/dbms/tests/queries/0_stateless/00416_pocopatch_progress_in_http_headers.reference +++ b/dbms/tests/queries/0_stateless/00416_pocopatch_progress_in_http_headers.reference @@ -1,6 +1,7 @@ < X-ClickHouse-Progress: {"read_rows":"0","read_bytes":"0","total_rows":"10"} < X-ClickHouse-Progress: {"read_rows":"5","read_bytes":"40","total_rows":"10"} < X-ClickHouse-Progress: {"read_rows":"10","read_bytes":"80","total_rows":"10"} +< X-ClickHouse-Progress: {"read_rows":"10","read_bytes":"80","total_rows":"10"} 9 < X-ClickHouse-Progress: {"read_rows":"1","read_bytes":"8","total_rows":"0"} < X-ClickHouse-Progress: {"read_rows":"2","read_bytes":"16","total_rows":"0"} @@ -12,6 +13,7 @@ < X-ClickHouse-Progress: {"read_rows":"8","read_bytes":"64","total_rows":"0"} < X-ClickHouse-Progress: {"read_rows":"9","read_bytes":"72","total_rows":"0"} < X-ClickHouse-Progress: {"read_rows":"10","read_bytes":"80","total_rows":"0"} +< X-ClickHouse-Progress: {"read_rows":"10","read_bytes":"80","total_rows":"0"} 0 1 2 @@ -32,3 +34,4 @@ 7 8 9 +< X-ClickHouse-Summary: {"read_rows":"10","read_bytes":"80","write_rows":"10","write_bytes":"40","total_rows":"0"} diff --git a/dbms/tests/queries/0_stateless/00416_pocopatch_progress_in_http_headers.sh b/dbms/tests/queries/0_stateless/00416_pocopatch_progress_in_http_headers.sh index 83f15cfb248..76ca56efca8 100755 --- a/dbms/tests/queries/0_stateless/00416_pocopatch_progress_in_http_headers.sh +++ b/dbms/tests/queries/0_stateless/00416_pocopatch_progress_in_http_headers.sh @@ -26,7 +26,7 @@ ${CLICKHOUSE_CURL} -vsS "${CLICKHOUSE_URL}" -H 'Accept-Encoding: gzip' -d 'DROP ${CLICKHOUSE_CURL} -vsS "${CLICKHOUSE_URL}" -H 'Accept-Encoding: gzip' -d 'CREATE TABLE insert_number_query (record UInt32) Engine = Memory' > /dev/null 2>&1 ${CLICKHOUSE_CURL} -vsS "${CLICKHOUSE_URL}" -H 'Accept-Encoding: gzip' -d 'CREATE TABLE insert_number_query_2 (record UInt32) Engine = Memory' > /dev/null 2>&1 -${CLICKHOUSE_CURL} -vsS "${CLICKHOUSE_URL}?max_block_size=1&http_headers_progress_interval_ms=0&send_progress_in_http_headers=1" -d 'INSERT INTO insert_number_query (record) SELECT number FROM system.numbers LIMIT 10' 2>&1 | grep -E 'Content-Encoding|X-ClickHouse-Progress|^[0-9]' +${CLICKHOUSE_CURL} -vsS "${CLICKHOUSE_URL}?max_block_size=1&http_headers_progress_interval_ms=0&send_progress_in_http_headers=1" -d 'INSERT INTO insert_number_query (record) SELECT number FROM system.numbers LIMIT 10' 2>&1 | grep -E 'Content-Encoding|X-ClickHouse-Summary|^[0-9]' ${CLICKHOUSE_CURL} -vsS "${CLICKHOUSE_URL}" -H 'Accept-Encoding: gzip' -d 'DROP TABLE insert_number_query' > /dev/null 2>&1 ${CLICKHOUSE_CURL} -vsS "${CLICKHOUSE_URL}" -H 'Accept-Encoding: gzip' -d 'DROP TABLE insert_number_query2' > /dev/null 2>&1 From 40db4551f20253062057fa2e6603ce3552f96408 Mon Sep 17 00:00:00 2001 From: Guillaume Tassery Date: Fri, 26 Apr 2019 12:01:02 +0700 Subject: [PATCH 074/709] Add USE_GPERF on configuration file --- dbms/src/Common/config.h.in | 1 + dbms/src/Functions/CMakeLists.txt | 12 +++++++----- dbms/src/Functions/firstSignificantSubdomain.h | 6 ++++-- dbms/src/Functions/tldLookup.h | 3 ++- docs/en/development/build.md | 7 +------ 5 files changed, 15 insertions(+), 14 deletions(-) diff --git a/dbms/src/Common/config.h.in b/dbms/src/Common/config.h.in index c323afe369e..8d779903c99 100644 --- a/dbms/src/Common/config.h.in +++ b/dbms/src/Common/config.h.in @@ -25,6 +25,7 @@ #cmakedefine01 USE_BROTLI #cmakedefine01 USE_SSL #cmakedefine01 USE_HYPERSCAN +#cmakedefine01 USE_GPERF #cmakedefine01 CLICKHOUSE_SPLIT_BINARY #cmakedefine01 LLVM_HAS_RTTI diff --git a/dbms/src/Functions/CMakeLists.txt b/dbms/src/Functions/CMakeLists.txt index 4247c26baa2..5068be69194 100644 --- a/dbms/src/Functions/CMakeLists.txt +++ b/dbms/src/Functions/CMakeLists.txt @@ -3,12 +3,14 @@ include(${ClickHouse_SOURCE_DIR}/cmake/dbms_glob_sources.cmake) add_headers_and_sources(clickhouse_functions ./GatherUtils) add_headers_and_sources(clickhouse_functions .) -add_custom_command( - OUTPUT ${CMAKE_CURRENT_SOURCE_DIR}/tldLookup.cpp - COMMAND ${GPERF} ${CMAKE_CURRENT_SOURCE_DIR}/gperf/tldLookup.gperf --output-file=${CMAKE_CURRENT_SOURCE_DIR}/tldLookup.cpp -) +if (USE_GPERF) + add_custom_command( + OUTPUT ${CMAKE_CURRENT_BINARY_DIR}/tldLookup.cpp + COMMAND ${GPERF} ${CMAKE_CURRENT_SOURCE_DIR}/gperf/tldLookup.gperf --output-file=${CMAKE_CURRENT_BINARY_DIR}/tldLookup.cpp + ) -list(APPEND clickhouse_functions_sources tldLookup.cpp) + list(APPEND clickhouse_functions_sources ${CMAKE_CURRENT_BINARY_DIR}/tldLookup.cpp) +endif () list(REMOVE_ITEM clickhouse_functions_sources IFunction.cpp FunctionFactory.cpp FunctionHelpers.cpp) list(REMOVE_ITEM clickhouse_functions_headers IFunction.h FunctionFactory.h FunctionHelpers.h) diff --git a/dbms/src/Functions/firstSignificantSubdomain.h b/dbms/src/Functions/firstSignificantSubdomain.h index ddc056df9f9..2073fafa7dc 100644 --- a/dbms/src/Functions/firstSignificantSubdomain.h +++ b/dbms/src/Functions/firstSignificantSubdomain.h @@ -2,6 +2,7 @@ #include #include +#include #include namespace DB @@ -64,17 +65,18 @@ struct ExtractFirstSignificantSubdomain end_of_level_domain = end; } +#if USE_GPERF if (tldLookup::is_valid(last_3_periods[1] + 1, end_of_level_domain - last_3_periods[1] - 1) != nullptr) { res_data += last_3_periods[2] + 1 - begin; res_size = last_3_periods[1] - last_3_periods[2] - 1; - } + } else { res_data += last_3_periods[1] + 1 - begin; res_size = last_3_periods[0] - last_3_periods[1] - 1; } - +#endif } }; diff --git a/dbms/src/Functions/tldLookup.h b/dbms/src/Functions/tldLookup.h index 76a87e6b8c7..d7629faf4c9 100644 --- a/dbms/src/Functions/tldLookup.h +++ b/dbms/src/Functions/tldLookup.h @@ -1,6 +1,6 @@ #pragma once - +#if USE_GPERF // Definition of the class generated by gperf, present on gperf/tldLookup.gperf class tldLookupHash { @@ -14,3 +14,4 @@ namespace DB { using tldLookup = tldLookupHash; } +#endif diff --git a/docs/en/development/build.md b/docs/en/development/build.md index 9a0b160d705..6d56d6a22b4 100644 --- a/docs/en/development/build.md +++ b/docs/en/development/build.md @@ -67,12 +67,7 @@ export CXX=g++-7 ## Install Required Libraries from Packages ```bash -sudo apt-get install libicu-dev libreadline-dev -``` - -## Install Additional dependencies -```bash -sudo apt-get install gperf +sudo apt-get install libicu-dev libreadline-dev gperf ``` ## Checkout ClickHouse Sources From cb51558bdfe78c6fd2188cfc191c954d99a6c0d0 Mon Sep 17 00:00:00 2001 From: Ivan Kushnarenko Date: Sat, 27 Apr 2019 11:24:50 +0300 Subject: [PATCH 075/709] check build clang7 splitted --- dbms/src/Storages/StorageMergeTree.cpp | 4 +++- 1 file changed, 3 insertions(+), 1 deletion(-) diff --git a/dbms/src/Storages/StorageMergeTree.cpp b/dbms/src/Storages/StorageMergeTree.cpp index 8f610bc7bdb..40213898b5a 100644 --- a/dbms/src/Storages/StorageMergeTree.cpp +++ b/dbms/src/Storages/StorageMergeTree.cpp @@ -197,7 +197,9 @@ void StorageMergeTree::rename(const String & new_path_to_db, const String & /*ne std::vector StorageMergeTree::prepareAlterTransactions( const ColumnsDescription & new_columns, const IndicesDescription & new_indices, const Context & context) { - auto parts = data.getDataParts({MergeTreeDataPartState::PreCommitted, MergeTreeDataPartState::Committed, MergeTreeDataPartState::Outdated}); + auto parts = data.getDataParts({MergeTreeDataPartState::PreCommitted, + MergeTreeDataPartState::Committed, + MergeTreeDataPartState::Outdated}); std::vector transactions(parts.size()); const auto& columns_for_parts = new_columns.getAllPhysical(); From 40be74ac658bc0c58809ed9c6619ceeced0684d3 Mon Sep 17 00:00:00 2001 From: ivan-kush Date: Sat, 27 Apr 2019 18:27:57 +0300 Subject: [PATCH 076/709] refactor --- dbms/src/Core/Settings.h | 2 +- dbms/src/Core/SettingsCommon.h | 7 ------- 2 files changed, 1 insertion(+), 8 deletions(-) diff --git a/dbms/src/Core/Settings.h b/dbms/src/Core/Settings.h index 34cfaded905..891e2a6e615 100644 --- a/dbms/src/Core/Settings.h +++ b/dbms/src/Core/Settings.h @@ -41,7 +41,7 @@ struct Settings M(SettingUInt64, min_insert_block_size_rows, DEFAULT_INSERT_BLOCK_SIZE, "Squash blocks passed to INSERT query to specified size in rows, if blocks are not big enough.") \ M(SettingUInt64, min_insert_block_size_bytes, (DEFAULT_INSERT_BLOCK_SIZE * 256), "Squash blocks passed to INSERT query to specified size in bytes, if blocks are not big enough.") \ M(SettingMaxThreads, max_threads, 0, "The maximum number of threads to execute the request. By default, it is determined automatically.") \ - M(SettingMaxAlterThreads, max_alter_threads, 0, "The maximum number of threads to execute the ALTER requests. By default, it is determined automatically.") \ + M(SettingMaxThreads, max_alter_threads, 0, "The maximum number of threads to execute the ALTER requests. By default, it is determined automatically.") \ M(SettingUInt64, max_read_buffer_size, DBMS_DEFAULT_BUFFER_SIZE, "The maximum size of the buffer to read from the filesystem.") \ M(SettingUInt64, max_distributed_connections, 1024, "The maximum number of connections for distributed processing of one query (should be greater than max_threads).") \ M(SettingUInt64, max_query_size, 262144, "Which part of the query can be read into RAM for parsing (the remaining data for INSERT, if any, is read later)") \ diff --git a/dbms/src/Core/SettingsCommon.h b/dbms/src/Core/SettingsCommon.h index d992b2d64f0..9f7eb1187c9 100644 --- a/dbms/src/Core/SettingsCommon.h +++ b/dbms/src/Core/SettingsCommon.h @@ -87,13 +87,6 @@ struct SettingMaxThreads UInt64 getAutoValueImpl() const; }; -struct SettingMaxAlterThreads: public SettingMaxThreads -{ - SettingMaxAlterThreads(UInt64 x = 0): - SettingMaxThreads(x) - {} -}; - struct SettingSeconds { Poco::Timespan value; From 26b3910b7dfc2a2ea4e3c29a1cb20c9d8591fc94 Mon Sep 17 00:00:00 2001 From: ivan-kush Date: Sat, 27 Apr 2019 20:01:30 +0300 Subject: [PATCH 077/709] tsan debug --- dbms/src/Core/SettingsCommon.h | 1 + dbms/src/Storages/StorageMergeTree.cpp | 6 +++++- 2 files changed, 6 insertions(+), 1 deletion(-) diff --git a/dbms/src/Core/SettingsCommon.h b/dbms/src/Core/SettingsCommon.h index 9f7eb1187c9..c661cef1570 100644 --- a/dbms/src/Core/SettingsCommon.h +++ b/dbms/src/Core/SettingsCommon.h @@ -87,6 +87,7 @@ struct SettingMaxThreads UInt64 getAutoValueImpl() const; }; + struct SettingSeconds { Poco::Timespan value; diff --git a/dbms/src/Storages/StorageMergeTree.cpp b/dbms/src/Storages/StorageMergeTree.cpp index 40213898b5a..49c07444f7f 100644 --- a/dbms/src/Storages/StorageMergeTree.cpp +++ b/dbms/src/Storages/StorageMergeTree.cpp @@ -211,9 +211,13 @@ std::vector StorageMergeTree::prepar size_t i = 0; for (const auto & part : parts) { + auto thread_group = CurrentThread::getGroup(); thread_pool.schedule( - [this, i, &transactions, &part, columns_for_parts, new_indices = new_indices.indices] + [this, i, &transactions, &part, columns_for_parts, thread_group, new_indices = new_indices.indices] { + setThreadName("AlterTransactions"); + if(thread_group) + CurrentThread::attachToIfDetached(thread_group); if (auto transaction = this->data.alterDataPart(part, columns_for_parts, new_indices, false)) transactions[i] = std::move(transaction); } From bdbe97276c7f1599d99b16887190a14233c53db4 Mon Sep 17 00:00:00 2001 From: Ivan Kushnarenko Date: Sat, 27 Apr 2019 23:15:10 +0300 Subject: [PATCH 078/709] remove groups --- dbms/src/Storages/StorageMergeTree.cpp | 6 +----- 1 file changed, 1 insertion(+), 5 deletions(-) diff --git a/dbms/src/Storages/StorageMergeTree.cpp b/dbms/src/Storages/StorageMergeTree.cpp index 49c07444f7f..40213898b5a 100644 --- a/dbms/src/Storages/StorageMergeTree.cpp +++ b/dbms/src/Storages/StorageMergeTree.cpp @@ -211,13 +211,9 @@ std::vector StorageMergeTree::prepar size_t i = 0; for (const auto & part : parts) { - auto thread_group = CurrentThread::getGroup(); thread_pool.schedule( - [this, i, &transactions, &part, columns_for_parts, thread_group, new_indices = new_indices.indices] + [this, i, &transactions, &part, columns_for_parts, new_indices = new_indices.indices] { - setThreadName("AlterTransactions"); - if(thread_group) - CurrentThread::attachToIfDetached(thread_group); if (auto transaction = this->data.alterDataPart(part, columns_for_parts, new_indices, false)) transactions[i] = std::move(transaction); } From d21cf9d85f66abe4f8f5e015b0e0168fae26d150 Mon Sep 17 00:00:00 2001 From: Yuriy Date: Mon, 29 Apr 2019 09:05:30 +0300 Subject: [PATCH 079/709] ssl support --- dbms/programs/server/MySQLHandler.cpp | 63 +++++++++++++++---- dbms/programs/server/MySQLHandler.h | 10 +++ dbms/src/Core/MySQLProtocol.h | 42 +++++++++++-- .../test_mysql_protocol/configs/config.xml | 16 +++++ .../test_mysql_protocol/configs/dhparam.pem | 8 +++ .../test_mysql_protocol/configs/server.crt | 18 ++++++ .../test_mysql_protocol/configs/server.key | 28 +++++++++ .../integration/test_mysql_protocol/test.py | 7 +-- 8 files changed, 170 insertions(+), 22 deletions(-) create mode 100644 dbms/tests/integration/test_mysql_protocol/configs/dhparam.pem create mode 100644 dbms/tests/integration/test_mysql_protocol/configs/server.crt create mode 100644 dbms/tests/integration/test_mysql_protocol/configs/server.key diff --git a/dbms/programs/server/MySQLHandler.cpp b/dbms/programs/server/MySQLHandler.cpp index e3a941206da..7ff1394b63c 100644 --- a/dbms/programs/server/MySQLHandler.cpp +++ b/dbms/programs/server/MySQLHandler.cpp @@ -10,6 +10,8 @@ #include #include #include +#include +#include #include "MySQLHandler.h" #include @@ -17,6 +19,8 @@ namespace DB { using namespace MySQLProtocol; +using Poco::Net::SecureStreamSocket; +using Poco::Net::SSLManager; namespace ErrorCodes { @@ -31,11 +35,7 @@ void MySQLHandler::run() { connection_context = server.context(); - { - auto in = std::make_shared(socket()); - auto out = std::make_shared(socket()); - packet_sender = PacketSender(in, out); - } + packet_sender = PacketSender(socket()); try { @@ -51,8 +51,7 @@ void MySQLHandler::run() LOG_TRACE(log, "Sent handshake"); - HandshakeResponse handshake_response; - packet_sender.receivePacket(handshake_response); + HandshakeResponse handshake_response = finishHandshake(); LOG_DEBUG(log, "Capabilities: " << handshake_response.capability_flags << "\nmax_packet_size: " @@ -130,6 +129,42 @@ void MySQLHandler::run() } } +MySQLProtocol::HandshakeResponse MySQLHandler::finishHandshake() +{ + /** Size of SSLRequest packet is 32 bytes. + * If we read more, then we will read part of SSL handshake, and it will be impossible to start SSL connection using Poco. + */ + HandshakeResponse packet; + char b[100]; /// Client can send either SSLRequest or HandshakeResponse. + size_t pos = 0; + while (pos < 3) { + int ret = socket().receiveBytes(b + pos, 36 - pos); + if (ret == 0) { + throw Exception("Cannot read all data. Bytes read: " + std::to_string(pos) + ". Bytes expected: 36.", ErrorCodes::CANNOT_READ_ALL_DATA); + } + pos += ret; + } + + size_t packet_size = *reinterpret_cast(b) & 0xFFFFFF; + LOG_TRACE(log, "packet size: " << packet_size); + if (packet_size == 32) { + ss = std::make_shared(SecureStreamSocket::attach(socket(), SSLManager::instance().defaultServerContext())); + packet_sender = PacketSender(*ss, 2); + secure_connection = true; + packet_sender.receivePacket(packet); + } else { + while (pos < 4 + packet_size) { + int ret = socket().receiveBytes(b + pos, 4 + packet_size - pos); + if (ret == 0) { + throw Exception("Cannot read all data. Bytes read: " + std::to_string(pos) + ". Bytes expected: " + std::to_string(4 + packet_size) + ".", ErrorCodes::CANNOT_READ_ALL_DATA); + } + pos += ret; + } + packet.readPayload(std::string(b + 4, packet_size)); + packet_sender.sequence_id++; + } + return packet; +} String MySQLHandler::generateScramble() { @@ -167,11 +202,11 @@ void MySQLHandler::authenticate(const HandshakeResponse & handshake_response, co auto getOpenSSLError = []() -> String { BIO * mem = BIO_new(BIO_s_mem()); ERR_print_errors(mem); - char * pem_buf = nullptr; - long pem_size = BIO_get_mem_data(mem, &pem_buf); - String pem(pem_buf, pem_size); + char * buf = nullptr; + long size = BIO_get_mem_data(mem, &buf); + String errors_str(buf, size); BIO_free(mem); - return pem; + return errors_str; }; if (auth_response == "\2") @@ -211,7 +246,7 @@ void MySQLHandler::authenticate(const HandshakeResponse & handshake_response, co * https://github.com/mysql/mysql-server/blob/8.0/sql/auth/sql_authentication.cc#L4017 */ - if (!(auth_response.empty() || (auth_response.size() == 1 && auth_response[0] == '\0'))) + if (!secure_connection && !(auth_response.empty() || (auth_response.size() == 1 && auth_response[0] == '\0'))) { LOG_TRACE(log, "Received nonempty password"); auto ciphertext = reinterpret_cast(auth_response.data()); @@ -229,6 +264,10 @@ void MySQLHandler::authenticate(const HandshakeResponse & handshake_response, co password[i] = plaintext[i] ^ static_cast(scramble[i % scramble.size()]); } } + else if (secure_connection) + { + password = auth_response; + } else { LOG_TRACE(log, "Received empty password"); diff --git a/dbms/programs/server/MySQLHandler.h b/dbms/programs/server/MySQLHandler.h index 71879353028..57938730ebb 100644 --- a/dbms/programs/server/MySQLHandler.h +++ b/dbms/programs/server/MySQLHandler.h @@ -1,6 +1,7 @@ #pragma once #include +#include #include #include #include @@ -32,6 +33,9 @@ public: void run() final; private: + /// Enables SSL, if client requested. + MySQLProtocol::HandshakeResponse finishHandshake(); + void comQuery(String payload); void comFieldList(String payload); @@ -57,6 +61,12 @@ private: static uint32_t last_connection_id; RSA * public_key, * private_key; + + std::shared_ptr in; + std::shared_ptr out; + + bool secure_connection = false; + std::shared_ptr ss; }; } diff --git a/dbms/src/Core/MySQLProtocol.h b/dbms/src/Core/MySQLProtocol.h index fb705635c69..dd6f1c610ff 100644 --- a/dbms/src/Core/MySQLProtocol.h +++ b/dbms/src/Core/MySQLProtocol.h @@ -3,8 +3,11 @@ #include #include #include +#include +#include #include #include +#include #include #include @@ -46,6 +49,7 @@ enum Capability { CLIENT_CONNECT_WITH_DB = 0x00000008, CLIENT_PROTOCOL_41 = 0x00000200, + CLIENT_SSL = 0x00000800, CLIENT_TRANSACTIONS = 0x00002000, // TODO CLIENT_SESSION_TRACK = 0x00800000, // TODO CLIENT_SECURE_CONNECTION = 0x00008000, @@ -128,6 +132,8 @@ public: class ReadPacket { public: + ReadPacket() = default; + ReadPacket(const ReadPacket &) = default; virtual void readPayload(String payload) = 0; virtual ~ReadPacket() = default; @@ -140,11 +146,15 @@ public: class PacketSender { public: - PacketSender() - {} + size_t sequence_id = 0; - PacketSender(std::shared_ptr in, std::shared_ptr out) - : in(std::move(in)), out(std::move(out)), sequence_id(0), log(&Poco::Logger::get("MySQLHandler")) + PacketSender() = default; + + explicit PacketSender(Poco::Net::StreamSocket & socket, size_t sequence_id=0) + : sequence_id(sequence_id) + , in(std::make_shared(socket)) + , out(std::make_shared(socket)) + , log(&Poco::Logger::get("MySQLHandler")) { } @@ -230,7 +240,7 @@ private: std::shared_ptr in; std::shared_ptr out; - size_t sequence_id; + Poco::Logger * log; }; @@ -259,7 +269,7 @@ public: , server_version(std::move(server_version)) , connection_id(connection_id) , capability_flags(CLIENT_PROTOCOL_41 | CLIENT_SECURE_CONNECTION | CLIENT_PLUGIN_AUTH | CLIENT_PLUGIN_AUTH_LENENC_CLIENT_DATA - | CLIENT_CONNECT_WITH_DB | CLIENT_DEPRECATE_EOF) + | CLIENT_CONNECT_WITH_DB | CLIENT_DEPRECATE_EOF | CLIENT_SSL) , character_set(CharacterSet::utf8_general_ci) , status_flags(0) , auth_plugin_data(auth_plugin_data) @@ -286,6 +296,22 @@ public: } }; +class SSLRequest : public ReadPacket +{ +public: + uint32_t capability_flags; + uint32_t max_packet_size; + uint8_t character_set; + + void readPayload(String s) override + { + std::istringstream ss(s); + ss.readsome(reinterpret_cast(&capability_flags), 4); + ss.readsome(reinterpret_cast(&max_packet_size), 4); + ss.readsome(reinterpret_cast(&character_set), 1); + } +}; + class HandshakeResponse : public ReadPacket { public: @@ -297,6 +323,10 @@ public: String database; String auth_plugin_name; + HandshakeResponse() = default; + + HandshakeResponse(const HandshakeResponse &) = default; + void readPayload(String s) override { std::istringstream ss(s); diff --git a/dbms/tests/integration/test_mysql_protocol/configs/config.xml b/dbms/tests/integration/test_mysql_protocol/configs/config.xml index 7c73809100b..86d055b50b5 100644 --- a/dbms/tests/integration/test_mysql_protocol/configs/config.xml +++ b/dbms/tests/integration/test_mysql_protocol/configs/config.xml @@ -8,6 +8,22 @@ 10 + + + + + /etc/clickhouse-server/server.crt + /etc/clickhouse-server/server.key + + /etc/clickhouse-server/dhparam.pem + none + true + true + sslv2,sslv3 + true + + + 9000 9001 127.0.0.1 diff --git a/dbms/tests/integration/test_mysql_protocol/configs/dhparam.pem b/dbms/tests/integration/test_mysql_protocol/configs/dhparam.pem new file mode 100644 index 00000000000..fb935b9c898 --- /dev/null +++ b/dbms/tests/integration/test_mysql_protocol/configs/dhparam.pem @@ -0,0 +1,8 @@ +-----BEGIN DH PARAMETERS----- +MIIBCAKCAQEAkPGhfLY5nppeQkFBKYRpiisxzrRQfyyTUu6aabZP2CbAMAuoYzaC +Z+iqeWSQZKRYeA21SZXkC9xE1e5FJsc5IWzCRiMNZeLuj4ApUNysMu89DpX8/b91 ++Ka6wRJnaO43ZqHj/9FpU4JiYtxoIpXDC9HeiSAnwLwJc3L+nkYfnSGgvzWIxhGV +gCoVmVBoTe7wrqCyVlM5nrNZSjhlSugvXmu2bSK3MwYF08QLKvlF68eedbs0PMWh +WC0bFM/X7gMBEqL4DiINufAShbZPKxD6eL2APiHPUo6xun3ed/Po/5j8QBmiku0c +5Jb12ZhOTRTQjaRg2aFF8LPdW2tDE7HmewIBAg== +-----END DH PARAMETERS----- diff --git a/dbms/tests/integration/test_mysql_protocol/configs/server.crt b/dbms/tests/integration/test_mysql_protocol/configs/server.crt new file mode 100644 index 00000000000..6f4deca038f --- /dev/null +++ b/dbms/tests/integration/test_mysql_protocol/configs/server.crt @@ -0,0 +1,18 @@ +-----BEGIN CERTIFICATE----- +MIIC+zCCAeOgAwIBAgIJAIhI9ozZJ+TWMA0GCSqGSIb3DQEBCwUAMBQxEjAQBgNV +BAMMCWxvY2FsaG9zdDAeFw0xOTA0MjIwNDMyNTJaFw0yMDA0MjEwNDMyNTJaMBQx +EjAQBgNVBAMMCWxvY2FsaG9zdDCCASIwDQYJKoZIhvcNAQEBBQADggEPADCCAQoC +ggEBAK+wVUEdqF2uXvN0MJBgnAHyXi6JTi4p/F6igsrCjSNjJWzHH0vQmK8ujfcF +CkifW88i+W5eHctuEtQqNHK+t9x9YiZtXrj6m/XkOXs20mYgENSmbbbHbriTPnZB +zZrq6UqMlwIHNNAa+I3NMORQxVRaI0ybXnGVO5elr70xHpk03xL0JWKHpEqYp4db +2aBQgF6y3Ww4khxjIYqpUYXWXGFnVIRU7FKVEAM1xyKqvQzXjQ5sVM/wyHknveEF +3b/X4ggN+KNl5KOc0cWDh1/XaatJAPaUUPqZcq76tynLbP64Xm3dxHcj+gtRkO67 +ef6MSg6l63m3XQP6Qb+MIkd06OsCAwEAAaNQME4wHQYDVR0OBBYEFDmODTO8QLDN +ykR3x0LIOnjNhrKhMB8GA1UdIwQYMBaAFDmODTO8QLDNykR3x0LIOnjNhrKhMAwG +A1UdEwQFMAMBAf8wDQYJKoZIhvcNAQELBQADggEBAAwaiJc7uqEpnH3aukbftDwX +m8GfEnj1HVdgg+9GGNq+9rvUYBF6gdPmjRCX9dO0cclLFx8jc2org0rTSq9WoOhX +E6qL4Eqrmc5SE3Y9jZM0h6GRD4oXK014FmtZ3T6ddZU3dQLj3BS2r1XrvmubTvGN +ZuTJNY8nx8Hh6H5XINmsEjUF9E5hog+PwCE03xt2adIdYL+gsbxASeNYyeUFpZv5 +zcXR3VoakBWnAaOVgCHq2qh96QAnL7ZKzFkGf/MdwV10KU3dmb+ICbQUUdf9Gc17 +aaDCIRws312F433FdXBkGs2UkB7ZZme9dfn6O1QbeTNvex2VLMqYx/CTkfFbOQA= +-----END CERTIFICATE----- diff --git a/dbms/tests/integration/test_mysql_protocol/configs/server.key b/dbms/tests/integration/test_mysql_protocol/configs/server.key new file mode 100644 index 00000000000..6eddb3295db --- /dev/null +++ b/dbms/tests/integration/test_mysql_protocol/configs/server.key @@ -0,0 +1,28 @@ +-----BEGIN PRIVATE KEY----- +MIIEvQIBADANBgkqhkiG9w0BAQEFAASCBKcwggSjAgEAAoIBAQCvsFVBHahdrl7z +dDCQYJwB8l4uiU4uKfxeooLKwo0jYyVsxx9L0JivLo33BQpIn1vPIvluXh3LbhLU +KjRyvrfcfWImbV64+pv15Dl7NtJmIBDUpm22x264kz52Qc2a6ulKjJcCBzTQGviN +zTDkUMVUWiNMm15xlTuXpa+9MR6ZNN8S9CVih6RKmKeHW9mgUIBest1sOJIcYyGK +qVGF1lxhZ1SEVOxSlRADNcciqr0M140ObFTP8Mh5J73hBd2/1+IIDfijZeSjnNHF +g4df12mrSQD2lFD6mXKu+rcpy2z+uF5t3cR3I/oLUZDuu3n+jEoOpet5t10D+kG/ +jCJHdOjrAgMBAAECggEARF66zrxb6RkSmmt8+rKeA6PuQu3sHsr4C1vyyjUr97l9 +tvdGlpp20LWtSZQMjHZ3pARYTTsTHTeY3DgQcRcHNicVKx8k3ZepWeeW9vw+pL+V +zSt3RsoVrH6gsCSrfr4sS3aqzX9AbjwQvh48CJ3mLQ1m70kHV+xbZIh1+4pB/hyP +1wKyUE18ZkOptXvO/TtoHzLQCecpkXtWzmry1Eh2isvXA+NMrAtLibGsyM1mtm7i +5ozevzHabvvCDBEe+KgZdONgVhhhvm2eOd+/s4w3rw4ETud4fI/ZAJyWXhiIKFnA +VJbElWruSAoVBW7p2bsF5PbmVzvo8vXL+VylxYD+AQKBgQDhLoRKTVhNkn/QjKxq +sdOh+QZra0LzjVpAmkQzu7wZMSHEz9qePQciDQQrYKrmRF1vNcIRCVUTqWYheJ/1 +lKRrCGa0ab6k96zkWMqLHD5u+UeJV7r1dJIx08ME9kNJ+x/XtB8klRIji16NiQUS +qc6p8z0M2AnbJzsRfWZRH8FeYwKBgQDHu8dzdtVGI7MtxfPOE/bfajiopDg8BdTC +pdug2T8XofRHRq7Q+0vYjTAZFT/slib91Pk6VvvPdo9VBZiL4omv4dAq6mOOdX/c +U14mJe1X5GCrr8ExZ8BfNJ3t/6sV1fcxyJwAw7iBguqxA2JqdM/wFk10K8XqvzVn +CD6O9yGt2QKBgFX1BMi8N538809vs41S7l9hCQNOQZNo/O+2M5yv6ECRkbtoQKKw +1x03bMUGNJaLuELweXE5Z8GGo5bZTe5X3F+DKHlr+DtO1C+ieUaa9HY2MAmMdLCn +2/qrREGLo+oEs4YKmuzC/taUp/ZNPKOAMISNdluFyFVg51pozPrgrVbTAoGBAKkE +LBl3O67o0t0vH8sJdeVFG8EJhlS0koBMnfgVHqC++dm+5HwPyvTrNQJkyv1HaqNt +r6FArkG3ED9gRuBIyT6+lctbIPgSUip9mbQqcBfqOCvQxGksZMur2ODncz09HLtS +CUFUXjOqNzOnq4ZuZu/Bz7U4vXiSaXxQq6+LTUKxAoGAFZU/qrI06XxnrE9A1X0W +l7DSkpZaDcu11NrZ473yONih/xOZNh4SSBpX8a7F6Pmh9BdtGqphML8NFPvQKcfP +b9H2iid2tc292uyrUEb5uTMmv61zoTwtitqLzO0+tS6PT3fXobX+eyeEWKzPBljL +HFtxG5CCXpkdnWRmaJnhTzA= +-----END PRIVATE KEY----- diff --git a/dbms/tests/integration/test_mysql_protocol/test.py b/dbms/tests/integration/test_mysql_protocol/test.py index dd2d7453a35..6034e866b2d 100644 --- a/dbms/tests/integration/test_mysql_protocol/test.py +++ b/dbms/tests/integration/test_mysql_protocol/test.py @@ -13,8 +13,9 @@ from helpers.cluster import ClickHouseCluster SCRIPT_DIR = os.path.dirname(os.path.realpath(__file__)) -cluster = ClickHouseCluster(__file__, base_configs_dir=os.path.join(SCRIPT_DIR, './configs')) -node = cluster.add_instance('node') +config_dir = os.path.join(SCRIPT_DIR, './configs') +cluster = ClickHouseCluster(__file__) +node = cluster.add_instance('node', config_dir=config_dir) server_port = 9001 @@ -50,8 +51,6 @@ def test_mysql_client(mysql_client, server_address): -e "select 'тест' as b;" '''.format(host=server_address, port=server_port), demux=True) - import pdb - pdb.set_trace() assert stdout == 'a\n1\nb\nтест\n' code, (stdout, stderr) = mysql_client.exec_run(''' From 8a3e75d92f2e2080164438af62c3733064290f72 Mon Sep 17 00:00:00 2001 From: Yuriy Date: Mon, 29 Apr 2019 09:37:39 +0300 Subject: [PATCH 080/709] fixed style --- dbms/programs/server/MySQLHandler.cpp | 41 +++-- dbms/programs/server/MySQLHandlerFactory.h | 166 +++++++++++---------- 2 files changed, 114 insertions(+), 93 deletions(-) diff --git a/dbms/programs/server/MySQLHandler.cpp b/dbms/programs/server/MySQLHandler.cpp index 7ff1394b63c..fe50b6fcd2f 100644 --- a/dbms/programs/server/MySQLHandler.cpp +++ b/dbms/programs/server/MySQLHandler.cpp @@ -24,8 +24,8 @@ using Poco::Net::SSLManager; namespace ErrorCodes { - extern const int MYSQL_CLIENT_INSUFFICIENT_CAPABILITIES; - extern const int UNKNOWN_EXCEPTION; +extern const int MYSQL_CLIENT_INSUFFICIENT_CAPABILITIES; +extern const int UNKNOWN_EXCEPTION; } uint32_t MySQLHandler::last_connection_id = 0; @@ -137,9 +137,11 @@ MySQLProtocol::HandshakeResponse MySQLHandler::finishHandshake() HandshakeResponse packet; char b[100]; /// Client can send either SSLRequest or HandshakeResponse. size_t pos = 0; - while (pos < 3) { + while (pos < 3) + { int ret = socket().receiveBytes(b + pos, 36 - pos); - if (ret == 0) { + if (ret == 0) + { throw Exception("Cannot read all data. Bytes read: " + std::to_string(pos) + ". Bytes expected: 36.", ErrorCodes::CANNOT_READ_ALL_DATA); } pos += ret; @@ -147,15 +149,20 @@ MySQLProtocol::HandshakeResponse MySQLHandler::finishHandshake() size_t packet_size = *reinterpret_cast(b) & 0xFFFFFF; LOG_TRACE(log, "packet size: " << packet_size); - if (packet_size == 32) { + if (packet_size == 32) + { ss = std::make_shared(SecureStreamSocket::attach(socket(), SSLManager::instance().defaultServerContext())); packet_sender = PacketSender(*ss, 2); secure_connection = true; packet_sender.receivePacket(packet); - } else { - while (pos < 4 + packet_size) { + } + else + { + while (pos < 4 + packet_size) + { int ret = socket().receiveBytes(b + pos, 4 + packet_size - pos); - if (ret == 0) { + if (ret == 0) + { throw Exception("Cannot read all data. Bytes read: " + std::to_string(pos) + ". Bytes expected: " + std::to_string(4 + packet_size) + ".", ErrorCodes::CANNOT_READ_ALL_DATA); } pos += ret; @@ -170,17 +177,20 @@ String MySQLHandler::generateScramble() { String scramble(MySQLProtocol::SCRAMBLE_LENGTH, 0); Poco::RandomInputStream generator; - for (size_t i = 0; i < scramble.size(); i++) { + for (size_t i = 0; i < scramble.size(); i++) + { generator >> scramble[i]; } return scramble; } -void MySQLHandler::authenticate(const HandshakeResponse & handshake_response, const String & scramble) { +void MySQLHandler::authenticate(const HandshakeResponse & handshake_response, const String & scramble) +{ String auth_response; AuthSwitchResponse response; - if (handshake_response.auth_plugin_name != Authentication::CachingSHA2) { + if (handshake_response.auth_plugin_name != Authentication::CachingSHA2) + { packet_sender.sendPacket(AuthSwitchRequest(Authentication::CachingSHA2, scramble + '\0'), true); packet_sender.receivePacket(response); auth_response = response.value; @@ -199,7 +209,8 @@ void MySQLHandler::authenticate(const HandshakeResponse & handshake_response, co packet_sender.receivePacket(response); auth_response = response.value; - auto getOpenSSLError = []() -> String { + auto getOpenSSLError = []() -> String + { BIO * mem = BIO_new(BIO_s_mem()); ERR_print_errors(mem); char * buf = nullptr; @@ -260,7 +271,8 @@ void MySQLHandler::authenticate(const HandshakeResponse & handshake_response, co } password.resize(plaintext_size); - for (int i = 0; i < plaintext_size; i++) { + for (int i = 0; i < plaintext_size; i++) + { password[i] = plaintext[i] ^ static_cast(scramble[i % scramble.size()]); } } @@ -273,7 +285,8 @@ void MySQLHandler::authenticate(const HandshakeResponse & handshake_response, co LOG_TRACE(log, "Received empty password"); } - if (!password.empty()) { + if (!password.empty()) + { /// remove terminating null byte password.pop_back(); } diff --git a/dbms/programs/server/MySQLHandlerFactory.h b/dbms/programs/server/MySQLHandlerFactory.h index 459e3f4f5e3..70cc0d20863 100644 --- a/dbms/programs/server/MySQLHandlerFactory.h +++ b/dbms/programs/server/MySQLHandlerFactory.h @@ -7,98 +7,106 @@ #include "IServer.h" #include "MySQLHandler.h" -namespace Poco { class Logger; } +namespace Poco +{ +class Logger; +} namespace DB { - class MySQLHandlerFactory : public Poco::Net::TCPServerConnectionFactory +class MySQLHandlerFactory : public Poco::Net::TCPServerConnectionFactory +{ +private: + IServer & server; + Poco::Logger * log; + RSA * public_key = nullptr, * private_key = nullptr; + +public: + explicit MySQLHandlerFactory(IServer & server_) + : server(server_), log(&Logger::get("MySQLHandlerFactory")) { - private: - IServer & server; - Poco::Logger * log; - RSA * public_key = nullptr, * private_key = nullptr; + /// Reading rsa keys for SHA256 authentication plugin. + const Poco::Util::LayeredConfiguration & config = Poco::Util::Application::instance().config(); + String certificateFileProperty = "openSSL.server.certificateFile"; + String privateKeyFileProperty = "openSSL.server.privateKeyFile"; - public: - explicit MySQLHandlerFactory(IServer & server_) - : server(server_) - , log(&Logger::get("MySQLHandlerFactory")) + if (!config.has(certificateFileProperty)) { - /// Reading rsa keys for SHA256 authentication plugin. - const Poco::Util::LayeredConfiguration & config = Poco::Util::Application::instance().config(); - String certificateFileProperty = "openSSL.server.certificateFile"; - String privateKeyFileProperty = "openSSL.server.privateKeyFile"; - - if (!config.has(certificateFileProperty)) - { - LOG_INFO(log, "Certificate file is not set."); - generateRSAKeys(); - return; - } - if (!config.has(privateKeyFileProperty)) { - LOG_INFO(log, "Private key file is not set."); - generateRSAKeys(); - return; - } - - String certificateFile = config.getString(certificateFileProperty); - FILE * fp = fopen(certificateFile.data(), "r"); - if (fp == nullptr) { - LOG_WARNING(log, "Cannot open certificate file: " << certificateFile << "."); - generateRSAKeys(); - return; - } - X509* x509 = PEM_read_X509(fp, nullptr, nullptr, nullptr); - EVP_PKEY* p = X509_get_pubkey(x509); - public_key = EVP_PKEY_get1_RSA(p); - X509_free(x509); - fclose(fp); - - String privateKeyFile = config.getString(privateKeyFileProperty); - fp = fopen(privateKeyFile.data(), "r"); - if (fp == nullptr) { - LOG_WARNING(log, "Cannot open private key file " << privateKeyFile << "."); - generateRSAKeys(); - return; - } - private_key = PEM_read_RSAPrivateKey(fp, nullptr, nullptr, nullptr); - fclose(fp); + LOG_INFO(log, "Certificate file is not set."); + generateRSAKeys(); + return; + } + if (!config.has(privateKeyFileProperty)) + { + LOG_INFO(log, "Private key file is not set."); + generateRSAKeys(); + return; } - void generateRSAKeys() + String certificateFile = config.getString(certificateFileProperty); + FILE * fp = fopen(certificateFile.data(), "r"); + if (fp == nullptr) { - LOG_INFO(log, "Generating new RSA key."); - RSA *rsa = RSA_new(); - if (rsa == nullptr) { - throw Exception("Failed to allocate RSA key.", 1002); - } - BIGNUM *e = BN_new(); - if (!e) { - RSA_free(rsa); - throw Exception("Failed to allocate BIGNUM.", 1002); - } - if (!BN_set_word(e, 65537) || !RSA_generate_key_ex(rsa, 2048, e, nullptr)) - { - RSA_free(rsa); - BN_free(e); - throw Exception("Failed to generate RSA key.", 1002); - } + LOG_WARNING(log, "Cannot open certificate file: " << certificateFile << "."); + generateRSAKeys(); + return; + } + X509 * x509 = PEM_read_X509(fp, nullptr, nullptr, nullptr); + EVP_PKEY * p = X509_get_pubkey(x509); + public_key = EVP_PKEY_get1_RSA(p); + X509_free(x509); + fclose(fp); + + String privateKeyFile = config.getString(privateKeyFileProperty); + fp = fopen(privateKeyFile.data(), "r"); + if (fp == nullptr) + { + LOG_WARNING(log, "Cannot open private key file " << privateKeyFile << "."); + generateRSAKeys(); + return; + } + private_key = PEM_read_RSAPrivateKey(fp, nullptr, nullptr, nullptr); + fclose(fp); + } + + void generateRSAKeys() + { + LOG_INFO(log, "Generating new RSA key."); + RSA * rsa = RSA_new(); + if (rsa == nullptr) + { + throw Exception("Failed to allocate RSA key.", 1002); + } + BIGNUM * e = BN_new(); + if (!e) + { + RSA_free(rsa); + throw Exception("Failed to allocate BIGNUM.", 1002); + } + if (!BN_set_word(e, 65537) || !RSA_generate_key_ex(rsa, 2048, e, nullptr)) + { + RSA_free(rsa); BN_free(e); - - public_key = rsa; - private_key = RSAPrivateKey_dup(rsa); + throw Exception("Failed to generate RSA key.", 1002); } + BN_free(e); - Poco::Net::TCPServerConnection * createConnection(const Poco::Net::StreamSocket & socket) override - { - LOG_TRACE(log, "MySQL connection. Address: " << socket.peerAddress().toString()); - return new MySQLHandler(server, socket, public_key, private_key); - } + public_key = rsa; + private_key = RSAPrivateKey_dup(rsa); + } - ~MySQLHandlerFactory() override { - RSA_free(public_key); - RSA_free(private_key); - } - }; + Poco::Net::TCPServerConnection * createConnection(const Poco::Net::StreamSocket & socket) override + { + LOG_TRACE(log, "MySQL connection. Address: " << socket.peerAddress().toString()); + return new MySQLHandler(server, socket, public_key, private_key); + } + + ~MySQLHandlerFactory() override + { + RSA_free(public_key); + RSA_free(private_key); + } +}; } From 9a5a0b2776fc6df5462d7c22e613b21ed1fcb966 Mon Sep 17 00:00:00 2001 From: Guillaume Tassery Date: Tue, 30 Apr 2019 13:50:17 +0700 Subject: [PATCH 081/709] Formatting --- dbms/src/Functions/firstSignificantSubdomain.h | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/dbms/src/Functions/firstSignificantSubdomain.h b/dbms/src/Functions/firstSignificantSubdomain.h index 2073fafa7dc..b76caf01b65 100644 --- a/dbms/src/Functions/firstSignificantSubdomain.h +++ b/dbms/src/Functions/firstSignificantSubdomain.h @@ -59,7 +59,7 @@ struct ExtractFirstSignificantSubdomain if (!last_3_periods[2]) last_3_periods[2] = begin - 1; - auto end_of_level_domain = find_first_symbols<'/'>(last_3_periods[0], end); + auto end_of_level_domain = find_first_symbols<'/'>(last_3_periods[0], end); if (!end_of_level_domain) { end_of_level_domain = end; From e38f6e08d838eb68e5233c83e0cc857f1413963c Mon Sep 17 00:00:00 2001 From: Ivan Kushnarenko Date: Wed, 1 May 2019 02:46:19 +0300 Subject: [PATCH 082/709] debug tsan refactor trash --- dbms/src/Storages/MergeTree/MergeTreeData.cpp | 31 ++++++++++++++----- dbms/src/Storages/MergeTree/MergeTreeData.h | 21 ++++++------- .../ReplicatedMergeTreeAlterThread.cpp | 5 +-- dbms/src/Storages/StorageMergeTree.cpp | 24 +++++--------- .../Storages/StorageReplicatedMergeTree.cpp | 5 +-- 5 files changed, 47 insertions(+), 39 deletions(-) diff --git a/dbms/src/Storages/MergeTree/MergeTreeData.cpp b/dbms/src/Storages/MergeTree/MergeTreeData.cpp index 453f680c6ba..61e9c97b6a6 100644 --- a/dbms/src/Storages/MergeTree/MergeTreeData.cpp +++ b/dbms/src/Storages/MergeTree/MergeTreeData.cpp @@ -1435,14 +1435,14 @@ void MergeTreeData::createConvertExpression(const DataPartPtr & part, const Name } } -MergeTreeData::AlterDataPartTransactionPtr MergeTreeData::alterDataPart( - const DataPartPtr & part, +void MergeTreeData::alterDataPart( const NamesAndTypesList & new_columns, const IndicesASTs & new_indices, - bool skip_sanity_checks) + bool skip_sanity_checks, + AlterDataPartTransactionPtr& transaction) { ExpressionActionsPtr expression; - AlterDataPartTransactionPtr transaction(new AlterDataPartTransaction(part)); /// Blocks changes to the part. + const auto& part = transaction->getDataPart(); bool force_update_metadata; createConvertExpression(part, part->columns, new_columns, getIndicesDescription().indices, new_indices, @@ -1504,7 +1504,7 @@ MergeTreeData::AlterDataPartTransactionPtr MergeTreeData::alterDataPart( if (transaction->rename_map.empty() && !force_update_metadata) { transaction->clear(); - return nullptr; + return; } /// Apply the expression and write the result to temporary files. @@ -1573,7 +1573,7 @@ MergeTreeData::AlterDataPartTransactionPtr MergeTreeData::alterDataPart( transaction->rename_map["columns.txt.tmp"] = "columns.txt"; } - return transaction; + return; } void MergeTreeData::removeEmptyColumnsFromPart(MergeTreeData::MutableDataPartPtr & data_part) @@ -1596,9 +1596,11 @@ void MergeTreeData::removeEmptyColumnsFromPart(MergeTreeData::MutableDataPartPtr } LOG_INFO(log, "Removing empty columns: " << log_message.str() << " from part " << data_part->name); - - if (auto transaction = alterDataPart(data_part, new_columns, getIndicesDescription().indices, false)) + AlterDataPartTransactionPtr transaction(new AlterDataPartTransaction(data_part)); + alterDataPart(new_columns, getIndicesDescription().indices, false, transaction); + if (transaction->isValid()) transaction->commit(); + empty_columns.clear(); } @@ -1607,10 +1609,21 @@ void MergeTreeData::freezeAll(const String & with_name, const Context & context) freezePartitionsByMatcher([] (const DataPartPtr &){ return true; }, with_name, context); } +bool MergeTreeData::AlterDataPartTransaction::isValid() const +{ + return data_part != nullptr; +} + +void MergeTreeData::AlterDataPartTransaction::clear() +{ + data_part = nullptr; +} + void MergeTreeData::AlterDataPartTransaction::commit() { if (!data_part) return; + try { std::unique_lock lock(data_part->columns_lock); @@ -1668,6 +1681,8 @@ void MergeTreeData::AlterDataPartTransaction::commit() MergeTreeData::AlterDataPartTransaction::~AlterDataPartTransaction() { + alter_lock.unlock(); + try { if (!data_part) diff --git a/dbms/src/Storages/MergeTree/MergeTreeData.h b/dbms/src/Storages/MergeTree/MergeTreeData.h index 34ad47cbaba..6e7ab4b47c0 100644 --- a/dbms/src/Storages/MergeTree/MergeTreeData.h +++ b/dbms/src/Storages/MergeTree/MergeTreeData.h @@ -227,16 +227,13 @@ public: const NamesAndTypesList & getNewColumns() const { return new_columns; } const DataPart::Checksums & getNewChecksums() const { return new_checksums; } + AlterDataPartTransaction(DataPartPtr data_part_) : data_part(data_part_), alter_lock(data_part->alter_mutex) {} + const DataPartPtr& getDataPart() const { return data_part; } + bool isValid() const; + private: friend class MergeTreeData; - - AlterDataPartTransaction(DataPartPtr data_part_) : data_part(data_part_), alter_lock(data_part->alter_mutex) {} - - void clear() - { - alter_lock.unlock(); - data_part = nullptr; - } + void clear(); DataPartPtr data_part; DataPartsLock alter_lock; @@ -515,11 +512,13 @@ public: /// Returns an object allowing to rename temporary files to permanent files. /// If the number of affected columns is suspiciously high and skip_sanity_checks is false, throws an exception. /// If no data transformations are necessary, returns nullptr. - AlterDataPartTransactionPtr alterDataPart( - const DataPartPtr & part, +// AlterDataPartTransactionPtr + void alterDataPart( +// const DataPartPtr & part, const NamesAndTypesList & new_columns, const IndicesASTs & new_indices, - bool skip_sanity_checks); + bool skip_sanity_checks, + AlterDataPartTransactionPtr& transaction); /// Remove columns, that have been markedd as empty after zeroing values with expired ttl void removeEmptyColumnsFromPart(MergeTreeData::MutableDataPartPtr & data_part); diff --git a/dbms/src/Storages/MergeTree/ReplicatedMergeTreeAlterThread.cpp b/dbms/src/Storages/MergeTree/ReplicatedMergeTreeAlterThread.cpp index 1b1c43e1cd1..17c4f97334a 100644 --- a/dbms/src/Storages/MergeTree/ReplicatedMergeTreeAlterThread.cpp +++ b/dbms/src/Storages/MergeTree/ReplicatedMergeTreeAlterThread.cpp @@ -150,8 +150,9 @@ void ReplicatedMergeTreeAlterThread::run() /// Update the part and write result to temporary files. /// TODO: You can skip checking for too large changes if ZooKeeper has, for example, /// node /flags/force_alter. - auto transaction = storage.data.alterDataPart(part, columns_for_parts, indices_for_parts.indices, false); - if (!transaction) + MergeTreeData::AlterDataPartTransactionPtr transaction(new MergeTreeData::AlterDataPartTransaction(part)); + storage.data.alterDataPart(columns_for_parts, indices_for_parts.indices, false, transaction); + if (!transaction->isValid()) continue; storage.updatePartHeaderInZooKeeperAndCommit(zookeeper, *transaction); diff --git a/dbms/src/Storages/StorageMergeTree.cpp b/dbms/src/Storages/StorageMergeTree.cpp index 40213898b5a..94219d15504 100644 --- a/dbms/src/Storages/StorageMergeTree.cpp +++ b/dbms/src/Storages/StorageMergeTree.cpp @@ -200,7 +200,8 @@ std::vector StorageMergeTree::prepar auto parts = data.getDataParts({MergeTreeDataPartState::PreCommitted, MergeTreeDataPartState::Committed, MergeTreeDataPartState::Outdated}); - std::vector transactions(parts.size()); + std::vector transactions; + transactions.reserve(parts.size()); const auto& columns_for_parts = new_columns.getAllPhysical(); @@ -208,29 +209,18 @@ std::vector StorageMergeTree::prepar size_t thread_pool_size = std::min(parts.size(), settings.max_alter_threads); ThreadPool thread_pool(thread_pool_size); - size_t i = 0; for (const auto & part : parts) { + transactions.push_back(MergeTreeData::AlterDataPartTransactionPtr(new MergeTreeData::AlterDataPartTransaction(part))); thread_pool.schedule( - [this, i, &transactions, &part, columns_for_parts, new_indices = new_indices.indices] + [this, &transaction = transactions.back(), columns_for_parts, new_indices = new_indices.indices] { - if (auto transaction = this->data.alterDataPart(part, columns_for_parts, new_indices, false)) - transactions[i] = std::move(transaction); + this->data.alterDataPart(columns_for_parts, new_indices, false, transaction); } ); - - ++i; } thread_pool.wait(); - auto erase_pos = std::remove_if(transactions.begin(), transactions.end(), - [](const MergeTreeData::AlterDataPartTransactionPtr & transaction) - { - return transaction == nullptr; - } - ); - transactions.erase(erase_pos, transactions.end()); - return transactions; } @@ -846,7 +836,9 @@ void StorageMergeTree::clearColumnInPartition(const ASTPtr & partition, const Fi if (part->info.partition_id != partition_id) throw Exception("Unexpected partition ID " + part->info.partition_id + ". This is a bug.", ErrorCodes::LOGICAL_ERROR); - if (auto transaction = data.alterDataPart(part, columns_for_parts, new_indices.indices, false)) + MergeTreeData::AlterDataPartTransactionPtr transaction(new MergeTreeData::AlterDataPartTransaction(part)); + data.alterDataPart(columns_for_parts, new_indices.indices, false, transaction); + if (transaction->isValid()) transactions.push_back(std::move(transaction)); LOG_DEBUG(log, "Removing column " << get(column_name) << " from part " << part->name); diff --git a/dbms/src/Storages/StorageReplicatedMergeTree.cpp b/dbms/src/Storages/StorageReplicatedMergeTree.cpp index 19751e112d7..515459814aa 100644 --- a/dbms/src/Storages/StorageReplicatedMergeTree.cpp +++ b/dbms/src/Storages/StorageReplicatedMergeTree.cpp @@ -1535,8 +1535,9 @@ void StorageReplicatedMergeTree::executeClearColumnInPartition(const LogEntry & LOG_DEBUG(log, "Clearing column " << entry.column_name << " in part " << part->name); - auto transaction = data.alterDataPart(part, columns_for_parts, new_indices.indices, false); - if (!transaction) + MergeTreeData::AlterDataPartTransactionPtr transaction(new MergeTreeData::AlterDataPartTransaction(part)); + data.alterDataPart(columns_for_parts, new_indices.indices, false, transaction); + if (!transaction->isValid()) continue; updatePartHeaderInZooKeeperAndCommit(zookeeper, *transaction); From 4a3a1fc6d9be6199db01a9977da3e255329d5820 Mon Sep 17 00:00:00 2001 From: ivan-kush Date: Wed, 1 May 2019 15:43:43 +0300 Subject: [PATCH 083/709] return transactions cleaning --- dbms/src/Storages/MergeTree/MergeTreeData.h | 2 -- dbms/src/Storages/StorageMergeTree.cpp | 8 ++++++++ 2 files changed, 8 insertions(+), 2 deletions(-) diff --git a/dbms/src/Storages/MergeTree/MergeTreeData.h b/dbms/src/Storages/MergeTree/MergeTreeData.h index 6e7ab4b47c0..b286f1cb863 100644 --- a/dbms/src/Storages/MergeTree/MergeTreeData.h +++ b/dbms/src/Storages/MergeTree/MergeTreeData.h @@ -512,9 +512,7 @@ public: /// Returns an object allowing to rename temporary files to permanent files. /// If the number of affected columns is suspiciously high and skip_sanity_checks is false, throws an exception. /// If no data transformations are necessary, returns nullptr. -// AlterDataPartTransactionPtr void alterDataPart( -// const DataPartPtr & part, const NamesAndTypesList & new_columns, const IndicesASTs & new_indices, bool skip_sanity_checks, diff --git a/dbms/src/Storages/StorageMergeTree.cpp b/dbms/src/Storages/StorageMergeTree.cpp index 94219d15504..a1781d63316 100644 --- a/dbms/src/Storages/StorageMergeTree.cpp +++ b/dbms/src/Storages/StorageMergeTree.cpp @@ -221,6 +221,14 @@ std::vector StorageMergeTree::prepar } thread_pool.wait(); + auto erase_pos = std::remove_if(transactions.begin(), transactions.end(), + [](const MergeTreeData::AlterDataPartTransactionPtr & transaction) + { + return !transaction->isValid(); + } + ); + transactions.erase(erase_pos, transactions.end()); + return transactions; } From 6ac5aa5e49c7841792af0f0eb1178b86da44e97d Mon Sep 17 00:00:00 2001 From: ivan-kush Date: Wed, 1 May 2019 18:46:17 +0300 Subject: [PATCH 084/709] restart performance --- dbms/src/Storages/MergeTree/MergeTreeData.cpp | 1 + 1 file changed, 1 insertion(+) diff --git a/dbms/src/Storages/MergeTree/MergeTreeData.cpp b/dbms/src/Storages/MergeTree/MergeTreeData.cpp index 61e9c97b6a6..3a91f73ea9b 100644 --- a/dbms/src/Storages/MergeTree/MergeTreeData.cpp +++ b/dbms/src/Storages/MergeTree/MergeTreeData.cpp @@ -1609,6 +1609,7 @@ void MergeTreeData::freezeAll(const String & with_name, const Context & context) freezePartitionsByMatcher([] (const DataPartPtr &){ return true; }, with_name, context); } + bool MergeTreeData::AlterDataPartTransaction::isValid() const { return data_part != nullptr; From 591325468b98545415b7d81504d5f1e00e25e306 Mon Sep 17 00:00:00 2001 From: ivan-kush Date: Thu, 2 May 2019 14:54:34 +0300 Subject: [PATCH 085/709] make_unique --- dbms/src/Storages/StorageMergeTree.cpp | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/dbms/src/Storages/StorageMergeTree.cpp b/dbms/src/Storages/StorageMergeTree.cpp index a1781d63316..bb14725f781 100644 --- a/dbms/src/Storages/StorageMergeTree.cpp +++ b/dbms/src/Storages/StorageMergeTree.cpp @@ -211,7 +211,7 @@ std::vector StorageMergeTree::prepar for (const auto & part : parts) { - transactions.push_back(MergeTreeData::AlterDataPartTransactionPtr(new MergeTreeData::AlterDataPartTransaction(part))); + transactions.push_back(std::make_unique(part)); thread_pool.schedule( [this, &transaction = transactions.back(), columns_for_parts, new_indices = new_indices.indices] { From 3ecb66d96501a95ffb87d088bf0415371a11c249 Mon Sep 17 00:00:00 2001 From: ivan-kush Date: Thu, 2 May 2019 16:42:09 +0300 Subject: [PATCH 086/709] debug stress address --- dbms/src/Storages/MergeTree/MergeTreeData.cpp | 15 +++++++++------ dbms/src/Storages/MergeTree/MergeTreeData.h | 3 +++ 2 files changed, 12 insertions(+), 6 deletions(-) diff --git a/dbms/src/Storages/MergeTree/MergeTreeData.cpp b/dbms/src/Storages/MergeTree/MergeTreeData.cpp index 3a91f73ea9b..bb773ee2b0b 100644 --- a/dbms/src/Storages/MergeTree/MergeTreeData.cpp +++ b/dbms/src/Storages/MergeTree/MergeTreeData.cpp @@ -1612,16 +1612,18 @@ void MergeTreeData::freezeAll(const String & with_name, const Context & context) bool MergeTreeData::AlterDataPartTransaction::isValid() const { - return data_part != nullptr; + return valid && data_part; } void MergeTreeData::AlterDataPartTransaction::clear() { - data_part = nullptr; + valid = false; } void MergeTreeData::AlterDataPartTransaction::commit() { + if (!isValid()) + return; if (!data_part) return; @@ -1682,13 +1684,14 @@ void MergeTreeData::AlterDataPartTransaction::commit() MergeTreeData::AlterDataPartTransaction::~AlterDataPartTransaction() { - alter_lock.unlock(); + + if (!isValid()) + return; + if (!data_part) + return; try { - if (!data_part) - return; - LOG_WARNING(data_part->storage.log, "Aborting ALTER of part " << data_part->relative_path); String path = data_part->getFullPath(); diff --git a/dbms/src/Storages/MergeTree/MergeTreeData.h b/dbms/src/Storages/MergeTree/MergeTreeData.h index b286f1cb863..46351fe4dc4 100644 --- a/dbms/src/Storages/MergeTree/MergeTreeData.h +++ b/dbms/src/Storages/MergeTree/MergeTreeData.h @@ -235,6 +235,9 @@ public: friend class MergeTreeData; void clear(); + bool valid = true; + + //don't interchange order of data_part & alter_lock DataPartPtr data_part; DataPartsLock alter_lock; From ea82760463b790591e45cfe085b7fedcac2b1546 Mon Sep 17 00:00:00 2001 From: ivan-kush Date: Thu, 2 May 2019 18:12:57 +0300 Subject: [PATCH 087/709] add reset --- dbms/src/Storages/StorageMergeTree.cpp | 6 ++++++ 1 file changed, 6 insertions(+) diff --git a/dbms/src/Storages/StorageMergeTree.cpp b/dbms/src/Storages/StorageMergeTree.cpp index bb14725f781..522a9517996 100644 --- a/dbms/src/Storages/StorageMergeTree.cpp +++ b/dbms/src/Storages/StorageMergeTree.cpp @@ -290,7 +290,10 @@ void StorageMergeTree::alter( data.setTTLExpressions(new_columns.getColumnTTLs(), new_ttl_table_ast); for (auto & transaction : transactions) + { transaction->commit(); + transaction.reset(); + } /// Columns sizes could be changed data.recalculateColumnSizes(); @@ -856,7 +859,10 @@ void StorageMergeTree::clearColumnInPartition(const ASTPtr & partition, const Fi return; for (auto & transaction : transactions) + { transaction->commit(); + transaction.reset(); + } /// Recalculate columns size (not only for the modified column) data.recalculateColumnSizes(); From d555a165a4ddf3b126e685d68a9215931924bdbd Mon Sep 17 00:00:00 2001 From: ivan-kush Date: Thu, 2 May 2019 21:48:38 +0300 Subject: [PATCH 088/709] debug stress address --- dbms/src/Storages/StorageMergeTree.cpp | 10 +++++++--- 1 file changed, 7 insertions(+), 3 deletions(-) diff --git a/dbms/src/Storages/StorageMergeTree.cpp b/dbms/src/Storages/StorageMergeTree.cpp index 522a9517996..9611793cb6c 100644 --- a/dbms/src/Storages/StorageMergeTree.cpp +++ b/dbms/src/Storages/StorageMergeTree.cpp @@ -200,6 +200,7 @@ std::vector StorageMergeTree::prepar auto parts = data.getDataParts({MergeTreeDataPartState::PreCommitted, MergeTreeDataPartState::Committed, MergeTreeDataPartState::Outdated}); + //std::vector transactions(parts.size()); std::vector transactions; transactions.reserve(parts.size()); @@ -209,13 +210,16 @@ std::vector StorageMergeTree::prepar size_t thread_pool_size = std::min(parts.size(), settings.max_alter_threads); ThreadPool thread_pool(thread_pool_size); + for (const auto & part : parts) - { transactions.push_back(std::make_unique(part)); + + for(size_t i = 0; i < parts.size(); ++i) + { thread_pool.schedule( - [this, &transaction = transactions.back(), columns_for_parts, new_indices = new_indices.indices] + [this, i, &transactions, &columns_for_parts, &new_indices = new_indices.indices] { - this->data.alterDataPart(columns_for_parts, new_indices, false, transaction); + this->data.alterDataPart(columns_for_parts, new_indices, false, transactions[i]); } ); } From abfb681a04c59d0157ba8ce18da884a22caf6489 Mon Sep 17 00:00:00 2001 From: ivan-kush Date: Fri, 3 May 2019 00:43:24 +0300 Subject: [PATCH 089/709] hz --- dbms/src/Storages/StorageMergeTree.cpp | 23 +++++++++++++++++------ 1 file changed, 17 insertions(+), 6 deletions(-) diff --git a/dbms/src/Storages/StorageMergeTree.cpp b/dbms/src/Storages/StorageMergeTree.cpp index 9611793cb6c..347b2d3245a 100644 --- a/dbms/src/Storages/StorageMergeTree.cpp +++ b/dbms/src/Storages/StorageMergeTree.cpp @@ -200,7 +200,6 @@ std::vector StorageMergeTree::prepar auto parts = data.getDataParts({MergeTreeDataPartState::PreCommitted, MergeTreeDataPartState::Committed, MergeTreeDataPartState::Outdated}); - //std::vector transactions(parts.size()); std::vector transactions; transactions.reserve(parts.size()); @@ -210,11 +209,10 @@ std::vector StorageMergeTree::prepar size_t thread_pool_size = std::min(parts.size(), settings.max_alter_threads); ThreadPool thread_pool(thread_pool_size); - - for (const auto & part : parts) + /*for (const auto & part : parts) transactions.push_back(std::make_unique(part)); - for(size_t i = 0; i < parts.size(); ++i) + for (size_t i = 0; i < parts.size(); ++i) { thread_pool.schedule( [this, i, &transactions, &columns_for_parts, &new_indices = new_indices.indices] @@ -222,17 +220,30 @@ std::vector StorageMergeTree::prepar this->data.alterDataPart(columns_for_parts, new_indices, false, transactions[i]); } ); + }*/ + + for (const auto & part : parts) + { + transactions.push_back(std::make_unique(part)); + + thread_pool.schedule( + [this, &transaction = transactions.back(), columns_for_parts, new_indices = new_indices.indices] + { + this->data.alterDataPart(columns_for_parts, new_indices, false, transaction); + } + ); } + thread_pool.wait(); - auto erase_pos = std::remove_if(transactions.begin(), transactions.end(), + /*auto erase_pos = std::remove_if(transactions.begin(), transactions.end(), [](const MergeTreeData::AlterDataPartTransactionPtr & transaction) { return !transaction->isValid(); } ); transactions.erase(erase_pos, transactions.end()); - + */ return transactions; } From d86d60297a30836739e22fee0689cb87fab49037 Mon Sep 17 00:00:00 2001 From: hcz Date: Mon, 6 May 2019 11:49:14 +0800 Subject: [PATCH 090/709] Add skewness and kurtosis functions --- .../AggregateFunctionStatisticsSimple.cpp | 4 + .../AggregateFunctionStatisticsSimple.h | 288 +++++++++++++++--- 2 files changed, 247 insertions(+), 45 deletions(-) diff --git a/dbms/src/AggregateFunctions/AggregateFunctionStatisticsSimple.cpp b/dbms/src/AggregateFunctions/AggregateFunctionStatisticsSimple.cpp index 1fafa6e00c9..62a02ed6234 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionStatisticsSimple.cpp +++ b/dbms/src/AggregateFunctions/AggregateFunctionStatisticsSimple.cpp @@ -56,6 +56,10 @@ void registerAggregateFunctionsStatisticsSimple(AggregateFunctionFactory & facto factory.registerFunction("varPop", createAggregateFunctionStatisticsUnary); factory.registerFunction("stddevSamp", createAggregateFunctionStatisticsUnary); factory.registerFunction("stddevPop", createAggregateFunctionStatisticsUnary); + factory.registerFunction("skewSamp", createAggregateFunctionStatisticsUnary); + factory.registerFunction("skewPop", createAggregateFunctionStatisticsUnary); + factory.registerFunction("kurtSamp", createAggregateFunctionStatisticsUnary); + factory.registerFunction("kurtPop", createAggregateFunctionStatisticsUnary); factory.registerFunction("covarSamp", createAggregateFunctionStatisticsBinary); factory.registerFunction("covarPop", createAggregateFunctionStatisticsBinary); diff --git a/dbms/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h b/dbms/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h index 3a4afd2c251..9b0f25edeca 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h +++ b/dbms/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h @@ -32,7 +32,6 @@ namespace DB namespace ErrorCodes { - extern const int LOGICAL_ERROR; extern const int DECIMAL_OVERFLOW; } @@ -79,8 +78,6 @@ struct VarMoments return std::numeric_limits::quiet_NaN(); return (m2 - m1 * m1 / m0) / (m0 - 1); } - - T get() const { throw Exception("Unexpected call", ErrorCodes::LOGICAL_ERROR); } }; template @@ -139,8 +136,174 @@ struct VarMomentsDecimal throw Exception("Decimal math overflow", ErrorCodes::DECIMAL_OVERFLOW); return convertFromDecimal, DataTypeNumber>(tmp / (m0 - 1), scale); } +}; - Float64 get() const { throw Exception("Unexpected call", ErrorCodes::LOGICAL_ERROR); } +template +struct HighOrderMoments +{ + T m0{}; + T m1{}; + T m2{}; + T m3{}; + T m4{}; + + void add(T x) + { + ++m0; + m1 += x; + m2 += x * x; + if constexpr (_level >= 3) m3 += x * x * x; + if constexpr (_level >= 4) m4 += x * x * x * x; + } + + void merge(const HighOrderMoments & rhs) + { + m0 += rhs.m0; + m1 += rhs.m1; + m2 += rhs.m2; + if constexpr (_level >= 3) m3 += rhs.m3; + if constexpr (_level >= 4) m4 += rhs.m4; + } + + void write(WriteBuffer & buf) const + { + writePODBinary(*this, buf); + } + + void read(ReadBuffer & buf) + { + readPODBinary(*this, buf); + } + + T NO_SANITIZE_UNDEFINED getPopulation() const + { + return (m2 - m1 * m1 / m0) / m0; + } + + T NO_SANITIZE_UNDEFINED getSample() const + { + if (m0 == 0) + return std::numeric_limits::quiet_NaN(); + return (m2 - m1 * m1 / m0) / (m0 - 1); + } + + T NO_SANITIZE_UNDEFINED getMoment3() const + { + return (m3 + - (3 * m2 + - 2 * m1 * m1 / m0 + ) * m1 / m0 + ) / m0; + } + + T NO_SANITIZE_UNDEFINED getMoment4() const + { + return (m4 + - (4 * m3 + - (6 * m2 + - 3 * m1 * m1 / m0 + ) * m1 / m0 + ) * m1 / m0 + ) / m0; + } +}; + +template +struct HighOrderMomentsDecimal +{ + using NativeType = typename T::NativeType; + + UInt64 m0{}; + NativeType m1{}; + NativeType m2{}; + NativeType m3{}; + NativeType m4{}; + + void add(NativeType x) + { + ++m0; + m1 += x; + + NativeType tmp; + if (common::mulOverflow(x, x, tmp) || common::addOverflow(m2, tmp, m2)) + throw Exception("Decimal math overflow", ErrorCodes::DECIMAL_OVERFLOW); + if constexpr (_level >= 3) if (common::mulOverflow(tmp, x, tmp) || common::addOverflow(m3, tmp, m3)) + throw Exception("Decimal math overflow", ErrorCodes::DECIMAL_OVERFLOW); + if constexpr (_level >= 4) if (common::mulOverflow(tmp, x, tmp) || common::addOverflow(m4, tmp, m4)) + throw Exception("Decimal math overflow", ErrorCodes::DECIMAL_OVERFLOW); + } + + void merge(const HighOrderMomentsDecimal & rhs) + { + m0 += rhs.m0; + m1 += rhs.m1; + + if (common::addOverflow(m2, rhs.m2, m2)) + throw Exception("Decimal math overflow", ErrorCodes::DECIMAL_OVERFLOW); + if constexpr (_level >= 3) if (common::addOverflow(m3, rhs.m3, m3)) + throw Exception("Decimal math overflow", ErrorCodes::DECIMAL_OVERFLOW); + if constexpr (_level >= 4) if (common::addOverflow(m4, rhs.m4, m4)) + throw Exception("Decimal math overflow", ErrorCodes::DECIMAL_OVERFLOW); + } + + void write(WriteBuffer & buf) const { writePODBinary(*this, buf); } + void read(ReadBuffer & buf) { readPODBinary(*this, buf); } + + Float64 getPopulation(UInt32 scale) const + { + if (m0 == 0) + return std::numeric_limits::infinity(); + + NativeType tmp; + if (common::mulOverflow(m1, m1, tmp) || + common::subOverflow(m2, NativeType(tmp / m0), tmp)) + throw Exception("Decimal math overflow", ErrorCodes::DECIMAL_OVERFLOW); + return convertFromDecimal, DataTypeNumber>(tmp / m0, scale); + } + + Float64 getSample(UInt32 scale) const + { + if (m0 == 0) + return std::numeric_limits::quiet_NaN(); + if (m0 == 1) + return std::numeric_limits::infinity(); + + NativeType tmp; + if (common::mulOverflow(m1, m1, tmp) || + common::subOverflow(m2, NativeType(tmp / m0), tmp)) + throw Exception("Decimal math overflow", ErrorCodes::DECIMAL_OVERFLOW); + return convertFromDecimal, DataTypeNumber>(tmp / (m0 - 1), scale); + } + + Float64 getMoment3(UInt32 scale) const + { + if (m0 == 0) + return std::numeric_limits::infinity(); + + NativeType tmp; + if (common::mulOverflow(2 * m1, m1, tmp) || + common::subOverflow(3 * m2, NativeType(tmp / m0), tmp) || + common::mulOverflow(tmp, m1, tmp) || + common::subOverflow(m3, NativeType(tmp / m0), tmp)) + throw Exception("Decimal math overflow", ErrorCodes::DECIMAL_OVERFLOW); + return convertFromDecimal, DataTypeNumber>(tmp / m0, scale); + } + + Float64 getMoment4(UInt32 scale) const + { + if (m0 == 0) + return std::numeric_limits::infinity(); + + NativeType tmp; + if (common::mulOverflow(3 * m1, m1, tmp) || + common::subOverflow(6 * m2, NativeType(tmp / m0), tmp) || + common::mulOverflow(tmp, m1, tmp) || + common::subOverflow(4 * m3, NativeType(tmp / m0), tmp) || + common::mulOverflow(tmp, m1, tmp) || + common::subOverflow(m4, NativeType(tmp / m0), tmp)) + throw Exception("Decimal math overflow", ErrorCodes::DECIMAL_OVERFLOW); + return convertFromDecimal, DataTypeNumber>(tmp / m0, scale); + } }; template @@ -188,8 +351,6 @@ struct CovarMoments return std::numeric_limits::quiet_NaN(); return (xy - x1 * y1 / m0) / (m0 - 1); } - - T get() const { throw Exception("Unexpected call", ErrorCodes::LOGICAL_ERROR); } }; template @@ -236,9 +397,6 @@ struct CorrMoments { return (m0 * xy - x1 * y1) / sqrt((m0 * x2 - x1 * x1) * (m0 * y2 - y1 * y1)); } - - T getPopulation() const { throw Exception("Unexpected call", ErrorCodes::LOGICAL_ERROR); } - T getSample() const { throw Exception("Unexpected call", ErrorCodes::LOGICAL_ERROR); } }; @@ -246,18 +404,24 @@ enum class StatisticsFunctionKind { varPop, varSamp, stddevPop, stddevSamp, + skewPop, skewSamp, + kurtPop, kurtSamp, covarPop, covarSamp, corr }; -template +template struct StatFuncOneArg { using Type1 = T; using Type2 = T; using ResultType = std::conditional_t, Float32, Float64>; - using Data = std::conditional_t, VarMomentsDecimal, VarMoments>; + using Data = std::conditional_t< + _level <= 2, + std::conditional_t, VarMomentsDecimal, VarMoments>, + std::conditional_t, HighOrderMomentsDecimal, HighOrderMoments> + >; static constexpr StatisticsFunctionKind kind = _kind; static constexpr UInt32 num_args = 1; @@ -300,17 +464,28 @@ public: String getName() const override { - switch (StatFunc::kind) - { - case StatisticsFunctionKind::varPop: return "varPop"; - case StatisticsFunctionKind::varSamp: return "varSamp"; - case StatisticsFunctionKind::stddevPop: return "stddevPop"; - case StatisticsFunctionKind::stddevSamp: return "stddevSamp"; - case StatisticsFunctionKind::covarPop: return "covarPop"; - case StatisticsFunctionKind::covarSamp: return "covarSamp"; - case StatisticsFunctionKind::corr: return "corr"; - } - __builtin_unreachable(); + if constexpr (StatFunc::kind == StatisticsFunctionKind::varPop) + return "varPop"; + if constexpr (StatFunc::kind == StatisticsFunctionKind::varSamp) + return "varSamp"; + if constexpr (StatFunc::kind == StatisticsFunctionKind::stddevPop) + return "stddevPop"; + if constexpr (StatFunc::kind == StatisticsFunctionKind::stddevSamp) + return "stddevSamp"; + if constexpr (StatFunc::kind == StatisticsFunctionKind::skewPop) + return "skewPop"; + if constexpr (StatFunc::kind == StatisticsFunctionKind::skewSamp) + return "skewSamp"; + if constexpr (StatFunc::kind == StatisticsFunctionKind::kurtPop) + return "kurtPop"; + if constexpr (StatFunc::kind == StatisticsFunctionKind::kurtSamp) + return "kurtSamp"; + if constexpr (StatFunc::kind == StatisticsFunctionKind::covarPop) + return "covarPop"; + if constexpr (StatFunc::kind == StatisticsFunctionKind::covarSamp) + return "covarSamp"; + if constexpr (StatFunc::kind == StatisticsFunctionKind::corr) + return "corr"; } DataTypePtr getReturnType() const override @@ -351,28 +526,47 @@ public: if constexpr (IsDecimalNumber) { - switch (StatFunc::kind) - { - case StatisticsFunctionKind::varPop: dst.push_back(data.getPopulation(src_scale * 2)); break; - case StatisticsFunctionKind::varSamp: dst.push_back(data.getSample(src_scale * 2)); break; - case StatisticsFunctionKind::stddevPop: dst.push_back(sqrt(data.getPopulation(src_scale * 2))); break; - case StatisticsFunctionKind::stddevSamp: dst.push_back(sqrt(data.getSample(src_scale * 2))); break; - default: - __builtin_unreachable(); - } + if constexpr (StatFunc::kind == StatisticsFunctionKind::varPop) + dst.push_back(data.getPopulation(src_scale * 2)); + if constexpr (StatFunc::kind == StatisticsFunctionKind::varSamp) + dst.push_back(data.getSample(src_scale * 2)); + if constexpr (StatFunc::kind == StatisticsFunctionKind::stddevPop) + dst.push_back(sqrt(data.getPopulation(src_scale * 2))); + if constexpr (StatFunc::kind == StatisticsFunctionKind::stddevSamp) + dst.push_back(sqrt(data.getSample(src_scale * 2))); + if constexpr (StatFunc::kind == StatisticsFunctionKind::skewPop) + dst.push_back(data.getMoment3(src_scale * 3) / pow(data.getPopulation(src_scale * 2), 1.5)); + if constexpr (StatFunc::kind == StatisticsFunctionKind::skewSamp) + dst.push_back(data.getMoment3(src_scale * 3) / pow(data.getSample(src_scale * 2), 1.5)); + if constexpr (StatFunc::kind == StatisticsFunctionKind::kurtPop) + dst.push_back(data.getMoment4(src_scale * 4) / pow(data.getPopulation(src_scale * 2), 2)); + if constexpr (StatFunc::kind == StatisticsFunctionKind::kurtSamp) + dst.push_back(data.getMoment4(src_scale * 4) / pow(data.getSample(src_scale * 2), 2)); } else { - switch (StatFunc::kind) - { - case StatisticsFunctionKind::varPop: dst.push_back(data.getPopulation()); break; - case StatisticsFunctionKind::varSamp: dst.push_back(data.getSample()); break; - case StatisticsFunctionKind::stddevPop: dst.push_back(sqrt(data.getPopulation())); break; - case StatisticsFunctionKind::stddevSamp: dst.push_back(sqrt(data.getSample())); break; - case StatisticsFunctionKind::covarPop: dst.push_back(data.getPopulation()); break; - case StatisticsFunctionKind::covarSamp: dst.push_back(data.getSample()); break; - case StatisticsFunctionKind::corr: dst.push_back(data.get()); break; - } + if constexpr (StatFunc::kind == StatisticsFunctionKind::varPop) + dst.push_back(data.getPopulation()); + if constexpr (StatFunc::kind == StatisticsFunctionKind::varSamp) + dst.push_back(data.getSample()); + if constexpr (StatFunc::kind == StatisticsFunctionKind::stddevPop) + dst.push_back(sqrt(data.getPopulation())); + if constexpr (StatFunc::kind == StatisticsFunctionKind::stddevSamp) + dst.push_back(sqrt(data.getSample())); + if constexpr (StatFunc::kind == StatisticsFunctionKind::skewPop) + dst.push_back(data.getMoment3() / pow(data.getPopulation(), 1.5)); + if constexpr (StatFunc::kind == StatisticsFunctionKind::skewSamp) + dst.push_back(data.getMoment3() / pow(data.getSample(), 1.5)); + if constexpr (StatFunc::kind == StatisticsFunctionKind::kurtPop) + dst.push_back(data.getMoment4() / pow(data.getPopulation(), 2)); + if constexpr (StatFunc::kind == StatisticsFunctionKind::kurtSamp) + dst.push_back(data.getMoment4() / pow(data.getSample(), 2)); + if constexpr (StatFunc::kind == StatisticsFunctionKind::covarPop) + dst.push_back(data.getPopulation()); + if constexpr (StatFunc::kind == StatisticsFunctionKind::covarSamp) + dst.push_back(data.getSample()); + if constexpr (StatFunc::kind == StatisticsFunctionKind::corr) + dst.push_back(data.get()); } } @@ -383,10 +577,14 @@ private: }; -template using AggregateFunctionVarPopSimple = AggregateFunctionVarianceSimple>; -template using AggregateFunctionVarSampSimple = AggregateFunctionVarianceSimple>; -template using AggregateFunctionStddevPopSimple = AggregateFunctionVarianceSimple>; -template using AggregateFunctionStddevSampSimple = AggregateFunctionVarianceSimple>; +template using AggregateFunctionVarPopSimple = AggregateFunctionVarianceSimple>; +template using AggregateFunctionVarSampSimple = AggregateFunctionVarianceSimple>; +template using AggregateFunctionStddevPopSimple = AggregateFunctionVarianceSimple>; +template using AggregateFunctionStddevSampSimple = AggregateFunctionVarianceSimple>; +template using AggregateFunctionSkewPopSimple = AggregateFunctionVarianceSimple>; +template using AggregateFunctionSkewSampSimple = AggregateFunctionVarianceSimple>; +template using AggregateFunctionKurtPopSimple = AggregateFunctionVarianceSimple>; +template using AggregateFunctionKurtSampSimple = AggregateFunctionVarianceSimple>; template using AggregateFunctionCovarPopSimple = AggregateFunctionVarianceSimple>; template using AggregateFunctionCovarSampSimple = AggregateFunctionVarianceSimple>; template using AggregateFunctionCorrSimple = AggregateFunctionVarianceSimple>; From 4f3e164c73ed1e307b97e8021b13565945bccc85 Mon Sep 17 00:00:00 2001 From: hcz Date: Mon, 6 May 2019 12:08:54 +0800 Subject: [PATCH 091/709] Fix and add tests --- .../AggregateFunctionStatisticsSimple.h | 6 ++ ...1_aggregate_functions_statistics.reference | 12 ++++ .../00181_aggregate_functions_statistics.sql | 70 +++++++++++++++++++ 3 files changed, 88 insertions(+) diff --git a/dbms/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h b/dbms/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h index 9b0f25edeca..f034fd5bbc4 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h +++ b/dbms/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h @@ -189,6 +189,9 @@ struct HighOrderMoments T NO_SANITIZE_UNDEFINED getMoment3() const { + // to avoid accuracy problem + if (m0 == 1) + return 0; return (m3 - (3 * m2 - 2 * m1 * m1 / m0 @@ -198,6 +201,9 @@ struct HighOrderMoments T NO_SANITIZE_UNDEFINED getMoment4() const { + // to avoid accuracy problem + if (m0 == 1) + return 0; return (m4 - (4 * m3 - (6 * m2 diff --git a/dbms/tests/queries/0_stateless/00181_aggregate_functions_statistics.reference b/dbms/tests/queries/0_stateless/00181_aggregate_functions_statistics.reference index b4a55ae0d66..18e8c38663e 100644 --- a/dbms/tests/queries/0_stateless/00181_aggregate_functions_statistics.reference +++ b/dbms/tests/queries/0_stateless/00181_aggregate_functions_statistics.reference @@ -5,6 +5,12 @@ nan nan 0 nan +nan +0 +nan +nan +0 +nan 0 0 nan @@ -14,6 +20,12 @@ nan nan 0 nan +nan +0 +nan +nan +0 +nan 0 0 nan diff --git a/dbms/tests/queries/0_stateless/00181_aggregate_functions_statistics.sql b/dbms/tests/queries/0_stateless/00181_aggregate_functions_statistics.sql index aeecdc20c67..4938a633810 100644 --- a/dbms/tests/queries/0_stateless/00181_aggregate_functions_statistics.sql +++ b/dbms/tests/queries/0_stateless/00181_aggregate_functions_statistics.sql @@ -30,6 +30,41 @@ SELECT FROM series ); +/* skewSamp */ + +SELECT skewSamp(x_value) FROM (SELECT x_value FROM series LIMIT 0); +SELECT skewSamp(x_value) FROM (SELECT x_value FROM series LIMIT 1); + +SELECT round(abs(res1 - res2), 6) FROM +( +SELECT + skewSamp(x_value) AS res1, + ( + sum(x_value * x_value * x_value) / count() + - 3 * sum(x_value * x_value) / count() * sum(x_value) / count() + + 2 * sum(x_value) / count() * sum(x_value) / count() * sum(x_value) / count() + ) / pow((sum(x_value * x_value) - ((sum(x_value) * sum(x_value)) / count())) / (count() - 1), 1.5) AS res2 +FROM series +); + +/* kurtSamp */ + +SELECT kurtSamp(x_value) FROM (SELECT x_value FROM series LIMIT 0); +SELECT kurtSamp(x_value) FROM (SELECT x_value FROM series LIMIT 1); + +SELECT round(abs(res1 - res2), 6) FROM +( +SELECT + kurtSamp(x_value) AS res1, + ( + sum(x_value * x_value * x_value * x_value) / count() + - 4 * sum(x_value * x_value * x_value) / count() * sum(x_value) / count() + + 6 * sum(x_value * x_value) / count() * sum(x_value) / count() * sum(x_value) / count() + - 3 * sum(x_value) / count() * sum(x_value) / count() * sum(x_value) / count() * sum(x_value) / count() + ) / pow((sum(x_value * x_value) - ((sum(x_value) * sum(x_value)) / count())) / (count() - 1), 2) AS res2 +FROM series +); + /* varPop */ SELECT varPop(x_value) FROM (SELECT x_value FROM series LIMIT 0); @@ -56,6 +91,41 @@ SELECT FROM series ); +/* skewPop */ + +SELECT skewPop(x_value) FROM (SELECT x_value FROM series LIMIT 0); +SELECT skewPop(x_value) FROM (SELECT x_value FROM series LIMIT 1); + +SELECT round(abs(res1 - res2), 6) FROM +( +SELECT + skewPop(x_value) AS res1, + ( + sum(x_value * x_value * x_value) / count() + - 3 * sum(x_value * x_value) / count() * sum(x_value) / count() + + 2 * sum(x_value) / count() * sum(x_value) / count() * sum(x_value) / count() + ) / pow((sum(x_value * x_value) - ((sum(x_value) * sum(x_value)) / count())) / count(), 1.5) AS res2 +FROM series +); + +/* kurtPop */ + +SELECT kurtPop(x_value) FROM (SELECT x_value FROM series LIMIT 0); +SELECT kurtPop(x_value) FROM (SELECT x_value FROM series LIMIT 1); + +SELECT round(abs(res1 - res2), 6) FROM +( +SELECT + kurtPop(x_value) AS res1, + ( + sum(x_value * x_value * x_value * x_value) / count() + - 4 * sum(x_value * x_value * x_value) / count() * sum(x_value) / count() + + 6 * sum(x_value * x_value) / count() * sum(x_value) / count() * sum(x_value) / count() + - 3 * sum(x_value) / count() * sum(x_value) / count() * sum(x_value) / count() * sum(x_value) / count() + ) / pow((sum(x_value * x_value) - ((sum(x_value) * sum(x_value)) / count())) / count(), 2) AS res2 +FROM series +); + /* covarSamp */ SELECT covarSamp(x_value, y_value) FROM (SELECT x_value, y_value FROM series LIMIT 0); From e0bd16c1f4e60d7c62d6e7e6044da08adc4fd2fb Mon Sep 17 00:00:00 2001 From: Guillaume Tassery Date: Mon, 6 May 2019 13:14:37 +0700 Subject: [PATCH 092/709] Backward compatibility for write progress with old version of server and client --- dbms/src/Core/Defines.h | 2 ++ dbms/src/IO/Progress.cpp | 24 +++++++++++++++++ dbms/src/IO/Progress.h | 56 ++++++++++++++++++++++++++++++---------- 3 files changed, 68 insertions(+), 14 deletions(-) diff --git a/dbms/src/Core/Defines.h b/dbms/src/Core/Defines.h index 0a3b384797d..3a8af6b81ff 100644 --- a/dbms/src/Core/Defines.h +++ b/dbms/src/Core/Defines.h @@ -56,6 +56,8 @@ #define DBMS_MIN_REVISION_WITH_LOW_CARDINALITY_TYPE 54405 +#define DBMS_MIN_REVISION_WITH_CLIENT_WRITE_INFO 54421 + /// Version of ClickHouse TCP protocol. Set to git tag with latest protocol change. #define DBMS_TCP_PROTOCOL_VERSION 54226 diff --git a/dbms/src/IO/Progress.cpp b/dbms/src/IO/Progress.cpp index 74c01135181..f6b29a6ceda 100644 --- a/dbms/src/IO/Progress.cpp +++ b/dbms/src/IO/Progress.cpp @@ -57,6 +57,30 @@ void AllProgressValueImpl::writeJSON(const ProgressValues & value, WriteBuffer & writeCString("\"}", out); } +void ReadProgressValueImpl::read(ProgressValues & value, ReadBuffer & in, UInt64 /*server_revision*/) +{ + size_t new_rows = 0; + size_t new_bytes = 0; + size_t new_total_rows = 0; + + readVarUInt(new_rows, in); + readVarUInt(new_bytes, in); + readVarUInt(new_total_rows, in); + + value.rows = new_rows; + value.bytes = new_bytes; + value.total_rows = new_total_rows; +} + + +void ReadProgressValueImpl::write(const ProgressValues & value, WriteBuffer & out, UInt64 /*client_revision*/) +{ + writeVarUInt(value.rows, out); + writeVarUInt(value.bytes, out); + writeVarUInt(value.total_rows, out); +} + + void ReadProgressValueImpl::writeJSON(const ProgressValues & value, WriteBuffer & out) { /// Numbers are written in double quotes (as strings) to avoid loss of precision diff --git a/dbms/src/IO/Progress.h b/dbms/src/IO/Progress.h index 8065b4b5a44..827fa118c63 100644 --- a/dbms/src/IO/Progress.h +++ b/dbms/src/IO/Progress.h @@ -23,34 +23,28 @@ struct ProgressValues size_t write_rows; size_t write_bytes; + template - void read(ReadBuffer & in, UInt64 server_revision) - { - ReadImpl::read(*this, in, server_revision); - } + inline void read(ReadBuffer & in, UInt64 server_revision); template - void write(WriteBuffer & out, UInt64 client_revision) const - { - WriteImpl::write(*this, out, client_revision); - } + inline void write(WriteBuffer & out, UInt64 client_revision) const; template - void writeJSON(WriteBuffer & out) const - { - WriteJSONImpl::writeJSON(*this, out); - } + inline void writeJSON(WriteBuffer & out) const; }; struct AllProgressValueImpl { static void read(ProgressValues & value, ReadBuffer & in, UInt64 server_revision); - static void write(const ProgressValues & value, WriteBuffer & out, UInt64 client_revision) ; + static void write(const ProgressValues & value, WriteBuffer & out, UInt64 client_revision); static void writeJSON(const ProgressValues & value, WriteBuffer & out); }; struct ReadProgressValueImpl : public AllProgressValueImpl { + static void read(ProgressValues & value, ReadBuffer & in, UInt64 server_revision); + static void write(const ProgressValues & value, WriteBuffer & out, UInt64 client_revision); static void writeJSON(const ProgressValues & value, WriteBuffer & out); }; @@ -198,12 +192,46 @@ void Progress::write(WriteBuffer & out, UInt64 client_revision) const getValues().write(out, client_revision); } - template void Progress::writeJSON(WriteBuffer & out) const { getValues().writeJSON(out); } +template +inline void ProgressValues::read(ReadBuffer & in, UInt64 server_revision) +{ + if (server_revision >= DBMS_MIN_REVISION_WITH_CLIENT_WRITE_INFO) + ReadImpl::read(*this, in, server_revision); + else + read(in, server_revision); +} + +template <> +inline void ProgressValues::read(ReadBuffer & in, UInt64 server_revision) +{ + ReadProgressValueImpl::read(*this, in, server_revision); +} + +template +inline void ProgressValues::write(WriteBuffer & out, UInt64 client_revision) const +{ + if (client_revision >= DBMS_MIN_REVISION_WITH_CLIENT_WRITE_INFO) + WriteImpl::write(*this, out, client_revision); + else + write(out, client_revision); +} + +template <> +inline void ProgressValues::write(WriteBuffer & out, UInt64 client_revision) const +{ + ReadProgressValueImpl::write(*this, out, client_revision); +} + +template +void ProgressValues::writeJSON(WriteBuffer & out) const +{ + WriteJSONImpl::writeJSON(*this, out); +} } From 55842dce102bea37206b66dbd977b6920611e4e6 Mon Sep 17 00:00:00 2001 From: Guillaume Tassery Date: Mon, 6 May 2019 13:57:48 +0700 Subject: [PATCH 093/709] code style --- dbms/src/IO/Progress.cpp | 12 ++++++------ dbms/src/IO/Progress.h | 6 +++--- dbms/src/IO/WriteBufferFromHTTPServerResponse.cpp | 4 ++-- dbms/src/Interpreters/executeQuery.cpp | 2 +- 4 files changed, 12 insertions(+), 12 deletions(-) diff --git a/dbms/src/IO/Progress.cpp b/dbms/src/IO/Progress.cpp index f6b29a6ceda..bdff0ce0d92 100644 --- a/dbms/src/IO/Progress.cpp +++ b/dbms/src/IO/Progress.cpp @@ -15,19 +15,19 @@ void AllProgressValueImpl::read(ProgressValues & value, ReadBuffer & in, UInt64 size_t new_total_rows = 0; size_t new_write_rows = 0; size_t new_write_bytes = 0; - + readVarUInt(new_rows, in); readVarUInt(new_bytes, in); readVarUInt(new_total_rows, in); readVarUInt(new_write_rows, in); readVarUInt(new_write_bytes, in); - + value.rows = new_rows; value.bytes = new_bytes; value.total_rows = new_total_rows; value.write_rows = new_write_rows; value.write_bytes = new_write_bytes; -} +} void AllProgressValueImpl::write(const ProgressValues & value, WriteBuffer & out, UInt64 /*client_revision*/) @@ -62,15 +62,15 @@ void ReadProgressValueImpl::read(ProgressValues & value, ReadBuffer & in, UInt64 size_t new_rows = 0; size_t new_bytes = 0; size_t new_total_rows = 0; - + readVarUInt(new_rows, in); readVarUInt(new_bytes, in); readVarUInt(new_total_rows, in); - + value.rows = new_rows; value.bytes = new_bytes; value.total_rows = new_total_rows; -} +} void ReadProgressValueImpl::write(const ProgressValues & value, WriteBuffer & out, UInt64 /*client_revision*/) diff --git a/dbms/src/IO/Progress.h b/dbms/src/IO/Progress.h index 827fa118c63..e2b31eeb421 100644 --- a/dbms/src/IO/Progress.h +++ b/dbms/src/IO/Progress.h @@ -21,7 +21,7 @@ struct ProgressValues size_t bytes; size_t total_rows; size_t write_rows; - size_t write_bytes; + size_t write_bytes; template @@ -152,7 +152,7 @@ struct Progress res.total_rows = total_rows.fetch_and(0); res.write_rows = write_rows.fetch_and(0); res.write_bytes = write_bytes.fetch_and(0); - + return res; } @@ -163,7 +163,7 @@ struct Progress total_rows = other.total_rows.load(std::memory_order_relaxed); write_rows = other.write_rows.load(std::memory_order_relaxed); write_bytes = other.write_bytes.load(std::memory_order_relaxed); - + return *this; } diff --git a/dbms/src/IO/WriteBufferFromHTTPServerResponse.cpp b/dbms/src/IO/WriteBufferFromHTTPServerResponse.cpp index 0f63eb68496..6d740f4162c 100644 --- a/dbms/src/IO/WriteBufferFromHTTPServerResponse.cpp +++ b/dbms/src/IO/WriteBufferFromHTTPServerResponse.cpp @@ -40,7 +40,7 @@ void WriteBufferFromHTTPServerResponse::writeHeaderSummary() { if (headers_finished_sending) return; - + WriteBufferFromOwnString progress_string_writer; accumulated_progress.writeJSON(progress_string_writer); @@ -53,7 +53,7 @@ void WriteBufferFromHTTPServerResponse::writeHeaderProgress() { if (headers_finished_sending) return; - + WriteBufferFromOwnString progress_string_writer; accumulated_progress.writeJSON(progress_string_writer); diff --git a/dbms/src/Interpreters/executeQuery.cpp b/dbms/src/Interpreters/executeQuery.cpp index b67ce8334f2..4cd51559df7 100644 --- a/dbms/src/Interpreters/executeQuery.cpp +++ b/dbms/src/Interpreters/executeQuery.cpp @@ -317,7 +317,7 @@ static std::tuple executeQueryImpl( elem.written_bytes = info.written_bytes; auto progress_callback = context.getProgressCallback(); - + if (progress_callback) progress_callback(Progress(WriteProgress(info.written_rows, info.written_bytes))); From c389830aed4f78cc512ec142fd3253cbcd14fb42 Mon Sep 17 00:00:00 2001 From: BayoNet Date: Mon, 6 May 2019 11:25:46 +0300 Subject: [PATCH 094/709] DOCAPI-6550: Description of the 'basename' function. --- .../functions/other_functions.md | 38 +++++++++++++++++++ 1 file changed, 38 insertions(+) diff --git a/docs/en/query_language/functions/other_functions.md b/docs/en/query_language/functions/other_functions.md index 7b8d54b7993..a6e6ddef1d9 100644 --- a/docs/en/query_language/functions/other_functions.md +++ b/docs/en/query_language/functions/other_functions.md @@ -4,6 +4,44 @@ Returns a string with the name of the host that this function was performed on. For distributed processing, this is the name of the remote server host, if the function is performed on a remote server. +## basename + +Extracts trailing part of a string after the last slash or backslash. + +``` +basename( expr ) +``` + +**Parameters** + +`expr` — Expression, resulting in the [String](../../data_types/string.md)-type value. + +**Returned value** + +A string-type value that contains: + +- Trailing part of a string after the last slash or backslash in it. +- Original string if there is no slashes or backslashes in it. + +**Example** + +```sql +SELECT basename(a), 'some/long/path/to/file' AS a +``` +```text +┌─basename('some/long/path/to/file')─┬─a──────────────────────┐ +│ file │ some/long/path/to/file │ +└────────────────────────────────────┴────────────────────────┘ +``` +```sql +SELECT basename(a), 'some-file-name' AS a +``` +```text +┌─basename('some-file-name')─┬─a──────────────┐ +│ some-file-name │ some-file-name │ +└────────────────────────────┴────────────────┘ +``` + ## visibleWidth(x) Calculates the approximate width when outputting values to the console in text format (tab-separated). From 7d578edc85aeaf0436b72276bd5fa1ced7cd7fed Mon Sep 17 00:00:00 2001 From: Guillaume Tassery Date: Mon, 6 May 2019 16:09:45 +0700 Subject: [PATCH 095/709] Check null values for when we send summary header --- dbms/src/IO/WriteBufferFromHTTPServerResponse.cpp | 3 ++- 1 file changed, 2 insertions(+), 1 deletion(-) diff --git a/dbms/src/IO/WriteBufferFromHTTPServerResponse.cpp b/dbms/src/IO/WriteBufferFromHTTPServerResponse.cpp index 6d740f4162c..e00f7273141 100644 --- a/dbms/src/IO/WriteBufferFromHTTPServerResponse.cpp +++ b/dbms/src/IO/WriteBufferFromHTTPServerResponse.cpp @@ -45,7 +45,8 @@ void WriteBufferFromHTTPServerResponse::writeHeaderSummary() accumulated_progress.writeJSON(progress_string_writer); #if defined(POCO_CLICKHOUSE_PATCH) - *response_header_ostr << "X-ClickHouse-Summary: " << progress_string_writer.str() << "\r\n" << std::flush; + if (response_header_ostr) + *response_header_ostr << "X-ClickHouse-Summary: " << progress_string_writer.str() << "\r\n" << std::flush; #endif } From 78672f43e17cc7d9cee3edf1a045dd22453cd798 Mon Sep 17 00:00:00 2001 From: BayoNet Date: Mon, 6 May 2019 12:46:13 +0300 Subject: [PATCH 096/709] Mentioned a Brotli compression for HTTP-interface. --- docs/en/interfaces/http.md | 10 ++++++++-- 1 file changed, 8 insertions(+), 2 deletions(-) diff --git a/docs/en/interfaces/http.md b/docs/en/interfaces/http.md index e1d1708a04e..9024806ce55 100644 --- a/docs/en/interfaces/http.md +++ b/docs/en/interfaces/http.md @@ -133,8 +133,14 @@ You can use the internal ClickHouse compression format when transmitting data. T If you specified `compress=1` in the URL, the server compresses the data it sends you. If you specified `decompress=1` in the URL, the server decompresses the same data that you pass in the `POST` method. -It is also possible to use standard `gzip`-based [HTTP compression](https://en.wikipedia.org/wiki/HTTP_compression). To send a `POST` request compressed using `gzip`, append the request header `Content-Encoding: gzip`. -In order for ClickHouse to compress the response using `gzip`, you must append `Accept-Encoding: gzip` to the request headers, and enable the ClickHouse [enable_http_compression](../operations/settings/settings.md#settings-enable_http_compression) setting. You can configure the compression level of the data with the [http_zlib_compression_level](#settings-http_zlib_compression_level) setting. +It is also possible to use other compression methods for HTTP data. To send a `POST` request compressed, append the request header `Content-Encoding: compression_method`. In order for ClickHouse to compress the response, you must append `Accept-Encoding: compression_method`. You can use the following compression methods: + +- Standard `gzip`-based [HTTP compression](https://en.wikipedia.org/wiki/HTTP_compression) (`compression_method = gzip`). + + You should use the ClickHouse [enable_http_compression](../operations/settings/settings.md#settings-enable_http_compression) setting. You can configure the compression level of the data with the [http_zlib_compression_level](#settings-http_zlib_compression_level) setting. + +- [Brotli](https://en.wikipedia.org/wiki/Brotli) compression (`compression_method = br`). + You can use this to reduce network traffic when transmitting a large amount of data, or for creating dumps that are immediately compressed. From 3f8121d34fcf0c71b5d7cee448eefe1857545bb7 Mon Sep 17 00:00:00 2001 From: Guillaume Tassery Date: Mon, 6 May 2019 17:23:06 +0700 Subject: [PATCH 097/709] format code style --- dbms/src/Functions/tldLookup.h | 6 +++--- 1 file changed, 3 insertions(+), 3 deletions(-) diff --git a/dbms/src/Functions/tldLookup.h b/dbms/src/Functions/tldLookup.h index d7629faf4c9..08cb0e4333f 100644 --- a/dbms/src/Functions/tldLookup.h +++ b/dbms/src/Functions/tldLookup.h @@ -4,10 +4,10 @@ // Definition of the class generated by gperf, present on gperf/tldLookup.gperf class tldLookupHash { -private: - static inline unsigned int hash (const char *str, size_t len); +private: + static inline unsigned int hash (const char *str, size_t len); public: - static const char *is_valid (const char *str, size_t len); + static const char *is_valid (const char *str, size_t len); }; namespace DB From 46ea2903a916f1f31f9575ecd53acfc06b5c2c19 Mon Sep 17 00:00:00 2001 From: Guillaume Tassery Date: Mon, 6 May 2019 20:09:11 +0700 Subject: [PATCH 098/709] Update test 00754_first_significant_subdomain_more --- .../00754_first_significant_subdomain_more.reference | 6 +++--- 1 file changed, 3 insertions(+), 3 deletions(-) diff --git a/dbms/tests/queries/0_stateless/00754_first_significant_subdomain_more.reference b/dbms/tests/queries/0_stateless/00754_first_significant_subdomain_more.reference index 1163aa3ee27..0b3273b70e5 100644 --- a/dbms/tests/queries/0_stateless/00754_first_significant_subdomain_more.reference +++ b/dbms/tests/queries/0_stateless/00754_first_significant_subdomain_more.reference @@ -1,3 +1,3 @@ -usa -pentagon -stanford +gov +mil +edu From 52f4d508bfbbb430d9ca2a6619119ffc2e3257cb Mon Sep 17 00:00:00 2001 From: BayoNet Date: Mon, 6 May 2019 21:09:28 +0300 Subject: [PATCH 099/709] DOCAPI-3822: Some corrections. --- docs/en/operations/server_settings/settings.md | 6 +++--- docs/zh/faq/general.md | 2 +- 2 files changed, 4 insertions(+), 4 deletions(-) diff --git a/docs/en/operations/server_settings/settings.md b/docs/en/operations/server_settings/settings.md index d73c7205293..8b4285c422e 100644 --- a/docs/en/operations/server_settings/settings.md +++ b/docs/en/operations/server_settings/settings.md @@ -668,7 +668,7 @@ Path to the file that contains: Contains settings that allow ClickHouse to interact with [ZooKeeper](http://zookeeper.apache.org/) cluster. -ClickHouse uses ZooKeeper for storing replicas' metadata when using replicated tables. If replicated tables are not used, this parameter section can be omitted. +ClickHouse uses ZooKeeper for storing metadata of replicas when using replicated tables. If replicated tables are not used, this parameter section can be omitted. This parameter section contains the following parameters: @@ -683,7 +683,7 @@ This parameter section contains the following parameters: ``` - The `index` attribute specify an order of node, when trying to connect to ZooKeeper cluster. + The `index` attribute specifies an order of node, when trying to connect to ZooKeeper cluster. - `session_timeout` — Maximum timeout for client session in milliseconds. - `root` — ZNode, that is used as root for znodes used by ClickHouse server. Optional. @@ -712,7 +712,7 @@ This parameter section contains the following parameters: **See Also** - [Replication](../../operations/table_engines/replication.md) -- [ZooKeeper Programmer's Guide](http://zookeeper.apache.org/doc/r3.3.4/zookeeperProgrammers.html) +- [ZooKeeper Programmer's Guide](http://zookeeper.apache.org/doc/current/zookeeperProgrammers.html) ## use_minimalistic_part_header_in_zookeeper {#server-settings-use_minimalistic_part_header_in_zookeeper} diff --git a/docs/zh/faq/general.md b/docs/zh/faq/general.md index 1f0121133f7..a7568cc60b0 100644 --- a/docs/zh/faq/general.md +++ b/docs/zh/faq/general.md @@ -16,7 +16,7 @@ If you use Oracle through ODBC driver as a source of external dictionaries, you **Example** ``` -NLS_LANG=RUSSIAN_RUSSIA.UTF8 +NLS_LANG=CHINESE_CHINA.ZHS16GBK ``` [来源文章](https://clickhouse.yandex/docs/zh/faq/general/) From 95626b068d7adf40dd86bc3fa4a1ec25c5375db8 Mon Sep 17 00:00:00 2001 From: BayoNet Date: Tue, 7 May 2019 17:56:46 +0300 Subject: [PATCH 100/709] DOCAPI-6550: Some clarifications. --- docs/en/interfaces/http.md | 2 +- .../en/query_language/functions/other_functions.md | 14 ++++++++++++-- 2 files changed, 13 insertions(+), 3 deletions(-) diff --git a/docs/en/interfaces/http.md b/docs/en/interfaces/http.md index 9024806ce55..a6c913cec9e 100644 --- a/docs/en/interfaces/http.md +++ b/docs/en/interfaces/http.md @@ -135,7 +135,7 @@ If you specified `decompress=1` in the URL, the server decompresses the same dat It is also possible to use other compression methods for HTTP data. To send a `POST` request compressed, append the request header `Content-Encoding: compression_method`. In order for ClickHouse to compress the response, you must append `Accept-Encoding: compression_method`. You can use the following compression methods: -- Standard `gzip`-based [HTTP compression](https://en.wikipedia.org/wiki/HTTP_compression) (`compression_method = gzip`). +- Common gzip-based [HTTP compression](https://en.wikipedia.org/wiki/HTTP_compression) (`compression_method = gzip`). You should use the ClickHouse [enable_http_compression](../operations/settings/settings.md#settings-enable_http_compression) setting. You can configure the compression level of the data with the [http_zlib_compression_level](#settings-http_zlib_compression_level) setting. diff --git a/docs/en/query_language/functions/other_functions.md b/docs/en/query_language/functions/other_functions.md index a6e6ddef1d9..d89c60010fc 100644 --- a/docs/en/query_language/functions/other_functions.md +++ b/docs/en/query_language/functions/other_functions.md @@ -6,12 +6,14 @@ Returns a string with the name of the host that this function was performed on. ## basename -Extracts trailing part of a string after the last slash or backslash. +Extracts trailing part of a string after the last slash or backslash. This function if often used to extract the filename from the path. ``` basename( expr ) ``` +Backslashes should be escaped in `expr`. + **Parameters** `expr` — Expression, resulting in the [String](../../data_types/string.md)-type value. @@ -21,7 +23,7 @@ basename( expr ) A string-type value that contains: - Trailing part of a string after the last slash or backslash in it. -- Original string if there is no slashes or backslashes in it. +- Original string if there are no slashes or backslashes in it. **Example** @@ -34,6 +36,14 @@ SELECT basename(a), 'some/long/path/to/file' AS a └────────────────────────────────────┴────────────────────────┘ ``` ```sql +SELECT basename(a), 'some\\long\\path\\to\\file' AS a +``` +```text +┌─basename('some\\long\\path\\to\\file')─┬─a──────────────────────┐ +│ file │ some\long\path\to\file │ +└────────────────────────────────────────┴────────────────────────┘ +``` +```sql SELECT basename(a), 'some-file-name' AS a ``` ```text From d53efd16055faa164d1aac5598858bdaf14ecc97 Mon Sep 17 00:00:00 2001 From: BayoNet Date: Tue, 7 May 2019 18:07:29 +0300 Subject: [PATCH 101/709] DOCAPI-6550: Some clarifications. --- .../functions/other_functions.md | 27 ++++++++++--------- 1 file changed, 15 insertions(+), 12 deletions(-) diff --git a/docs/en/query_language/functions/other_functions.md b/docs/en/query_language/functions/other_functions.md index d89c60010fc..a89cc9f6722 100644 --- a/docs/en/query_language/functions/other_functions.md +++ b/docs/en/query_language/functions/other_functions.md @@ -23,33 +23,36 @@ Backslashes should be escaped in `expr`. A string-type value that contains: - Trailing part of a string after the last slash or backslash in it. + + If the input string contains a path, ending with slash or backslash, for example, `\` or `\home\`, the function returns an empty string. + - Original string if there are no slashes or backslashes in it. **Example** ```sql -SELECT basename(a), 'some/long/path/to/file' AS a +SELECT 'some/long/path/to/file' AS a, basename(a) ``` ```text -┌─basename('some/long/path/to/file')─┬─a──────────────────────┐ -│ file │ some/long/path/to/file │ -└────────────────────────────────────┴────────────────────────┘ +┌─a──────────────────────┬─basename('some\\long\\path\\to\\file')─┐ +│ some\long\path\to\file │ file │ +└────────────────────────┴────────────────────────────────────────┘ ``` ```sql -SELECT basename(a), 'some\\long\\path\\to\\file' AS a +SELECT 'some\\long\\path\\to\\file' AS a, basename(a) ``` ```text -┌─basename('some\\long\\path\\to\\file')─┬─a──────────────────────┐ -│ file │ some\long\path\to\file │ -└────────────────────────────────────────┴────────────────────────┘ +┌─a──────────────────────┬─basename('some\\long\\path\\to\\file')─┐ +│ some\long\path\to\file │ file │ +└────────────────────────┴────────────────────────────────────────┘ ``` ```sql -SELECT basename(a), 'some-file-name' AS a +SELECT 'some-file-name' AS a, basename(a) ``` ```text -┌─basename('some-file-name')─┬─a──────────────┐ -│ some-file-name │ some-file-name │ -└────────────────────────────┴────────────────┘ +┌─a──────────────┬─basename('some-file-name')─┐ +│ some-file-name │ some-file-name │ +└────────────────┴────────────────────────────┘ ``` ## visibleWidth(x) From 411238bb57b66e81e74f9527c2c514d409958d4f Mon Sep 17 00:00:00 2001 From: BayoNet Date: Tue, 7 May 2019 18:18:28 +0300 Subject: [PATCH 102/709] DOCAPI-6550: Some clarifications. --- docs/en/interfaces/http.md | 5 ++--- 1 file changed, 2 insertions(+), 3 deletions(-) diff --git a/docs/en/interfaces/http.md b/docs/en/interfaces/http.md index a6c913cec9e..bc2a1012b2f 100644 --- a/docs/en/interfaces/http.md +++ b/docs/en/interfaces/http.md @@ -136,11 +136,10 @@ If you specified `decompress=1` in the URL, the server decompresses the same dat It is also possible to use other compression methods for HTTP data. To send a `POST` request compressed, append the request header `Content-Encoding: compression_method`. In order for ClickHouse to compress the response, you must append `Accept-Encoding: compression_method`. You can use the following compression methods: - Common gzip-based [HTTP compression](https://en.wikipedia.org/wiki/HTTP_compression) (`compression_method = gzip`). - - You should use the ClickHouse [enable_http_compression](../operations/settings/settings.md#settings-enable_http_compression) setting. You can configure the compression level of the data with the [http_zlib_compression_level](#settings-http_zlib_compression_level) setting. - - [Brotli](https://en.wikipedia.org/wiki/Brotli) compression (`compression_method = br`). +- [Deflate](https://en.wikipedia.org/wiki/DEFLATE) compression (`compression_method = deflate`). +You should use the ClickHouse [enable_http_compression](../operations/settings/settings.md#settings-enable_http_compression) setting. You can configure the compression level of the data with the [http_zlib_compression_level](#settings-http_zlib_compression_level) setting. You can use this to reduce network traffic when transmitting a large amount of data, or for creating dumps that are immediately compressed. From 2843d14a33e586b0568b2d3fb0d65c36eedee0b4 Mon Sep 17 00:00:00 2001 From: BayoNet Date: Tue, 7 May 2019 18:20:07 +0300 Subject: [PATCH 103/709] DOCAPI-6550: Some clarifications. --- docs/en/interfaces/http.md | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/docs/en/interfaces/http.md b/docs/en/interfaces/http.md index bc2a1012b2f..fd2d53a1429 100644 --- a/docs/en/interfaces/http.md +++ b/docs/en/interfaces/http.md @@ -139,7 +139,7 @@ It is also possible to use other compression methods for HTTP data. To send a `P - [Brotli](https://en.wikipedia.org/wiki/Brotli) compression (`compression_method = br`). - [Deflate](https://en.wikipedia.org/wiki/DEFLATE) compression (`compression_method = deflate`). -You should use the ClickHouse [enable_http_compression](../operations/settings/settings.md#settings-enable_http_compression) setting. You can configure the compression level of the data with the [http_zlib_compression_level](#settings-http_zlib_compression_level) setting. +To enable HTTP compression, you must use the ClickHouse [enable_http_compression](../operations/settings/settings.md#settings-enable_http_compression) setting. You can configure the compression level of the data with the [http_zlib_compression_level](#settings-http_zlib_compression_level) setting for all the compression methods. You can use this to reduce network traffic when transmitting a large amount of data, or for creating dumps that are immediately compressed. From 5bde1c69ab983c3e5768ef9631b6e483f296df0b Mon Sep 17 00:00:00 2001 From: ivan-kush Date: Tue, 7 May 2019 23:41:15 +0300 Subject: [PATCH 104/709] last try? --- dbms/src/Storages/StorageMergeTree.cpp | 18 +++--------------- 1 file changed, 3 insertions(+), 15 deletions(-) diff --git a/dbms/src/Storages/StorageMergeTree.cpp b/dbms/src/Storages/StorageMergeTree.cpp index 347b2d3245a..16e74c266ed 100644 --- a/dbms/src/Storages/StorageMergeTree.cpp +++ b/dbms/src/Storages/StorageMergeTree.cpp @@ -209,25 +209,13 @@ std::vector StorageMergeTree::prepar size_t thread_pool_size = std::min(parts.size(), settings.max_alter_threads); ThreadPool thread_pool(thread_pool_size); - /*for (const auto & part : parts) - transactions.push_back(std::make_unique(part)); - - for (size_t i = 0; i < parts.size(); ++i) - { - thread_pool.schedule( - [this, i, &transactions, &columns_for_parts, &new_indices = new_indices.indices] - { - this->data.alterDataPart(columns_for_parts, new_indices, false, transactions[i]); - } - ); - }*/ for (const auto & part : parts) { transactions.push_back(std::make_unique(part)); thread_pool.schedule( - [this, &transaction = transactions.back(), columns_for_parts, new_indices = new_indices.indices] + [this, &transaction = transactions.back(), &columns_for_parts, &new_indices = new_indices.indices] { this->data.alterDataPart(columns_for_parts, new_indices, false, transaction); } @@ -236,14 +224,14 @@ std::vector StorageMergeTree::prepar thread_pool.wait(); - /*auto erase_pos = std::remove_if(transactions.begin(), transactions.end(), + auto erase_pos = std::remove_if(transactions.begin(), transactions.end(), [](const MergeTreeData::AlterDataPartTransactionPtr & transaction) { return !transaction->isValid(); } ); transactions.erase(erase_pos, transactions.end()); - */ + return transactions; } From 26c628e0b775dd41c1f1cd4be3b327bfe759f0a0 Mon Sep 17 00:00:00 2001 From: BayoNet Date: Wed, 8 May 2019 10:32:50 +0300 Subject: [PATCH 105/709] DOCAPI-6181: Prepared placeholder for the future section about Parquet format. --- docs/en/interfaces/formats.md | 6 ++++++ 1 file changed, 6 insertions(+) diff --git a/docs/en/interfaces/formats.md b/docs/en/interfaces/formats.md index 38e8ab3194a..5dffe43d60f 100644 --- a/docs/en/interfaces/formats.md +++ b/docs/en/interfaces/formats.md @@ -24,6 +24,7 @@ The table below lists supported formats and how they can be used in `INSERT` and | [PrettyNoEscapes](#prettynoescapes) | ✗ | ✔ | | [PrettySpace](#prettyspace) | ✗ | ✔ | | [Protobuf](#protobuf) | ✔ | ✔ | +| [Parquet](#data-format-parquet) | ✔ | ✔ | | [RowBinary](#rowbinary) | ✔ | ✔ | | [Native](#native) | ✔ | ✔ | | [Null](#null) | ✗ | ✔ | @@ -711,6 +712,11 @@ ClickHouse inputs and outputs protobuf messages in the `length-delimited` format It means before every message should be written its length as a [varint](https://developers.google.com/protocol-buffers/docs/encoding#varints). See also [how to read/write length-delimited protobuf messages in popular languages](https://cwiki.apache.org/confluence/display/GEODE/Delimiting+Protobuf+Messages). +## Parquet {#data-format-parquet} + +[Apache Parquet](http://parquet.apache.org/) format. + + ## Format Schema {#formatschema} The file name containing the format schema is set by the setting `format_schema`. From b7f4d1ace12cd8461db5400a9c54555387b678e7 Mon Sep 17 00:00:00 2001 From: Vasily Nemkov Date: Fri, 10 May 2019 09:10:29 +0300 Subject: [PATCH 106/709] A script to set symlinks to docs missing in other languages. --- docs/tools/make_links.sh | 23 +++++++++++++++++++++++ 1 file changed, 23 insertions(+) create mode 100755 docs/tools/make_links.sh diff --git a/docs/tools/make_links.sh b/docs/tools/make_links.sh new file mode 100755 index 00000000000..cca2f5feb6b --- /dev/null +++ b/docs/tools/make_links.sh @@ -0,0 +1,23 @@ +#!/bin/bash + +# Fixes missing documentation in other languages +# by putting relative symbolic links to the original doc file. +# This is to be run from root of language directory, like "docs/en". + +function do_make_links() +{ + langs=(en ru fa zh) + src_file="$1" + for lang in "${langs[@]}" + do + # replacing "/./" with / + dst_file="../${lang}/${src_file}" + dst_file="${dst_file/\/\.\//\/}" + + mkdir -p $(dirname "${dst_file}") + ln -sr "${src_file}" "${dst_file}" + done +} + +export -f do_make_links +find . -iname '*.md' -exec /bin/bash -c 'do_make_links "{}"' \; From 4c17864685ac2295819bd345a80158ea599fa246 Mon Sep 17 00:00:00 2001 From: Vasily Nemkov Date: Mon, 6 May 2019 20:33:14 +0300 Subject: [PATCH 107/709] IPv4 and IPv6 domain docs. --- docs/en/data_types/domains/ipv4.md | 79 +++++++++++++++++++ docs/en/data_types/domains/ipv6.md | 79 +++++++++++++++++++ docs/en/data_types/domains/overview.md | 26 ++++++ .../functions/ip_address_functions.md | 65 ++++++++++++++- docs/fa/data_types/domains/ipv4.md | 1 + docs/fa/data_types/domains/ipv6.md | 1 + docs/fa/data_types/domains/overview.md | 1 + docs/ru/data_types/domains/ipv4.md | 1 + docs/ru/data_types/domains/ipv6.md | 1 + docs/ru/data_types/domains/overview.md | 1 + docs/toc_en.yml | 4 + docs/toc_fa.yml | 4 + docs/toc_ru.yml | 4 + docs/toc_zh.yml | 4 + docs/zh/data_types/domains/ipv4.md | 1 + docs/zh/data_types/domains/ipv6.md | 1 + docs/zh/data_types/domains/overview.md | 1 + 17 files changed, 273 insertions(+), 1 deletion(-) create mode 100644 docs/en/data_types/domains/ipv4.md create mode 100644 docs/en/data_types/domains/ipv6.md create mode 100644 docs/en/data_types/domains/overview.md create mode 120000 docs/fa/data_types/domains/ipv4.md create mode 120000 docs/fa/data_types/domains/ipv6.md create mode 120000 docs/fa/data_types/domains/overview.md create mode 120000 docs/ru/data_types/domains/ipv4.md create mode 120000 docs/ru/data_types/domains/ipv6.md create mode 120000 docs/ru/data_types/domains/overview.md create mode 120000 docs/zh/data_types/domains/ipv4.md create mode 120000 docs/zh/data_types/domains/ipv6.md create mode 120000 docs/zh/data_types/domains/overview.md diff --git a/docs/en/data_types/domains/ipv4.md b/docs/en/data_types/domains/ipv4.md new file mode 100644 index 00000000000..dd7e08d673e --- /dev/null +++ b/docs/en/data_types/domains/ipv4.md @@ -0,0 +1,79 @@ +## IPv4 + +`IPv4` is a domain based on `UInt32` type and serves as typed replacement for storing IPv4 values. It provides compact storage with human-friendly input-output format, and column type information on inspection. + +### Basic Usage + +``` sql +CREATE TABLE hits (url String, from IPv4) ENGINE = MergeTree() ORDER BY url; + +DESCRIBE TABLE hits; +``` + +``` +┌─name─┬─type───┬─default_type─┬─default_expression─┬─comment─┬─codec_expression─┐ +│ url │ String │ │ │ │ │ +│ from │ IPv4 │ │ │ │ │ +└──────┴────────┴──────────────┴────────────────────┴─────────┴──────────────────┘ +``` + +OR you can use IPv4 domain as a key: + +``` sql +CREATE TABLE hits (url String, from IPv4) ENGINE = MergeTree() ORDER BY from; +``` + +`IPv4` domain supports custom input format as IPv4-strings: + +``` sql +INSERT INTO hits (url, from) VALUES ('https://wikipedia.org', '116.253.40.133')('https://clickhouse.yandex', '183.247.232.58')('https://clickhouse.yandex/docs/en/', '116.106.34.242'); + +SELECT * FROM hits; +``` + +``` +┌─url────────────────────────────────┬───────────from─┐ +│ https://clickhouse.yandex/docs/en/ │ 116.106.34.242 │ +│ https://wikipedia.org │ 116.253.40.133 │ +│ https://clickhouse.yandex │ 183.247.232.58 │ +└────────────────────────────────────┴────────────────┘ +``` + +Values are stored in compact binary form: + +``` sql +SELECT toTypeName(from), hex(from) FROM hits LIMIT 1; +``` + +``` +┌─toTypeName(from)─┬─hex(from)─┐ +│ IPv4 │ B7F7E83A │ +└──────────────────┴───────────┘ +``` + +Domain values are not implicitly convertible to types other than `UInt32`. +If you want to convert `IPv4` value to a string, you have to do that explicitly with `IPv4NumToString()` function: + +``` sql +SELECT toTypeName(s), IPv4NumToString(from) as s FROM hits LIMIT 1; +``` + +``` +┌─toTypeName(IPv4NumToString(from))─┬─s──────────────┐ +│ String │ 183.247.232.58 │ +└───────────────────────────────────┴────────────────┘ +``` + +Or cast to a `UInt32` value: + +``` sql +SELECT toTypeName(i), CAST(from as UInt32) as i FROM hits LIMIT 1; +``` + +``` +┌─toTypeName(CAST(from, 'UInt32'))─┬──────────i─┐ +│ UInt32 │ 3086477370 │ +└──────────────────────────────────┴────────────┘ +``` + +[Original article](https://clickhouse.yandex/docs/en/data_types/domains/ipv4) diff --git a/docs/en/data_types/domains/ipv6.md b/docs/en/data_types/domains/ipv6.md new file mode 100644 index 00000000000..1bfbe3400b5 --- /dev/null +++ b/docs/en/data_types/domains/ipv6.md @@ -0,0 +1,79 @@ +## IPv6 + +`IPv6` is a domain based on `FixedString(16)` type and serves as typed replacement for storing IPv6 values. It provides compact storage with human-friendly input-output format, and column type information on inspection. + +### Basic Usage + +``` sql +CREATE TABLE hits (url String, from IPv6) ENGINE = MergeTree() ORDER BY url; + +DESCRIBE TABLE hits; +``` + +``` +┌─name─┬─type───┬─default_type─┬─default_expression─┬─comment─┬─codec_expression─┐ +│ url │ String │ │ │ │ │ +│ from │ IPv6 │ │ │ │ │ +└──────┴────────┴──────────────┴────────────────────┴─────────┴──────────────────┘ +``` + +OR you can use `IPv6` domain as a key: + +``` sql +CREATE TABLE hits (url String, from IPv6) ENGINE = MergeTree() ORDER BY from; +``` + +`IPv6` domain supports custom input as IPv6-strings: + +``` sql +INSERT INTO hits (url, from) VALUES ('https://wikipedia.org', '2a02:aa08:e000:3100::2')('https://clickhouse.yandex', '2001:44c8:129:2632:33:0:252:2')('https://clickhouse.yandex/docs/en/', '2a02:e980:1e::1'); + +SELECT * FROM hits; +``` + +``` +┌─url────────────────────────────────┬─from──────────────────────────┐ +│ https://clickhouse.yandex │ 2001:44c8:129:2632:33:0:252:2 │ +│ https://clickhouse.yandex/docs/en/ │ 2a02:e980:1e::1 │ +│ https://wikipedia.org │ 2a02:aa08:e000:3100::2 │ +└────────────────────────────────────┴───────────────────────────────┘ +``` + +Values are stored in compact binary form: + +``` sql +SELECT toTypeName(from), hex(from) FROM hits LIMIT 1; +``` + +``` +┌─toTypeName(from)─┬─hex(from)────────────────────────┐ +│ IPv6 │ 200144C8012926320033000002520002 │ +└──────────────────┴──────────────────────────────────┘ +``` + +Domain values are not implicitly convertible to types other than `FixedString(16)`. +If you want to convert `IPv6` value to a string, you have to do that explicitly with `IPv6NumToString()` function: + +``` sql +SELECT toTypeName(s), IPv6NumToString(from) as s FROM hits LIMIT 1; +``` + +``` +┌─toTypeName(IPv6NumToString(from))─┬─s─────────────────────────────┐ +│ String │ 2001:44c8:129:2632:33:0:252:2 │ +└───────────────────────────────────┴───────────────────────────────┘ +``` + +Or cast to a `FixedString(16)` value: + +``` sql +SELECT toTypeName(i), CAST(from as FixedString(16)) as i FROM hits LIMIT 1; +``` + +``` +┌─toTypeName(CAST(from, 'FixedString(16)'))─┬─i───────┐ +│ FixedString(16) │ ��� │ +└───────────────────────────────────────────┴─────────┘ +``` + +[Original article](https://clickhouse.yandex/docs/en/data_types/domains/ipv6) diff --git a/docs/en/data_types/domains/overview.md b/docs/en/data_types/domains/overview.md new file mode 100644 index 00000000000..fe7cd82df28 --- /dev/null +++ b/docs/en/data_types/domains/overview.md @@ -0,0 +1,26 @@ +# Domains + +Domains are special-purpose types, that add some extra features atop of existing base type, leaving on-wire and on-disc format of underlying table intact. At the moment, ClickHouse does not support user-defined domains. + +You can use domains anywhere corresponding base type can be used: + +* Create a column of domain type +* Read/write values from/to domain column +* Use it as index if base type can be used as index +* Call functions with values of domain column +* etc. + +### Extra Features of Domains + +* Explicit column type name in `SHOW CREATE TABLE` or `DESCRIBE TABLE` +* Input from human-friendly format with `INSERT INTO domain_table(domain_column) VALUES(...)` +* Output to human-friendly format for `SELECT domain_column FROM domain_table` +* Loading data from external source in human-friendly format: `INSERT INTO domain_table FORMAT CSV ...` + +### Limitations + +* Can't convert index column of base type to domain type via `ALTER TABLE`. +* Can't implicitly convert string values into domain values when inserting data from another column or table. +* Domain adds no constrains on stored values. + +[Original article](https://clickhouse.yandex/docs/en/data_types/domains/overview) \ No newline at end of file diff --git a/docs/en/query_language/functions/ip_address_functions.md b/docs/en/query_language/functions/ip_address_functions.md index 8cc6caff462..70dcb1cdf0e 100644 --- a/docs/en/query_language/functions/ip_address_functions.md +++ b/docs/en/query_language/functions/ip_address_functions.md @@ -131,7 +131,7 @@ SELECT IPv6NumToString(IPv4ToIPv6(IPv4StringToNum('192.168.0.1'))) AS addr Accepts a FixedString(16) value containing the IPv6 address in binary format. Returns a string containing the address of the specified number of bits removed in text format. For example: -```sql +``` sql WITH IPv6StringToNum('2001:0DB8:AC10:FE01:FEED:BABE:CAFE:F00D') AS ipv6, IPv4ToIPv6(IPv4StringToNum('192.168.0.1')) AS ipv4 @@ -178,5 +178,68 @@ SELECT IPv6CIDRtoIPv6Range(toIPv6('2001:0db8:0000:85a3:0000:0000:ac1f:8001'), 32 └────────────────────────────────────────────────────────────────────────────┘ ``` +## toIPv4(string) + +An alias to `IPv4StringToNum()` that takes a string form of IPv4 address and returns value of [IPv4](../../data_types/domains/ipv4.md) type, which is binary equal to value returned by `IPv4StringToNum()`. + +``` sql +WITH + '171.225.130.45' as IPv4_string +SELECT + toTypeName(IPv4StringToNum(IPv4_string)), + toTypeName(toIPv4(IPv4_string)) +``` + +``` +┌─toTypeName(IPv4StringToNum(IPv4_string))─┬─toTypeName(toIPv4(IPv4_string))─┐ +│ UInt32 │ IPv4 │ +└──────────────────────────────────────────┴─────────────────────────────────┘ +``` + +``` sql +WITH + '171.225.130.45' as IPv4_string +SELECT + hex(IPv4StringToNum(IPv4_string)), + hex(toIPv4(IPv4_string)) +``` + +``` +┌─hex(IPv4StringToNum(IPv4_string))─┬─hex(toIPv4(IPv4_string))─┐ +│ ABE1822D │ ABE1822D │ +└───────────────────────────────────┴──────────────────────────┘ +``` + +## toIPv6(string) + +An alias to `IPv6StringToNum()` that takes a string form of IPv6 address and returns value of [IPv6](../../data_types/domains/ipv6.md) type, which is binary equal to value returned by `IPv6StringToNum()`. + +``` sql +WITH + '2001:438:ffff::407d:1bc1' as IPv6_string +SELECT + toTypeName(IPv6StringToNum(IPv6_string)), + toTypeName(toIPv6(IPv6_string)) +``` + +``` +┌─toTypeName(IPv6StringToNum(IPv6_string))─┬─toTypeName(toIPv6(IPv6_string))─┐ +│ FixedString(16) │ IPv6 │ +└──────────────────────────────────────────┴─────────────────────────────────┘ +``` + +``` sql +WITH + '2001:438:ffff::407d:1bc1' as IPv6_string +SELECT + hex(IPv6StringToNum(IPv6_string)), + hex(toIPv6(IPv6_string)) +``` + +``` +┌─hex(IPv6StringToNum(IPv6_string))─┬─hex(toIPv6(IPv6_string))─────────┐ +│ 20010438FFFF000000000000407D1BC1 │ 20010438FFFF000000000000407D1BC1 │ +└───────────────────────────────────┴──────────────────────────────────┘ +``` [Original article](https://clickhouse.yandex/docs/en/query_language/functions/ip_address_functions/) diff --git a/docs/fa/data_types/domains/ipv4.md b/docs/fa/data_types/domains/ipv4.md new file mode 120000 index 00000000000..eb4cc7d57b5 --- /dev/null +++ b/docs/fa/data_types/domains/ipv4.md @@ -0,0 +1 @@ +../../../en/data_types/domains/ipv4.md \ No newline at end of file diff --git a/docs/fa/data_types/domains/ipv6.md b/docs/fa/data_types/domains/ipv6.md new file mode 120000 index 00000000000..cca37a22458 --- /dev/null +++ b/docs/fa/data_types/domains/ipv6.md @@ -0,0 +1 @@ +../../../en/data_types/domains/ipv6.md \ No newline at end of file diff --git a/docs/fa/data_types/domains/overview.md b/docs/fa/data_types/domains/overview.md new file mode 120000 index 00000000000..13465d655ee --- /dev/null +++ b/docs/fa/data_types/domains/overview.md @@ -0,0 +1 @@ +../../../en/data_types/domains/overview.md \ No newline at end of file diff --git a/docs/ru/data_types/domains/ipv4.md b/docs/ru/data_types/domains/ipv4.md new file mode 120000 index 00000000000..eb4cc7d57b5 --- /dev/null +++ b/docs/ru/data_types/domains/ipv4.md @@ -0,0 +1 @@ +../../../en/data_types/domains/ipv4.md \ No newline at end of file diff --git a/docs/ru/data_types/domains/ipv6.md b/docs/ru/data_types/domains/ipv6.md new file mode 120000 index 00000000000..cca37a22458 --- /dev/null +++ b/docs/ru/data_types/domains/ipv6.md @@ -0,0 +1 @@ +../../../en/data_types/domains/ipv6.md \ No newline at end of file diff --git a/docs/ru/data_types/domains/overview.md b/docs/ru/data_types/domains/overview.md new file mode 120000 index 00000000000..13465d655ee --- /dev/null +++ b/docs/ru/data_types/domains/overview.md @@ -0,0 +1 @@ +../../../en/data_types/domains/overview.md \ No newline at end of file diff --git a/docs/toc_en.yml b/docs/toc_en.yml index a67bc9cd309..50d8a373a3d 100644 --- a/docs/toc_en.yml +++ b/docs/toc_en.yml @@ -56,6 +56,10 @@ nav: - 'Expression': 'data_types/special_data_types/expression.md' - 'Set': 'data_types/special_data_types/set.md' - 'Nothing': 'data_types/special_data_types/nothing.md' + - 'Domains': + - 'Overview': 'data_types/domains/overview.md' + - 'IPv4': 'data_types/domains/ipv4.md' + - 'IPv6': 'data_types/domains/ipv6.md' - 'Table Engines': - 'Introduction': 'operations/table_engines/index.md' diff --git a/docs/toc_fa.yml b/docs/toc_fa.yml index 67335934850..95784495d36 100644 --- a/docs/toc_fa.yml +++ b/docs/toc_fa.yml @@ -56,6 +56,10 @@ nav: - 'Expression': 'data_types/special_data_types/expression.md' - 'Set': 'data_types/special_data_types/set.md' - 'Nothing': 'data_types/special_data_types/nothing.md' + - 'Domains': + - 'Overview': 'data_types/domains/overview.md' + - 'IPv4': 'data_types/domains/ipv4.md' + - 'IPv6': 'data_types/domains/ipv6.md' - 'Table Engines': - 'Introduction': 'operations/table_engines/index.md' diff --git a/docs/toc_ru.yml b/docs/toc_ru.yml index 2840eaed6db..3229dedf0ce 100644 --- a/docs/toc_ru.yml +++ b/docs/toc_ru.yml @@ -57,6 +57,10 @@ nav: - 'Expression': 'data_types/special_data_types/expression.md' - 'Set': 'data_types/special_data_types/set.md' - 'Nothing': 'data_types/special_data_types/nothing.md' + - 'Domains': + - 'Overview': 'data_types/domains/overview.md' + - 'IPv4': 'data_types/domains/ipv4.md' + - 'IPv6': 'data_types/domains/ipv6.md' - 'Движки таблиц': - 'Введение': 'operations/table_engines/index.md' diff --git a/docs/toc_zh.yml b/docs/toc_zh.yml index 81866ae7af8..f159b481944 100644 --- a/docs/toc_zh.yml +++ b/docs/toc_zh.yml @@ -55,6 +55,10 @@ nav: - 'Expression': 'data_types/special_data_types/expression.md' - 'Set': 'data_types/special_data_types/set.md' - 'Nothing': 'data_types/special_data_types/nothing.md' + - 'Domains': + - 'Overview': 'data_types/domains/overview.md' + - 'IPv4': 'data_types/domains/ipv4.md' + - 'IPv6': 'data_types/domains/ipv6.md' - 'Table Engines': - 'Introduction': 'operations/table_engines/index.md' diff --git a/docs/zh/data_types/domains/ipv4.md b/docs/zh/data_types/domains/ipv4.md new file mode 120000 index 00000000000..eb4cc7d57b5 --- /dev/null +++ b/docs/zh/data_types/domains/ipv4.md @@ -0,0 +1 @@ +../../../en/data_types/domains/ipv4.md \ No newline at end of file diff --git a/docs/zh/data_types/domains/ipv6.md b/docs/zh/data_types/domains/ipv6.md new file mode 120000 index 00000000000..cca37a22458 --- /dev/null +++ b/docs/zh/data_types/domains/ipv6.md @@ -0,0 +1 @@ +../../../en/data_types/domains/ipv6.md \ No newline at end of file diff --git a/docs/zh/data_types/domains/overview.md b/docs/zh/data_types/domains/overview.md new file mode 120000 index 00000000000..13465d655ee --- /dev/null +++ b/docs/zh/data_types/domains/overview.md @@ -0,0 +1 @@ +../../../en/data_types/domains/overview.md \ No newline at end of file From a4c891e52974019aaa9676826be3c7054f5ff6cb Mon Sep 17 00:00:00 2001 From: Guillaume Tassery Date: Fri, 10 May 2019 13:50:48 +0700 Subject: [PATCH 108/709] Typo for progress and summary header --- dbms/src/IO/WriteBufferFromHTTPServerResponse.h | 4 ++-- 1 file changed, 2 insertions(+), 2 deletions(-) diff --git a/dbms/src/IO/WriteBufferFromHTTPServerResponse.h b/dbms/src/IO/WriteBufferFromHTTPServerResponse.h index ac7794afd4e..5a7dedbc23d 100644 --- a/dbms/src/IO/WriteBufferFromHTTPServerResponse.h +++ b/dbms/src/IO/WriteBufferFromHTTPServerResponse.h @@ -80,9 +80,9 @@ private: /// but not finish them with \r\n, allowing to send more headers subsequently. void startSendHeaders(); - // Used for write the header X-ClickHouse-progress + // Used for write the header X-ClickHouse-Progress void writeHeaderProgress(); - // Used for write the header X-ClickHouse-summary + // Used for write the header X-ClickHouse-Summary void writeHeaderSummary(); /// This method finish headers with \r\n, allowing to start to send body. From bd43e8bada90a71bd317a759bc8307c24870a568 Mon Sep 17 00:00:00 2001 From: =?UTF-8?q?=E5=90=B4=E5=81=A5?= Date: Fri, 10 May 2019 18:42:00 +0800 Subject: [PATCH 109/709] Fix if, multiIf's nullable bug. --- dbms/src/Functions/if.cpp | 31 +- dbms/src/Functions/multiIf.cpp | 10 +- .../0_stateless/00395_nullable.reference | 24 +- .../queries/0_stateless/00395_nullable.sql | 15 + .../0_stateless/00431_if_nulls.reference | 315 +++++++++--------- .../queries/0_stateless/00431_if_nulls.sql | 5 + 6 files changed, 211 insertions(+), 189 deletions(-) diff --git a/dbms/src/Functions/if.cpp b/dbms/src/Functions/if.cpp index 272351956c1..ff034848460 100644 --- a/dbms/src/Functions/if.cpp +++ b/dbms/src/Functions/if.cpp @@ -656,7 +656,7 @@ private: block.getByPosition(result).column = std::move(result_column); } - bool executeForNullableCondition(Block & block, const ColumnNumbers & arguments, size_t result, size_t input_rows_count) + bool executeForNullableCondition(Block & block, const ColumnNumbers & arguments, size_t result, size_t /*input_rows_count*/) { const ColumnWithTypeAndName & arg_cond = block.getByPosition(arguments[0]); bool cond_is_null = arg_cond.column->onlyNull(); @@ -664,7 +664,7 @@ private: if (cond_is_null) { - block.getByPosition(result).column = block.getByPosition(result).type->createColumnConstWithDefaultValue(input_rows_count); + block.getByPosition(result).column = std::move(block.getByPosition(arguments[2]).column); return true; } @@ -680,25 +680,8 @@ private: executeImpl(temporary_block, {0, 1, 2}, 3, temporary_block.rows()); - const ColumnPtr & result_column = temporary_block.getByPosition(3).column; - if (result_column->isColumnNullable()) - { - MutableColumnPtr mutable_result_column = (*std::move(result_column)).mutate(); - static_cast(*mutable_result_column).applyNullMap(static_cast(*arg_cond.column)); - block.getByPosition(result).column = std::move(mutable_result_column); - return true; - } - else if (result_column->onlyNull()) - { - block.getByPosition(result).column = block.getByPosition(result).type->createColumnConstWithDefaultValue(input_rows_count); - return true; - } - else - { - block.getByPosition(result).column = ColumnNullable::create( - materializeColumnIfConst(result_column), static_cast(*arg_cond.column).getNullMapColumnPtr()); - return true; - } + block.getByPosition(result).column = std::move(temporary_block.getByPosition(3).column); + return true; } return false; @@ -917,11 +900,11 @@ public: DataTypePtr getReturnTypeImpl(const DataTypes & arguments) const override { if (arguments[0]->onlyNull()) - return arguments[0]; + return arguments[2]; if (arguments[0]->isNullable()) - return makeNullable(getReturnTypeImpl({ - removeNullable(arguments[0]), arguments[1], arguments[2]})); + return getReturnTypeImpl({ + removeNullable(arguments[0]), arguments[1], arguments[2]}); if (!WhichDataType(arguments[0]).isUInt8()) throw Exception("Illegal type " + arguments[0]->getName() + " of first argument (condition) of function if. Must be UInt8.", diff --git a/dbms/src/Functions/multiIf.cpp b/dbms/src/Functions/multiIf.cpp index 818a8f946c6..f5b27e798b3 100644 --- a/dbms/src/Functions/multiIf.cpp +++ b/dbms/src/Functions/multiIf.cpp @@ -63,16 +63,12 @@ public: throw Exception{"Invalid number of arguments for function " + getName(), ErrorCodes::NUMBER_OF_ARGUMENTS_DOESNT_MATCH}; - /// Conditions must be UInt8, Nullable(UInt8) or Null. If one of conditions is Nullable, the result is also Nullable. - bool have_nullable_condition = false; for_conditions([&](const DataTypePtr & arg) { const IDataType * nested_type; if (arg->isNullable()) { - have_nullable_condition = true; - if (arg->onlyNull()) return; @@ -98,11 +94,7 @@ public: types_of_branches.emplace_back(arg); }); - DataTypePtr common_type_of_branches = getLeastSupertype(types_of_branches); - - return have_nullable_condition - ? makeNullable(common_type_of_branches) - : common_type_of_branches; + return getLeastSupertype(types_of_branches); } void executeImpl(Block & block, const ColumnNumbers & args, size_t result, size_t input_rows_count) override diff --git a/dbms/tests/queries/0_stateless/00395_nullable.reference b/dbms/tests/queries/0_stateless/00395_nullable.reference index 64af8c3d21d..5ab0e1843ca 100644 --- a/dbms/tests/queries/0_stateless/00395_nullable.reference +++ b/dbms/tests/queries/0_stateless/00395_nullable.reference @@ -66,7 +66,7 @@ \N \N \N 2 7 2 5 1 5 -9 \N \N +9 \N 9 42 42 \N \N 6 \N \N \N \N @@ -100,6 +100,28 @@ 42 \N \N +----- if ----- +a 1 UInt8 +b 1 UInt8 +c 0 UInt8 +\N 0 UInt8 +a \N Nullable(UInt8) +b \N Nullable(UInt8) +c 0 Nullable(UInt8) +\N 0 Nullable(UInt8) +----- case when ----- +a 1 UInt8 +b 1 UInt8 +c 0 UInt8 +\N 0 UInt8 +a \N Nullable(UInt8) +b \N Nullable(UInt8) +c 0 Nullable(UInt8) +\N 0 Nullable(UInt8) +a 1 Nullable(UInt8) +b 1 Nullable(UInt8) +c \N Nullable(UInt8) +\N \N Nullable(UInt8) ----- multiIf ----- \N 2 diff --git a/dbms/tests/queries/0_stateless/00395_nullable.sql b/dbms/tests/queries/0_stateless/00395_nullable.sql index 77efc018a8a..92ede10567a 100644 --- a/dbms/tests/queries/0_stateless/00395_nullable.sql +++ b/dbms/tests/queries/0_stateless/00395_nullable.sql @@ -146,6 +146,21 @@ SELECT '----- IS NULL, IS NOT NULL -----'; SELECT col1 FROM test1 WHERE col1 IS NOT NULL ORDER BY col1 ASC; SELECT col1 FROM test1 WHERE col1 IS NULL; +SELECT '----- if -----'; + +DROP TABLE IF EXISTS test.test1; +CREATE TABLE test.test1 (col1 Nullable(String)) ENGINE=TinyLog; +INSERT INTO test.test1 VALUES ('a'), ('b'), ('c'), (NULL); + +SELECT col1, if(col1 IN ('a' ,'b'), 1, 0) AS t, toTypeName(t) FROM test.test1; +SELECT col1, if(col1 IN ('a' ,'b'), NULL, 0) AS t, toTypeName(t) FROM test.test1; + +SELECT '----- case when -----'; + +SELECT col1, CASE WHEN col1 IN ('a' ,'b') THEN 1 ELSE 0 END AS t, toTypeName(t) FROM test.test1; +SELECT col1, CASE WHEN col1 IN ('a' ,'b') THEN NULL ELSE 0 END AS t, toTypeName(t) FROM test.test1; +SELECT col1, CASE WHEN col1 IN ('a' ,'b') THEN 1 END AS t, toTypeName(t) FROM test.test1; + SELECT '----- multiIf -----'; SELECT multiIf(1, NULL, 1, 3, 4); diff --git a/dbms/tests/queries/0_stateless/00431_if_nulls.reference b/dbms/tests/queries/0_stateless/00431_if_nulls.reference index 428a6518fc3..a6e880eedc3 100644 --- a/dbms/tests/queries/0_stateless/00431_if_nulls.reference +++ b/dbms/tests/queries/0_stateless/00431_if_nulls.reference @@ -1,3 +1,4 @@ +---------- constant_true ---------- Hello Hello Hello @@ -158,6 +159,7 @@ Hello 7 8 9 +---------- constant_false ---------- World World World @@ -318,6 +320,17 @@ World -7 -8 -9 +---------- constant_null ---------- +World +World +World +World +World +World +World +World +World +World \N \N \N @@ -328,7 +341,36 @@ World \N \N \N +0 +-1 +-2 +-3 +-4 +-5 +-6 +-7 +-8 +-9 +0 +-1 +-2 +-3 +-4 \N +-6 +-7 +-8 +-9 +World +World +World +World +World +World +World +World +World +World \N \N \N @@ -339,7 +381,36 @@ World \N \N \N +0 +-1 +-2 +-3 +-4 +-5 +-6 +-7 +-8 +-9 +0 +-1 +-2 +-3 +-4 \N +-6 +-7 +-8 +-9 +World +World +World +World +World +World +World +World +World +World \N \N \N @@ -350,7 +421,36 @@ World \N \N \N +0 +-1 +-2 +-3 +-4 +-5 +-6 +-7 +-8 +-9 +0 +-1 +-2 +-3 +-4 \N +-6 +-7 +-8 +-9 +World +World +World +World +World +World +World +World +World +World \N \N \N @@ -361,123 +461,27 @@ World \N \N \N +0 +-1 +-2 +-3 +-4 +-5 +-6 +-7 +-8 +-9 +0 +-1 +-2 +-3 +-4 \N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N -\N +-6 +-7 +-8 +-9 +---------- cond_non_constant ---------- World Hello World @@ -638,15 +642,16 @@ World 7 -8 -9 +---------- cond_non_constant_nullable ---------- World Hello -\N +World World Hello -\N +World World Hello -\N +World World \N Hello @@ -660,33 +665,33 @@ Hello \N 0 Hello -\N +-2 +-3 +Hello +-5 +-6 +Hello +-8 +-9 +0 +Hello +-2 -3 Hello \N -6 Hello -\N --9 -0 -Hello -\N --3 -Hello -\N --6 -Hello -\N +-8 -9 World \N -\N +World World \N -\N +World World \N -\N +World World \N \N @@ -700,33 +705,33 @@ World \N 0 \N -\N +-2 -3 \N -\N +-5 -6 \N -\N +-8 -9 0 \N -\N +-2 -3 \N \N -6 \N -\N +-8 -9 World 1 -\N +World World 4 -\N +World World 7 -\N +World World \N 1 @@ -740,33 +745,33 @@ World \N 0 1 -\N +-2 -3 4 -\N +-5 -6 7 -\N +-8 -9 0 1 -\N +-2 -3 4 \N -6 7 -\N +-8 -9 World 1 -\N +World World 4 -\N +World World 7 -\N +World World \N 1 @@ -780,21 +785,21 @@ World \N 0 1 -\N +-2 -3 4 -\N +-5 -6 7 -\N +-8 -9 0 1 -\N +-2 -3 4 \N -6 7 -\N +-8 -9 diff --git a/dbms/tests/queries/0_stateless/00431_if_nulls.sql b/dbms/tests/queries/0_stateless/00431_if_nulls.sql index 1e78c2b27a3..024f2494410 100644 --- a/dbms/tests/queries/0_stateless/00431_if_nulls.sql +++ b/dbms/tests/queries/0_stateless/00431_if_nulls.sql @@ -31,6 +31,7 @@ AS SELECT nullIf(toString(-number), '-5') AS else_non_constant_nullable FROM system.numbers LIMIT 10; +SELECT '---------- constant_true ----------'; SELECT constant_true ? then_constant : else_constant AS res FROM nullable_00431; SELECT constant_true ? then_constant : constant_null AS res FROM nullable_00431; @@ -52,6 +53,7 @@ SELECT constant_true ? then_non_constant_nullable : constant_null AS res FROM nu SELECT constant_true ? then_non_constant_nullable : else_non_constant AS res FROM nullable_00431; SELECT constant_true ? then_non_constant_nullable : else_non_constant_nullable AS res FROM nullable_00431; +SELECT '---------- constant_false ----------'; SELECT constant_false ? then_constant : else_constant AS res FROM nullable_00431; SELECT constant_false ? then_constant : constant_null AS res FROM nullable_00431; @@ -73,6 +75,7 @@ SELECT constant_false ? then_non_constant_nullable : constant_null AS res FROM n SELECT constant_false ? then_non_constant_nullable : else_non_constant AS res FROM nullable_00431; SELECT constant_false ? then_non_constant_nullable : else_non_constant_nullable AS res FROM nullable_00431; +SELECT '---------- constant_null ----------'; SELECT constant_null ? then_constant : else_constant AS res FROM nullable_00431; SELECT constant_null ? then_constant : constant_null AS res FROM nullable_00431; @@ -94,6 +97,7 @@ SELECT constant_null ? then_non_constant_nullable : constant_null AS res FROM nu SELECT constant_null ? then_non_constant_nullable : else_non_constant AS res FROM nullable_00431; SELECT constant_null ? then_non_constant_nullable : else_non_constant_nullable AS res FROM nullable_00431; +SELECT '---------- cond_non_constant ----------'; SELECT cond_non_constant ? then_constant : else_constant AS res FROM nullable_00431; SELECT cond_non_constant ? then_constant : constant_null AS res FROM nullable_00431; @@ -115,6 +119,7 @@ SELECT cond_non_constant ? then_non_constant_nullable : constant_null AS res FRO SELECT cond_non_constant ? then_non_constant_nullable : else_non_constant AS res FROM nullable_00431; SELECT cond_non_constant ? then_non_constant_nullable : else_non_constant_nullable AS res FROM nullable_00431; +SELECT '---------- cond_non_constant_nullable ----------'; SELECT cond_non_constant_nullable ? then_constant : else_constant AS res FROM nullable_00431; SELECT cond_non_constant_nullable ? then_constant : constant_null AS res FROM nullable_00431; From e4988110ec11500a83c618e0f2e772883a906179 Mon Sep 17 00:00:00 2001 From: Vasily Nemkov Date: Tue, 9 Apr 2019 22:19:30 +0300 Subject: [PATCH 110/709] Implementation of geohashEncode and geohashDecode functions; Function signatures: * geohashEncode(float lon, float lat, int precision) => string * geohashDecode(string encoded) => (float llon, float lat) With test cases and documentation; --- dbms/src/DataTypes/IDataType.h | 7 + dbms/src/Functions/FunctionHelpers.cpp | 19 ++ dbms/src/Functions/FunctionHelpers.h | 9 +- dbms/src/Functions/FunctionsGeo.cpp | 199 ++++++++++++++- dbms/src/Functions/GeoUtils.cpp | 232 ++++++++++++++++++ dbms/src/Functions/GeoUtils.h | 4 + .../funtions_geo/functions_geo.xml | 29 +++ .../00932_geohash_support.reference | 227 +++++++++++++++++ .../0_stateless/00932_geohash_support.sql | 67 +++++ docs/en/query_language/functions/geo.md | 52 ++++ 10 files changed, 838 insertions(+), 7 deletions(-) create mode 100644 dbms/src/Functions/GeoUtils.cpp create mode 100644 dbms/tests/performance/funtions_geo/functions_geo.xml create mode 100644 dbms/tests/queries/0_stateless/00932_geohash_support.reference create mode 100644 dbms/tests/queries/0_stateless/00932_geohash_support.sql diff --git a/dbms/src/DataTypes/IDataType.h b/dbms/src/DataTypes/IDataType.h index 60124cd3d5d..ad03b3cdd48 100644 --- a/dbms/src/DataTypes/IDataType.h +++ b/dbms/src/DataTypes/IDataType.h @@ -573,6 +573,13 @@ inline bool isInteger(const T & data_type) return which.isInt() || which.isUInt(); } +template +inline bool isFloat(const T & data_type) +{ + WhichDataType which(data_type); + return which.isFloat(); +} + template inline bool isNumber(const T & data_type) { diff --git a/dbms/src/Functions/FunctionHelpers.cpp b/dbms/src/Functions/FunctionHelpers.cpp index 1a05d3c2bfe..42fcebd5848 100644 --- a/dbms/src/Functions/FunctionHelpers.cpp +++ b/dbms/src/Functions/FunctionHelpers.cpp @@ -1,4 +1,5 @@ #include +#include #include #include #include @@ -13,6 +14,7 @@ namespace DB namespace ErrorCodes { extern const int ILLEGAL_COLUMN; + extern const int NUMBER_OF_ARGUMENTS_DOESNT_MATCH; } const ColumnConst * checkAndGetColumnConstStringOrFixedString(const IColumn * column) @@ -99,4 +101,21 @@ Block createBlockWithNestedColumns(const Block & block, const ColumnNumbers & ar return createBlockWithNestedColumnsImpl(block, args_set); } +void validateArgumentType(const IFunction & func, const DataTypes & arguments, + size_t argument_index, bool (* validator_func)(const IDataType &), + const char * expected_type_description) +{ + if (arguments.size() <= argument_index) + throw Exception("Incorrect number of arguments of function " + func.getName(), + ErrorCodes::NUMBER_OF_ARGUMENTS_DOESNT_MATCH); + + const auto & argument = arguments[argument_index]; + if (validator_func(*argument) == false) + throw Exception("Illegal type " + argument->getName() + + " of " + std::to_string(argument_index) + + " argument of function " + func.getName() + + " expected " + expected_type_description, + ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT); +} + } diff --git a/dbms/src/Functions/FunctionHelpers.h b/dbms/src/Functions/FunctionHelpers.h index 6be58f32c5e..8e1efd113f8 100644 --- a/dbms/src/Functions/FunctionHelpers.h +++ b/dbms/src/Functions/FunctionHelpers.h @@ -12,6 +12,8 @@ namespace DB { +class IFunction; + /// Methods, that helps dispatching over real column types. template @@ -64,7 +66,6 @@ bool checkColumnConst(const IColumn * column) return checkAndGetColumnConst(column); } - /// Returns non-nullptr if column is ColumnConst with ColumnString or ColumnFixedString inside. const ColumnConst * checkAndGetColumnConstStringOrFixedString(const IColumn * column); @@ -94,4 +95,10 @@ Block createBlockWithNestedColumns(const Block & block, const ColumnNumbers & ar /// Similar function as above. Additionally transform the result type if needed. Block createBlockWithNestedColumns(const Block & block, const ColumnNumbers & args, size_t result); +/// Checks argument type at specified index with predicate. +/// throws if there is no argument at specified index or if predicate returns false. +void validateArgumentType(const IFunction & func, const DataTypes & arguments, + size_t argument_index, bool (* validator_func)(const IDataType &), + const char * expected_type_description); + } diff --git a/dbms/src/Functions/FunctionsGeo.cpp b/dbms/src/Functions/FunctionsGeo.cpp index 0d13914f103..7b45fb8a668 100644 --- a/dbms/src/Functions/FunctionsGeo.cpp +++ b/dbms/src/Functions/FunctionsGeo.cpp @@ -1,19 +1,24 @@ #include #include #include +#include #include #include #include -#include -#include -#include -#include -#include #include -#include +#include +#include +#include #include +#include +#include +#include +#include +#include +#include + #include #include @@ -246,6 +251,186 @@ private: }; +const size_t GEOHASH_MAX_TEXT_LENGTH = 16; + +// geohashEncode(lon float32/64, lat float32/64, length UInt8) => string +class FunctionGeohashEncode : public IFunction +{ +public: + static constexpr auto name = "geohashEncode"; + static FunctionPtr create(const Context &) { return std::make_shared(); } + + String getName() const override + { + return name; + } + + bool isVariadic() const override { return true; } + size_t getNumberOfArguments() const override { return 0; } + ColumnNumbers getArgumentsThatAreAlwaysConstant() const override { return {2}; } + bool useDefaultImplementationForConstants() const override { return true; } + + DataTypePtr getReturnTypeImpl(const DataTypes & arguments) const override + { + validateArgumentType(*this, arguments, 0, isFloat, "float"); + validateArgumentType(*this, arguments, 1, isFloat, "float"); + if (arguments.size() == 3) + { + validateArgumentType(*this, arguments, 2, isInteger, "integer"); + } + if (arguments.size() > 3) + { + throw Exception("Too many arguments for function " + getName() + + " expected at most 3", + ErrorCodes::TOO_MANY_ARGUMENTS_FOR_FUNCTION); + } + + return std::make_shared(); + } + + template + bool tryExecute(const IColumn * lon_column, const IColumn * lat_column, UInt64 precision_value, ColumnPtr & result) + { + const ColumnVector * longitude = checkAndGetColumn>(lon_column); + const ColumnVector * latitude = checkAndGetColumn>(lat_column); + if (!latitude || !longitude) + return false; + + auto col_str = ColumnString::create(); + ColumnString::Chars & out_vec = col_str->getChars(); + ColumnString::Offsets & out_offsets = col_str->getOffsets(); + + const size_t size = lat_column->size(); + + out_offsets.resize(size); + out_vec.resize(size * (GEOHASH_MAX_TEXT_LENGTH + 1)); + + char * begin = reinterpret_cast(out_vec.data()); + char * pos = begin; + + for (size_t i = 0; i < size; ++i) + { + const Float64 longitude_value = longitude->getElement(i); + const Float64 latitude_value = latitude->getElement(i); + + const size_t encoded_size = GeoUtils::geohashEncode(longitude_value, latitude_value, precision_value, pos); + + pos += encoded_size; + *pos = '\0'; + out_offsets[i] = ++pos - begin; + } + out_vec.resize(pos - begin); + + if (!out_offsets.empty() && out_offsets.back() != out_vec.size()) + throw Exception("Column size mismatch (internal logical error)", ErrorCodes::LOGICAL_ERROR); + + result = std::move(col_str); + + return true; + + } + + void executeImpl(Block & block, const ColumnNumbers & arguments, size_t result, size_t /*input_rows_count*/) override + { + const IColumn * longitude = block.getByPosition(arguments[0]).column.get(); + const IColumn * latitude = block.getByPosition(arguments[1]).column.get(); + + const UInt64 precision_value = std::min(GEOHASH_MAX_TEXT_LENGTH, + arguments.size() == 3 ? block.getByPosition(arguments[2]).column->get64(0) : GEOHASH_MAX_TEXT_LENGTH); + + ColumnPtr & res_column = block.getByPosition(result).column; + + if (tryExecute(longitude, latitude, precision_value, res_column) || + tryExecute(longitude, latitude, precision_value, res_column) || + tryExecute(longitude, latitude, precision_value, res_column) || + tryExecute(longitude, latitude, precision_value, res_column)) + return; + + const char sep[] = ", "; + std::string arguments_description = ""; + for (size_t i = 0; i < arguments.size(); ++i) + { + arguments_description += block.getByPosition(arguments[i]).column->getName() + sep; + } + if (arguments_description.size() > sizeof(sep)) + { + arguments_description.erase(arguments_description.size() - sizeof(sep) - 1); + } + + throw Exception("Unsupported argument types: " + arguments_description + + + " for function " + getName(), + ErrorCodes::ILLEGAL_COLUMN); + } +}; + +// geohashDecode(string) => (lon float64, lat float64) +class FunctionGeohashDecode : public IFunction +{ +public: + static constexpr auto name = "geohashDecode"; + static FunctionPtr create(const Context &) { return std::make_shared(); } + + String getName() const override + { + return name; + } + + size_t getNumberOfArguments() const override { return 1; } + bool useDefaultImplementationForConstants() const override { return true; } + + DataTypePtr getReturnTypeImpl(const DataTypes & arguments) const override + { + validateArgumentType(*this, arguments, 0, isStringOrFixedString, "string or fixed string"); + + return std::make_shared( + DataTypes{std::make_shared(), std::make_shared()}, + Strings{"longitude", "latitude"}); + } + + template + bool tryExecute(const IColumn * encoded_column, ColumnPtr & result_column) + { + const auto * encoded = checkAndGetColumn(encoded_column); + if (!encoded) + return false; + + const size_t count = encoded->size(); + + auto latitude = ColumnFloat64::create(count); + auto longitude = ColumnFloat64::create(count); + + ColumnFloat64::Container & lon_data = longitude->getData(); + ColumnFloat64::Container & lat_data = latitude->getData(); + + for (size_t i = 0; i < count; ++i) + { + StringRef encoded_string = encoded->getDataAt(i); + GeoUtils::geohashDecode(encoded_string.data, encoded_string.size, &lon_data[i], &lat_data[i]); + } + + MutableColumns result; + result.emplace_back(std::move(longitude)); + result.emplace_back(std::move(latitude)); + result_column = ColumnTuple::create(std::move(result)); + + return true; + } + + void executeImpl(Block & block, const ColumnNumbers & arguments, size_t result, size_t /*input_rows_count*/) override + { + const IColumn * encoded = block.getByPosition(arguments[0]).column.get(); + ColumnPtr & res_column = block.getByPosition(result).column; + + if (tryExecute(encoded, res_column) || + tryExecute(encoded, res_column)) + return; + + throw Exception("Unsupported argument type:" + block.getByPosition(arguments[0]).column->getName() + + " of argument of function " + getName(), + ErrorCodes::ILLEGAL_COLUMN); + } +}; + template using Point = boost::geometry::model::d2::point_xy; @@ -261,5 +446,7 @@ void registerFunctionsGeo(FunctionFactory & factory) factory.registerFunction(); factory.registerFunction>(); + factory.registerFunction(); + factory.registerFunction(); } } diff --git a/dbms/src/Functions/GeoUtils.cpp b/dbms/src/Functions/GeoUtils.cpp new file mode 100644 index 00000000000..8624b1c3b45 --- /dev/null +++ b/dbms/src/Functions/GeoUtils.cpp @@ -0,0 +1,232 @@ +#include +#include + +namespace +{ + +using namespace DB; + +const char geohash_base32_encode_lookup_table[32] = { + '0', '1', '2', '3', '4', '5', '6', '7', '8', '9', + 'b', 'c', 'd', 'e', 'f', 'g', 'h', 'j', 'k', 'm', + 'n', 'p', 'q', 'r', 's', 't', 'u', 'v', 'w', 'x', + 'y', 'z', +}; + +// TODO: this could be halved by excluding 128-255 range. +const UInt8 geohash_base32_decode_lookup_table[256] = { + 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, + 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, + 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, + 0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, + 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, + 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, + 0xFF, 0xFF, 10, 11, 12, 13, 14, 15, 16, 0xFF, 17, 18, 0xFF, 19, 20, 0xFF, + 21, 22, 23, 24, 25, 26, 27, 28, 29, 30, 31, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, + 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, + 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, + 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, + 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, + 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, + 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, + 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, + 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, +}; + +const size_t BITS_PER_SYMBOL = 5; +const size_t MAX_PRECISION = 12; +const size_t MAX_BITS = MAX_PRECISION * BITS_PER_SYMBOL * 1.5; + +using Encoded = std::array; + +enum CoordType +{ + LATITUDE, + LONGITUDE, +}; + +inline UInt8 singleCoordBitsPrecision(UInt8 precision, CoordType type) +{ + // Single coordinate occupies only half of the total bits. + const UInt8 bits = (precision * BITS_PER_SYMBOL) / 2; + if (precision & 0x1 && type == LONGITUDE) + { + return bits + 1; + } + + return bits; +} + +inline Encoded encodeCoordinate(Float64 coord, Float64 min, Float64 max, UInt8 bits) +{ + Encoded result; + result.fill(0); + + for (int i = 0; i < bits; ++i) + { + Float64 mid = (max + min) / 2; + if (coord >= mid) + { + result[i] = 1; + min = mid; + } + else + { + result[i] = 0; + max = mid; + } + } + + return result; +} + +inline Float64 decodeCoordinate(const Encoded & coord, Float64 min, Float64 max, UInt8 bits) +{ + Float64 mid = (max + min) / 2; + for (int i = 0; i < bits; ++i) + { + const auto c = coord[i]; + if (c == 1) + { + min = mid; + } + else + { + max = mid; + } + + mid = (max + min) / 2; + } + + return mid; +} + +inline Encoded merge(const Encoded & encodedLon, const Encoded & encodedLat, UInt8 precision) +{ + Encoded result; + result.fill(0); + + const auto bits = (precision * BITS_PER_SYMBOL) / 2; + UInt8 i = 0; + for (; i < bits; ++i) + { + result[i * 2 + 0] = encodedLon[i]; + result[i * 2 + 1] = encodedLat[i]; + } + // in case of even precision, add last bit of longitude + if (precision & 0x1) + { + result[i * 2] = encodedLon[i]; + } + + return result; +} + +inline std::tuple split(const Encoded & combined, UInt8 precision) +{ + Encoded lat, lon; + lat.fill(0); + lon.fill(0); + + UInt8 i = 0; + for (; i < precision * BITS_PER_SYMBOL - 1; i += 2) + { + // longitude is even bits + lon[i/2] = combined[i]; + lat[i/2] = combined[i + 1]; + } + // precision is even, read the last bit as lat. + if (precision & 0x1) + { + lon[i/2] = combined[precision * BITS_PER_SYMBOL - 1]; + } + + return std::tie(lon, lat); +} + +inline void base32Encode(const Encoded & binary, UInt8 precision, char * out) +{ + extern const char geohash_base32_encode_lookup_table[32]; + + for (UInt8 i = 0; i < precision * BITS_PER_SYMBOL; i += 5) + { + UInt8 v = binary[i]; + v <<= 1; + v |= binary[i + 1]; + v <<= 1; + v |= binary[i + 2]; + v <<= 1; + v |= binary[i + 3]; + v <<= 1; + v |= binary[i + 4]; + + assert(v < 32); + + *out = geohash_base32_encode_lookup_table[v]; + ++out; + } +} + +inline Encoded base32Decode(const char * encoded_string, size_t encoded_length) +{ + extern const UInt8 geohash_base32_decode_lookup_table[256]; + + Encoded result; + + for (size_t i = 0; i < encoded_length; ++i) + { + const UInt8 c = static_cast(encoded_string[i]); + const UInt8 decoded = geohash_base32_decode_lookup_table[c] & 0x1F; + result[i * 5 + 4] = (decoded >> 0) & 0x01; + result[i * 5 + 3] = (decoded >> 1) & 0x01; + result[i * 5 + 2] = (decoded >> 2) & 0x01; + result[i * 5 + 1] = (decoded >> 3) & 0x01; + result[i * 5 + 0] = (decoded >> 4) & 0x01; + } + + return result; +} + +} // namespace + +namespace DB +{ + +namespace GeoUtils +{ + +size_t geohashEncode(Float64 longitude, Float64 latitude, UInt8 precision, char *& out) +{ + if (precision == 0 || precision > MAX_PRECISION) + { + precision = MAX_PRECISION; + } + + const Encoded combined = merge( + encodeCoordinate(longitude, -180, 180, singleCoordBitsPrecision(precision, LONGITUDE)), + encodeCoordinate(latitude, -90, 90, singleCoordBitsPrecision(precision, LATITUDE)), + precision); + + base32Encode(combined, precision, out); + + return precision; +} + +void geohashDecode(const char * encoded_string, size_t encoded_len, Float64 * longitude, Float64 * latitude) +{ + const UInt8 precision = std::min(encoded_len, MAX_PRECISION); + if (precision == 0) + { + return; + } + + Encoded lat_encoded, lon_encoded; + std::tie(lon_encoded, lat_encoded) = split(base32Decode(encoded_string, precision), precision); + + *longitude = decodeCoordinate(lon_encoded, -180, 180, singleCoordBitsPrecision(precision, LONGITUDE)); + *latitude = decodeCoordinate(lat_encoded, -90, 90, singleCoordBitsPrecision(precision, LATITUDE)); +} + +} // namespace GeoUtils + +} // namespace DB diff --git a/dbms/src/Functions/GeoUtils.h b/dbms/src/Functions/GeoUtils.h index 425377f17ae..731305cd705 100644 --- a/dbms/src/Functions/GeoUtils.h +++ b/dbms/src/Functions/GeoUtils.h @@ -699,6 +699,10 @@ std::string serialize(Polygon && polygon) return result; } +size_t geohashEncode(Float64 longitude, Float64 latitude, UInt8 precision, char *& out); + +void geohashDecode(const char * encoded_string, size_t encoded_len, Float64 * longitude, Float64 * latitude); + } /// GeoUtils diff --git a/dbms/tests/performance/funtions_geo/functions_geo.xml b/dbms/tests/performance/funtions_geo/functions_geo.xml new file mode 100644 index 00000000000..b1ea38be447 --- /dev/null +++ b/dbms/tests/performance/funtions_geo/functions_geo.xml @@ -0,0 +1,29 @@ + + functions_coding + once + + + + 300 + 1000 + + + + + + + + + + + + SELECT count() FROM system.numbers WHERE NOT ignore(geohashEncode((number % 150)*1.1 - 75, (number * 3.14 % 300)*1.1 - 150)) + SELECT count() FROM system.numbers WHERE NOT ignore(geohashDecode(toString(number % 1000000))) + + SELECT count() FROM system.numbers WHERE NOT ignore(geohashEncode(1.0/rand(), 2.0/rand())) + SELECT count() FROM system.numbers WHERE NOT ignore(geohashDecode(toString(rand() % 1000000))) + + + SELECT count() FROM system.numbers WHERE NOT ignore(geohashEncode(number + 91.0, number + 181.0)) + SELECT count() FROM system.numbers WHERE NOT ignore(geohashDecode(hex(number))) + diff --git a/dbms/tests/queries/0_stateless/00932_geohash_support.reference b/dbms/tests/queries/0_stateless/00932_geohash_support.reference new file mode 100644 index 00000000000..ffc290681c7 --- /dev/null +++ b/dbms/tests/queries/0_stateless/00932_geohash_support.reference @@ -0,0 +1,227 @@ +invalid values: +zzzzzzzzzzzz +000000000000 +1 +constant values: +ezs42d000000 +-5.60303 42.60498 +default precision: +ezs42d000000 +mixing const and non-const-columns: +ezs42d000000 +from table (with const precision): +1 6 Ok +1 6 Ok +1 6 Ok +1 7 Ok +1 7 Ok +1 k Ok +1 k Ok +1 k Ok +1 7 Ok +1 7 Ok +1 k Ok +1 k Ok +1 k Ok +1 e Ok +1 e Ok +1 s Ok +1 s Ok +1 s Ok +1 e Ok +1 e Ok +1 s Ok +1 s Ok +1 s Ok +1 e Ok +1 e Ok +1 s Ok +1 s Ok +1 s Ok +1 w Ok +1 g Ok +1 u Ok +2 6g Ok +2 6g Ok +2 6g Ok +2 7z Ok +2 7z Ok +2 kp Ok +2 kp Ok +2 kp Ok +2 7z Ok +2 7z Ok +2 kp Ok +2 kp Ok +2 kp Ok +2 eb Ok +2 eb Ok +2 s0 Ok +2 s0 Ok +2 s0 Ok +2 eb Ok +2 eb Ok +2 s0 Ok +2 s0 Ok +2 s0 Ok +2 eb Ok +2 eb Ok +2 s0 Ok +2 s0 Ok +2 s0 Ok +2 w1 Ok +2 gc Ok +2 u9 Ok +3 6gk Ok +3 6gk Ok +3 6gk Ok +3 7zz Ok +3 7zz Ok +3 kpb Ok +3 kpb Ok +3 kpb Ok +3 7zz Ok +3 7zz Ok +3 kpb Ok +3 kpb Ok +3 kpb Ok +3 ebp Ok +3 ebp Ok +3 s00 Ok +3 s00 Ok +3 s00 Ok +3 ebp Ok +3 ebp Ok +3 s00 Ok +3 s00 Ok +3 s00 Ok +3 ebp Ok +3 ebp Ok +3 s00 Ok +3 s00 Ok +3 s00 Ok +3 w1m Ok +3 gcp Ok +3 u9e Ok +4 6gkz Ok +4 6gkz Ok +4 6gkz Ok +4 7zzz Ok +4 7zzz Ok +4 kpbp Ok +4 kpbp Ok +4 kpbp Ok +4 7zzz Ok +4 7zzz Ok +4 kpbp Ok +4 kpbp Ok +4 kpbp Ok +4 ebpb Ok +4 ebpb Ok +4 s000 Ok +4 s000 Ok +4 s000 Ok +4 ebpb Ok +4 ebpb Ok +4 s000 Ok +4 s000 Ok +4 s000 Ok +4 ebpb Ok +4 ebpb Ok +4 s000 Ok +4 s000 Ok +4 s000 Ok +4 w1mu Ok +4 gcpv Ok +4 u9ed Ok +5 6gkzm Ok +5 6gkzw Ok +5 6gkzw Ok +5 7zzzm Ok +5 7zzzr Ok +5 kpbp2 Ok +5 kpbp2 Ok +5 kpbp6 Ok +5 7zzzv Ok +5 7zzzz Ok +5 kpbpb Ok +5 kpbpb Ok +5 kpbpf Ok +5 ebpbj Ok +5 ebpbp Ok +5 s0000 Ok +5 s0004 Ok +5 ebpbj Ok +5 ebpbp Ok +5 s0000 Ok +5 s0000 Ok +5 s0004 Ok +5 ebpbt Ok +5 ebpbx Ok +5 s0008 Ok +5 s0008 Ok +5 s000d Ok +5 w1muy Ok +5 gcpvn Ok +5 u9edu Ok +6 6gkzmg Ok +6 6gkzwg Ok +6 6gkzwg Ok +6 7zzzrv Ok +6 kpbp2j Ok +6 7zzzvw Ok +6 7zzzzy Ok +6 kpbpbn Ok +6 kpbpbn Ok +6 kpbpfq Ok +6 ebpbpb Ok +6 s00000 Ok +6 ebpbj9 Ok +6 ebpbpc Ok +6 s00001 Ok +6 s00001 Ok +6 s00043 Ok +6 ebpbxf Ok +6 s00084 Ok +6 w1muy6 Ok +6 gcpvn5 Ok +6 u9edu0 Ok +7 6gkzmg1 Ok +7 6gkzwgj Ok +7 6gkzwgj Ok +7 7zzzrvb Ok +7 kpbp2jz Ok +7 7zzzzy0 Ok +7 kpbpbnp Ok +7 ebpbpb0 Ok +7 s00000p Ok +7 ebpbpcb Ok +7 s00001z Ok +7 ebpbxf0 Ok +7 s00084p Ok +7 w1muy6d Ok +7 gcpvn5w Ok +7 u9edu0q Ok +8 6gkzmg1u Ok +8 6gkzwgjt Ok +8 6gkzwgjz Ok +8 w1muy6dt Ok +8 gcpvn5w2 Ok +8 u9edu0qs Ok +9 6gkzwgjzn Ok +9 w1muy6dt2 Ok +9 gcpvn5w2e Ok +9 u9edu0qsf Ok +10 6gkzwgjzn8 Ok +10 w1muy6dt2p Ok +10 gcpvn5w2eu Ok +10 u9edu0qsf7 Ok +11 6gkzwgjzn82 Ok +11 w1muy6dt2pt Ok +11 gcpvn5w2euk Ok +11 u9edu0qsf7d Ok +12 6gkzwgjzn820 Ok +12 w1muy6dt2ptk Ok +12 gcpvn5w2euky Ok +12 u9edu0qsf7dn Ok +incorrectly decoded values: diff --git a/dbms/tests/queries/0_stateless/00932_geohash_support.sql b/dbms/tests/queries/0_stateless/00932_geohash_support.sql new file mode 100644 index 00000000000..a477332b532 --- /dev/null +++ b/dbms/tests/queries/0_stateless/00932_geohash_support.sql @@ -0,0 +1,67 @@ +drop table if exists geohash_test_data; + +create table geohash_test_data ( + latitude Float64, + longitude Float64, + encoded String +) engine = MergeTree order by (latitude, longitude, encoded); + +-- data obtained from geohash.com +insert into geohash_test_data values (-25.427, -49.315, '6'), (-25.427, -49.315, '6g'), (-25.427, -49.315, '6gk'), (-25.427, -49.315, '6gkz'), (-25.427, -49.315, '6gkzm'), (-25.427, -49.315, '6gkzmg'), (-25.427, -49.315, '6gkzmg1'), (-25.427, -49.315, '6gkzmg1u'), (-25.383, -49.266, '6'), (-25.383, -49.266, '6g'), (-25.383, -49.266, '6gk'), (-25.383, -49.266, '6gkz'), (-25.383, -49.266, '6gkzw'), (-25.383, -49.266, '6gkzwg'), (-25.383, -49.266, '6gkzwgj'), (-25.383, -49.266, '6gkzwgjt'), (-25.382708, -49.265506, '6'), (-25.382708, -49.265506, '6g'), (-25.382708, -49.265506, '6gk'), (-25.382708, -49.265506, '6gkz'), (-25.382708, -49.265506, '6gkzw'), (-25.382708, -49.265506, '6gkzwg'), (-25.382708, -49.265506, '6gkzwgj'), (-25.382708, -49.265506, '6gkzwgjz'), (-25.382708, -49.265506, '6gkzwgjzn'), (-25.382708, -49.265506, '6gkzwgjzn8'), (-25.382708, -49.265506, '6gkzwgjzn82'), (-25.382708, -49.265506, '6gkzwgjzn820'), (-0.1, -0.1, '7'), (-0.1, -0.1, '7z'), (-0.1, -0.1, '7zz'), (-0.1, -0.1, '7zzz'), (-0.1, -0.1, '7zzzm'), (-0.1, -0.01, '7'), (-0.1, -0.01, '7z'), (-0.1, -0.01, '7zz'), (-0.1, -0.01, '7zzz'), (-0.1, -0.01, '7zzzr'), (-0.1, -0.01, '7zzzrv'), (-0.1, -0.01, '7zzzrvb'), (-0.1, 0, 'k'), (-0.1, 0, 'kp'), (-0.1, 0, 'kpb'), (-0.1, 0, 'kpbp'), (-0.1, 0, 'kpbp2'), (-0.1, 0.01, 'k'), (-0.1, 0.01, 'kp'), (-0.1, 0.01, 'kpb'), (-0.1, 0.01, 'kpbp'), (-0.1, 0.01, 'kpbp2'), (-0.1, 0.01, 'kpbp2j'), (-0.1, 0.01, 'kpbp2jz'), (-0.1, 0.1, 'k'), (-0.1, 0.1, 'kp'), (-0.1, 0.1, 'kpb'), (-0.1, 0.1, 'kpbp'), (-0.1, 0.1, 'kpbp6'), (-0.01, -0.1, '7'), (-0.01, -0.1, '7z'), (-0.01, -0.1, '7zz'), (-0.01, -0.1, '7zzz'), (-0.01, -0.1, '7zzzv'), (-0.01, -0.1, '7zzzvw'), (-0.01, -0.01, '7'), (-0.01, -0.01, '7z'), (-0.01, -0.01, '7zz'), (-0.01, -0.01, '7zzz'), (-0.01, -0.01, '7zzzz'), (-0.01, -0.01, '7zzzzy'), (-0.01, -0.01, '7zzzzy0'), (-0.01, 0, 'k'), (-0.01, 0, 'kp'), (-0.01, 0, 'kpb'), (-0.01, 0, 'kpbp'), (-0.01, 0, 'kpbpb'), (-0.01, 0, 'kpbpbn'), (-0.01, 0.01, 'k'), (-0.01, 0.01, 'kp'), (-0.01, 0.01, 'kpb'), (-0.01, 0.01, 'kpbp'), (-0.01, 0.01, 'kpbpb'), (-0.01, 0.01, 'kpbpbn'), (-0.01, 0.01, 'kpbpbnp'), (-0.01, 0.1, 'k'), (-0.01, 0.1, 'kp'), (-0.01, 0.1, 'kpb'), (-0.01, 0.1, 'kpbp'), (-0.01, 0.1, 'kpbpf'), (-0.01, 0.1, 'kpbpfq'), (0, -0.1, 'e'), (0, -0.1, 'eb'), (0, -0.1, 'ebp'), (0, -0.1, 'ebpb'), (0, -0.1, 'ebpbj'), (0, -0.01, 'e'), (0, -0.01, 'eb'), (0, -0.01, 'ebp'), (0, -0.01, 'ebpb'), (0, -0.01, 'ebpbp'), (0, -0.01, 'ebpbpb'), (0, -0.01, 'ebpbpb0'), (0, 0, 's'), (0, 0, 's0'), (0, 0, 's00'), (0, 0, 's000'), (0, 0.01, 's'), (0, 0.01, 's0'), (0, 0.01, 's00'), (0, 0.01, 's000'), (0, 0.01, 's0000'), (0, 0.01, 's00000'), (0, 0.01, 's00000p'), (0, 0.1, 's'), (0, 0.1, 's0'), (0, 0.1, 's00'), (0, 0.1, 's000'), (0, 0.1, 's0004'), (0.01, -0.1, 'e'), (0.01, -0.1, 'eb'), (0.01, -0.1, 'ebp'), (0.01, -0.1, 'ebpb'), (0.01, -0.1, 'ebpbj'), (0.01, -0.1, 'ebpbj9'), (0.01, -0.01, 'e'), (0.01, -0.01, 'eb'), (0.01, -0.01, 'ebp'), (0.01, -0.01, 'ebpb'), (0.01, -0.01, 'ebpbp'), (0.01, -0.01, 'ebpbpc'), (0.01, -0.01, 'ebpbpcb'), (0.01, 0, 's'), (0.01, 0, 's0'), (0.01, 0, 's00'), (0.01, 0, 's000'), (0.01, 0, 's0000'), (0.01, 0, 's00001'), (0.01, 0.01, 's'), (0.01, 0.01, 's0'), (0.01, 0.01, 's00'), (0.01, 0.01, 's000'), (0.01, 0.01, 's0000'), (0.01, 0.01, 's00001'), (0.01, 0.01, 's00001z'), (0.01, 0.1, 's'), (0.01, 0.1, 's0'), (0.01, 0.1, 's00'), (0.01, 0.1, 's000'), (0.01, 0.1, 's0004'), (0.01, 0.1, 's00043'), (0.1, -0.1, 'e'), (0.1, -0.1, 'eb'), (0.1, -0.1, 'ebp'), (0.1, -0.1, 'ebpb'), (0.1, -0.1, 'ebpbt'), (0.1, -0.01, 'e'), (0.1, -0.01, 'eb'), (0.1, -0.01, 'ebp'), (0.1, -0.01, 'ebpb'), (0.1, -0.01, 'ebpbx'), (0.1, -0.01, 'ebpbxf'), (0.1, -0.01, 'ebpbxf0'), (0.1, 0, 's'), (0.1, 0, 's0'), (0.1, 0, 's00'), (0.1, 0, 's000'), (0.1, 0, 's0008'), (0.1, 0.01, 's'), (0.1, 0.01, 's0'), (0.1, 0.01, 's00'), (0.1, 0.01, 's000'), (0.1, 0.01, 's0008'), (0.1, 0.01, 's00084'), (0.1, 0.01, 's00084p'), (0.1, 0.1, 's'), (0.1, 0.1, 's0'), (0.1, 0.1, 's00'), (0.1, 0.1, 's000'), (0.1, 0.1, 's000d'), (7.880886, 98.3640363, 'w'), (7.880886, 98.3640363, 'w1'), (7.880886, 98.3640363, 'w1m'), (7.880886, 98.3640363, 'w1mu'), (7.880886, 98.3640363, 'w1muy'), (7.880886, 98.3640363, 'w1muy6'), (7.880886, 98.3640363, 'w1muy6d'), (7.880886, 98.3640363, 'w1muy6dt'), (7.880886, 98.3640363, 'w1muy6dt2'), (7.880886, 98.3640363, 'w1muy6dt2p'), (7.880886, 98.3640363, 'w1muy6dt2pt'), (7.880886, 98.3640363, 'w1muy6dt2ptk'), (51.523242, -0.07914, 'g'), (51.523242, -0.07914, 'gc'), (51.523242, -0.07914, 'gcp'), (51.523242, -0.07914, 'gcpv'), (51.523242, -0.07914, 'gcpvn'), (51.523242, -0.07914, 'gcpvn5'), (51.523242, -0.07914, 'gcpvn5w'), (51.523242, -0.07914, 'gcpvn5w2'), (51.523242, -0.07914, 'gcpvn5w2e'), (51.523242, -0.07914, 'gcpvn5w2eu'), (51.523242, -0.07914, 'gcpvn5w2euk'), (51.523242, -0.07914, 'gcpvn5w2euky'), (53.923107, 27.606682, 'u'), (53.923107, 27.606682, 'u9'), (53.923107, 27.606682, 'u9e'), (53.923107, 27.606682, 'u9ed'), (53.923107, 27.606682, 'u9edu'), (53.923107, 27.606682, 'u9edu0'), (53.923107, 27.606682, 'u9edu0q'), (53.923107, 27.606682, 'u9edu0qs'), (53.923107, 27.606682, 'u9edu0qsf'), (53.923107, 27.606682, 'u9edu0qsf7'), (53.923107, 27.606682, 'u9edu0qsf7d'), (53.923107, 27.606682, 'u9edu0qsf7dn'); + + +select 'invalid values:'; -- must not crash +select geohashEncode(181.0, 91.0); +select geohashEncode(-181.0, -91.0); +select count(geohashDecode('abcdefghijklmnopqrstuvwxyz')); + +select 'constant values:'; +select geohashEncode(-5.60302734375, 42.593994140625, 0); +select round(geohashDecode('ezs42').1, 5), round(geohashDecode('ezs42').2, 5); + +select 'default precision:'; +select geohashEncode(-5.60302734375, 42.593994140625); + +select 'mixing const and non-const-columns:'; +select geohashEncode(materialize(-5.60302734375), materialize(42.593994140625), 0); +select geohashEncode(materialize(-5.60302734375), materialize(42.593994140625), materialize(0)); -- { serverError 44 } + + +select 'from table (with const precision):'; + +-- here results are strings, so reference may contain values to match for equality. +select 1 as p, geohashEncode(longitude, latitude, p) as actual, if(actual = encoded, 'Ok', concat('expected: ', encoded)) from geohash_test_data WHERE length(encoded) = p; +select 2 as p, geohashEncode(longitude, latitude, p) as actual, if(actual = encoded, 'Ok', concat('expected: ', encoded)) from geohash_test_data WHERE length(encoded) = p; +select 3 as p, geohashEncode(longitude, latitude, p) as actual, if(actual = encoded, 'Ok', concat('expected: ', encoded)) from geohash_test_data WHERE length(encoded) = p; +select 4 as p, geohashEncode(longitude, latitude, p) as actual, if(actual = encoded, 'Ok', concat('expected: ', encoded)) from geohash_test_data WHERE length(encoded) = p; +select 5 as p, geohashEncode(longitude, latitude, p) as actual, if(actual = encoded, 'Ok', concat('expected: ', encoded)) from geohash_test_data WHERE length(encoded) = p; +select 6 as p, geohashEncode(longitude, latitude, p) as actual, if(actual = encoded, 'Ok', concat('expected: ', encoded)) from geohash_test_data WHERE length(encoded) = p; +select 7 as p, geohashEncode(longitude, latitude, p) as actual, if(actual = encoded, 'Ok', concat('expected: ', encoded)) from geohash_test_data WHERE length(encoded) = p; +select 8 as p, geohashEncode(longitude, latitude, p) as actual, if(actual = encoded, 'Ok', concat('expected: ', encoded)) from geohash_test_data WHERE length(encoded) = p; +select 9 as p, geohashEncode(longitude, latitude, p) as actual, if(actual = encoded, 'Ok', concat('expected: ', encoded)) from geohash_test_data WHERE length(encoded) = p; +select 10 as p, geohashEncode(longitude, latitude, p) as actual, if(actual = encoded, 'Ok', concat('expected: ', encoded)) from geohash_test_data WHERE length(encoded) = p; +select 11 as p, geohashEncode(longitude, latitude, p) as actual, if(actual = encoded, 'Ok', concat('expected: ', encoded)) from geohash_test_data WHERE length(encoded) = p; +select 12 as p, geohashEncode(longitude, latitude, p) as actual, if(actual = encoded, 'Ok', concat('expected: ', encoded)) from geohash_test_data WHERE length(encoded) = p; + +-- Here results are floats, and hence may not be compared for equality directly. +-- We select all values that are off by some reasonable value: +-- each byte of encoded string provides 5 bits of precison, (roughly 2.5 for lon and lat) +-- each bit of precision divides value range by 2. +-- hence max error is roughly value range 2.5 times divided by 2 for each precision bit. +-- initial value range is [-90..90] for latitude and [-180..180] for longitude. +select 'incorrectly decoded values:'; +select + geohashDecode(encoded) as actual, + 'expected:', encoded, '=>', latitude, longitude, + 'length:', length(encoded), + 'max lat error:', 180 / power(2, 2.5 * length(encoded)) as latitude_max_error, + 'max lon error:', 360 / power(2, 2.5 * length(encoded)) as longitude_max_error, + 'err:', (actual.2 - latitude) as lat_error, (actual.1 - longitude) as lon_error, + 'derr:', abs(lat_error) - latitude_max_error, abs(lon_error) - longitude_max_error +from geohash_test_data +where + abs(lat_error) > latitude_max_error + or + abs(lon_error) > longitude_max_error; + +drop table if exists geohash_test_data; diff --git a/docs/en/query_language/functions/geo.md b/docs/en/query_language/functions/geo.md index 2c9a3aac38f..97c4d1b5b4f 100644 --- a/docs/en/query_language/functions/geo.md +++ b/docs/en/query_language/functions/geo.md @@ -98,5 +98,57 @@ SELECT pointInPolygon((3., 3.), [(6, 0), (8, 4), (5, 8), (0, 2)]) AS res └─────┘ ``` +## geohashEncode + +Encodes latitude and longitude as a geohash-string, please see (http://geohash.org/, https://en.wikipedia.org/wiki/Geohash). +``` +geohashEncode(longitude, latitude, [precision]) +``` + +**Input values** + +- longitude - longitude part of the coordinate you want to encode. Floating in range`[-180°, 180°]` +- latitude - latitude part of the coordinate you want to encode. Floating in range `[-90°, 90°]` +- precision - Optional, length of the resulting encoded string, defaults to `12`. Integer in range `[1, 12]`. Any value less than `1` or greater than `12` is silently converted to `12`. + +**Returned values** + +- alphanumeric `String` of encoded coordinate (modified version of the base32-encoding alphabet is used). + +**Example** + +``` sql +SELECT geohashEncode(-5.60302734375, 42.593994140625, 0) AS res +``` + +``` +┌─res──────────┐ +│ ezs42d000000 │ +└──────────────┘ +``` + +## geohashDecode + +Decodes any geohash-encoded string into longitude and latitude. + +**Input values** + +- encoded string - geohash-encoded string. + +**Returned values** + +- (longitude, latitude) - 2-tuple of `Float64` values of longitude and latitude. + +**Example** + +``` sql +SELECT geohashDecode('ezs42') AS res +``` + +``` +┌─res─────────────────────────────┐ +│ (-5.60302734375,42.60498046875) │ +└─────────────────────────────────┘ +``` [Original article](https://clickhouse.yandex/docs/en/query_language/functions/geo/) From ab6558b8b4f9c92710d8fb4ad600e64e7890816e Mon Sep 17 00:00:00 2001 From: ivan-kush Date: Fri, 10 May 2019 17:29:13 +0300 Subject: [PATCH 111/709] add spaces amp --- dbms/src/Storages/MergeTree/MergeTreeData.cpp | 4 ++-- dbms/src/Storages/MergeTree/MergeTreeData.h | 2 +- dbms/src/Storages/StorageMergeTree.cpp | 4 ++-- 3 files changed, 5 insertions(+), 5 deletions(-) diff --git a/dbms/src/Storages/MergeTree/MergeTreeData.cpp b/dbms/src/Storages/MergeTree/MergeTreeData.cpp index 503d1708300..ea51159d9ba 100644 --- a/dbms/src/Storages/MergeTree/MergeTreeData.cpp +++ b/dbms/src/Storages/MergeTree/MergeTreeData.cpp @@ -1439,10 +1439,10 @@ void MergeTreeData::alterDataPart( const NamesAndTypesList & new_columns, const IndicesASTs & new_indices, bool skip_sanity_checks, - AlterDataPartTransactionPtr& transaction) + AlterDataPartTransactionPtr & transaction) { ExpressionActionsPtr expression; - const auto& part = transaction->getDataPart(); + const auto & part = transaction->getDataPart(); bool force_update_metadata; createConvertExpression(part, part->columns, new_columns, getIndices().indices, new_indices, diff --git a/dbms/src/Storages/MergeTree/MergeTreeData.h b/dbms/src/Storages/MergeTree/MergeTreeData.h index 98ce5b4c371..fecddb28540 100644 --- a/dbms/src/Storages/MergeTree/MergeTreeData.h +++ b/dbms/src/Storages/MergeTree/MergeTreeData.h @@ -228,7 +228,7 @@ public: const DataPart::Checksums & getNewChecksums() const { return new_checksums; } AlterDataPartTransaction(DataPartPtr data_part_) : data_part(data_part_), alter_lock(data_part->alter_mutex) {} - const DataPartPtr& getDataPart() const { return data_part; } + const DataPartPtr & getDataPart() const { return data_part; } bool isValid() const; private: diff --git a/dbms/src/Storages/StorageMergeTree.cpp b/dbms/src/Storages/StorageMergeTree.cpp index d80a05a8bab..fe66a11e6d6 100644 --- a/dbms/src/Storages/StorageMergeTree.cpp +++ b/dbms/src/Storages/StorageMergeTree.cpp @@ -203,7 +203,7 @@ std::vector StorageMergeTree::prepar std::vector transactions; transactions.reserve(parts.size()); - const auto& columns_for_parts = new_columns.getAllPhysical(); + const auto & columns_for_parts = new_columns.getAllPhysical(); const Settings & settings = context.getSettingsRef(); size_t thread_pool_size = std::min(parts.size(), settings.max_alter_threads); @@ -215,7 +215,7 @@ std::vector StorageMergeTree::prepar transactions.push_back(std::make_unique(part)); thread_pool.schedule( - [this, &transaction = transactions.back(), &columns_for_parts, &new_indices = new_indices.indices] + [this, & transaction = transactions.back(), & columns_for_parts, & new_indices = new_indices.indices] { this->alterDataPart(columns_for_parts, new_indices, false, transaction); } From cf95327cba4d764aa3c12a1140e3db43a13c7421 Mon Sep 17 00:00:00 2001 From: hcz Date: Sat, 11 May 2019 01:14:30 +0800 Subject: [PATCH 112/709] Remove unused variables and add comment --- .../AggregateFunctionStatisticsSimple.h | 126 ++++++++++-------- 1 file changed, 68 insertions(+), 58 deletions(-) diff --git a/dbms/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h b/dbms/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h index f034fd5bbc4..fc9531710c8 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h +++ b/dbms/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h @@ -141,28 +141,24 @@ struct VarMomentsDecimal template struct HighOrderMoments { - T m0{}; - T m1{}; - T m2{}; - T m3{}; - T m4{}; + T m[_level + 1]{}; void add(T x) { - ++m0; - m1 += x; - m2 += x * x; - if constexpr (_level >= 3) m3 += x * x * x; - if constexpr (_level >= 4) m4 += x * x * x * x; + ++m[0]; + m[1] += x; + m[2] += x * x; + if constexpr (_level >= 3) m[3] += x * x * x; + if constexpr (_level >= 4) m[4] += x * x * x * x; } void merge(const HighOrderMoments & rhs) { - m0 += rhs.m0; - m1 += rhs.m1; - m2 += rhs.m2; - if constexpr (_level >= 3) m3 += rhs.m3; - if constexpr (_level >= 4) m4 += rhs.m4; + m[0] += rhs.m[0]; + m[1] += rhs.m[1]; + m[2] += rhs.m[2]; + if constexpr (_level >= 3) m[3] += rhs.m[3]; + if constexpr (_level >= 4) m[4] += rhs.m[4]; } void write(WriteBuffer & buf) const @@ -177,78 +173,92 @@ struct HighOrderMoments T NO_SANITIZE_UNDEFINED getPopulation() const { - return (m2 - m1 * m1 / m0) / m0; + return (m[2] - m[1] * m[1] / m[0]) / m[0]; } T NO_SANITIZE_UNDEFINED getSample() const { - if (m0 == 0) + if (m[0] == 0) return std::numeric_limits::quiet_NaN(); - return (m2 - m1 * m1 / m0) / (m0 - 1); + return (m[2] - m[1] * m[1] / m[0]) / (m[0] - 1); } T NO_SANITIZE_UNDEFINED getMoment3() const { // to avoid accuracy problem - if (m0 == 1) + if (m[0] == 1) return 0; - return (m3 - - (3 * m2 - - 2 * m1 * m1 / m0 - ) * m1 / m0 - ) / m0; + return (m[3] + - (3 * m[2] + - 2 * m[1] * m[1] / m[0] + ) * m[1] / m[0] + ) / m[0]; } T NO_SANITIZE_UNDEFINED getMoment4() const { // to avoid accuracy problem - if (m0 == 1) + if (m[0] == 1) return 0; - return (m4 - - (4 * m3 - - (6 * m2 - - 3 * m1 * m1 / m0 - ) * m1 / m0 - ) * m1 / m0 - ) / m0; + return (m[4] + - (4 * m[3] + - (6 * m[2] + - 3 * m[1] * m[1] / m[0] + ) * m[1] / m[0] + ) * m[1] / m[0] + ) / m[0]; } }; +/** + Calculating high-order central moments + References: + https://en.wikipedia.org/wiki/Moment_(mathematics) + https://en.wikipedia.org/wiki/Skewness + https://en.wikipedia.org/wiki/Kurtosis +*/ template struct HighOrderMomentsDecimal { using NativeType = typename T::NativeType; UInt64 m0{}; - NativeType m1{}; - NativeType m2{}; - NativeType m3{}; - NativeType m4{}; + NativeType m[_level]{}; + + NativeType & getM(size_t i) + { + return m[i - 1]; + } + + const NativeType & getM(size_t i) const + { + return m[i - 1]; + } void add(NativeType x) { ++m0; - m1 += x; + getM(1) += x; NativeType tmp; - if (common::mulOverflow(x, x, tmp) || common::addOverflow(m2, tmp, m2)) + if (common::mulOverflow(x, x, tmp) || common::addOverflow(getM(2), tmp, getM(2))) throw Exception("Decimal math overflow", ErrorCodes::DECIMAL_OVERFLOW); - if constexpr (_level >= 3) if (common::mulOverflow(tmp, x, tmp) || common::addOverflow(m3, tmp, m3)) + if constexpr (_level >= 3) if (common::mulOverflow(tmp, x, tmp) || common::addOverflow(getM(3), tmp, getM(3))) throw Exception("Decimal math overflow", ErrorCodes::DECIMAL_OVERFLOW); - if constexpr (_level >= 4) if (common::mulOverflow(tmp, x, tmp) || common::addOverflow(m4, tmp, m4)) + if constexpr (_level >= 4) if (common::mulOverflow(tmp, x, tmp) || common::addOverflow(getM(4), tmp, getM(4))) throw Exception("Decimal math overflow", ErrorCodes::DECIMAL_OVERFLOW); } void merge(const HighOrderMomentsDecimal & rhs) { m0 += rhs.m0; - m1 += rhs.m1; + getM(1) += rhs.getM(1); - if (common::addOverflow(m2, rhs.m2, m2)) + if (common::addOverflow(getM(2), rhs.getM(2), getM(2))) throw Exception("Decimal math overflow", ErrorCodes::DECIMAL_OVERFLOW); - if constexpr (_level >= 3) if (common::addOverflow(m3, rhs.m3, m3)) + if constexpr (_level >= 3) if (common::addOverflow(getM(3), rhs.getM(3), getM(3))) throw Exception("Decimal math overflow", ErrorCodes::DECIMAL_OVERFLOW); - if constexpr (_level >= 4) if (common::addOverflow(m4, rhs.m4, m4)) + if constexpr (_level >= 4) if (common::addOverflow(getM(4), rhs.getM(4), getM(4))) throw Exception("Decimal math overflow", ErrorCodes::DECIMAL_OVERFLOW); } @@ -261,8 +271,8 @@ struct HighOrderMomentsDecimal return std::numeric_limits::infinity(); NativeType tmp; - if (common::mulOverflow(m1, m1, tmp) || - common::subOverflow(m2, NativeType(tmp / m0), tmp)) + if (common::mulOverflow(getM(1), getM(1), tmp) || + common::subOverflow(getM(2), NativeType(tmp / m0), tmp)) throw Exception("Decimal math overflow", ErrorCodes::DECIMAL_OVERFLOW); return convertFromDecimal, DataTypeNumber>(tmp / m0, scale); } @@ -275,8 +285,8 @@ struct HighOrderMomentsDecimal return std::numeric_limits::infinity(); NativeType tmp; - if (common::mulOverflow(m1, m1, tmp) || - common::subOverflow(m2, NativeType(tmp / m0), tmp)) + if (common::mulOverflow(getM(1), getM(1), tmp) || + common::subOverflow(getM(2), NativeType(tmp / m0), tmp)) throw Exception("Decimal math overflow", ErrorCodes::DECIMAL_OVERFLOW); return convertFromDecimal, DataTypeNumber>(tmp / (m0 - 1), scale); } @@ -287,10 +297,10 @@ struct HighOrderMomentsDecimal return std::numeric_limits::infinity(); NativeType tmp; - if (common::mulOverflow(2 * m1, m1, tmp) || - common::subOverflow(3 * m2, NativeType(tmp / m0), tmp) || - common::mulOverflow(tmp, m1, tmp) || - common::subOverflow(m3, NativeType(tmp / m0), tmp)) + if (common::mulOverflow(2 * getM(1), getM(1), tmp) || + common::subOverflow(3 * getM(2), NativeType(tmp / m0), tmp) || + common::mulOverflow(tmp, getM(1), tmp) || + common::subOverflow(getM(3), NativeType(tmp / m0), tmp)) throw Exception("Decimal math overflow", ErrorCodes::DECIMAL_OVERFLOW); return convertFromDecimal, DataTypeNumber>(tmp / m0, scale); } @@ -301,12 +311,12 @@ struct HighOrderMomentsDecimal return std::numeric_limits::infinity(); NativeType tmp; - if (common::mulOverflow(3 * m1, m1, tmp) || - common::subOverflow(6 * m2, NativeType(tmp / m0), tmp) || - common::mulOverflow(tmp, m1, tmp) || - common::subOverflow(4 * m3, NativeType(tmp / m0), tmp) || - common::mulOverflow(tmp, m1, tmp) || - common::subOverflow(m4, NativeType(tmp / m0), tmp)) + if (common::mulOverflow(3 * getM(1), getM(1), tmp) || + common::subOverflow(6 * getM(2), NativeType(tmp / m0), tmp) || + common::mulOverflow(tmp, getM(1), tmp) || + common::subOverflow(4 * getM(3), NativeType(tmp / m0), tmp) || + common::mulOverflow(tmp, getM(1), tmp) || + common::subOverflow(getM(4), NativeType(tmp / m0), tmp)) throw Exception("Decimal math overflow", ErrorCodes::DECIMAL_OVERFLOW); return convertFromDecimal, DataTypeNumber>(tmp / m0, scale); } From ebdd5af7abb9be9a9fc40788bda47e59cebf2fcf Mon Sep 17 00:00:00 2001 From: ivan-kush Date: Sat, 11 May 2019 00:13:50 +0300 Subject: [PATCH 113/709] add test --- ...4_alter_modify_column_partitions.reference | 206 ++++++++++++++++++ .../00754_alter_modify_column_partitions.sql | 24 ++ 2 files changed, 230 insertions(+) create mode 100644 dbms/tests/queries/0_stateless/00754_alter_modify_column_partitions.reference create mode 100644 dbms/tests/queries/0_stateless/00754_alter_modify_column_partitions.sql diff --git a/dbms/tests/queries/0_stateless/00754_alter_modify_column_partitions.reference b/dbms/tests/queries/0_stateless/00754_alter_modify_column_partitions.reference new file mode 100644 index 00000000000..0aedcdf32c5 --- /dev/null +++ b/dbms/tests/queries/0_stateless/00754_alter_modify_column_partitions.reference @@ -0,0 +1,206 @@ +*** Check SHOW CREATE TABLE *** +CREATE TABLE test.alter_column (`x` UInt32, `y` Int32) ENGINE = MergeTree PARTITION BY x ORDER BY x SETTINGS index_granularity = 8192 +*** Check parts *** +0 0 +10 -10 +11 -11 +12 -12 +13 -13 +14 -14 +15 -15 +16 -16 +17 -17 +18 -18 +19 -19 +1 -1 +20 -20 +21 -21 +22 -22 +23 -23 +24 -24 +25 -25 +26 -26 +27 -27 +28 -28 +29 -29 +2 -2 +30 -30 +31 -31 +32 -32 +33 -33 +34 -34 +35 -35 +36 -36 +37 -37 +38 -38 +39 -39 +3 -3 +40 -40 +41 -41 +42 -42 +43 -43 +44 -44 +45 -45 +46 -46 +47 -47 +48 -48 +49 -49 +4 -4 +50 -50 +51 -51 +52 -52 +53 -53 +54 -54 +55 -55 +56 -56 +57 -57 +58 -58 +59 -59 +5 -5 +60 -60 +61 -61 +62 -62 +63 -63 +64 -64 +65 -65 +66 -66 +67 -67 +68 -68 +69 -69 +6 -6 +70 -70 +71 -71 +72 -72 +73 -73 +74 -74 +75 -75 +76 -76 +77 -77 +78 -78 +79 -79 +7 -7 +80 -80 +81 -81 +82 -82 +83 -83 +84 -84 +85 -85 +86 -86 +87 -87 +88 -88 +89 -89 +8 -8 +90 -90 +91 -91 +92 -92 +93 -93 +94 -94 +95 -95 +96 -96 +97 -97 +98 -98 +99 -99 +9 -9 +*** Check SHOW CREATE TABLE after ALTER MODIFY *** +CREATE TABLE test.alter_column (`x` UInt32, `y` Int64) ENGINE = MergeTree PARTITION BY x ORDER BY x SETTINGS index_granularity = 8192 +*** Check parts after ALTER MODIFY *** +0 0 +10 -10 +11 -11 +12 -12 +13 -13 +14 -14 +15 -15 +16 -16 +17 -17 +18 -18 +19 -19 +1 -1 +20 -20 +21 -21 +22 -22 +23 -23 +24 -24 +25 -25 +26 -26 +27 -27 +28 -28 +29 -29 +2 -2 +30 -30 +31 -31 +32 -32 +33 -33 +34 -34 +35 -35 +36 -36 +37 -37 +38 -38 +39 -39 +3 -3 +40 -40 +41 -41 +42 -42 +43 -43 +44 -44 +45 -45 +46 -46 +47 -47 +48 -48 +49 -49 +4 -4 +50 -50 +51 -51 +52 -52 +53 -53 +54 -54 +55 -55 +56 -56 +57 -57 +58 -58 +59 -59 +5 -5 +60 -60 +61 -61 +62 -62 +63 -63 +64 -64 +65 -65 +66 -66 +67 -67 +68 -68 +69 -69 +6 -6 +70 -70 +71 -71 +72 -72 +73 -73 +74 -74 +75 -75 +76 -76 +77 -77 +78 -78 +79 -79 +7 -7 +80 -80 +81 -81 +82 -82 +83 -83 +84 -84 +85 -85 +86 -86 +87 -87 +88 -88 +89 -89 +8 -8 +90 -90 +91 -91 +92 -92 +93 -93 +94 -94 +95 -95 +96 -96 +97 -97 +98 -98 +99 -99 +9 -9 diff --git a/dbms/tests/queries/0_stateless/00754_alter_modify_column_partitions.sql b/dbms/tests/queries/0_stateless/00754_alter_modify_column_partitions.sql new file mode 100644 index 00000000000..71c482c8d53 --- /dev/null +++ b/dbms/tests/queries/0_stateless/00754_alter_modify_column_partitions.sql @@ -0,0 +1,24 @@ +-- check ALTER MODIFY COLUMN with partitions + +SET send_logs_level = 'none'; + +DROP TABLE IF EXISTS test.alter_column; + +CREATE TABLE test.alter_column(x UInt32, y Int32) ENGINE MergeTree PARTITION BY x ORDER BY x; +INSERT INTO test.alter_column (x, y) SELECT number AS x, -number AS y FROM system.numbers LIMIT 100; + +SELECT '*** Check SHOW CREATE TABLE ***'; +SHOW CREATE TABLE test.alter_column; + +SELECT '*** Check parts ***'; +SELECT * FROM test.alter_column ORDER BY _part; + +ALTER TABLE test.alter_column MODIFY COLUMN y Int64; + +SELECT '*** Check SHOW CREATE TABLE after ALTER MODIFY ***'; +SHOW CREATE TABLE test.alter_column; + +SELECT '*** Check parts after ALTER MODIFY ***'; +SELECT * FROM test.alter_column ORDER BY _part; + +DROP TABLE test.alter_column; From 5f6ab5eb10cbea5dfbecd83b00953ede9fd782af Mon Sep 17 00:00:00 2001 From: ivan-kush Date: Sat, 11 May 2019 21:28:06 +0300 Subject: [PATCH 114/709] tsan? --- ...4_alter_modify_column_partitions.reference | 100 ------------------ .../00754_alter_modify_column_partitions.sql | 2 +- 2 files changed, 1 insertion(+), 101 deletions(-) diff --git a/dbms/tests/queries/0_stateless/00754_alter_modify_column_partitions.reference b/dbms/tests/queries/0_stateless/00754_alter_modify_column_partitions.reference index 0aedcdf32c5..058704085bb 100644 --- a/dbms/tests/queries/0_stateless/00754_alter_modify_column_partitions.reference +++ b/dbms/tests/queries/0_stateless/00754_alter_modify_column_partitions.reference @@ -46,60 +46,10 @@ CREATE TABLE test.alter_column (`x` UInt32, `y` Int32) ENGINE = MergeTree PARTIT 48 -48 49 -49 4 -4 -50 -50 -51 -51 -52 -52 -53 -53 -54 -54 -55 -55 -56 -56 -57 -57 -58 -58 -59 -59 5 -5 -60 -60 -61 -61 -62 -62 -63 -63 -64 -64 -65 -65 -66 -66 -67 -67 -68 -68 -69 -69 6 -6 -70 -70 -71 -71 -72 -72 -73 -73 -74 -74 -75 -75 -76 -76 -77 -77 -78 -78 -79 -79 7 -7 -80 -80 -81 -81 -82 -82 -83 -83 -84 -84 -85 -85 -86 -86 -87 -87 -88 -88 -89 -89 8 -8 -90 -90 -91 -91 -92 -92 -93 -93 -94 -94 -95 -95 -96 -96 -97 -97 -98 -98 -99 -99 9 -9 *** Check SHOW CREATE TABLE after ALTER MODIFY *** CREATE TABLE test.alter_column (`x` UInt32, `y` Int64) ENGINE = MergeTree PARTITION BY x ORDER BY x SETTINGS index_granularity = 8192 @@ -149,58 +99,8 @@ CREATE TABLE test.alter_column (`x` UInt32, `y` Int64) ENGINE = MergeTree PARTIT 48 -48 49 -49 4 -4 -50 -50 -51 -51 -52 -52 -53 -53 -54 -54 -55 -55 -56 -56 -57 -57 -58 -58 -59 -59 5 -5 -60 -60 -61 -61 -62 -62 -63 -63 -64 -64 -65 -65 -66 -66 -67 -67 -68 -68 -69 -69 6 -6 -70 -70 -71 -71 -72 -72 -73 -73 -74 -74 -75 -75 -76 -76 -77 -77 -78 -78 -79 -79 7 -7 -80 -80 -81 -81 -82 -82 -83 -83 -84 -84 -85 -85 -86 -86 -87 -87 -88 -88 -89 -89 8 -8 -90 -90 -91 -91 -92 -92 -93 -93 -94 -94 -95 -95 -96 -96 -97 -97 -98 -98 -99 -99 9 -9 diff --git a/dbms/tests/queries/0_stateless/00754_alter_modify_column_partitions.sql b/dbms/tests/queries/0_stateless/00754_alter_modify_column_partitions.sql index 71c482c8d53..0e4e0a14237 100644 --- a/dbms/tests/queries/0_stateless/00754_alter_modify_column_partitions.sql +++ b/dbms/tests/queries/0_stateless/00754_alter_modify_column_partitions.sql @@ -5,7 +5,7 @@ SET send_logs_level = 'none'; DROP TABLE IF EXISTS test.alter_column; CREATE TABLE test.alter_column(x UInt32, y Int32) ENGINE MergeTree PARTITION BY x ORDER BY x; -INSERT INTO test.alter_column (x, y) SELECT number AS x, -number AS y FROM system.numbers LIMIT 100; +INSERT INTO test.alter_column (x, y) SELECT number AS x, -number AS y FROM system.numbers LIMIT 50; SELECT '*** Check SHOW CREATE TABLE ***'; SHOW CREATE TABLE test.alter_column; From 22389d4eca5e1e5056eed9c30f44d0492ff1a894 Mon Sep 17 00:00:00 2001 From: svladykin Date: Sun, 12 May 2019 17:47:31 +0300 Subject: [PATCH 115/709] Support for bitmapHasAny and bitmapHasAll functions. --- dbms/programs/server/data/.gitignore | 3 + .../AggregateFunctionGroupBitmapData.h | 84 ++- dbms/src/Functions/FunctionsBitmap.cpp | 2 + dbms/src/Functions/FunctionsBitmap.h | 42 +- .../00829_bitmap_function.reference | 26 + .../0_stateless/00829_bitmap_function.sql | 67 +- .../functions/bitmap_functions.md | 604 ++++++++++-------- 7 files changed, 536 insertions(+), 292 deletions(-) diff --git a/dbms/programs/server/data/.gitignore b/dbms/programs/server/data/.gitignore index 5d26e622e3e..3e223bc0920 100644 --- a/dbms/programs/server/data/.gitignore +++ b/dbms/programs/server/data/.gitignore @@ -1,2 +1,5 @@ *.bin *.mrk +*.txt +*.dat +*.idx diff --git a/dbms/src/AggregateFunctions/AggregateFunctionGroupBitmapData.h b/dbms/src/AggregateFunctions/AggregateFunctionGroupBitmapData.h index 7f41e3f4fcf..72cc6aace08 100644 --- a/dbms/src/AggregateFunctions/AggregateFunctionGroupBitmapData.h +++ b/dbms/src/AggregateFunctions/AggregateFunctionGroupBitmapData.h @@ -308,16 +308,86 @@ public: /** * Check whether two bitmaps intersect. + * Intersection with an empty set is always 0 (consistent with hasAny). */ - UInt8 rb_intersect(const RoaringBitmapWithSmallSet & r1) + UInt8 rb_intersect(const RoaringBitmapWithSmallSet & r1) const { if (isSmall()) - toLarge(); - roaring_bitmap_t * rb1 = r1.isSmall() ? r1.getNewRbFromSmall() : r1.getRb(); - UInt8 is_true = roaring_bitmap_intersect(rb, rb1); - if (r1.isSmall()) - roaring_bitmap_free(rb1); - return is_true; + { + if (r1.isSmall()) { + for (const auto & x : r1.small) + if (small.find(x.getValue()) != small.end()) + return 1; + } + else + { + for (const auto & x : small) + if (roaring_bitmap_contains(r1.rb, x.getValue())) + return 1; + } + } + else if (r1.isSmall()) + { + for (const auto & x : r1.small) + if (roaring_bitmap_contains(rb, x.getValue())) + return 1; + } + else if (roaring_bitmap_intersect(rb, r1.rb)) + return 1; + + return 0; + } + + /** + * Check whether the argument is the subset of this set. + * Empty set is a subset of any other set (consistent with hasAll). + */ + UInt8 rb_is_subset(const RoaringBitmapWithSmallSet & r1) const + { + if (isSmall()) + { + if (r1.isSmall()) + { + for (const auto & x : r1.small) + if (small.find(x.getValue()) == small.end()) + return 0; + } + else { + UInt64 r1_size = r1.size(); + + if (r1_size > small.size()) + return 0; // A bigger set can not be a subset of ours. + + // This is a rare case with a small number of elements on + // both sides: r1 was promoted to large for some reason and + // it is still not larger than our small set. + // If r1 is our subset then our size must be equal to + // r1_size + number of not found elements, if this sum becomes + // greater then r1 is not a subset. + for (const auto & x : small) + if (!roaring_bitmap_contains(r1.rb, x.getValue()) && ++r1_size > small.size()) + return 0; + } + } + else if (r1.isSmall()) + { + for (const auto & x : r1.small) + if (!roaring_bitmap_contains(rb, x.getValue())) + return 0; + } + else if (!roaring_bitmap_is_subset(r1.rb, rb)) + return 0; + + return 1; + } + + /** + * Check whether this bitmap contains the argument. + */ + UInt8 rb_contains(const UInt32 x) const + { + return isSmall() ? small.find(x) != small.end() : + roaring_bitmap_contains(rb, x); } /** diff --git a/dbms/src/Functions/FunctionsBitmap.cpp b/dbms/src/Functions/FunctionsBitmap.cpp index 1b4bcbaaf7b..c3763124bcf 100644 --- a/dbms/src/Functions/FunctionsBitmap.cpp +++ b/dbms/src/Functions/FunctionsBitmap.cpp @@ -21,5 +21,7 @@ void registerFunctionsBitmap(FunctionFactory & factory) factory.registerFunction(); factory.registerFunction(); + factory.registerFunction(); + factory.registerFunction(); } } diff --git a/dbms/src/Functions/FunctionsBitmap.h b/dbms/src/Functions/FunctionsBitmap.h index c5b0bc78d61..21083f49908 100644 --- a/dbms/src/Functions/FunctionsBitmap.h +++ b/dbms/src/Functions/FunctionsBitmap.h @@ -342,7 +342,27 @@ struct BitmapAndnotCardinalityImpl } }; -template