repo_id
stringlengths 21
96
| file_path
stringlengths 31
155
| content
stringlengths 1
92.9M
| __index_level_0__
int64 0
0
|
---|---|---|---|
rapidsai_public_repos/node/modules/sql
|
rapidsai_public_repos/node/modules/sql/src/json_plan.ts
|
// Copyright (c) 2021, NVIDIA CORPORATION.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
import {spawnSync} from 'child_process';
export const json_plan_py = (algebra: string, shouldFormat: 'True'|'False' = 'False') => {
const {stderr, stdout} =
spawnSync('python3', [
'-c',
`
import collections
import json
import re
__all__ = ["get_json_plan", "format_json_plan"]
def visitJson(data, result, level):
level += 1
isValid = True
while isValid:
if "expr" in data:
result += (" " * level) + data["expr"] + "\\n"
if "children" in data:
if data["children"] != "":
lenData = len(data["children"])
for i in range(lenData):
result = visitJson(data["children"][i], result, level)
return result
else:
return result
def format_json_plan(json_plan):
data = json.loads(json_plan)
result = ""
result = visitJson(data, result, -1)
return result
def get_json_plan(algebra):
lines = algebra.split("\\n")
lines = _replace_indentation_for_tabs(lines)
lines = list(filter(None, lines))
list_step = _lines_to_list_steps(lines)
return _visit(list_step)
def _is_double_children(expr):
return "LogicalJoin" in expr or "LogicalUnion" in expr
def _visit(lines):
deque = collections.deque()
root_level = 0
dicc = {"expr": lines[root_level][1], "children": []}
processed = set()
for index in range(len(lines)):
child_level, expr = lines[index]
if child_level == root_level + 1:
new_dicc = {"expr": expr, "children": []}
if (len(dicc["children"]) == 0):
dicc["children"] = [new_dicc]
else:
dicc["children"].append(new_dicc)
deque.append((index, child_level, expr, new_dicc))
processed.add(index)
for index in processed:
lines[index][0] = -1
while len(deque) > 0:
curr_index, curr_level, curr_expr, curr_dicc = deque.pop()
processed = set()
if curr_index < len(lines) - 1: # is brother
child_level, expr = lines[curr_index + 1]
if child_level == curr_level:
continue
elif child_level == curr_level + 1:
index = curr_index + 1
if _is_double_children(curr_expr):
while index < len(lines) and len(curr_dicc["children"]) < 2:
child_level, expr = lines[index]
if child_level == curr_level + 1:
new_dicc = {"expr": expr, "children": []}
if len(curr_dicc["children"]) == 0:
curr_dicc["children"] = [new_dicc]
else:
curr_dicc["children"].append(new_dicc)
processed.add(index)
deque.append((index, child_level, expr, new_dicc))
index += 1
else:
while index < len(lines) and len(curr_dicc["children"]) < 1:
child_level, expr = lines[index]
if child_level == curr_level + 1:
new_dicc = {"expr": expr, "children": []}
if len(curr_dicc["children"]) == 0:
curr_dicc["children"] = [new_dicc]
else:
curr_dicc["children"].append(new_dicc)
processed.add(index)
deque.append((index, child_level, expr, new_dicc))
index += 1
for index in processed:
lines[index][0] = -1
return json.dumps(dicc)
def _validate_indendation(indentation_type, current_indentation):
if not current_indentation:
return
match = re.search("^(" + indentation_type + ")+$", current_indentation)
if not match:
raise Exception(
"Indentation invalid, current indentation is ("
+ indentation_type
+ "), but ("
+ current_indentation
+ ") was received."
)
def _replace_indentation_for_tabs(lines):
indentation_type = ""
for i in range(len(lines)):
lines[i] = lines[i].rstrip()
match = re.search(r"(^\\s+)(.*)", lines[i])
if match:
if not indentation_type:
indentation_type = match.group(1)
else:
_validate_indendation(indentation_type, match.group(1))
expr = match.group(2)
else:
expr = lines[i]
beginning_spaces = len(lines[i]) - len(expr)
if beginning_spaces > 0:
lines[i] = ("\\t" * (beginning_spaces // len(indentation_type))) + expr
return lines
def _lines_to_list_steps(lines):
# It also removes the tabs in each expression
list_step = []
for i in range(len(lines)):
line = lines[i]
level = line.count("\\t")
list_step.append([level, line.replace("\\t", "")])
return list_step
if ${shouldFormat}:
print(format_json_plan("""${algebra}"""))
else:
print(get_json_plan("""${algebra}"""))
`
]);
if (stderr.length) { throw new Error('' + stderr.toString()); }
return '' + stdout.toString();
};
| 0 |
rapidsai_public_repos/node/modules/sql
|
rapidsai_public_repos/node/modules/sql/src/addon.cpp
|
// Copyright (c) 2021-2022, NVIDIA CORPORATION.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
#include <blazingsql_wrapper/api.hpp>
#include <blazingsql_wrapper/cache.hpp>
#include <blazingsql_wrapper/graph.hpp>
#include <nv_node/utilities/args.hpp>
struct rapidsai_sql : public nv::EnvLocalAddon, public Napi::Addon<rapidsai_sql> {
rapidsai_sql(Napi::Env env, Napi::Object exports) : nv::EnvLocalAddon(env, exports) {
DefineAddon(
exports,
{
InstanceMethod("init", &rapidsai_sql::InitAddon),
InstanceValue("_cpp_exports", _cpp_exports.Value()),
InstanceValue("Context", InitClass<nv::blazingsql::Context>(env, exports)),
InstanceValue("UcpContext", InitClass<nv::blazingsql::UcpContext>(env, exports)),
InstanceValue("CacheMachine", InitClass<nv::blazingsql::CacheMachine>(env, exports)),
InstanceValue("ExecutionGraph", InitClass<nv::blazingsql::ExecutionGraph>(env, exports)),
InstanceMethod<&rapidsai_sql::parse_schema>("parseSchema"),
InstanceMethod<&rapidsai_sql::get_table_scan_info>("getTableScanInfo"),
InstanceMethod<&rapidsai_sql::run_generate_physical_graph>("runGeneratePhysicalGraph"),
});
}
private:
Napi::Value get_table_scan_info(Napi::CallbackInfo const& info) {
auto env = info.Env();
auto [names, steps] = nv::blazingsql::get_table_scan_info(info[0].ToString());
Napi::Array table_names = Napi::Array::New(env, names.size());
Napi::Array table_scans = Napi::Array::New(env, steps.size());
for (std::size_t i = 0; i < names.size(); ++i) {
table_names[i] = Napi::String::New(env, names[i]);
}
for (std::size_t i = 0; i < steps.size(); ++i) {
table_scans[i] = Napi::String::New(env, steps[i]);
}
auto result = Napi::Array::New(env, 2);
result.Set(0u, table_names);
result.Set(1u, table_scans);
return result;
}
Napi::Value run_generate_physical_graph(Napi::CallbackInfo const& info) {
auto env = info.Env();
nv::CallbackArgs args{info};
std::vector<std::string> worker_ids = args[0];
int32_t ctx_token = args[1];
std::string query = args[2];
return Napi::String::New(
env, nv::blazingsql::run_generate_physical_graph(0, worker_ids, ctx_token, query));
}
Napi::Value parse_schema(Napi::CallbackInfo const& info) {
auto env = info.Env();
nv::CallbackArgs args{info};
std::vector<std::string> input = args[0];
std::string file_type = args[1];
return nv::blazingsql::parse_schema(env, input, file_type, false);
}
};
NODE_API_ADDON(rapidsai_sql);
| 0 |
rapidsai_public_repos/node/modules/sql
|
rapidsai_public_repos/node/modules/sql/src/addon.ts
|
// Copyright (c) 2021-2022, NVIDIA CORPORATION.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
/* eslint-disable @typescript-eslint/no-redeclare */
import {addon as CORE} from '@rapidsai/core';
import {addon as CUDA} from '@rapidsai/cuda';
import {addon as CUDF} from '@rapidsai/cudf';
import {addon as RMM} from '@rapidsai/rmm';
export const {
parseSchema,
getTableScanInfo,
runGeneratePhysicalGraph,
Context,
UcpContext,
ExecutionGraph,
_cpp_exports,
} = require('bindings')('rapidsai_sql.node').init(CORE, CUDA, RMM, CUDF) as
typeof import('./rapidsai_sql');
export type getTableScanInfo = typeof import('./rapidsai_sql').getTableScanInfo;
export type runGeneratePhysicalGraph = typeof import('./rapidsai_sql').runGeneratePhysicalGraph;
export type parseSchema = typeof import('./rapidsai_sql').parseSchema;
export type Context = import('./rapidsai_sql').Context;
export type UcpContext = import('./rapidsai_sql').UcpContext;
export type ExecutionGraph = import('./rapidsai_sql').ExecutionGraph;
export type ContextProps = import('./rapidsai_sql').ContextProps;
export type WorkerUcpInfo = import('./rapidsai_sql').WorkerUcpInfo;
| 0 |
rapidsai_public_repos/node/modules/sql/src
|
rapidsai_public_repos/node/modules/sql/src/cluster/remote.ts
|
// Copyright (c) 2021, NVIDIA CORPORATION.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
/* eslint-disable @typescript-eslint/no-unused-vars */
/* eslint-disable @typescript-eslint/await-thenable */
import {ChildProcess, fork} from 'child_process';
import {nanoid} from 'nanoid';
import * as Path from 'path';
import {ContextProps} from '../addon';
import {SQLCluster, Worker} from '../cluster';
const remoteWorkerPath =
Path.resolve(__dirname.includes('/src') ? `${__dirname}/../../build/js/cluster/worker.js`
: `${__dirname}/worker.js`);
export class RemoteSQLWorker implements Worker {
declare public readonly id: number;
declare private _proc: ChildProcess;
declare private _jobs: Map<string, {
promise: Promise<any>,
resolve: (val: any) => any,
reject: (err?: any) => any,
}>;
declare private _cluster: SQLCluster;
constructor(cluster: SQLCluster, id: number, env: any = {...process.env}) {
this.id = id;
this._jobs = new Map();
this._cluster = cluster;
this._proc = fork(remoteWorkerPath, {env})
.on('message', this._recv.bind(this))
.on('exit', this._onExit.bind(this))
.on('error', this._onError.bind(this))
.on('close', this._onClose.bind(this))
.on('disconnect', this._onDisconnect.bind(this));
}
public kill() {
if (this._connected) {
this._proc.send({type: 'exit', code: 0});
this._proc.kill();
}
}
public createContext(props: Omit<ContextProps, 'id'>) {
const {id} = this, port = props.port + id;
return this._send({type: 'init', ...props, id, port}).then(() => undefined);
}
public createDataFrameTable(name: string, table_id: string) {
return this._send({type: 'createDataFrameTable', name, table_id}).then(() => undefined);
}
public createCSVTable(name: string, paths: string[]) {
return this._send({type: 'createCSVTable', name, paths}).then(() => undefined);
}
public createParquetTable(name: string, paths: string[]) {
return this._send({type: 'createParquetTable', name, paths}).then(() => undefined);
}
public createORCTable(name: string, paths: string[]) {
return this._send({type: 'createORCTable', name, paths}).then(() => undefined);
}
public dropTable(name: string) {
return this._send({type: 'dropTable', name}).then(() => undefined);
}
public sql(query: string, token: number) {
return this._send({type: 'sql', query, token, destinationId: this._cluster.context.id})
.then(({messageIds}: {messageIds: string[]}) => {
return Promise.all(messageIds.map((messageId: string) => {
return this._cluster.context.pull(messageId).then((df) => {
// eslint-disable-next-line @typescript-eslint/no-floating-promises
this._send({type: 'release', messageId});
return df;
});
}));
});
}
private _send({type, ...rest}: any = {}) {
if (this._connected) {
const uuid = nanoid();
this._jobs.set(uuid, promiseSubject());
this._proc.send({type, uuid, ...rest});
// eslint-disable-next-line @typescript-eslint/no-non-null-assertion
return this._jobs.get(uuid)!.promise;
}
return Promise.resolve({});
}
private _recv({error, ...rest}: any = {}) {
const {uuid} = rest;
if (uuid && this._jobs.has(uuid)) {
// eslint-disable-next-line @typescript-eslint/no-non-null-assertion
const {resolve, reject} = this._jobs.get(uuid)!;
this._jobs.delete(uuid);
(error != null) ? reject(error) : resolve(rest);
}
}
private get _connected() { return this._proc && !this._proc.killed; }
private _onExit(..._: any[]) {
// console.log(`worker ${this.id} exit`, ..._);
}
private _onError(..._: any[]) {
// console.log(`worker ${this.id} error`, ..._);
}
private _onClose(..._: any[]) {
// console.log(`worker ${this.id} close`, ..._);
}
private _onDisconnect(..._: any[]) {
// console.log(`worker ${this.id} disconnect`, ..._);
}
}
function promiseSubject() {
let resolve = (_x: any) => {};
let reject = (_er: any) => {};
const promise = new Promise((r1, r2) => {
resolve = r1;
reject = r2;
});
return {promise, resolve, reject};
}
| 0 |
rapidsai_public_repos/node/modules/sql/src
|
rapidsai_public_repos/node/modules/sql/src/cluster/worker.ts
|
// Copyright (c) 2021, NVIDIA CORPORATION.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
import {DataFrame} from '@rapidsai/cudf';
import {ContextProps, UcpContext} from '../addon';
import {SQLContext} from '../context';
let context: SQLContext;
const allInFlightTables: Record<string, DataFrame> = {};
function die({code = 0}: any) { process.exit(code); }
// eslint-disable-next-line @typescript-eslint/no-unused-vars
function init({uuid, ...props}: {uuid: string}&ContextProps) {
context = new SQLContext({...props, ucpContext: new UcpContext()});
}
function dropTable({name}: {name: string}) { context.dropTable(name); }
async function createDataFrameTable({name, table_id}: {name: string, table_id: string}) {
const table = await context.pull(table_id);
context.createDataFrameTable(name, table);
}
function createCSVTable({name, paths}: {name: string, paths: string[]}) {
context.createCSVTable(name, paths);
}
function createParquetTable({name, paths}: {name: string, paths: string[]}) {
context.createParquetTable(name, paths);
}
function createORCTable({name, paths}: {name: string, paths: string[]}) {
context.createORCTable(name, paths);
}
async function sql({query, token, destinationId}:
{uuid: string, query: string, token: number; destinationId: number}) {
const newInFlightTables = await context.sql(query, token).sendTo(destinationId);
Object.assign(allInFlightTables, newInFlightTables);
return {messageIds: Object.keys(newInFlightTables)};
}
function release({messageId}: {messageId: string}) {
const df = allInFlightTables[messageId];
if (df) {
delete allInFlightTables[messageId];
df.dispose();
}
}
process.on('message', ({type, ...opts}: any) => {
// eslint-disable-next-line @typescript-eslint/no-floating-promises
(async () => {
switch (type) {
case 'kill': return die(opts);
case 'init': return init(opts);
case 'sql': return await sql(opts);
case 'release': return release(opts);
case 'dropTable': return dropTable(opts);
case 'createDataFrameTable': return await createDataFrameTable(opts);
case 'createCSVTable': return createCSVTable(opts);
case 'createParquetTable': return createParquetTable(opts);
case 'createORCTable': return createORCTable(opts);
}
return {};
})()
.catch((error) => {
if (opts.uuid && process.send) {
process.send({
error: {message: error?.message || 'Unknown error', stack: error?.stack},
uuid: opts.uuid
});
}
})
.then((res: any) => {
if (opts.uuid && process.send) { process.send({...res, uuid: opts.uuid}); }
});
});
| 0 |
rapidsai_public_repos/node/modules/sql/src
|
rapidsai_public_repos/node/modules/sql/src/cluster/local.ts
|
// Copyright (c) 2021-2022, NVIDIA CORPORATION.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
/* eslint-disable @typescript-eslint/await-thenable */
import {ContextProps, UcpContext} from '../addon';
import {Worker} from '../cluster';
import {SQLContext} from '../context';
export class LocalSQLWorker implements Worker {
declare public readonly id: number;
declare public context: SQLContext;
constructor(id: number) { this.id = id; }
public kill() {}
public createContext(props: Omit<ContextProps, 'id'>) {
return new Promise<void>((resolve) => {
const {id} = this, port = props.port + id;
this.context = new SQLContext({...props, id, port, ucpContext: new UcpContext});
resolve();
});
}
public async createDataFrameTable(name: string, table_id: string) {
const table = await this.context.pull(table_id);
this.context.createDataFrameTable(name, table);
}
public async createCSVTable(name: string, paths: string[]) {
await this.context.createCSVTable(name, paths);
}
public async createParquetTable(name: string, paths: string[]) {
await this.context.createParquetTable(name, paths);
}
public async createORCTable(name: string, paths: string[]) {
await this.context.createORCTable(name, paths);
}
public async dropTable(name: string) { await this.context.dropTable(name); }
public async sql(query: string, token: number) { return await this.context.sql(query, token); }
}
| 0 |
rapidsai_public_repos/node/modules/sql
|
rapidsai_public_repos/node/modules/sql/test/sql-cluster-io-tests.ts
|
// Copyright (c) 2021, NVIDIA CORPORATION.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
import {DataFrame, Float64, Int64, Series, Utf8String} from '@rapidsai/cudf';
import {SQLCluster} from '@rapidsai/sql';
import {promises} from 'fs';
import * as Path from 'path';
describe('CSV', () => {
test('create, list, describe, and drop CSV table', async () => {
const rows = [
{a: 0, b: 0.0, c: 'foo'},
{a: 1, b: 1.1, c: 'bar'},
{a: 2, b: 2.2, c: 'foo'},
];
const path = Path.join(tmpDir, 'simple.csv');
await promises.writeFile(path, makeCSVString({rows}));
const sqlContext = await SQLCluster.init({numWorkers: 2});
await sqlContext.createCSVTable('test_table', [path]);
expect(sqlContext.listTables()).toEqual(['test_table']);
const tableDescription = sqlContext.describeTable('test_table');
expect([...tableDescription.keys()]).toEqual(['a', 'b', 'c']);
expect([...tableDescription.values()]).toEqual([new Int64, new Float64, new Utf8String]);
await sqlContext.dropTable('test_table');
expect(sqlContext.listTables().length).toEqual(0);
});
test('query CSV table', async () => {
const rows = [
{a: 0, b: 0.0, c: 'foo'},
{a: 1, b: 1.1, c: 'bar'},
{a: 2, b: 2.2, c: 'foo'},
];
const path = Path.join(tmpDir, 'simple.csv');
await promises.writeFile(path, makeCSVString({rows}));
const sqlContext = await SQLCluster.init({numWorkers: 2});
await sqlContext.createCSVTable('test_table', [path]);
await expect(sqlContext.sql('SELECT c FROM test_table')).resolves.toStrictEqual([new DataFrame(
{'c': Series.new(['foo', 'bar', 'foo'])})]);
});
});
describe('Parquet', () => {
test('create, list, describe, and drop Parquet table', async () => {
const a = Series.new([1.0, 2.0, 3.0]);
const b = Series.new(['foo', 'bar', 'foo']);
const df = new DataFrame({'a': a, 'b': b});
const path = Path.join(tmpDir, 'simple.parquet');
df.toParquet(path);
const sqlContext = await SQLCluster.init({numWorkers: 2});
await sqlContext.createParquetTable('test_table', [path]);
expect(sqlContext.listTables()).toEqual(['test_table']);
const tableDescription = sqlContext.describeTable('test_table');
expect([...tableDescription.keys()]).toEqual(['a', 'b']);
expect([...tableDescription.values()]).toEqual([new Float64, new Utf8String]);
await sqlContext.dropTable('test_table');
expect(sqlContext.listTables().length).toEqual(0);
});
test('query Parquet table', async () => {
const a = Series.new([1.0, 2.0, 3.0]);
const b = Series.new(['foo', 'bar', 'foo']);
const df = new DataFrame({'a': a, 'b': b});
const path = Path.join(tmpDir, 'simple.parquet');
df.toParquet(path);
const sqlContext = await SQLCluster.init({numWorkers: 2});
await sqlContext.createParquetTable('test_table', [path]);
await expect(sqlContext.sql('SELECT b FROM test_table')).resolves.toStrictEqual([new DataFrame(
{'b': Series.new(['foo', 'bar', 'foo'])})]);
});
});
describe('ORC', () => {
test('create, list, describe, and drop ORC table', async () => {
const a = Series.new([1.0, 2.0, 3.0]);
const b = Series.new(['foo', 'bar', 'foo']);
const df = new DataFrame({'a': a, 'b': b});
const path = Path.join(tmpDir, 'simple.orc');
df.toORC(path);
const sqlContext = await SQLCluster.init({numWorkers: 2});
await sqlContext.createORCTable('test_table', [path]);
expect(sqlContext.listTables()).toEqual(['test_table']);
const tableDescription = sqlContext.describeTable('test_table');
expect([...tableDescription.keys()]).toEqual(['a', 'b']);
expect([...tableDescription.values()]).toEqual([new Float64, new Utf8String]);
await sqlContext.dropTable('test_table');
expect(sqlContext.listTables().length).toEqual(0);
});
test('query ORC table', async () => {
const a = Series.new([1.0, 2.0, 3.0]);
const b = Series.new(['foo', 'bar', 'foo']);
const df = new DataFrame({'a': a, 'b': b});
const path = Path.join(tmpDir, 'simple.orc');
df.toORC(path);
const sqlContext = await SQLCluster.init({numWorkers: 2});
await sqlContext.createORCTable('test_table', [path]);
await expect(sqlContext.sql('SELECT b FROM test_table')).resolves.toStrictEqual([new DataFrame(
{'b': Series.new(['foo', 'bar', 'foo'])})]);
});
});
let tmpDir = '';
const rimraf = require('rimraf');
function makeCSVString(
opts: {rows?: any[], delimiter?: string, lineTerminator?: string, header?: boolean} = {}) {
const {rows = [], delimiter = ',', lineTerminator = '\n', header = true} = opts;
const names = Object.keys(rows.reduce(
(keys, row) => Object.keys(row).reduce((keys, key) => ({...keys, [key]: true}), keys), {}));
return [
...[header ? names.join(delimiter) : []],
...rows.map((row) =>
names.map((name) => row[name] === undefined ? '' : row[name]).join(delimiter))
].join(lineTerminator) +
lineTerminator;
}
beforeAll(async () => { //
tmpDir = await promises.mkdtemp(Path.join('/tmp', 'node_sql'));
});
afterAll(() => {
return new Promise<void>((resolve, reject) => { //
rimraf(tmpDir, (err?: Error|null) => err ? reject(err) : resolve());
});
});
| 0 |
rapidsai_public_repos/node/modules/sql
|
rapidsai_public_repos/node/modules/sql/test/tsconfig.json
|
{
"extends": "../tsconfig.json",
"include": [
"../src/**/*.ts",
"../test/**/*.ts"
],
"compilerOptions": {
"target": "esnext",
"module": "commonjs",
"allowJs": true,
"importHelpers": false,
"noEmitHelpers": false,
"noEmitOnError": false,
"sourceMap": false,
"inlineSources": false,
"inlineSourceMap": false,
"downlevelIteration": false,
"baseUrl": "../",
"paths": {
"@rapidsai/sql": ["src/index"],
"@rapidsai/sql/*": ["src/*"]
}
}
}
| 0 |
rapidsai_public_repos/node/modules/sql
|
rapidsai_public_repos/node/modules/sql/test/sql-context-io-tests.ts
|
// Copyright (c) 2021, NVIDIA CORPORATION.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
import {DataFrame, Float64, Int64, Series, Utf8String} from '@rapidsai/cudf';
import {SQLContext} from '@rapidsai/sql';
import {promises} from 'fs';
import * as Path from 'path';
describe('CSV', () => {
test('create, list, describe, and drop CSV table', async () => {
const rows = [
{a: 0, b: 0.0, c: 'foo'},
{a: 1, b: 1.1, c: 'bar'},
{a: 2, b: 2.2, c: 'foo'},
];
const path = Path.join(tmpDir, 'simple.csv');
await promises.writeFile(path, makeCSVString({rows}));
const sqlContext = new SQLContext();
sqlContext.createCSVTable('test_table', [path]);
expect(sqlContext.listTables()).toEqual(['test_table']);
const tableDescription = sqlContext.describeTable('test_table');
expect([...tableDescription.keys()]).toEqual(['a', 'b', 'c']);
expect([...tableDescription.values()]).toEqual([new Int64, new Float64, new Utf8String]);
sqlContext.dropTable('test_table');
expect(sqlContext.listTables().length).toEqual(0);
});
test('query CSV table', async () => {
const rows = [
{a: 0, b: 0.0, c: 'foo'},
{a: 1, b: 1.1, c: 'bar'},
{a: 2, b: 2.2, c: 'foo'},
];
const path = Path.join(tmpDir, 'simple.csv');
await promises.writeFile(path, makeCSVString({rows}));
const sqlContext = new SQLContext();
sqlContext.createCSVTable('test_table', [path]);
await expect(sqlContext.sql('SELECT c FROM test_table').result()).resolves.toStrictEqual([
new DataFrame({'c': Series.new(['foo', 'bar', 'foo'])})
]);
});
});
describe('Parquet', () => {
test('create, list, describe, and drop Parquet table', () => {
const a = Series.new([1.0, 2.0, 3.0]);
const b = Series.new(['foo', 'bar', 'foo']);
const df = new DataFrame({'a': a, 'b': b});
const path = Path.join(tmpDir, 'simple.parquet');
df.toParquet(path);
const sqlContext = new SQLContext();
sqlContext.createParquetTable('test_table', [path]);
expect(sqlContext.listTables()).toEqual(['test_table']);
const tableDescription = sqlContext.describeTable('test_table');
expect([...tableDescription.keys()]).toEqual(['a', 'b']);
expect([...tableDescription.values()]).toEqual([new Float64, new Utf8String]);
sqlContext.dropTable('test_table');
expect(sqlContext.listTables().length).toEqual(0);
});
test('query Parquet table', async () => {
const a = Series.new([1.0, 2.0, 3.0]);
const b = Series.new(['foo', 'bar', 'foo']);
const df = new DataFrame({'a': a, 'b': b});
const path = Path.join(tmpDir, 'simple.parquet');
df.toParquet(path);
const sqlContext = new SQLContext();
sqlContext.createParquetTable('test_table', [path]);
await expect(sqlContext.sql('SELECT b FROM test_table').result()).resolves.toStrictEqual([
new DataFrame({'b': Series.new(['foo', 'bar', 'foo'])})
]);
});
});
describe('ORC', () => {
test('create, list, describe, and drop ORC table', () => {
const a = Series.new([1.0, 2.0, 3.0]);
const b = Series.new(['foo', 'bar', 'foo']);
const df = new DataFrame({'a': a, 'b': b});
const path = Path.join(tmpDir, 'simple.orc');
df.toORC(path);
const sqlContext = new SQLContext();
sqlContext.createORCTable('test_table', [path]);
expect(sqlContext.listTables()).toEqual(['test_table']);
const tableDescription = sqlContext.describeTable('test_table');
expect([...tableDescription.keys()]).toEqual(['a', 'b']);
expect([...tableDescription.values()]).toEqual([new Float64, new Utf8String]);
sqlContext.dropTable('test_table');
expect(sqlContext.listTables().length).toEqual(0);
});
test('query ORC table', async () => {
const a = Series.new([1.0, 2.0, 3.0]);
const b = Series.new(['foo', 'bar', 'foo']);
const df = new DataFrame({'a': a, 'b': b});
const path = Path.join(tmpDir, 'simple.orc');
df.toORC(path);
const sqlContext = new SQLContext();
sqlContext.createORCTable('test_table', [path]);
await expect(sqlContext.sql('SELECT b FROM test_table').result()).resolves.toStrictEqual([
new DataFrame({'b': Series.new(['foo', 'bar', 'foo'])})
]);
});
});
let tmpDir = '';
const rimraf = require('rimraf');
function makeCSVString(
opts: {rows?: any[], delimiter?: string, lineTerminator?: string, header?: boolean} = {}) {
const {rows = [], delimiter = ',', lineTerminator = '\n', header = true} = opts;
const names = Object.keys(rows.reduce(
(keys, row) => Object.keys(row).reduce((keys, key) => ({...keys, [key]: true}), keys), {}));
return [
...[header ? names.join(delimiter) : []],
...rows.map((row) =>
names.map((name) => row[name] === undefined ? '' : row[name]).join(delimiter))
].join(lineTerminator) +
lineTerminator;
}
beforeAll(async () => { //
tmpDir = await promises.mkdtemp(Path.join('/tmp', 'node_sql'));
});
afterAll(() => {
return new Promise<void>((resolve, reject) => { //
rimraf(tmpDir, (err?: Error|null) => err ? reject(err) : resolve());
});
});
| 0 |
rapidsai_public_repos/node/modules/sql
|
rapidsai_public_repos/node/modules/sql/test/sql-context-tests.ts
|
// Copyright (c) 2021-2022, NVIDIA CORPORATION.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
import {DataFrame, Float64, Series, Utf8String} from '@rapidsai/cudf';
import {SQLContext} from '@rapidsai/sql';
test('create and drop table', () => {
const a = Series.new([1, 2, 3]);
const df = new DataFrame({'a': a});
const sqlContext = new SQLContext();
sqlContext.createDataFrameTable('test_table', df);
expect(sqlContext.listTables().length).toEqual(1);
sqlContext.dropTable('test_table');
expect(sqlContext.listTables().length).toEqual(0);
});
test('list tables', () => {
const a = Series.new([1, 2, 3]);
const df = new DataFrame({'a': a});
const sqlContext = new SQLContext();
sqlContext.createDataFrameTable('test_table', df);
sqlContext.createDataFrameTable('test_table2', df);
expect(sqlContext.listTables()).toEqual(['test_table', 'test_table2']);
});
test('describe table', () => {
const a = Series.new([1, 2, 3]);
const b = Series.new(['foo', 'bar', 'foo']);
const df = new DataFrame({'a': a, 'b': b});
const sqlContext = new SQLContext();
// Empty map since table doesn't exist
expect(sqlContext.describeTable('nonexisting_table').size).toEqual(0);
sqlContext.createDataFrameTable('test_table', df);
const tableDescription = sqlContext.describeTable('test_table');
expect([...tableDescription.keys()]).toEqual(['a', 'b']);
expect([...tableDescription.values()]).toEqual([new Float64, new Utf8String]);
});
test('explain', () => {
const key = Series.new(['a', 'b', 'c', 'd', 'e']);
const val = Series.new([7.6, 2.9, 7.1, 1.6, 2.2]);
const df = new DataFrame({'key': key, 'val': val});
const sqlContext = new SQLContext();
sqlContext.createDataFrameTable('test_table', df);
const query = 'SELECT * FROM test_table WHERE val > 4';
expect(sqlContext.explain(query))
.toEqual(
`LogicalProject(key=[$0], val=[$1])
BindableTableScan(table=[[main, test_table]], filters=[[>($1, 4)]])
`);
expect(sqlContext.explain(query, true))
.toEqual(
`LogicalProject(key=[$0], val=[$1])
BindableTableScan(table=[[main, test_table]], filters=[[>($1, 4)]])
`);
});
test('select a single column', async () => {
const a = Series.new([6, 9, 1, 6, 2]);
const b = Series.new([7, 2, 7, 1, 2]);
const df = new DataFrame({'a': a, 'b': b});
const sqlContext = new SQLContext();
sqlContext.createDataFrameTable('test_table', df);
await expect(sqlContext.sql('SELECT a FROM test_table').result()).resolves.toStrictEqual([
new DataFrame({a})
]);
});
test('select all columns', async () => {
const a = Series.new([6, 9, 1, 6, 2]);
const b = Series.new([7, 2, 7, 1, 2]);
const df = new DataFrame({'a': a, 'b': b});
const sqlContext = new SQLContext();
sqlContext.createDataFrameTable('test_table', df);
await expect(sqlContext.sql('SELECT * FROM test_table').result()).resolves.toStrictEqual([
new DataFrame({'a': a, 'b': b})
]);
});
test('union columns from two tables', async () => {
const a = Series.new([1, 2, 3]);
const df1 = new DataFrame({'a': a});
const df2 = new DataFrame({'a': a});
const sqlContext = new SQLContext();
sqlContext.createDataFrameTable('t1', df1);
sqlContext.createDataFrameTable('t2', df2);
await expect(sqlContext.sql('SELECT a FROM t1 AS a UNION ALL SELECT a FROM t2').result())
.resolves.toStrictEqual([new DataFrame({'a': Series.new([...a, ...a])})]);
});
test('find all columns within a table that meet condition', async () => {
const key = Series.new(['a', 'b', 'c', 'd', 'e']);
const val = Series.new([7.6, 2.9, 7.1, 1.6, 2.2]);
const df = new DataFrame({'key': key, 'val': val});
const sqlContext = new SQLContext();
sqlContext.createDataFrameTable('test_table', df);
await expect(sqlContext.sql('SELECT * FROM test_table WHERE val > 4').result())
.resolves.toStrictEqual(
[new DataFrame({'key': Series.new(['a', 'b']), 'val': Series.new([7.6, 7.1])})]);
});
test('empty sql result', async () => {
const key = Series.new(['a', 'b', 'c', 'd', 'e']);
const val = Series.new([7.6, 2.9, 7.1, 1.6, 2.2]);
const df = new DataFrame({'key': key, 'val': val});
const sqlContext = new SQLContext();
sqlContext.createDataFrameTable('test_table', df);
// Query should be empty since BETWEEN values are reversed.
await expect(sqlContext.sql('SELECT * FROM test_table WHERE val BETWEEN 10 AND 0').result())
.resolves.toStrictEqual([new DataFrame()]);
});
| 0 |
rapidsai_public_repos/node/modules/sql
|
rapidsai_public_repos/node/modules/sql/test/sql-cluster-tests.ts
|
// Copyright (c) 2021, NVIDIA CORPORATION.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
import {DataFrame, Float64, Series, Utf8String} from '@rapidsai/cudf';
import {SQLCluster} from '@rapidsai/sql';
let sqlCluster: SQLCluster;
beforeAll(async () => { sqlCluster = await SQLCluster.init({numWorkers: 2}); });
afterAll(() => { sqlCluster?.kill(); });
test('create and drop table', async () => {
const a = Series.new([1, 2, 3]);
const df = new DataFrame({'a': a});
await sqlCluster.createDataFrameTable('test_table', df);
expect(sqlCluster.listTables().length).toEqual(1);
await sqlCluster.dropTable('test_table');
expect(sqlCluster.listTables().length).toEqual(0);
});
test('list tables', async () => {
const a = Series.new([1, 2, 3]);
const df = new DataFrame({'a': a});
await sqlCluster.createDataFrameTable('test_table', df);
await sqlCluster.createDataFrameTable('test_table2', df);
expect(sqlCluster.listTables()).toEqual(['test_table', 'test_table2']);
});
test('describe table', async () => {
const a = Series.new([1, 2, 3]);
const b = Series.new(['foo', 'bar', 'foo']);
const df = new DataFrame({'a': a, 'b': b});
// Empty map since table doesn't exist
expect(sqlCluster.describeTable('nonexisting_table').size).toEqual(0);
await sqlCluster.createDataFrameTable('test_table', df);
const tableDescription = sqlCluster.describeTable('test_table');
expect([...tableDescription.keys()]).toEqual(['a', 'b']);
expect([...tableDescription.values()]).toEqual([new Float64, new Utf8String]);
});
test('explain', async () => {
const key = Series.new(['a', 'b', 'c', 'd', 'e']);
const val = Series.new([7.6, 2.9, 7.1, 1.6, 2.2]);
const df = new DataFrame({'key': key, 'val': val});
await sqlCluster.createDataFrameTable('test_table', df);
const query = 'SELECT * FROM test_table WHERE val > 4';
expect(sqlCluster.explain(query))
.toEqual(
`LogicalProject(key=[$0], val=[$1])
BindableTableScan(table=[[main, test_table]], filters=[[>($1, 4)]])
`);
expect(sqlCluster.explain(query, true))
.toEqual(
`LogicalProject(key=[$0], val=[$1])
BindableTableScan(table=[[main, test_table]], filters=[[>($1, 4)]])
`);
});
async function toArray(src: AsyncIterable<DataFrame>) {
const dfs = [];
for await (const df of src) { dfs.push(df); }
return dfs;
}
test('select a single column (one worker)', async () => {
const a = Series.new([6, 9, 1, 6, 2]);
const b = Series.new([7, 2, 7, 1, 2]);
const df = new DataFrame({'a': a, 'b': b});
await sqlCluster.createDataFrameTable('test_table', df);
const result = concat(await toArray(sqlCluster.sql('SELECT a FROM test_table')));
expect(result).toStrictEqual(new DataFrame({a}));
});
test('select all columns (one worker)', async () => {
const a = Series.new([6, 9, 1, 6, 2]);
const b = Series.new([7, 2, 7, 1, 2]);
const df = new DataFrame({'a': a, 'b': b});
await sqlCluster.createDataFrameTable('test_table', df);
const result = concat(await toArray(sqlCluster.sql('SELECT * FROM test_table')));
expect(result).toStrictEqual(new DataFrame({'a': a, 'b': b}));
});
test('union columns from two tables (one worker)', async () => {
const a = Series.new([1, 2, 3]);
const df1 = new DataFrame({'a': a});
const df2 = new DataFrame({'a': a});
await sqlCluster.createDataFrameTable('t1', df1);
await sqlCluster.createDataFrameTable('t2', df2);
const result =
concat(await toArray(sqlCluster.sql('SELECT a FROM t1 AS a UNION ALL SELECT a FROM t2')));
expect(result).toStrictEqual(new DataFrame({'a': Series.new([...a, ...a])}));
});
test('find all columns within a table that meet condition (one worker)', async () => {
const key = Series.new(['a', 'b', 'c', 'd', 'e']);
const val = Series.new([7.6, 2.9, 7.1, 1.6, 2.2]);
const df = new DataFrame({'key': key, 'val': val});
await sqlCluster.createDataFrameTable('test_table', df);
const result = concat(await toArray(sqlCluster.sql('SELECT * FROM test_table WHERE val > 4')));
expect(result).toStrictEqual(
new DataFrame({'key': Series.new(['a', 'b']), 'val': Series.new([7.6, 7.1])}));
});
test('empty sql result', async () => {
const key = Series.new(['a', 'b', 'c', 'd', 'e']);
const val = Series.new([7.6, 2.9, 7.1, 1.6, 2.2]);
const df = new DataFrame({'key': key, 'val': val});
await sqlCluster.createDataFrameTable('test_table', df);
// Query should be empty since BETWEEN values are reversed.
const result =
concat(await toArray(sqlCluster.sql('SELECT * FROM test_table WHERE val BETWEEN 10 AND 0')));
expect(result).toStrictEqual(new DataFrame({}));
});
function concat(dfs: DataFrame[]) {
let result = new DataFrame();
dfs.forEach((df) => { result = result.concat(df); });
return result;
}
| 0 |
rapidsai_public_repos/node/modules
|
rapidsai_public_repos/node/modules/demo/README.md
|
# Node RAPIDS Demos
### A collection of demos, templates, and applications showcasing the features and uses for Node RAPIDS.
<br/>
## Starting Demos
In a properly configured env or docker container, most demos can be selected from a list and started with:
```bash
yarn demo
```
Or directly with:
```bash
yarn demo modules/demo/graph
```
Or in most cases within each demo's folder with:
```bash
yarn start
```
## Data Requirements
Some demos require downloading datasets to run, while others have defaults included. See each demo's README for details.
<br/><br/>
# Demos List
## [Viz App](https://github.com/rapidsai/node/tree/main/modules/demo/viz-app) + [SSR Graph](https://github.com/rapidsai/node/tree/main/modules/demo/ssr/graph) | [YouTube Demo](https://youtu.be/zzOCIJ-K1dE)
### Streaming SSR graph visualization with nvENC webRTC to a browser app, using cuDF and cuGraph bindings *Note: future demo will have simplified startup*

<br/><br/>
## [Viz App](https://github.com/rapidsai/node/tree/main/modules/demo/viz-app) + [SSR Point Cloud](https://github.com/rapidsai/node/tree/main/modules/demo/ssr/graph) | [YouTube Demo](https://youtu.be/vCAiKIkCP3E)
### Streaming SSR point cloud visualization with nvENC webRTC to a browser *Note: future demo will have simplified startup*

<br/><br/>
## [Client Server](https://github.com/rapidsai/node/tree/main/modules/demo/client-server) | [YouTube Demo](https://youtu.be/H8E0HLiL9YA)
### Browser crossfilter visualization app with server side compute using cuDF

<br/><br/>
## [SQL](https://github.com/rapidsai/node/tree/main/modules/demo/sql/sql-cluster-server) | [YouTube Demo](https://youtu.be/EmwcMM_mYKA)
### Demo of multi-GPU SQL demo w/ a browser UI query builder

<br/><br/>
## [Node.js Notebook](https://github.com/rapidsai/node/tree/main/modules/cudf/notebooks) | [YouTube Demo](https://youtu.be/LbHpK8M3cV4)
### GPU accelerated data science in JupyterLab Notebook with Node.js

<br/><br/>
## [Spatial](https://github.com/rapidsai/node/tree/main/modules/demo/spatial)
### Using cuSpatial bindings of Quadtree to segment geospatial data

<br/><br/>
## [Graph](https://github.com/rapidsai/node/tree/main/modules/demo/graph)
### Using cuGraph bindings of FA2 to compute graph layout

<br/><br/>
## [UMAP](https://github.com/rapidsai/node/tree/main/modules/demo/umap)
### Using cuML bindings of UMAP to compute clusters

<br/><br/>
## [Deck.gl](https://github.com/rapidsai/node/tree/main/modules/demo/deck) | [Examples Page](https://deck.gl/examples)
### Running Deck.gl examples with OpenGL Server Side

<br/><br/>
## [Luma.gl](https://github.com/rapidsai/node/tree/main/modules/demo/luma) | [Examples Page](https://luma.gl/examples)
### Running (older) Luma.gl examples with OpenGL Server Side

<br/><br/>
## Misc Demos
### [Xterm](https://github.com/rapidsai/node/tree/main/modules/demo/xterm) | Emulating GPU rendered xterminal
### [tfjs weblGL](https://github.com/rapidsai/node/tree/main/modules/demo/tfjs/webgl-tests) | ( **Deprecated** ) bindings to tensorflow-js webGl test
### [tfjs RNN addition](https://github.com/rapidsai/node/tree/main/modules/demo/tfjs/addition-rnn) | ( **Deprecated** ) bindings to tensorflow-js addition demo
### [IPC](https://github.com/rapidsai/node/tree/main/modules/demo/ipc) | ( **Deprecated** ) Demo of Inter Process Communication between Python and Node.js
<br/><br/>
# Troubleshooting
## My GLFW window is blank:
If you have more than one GPU, for windowed (no browser) demos you must specify a display GPU by setting: `NVIDIA_VISIBLE_DEVICES=1` in the `.env` file, or docker command. Sometimes it takes a few seconds for things to load too.
## Starting the demo produced an error:
Make sure you have downloaded the required datasets, the data is not malformed, and it is in the correct location -usually `/data`.
If that does not work and if you are running a locally built environment, try rebuilding the module.
Some demo's may have stopped working - check our **[Issues](https://github.com/rapidsai/node/issues)** for details.
| 0 |
rapidsai_public_repos/node/modules/demo
|
rapidsai_public_repos/node/modules/demo/graph/package.json
|
{
"private": true,
"name": "@rapidsai/demo-graph",
"main": "index.js",
"version": "22.12.2",
"license": "Apache-2.0",
"author": "NVIDIA, Inc. (https://nvidia.com/)",
"maintainers": [
"Paul Taylor <[email protected]>"
],
"bin": "index.js",
"scripts": {
"start": "node --experimental-vm-modules --enable-source-maps --trace-uncaught index.js",
"watch": "find -type f | entr -c -d -r node --experimental-vm-modules --enable-source-maps --trace-uncaught index.js"
},
"dependencies": {
"@deck.gl/core": "8.8.10",
"@deck.gl/react": "8.8.10",
"@luma.gl/core": "8.5.16",
"@rapidsai/cuda": "~22.12.2",
"@rapidsai/cudf": "~22.12.2",
"@rapidsai/cugraph": "~22.12.2",
"@rapidsai/deck.gl": "~22.12.2",
"@rapidsai/glfw": "~22.12.2",
"@rapidsai/jsdom": "~22.12.2",
"ix": "4.4.1",
"mjolnir.js": "2.7.1",
"react": "17.0.2",
"react-dom": "17.0.2"
},
"files": [
"src",
"index.js",
"package.json"
]
}
| 0 |
rapidsai_public_repos/node/modules/demo
|
rapidsai_public_repos/node/modules/demo/graph/index.js
|
#!/usr/bin/env node
// Copyright (c) 2020-2021, NVIDIA CORPORATION.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
module.exports = (glfwOptions = {
title: 'Graph Demo',
visible: true,
transparent: false,
}) => {
let args = process.argv.slice(2);
if (args.length === 1 && args[0].includes(' ')) { args = args[0].split(' '); }
const parseArg = (prefix, fallback = '') =>
(args.find((arg) => arg.includes(prefix)) || `${prefix}${fallback}`).slice(prefix.length);
const delay = Math.max(0, parseInt(parseArg('--delay=', 0)) | 0);
async function* inputs(delay, paths) {
const sleep = (t) => new Promise((r) => setTimeout(r, t));
for (const path of paths.split(',')) {
if (path) { yield path; }
await sleep(delay);
}
}
return require('@rapidsai/jsdom')
.RapidsJSDOM.fromReactComponent(
'./src/app.jsx',
{
glfwOptions: {
...glfwOptions,
width: parseInt(parseArg('--width=', 800)) | 0,
height: parseInt(parseArg('--height=', 600)) | 0,
},
// Change cwd to the example dir so relative file paths are resolved
module: {path: __dirname},
},
{
nodes: inputs(delay, parseArg('--nodes=')),
edges: inputs(delay, parseArg('--edges=')),
layoutParams: JSON.parse(`{${parseArg('--params=')}}`),
});
};
if (require.main === module) {
module.exports().window.addEventListener('close', () => process.exit(0), {once: true});
}
| 0 |
rapidsai_public_repos/node/modules/demo
|
rapidsai_public_repos/node/modules/demo/graph/README.md
|
# Simple Graph Demo
A simple graph visualization powered by cuGraph and deck.gl, using a glfw instance. While running, you can select parameters by using the up/down arrow keys or 1-9 and adjust by using left/right arrow keys. Pan and zoom with a mouse.
## Featured Dependencies
- @rapidsai/cudf
- @rapidsai/cuspatial
- @rapidsai/jsdom
- @rapidsai/deckgl
- @rapidsai/glfw
## Data Requirements
Without passing data, graph demo will default to internal data. Passing graph data assumes a node and edge `.csv` format in `/data` folder.
## Start
Example of starting the graph demo with selected data and preset parameters:
```bash
yarn start
--width=1920 --height=1080 \
--nodes=data/netscience.nodes.csv \
--edges=data/netscience.edges.csv \
--params='"autoCenter":1,"outboundAttraction":1,"strongGravityMode":1,"jitterTolerance":0.02,"barnesHutTheta":0,"scalingRatio":2,"gravity":0.5,"controlsVisible":0'
```
| 0 |
rapidsai_public_repos/node/modules/demo
|
rapidsai_public_repos/node/modules/demo/graph/Graph Demo.ipynb
|
var graphDemoWindow = require('@rapidsai/demo-graph');
graphDemoWindow.open({
_title: 'Graph Demo',
width: 1024,
height: 768,
layoutParams: {
scalingRatio: 5,
autoCenter: false,
}
})
| 0 |
rapidsai_public_repos/node/modules/demo/graph
|
rapidsai_public_repos/node/modules/demo/graph/src/loader.js
|
// Copyright (c) 2021-2022, NVIDIA CORPORATION.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
import {clampRange as clamp, Float32Buffer} from '@rapidsai/cuda';
import {DataFrame, Float32, Int32, Series, Uint32, Uint64, Uint8, Utf8String} from '@rapidsai/cudf';
import {Graph} from '@rapidsai/cugraph';
import {concat as concatAsync, zip as zipAsync} from 'ix/asynciterable';
import {flatMap as flatMapAsync} from 'ix/asynciterable/operators';
const defaultLayoutParams = {
simulating: {name: 'simulating', val: true},
autoCenter: {name: 'auto-center', val: false},
outboundAttraction: {name: 'outbound attraction', val: false},
linLogMode: {name: 'lin-log', val: false},
strongGravityMode: {name: 'strong gravity', val: false},
jitterTolerance: {name: 'layout speed', val: 0.05, min: 0.0001, max: 1.0, step: 0.0001},
barnesHutTheta: {
name: 'theta',
val: 0.0,
min: 0.0,
max: 1.0,
step: 0.001,
},
scalingRatio: {
name: 'scale ratio',
val: 5.0,
min: 0.0,
max: 100.0,
step: 0.1,
},
gravity: {
name: 'gravity',
val: 1.0,
min: 0.0,
max: 100.0,
step: 0.1,
},
controlsVisible: {name: 'controls visible', val: true},
};
const layoutParamNames = Object.keys(defaultLayoutParams);
export default async function* loadGraphData(props = {}) {
const layoutParams = {...defaultLayoutParams};
if (props.layoutParams) {
layoutParamNames.forEach((name) => {
if (props.layoutParams.hasOwnProperty(name)) {
const {val, min, max} = layoutParams[name];
switch (typeof val) {
case 'boolean': layoutParams[name].val = !!props.layoutParams[name]; break;
case 'number':
layoutParams[name].val = Math.max(min, Math.min(max, props.layoutParams[name]));
break;
}
}
});
}
let selectedParameter = 0;
window.addEventListener('keydown', (e) => {
if ('1234567890'.includes(e.key)) {
selectedParameter = +e.key;
} else if (e.code === 'ArrowUp') {
selectedParameter =
clamp(layoutParamNames.length, selectedParameter - 1)[0] % layoutParamNames.length;
} else if (e.code === 'ArrowDown') {
selectedParameter =
clamp(layoutParamNames.length, selectedParameter + 1)[0] % layoutParamNames.length;
} else if (['PageUp', 'PageDown', 'ArrowLeft', 'ArrowRight'].indexOf(e.code) !== -1) {
const key = layoutParamNames[selectedParameter];
const {val, min, max, step} = layoutParams[key];
if (typeof val === 'boolean') {
layoutParams[key].val = !val;
} else if (e.code === 'PageUp') {
layoutParams[key].val = Math.min(max, parseFloat(Number(val + step * 10).toPrecision(3)));
} else if (e.code === 'PageDown') {
layoutParams[key].val = Math.max(min, parseFloat(Number(val - step * 10).toPrecision(3)));
} else if (e.code === 'ArrowLeft') {
layoutParams[key].val = Math.max(min, parseFloat(Number(val - step).toPrecision(3)));
} else if (e.code === 'ArrowRight') {
layoutParams[key].val = Math.min(max, parseFloat(Number(val + step).toPrecision(3)));
}
}
});
async function* getDataFrames(source, getDefault, dataTypes) {
if (!source) {
if (typeof getDefault === 'function') { yield getDefault(); }
return;
}
if (source instanceof DataFrame) { return yield source; }
if (typeof source === 'string' && dataTypes) {
return yield DataFrame.readCSV(
{header: 0, sourceType: 'files', sources: [source], dataTypes});
}
if (typeof source[Symbol.iterator] === 'function' ||
typeof source[Symbol.asyncIterator] === 'function') {
let count = 0;
for await (const x of flatMapAsync((x) => getDataFrames(x, undefined, dataTypes))(source)) {
count++;
yield x;
}
if (count == 0) { yield* getDataFrames(null, getDefault, dataTypes); }
}
}
let nodeDFs = getDataFrames(props.nodes, getDefaultNodes, {
name: new Utf8String,
id: new Uint32,
color: new Uint32,
size: new Uint8,
data: new Utf8String,
});
let edgeDFs = getDataFrames(props.edges, getDefaultEdges, {
name: new Utf8String,
src: new Int32,
dst: new Int32,
edge: new Uint64,
color: new Uint64,
bundle: new Uint64,
data: new Utf8String,
});
/**
* @type DataFrame<{
* name: Utf8String,
* id: Uint32,
* color: Uint32,
* size: Uint8,
* x: Float32,
* y: Float32
* }>
*/
let nodes = null;
/**
* @type DataFrame<{
* name: Utf8String,
* src: Int32,
* dst: Int32,
* edge: Uint64,
* color: Uint64,
* bundle: Uint64
* }>
*/
let edges = null;
/**
* @type Graph
*/
let graph = null;
/**
* @type Float32Buffer
*/
let positions = null;
let graphDesc = {};
let bbox = [0, 0, 0, 0];
let onAfterRender = () => {};
let rendered = new Promise(() => {});
let dataframes = concatAsync(zipAsync(nodeDFs, edgeDFs), (async function*() {
datasourceCompleted = true;
nextFrames = new Promise(() => {});
})())[Symbol.asyncIterator]();
let nextFrames = dataframes.next();
let datasourceCompleted = false;
let graphUpdated = false;
while (true) {
graphUpdated = false;
// Wait for a new set of source dataframes or for the
// most recent frame to finish rendering before advancing
const newDFs = await (datasourceCompleted
? rendered
: Promise.race([rendered, nextFrames.then(({value} = {}) => value)]));
// If new nodes/edges, recreate the Graph
if (newDFs) {
if (newDFs[0] !== nodes || newDFs[1] !== edges) {
graphUpdated = true;
[nodes, edges] = newDFs;
nextFrames = dataframes.next();
graph = Graph.fromEdgeList(edges.get('src'), edges.get('dst'));
}
}
const n = graph.numNodes;
if (!layoutParams.simulating.val && !graphUpdated) {
// If user paused rendering, wait a bit and continue
rendered = new Promise((r) => (onAfterRender = () => setTimeout(r, 50)));
} else {
// Compute positions from the previous positions
positions = graph.forceAtlas2({
positions,
...layoutParamNames.reduce((params, name) => ({...params, [name]: layoutParams[name].val}),
{})
});
const positionSeries = Series.new({type: new Float32, data: positions.buffer});
if (positionSeries.isNaN().any()) { positions.copyFrom(positionSeries.replaceNaNs(0).data); }
// Extract the x and y positions and assign them as columns in our nodes DF
nodes = nodes.assign({
x: Series.new({type: new Float32, length: n, offset: 0, data: positions.buffer}),
y: Series.new({type: new Float32, length: n, offset: n, data: positions.buffer}),
});
// Compute the positions minimum bounding box [xMin, xMax, yMin, yMax]
bbox = [...nodes.get('x').minmax(), ...nodes.get('y').minmax()];
graphDesc = createGraphRenderProps(nodes, edges, graph);
({promise: rendered, resolve: onAfterRender} = promiseSubject());
}
// Yield the results to the caller for rendering
yield {
graph: graphDesc,
params: layoutParams,
selectedParameter: layoutParams.controlsVisible.val ? selectedParameter : undefined,
bbox,
autoCenter: layoutParams.autoCenter.val,
onAfterRender
};
// Wait for the frame to finish rendering before advancing
rendered = rendered.catch(() => {}).then(() => {});
}
}
function promiseSubject() {
let resolve, reject;
let promise = new Promise((r1, r2) => {
resolve = r1;
reject = r2;
});
return {promise, resolve, reject};
}
/**
*
* @param {DataFrame<{
* name: Utf8String, id: Uint32, color: Uint32, size: Uint8, x: Float32, y: Float32,
* }>} nodes
* @param {DataFrame<{
* name: Utf8String, src: Int32, dst: Int32, edge: Uint64, color: Uint64, bundle: Uint64,
* }>} edges
* @param {*} graph
*/
function createGraphRenderProps(nodes, edges, graph) {
const numNodes = graph.numNodes;
const numEdges = graph.numEdges;
return {
numNodes, numEdges, nodeRadiusScale: 1 / 75,
// nodeRadiusScale: 1/255,
nodeRadiusMinPixels: 5, nodeRadiusMaxPixels: 150, data: {
edges: {
offset: 0,
length: numEdges,
attributes: {
edgeName: edges.get('name'),
edgeList: edges.get('edge').data,
edgeColors: edges.get('color').data,
edgeBundles: edges.get('bundle').data,
edgeData: edges.has('data') ? edges.get('data') : null
}
},
nodes: {
offset: 0,
length: numNodes,
attributes: {
nodeName: nodes.get('name'),
nodeRadius: nodes.get('size').data,
nodeXPositions: nodes.get('x').data,
nodeYPositions: nodes.get('y').data,
nodeFillColors: nodes.get('color').data,
nodeElementIndices: nodes.get('id').data,
nodeData: nodes.has('data') ? nodes.get('data') : null
}
},
},
}
}
function getDefaultNodes() {
return new DataFrame({
name: Series.new([
'bool::False',
'bool::True',
'char::a',
'char::b',
'char::c',
'char::d',
'colors::1',
'colors::2',
'date::2018-01-01 00:00:00.000000000',
'date_str::2018-01-01 00:00:00',
'date_str::2018-01-02 00:00:00',
'date_str::2018-01-03 00:00:00',
'date_str::2018-01-05 00:00:00',
'dst::0',
'dst::1',
'dst::2',
'dst::3',
'emoji::😋',
'emoji::😋😋',
'int::0',
'int::1',
'int::2',
'int::3',
'num::0.5',
'num::1.5',
'num::2.5',
'num::3.5',
'src::0',
'src::1',
'src::2',
'src::3',
'str::a',
'str::b',
'str::c',
'str::d',
'time::2018-01-05 00:00:00.000000000',
'ustr::a',
'ustr::b',
'ustr::c',
'ustr::d'
]),
id: Series.new({
type: new Uint32,
data: [
0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10, 11, 12, 13, 14, 15, 16, 17, 18, 19,
20, 21, 22, 23, 24, 25, 26, 27, 28, 29, 30, 31, 32, 33, 34, 35, 36, 37, 38, 39
]
}),
color: Series.new({
type: new Uint32,
data: [
4293326232, 4294815329, 4294208835, 4294967231, 4293326232, 4294967231, 4281501885,
4294208835, 4292165199, 4284924581, 4281501885, 4281501885, 4294967231, 4294967231,
4281501885, 4289453476, 4281501885, 4294208835, 4289453476, 4281501885, 4289453476,
4289453476, 4294967231, 4281501885, 4293326232, 4281501885, 4294967231, 4294208835,
4289453476, 4294967231, 4294967231, 4294893707, 4294967231, 4281501885, 4294967231,
4284924581, 4294893707, 4294967231, 4294893707, 4294893707
]
}),
size: Series.new({
type: new Uint8,
data: [
1, 170, 1, 1, 1, 1, 85, 85, 255, 1, 1, 1, 1, 1, 1, 1, 1, 170, 1, 1,
1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 255, 1, 1, 1, 1
]
}),
});
}
function getDefaultEdges() {
return new DataFrame({
name: Series.new(Array.from({length: 312}, (_, i) => `${i}`)),
src: Series.new({
type: new Int32,
data: [
1, 0, 1, 1, 1, 0, 1, 1, 1, 0, 1, 1, 1, 0, 1, 1, 1, 0, 1, 1, 1, 0, 1,
1, 1, 0, 1, 1, 1, 0, 1, 1, 1, 0, 1, 1, 1, 0, 1, 1, 1, 0, 1, 1, 1, 0,
1, 1, 2, 3, 4, 5, 2, 3, 4, 5, 2, 3, 4, 5, 2, 3, 4, 5, 2, 3, 4, 5, 2,
3, 4, 5, 2, 3, 4, 5, 2, 3, 4, 5, 2, 3, 4, 5, 2, 3, 4, 5, 2, 3, 4, 5,
6, 6, 7, 7, 6, 6, 7, 7, 6, 6, 7, 7, 6, 6, 7, 7, 6, 6, 7, 7, 6, 6, 7,
7, 6, 6, 7, 7, 6, 6, 7, 7, 6, 6, 7, 7, 6, 6, 7, 7, 8, 8, 8, 8, 8, 8,
8, 8, 8, 8, 8, 8, 8, 8, 8, 8, 8, 8, 8, 8, 8, 8, 8, 8, 8, 8, 8, 8, 8,
8, 8, 8, 8, 8, 8, 8, 9, 10, 11, 12, 9, 10, 11, 12, 9, 10, 11, 12, 9, 10, 11, 12,
9, 10, 11, 12, 9, 10, 11, 12, 9, 10, 11, 12, 9, 10, 11, 12, 14, 15, 16, 13, 14, 15, 16,
13, 14, 15, 16, 13, 14, 15, 16, 13, 14, 15, 16, 13, 14, 15, 16, 13, 14, 15, 16, 13, 17, 18,
17, 17, 17, 18, 17, 17, 17, 18, 17, 17, 17, 18, 17, 17, 17, 18, 17, 17, 17, 18, 17, 17, 19,
20, 21, 22, 19, 20, 21, 22, 19, 20, 21, 22, 19, 20, 21, 22, 19, 20, 21, 22, 23, 24, 25, 26,
23, 24, 25, 26, 23, 24, 25, 26, 23, 24, 25, 26, 27, 28, 29, 30, 27, 28, 29, 30, 27, 28, 29,
30, 31, 32, 33, 34, 31, 32, 33, 34, 35, 35, 35, 35
]
}),
dst: Series.new({
type: new Int32,
data: [
2, 3, 4, 5, 6, 6, 7, 7, 8, 8, 8, 8, 9, 10, 11, 12, 14, 15, 16, 13, 17, 18, 17,
17, 19, 20, 21, 22, 23, 24, 25, 26, 27, 28, 29, 30, 31, 32, 33, 34, 35, 35, 35, 35, 36, 37,
38, 39, 6, 6, 7, 7, 8, 8, 8, 8, 9, 10, 11, 12, 14, 15, 16, 13, 17, 18, 17, 17, 19,
20, 21, 22, 23, 24, 25, 26, 27, 28, 29, 30, 31, 32, 33, 34, 35, 35, 35, 35, 36, 37, 38, 39,
8, 8, 8, 8, 9, 10, 11, 12, 14, 15, 16, 13, 17, 18, 17, 17, 19, 20, 21, 22, 23, 24, 25,
26, 27, 28, 29, 30, 31, 32, 33, 34, 35, 35, 35, 35, 36, 37, 38, 39, 9, 10, 11, 12, 14, 15,
16, 13, 17, 18, 17, 17, 19, 20, 21, 22, 23, 24, 25, 26, 27, 28, 29, 30, 31, 32, 33, 34, 35,
35, 35, 35, 36, 37, 38, 39, 14, 15, 16, 13, 17, 18, 17, 17, 19, 20, 21, 22, 23, 24, 25, 26,
27, 28, 29, 30, 31, 32, 33, 34, 35, 35, 35, 35, 36, 37, 38, 39, 17, 18, 17, 17, 19, 20, 21,
22, 23, 24, 25, 26, 27, 28, 29, 30, 31, 32, 33, 34, 35, 35, 35, 35, 36, 37, 38, 39, 19, 20,
21, 22, 23, 24, 25, 26, 27, 28, 29, 30, 31, 32, 33, 34, 35, 35, 35, 35, 36, 37, 38, 39, 23,
24, 25, 26, 27, 28, 29, 30, 31, 32, 33, 34, 35, 35, 35, 35, 36, 37, 38, 39, 27, 28, 29, 30,
31, 32, 33, 34, 35, 35, 35, 35, 36, 37, 38, 39, 31, 32, 33, 34, 35, 35, 35, 35, 36, 37, 38,
39, 35, 35, 35, 35, 36, 37, 38, 39, 36, 37, 38, 39
]
}),
edge: Series.new({
type: new Uint64,
data: [
8589934593n, 12884901888n, 17179869185n, 21474836481n, 25769803777n, 25769803776n,
30064771073n, 30064771073n, 34359738369n, 34359738368n, 34359738369n, 34359738369n,
38654705665n, 42949672960n, 47244640257n, 51539607553n, 60129542145n, 64424509440n,
68719476737n, 55834574849n, 73014444033n, 77309411328n, 73014444033n, 73014444033n,
81604378625n, 85899345920n, 90194313217n, 94489280513n, 98784247809n, 103079215104n,
107374182401n, 111669149697n, 115964116993n, 120259084288n, 124554051585n, 128849018881n,
133143986177n, 137438953472n, 141733920769n, 146028888065n, 150323855361n, 150323855360n,
150323855361n, 150323855361n, 154618822657n, 158913789952n, 163208757249n, 167503724545n,
25769803778n, 25769803779n, 30064771076n, 30064771077n, 34359738370n, 34359738371n,
34359738372n, 34359738373n, 38654705666n, 42949672963n, 47244640260n, 51539607557n,
60129542146n, 64424509443n, 68719476740n, 55834574853n, 73014444034n, 77309411331n,
73014444036n, 73014444037n, 81604378626n, 85899345923n, 90194313220n, 94489280517n,
98784247810n, 103079215107n, 107374182404n, 111669149701n, 115964116994n, 120259084291n,
124554051588n, 128849018885n, 133143986178n, 137438953475n, 141733920772n, 146028888069n,
150323855362n, 150323855363n, 150323855364n, 150323855365n, 154618822658n, 158913789955n,
163208757252n, 167503724549n, 34359738374n, 34359738374n, 34359738375n, 34359738375n,
38654705670n, 42949672966n, 47244640263n, 51539607559n, 60129542150n, 64424509446n,
68719476743n, 55834574855n, 73014444038n, 77309411334n, 73014444039n, 73014444039n,
81604378630n, 85899345926n, 90194313223n, 94489280519n, 98784247814n, 103079215110n,
107374182407n, 111669149703n, 115964116998n, 120259084294n, 124554051591n, 128849018887n,
133143986182n, 137438953478n, 141733920775n, 146028888071n, 150323855366n, 150323855366n,
150323855367n, 150323855367n, 154618822662n, 158913789958n, 163208757255n, 167503724551n,
38654705672n, 42949672968n, 47244640264n, 51539607560n, 60129542152n, 64424509448n,
68719476744n, 55834574856n, 73014444040n, 77309411336n, 73014444040n, 73014444040n,
81604378632n, 85899345928n, 90194313224n, 94489280520n, 98784247816n, 103079215112n,
107374182408n, 111669149704n, 115964117000n, 120259084296n, 124554051592n, 128849018888n,
133143986184n, 137438953480n, 141733920776n, 146028888072n, 150323855368n, 150323855368n,
150323855368n, 150323855368n, 154618822664n, 158913789960n, 163208757256n, 167503724552n,
60129542153n, 64424509450n, 68719476747n, 55834574860n, 73014444041n, 77309411338n,
73014444043n, 73014444044n, 81604378633n, 85899345930n, 90194313227n, 94489280524n,
98784247817n, 103079215114n, 107374182411n, 111669149708n, 115964117001n, 120259084298n,
124554051595n, 128849018892n, 133143986185n, 137438953482n, 141733920779n, 146028888076n,
150323855369n, 150323855370n, 150323855371n, 150323855372n, 154618822665n, 158913789962n,
163208757259n, 167503724556n, 73014444046n, 77309411343n, 73014444048n, 73014444045n,
81604378638n, 85899345935n, 90194313232n, 94489280525n, 98784247822n, 103079215119n,
107374182416n, 111669149709n, 115964117006n, 120259084303n, 124554051600n, 128849018893n,
133143986190n, 137438953487n, 141733920784n, 146028888077n, 150323855374n, 150323855375n,
150323855376n, 150323855373n, 154618822670n, 158913789967n, 163208757264n, 167503724557n,
81604378641n, 85899345938n, 90194313233n, 94489280529n, 98784247825n, 103079215122n,
107374182417n, 111669149713n, 115964117009n, 120259084306n, 124554051601n, 128849018897n,
133143986193n, 137438953490n, 141733920785n, 146028888081n, 150323855377n, 150323855378n,
150323855377n, 150323855377n, 154618822673n, 158913789970n, 163208757265n, 167503724561n,
98784247827n, 103079215124n, 107374182421n, 111669149718n, 115964117011n, 120259084308n,
124554051605n, 128849018902n, 133143986195n, 137438953492n, 141733920789n, 146028888086n,
150323855379n, 150323855380n, 150323855381n, 150323855382n, 154618822675n, 158913789972n,
163208757269n, 167503724566n, 115964117015n, 120259084312n, 124554051609n, 128849018906n,
133143986199n, 137438953496n, 141733920793n, 146028888090n, 150323855383n, 150323855384n,
150323855385n, 150323855386n, 154618822679n, 158913789976n, 163208757273n, 167503724570n,
133143986203n, 137438953500n, 141733920797n, 146028888094n, 150323855387n, 150323855388n,
150323855389n, 150323855390n, 154618822683n, 158913789980n, 163208757277n, 167503724574n,
150323855391n, 150323855392n, 150323855393n, 150323855394n, 154618822687n, 158913789984n,
163208757281n, 167503724578n, 154618822691n, 158913789987n, 163208757283n, 167503724579n
]
}),
color: Series.new({
type: new Uint64,
data: [
18443486512814075489n, 18446743798830003608n, 18439695761793724001n,
18446743798831492705n, 18388910578132168289n, 18388910578130679192n,
18443486512814075489n, 18443486512814075489n, 18434709163029147233n,
18434709163027658136n, 18434709163029147233n, 18434709163029147233n,
18403610945516318305n, 18388910578130679192n, 18388910578132168289n,
18446743798831492705n, 18388910578132168289n, 18423062401426847128n,
18388910578132168289n, 18446743798831492705n, 18443486512814075489n,
18423062401426847128n, 18443486512814075489n, 18443486512814075489n,
18388910578132168289n, 18423062401426847128n, 18423062401428336225n,
18446743798831492705n, 18388910578132168289n, 18439695761792234904n,
18388910578132168289n, 18446743798831492705n, 18443486512814075489n,
18423062401426847128n, 18446743798831492705n, 18446743798831492705n,
18446428015656021601n, 18446743798830003608n, 18388910578132168289n,
18446743798831492705n, 18403610945516318305n, 18403610945514829208n,
18403610945516318305n, 18403610945516318305n, 18446428015656021601n,
18446743798830003608n, 18446428015656021601n, 18446428015656021601n,
18388910578131561795n, 18388910578132320191n, 18443486512812586392n,
18443486512814227391n, 18434709163028540739n, 18434709163029299135n,
18434709163027658136n, 18434709163029299135n, 18403610945515711811n,
18388910578132320191n, 18388910578130679192n, 18446743798831644607n,
18388910578131561795n, 18423062401428488127n, 18388910578130679192n,
18446743798831644607n, 18443486512813468995n, 18423062401428488127n,
18443486512812586392n, 18443486512814227391n, 18388910578131561795n,
18423062401428488127n, 18423062401426847128n, 18446743798831644607n,
18388910578131561795n, 18439695761793875903n, 18388910578130679192n,
18446743798831644607n, 18443486512813468995n, 18423062401428488127n,
18446743798830003608n, 18446743798831644607n, 18446428015655415107n,
18446743798831644607n, 18388910578130679192n, 18446743798831644607n,
18403610945515711811n, 18403610945516470207n, 18403610945514829208n,
18403610945516470207n, 18446428015655415107n, 18446743798831644607n,
18446428015654532504n, 18446428015656173503n, 18434709163015833789n,
18434709163015833789n, 18434709163028540739n, 18434709163028540739n,
18403610945503004861n, 18388910578118854845n, 18388910578131561795n,
18446743798830886211n, 18388910578118854845n, 18423062401415022781n,
18388910578131561795n, 18446743798830886211n, 18443486512800762045n,
18423062401415022781n, 18443486512813468995n, 18443486512813468995n,
18388910578118854845n, 18423062401415022781n, 18423062401427729731n,
18446743798830886211n, 18388910578118854845n, 18439695761780410557n,
18388910578131561795n, 18446743798830886211n, 18443486512800762045n,
18423062401415022781n, 18446743798830886211n, 18446743798830886211n,
18446428015642708157n, 18446743798818179261n, 18388910578131561795n,
18446743798830886211n, 18403610945503004861n, 18403610945503004861n,
18403610945515711811n, 18403610945515711811n, 18446428015642708157n,
18446743798818179261n, 18446428015655415107n, 18446428015655415107n,
18403610945513668175n, 18388910578129518159n, 18388910578129518159n,
18446743798828842575n, 18388910578129518159n, 18423062401425686095n,
18388910578129518159n, 18446743798828842575n, 18443486512811425359n,
18423062401425686095n, 18443486512811425359n, 18443486512811425359n,
18388910578129518159n, 18423062401425686095n, 18423062401425686095n,
18446743798828842575n, 18388910578129518159n, 18439695761791073871n,
18388910578129518159n, 18446743798828842575n, 18443486512811425359n,
18423062401425686095n, 18446743798828842575n, 18446743798828842575n,
18446428015653371471n, 18446743798828842575n, 18388910578129518159n,
18446743798828842575n, 18403610945513668175n, 18403610945513668175n,
18403610945513668175n, 18403610945513668175n, 18446428015653371471n,
18446743798828842575n, 18446428015653371471n, 18446428015653371471n,
18388910578122277541n, 18423062401415022781n, 18388910578118854845n,
18446743798831644607n, 18443486512804184741n, 18423062401415022781n,
18443486512800762045n, 18443486512814227391n, 18388910578122277541n,
18423062401415022781n, 18423062401415022781n, 18446743798831644607n,
18388910578122277541n, 18439695761780410557n, 18388910578118854845n,
18446743798831644607n, 18443486512804184741n, 18423062401415022781n,
18446743798818179261n, 18446743798831644607n, 18446428015646130853n,
18446743798818179261n, 18388910578118854845n, 18446743798831644607n,
18403610945506427557n, 18403610945503004861n, 18403610945503004861n,
18403610945516470207n, 18446428015646130853n, 18446743798818179261n,
18446428015642708157n, 18446428015656173503n, 18443486512800762045n,
18423062401422974372n, 18443486512800762045n, 18443486512814227391n,
18388910578118854845n, 18423062401422974372n, 18423062401415022781n,
18446743798831644607n, 18388910578118854845n, 18439695761788362148n,
18388910578118854845n, 18446743798831644607n, 18443486512800762045n,
18423062401422974372n, 18446743798818179261n, 18446743798831644607n,
18446428015642708157n, 18446743798826130852n, 18388910578118854845n,
18446743798831644607n, 18403610945503004861n, 18403610945510956452n,
18403610945503004861n, 18403610945516470207n, 18446428015642708157n,
18446743798826130852n, 18446428015642708157n, 18446428015656173503n,
18388910578131561795n, 18423062401422974372n, 18423062401427729731n,
18446743798830886211n, 18388910578131561795n, 18439695761788362148n,
18388910578131561795n, 18446743798830886211n, 18443486512813468995n,
18423062401422974372n, 18446743798830886211n, 18446743798830886211n,
18446428015655415107n, 18446743798826130852n, 18388910578131561795n,
18446743798830886211n, 18403610945515711811n, 18403610945510956452n,
18403610945515711811n, 18403610945515711811n, 18446428015655415107n,
18446743798826130852n, 18446428015655415107n, 18446428015655415107n,
18388910578118854845n, 18439695761788362148n, 18388910578126806436n,
18446743798831644607n, 18443486512800762045n, 18423062401422974372n,
18446743798826130852n, 18446743798831644607n, 18446428015642708157n,
18446743798826130852n, 18388910578126806436n, 18446743798831644607n,
18403610945503004861n, 18403610945510956452n, 18403610945510956452n,
18403610945516470207n, 18446428015642708157n, 18446743798826130852n,
18446428015650659748n, 18446428015656173503n, 18443486512800762045n,
18423062401426847128n, 18446743798818179261n, 18446743798831644607n,
18446428015642708157n, 18446743798830003608n, 18388910578118854845n,
18446743798831644607n, 18403610945503004861n, 18403610945514829208n,
18403610945503004861n, 18403610945516470207n, 18446428015642708157n,
18446743798830003608n, 18446428015642708157n, 18446428015656173503n,
18446428015655415107n, 18446743798826130852n, 18388910578132320191n,
18446743798831644607n, 18403610945515711811n, 18403610945510956452n,
18403610945516470207n, 18403610945516470207n, 18446428015655415107n,
18446743798826130852n, 18446428015656173503n, 18446428015656173503n,
18403610945516396683n, 18403610945516470207n, 18403610945503004861n,
18403610945516470207n, 18446428015656099979n, 18446743798831644607n,
18446428015642708157n, 18446428015656173503n, 18446428015646130853n,
18446743798821601957n, 18446428015646130853n, 18446428015646130853n
]
}),
bundle: Series.new({
type: new Uint64,
data: [
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
8589934592n, 8589934593n, 12884901888n, 4294967296n, 12884901889n, 12884901890n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 12884901890n, 4294967296n, 12884901888n, 12884901889n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 12884901888n, 4294967296n,
12884901889n, 12884901890n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 8589934592n, 8589934593n, 8589934593n, 8589934592n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 8589934592n, 8589934593n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 8589934592n, 8589934593n,
8589934592n, 8589934593n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 12884901888n, 4294967296n, 12884901889n, 12884901890n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 17179869184n, 17179869185n,
17179869186n, 17179869187n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 12884901888n, 4294967296n,
12884901889n, 12884901890n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n,
4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n, 4294967296n
]
})
});
}
| 0 |
rapidsai_public_repos/node/modules/demo/graph
|
rapidsai_public_repos/node/modules/demo/graph/src/app.jsx
|
// Copyright (c) 2020-2022, NVIDIA CORPORATION.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
import { log as deckLog, OrthographicView } from '@deck.gl/core';
import { TextLayer } from '@deck.gl/layers';
import { default as DeckGL } from '@deck.gl/react';
import { GraphLayer } from '@rapidsai/deck.gl';
import { as as asAsyncIterable } from 'ix/asynciterable/as';
import { takeWhile } from 'ix/asynciterable/operators/takewhile';
import * as React from 'react';
import { default as loadGraphData } from './loader';
deckLog.level = 0;
deckLog.enable(false);
const composeFns = (fns) => function (...args) { fns.forEach((fn) => fn && fn.apply(this, args)); }
export class App extends React.Component {
constructor(props, context) {
super(props, context);
this._isMounted = false;
this._deck = React.createRef();
this.state = { graph: {}, autoCenter: true };
}
componentWillUnmount() { this._isMounted = false; }
componentDidMount() {
this._isMounted = true;
asAsyncIterable(loadGraphData(this.props))
.pipe(takeWhile(() => this._isMounted))
.forEach((state) => this.setState(state))
.catch((e) => console.error(e));
}
render() {
const { onAfterRender, ...props } = this.props;
const { params = {}, selectedParameter } = this.state;
const [viewport] = (this._deck?.current?.deck?.viewManager?.getViewports() || []);
if (this.state.autoCenter && this.state.bbox) {
const viewState = centerOnBbox(this.state.bbox);
viewState && (props.initialViewState = viewState);
}
const [minX = Number.NEGATIVE_INFINITY, minY = Number.NEGATIVE_INFINITY] =
(viewport?.getBounds() || []);
return (
<DeckGL {...props}
ref={this._deck}
onViewStateChange={() => this.setState({
autoCenter: params.autoCenter ? (params.autoCenter.val = false) : false
})}
_framebuffer={props.getRenderTarget ? props.getRenderTarget() : null}
onAfterRender={composeFns([onAfterRender, this.state.onAfterRender])}>
<GraphLayer
edgeStrokeWidth={2}
edgeOpacity={.5}
nodesStroked={true}
nodeFillOpacity={.5}
nodeStrokeOpacity={.9}
{...this.state.graph}
getNodeLabels={getNodeLabels}
getEdgeLabels={getEdgeLabels}
/>
{viewport && selectedParameter !== undefined ?
<TextLayer
sizeScale={1}
opacity={0.9}
maxWidth={2000}
pickable={false}
background={true}
getBackgroundColor={() => [46, 46, 46]}
getTextAnchor='start'
getAlignmentBaseline='top'
getSize={(d) => d.size}
getColor={(d) => d.color}
getPixelOffset={(d) => [0, d.index * 15]}
getPosition={(d) => d.position}
data={Object.keys(params).map((key, i) => ({
size: 15,
index: i,
text: i === selectedParameter
? `(${i}) ${params[key].name}: ${params[key].val}`
: ` ${i} ${params[key].name}: ${params[key].val}`,
color: [255, 255, 255],
position: [minX, minY],
}))}
/> : null
}
</DeckGL>
);
}
}
export default App;
App.defaultProps = {
controller: { keyboard: false },
onHover: onDragEnd,
onDrag: onDragStart,
onDragEnd: onDragEnd,
onDragStart: onDragStart,
initialViewState: {
zoom: 1,
target: [0, 0, 0],
minZoom: Number.NEGATIVE_INFINITY,
maxZoom: Number.POSITIVE_INFINITY,
},
views: [
new OrthographicView({
clear: {
color: [...[46, 46, 46].map((x) => x / 255), 1]
}
})
]
};
function onDragStart({ index }, { target }) {
if (target) { [window, target].forEach((element) => (element.style || {}).cursor = 'grabbing'); }
}
function onDragEnd({ index }, { target }) {
if (target) {
[window, target].forEach((element) => (element.style || {}).cursor =
~index ? 'pointer' : 'default');
}
}
function centerOnBbox([minX, maxX, minY, maxY]) {
const width = maxX - minX, height = maxY - minY;
if ((width === width) && (height === height)) {
const { outerWidth, outerHeight } = window;
const world = (width > height ? width : height);
const screen = (width > height ? outerWidth : outerHeight) * .9;
const zoom = (world > screen ? -(world / screen) : (screen / world));
return {
minZoom: Number.NEGATIVE_INFINITY,
maxZoom: Number.POSITIVE_INFINITY,
zoom: Math.log2(Math.abs(zoom)) * Math.sign(zoom),
target: [minX + (width * .5), minY + (height * .5), 0],
};
}
}
function getNodeLabels({ x, y, coordinate, nodeId, props, layer }) {
let size = 14;
const color = [255, 255, 255];
const labels = [{
size,
color,
offset: [14, 0],
position: () => {
const x = window.mouseInWindow ? window.mouseX : -1;
const y = window.mouseInWindow ? window.mouseY : -1;
return layer.context.viewport.unproject([x, y]);
},
text: props.data.nodes.attributes.nodeName
? props.data.nodes.attributes.nodeName.getValue(nodeId)
: `${nodeId}`,
}];
if (props.data.nodes.attributes.nodeData) {
size *= 1.5;
const text = `${props.data.nodes.attributes.nodeData.getValue(nodeId) || ''}`.trimEnd();
const lineSpacing = 3, padding = 20;
const nBreaks = ((text.match(/\n/ig) || []).length + 1);
const offsetX = 0, offsetY = (size + lineSpacing) * nBreaks;
labels.push({
text,
color,
size,
position: () => {
const [minX, , , maxY] = layer.context.viewport.getBounds();
return [minX, maxY];
},
offset: [offsetX + padding, -padding - offsetY],
});
}
return labels;
}
function getEdgeLabels({ x, y, coordinate, edgeId, props, layer }) {
let size = 14;
const color = [255, 255, 255];
const labels = [{
size,
color,
offset: [14, 0],
position: () => {
const x = window.mouseInWindow ? window.mouseX : -1;
const y = window.mouseInWindow ? window.mouseY : -1;
return layer.context.viewport.unproject([x, y]);
},
text: props.data.edges.attributes.edgeName
? props.data.edges.attributes.edgeName.getValue(edgeId)
: `${sourceNodeId} - ${targetNodeId}`,
}];
if (props.data.edges.attributes.edgeData) {
size *= 1.5;
const text = `${props.data.edges.attributes.edgeData.getValue(edgeId) || ''}`.trimEnd();
const lineSpacing = 3, padding = 20;
const nBreaks = ((text.match(/\n/ig) || []).length + 1);
const offsetX = 0, offsetY = (size + lineSpacing) * nBreaks;
labels.push({
text,
color,
size,
offset: [offsetX + padding, -padding - offsetY],
position: () => {
const [minX, , , maxY] = layer.context.viewport.getBounds();
return [minX, maxY];
},
});
}
return labels;
}
| 0 |
rapidsai_public_repos/node/modules/demo
|
rapidsai_public_repos/node/modules/demo/api-server/package.json
|
{
"private": true,
"name": "@rapidsai/demo-api-server",
"main": "index.js",
"version": "22.12.2",
"license": "Apache-2.0",
"author": "NVIDIA, Inc. (https://nvidia.com/)",
"maintainers": [
"Thomson Comer <[email protected]>"
],
"bin": "index.js",
"description": "A fastify-based web server that provides browser-access to GPU resources.",
"scripts": {
"test": "tap \"test/**/*.test.js\"",
"start": "fastify start -l info -P -p 3010 -w app.js",
"dev": "fastify start -w -l info -P -p 3010 app.js"
},
"keywords": [
"rapids.ai",
"node",
"NVIDIA",
"gpu",
"Dataframe",
"pandas"
],
"dependencies": {
"@fastify/autoload": "^4.0.0",
"@fastify/cors": "latest",
"@fastify/sensible": "^4.0.0",
"@types/node": "17.0.33",
"fastify": "^4.0.0",
"fastify-arrow": "1.0.0",
"fastify-cli": "^3.0.1",
"fastify-plugin": "^3.0.0"
},
"devDependencies": {
"path": "0.12.7",
"tap": "^16.1.0"
},
"files": [
"util",
"routes",
"plugins",
"app.js",
"index.js",
"README.md",
"package.json"
]
}
| 0 |
rapidsai_public_repos/node/modules/demo
|
rapidsai_public_repos/node/modules/demo/api-server/index.js
|
#!/usr/bin/env node
// Copyright (c) 2022, NVIDIA CORPORATION.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
const Path = require('path');
// Change cwd to the example dir so relative file paths are resolved
process.chdir(__dirname);
const fastify = require.resolve('fastify-cli/cli.js');
const {spawnSync} = require('child_process');
const env = {
NEXT_TELEMETRY_DISABLED: 1, // disable https://fastifyjs.org/telemetry
...process.env,
};
spawnSync(process.execPath,
[fastify, 'start', '-l', 'info', '-P', '-p', '3010', '-w', 'app.js'],
{env, cwd: __dirname, stdio: 'inherit'});
| 0 |
rapidsai_public_repos/node/modules/demo
|
rapidsai_public_repos/node/modules/demo/api-server/README.md
|
# Fastify HTTP Server Demo
This project is a Fastify-based node http server that allows
commands and data to be sent to and from the NVIDIA GPUs installed
on the host machine.
Essentially, the node-rapids system is provided as a backend to any
HTTP client. At this time only limited functionality is available to
load JSON files in the `graphology` graph dataset format, plus API
requests to request Dataframes and their Columns via `apache-arrow`.
Two endpoints, `graphology/nodes` and `graphology/edges` specifically
return pre-formatted arrays that can be used directly with the
[sigma.js](https://github.com/jacomyal/sigma.js) renderer. An
[extra-large-graphs](https://github.com/jacomyal/sigma.js/pull/1252) example PR is in the works
that utilizes this GPU-accelerated data for rendering larger datasets
than available via only CPU.
## Main Dependencies
- @rapidsai/cudf
- fastify
- fastify-arrow
- apache-arrow
An example project that demonstrates this API has a PR being reviewed at [sigma.js](https://github.com/jacomyal/sigma.js),
but this project does not depend on sigma.js.j
## Installation
To install dependencies, run the following from the root directory for `node-rapids`
```bash
yarn
```
To run the demo
```bash
# Select the api-server demo from the list of demos
yarn demo
# OR specifically with
cd modules/demo/api-server
yarn start
```
## Dataset
Run the graph generator at <https://github.com/thomcom/sigma.js/blob/add-gpu-graph-to-example/examples/extra-large-graphs/generate-graph.js>
to create a very large graph using the object
```js
const state = {
order: 1000000,
size: 2000000,
clusters: 3,
edgesRenderer: 'edges-fast'
};
```
You don't need to edit the file in order to create a graph of the above size. Simply call the .js via node:
```bash
node graph-generator.js
```
Which will create a file `./large-graph.json`. Copy `./large-graph.json` into `api-server/` and then set your
API request to the location of the file relative to `routes/graphology/index.js`:
```
curl http://localhost:3010/graphology/read_large_demo?filename=../../large-graph.json
```
Which will use parallel JSON parsing to load the graph onto the GPU.
## Routes
```txt
/
/graphology
/graphology/read_json
/graphology/read_large_demo
/graphology/list_tables
/graphology/get_table/:table
/graphology/get_column/:table/:column
/graphology/nodes/bounds
/graphology/nodes
/graphology/edges
/graphology/release
```
| 0 |
rapidsai_public_repos/node/modules/demo
|
rapidsai_public_repos/node/modules/demo/api-server/app.js
|
'use strict'
const path = require('path')
const AutoLoad = require('@fastify/autoload')
module.exports = async function(fastify, opts) {
// Place here your custom code!
// Do not touch the following lines
// This loads all plugins defined in plugins
// those should be support plugins that are reused
// through your application
fastify.register(AutoLoad,
{dir: path.join(__dirname, 'plugins'), options: Object.assign({}, opts)})
// This loads all plugins defined in routes
// define your routes in one of these
fastify.register(
AutoLoad,
{dir: path.join(__dirname, 'routes'), options: Object.assign({}, opts), ignorePattern: /.*.ts/})
}
| 0 |
rapidsai_public_repos/node/modules/demo/api-server
|
rapidsai_public_repos/node/modules/demo/api-server/util/schema.js
|
// Copyright (c) 2022, NVIDIA CORPORATION.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
'use strict';
const schema = {
graphology: {
description: 'The graphology api provides GPU acceleration of graphology datasets.',
schema: {
read_json: {
filename: 'A URI to a graphology json dataset file.',
result: `Causes the node-rapids backend to attempt to load the json object specified
by :filename. The GPU will attempt to parse the json file asynchronously and will
return OK/ Not Found/ or Fail based on the file status.
If the load is successful, four tables will be created in the node-rapids backend:
nodes, edges, clusters, and tags. The root objects in the json target must match
these names and order.`,
returns: 'Result OK/Not Found/Fail'
},
read_large_demo: {
filename:
'A URI to a graphology json dataset file matching the sigma.js/examples/large-demos spec.',
result: `Produces the same result as 'read_json'.
If the load is successful, three tables will be created in the node-rapids backend:
nodes, edges, and options.`,
returns: 'Result OK/Not Found/Fail'
},
list_tables: {returns: 'Tables that are available presently in GPU memory.'},
get_table: {
':table':
{table: 'The name of the table that has been allocated previously into GPU memory.'}
},
get_column: {':table': {':column': {table: 'The table name', column: 'The column name'}}},
nodes: {
returns:
'Returns the existing nodes table after applying normalization functions for sigma.js'
},
nodes: {bounds: {returns: 'Returns the x and y bounds to be used in rendering.'}},
edges: {return: 'Returns the existing edges table after applying normalization for sigma.js'}
}
}
};
module.exports = schema;
| 0 |
rapidsai_public_repos/node/modules/demo/api-server
|
rapidsai_public_repos/node/modules/demo/api-server/util/gpu_cache.js
|
// Copyright (c) 2022, NVIDIA CORPORATION.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
const {Bool8, Utf8String, Int32, Int64, DataFrame, Series, Float32, Float64} =
require('@rapidsai/cudf');
let timeout = -1;
let datasets = {};
function clearCachedGPUData() {
for (const key in datasets) { datasets[key] = null; }
};
function json_key_attributes_to_dataframe(str) {
let arr = {};
const columns = ['cluster', 'x', 'y', 'size', 'label', 'color'];
const dtypes = [new Int32, new Float32, new Float32, new Int32, new Utf8String, new Utf8String];
const no_open_list = str.split('[\n').gather([1], false);
const tokenized = no_open_list.split('},');
const keys = tokenized.getJSONObject('.key');
arr['key'] = keys.cast(new Int32);
columns.forEach((col, ix) => {
const parse_result = tokenized.getJSONObject('.attributes.' + columns[ix]);
arr[col] = parse_result.cast(dtypes[ix]);
});
const result = new DataFrame(arr);
return result;
}
function json_aos_to_dataframe(str, columns, dtypes) {
let arr = {};
columns.forEach((col, ix) => {
const no_open_list = str.split('[\n').gather([1], false);
const tokenized = no_open_list.split('},');
const parse_result = tokenized.getJSONObject('.' + columns[ix]);
arr[col] = parse_result.cast(dtypes[ix]);
});
const result = new DataFrame(arr);
return result;
}
function json_aoa_to_dataframe(str, dtypes) {
let arr = {};
const no_open_list = str.split('[\n').gather([1], false);
const tokenized = no_open_list.split('],');
dtypes.forEach((_, ix) => {
const get_ix = `[${ix}]`;
const parse_result = tokenized.getJSONObject(get_ix);
arr[ix] = parse_result.cast(dtypes[ix]);
});
const result = new DataFrame(arr);
return result;
}
module.exports = {
async setDataframe(name, dataframe) {
if (timeout) { clearTimeout(timeout); }
timeout = setTimeout(clearCachedGPUData, 10 * 60 * 1000);
if (datasets === null) {
datasets = {};
}
datasets[name] = dataframe;
},
async getDataframe(name) { return datasets[name]; },
async listDataframes() { return datasets != null ? Object.keys(datasets) : []; },
async clearDataframes() {
clearCachedGPUData();
clearTimeout(timeout);
datasets = null;
},
async readLargeGraphDemo(path) {
console.log('readLargeGraphDemo');
const dataset = Series.readText(path, '');
let split = dataset.split('"options":');
if (split.length <= 1) { throw 'Bad readLargeGraphDemo format: options not found.'; };
const toptions = split.gather([1], false);
let rest = split.gather([0], false);
split = rest.split('"edges":');
if (split.length <= 1) { throw 'Bad readLargeGraphDemo format: edges not found.'; };
const tedges = split.gather([1], false);
rest = split.gather([0], false);
split = rest.split('"nodes":');
if (split.length <= 1) { throw 'Bad readLargeGraphDemo format: nodes not found.'; };
const tnodes = split.gather([1], false);
const nodes = json_key_attributes_to_dataframe(tnodes);
const edges = json_aos_to_dataframe(
tedges, ['key', 'source', 'target'], [new Utf8String, new Int64, new Int64]);
let optionsArr = {};
optionsArr['type'] = Series.new(toptions.getJSONObject('.type'));
optionsArr['multi'] = Series.new(toptions.getJSONObject('.multi'));
optionsArr['allowSelfLoops'] = Series.new(toptions.getJSONObject('.allowSelfLoops'));
const options = new DataFrame(optionsArr);
return {nodes: nodes, edges: edges, options: options};
},
async readGraphology(path) {
console.log('readGraphology');
const dataset = Series.readText(path, '');
if (dataset.length == 0) { throw 'File does not exist or is empty.' }
let split = dataset.split('"tags":');
if (split.length <= 1) { throw 'Bad graphology format: tags not found.'; }
const ttags = split.gather([1], false);
let rest = split.gather([0], false);
split = rest.split('"clusters":');
if (split.length <= 1) { throw 'Bad graphology format: clusters not found.'; }
const tclusters = split.gather([1], false);
rest = split.gather([0], false);
split = rest.split('"edges":');
if (split.length <= 1) { throw 'Bad graphology format: edges not found.'; }
const tedges = split.gather([1], false);
rest = split.gather([0], false);
split = rest.split('"nodes":');
if (split.length <= 1) { throw 'Bad graphology format: nodes not found.'; }
const tnodes = split.gather([1], false);
const tags = json_aos_to_dataframe(ttags, ['key', 'image'], [new Utf8String, new Utf8String]);
const clusters = json_aos_to_dataframe(
tclusters, ['key', 'color', 'clusterLabel'], [new Int64, new Utf8String, new Utf8String]);
const nodes =
json_aos_to_dataframe(tnodes, ['key', 'label', 'tag', 'URL', 'cluster', 'x', 'y', 'score'], [
new Utf8String,
new Utf8String,
new Utf8String,
new Utf8String,
new Int32,
new Float64,
new Float64,
new Int32
]);
const edges = json_aoa_to_dataframe(tedges, [new Utf8String, new Utf8String]);
return {nodes: nodes, edges: edges, tags: tags, clusters: clusters};
}
}
| 0 |
rapidsai_public_repos/node/modules/demo/api-server
|
rapidsai_public_repos/node/modules/demo/api-server/routes/README.md
|
# Routes Folder
Routes define routes within your application. Fastify provides an
easy path to a microservice architecture, in the future you might want
to independently deploy some of those.
In this folder you should define all the routes that define the endpoints
of your web application.
Each service is a [Fastify
plugin](https://www.fastify.io/docs/latest/Reference/Plugins/), it is
encapsulated (it can have its own independent plugins) and it is
typically stored in a file; be careful to group your routes logically,
e.g. all `/users` routes in a `users.js` file. We have added
a `root.js` file for you with a '/' root added.
If a single file become too large, create a folder and add a `index.js` file there:
this file must be a Fastify plugin, and it will be loaded automatically
by the application. You can now add as many files as you want inside that folder.
In this way you can create complex routes within a single monolith,
and eventually extract them.
If you need to share functionality between routes, place that
functionality into the `plugins` folder, and share it via
[decorators](https://www.fastify.io/docs/latest/Reference/Decorators/).
If you're a bit confused about using `async/await` to write routes, you would
better take a look at [Promise resolution](https://www.fastify.io/docs/latest/Routes/#promise-resolution) for more details.
| 0 |
rapidsai_public_repos/node/modules/demo/api-server
|
rapidsai_public_repos/node/modules/demo/api-server/routes/root.js
|
// Copyright (c) 2022, NVIDIA CORPORATION.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
const fastify = require('fastify');
const root_schema = require('../util/schema.js');
module.exports = async function(fastify, opts) {
fastify.get('/', async function(request, reply) {
return root_schema;
});
}
| 0 |
rapidsai_public_repos/node/modules/demo/api-server/routes
|
rapidsai_public_repos/node/modules/demo/api-server/routes/graphology/index.js
|
// Copyright (c) 2022, NVIDIA CORPORATION.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
const Fs = require('fs');
const {Utf8String, Int32, Uint32, Float32, DataFrame, Series, Float64} = require('@rapidsai/cudf');
const {RecordBatchStreamWriter, Field, Vector, List, Table} = require('apache-arrow');
const Path = require('path');
const {promisify} = require('util');
const Stat = promisify(Fs.stat);
const fastifyCors = require('@fastify/cors');
const fastify = require('fastify');
const arrowPlugin = require('fastify-arrow');
const gpu_cache = require('../../util/gpu_cache.js');
const root_schema = require('../../util/schema.js');
module.exports = async function(fastify, opts) {
fastify.register(arrowPlugin);
fastify.register(fastifyCors, {origin: 'http://localhost:3001'});
fastify.decorate('setDataframe', gpu_cache.setDataframe);
fastify.decorate('getDataframe', gpu_cache.getDataframe);
fastify.decorate('listDataframes', gpu_cache.listDataframes);
fastify.decorate('readGraphology', gpu_cache.readGraphology);
fastify.decorate('readLargeGraphDemo', gpu_cache.readLargeGraphDemo);
fastify.decorate('clearDataFrames', gpu_cache.clearDataframes);
fastify.get('/', async function(request, reply) { return root_schema; });
fastify.route({
method: 'POST',
url: '/read_large_demo',
schema: {
querystring: {filename: {type: 'string'}, 'rootkeys': {type: 'array'}},
response: {
200: {
type: 'object',
properties:
{success: {type: 'boolean'}, message: {type: 'string'}, params: {type: 'string'}}
}
}
},
handler: async (request, reply) => {
const query = request.query;
let result = {
'params': JSON.stringify(query),
success: false,
message: 'Finding file.',
statusCode: 200
};
try {
let path = undefined;
if (query.filename === undefined) {
result.message = 'Parameter filename is required';
result.statusCode = 400;
} else if (query.filename.search('http') != -1) {
result.message = 'Remote files not supported yet.';
result.statusCode = 406;
} else {
result.message = 'File is not remote';
// does the file exist?
const path = Path.join(__dirname, query.filename);
console.log('Does the file exist?');
const stats = await Stat(path);
const message = 'File is available';
result.message = message;
result.success = true;
try {
const graphology = await fastify.readLargeGraphDemo(path);
await fastify.setDataframe('nodes', graphology['nodes']);
await fastify.setDataframe('edges', graphology['edges']);
await fastify.setDataframe('options', graphology['options']);
result.message = 'File read onto GPU.';
} catch (e) {
result.success = false;
result.message = e;
result.statusCode = 500;
}
}
} catch (e) {
result.success = false;
result.message = e.message;
result.statusCode = 404;
};
await reply.code(result.statusCode).send(result);
}
});
fastify.route({
method: 'POST',
url: '/read_json',
schema: {
querystring: {filename: {type: 'string'}, 'rootkeys': {type: 'array'}},
response: {
200: {
type: 'object',
properties:
{success: {type: 'boolean'}, message: {type: 'string'}, params: {type: 'string'}}
}
}
},
handler: async (request, reply) => {
const query = request.query;
let result = {
'params': JSON.stringify(query),
success: false,
message: 'Finding file.',
statusCode: 200
};
try {
let path = undefined;
if (query.filename === undefined) {
result.message = 'Parameter filename is required';
result.statusCode = 400;
} else if (query.filename.search('http') != -1) {
result.message = 'Remote files not supported yet.';
result.statusCode = 406;
} else {
result.message = 'File is not remote';
// does the file exist?
const path = Path.join(__dirname, query.filename);
console.log('Does the file exist?');
const stats = await Stat(path);
const message = 'File is available';
result.message = message;
result.success = true;
try {
const graphology = await fastify.readGraphology(path);
await fastify.setDataframe('nodes', graphology['nodes']);
await fastify.setDataframe('edges', graphology['edges']);
await fastify.setDataframe('clusters', graphology['clusters']);
await fastify.setDataframe('tags', graphology['tags']);
result.message = 'File read onto GPU.';
} catch (e) {
result.success = false;
result.message = e;
result.statusCode = 500;
}
}
} catch (e) {
result.success = false;
result.message = e.message;
result.statusCode = 404;
};
await reply.code(result.statusCode).send(result);
}
});
fastify.route({
method: 'GET',
url: '/list_tables',
handler: async (request, reply) => {
let message = 'Error';
let result = {success: false, message: message};
const list = await fastify.listDataframes();
return list;
}
});
fastify.route({
method: 'GET',
url: '/get_column/:table/:column',
schema: {querystring: {table: {type: 'string'}, 'column': {type: 'string'}}},
handler: async (request, reply) => {
let message = 'Error';
let result = {'params': JSON.stringify(request.params), success: false, message: message};
const table = await fastify.getDataframe(request.params.table);
if (table == undefined) {
result.message = 'Table not found';
await reply.code(404).send(result);
} else {
try {
const name = request.params.column;
const column = table.get(name);
const newDfObject = {};
newDfObject[name] = column;
const result = new DataFrame(newDfObject);
const writer = RecordBatchStreamWriter.writeAll(result.toArrow());
await reply.code(200).send(writer.toNodeStream());
} catch (e) {
if (e.substring('Unknown column name') != -1) {
result.message = e;
console.log(result);
await reply.code(404).send(result);
} else {
result.message = e;
console.log(result);
await reply.code(500).send(result);
}
}
}
}
});
fastify.route({
method: 'GET',
url: '/get_table/:table',
schema: {querystring: {table: {type: 'string'}}},
handler: async (request, reply) => {
let message = 'Error';
let result = {'params': JSON.stringify(request.params), success: false, message: message};
const table = await fastify.getDataframe(request.params.table);
if (table == undefined) {
result.message = 'Table not found';
await reply.code(404).send(result);
} else {
const writer = RecordBatchStreamWriter.writeAll(table.toArrow());
await reply.code(200).send(writer.toNodeStream());
}
}
});
fastify.route({
method: 'GET',
url: '/nodes/bounds',
handler: async (request, reply) => {
let message = 'Error';
let result = {success: false, message: message};
const df = await fastify.getDataframe('nodes');
if (df == undefined) {
result.message = 'Table not found';
await reply.code(404).send(result);
} else {
// compute xmin, xmax, ymin, ymax
const x = df.get('x');
const y = df.get('y');
const [xmin, xmax] = x.minmax();
const [ymin, ymax] = y.minmax();
result.bounds = {xmin: xmin, xmax: xmax, ymin: ymin, ymax: ymax};
result.message = 'Success';
result.success = true;
await reply.code(200).send(result);
}
}
});
fastify.route({
method: 'GET',
url: '/nodes',
handler: async (request, reply) => {
let message = 'Error';
let result = {success: false, message: message};
const df = await fastify.getDataframe('nodes');
if (df == undefined) {
result.message = 'Table not found';
await reply.code(404).send(result);
} else {
// tile x, y, size, color
let tiled = Series.sequence({type: new Float32, init: 0.0, size: (4 * df.numRows)});
let base_offset = Series.sequence({type: new Int32, init: 0.0, size: df.numRows}).mul(4);
//
// Duplicatin the sigma.j createNormalizationFunction here because there's no other way
// to let the Graph object compute it.
//
const x = df.get('x');
const y = df.get('y');
let color = df.get('color');
const color_ints = color.hexToIntegers(new Uint32).bitwiseOr(0xef000000);
const [xMin, xMax] = x.minmax();
const [yMin, yMax] = y.minmax();
const ratio = Math.max(xMax - xMin, yMax - yMin);
const dX = (xMax + xMin) / 2.0;
const dY = (yMax + yMin) / 2.0;
const x_scaled = x.add(-1.0 * dX).mul(1.0 / ratio).add(0.5);
const y_scaled = y.add(-1.0 * dY).mul(1.0 / ratio).add(0.5);
tiled = tiled.scatter(x_scaled, base_offset.cast(new Int32));
tiled = tiled.scatter(y_scaled, base_offset.add(1).cast(new Int32));
tiled = tiled.scatter(df.get('size').mul(2), base_offset.add(2).cast(new Int32));
tiled = tiled.scatter(color_ints.view(new Float32), base_offset.add(3).cast(new Int32));
const writer = RecordBatchStreamWriter.writeAll(new DataFrame({nodes: tiled}).toArrow());
await reply.code(200).send(writer.toNodeStream());
}
}
});
fastify.route({
method: 'GET',
url: '/edges',
handler: async (request, reply) => {
let message = 'Error';
let result = {success: false, message: message};
/** @type DataFrame<{x: Float32, y: Float32}> */
const df = await fastify.getDataframe('nodes');
/** @type DataFrame<{x: Int32, y: Int32}> */
const edges = await fastify.getDataframe('edges');
if (df == undefined) {
result.message = 'Table not found';
await reply.code(404).send(result);
} else {
try {
// tile x, y, size, color
let tiled = Series.sequence({type: new Float32, init: 0.0, size: (6 * edges.numRows)});
let base_offset =
Series.sequence({type: new Int32, init: 0.0, size: edges.numRows}).mul(3);
//
// Duplicatin the sigma.js createNormalizationFunction here because this is the best way
// to let the Graph object compute it on GPU.
//
// Remap the indices in the key table to their real targets.
const keys = df.get('key');
const keys_df = new DataFrame({'keys': keys});
const source_unordered = edges.get('source');
const target_unordered = edges.get('target');
source_df = new DataFrame({
'keys': source_unordered,
'idx': Series.sequence({size: source_unordered.length, init: 0})
});
target_df = new DataFrame({
'keys': target_unordered,
'idx': Series.sequence({size: target_unordered.length, init: 0})
});
const source_idx_df = keys_df.join({other: source_df, on: ['keys'], how: 'left'});
const target_idx_df = keys_df.join({other: target_df, on: ['keys'], how: 'left'});
let source_map = source_idx_df.get('idx')
let target_map = target_idx_df.get('idx')
if (source_map.nullCount > 0) { throw 'Edge sources do not match node keys'; }
if (target_map.nullCount > 0) { throw 'Edge targets do not match node keys'; }
let x = df.get('x');
let y = df.get('y');
const [xMin, xMax] = x.minmax();
const [yMin, yMax] = y.minmax();
const ratio = Math.max(xMax - xMin, yMax - yMin);
const dX = (xMax + xMin) / 2.0;
const dY = (yMax + yMin) / 2.0;
x = x.add(-1.0 * dX).mul(1.0 / ratio).add(0.5);
y = y.add(-1.0 * dY).mul(1.0 / ratio).add(0.5);
const source_xmap = x.gather(source_map, false);
const source_ymap = y.gather(source_map, false);
const target_xmap = x.gather(target_map, false);
const target_ymap = y.gather(target_map, false);
const color = Series.new(['#999'])
.hexToIntegers(new Int32)
.bitwiseOr(0xff000000)
.view(new Float32)
.toArray()[0];
tiled =
tiled.scatter(Series.new(source_xmap), Series.new(base_offset.mul(2)).cast(new Int32));
tiled = tiled.scatter(Series.new(source_ymap),
Series.new(base_offset.mul(2).add(1)).cast(new Int32));
tiled = tiled.scatter(color, Series.new(base_offset.mul(2).add(2).cast(new Int32)));
tiled = tiled.scatter(Series.new(target_xmap),
Series.new(base_offset.mul(2).add(3)).cast(new Int32));
tiled = tiled.scatter(Series.new(target_ymap),
Series.new(base_offset.mul(2).add(4)).cast(new Int32));
tiled = tiled.scatter(color, Series.new(base_offset.mul(2).add(5).cast(new Int32)));
const writer = RecordBatchStreamWriter.writeAll(new DataFrame({edges: tiled}).toArrow());
await reply.code(200).send(writer.toNodeStream());
} catch (e) {
if (e.includes('do not match') >= 0) {
result.statusCode = 422;
} else {
result.statusCode = 500;
}
result.success = false;
result.message = e;
await reply.code(result.statusCode).send(result);
}
}
}
});
fastify.route({
method: 'POST',
url: '/release',
handler: async (request, reply) => {
await fastify.clearDataFrames();
await reply.code(200).send({message: 'OK'})
}
});
}
| 0 |
rapidsai_public_repos/node/modules/demo/api-server
|
rapidsai_public_repos/node/modules/demo/api-server/plugins/README.md
|
# Plugins Folder
Plugins define behavior that is common to all the routes in your
application. Authentication, caching, templates, and all the other cross
cutting concerns should be handled by plugins placed in this folder.
Files in this folder are typically defined through the
[`fastify-plugin`](https://github.com/fastify/fastify-plugin) module,
making them non-encapsulated. They can define decorators and set hooks
that will then be used in the rest of your application.
Check out:
* [The hitchhiker's guide to plugins](https://www.fastify.io/docs/latest/Guides/Plugins-Guide/)
* [Fastify decorators](https://www.fastify.io/docs/latest/Reference/Decorators/).
* [Fastify lifecycle](https://www.fastify.io/docs/latest/Reference/Lifecycle/).
| 0 |
rapidsai_public_repos/node/modules/demo/api-server
|
rapidsai_public_repos/node/modules/demo/api-server/plugins/support.js
|
'use strict'
const fp = require('fastify-plugin')
// the use of fastify-plugin is required to be able
// to export the decorators to the outer scope
module.exports = fp(async function (fastify, opts) {
fastify.decorate('someSupport', function () {
return 'hugs'
})
})
| 0 |
rapidsai_public_repos/node/modules/demo/api-server
|
rapidsai_public_repos/node/modules/demo/api-server/plugins/sensible.js
|
'use strict'
const fp = require('fastify-plugin')
/**
* This plugins adds some utilities to handle http errors
*
* @see https://github.com/fastify/fastify-sensible
*/
module.exports = fp(async function (fastify, opts) {
fastify.register(require('@fastify/sensible'), {
errorHandler: false
})
})
| 0 |
rapidsai_public_repos/node/modules/demo/api-server
|
rapidsai_public_repos/node/modules/demo/api-server/test/fixtures.js
|
// Copyright (c) 2022, NVIDIA CORPORATION.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
const json_good = {
'json_good.txt':
` {
"nodes":
[
{
"key": "customer data management",
"label": "Customer data management",
"tag": "Field",
"URL": "https://en.wikipedia.org/wiki/Customer%20data%20management",
"cluster": "7",
"x": -278.2200012207031,
"y": 436.0100402832031,
"score": 0
},
{
"key": "educational data mining",
"label": "Educational data mining",
"tag": "Field",
"URL": "https://en.wikipedia.org/wiki/Educational%20data%20mining",
"cluster": "7",
"x": -1.9823756217956543,
"y": 250.4990692138672,
"score": 0
}
],
"edges":
[
["office suite", "human interactome"],
["educational data mining", "human interactome"],
],
"clusters":
[
{"key": "0", "color": "#6c3e81", "clusterLabel": "human interactome"},
{"key": "1", "color": "#666666", "clusterLabel": "Spreadsheets"},
],
"tags": [
{"key": "Chart type", "image": "charttype.svg"},
{"key": "Company", "image": "company.svg"},
]
} `
};
const json_large = {
'json_large.txt':
` {
"attributes": {},
"nodes": [
{
"key": "0",
"attributes": {
"cluster": 0,
"x": -13.364310772761677,
"y": 4.134339113107921,
"size": 0,
"label": "Node n°291, in cluster n°0",
"color": "#e24b04"
}
},
{
"key": "1",
"attributes": {
"cluster": 1,
"x": 1.3836898237261988,
"y": -11.536596764896206,
"size": 1,
"label": "Node n°292, in cluster n°1",
"color": "#323455"
}
}
],
"edges": [
{"key": "geid_115_98", "source": "1", "target": "0"},
{"key": "geid_115_99", "source": "0", "target": "1"}
],
"options": {"type": "mixed", "multi": false, "allowSelfLoops": true}
}`
};
const json_out_of_order = {
'json_out_of_order.txt':
` {
"attributes": {},
"nodes": [
{
"key": "290",
"attributes": {
"cluster": 0,
"x": -13.364310772761677,
"y": 4.134339113107921,
"size": 0,
"label": "Node n°291, in cluster n°0",
"color": "#e24b04"
}
},
{
"key": "291",
"attributes": {
"cluster": 1,
"x": 1.3836898237261988,
"y": -11.536596764896206,
"size": 1,
"label": "Node n°292, in cluster n°1",
"color": "#323455"
}
}
],
"edges": [
{"key": "geid_115_98", "source": "290", "target": "291"},
{"key": "geid_115_99", "source": "291", "target": "290"}
],
"options": {"type": "mixed", "multi": false, "allowSelfLoops": true}
}`
};
const json_bad_map = {
'json_bad_map.txt':
` {
"attributes": {},
"nodes": [
{
"key": "290",
"attributes": {
"cluster": 0,
"x": -13.364310772761677,
"y": 4.134339113107921,
"size": 0,
"label": "Node n°291, in cluster n°0",
"color": "#e24b04"
}
},
{
"key": "291",
"attributes": {
"cluster": 1,
"x": 1.3836898237261988,
"y": -11.536596764896206,
"size": 1,
"label": "Node n°292, in cluster n°1",
"color": "#323455"
}
}
],
"edges": [
{"key": "geid_115_98", "source": "0", "target": "1"},
{"key": "geid_115_99", "source": "1", "target": "0"}
],
"options": {"type": "mixed", "multi": false, "allowSelfLoops": true}
}`
};
module.exports = {
json_good: json_good,
json_large: json_large,
json_out_of_order: json_out_of_order,
json_bad_map: json_bad_map,
};
| 0 |
rapidsai_public_repos/node/modules/demo/api-server
|
rapidsai_public_repos/node/modules/demo/api-server/test/helper.js
|
'use strict'
// This file contains code that we reuse
// between our tests.
const { build: buildApplication } = require('fastify-cli/helper')
const path = require('path')
const AppPath = path.join(__dirname, '..', 'app.js')
// Fill in this config with all the configurations
// needed for testing the application
function config () {
return {}
}
// automatically build and tear down our instance
async function build (t) {
// you can set all the options supported by the fastify CLI command
const argv = [AppPath]
// fastify-plugin ensures that all decorators
// are exposed for testing purposes, this is
// different from the production setup
const app = await buildApplication(argv, config())
// tear down our app after we are done
t.teardown(app.close.bind(app))
return app
}
module.exports = {
config,
build
}
| 0 |
rapidsai_public_repos/node/modules/demo/api-server/test
|
rapidsai_public_repos/node/modules/demo/api-server/test/routes/root.test.js
|
// Copyright (c) 2022, NVIDIA CORPORATION.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
'use strict'
const {test} = require('tap');
const {build} = require('../helper');
test('root returns API description', async (t) => {
const app = await build(t);
const res = await app.inject({url: '/'});
t.same(JSON.parse(res.payload), {
graphology: {
description: 'The graphology api provides GPU acceleration of graphology datasets.',
schema: {
read_json: {
filename: 'A URI to a graphology json dataset file.',
result: `Causes the node-rapids backend to attempt to load the json object specified
by :filename. The GPU will attempt to parse the json file asynchronously and will
return OK/ Not Found/ or Fail based on the file status.
If the load is successful, four tables will be created in the node-rapids backend:
nodes, edges, clusters, and tags. The root objects in the json target must match
these names and order.`,
returns: 'Result OK/Not Found/Fail'
},
read_large_demo: {
filename:
'A URI to a graphology json dataset file matching the sigma.js/examples/large-demos spec.',
result: `Produces the same result as 'read_json'.
If the load is successful, three tables will be created in the node-rapids backend:
nodes, edges, and options.`,
returns: 'Result OK/Not Found/Fail'
},
list_tables: {returns: 'Tables that are available presently in GPU memory.'},
get_table: {
':table':
{table: 'The name of the table that has been allocated previously into GPU memory.'}
},
get_column: {':table': {':column': {table: 'The table name', column: 'The column name'}}},
nodes: {
returns:
'Returns the existing nodes table after applying normalization functions for sigma.js'
},
nodes: {bounds: {returns: 'Returns the x and y bounds to be used in rendering.'}},
edges:
{return: 'Returns the existing edges table after applying normalization for sigma.js'}
}
}
});
});
| 0 |
rapidsai_public_repos/node/modules/demo/api-server/test
|
rapidsai_public_repos/node/modules/demo/api-server/test/routes/graphology.test.js
|
// Copyright (c) 2022, NVIDIA CORPORATION.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
'use strict'
const {dir} = require('console');
const {test} = require('tap');
const {build} = require('../helper');
const {tableFromIPC, RecordBatchStreamWriter} = require('apache-arrow');
const {json_large, json_good, json_out_of_order, json_bad_map} = require('../fixtures.js');
test('graphology root returns api description', async t => {
const app = await build(t);
const res = await app.inject({url: '/graphology'})
t.same(JSON.parse(res.payload), {
graphology: {
description: 'The graphology api provides GPU acceleration of graphology datasets.',
schema: {
read_json: {
filename: 'A URI to a graphology json dataset file.',
result: `Causes the node-rapids backend to attempt to load the json object specified
by :filename. The GPU will attempt to parse the json file asynchronously and will
return OK/ Not Found/ or Fail based on the file status.
If the load is successful, four tables will be created in the node-rapids backend:
nodes, edges, clusters, and tags. The root objects in the json target must match
these names and order.`,
returns: 'Result OK/Not Found/Fail'
},
read_large_demo: {
filename:
'A URI to a graphology json dataset file matching the sigma.js/examples/large-demos spec.',
result: `Produces the same result as 'read_json'.
If the load is successful, three tables will be created in the node-rapids backend:
nodes, edges, and options.`,
returns: 'Result OK/Not Found/Fail'
},
list_tables: {returns: 'Tables that are available presently in GPU memory.'},
get_table: {
':table':
{table: 'The name of the table that has been allocated previously into GPU memory.'}
},
get_column: {':table': {':column': {table: 'The table name', column: 'The column name'}}},
nodes: {
returns:
'Returns the existing nodes table after applying normalization functions for sigma.js'
},
nodes: {bounds: {returns: 'Returns the x and y bounds to be used in rendering.'}},
edges:
{return: 'Returns the existing edges table after applying normalization for sigma.js'}
}
}
})
});
test('read_json no filename', async t => {
const app = await build(t);
const res = await app.inject({method: 'POST', url: '/graphology/read_json'});
t.same(
JSON.parse(res.payload),
{success: false, message: 'Parameter filename is required', params: '{}', statusCode: 400});
});
test('read_json no file', async (t) => {
const app = await build(t);
const res =
await app.inject({method: 'POST', url: '/graphology/read_json?filename=filenotfound.txt'});
const payload = JSON.parse(res.payload);
t.ok(payload.message.includes('no such file or directory'));
t.equal(payload.statusCode, 404);
});
test('read_json incorrect format', async (t) => {
const dir = t.testdir({
'json_bad.txt': ` {
[
{
"key": "customer data management",
"label": "Customer data management",
"cluster": "7",
"x": -278.2200012207031,
"y": 436.0100402832031,
"score": 0
},
{
"key": "educational data mining",
"label": "Educational data mining",
"cluster": "7",
"x": -1.9823756217956543,
"y": 250.4990692138672,
"score": 0
},
],
"edges":
[
["office suite", "human interactome"],
["educational data mining", "human interactome"],
],
"clusters":
[
{"key": "0", "color": "#6c3e81", "clusterLabel": "human interactome"},
{"key": "1", "color": "#666666", "clusterLabel": "Spreadsheets"},
],
"tags": [
{"key": "Chart type", "image": "charttype.svg"},
{"key": "Company", "image": "company.svg"},
]
} `
});
const rpath = '../../test/routes/' + dir.substring(dir.lastIndexOf('/')) + '/json_bad.txt';
const app = await build(t);
const res = await app.inject({method: 'POST', url: '/graphology/read_json?filename=' + rpath});
const release = await app.inject({method: 'POST', url: '/graphology/release'});
const payload = JSON.parse(res.payload);
t.equal(payload.message, 'Bad graphology format: nodes not found.');
t.equal(payload.success, false);
});
test('read_json file good', async (t) => {
const dir = t.testdir(json_good);
const rpath = '../../test/routes/' + dir.substring(dir.lastIndexOf('/')) + '/json_good.txt';
const app = await build(t);
const res = await app.inject({method: 'POST', url: '/graphology/read_json?filename=' + rpath});
const release = await app.inject({method: 'POST', url: '/graphology/release'});
const payload = JSON.parse(res.payload);
t.equal(payload.message, 'File read onto GPU.');
t.equal(payload.success, true);
});
test('list_tables', async (t) => {
const dir = t.testdir(json_good);
const rpath = '../../test/routes/' + dir.substring(dir.lastIndexOf('/')) + '/json_good.txt';
const app = await build(t);
const load = await app.inject({method: 'POST', url: '/graphology/read_json?filename=' + rpath});
const res = await app.inject({method: 'GET', url: '/graphology/list_tables'});
const release = await app.inject({method: 'POST', url: '/graphology/release'});
const payload = JSON.parse(res.payload);
t.ok(payload.includes('nodes'));
});
test('get_table', async (t) => {
const dir = t.testdir(json_good);
const rpath = '../../test/routes/' + dir.substring(dir.lastIndexOf('/')) + '/json_good.txt';
const app = await build(t);
const load = await app.inject({method: 'POST', url: '/graphology/read_json?filename=' + rpath});
const res = await app.inject({
method: 'GET',
url: '/graphology/get_table/nodes',
header: {'accepts': 'application/octet-stream'}
});
t.same(res.statusCode, 200);
const table = tableFromIPC(res.rawPayload);
const release = await app.inject({method: 'POST', url: '/graphology/release'});
t.same(table.schema.names, ['key', 'label', 'tag', 'URL', 'cluster', 'x', 'y', 'score']);
t.equal(table.numRows, 2);
t.equal(table.numCols, 8);
});
test('get_column', async (t) => {
const dir = t.testdir(json_good);
const rpath = '../../test/routes/' + dir.substring(dir.lastIndexOf('/')) + '/json_good.txt';
const app = await build(t);
const load = await app.inject({method: 'POST', url: '/graphology/read_json?filename=' + rpath});
const res = await app.inject({
method: 'GET',
url: '/graphology/get_column/nodes/score',
header: {'accepts': 'application/octet-stream'}
});
t.same(res.statusCode, 200);
const table = tableFromIPC(res.rawPayload);
const release = await app.inject({method: 'POST', url: '/graphology/release'});
t.same(table.schema.names, ['score']);
t.equal(table.numRows, 2);
t.equal(table.numCols, 1);
});
test('nodes', async (t) => {
const dir = t.testdir(json_large);
const rpath = '../../test/routes/' + dir.substring(dir.lastIndexOf('/')) + '/json_large.txt';
const app = await build(t);
const load =
await app.inject({method: 'POST', url: '/graphology/read_large_demo?filename=' + rpath});
const res = await app.inject(
{method: 'GET', url: '/graphology/nodes', headers: {'accepts': 'application/octet-stream'}});
t.same(res.statusCode, 200);
const table = await tableFromIPC(res.rawPayload);
t.ok(table.getChild('nodes'));
t.same(table.getChild('nodes').toArray(), new Float32Array([
0.02944733388721943,
1,
0,
-1.4006860109112203e+29,
0.9705526828765869,
0,
2,
-5.515159729197043e+28
]))
const release = await app.inject({method: 'POST', url: '/graphology/release'});
});
test('nodes/bounds', async (t) => {
const dir = t.testdir(json_large);
const rpath = '../../test/routes/' + dir.substring(dir.lastIndexOf('/')) + '/json_large.txt';
const app = await build(t);
const load =
await app.inject({method: 'POST', url: '/graphology/read_large_demo?filename=' + rpath});
const res = await app.inject({method: 'GET', url: '/graphology/nodes/bounds'});
t.same(JSON.parse(res.payload), {
'success': true,
'message': 'Success',
'bounds': {
'xmin': -13.364311218261719,
'xmax': 1.3836898803710938,
'ymin': -11.536596298217773,
'ymax': 4.134339332580566,
}
});
const release = await app.inject({method: 'POST', url: '/graphology/release'});
});
test('nodes then nodes/bounds', async (t) => {
const dir = t.testdir(json_large);
const rpath = '../../test/routes/' + dir.substring(dir.lastIndexOf('/')) + '/json_large.txt';
const app = await build(t);
const load =
await app.inject({method: 'POST', url: '/graphology/read_large_demo?filename=' + rpath});
const nodes = await app.inject(
{method: 'GET', url: '/graphology/nodes', headers: {'accepts': 'application/octet-stream'}});
t.same(nodes.statusCode, 200);
const table = await tableFromIPC(nodes.rawPayload);
t.ok(table.getChild('nodes'));
t.same(table.getChild('nodes').toArray(), new Float32Array([
0.02944733388721943,
1,
0,
-1.4006860109112203e+29,
0.9705526828765869,
0,
2,
-5.515159729197043e+28
]))
const bounds = await app.inject({method: 'GET', url: '/graphology/nodes/bounds'});
t.same(JSON.parse(bounds.payload), {
'success': true,
'message': 'Success',
'bounds': {
'xmin': -13.364311218261719,
'xmax': 1.3836898803710938,
'ymin': -11.536596298217773,
'ymax': 4.134339332580566,
}
});
const release = await app.inject({method: 'POST', url: '/graphology/release'});
});
test('edges', async (t) => {
const dir = t.testdir(json_large);
const rpath = '../../test/routes/' + dir.substring(dir.lastIndexOf('/')) + '/json_large.txt';
const app = await build(t);
const load =
await app.inject({method: 'POST', url: '/graphology/read_large_demo?filename=' + rpath});
const res = await app.inject(
{method: 'GET', url: '/graphology/edges', header: {'accepts': 'application/octet-stream'}});
t.equal(res.statusCode, 200);
const table = tableFromIPC(res.rawPayload);
const release = await app.inject({method: 'POST', url: '/graphology/release'});
t.ok(table.getChild('edges'));
t.same(table.getChild('edges').toArray(), new Float32Array([
0.9705526828765869,
0,
-1.701910173408654e+38,
0.02944733388721943,
1,
-1.701910173408654e+38,
0.02944733388721943,
1,
-1.701910173408654e+38,
0.9705526828765869,
0,
-1.701910173408654e+38
]))
});
test('edges and nodes do not begin with 0', async (t) => {
const dir = t.testdir(json_out_of_order);
const rpath =
'../../test/routes/' + dir.substring(dir.lastIndexOf('/')) + '/json_out_of_order.txt';
const app = await build(t);
const load =
await app.inject({method: 'POST', url: '/graphology/read_large_demo?filename=' + rpath});
const res = await app.inject(
{method: 'GET', url: '/graphology/edges', header: {'accepts': 'application/octet-stream'}});
const release = await app.inject({method: 'POST', url: '/graphology/release'});
debugger;
t.equal(res.statusCode, 200);
const table = tableFromIPC(res.rawPayload);
t.ok(table.getChild('edges'));
t.same(table.getChild('edges').toArray(), new Float32Array([
0.02944733388721943,
1,
-1.701910173408654e+38,
0.9705526828765869,
0,
-1.701910173408654e+38,
0.9705526828765869,
0,
-1.701910173408654e+38,
0.02944733388721943,
1,
-1.701910173408654e+38,
]))
});
test('edge keys do not match node keys', {only: true}, async (t) => {
const dir = t.testdir(json_bad_map);
const rpath = '../../test/routes/' + dir.substring(dir.lastIndexOf('/')) + '/json_bad_map.txt';
const app = await build(t);
const load =
await app.inject({method: 'POST', url: '/graphology/read_large_demo?filename=' + rpath});
const res = await app.inject(
{method: 'GET', url: '/graphology/edges', header: {'accepts': 'application/octet-stream'}});
const release = await app.inject({method: 'POST', url: '/graphology/release'});
debugger;
t.equal(res.statusCode, 422);
t.same(JSON.parse(res.payload),
{success: false, message: 'Edge sources do not match node keys', statusCode: 422});
});
| 0 |
rapidsai_public_repos/node/modules/demo/api-server/test
|
rapidsai_public_repos/node/modules/demo/api-server/test/plugins/gpu_cache.test.js
|
// Copyright (c) 2022, NVIDIA CORPORATION.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
'use strict'
const {test} = require('tap')
const Fastify = require('fastify')
const Support = require('../../plugins/support')
const fixtures = require('../fixtures.js');
const gpuCache = require('../../util/gpu_cache.js');
test('clearCachedGPUData()', async t => {
await gpuCache.setDataframe('bob', 5);
const result = await gpuCache.getDataframe('bob');
t.equal(result, 5);
});
test('read_large_graph_demo', async t => {
const dir = t.testdir(fixtures);
const result = await gpuCache.readLargeGraphDemo(dir + '/json_large/json_large.txt');
await gpuCache.clearDataframes();
t.same(Object.keys(result), ['nodes', 'edges', 'options']);
});
test('readGraphology', async t => {
const dir = t.testdir(fixtures);
const result = await gpuCache.readGraphology(dir + '/json_good/json_good.txt');
await gpuCache.clearDataframes();
t.same(Object.keys(result), ['nodes', 'edges', 'tags', 'clusters']);
});
| 0 |
rapidsai_public_repos/node/modules/demo
|
rapidsai_public_repos/node/modules/demo/luma/package.json
|
{
"private": true,
"name": "@rapidsai/demo-luma.gl-lessons",
"main": "index.js",
"version": "22.12.2",
"license": "Apache-2.0",
"author": "NVIDIA, Inc. (https://nvidia.com/)",
"maintainers": [
"Paul Taylor <[email protected]>"
],
"bin": "index.js",
"scripts": {
"start": "node --experimental-vm-modules --enable-source-maps --trace-uncaught index.js",
"watch": "find -type f | entr -c -d -r node --experimental-vm-modules --enable-source-maps --trace-uncaught index.js"
},
"dependencies": {
"@rapidsai/glfw": "~22.12.2",
"@rapidsai/jsdom": "~22.12.2"
},
"files": [
"lessons",
"index.js",
"package.json"
]
}
| 0 |
rapidsai_public_repos/node/modules/demo
|
rapidsai_public_repos/node/modules/demo/luma/index.js
|
#!/usr/bin/env node
// Copyright (c) 2020, NVIDIA CORPORATION.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
module.exports = (glfwOptions = {
title: 'Luma Demo',
}) => {
const {RapidsJSDOM} = require('@rapidsai/jsdom');
const jsdom = new RapidsJSDOM({
glfwOptions: glfwOptions,
// Change cwd to the example dir so relative file paths are resolved
module: {path: require('path').join(__dirname, `lessons`, process.argv[2])}
});
jsdom.window.evalFn(() => import(`./app.js`));
return jsdom;
};
if (require.main === module) {
module.exports().window.addEventListener('close', () => process.exit(0), {once: true});
}
| 0 |
rapidsai_public_repos/node/modules/demo
|
rapidsai_public_repos/node/modules/demo/luma/README.md
|
## Luma.gl Lessons Demo
Running [Luma.gl](https://luma.gl/) lessons in a glfw instance, based on [webGL lessons](https://github.com/tparisi/webgl-lessons). Lessons 01 - 16 availble.
## Featured Dependencies
- @rapidsai/jsdom
- @rapidsai/glfw
Example of starting lesson 01:
```bash
yarn start 01`
```
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/07/package.json
|
{
"version": "0.0.1",
"private": true,
"name": "@rapidsai/demo-luma.gl-lessons-07",
"scripts": {
"start": "webpack-dev-server --progress --hot --open -d",
"start-local": "webpack-dev-server --env.local --progress --hot --open -d"
},
"dependencies": {
"@loaders.gl/images": "3.2.9",
"@luma.gl/constants": "8.5.16",
"@luma.gl/core": "8.5.16",
"@luma.gl/experimental": "8.5.16",
"@luma.gl/shadertools": "8.5.16",
"math.gl": "3.6.3"
}
}
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/07/app.js
|
import GL from '@luma.gl/constants';
import {Matrix4} from 'math.gl';
import { AnimationLoop } from '@luma.gl/engine';
import { Texture2D } from '@luma.gl/webgl';
import { setParameters, CubeGeometry } from '@luma.gl/core';
import { ModelNode } from '@luma.gl/experimental';
export const INFO_HTML = `
<p>
<a href="http://learningwebgl.com/blog/?p=684" target="_blank">
Basic directional and ambient lighting
</a>
<br/>
<br/>
Use arrow keys to spin the box and <code>+</code>/<code>-</code> to zoom in/out.
<br/>
<!--
<h2>Directional light:</h2>
<table style="border: 0; padding: 10px;">
<tr>
<td><b>Direction:</b>
<td>X: <input type="text" id="lightDirectionX" value="-0.25" />
<td>Y: <input type="text" id="lightDirectionY" value="-0.25" />
<td>Z: <input type="text" id="lightDirectionZ" value="-1.0" />
</tr>
<tr>
<td><b>Colour:</b>
<td>R: <input type="text" id="directionalR" value="0.8" />
<td>G: <input type="text" id="directionalG" value="0.8" />
<td>B: <input type="text" id="directionalB" value="0.8" />
</tr>
</table>
<h2>Ambient light:</h2>
<table style="border: 0; padding: 10px;">
<tr>
<td><b>Colour:</b>
<td>R: <input type="text" id="ambientR" value="0.2" />
<td>G: <input type="text" id="ambientG" value="0.2" />
<td>B: <input type="text" id="ambientB" value="0.2" />
</tr>
</table>
-->
<div>
<input type="checkbox" id="lighting" checked/> <b>Directional Lighting</b>
<br/>
<div class="control-block">
<div class="control-row">
Direction:
<div>X:
<input id="lightDirectionX" type="range" value="-0.25" min="-5" max="5" step="0.1"/>
</div>
<div>Y:
<input id="lightDirectionY" type="range" value="-0.25" min="-5" max="5" step="0.1"/>
</div>
<div>Z:
<input id="lightDirectionZ" type="range" value="1.0" min="0" max="5" step="0.1"/>
</div>
</div>
<div class="control-row">
Colour:
<div>R:
<input id="directionalR" type="range" value="0.2" min="0.0" max="1.0" step="0.01"/>
</div>
<div>G:
<input id="directionalG" type="range" value="0.2" min="0.0" max="1.0" step="0.01"/>
</div>
<div>B:
<input id="directionalB" type="range" value="0.2" min="0.0" max="1.0" step="0.01"/>
</div>
</div>
</div>
</div>
<br/>
<div>
<div><b>Ambient Lighting</b></div>
<div class="control-block">
<div class="control-row">
Colour:
<div>R:
<input id="ambientR" type="range" value="0.2" min="0.0" max="1.0" step="0.01"/>
</div>
<div>G:
<input id="ambientG" type="range" value="0.2" min="0.0" max="1.0" step="0.01"/>
</div>
<div>B:
<input id="ambientB" type="range" value="0.2" min="0.0" max="1.0" step="0.01"/>
</div>
</div>
</div>
</div>
<p>
The classic WebGL Lessons in luma.gl
`;
// Read Lighting form elements variables
function getHTMLControls() {
/* global document */
const $id = id => document.getElementById(id);
const $value = (id, defaultValue = 1) => ($id(id) ? Number($id(id).value) : defaultValue);
const $checked = id => ($id(id) ? $id(id).checked : true);
// Get lighting form elements
const lightingEnabled = $checked('lighting');
const lightDirection = [
$value('lightDirectionX', 0),
$value('lightDirectionY', 0),
$value('lightDirectionZ', 1)
];
const lightColor = [$value('directionalR'), $value('directionalG'), $value('directionalB')];
const ambientColor = [$value('ambientR'), $value('ambientG'), $value('ambientB')];
return {
lightingEnabled,
lightDirection,
lightColor,
ambientColor
};
}
const VERTEX_SHADER = `\
attribute vec3 positions;
attribute vec2 texCoords;
attribute vec3 normals;
uniform mat4 uMVMatrix;
uniform mat4 uPMatrix;
uniform vec3 uAmbientColor;
uniform vec3 uLightingDirection;
uniform vec3 uDirectionalColor;
uniform bool uUseLighting;
varying vec2 vTextureCoord;
varying vec3 vLightWeighting;
void main(void) {
gl_Position = uPMatrix * uMVMatrix * vec4(positions, 1.0);
vTextureCoord = texCoords;
if (!uUseLighting) {
vLightWeighting = vec3(1.0, 1.0, 1.0);
} else {
// Perform lighting in world space
// we should use 'transpose(inverse(mat3(uMVMatrix)))', but
// 'inverse' matrix operation not supported in GLSL 1.0, for now use
// upper-left 3X3 matrix of model view matrix, it works since we are not
// doing any non-uniform scaling transormations in this example.
mat3 normalMatrix = mat3(uMVMatrix);
vec3 transformedNormal = normalMatrix * normals;
float directionalLightWeighting = max(dot(transformedNormal, uLightingDirection), 0.0);
vLightWeighting = uAmbientColor + uDirectionalColor * directionalLightWeighting;
}
}
`;
const FRAGMENT_SHADER = `\
precision highp float;
varying vec2 vTextureCoord;
varying vec3 vLightWeighting;
uniform sampler2D uSampler;
void main(void) {
vec4 textureColor = texture2D(uSampler, vec2(vTextureCoord.s, vTextureCoord.t));
gl_FragColor = vec4(textureColor.rgb * vLightWeighting, textureColor.a);
}
`;
let xRot = 0;
let xSpeed = 0.01;
let yRot = 0;
let ySpeed = 0.0;
let z = -5.0;
export default class AppAnimationLoop extends AnimationLoop {
static getInfo() {
return INFO_HTML;
}
onInitialize({canvas, gl}) {
document.addEventListener('keydown', keyboardEventHandler);
setParameters(gl, {
clearColor: [0, 0, 0, 1],
clearDepth: 1,
depthTest: true,
depthFunc: GL.LEQUAL
});
return {
cube: new ModelNode(gl, {
geometry: new CubeGeometry(),
vs: VERTEX_SHADER,
fs: FRAGMENT_SHADER,
uniforms: {uSampler: new Texture2D(gl, 'crate.gif')}
})
};
}
onRender({gl, tick, aspect, cube}) {
xRot += xSpeed;
yRot += ySpeed;
gl.clear(GL.COLOR_BUFFER_BIT | GL.DEPTH_BUFFER_BIT);
// update element matrix to rotate cube on its center
cube.setRotation([xRot, yRot, 0]).updateMatrix();
const uMVMatrix = new Matrix4()
.lookAt({eye: [0, 0, 0]})
.translate([0, 0, z])
.rotateXYZ([tick * 0.01, tick * 0.01, tick * 0.01])
.multiplyRight(cube.matrix);
const {lightDirection, ambientColor} = getHTMLControls();
cube
.setUniforms({
uMVMatrix,
uPMatrix: new Matrix4().perspective({aspect}),
uAmbientColor: ambientColor,
uLightingDirection: lightDirection,
uDirectionalColor: [0.8, 0.8, 0.8],
uUseLighting: true
})
.draw();
}
onFinalize() {
document.removeEventListener('keydown', keyboardEventHandler);
}
}
function keyboardEventHandler(e) {
switch (e.code) {
case 'ArrowUp':
xSpeed -= 0.02;
break;
case 'ArrowDown':
xSpeed += 0.02;
break;
case 'ArrowLeft':
ySpeed -= 0.02;
break;
case 'ArrowRight':
ySpeed += 0.02;
break;
case 'Equal': // '+'
z += 0.05;
break;
case 'Minus': // '-'
z -= 0.05;
break;
default:
}
}
/* global window */
if (typeof window !== 'undefined' && !window.website) {
const animationLoop = new AppAnimationLoop();
animationLoop.start();
}
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/06/package.json
|
{
"version": "0.0.1",
"private": true,
"name": "@rapidsai/demo-luma.gl-lessons-06",
"scripts": {
"start": "webpack-dev-server --progress --hot --open -d",
"start-local": "webpack-dev-server --env.local --progress --hot --open -d"
},
"dependencies": {
"@loaders.gl/images": "3.2.9",
"@luma.gl/constants": "8.5.16",
"@luma.gl/core": "8.5.16",
"@luma.gl/experimental": "8.5.16",
"@luma.gl/shadertools": "8.5.16",
"math.gl": "3.6.3"
}
}
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/06/app.js
|
import GL from '@luma.gl/constants';
import {Matrix4} from 'math.gl';
import { AnimationLoop, CubeGeometry } from '@luma.gl/engine';
import { Texture2D, loadImage } from '@luma.gl/webgl';
import { setParameters } from '@luma.gl/core';
import { ModelNode } from '@luma.gl/experimental';
const INFO_HTML = `
<p>
<a href="http://learningwebgl.com/blog/?p=571" target="_blank">
Keyboard input and texture filters
</a>
<br/>
<br/>
Use arrow keys to spin the box and <code>+</code>/<code>-</code> to zoom in/out.
<br/>
<br/>
Filter (<code>F</code>): <code><span id='filter'/></code>
<p>
The classic WebGL Lessons in luma.gl
`;
const VERTEX_SHADER = `\
attribute vec3 positions;
attribute vec2 texCoords;
uniform mat4 uMVMatrix;
uniform mat4 uPMatrix;
varying vec2 vTextureCoord;
void main(void) {
gl_Position = uPMatrix * uMVMatrix * vec4(positions, 1.0);
vTextureCoord = texCoords;
}
`;
const FRAGMENT_SHADER = `\
precision highp float;
varying vec2 vTextureCoord;
uniform sampler2D uSampler;
void main(void) {
gl_FragColor = texture2D(uSampler, vec2(vTextureCoord.s, vTextureCoord.t));
}
`;
let xRot = 0;
let xSpeed = 0.01;
let yRot = 0;
let ySpeed = 0.013;
let z = -5.0;
let filter = 0;
const filters = ['nearest', 'linear', 'mipmap'];
function cycleFilter(newFilter) {
filter = newFilter !== undefined ? newFilter : (filter + 1) % 3;
/* global document */
const element = document.getElementById('filter');
if (element) {
element.textContent = `GL.${filters[filter].toUpperCase()}`;
}
}
export default class AppAnimationLoop extends AnimationLoop {
static getInfo() {
return INFO_HTML;
}
onInitialize({canvas, gl}) {
document.addEventListener('keydown', keyboardEventHandler);
setParameters(gl, {
clearColor: [0, 0, 0, 1],
clearDepth: 1,
depthTest: true,
depthFunc: GL.LEQUAL,
[GL.UNPACK_FLIP_Y_WEBGL]: true
});
cycleFilter(0);
// load image
const image = loadImage('crate.gif');
return {
cube: new ModelNode(gl, {
geometry: new CubeGeometry(),
vs: VERTEX_SHADER,
fs: FRAGMENT_SHADER
}),
textures: {
nearest: new Texture2D(gl, {
data: image,
parameters: {
[GL.TEXTURE_MIN_FILTER]: GL.NEAREST,
[GL.TEXTURE_MAG_FILTER]: GL.NEAREST
},
pixelStore: {
[GL.UNPACK_FLIP_Y_WEBGL]: true
}
}),
linear: new Texture2D(gl, {
data: image,
parameters: {
[GL.TEXTURE_MIN_FILTER]: GL.LINEAR,
[GL.TEXTURE_MAG_FILTER]: GL.LINEAR
},
pixelStore: {
[GL.UNPACK_FLIP_Y_WEBGL]: true
}
}),
mipmap: new Texture2D(gl, {
data: image,
mipmap: true,
parameters: {
[GL.TEXTURE_MIN_FILTER]: GL.LINEAR_MIPMAP_LINEAR,
[GL.TEXTURE_MAG_FILTER]: GL.LINEAR
},
pixelStore: {
[GL.UNPACK_FLIP_Y_WEBGL]: true
}
})
}
};
}
onRender({gl, tick, aspect, cube, textures}) {
xRot += xSpeed;
yRot += ySpeed;
gl.clear(GL.COLOR_BUFFER_BIT | GL.DEPTH_BUFFER_BIT);
// cube
// .setUniforms({
// uSampler: textures[filters[filter]],
// uPMatrix: new Matrix4().perspective({aspect}),
// uMVMatrix: new Matrix4()
// .lookAt({eye: [0, 0, 0]})
// .translate([0, 0, -5])
// })
// .draw();
// draw Cube
// update element matrix to rotate cube on its center
cube.setRotation([xRot, yRot, 0]).updateMatrix();
const uMVMatrix = new Matrix4()
.lookAt({eye: [0, 0, 0]})
.translate([0, 0, z])
.rotateXYZ([tick * 0.01, tick * 0.01, tick * 0.01])
.multiplyRight(cube.matrix);
cube
.setUniforms({
uMVMatrix,
uPMatrix: new Matrix4().perspective({aspect}),
uSampler: textures[filters[filter]]
})
.draw();
}
onFinalize() {
document.removeEventListener('keydown', keyboardEventHandler);
}
}
function keyboardEventHandler(e) {
switch (e.code) {
case 'KeyF':
cycleFilter();
break;
case 'ArrowUp':
xSpeed -= 0.01;
break;
case 'ArrowDown':
xSpeed += 0.01;
break;
case 'ArrowLeft':
ySpeed -= 0.01;
break;
case 'ArrowRight':
ySpeed += 0.01;
break;
case 'Equal': // '+'
z += 0.05;
break;
case 'Minus': // '-'
z -= 0.05;
break;
default:
}
}
/* global window */
if (typeof window !== 'undefined' && !window.website) {
const animationLoop = new AppAnimationLoop();
animationLoop.start();
}
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/05/package.json
|
{
"version": "0.0.1",
"private": true,
"name": "@rapidsai/demo-luma.gl-lessons-05",
"scripts": {
"start": "webpack-dev-server --progress --hot --open -d",
"start-local": "webpack-dev-server --env.local --progress --hot --open -d"
},
"dependencies": {
"@luma.gl/constants": "8.5.16",
"@luma.gl/core": "8.5.16",
"math.gl": "3.6.3"
}
}
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/05/app.js
|
import GL from '@luma.gl/constants';
import {Matrix4} from 'math.gl';
import { AnimationLoop, Model, CubeGeometry } from '@luma.gl/engine';
import { Texture2D } from '@luma.gl/webgl';
import { setParameters } from '@luma.gl/core';
const INFO_HTML = `
<p>
<a href="http://learningwebgl.com/blog/?p=507" target="_blank">
Introducing Textures
</a>
<p>
The classic WebGL Lessons in luma.gl
`;
const VERTEX_SHADER = `\
attribute vec3 positions;
attribute vec2 texCoords;
uniform mat4 uMVMatrix;
uniform mat4 uPMatrix;
varying vec2 vTextureCoord;
void main(void) {
gl_Position = uPMatrix * uMVMatrix * vec4(positions, 1.0);
vTextureCoord = texCoords;
}
`;
const FRAGMENT_SHADER = `\
precision highp float;
varying vec2 vTextureCoord;
uniform sampler2D uSampler;
void main(void) {
gl_FragColor = texture2D(uSampler, vec2(vTextureCoord.s, vTextureCoord.t));
}
`;
export default class AppAnimationLoop extends AnimationLoop {
static getInfo() {
return INFO_HTML;
}
onInitialize({gl}) {
setParameters(gl, {
clearColor: [0, 0, 0, 1],
clearDepth: 1,
depthTest: true,
depthFunc: GL.LEQUAL,
[GL.UNPACK_FLIP_Y_WEBGL]: true
});
return {
cube: new Model(gl, {
geometry: new CubeGeometry(),
vs: VERTEX_SHADER,
fs: FRAGMENT_SHADER,
uniforms: {
uSampler: new Texture2D(gl, 'nehe.gif')
}
})
};
}
onRender({gl, tick, aspect, cube}) {
gl.clear(GL.COLOR_BUFFER_BIT | GL.DEPTH_BUFFER_BIT);
return cube
.setUniforms({
uPMatrix: new Matrix4().perspective({aspect}),
uMVMatrix: new Matrix4()
.lookAt({eye: [0, 0, 0]})
.translate([0, 0, -5])
.rotateXYZ([tick * 0.01, tick * 0.01, tick * 0.01])
})
.draw();
}
}
/* global window */
if (typeof window !== 'undefined' && !window.website) {
const animationLoop = new AppAnimationLoop();
animationLoop.start();
}
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/14/package.json
|
{
"version": "0.0.1",
"private": true,
"name": "@rapidsai/demo-luma.gl-lessons-14",
"description": "The classic WebGL Lesson 14 ported to luma.gl.",
"contributors": [
"Xintong Xia <[email protected]>"
],
"scripts": {
"start": "webpack-dev-server --progress --hot --open -d",
"start-local": "webpack-dev-server --env.local --progress --hot --open -d"
},
"dependencies": {
"@loaders.gl/images": "3.2.9",
"@luma.gl/constants": "8.5.16",
"@luma.gl/core": "8.5.16",
"@luma.gl/experimental": "8.5.16",
"@luma.gl/shadertools": "8.5.16",
"math.gl": "3.6.3"
}
}
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/14/Teapot.json
|
{
"positions" : [5.929688,4.125,0,5.387188,4.125,2.7475,5.2971,4.494141,2.70917,5.832031,4.494141,0,5.401602,4.617188,2.753633,5.945313,4.617188,0,5.614209,4.494141,2.844092,6.175781,4.494141,0,5.848437,4.125,2.94375,6.429688,4.125,0,3.899688,4.125,4.97,3.830352,4.494141,4.900664,3.910782,4.617188,4.981094,4.074414,4.494141,5.144727,4.254687,4.125,5.325,1.677188,4.125,6.4575,1.638858,4.494141,6.367412,1.68332,4.617188,6.471914,1.77378,4.494141,6.684522,1.873438,4.125,6.91875,-1.070312,4.125,7,-1.070312,4.494141,6.902344,-1.070312,4.617188,7.015625,-1.070312,4.494141,7.246094,-1.070312,4.125,7.5,-1.070312,4.125,7,-4.007656,4.125,6.4575,-3.859572,4.494141,6.367412,-1.070312,4.494141,6.902344,-3.847676,4.617188,6.471914,-1.070312,4.617188,7.015625,-3.917371,4.494141,6.684522,-1.070312,4.494141,7.246094,-4.014062,4.125,6.91875,-1.070312,4.125,7.5,-6.209063,4.125,4.97,-6.042168,4.494141,4.900664,-6.0725,4.617188,4.981094,-6.217675,4.494141,5.144727,-6.395312,4.125,5.325,-7.591093,4.125,2.7475,-7.464421,4.494141,2.70917,-7.550137,4.617188,2.753633,-7.755822,4.494141,2.844092,-7.989062,4.125,2.94375,-8.070313,4.125,0,-7.972656,4.494141,0,-8.085938,4.617188,0,-8.316406,4.494141,0,-8.570313,4.125,0,-8.070313,4.125,0,-7.527812,4.125,-2.7475,-7.437724,4.494141,-2.70917,-7.972656,4.494141,0,-7.542227,4.617188,-2.753633,-8.085938,4.617188,0,-7.754834,4.494141,-2.844092,-8.316406,4.494141,0,-7.989062,4.125,-2.94375,-8.570313,4.125,0,-6.040312,4.125,-4.97,-5.970977,4.494141,-4.900664,-6.051406,4.617188,-4.981094,-6.215039,4.494141,-5.144727,-6.395312,4.125,-5.325,-3.817812,4.125,-6.4575,-3.779482,4.494141,-6.367412,-3.823945,4.617188,-6.471914,-3.914404,4.494141,-6.684522,-4.014062,4.125,-6.91875,-1.070312,4.125,-7,-1.070312,4.494141,-6.902344,-1.070312,4.617188,-7.015625,-1.070312,4.494141,-7.246094,-1.070312,4.125,-7.5,-1.070312,4.125,-7,1.677188,4.125,-6.4575,1.638858,4.494141,-6.367412,-1.070312,4.494141,-6.902344,1.68332,4.617188,-6.471914,-1.070312,4.617188,-7.015625,1.77378,4.494141,-6.684522,-1.070312,4.494141,-7.246094,1.873438,4.125,-6.91875,-1.070312,4.125,-7.5,3.899688,4.125,-4.97,3.830352,4.494141,-4.900664,3.910782,4.617188,-4.981094,4.074414,4.494141,-5.144727,4.254687,4.125,-5.325,5.387188,4.125,-2.7475,5.2971,4.494141,-2.70917,5.401602,4.617188,-2.753633,5.614209,4.494141,-2.844092,5.848437,4.125,-2.94375,5.929688,4.125,0,5.832031,4.494141,0,5.945313,4.617188,0,6.175781,4.494141,0,6.429688,4.125,0,6.429688,4.125,0,5.848437,4.125,2.94375,6.695264,2.162109,3.304053,7.347656,2.162109,0,7.433985,0.234375,3.61836,8.148438,0.234375,0,7.956494,-1.623047,3.840674,8.714844,-1.623047,0,8.154688,-3.375,3.925,8.929688,-3.375,0,4.254687,4.125,5.325,4.906446,2.162109,5.976758,5.475,0.234375,6.545312,5.877149,-1.623047,6.947461,6.029688,-3.375,7.1,1.873438,4.125,6.91875,2.23374,2.162109,7.765576,2.548047,0.234375,8.504297,2.770362,-1.623047,9.026807,2.854688,-3.375,9.225,-1.070312,4.125,7.5,-1.070312,2.162109,8.417969,-1.070312,0.234375,9.21875,-1.070312,-1.623047,9.785156,-1.070312,-3.375,10,-1.070312,4.125,7.5,-4.014062,4.125,6.91875,-4.374365,2.162109,7.765576,-1.070312,2.162109,8.417969,-4.688672,0.234375,8.504297,-1.070312,0.234375,9.21875,-4.910986,-1.623047,9.026807,-1.070312,-1.623047,9.785156,-4.995313,-3.375,9.225,-1.070312,-3.375,10,-6.395312,4.125,5.325,-7.047071,2.162109,5.976758,-7.615624,0.234375,6.545312,-8.017773,-1.623047,6.947461,-8.170312,-3.375,7.1,-7.989062,4.125,2.94375,-8.835889,2.162109,3.304053,-9.57461,0.234375,3.61836,-10.097119,-1.623047,3.840674,-10.295313,-3.375,3.925,-8.570313,4.125,0,-9.488281,2.162109,0,-10.289063,0.234375,0,-10.855469,-1.623047,0,-11.070313,-3.375,0,-8.570313,4.125,0,-7.989062,4.125,-2.94375,-8.835889,2.162109,-3.304053,-9.488281,2.162109,0,-9.57461,0.234375,-3.61836,-10.289063,0.234375,0,-10.097119,-1.623047,-3.840674,-10.855469,-1.623047,0,-10.295313,-3.375,-3.925,-11.070313,-3.375,0,-6.395312,4.125,-5.325,-7.047071,2.162109,-5.976758,-7.615624,0.234375,-6.545312,-8.017773,-1.623047,-6.947461,-8.170312,-3.375,-7.1,-4.014062,4.125,-6.91875,-4.374365,2.162109,-7.765576,-4.688672,0.234375,-8.504297,-4.910986,-1.623047,-9.026807,-4.995313,-3.375,-9.225,-1.070312,4.125,-7.5,-1.070312,2.162109,-8.417969,-1.070312,0.234375,-9.21875,-1.070312,-1.623047,-9.785156,-1.070312,-3.375,-10,-1.070312,4.125,-7.5,1.873438,4.125,-6.91875,2.23374,2.162109,-7.765576,-1.070312,2.162109,-8.417969,2.548047,0.234375,-8.504297,-1.070312,0.234375,-9.21875,2.770362,-1.623047,-9.026807,-1.070312,-1.623047,-9.785156,2.854688,-3.375,-9.225,-1.070312,-3.375,-10,4.254687,4.125,-5.325,4.906446,2.162109,-5.976758,5.475,0.234375,-6.545312,5.877149,-1.623047,-6.947461,6.029688,-3.375,-7.1,5.848437,4.125,-2.94375,6.695264,2.162109,-3.304053,7.433985,0.234375,-3.61836,7.956494,-1.623047,-3.840674,8.154688,-3.375,-3.925,6.429688,4.125,0,7.347656,2.162109,0,8.148438,0.234375,0,8.714844,-1.623047,0,8.929688,-3.375,0,8.929688,-3.375,0,8.154688,-3.375,3.925,7.794336,-4.857422,3.77168,8.539063,-4.857422,0,7.001562,-5.953125,3.434375,7.679688,-5.953125,0,6.208789,-6.697266,3.09707,6.820313,-6.697266,0,5.848437,-7.125,2.94375,6.429688,-7.125,0,6.029688,-3.375,7.1,5.752343,-4.857422,6.822656,5.142187,-5.953125,6.2125,4.532031,-6.697266,5.602344,4.254687,-7.125,5.325,2.854688,-3.375,9.225,2.701367,-4.857422,8.864649,2.364063,-5.953125,8.071875,2.026758,-6.697266,7.279101,1.873438,-7.125,6.91875,-1.070312,-3.375,10,-1.070312,-4.857422,9.609375,-1.070312,-5.953125,8.75,-1.070312,-6.697266,7.890625,-1.070312,-7.125,7.5,-1.070312,-3.375,10,-4.995313,-3.375,9.225,-4.841992,-4.857422,8.864649,-1.070312,-4.857422,9.609375,-4.504687,-5.953125,8.071875,-1.070312,-5.953125,8.75,-4.167383,-6.697266,7.279101,-1.070312,-6.697266,7.890625,-4.014062,-7.125,6.91875,-1.070312,-7.125,7.5,-8.170312,-3.375,7.1,-7.892968,-4.857422,6.822656,-7.282812,-5.953125,6.2125,-6.672656,-6.697266,5.602344,-6.395312,-7.125,5.325,-10.295313,-3.375,3.925,-9.934961,-4.857422,3.77168,-9.142187,-5.953125,3.434375,-8.349414,-6.697266,3.09707,-7.989062,-7.125,2.94375,-11.070313,-3.375,0,-10.679688,-4.857422,0,-9.820313,-5.953125,0,-8.960938,-6.697266,0,-8.570313,-7.125,0,-11.070313,-3.375,0,-10.295313,-3.375,-3.925,-9.934961,-4.857422,-3.77168,-10.679688,-4.857422,0,-9.142187,-5.953125,-3.434375,-9.820313,-5.953125,0,-8.349414,-6.697266,-3.09707,-8.960938,-6.697266,0,-7.989062,-7.125,-2.94375,-8.570313,-7.125,0,-8.170312,-3.375,-7.1,-7.892968,-4.857422,-6.822656,-7.282812,-5.953125,-6.2125,-6.672656,-6.697266,-5.602344,-6.395312,-7.125,-5.325,-4.995313,-3.375,-9.225,-4.841992,-4.857422,-8.864649,-4.504687,-5.953125,-8.071875,-4.167383,-6.697266,-7.279101,-4.014062,-7.125,-6.91875,-1.070312,-3.375,-10,-1.070312,-4.857422,-9.609375,-1.070312,-5.953125,-8.75,-1.070312,-6.697266,-7.890625,-1.070312,-7.125,-7.5,-1.070312,-3.375,-10,2.854688,-3.375,-9.225,2.701367,-4.857422,-8.864649,-1.070312,-4.857422,-9.609375,2.364063,-5.953125,-8.071875,-1.070312,-5.953125,-8.75,2.026758,-6.697266,-7.279101,-1.070312,-6.697266,-7.890625,1.873438,-7.125,-6.91875,-1.070312,-7.125,-7.5,6.029688,-3.375,-7.1,5.752343,-4.857422,-6.822656,5.142187,-5.953125,-6.2125,4.532031,-6.697266,-5.602344,4.254687,-7.125,-5.325,8.154688,-3.375,-3.925,7.794336,-4.857422,-3.77168,7.001562,-5.953125,-3.434375,6.208789,-6.697266,-3.09707,5.848437,-7.125,-2.94375,8.929688,-3.375,0,8.539063,-4.857422,0,7.679688,-5.953125,0,6.820313,-6.697266,0,6.429688,-7.125,0,6.429688,-7.125,0,5.848437,-7.125,2.94375,5.691685,-7.400391,2.877056,6.259766,-7.400391,0,4.853868,-7.640625,2.520586,5.351563,-7.640625,0,2.783648,-7.810547,1.639761,3.107422,-7.810547,0,-1.070312,-7.875,0,4.254687,-7.125,5.325,4.134043,-7.400391,5.204355,3.489219,-7.640625,4.559531,1.895879,-7.810547,2.966191,-1.070312,-7.875,0,1.873438,-7.125,6.91875,1.806743,-7.400391,6.761997,1.450274,-7.640625,5.92418,0.569448,-7.810547,3.85396,-1.070312,-7.875,0,-1.070312,-7.125,7.5,-1.070312,-7.400391,7.330078,-1.070312,-7.640625,6.421875,-1.070312,-7.810547,4.177734,-1.070312,-7.875,0,-1.070312,-7.125,7.5,-4.014062,-7.125,6.91875,-3.947368,-7.400391,6.761997,-1.070312,-7.400391,7.330078,-3.590898,-7.640625,5.92418,-1.070312,-7.640625,6.421875,-2.710073,-7.810547,3.85396,-1.070312,-7.810547,4.177734,-1.070312,-7.875,0,-6.395312,-7.125,5.325,-6.274668,-7.400391,5.204355,-5.629844,-7.640625,4.559531,-4.036504,-7.810547,2.966191,-1.070312,-7.875,0,-7.989062,-7.125,2.94375,-7.832309,-7.400391,2.877056,-6.994492,-7.640625,2.520586,-4.924272,-7.810547,1.639761,-1.070312,-7.875,0,-8.570313,-7.125,0,-8.400391,-7.400391,0,-7.492188,-7.640625,0,-5.248047,-7.810547,0,-1.070312,-7.875,0,-8.570313,-7.125,0,-7.989062,-7.125,-2.94375,-7.832309,-7.400391,-2.877056,-8.400391,-7.400391,0,-6.994492,-7.640625,-2.520586,-7.492188,-7.640625,0,-4.924272,-7.810547,-1.639761,-5.248047,-7.810547,0,-1.070312,-7.875,0,-6.395312,-7.125,-5.325,-6.274668,-7.400391,-5.204355,-5.629844,-7.640625,-4.559531,-4.036504,-7.810547,-2.966191,-1.070312,-7.875,0,-4.014062,-7.125,-6.91875,-3.947368,-7.400391,-6.761997,-3.590898,-7.640625,-5.92418,-2.710073,-7.810547,-3.85396,-1.070312,-7.875,0,-1.070312,-7.125,-7.5,-1.070312,-7.400391,-7.330078,-1.070312,-7.640625,-6.421875,-1.070312,-7.810547,-4.177734,-1.070312,-7.875,0,-1.070312,-7.125,-7.5,1.873438,-7.125,-6.91875,1.806743,-7.400391,-6.761997,-1.070312,-7.400391,-7.330078,1.450274,-7.640625,-5.92418,-1.070312,-7.640625,-6.421875,0.569448,-7.810547,-3.85396,-1.070312,-7.810547,-4.177734,-1.070312,-7.875,0,4.254687,-7.125,-5.325,4.134043,-7.400391,-5.204355,3.489219,-7.640625,-4.559531,1.895879,-7.810547,-2.966191,-1.070312,-7.875,0,5.848437,-7.125,-2.94375,5.691685,-7.400391,-2.877056,4.853868,-7.640625,-2.520586,2.783648,-7.810547,-1.639761,-1.070312,-7.875,0,6.429688,-7.125,0,6.259766,-7.400391,0,5.351563,-7.640625,0,3.107422,-7.810547,0,-1.070312,-7.875,0,-9.070313,2.25,0,-8.992188,2.425781,0.84375,-11.47583,2.405457,0.84375,-11.40625,2.232422,0,-13.298828,2.263184,0.84375,-13.132813,2.109375,0,-14.421631,1.877014,0.84375,-14.203125,1.775391,0,-14.804688,1.125,0.84375,-14.570313,1.125,0,-8.820313,2.8125,1.125,-11.628906,2.786134,1.125,-13.664063,2.601563,1.125,-14.902344,2.100586,1.125,-15.320313,1.125,1.125,-8.648438,3.199219,0.84375,-11.781982,3.166809,0.84375,-14.029297,2.939941,0.84375,-15.383057,2.324158,0.84375,-15.835938,1.125,0.84375,-8.570313,3.375,0,-11.851563,3.339844,0,-14.195313,3.09375,0,-15.601563,2.425781,0,-16.070313,1.125,0,-8.570313,3.375,0,-8.648438,3.199219,-0.84375,-11.781982,3.166809,-0.84375,-11.851563,3.339844,0,-14.029297,2.939941,-0.84375,-14.195313,3.09375,0,-15.383057,2.324158,-0.84375,-15.601563,2.425781,0,-15.835938,1.125,-0.84375,-16.070313,1.125,0,-8.820313,2.8125,-1.125,-11.628906,2.786134,-1.125,-13.664063,2.601563,-1.125,-14.902344,2.100586,-1.125,-15.320313,1.125,-1.125,-8.992188,2.425781,-0.84375,-11.47583,2.405457,-0.84375,-13.298828,2.263184,-0.84375,-14.421631,1.877014,-0.84375,-14.804688,1.125,-0.84375,-9.070313,2.25,0,-11.40625,2.232422,0,-13.132813,2.109375,0,-14.203125,1.775391,0,-14.570313,1.125,0,-14.570313,1.125,0,-14.804688,1.125,0.84375,-14.588013,0.00705,0.84375,-14.375,0.105469,0,-13.90918,-1.275146,0.84375,-13.757813,-1.125,0,-12.724976,-2.540863,0.84375,-12.671875,-2.355469,0,-10.992188,-3.609375,0.84375,-11.070313,-3.375,0,-15.320313,1.125,1.125,-15.056641,-0.209473,1.125,-14.242188,-1.605469,1.125,-12.841797,-2.94873,1.125,-10.820313,-4.125,1.125,-15.835938,1.125,0.84375,-15.525269,-0.425995,0.84375,-14.575195,-1.935791,0.84375,-12.958618,-3.356598,0.84375,-10.648438,-4.640625,0.84375,-16.070313,1.125,0,-15.738281,-0.524414,0,-14.726563,-2.085938,0,-13.011719,-3.541992,0,-10.570313,-4.875,0,-16.070313,1.125,0,-15.835938,1.125,-0.84375,-15.525269,-0.425995,-0.84375,-15.738281,-0.524414,0,-14.575195,-1.935791,-0.84375,-14.726563,-2.085938,0,-12.958618,-3.356598,-0.84375,-13.011719,-3.541992,0,-10.648438,-4.640625,-0.84375,-10.570313,-4.875,0,-15.320313,1.125,-1.125,-15.056641,-0.209473,-1.125,-14.242188,-1.605469,-1.125,-12.841797,-2.94873,-1.125,-10.820313,-4.125,-1.125,-14.804688,1.125,-0.84375,-14.588013,0.00705,-0.84375,-13.90918,-1.275146,-0.84375,-12.724976,-2.540863,-0.84375,-10.992188,-3.609375,-0.84375,-14.570313,1.125,0,-14.375,0.105469,0,-13.757813,-1.125,0,-12.671875,-2.355469,0,-11.070313,-3.375,0,7.429688,-0.75,0,7.429688,-1.394531,1.85625,10.01123,-0.677124,1.676074,9.828125,-0.199219,0,11.101563,0.84668,1.279688,10.867188,1.125,0,11.723145,2.629761,0.883301,11.4375,2.730469,0,12.898438,4.125,0.703125,12.429688,4.125,0,7.429688,-2.8125,2.475,10.414063,-1.728516,2.234766,11.617188,0.234375,1.70625,12.351563,2.408203,1.177734,13.929688,4.125,0.9375,7.429688,-4.230469,1.85625,10.816895,-2.779907,1.676074,12.132813,-0.37793,1.279688,12.97998,2.186646,0.883301,14.960938,4.125,0.703125,7.429688,-4.875,0,11,-3.257813,0,12.367188,-0.65625,0,13.265625,2.085938,0,15.429688,4.125,0,7.429688,-4.875,0,7.429688,-4.230469,-1.85625,10.816895,-2.779907,-1.676074,11,-3.257813,0,12.132813,-0.37793,-1.279688,12.367188,-0.65625,0,12.97998,2.186646,-0.883301,13.265625,2.085938,0,14.960938,4.125,-0.703125,15.429688,4.125,0,7.429688,-2.8125,-2.475,10.414063,-1.728516,-2.234766,11.617188,0.234375,-1.70625,12.351563,2.408203,-1.177734,13.929688,4.125,-0.9375,7.429688,-1.394531,-1.85625,10.01123,-0.677124,-1.676074,11.101563,0.84668,-1.279688,11.723145,2.629761,-0.883301,12.898438,4.125,-0.703125,7.429688,-0.75,0,9.828125,-0.199219,0,10.867188,1.125,0,11.4375,2.730469,0,12.429688,4.125,0,12.429688,4.125,0,12.898438,4.125,0.703125,13.291077,4.346237,0.65918,12.789063,4.335938,0,13.525879,4.422729,0.5625,13.054688,4.40625,0,13.532898,4.350357,0.46582,13.132813,4.335938,0,13.242188,4.125,0.421875,12.929688,4.125,0,13.929688,4.125,0.9375,14.395508,4.368896,0.878906,14.5625,4.458984,0.75,14.413086,4.38208,0.621094,13.929688,4.125,0.5625,14.960938,4.125,0.703125,15.499939,4.391556,0.65918,15.599121,4.495239,0.5625,15.293274,4.413804,0.46582,14.617188,4.125,0.421875,15.429688,4.125,0,16.001953,4.401855,0,16.070313,4.511719,0,15.693359,4.428224,0,14.929688,4.125,0,15.429688,4.125,0,14.960938,4.125,-0.703125,15.499939,4.391556,-0.65918,16.001953,4.401855,0,15.599121,4.495239,-0.5625,16.070313,4.511719,0,15.293274,4.413804,-0.46582,15.693359,4.428224,0,14.617188,4.125,-0.421875,14.929688,4.125,0,13.929688,4.125,-0.9375,14.395508,4.368896,-0.878906,14.5625,4.458984,-0.75,14.413086,4.38208,-0.621094,13.929688,4.125,-0.5625,12.898438,4.125,-0.703125,13.291077,4.346237,-0.65918,13.525879,4.422729,-0.5625,13.532898,4.350357,-0.46582,13.242188,4.125,-0.421875,12.429688,4.125,0,12.789063,4.335938,0,13.054688,4.40625,0,13.132813,4.335938,0,12.929688,4.125,0,0.501414,7.628906,0.670256,0.632813,7.628906,0,-1.070312,7.875,0,0.429278,7.03125,0.639395,0.554688,7.03125,0,-0.162029,6.292969,0.38696,-0.085937,6.292969,0,-0.147812,5.625,0.3925,-0.070312,5.625,0,0.140489,7.628906,1.210801,-1.070312,7.875,0,0.084844,7.03125,1.155156,-0.370879,6.292969,0.699434,-0.360312,5.625,0.71,-0.400056,7.628906,1.571726,-1.070312,7.875,0,-0.430918,7.03125,1.49959,-0.683352,6.292969,0.908284,-0.677812,5.625,0.9225,-1.070312,7.628906,1.703125,-1.070312,7.875,0,-1.070312,7.03125,1.625,-1.070312,6.292969,0.984375,-1.070312,5.625,1,-1.740569,7.628906,1.571726,-1.070312,7.628906,1.703125,-1.070312,7.875,0,-1.709707,7.03125,1.49959,-1.070312,7.03125,1.625,-1.457273,6.292969,0.908284,-1.070312,6.292969,0.984375,-1.462812,5.625,0.9225,-1.070312,5.625,1,-2.281113,7.628906,1.210801,-1.070312,7.875,0,-2.225469,7.03125,1.155156,-1.769746,6.292969,0.699434,-1.780312,5.625,0.71,-2.642038,7.628906,0.670256,-1.070312,7.875,0,-2.569902,7.03125,0.639395,-1.978596,6.292969,0.38696,-1.992812,5.625,0.3925,-2.773438,7.628906,0,-1.070312,7.875,0,-2.695313,7.03125,0,-2.054687,6.292969,0,-2.070312,5.625,0,-2.642038,7.628906,-0.670256,-2.773438,7.628906,0,-1.070312,7.875,0,-2.569902,7.03125,-0.639395,-2.695313,7.03125,0,-1.978596,6.292969,-0.38696,-2.054687,6.292969,0,-1.992812,5.625,-0.3925,-2.070312,5.625,0,-2.281113,7.628906,-1.210801,-1.070312,7.875,0,-2.225469,7.03125,-1.155156,-1.769746,6.292969,-0.699434,-1.780312,5.625,-0.71,-1.740569,7.628906,-1.571726,-1.070312,7.875,0,-1.709707,7.03125,-1.49959,-1.457273,6.292969,-0.908284,-1.462812,5.625,-0.9225,-1.070312,7.628906,-1.703125,-1.070312,7.875,0,-1.070312,7.03125,-1.625,-1.070312,6.292969,-0.984375,-1.070312,5.625,-1,-0.400056,7.628906,-1.571726,-1.070312,7.628906,-1.703125,-1.070312,7.875,0,-0.430918,7.03125,-1.49959,-1.070312,7.03125,-1.625,-0.683352,6.292969,-0.908284,-1.070312,6.292969,-0.984375,-0.677812,5.625,-0.9225,-1.070312,5.625,-1,0.140489,7.628906,-1.210801,-1.070312,7.875,0,0.084844,7.03125,-1.155156,-0.370879,6.292969,-0.699434,-0.360312,5.625,-0.71,0.501414,7.628906,-0.670256,-1.070312,7.875,0,0.429278,7.03125,-0.639395,-0.162029,6.292969,-0.38696,-0.147812,5.625,-0.3925,0.632813,7.628906,0,-1.070312,7.875,0,0.554688,7.03125,0,-0.085937,6.292969,0,-0.070312,5.625,0,-0.070312,5.625,0,-0.147812,5.625,0.3925,1.034141,5.179688,0.895391,1.210938,5.179688,0,2.735,4.875,1.619062,3.054688,4.875,0,4.262891,4.570313,2.26914,4.710938,4.570313,0,4.925938,4.125,2.55125,5.429688,4.125,0,-0.360312,5.625,0.71,0.549375,5.179688,1.619688,1.858438,4.875,2.92875,3.034375,4.570313,4.104687,3.544688,4.125,4.615,-0.677812,5.625,0.9225,-0.174922,5.179688,2.104453,0.54875,4.875,3.805313,1.198828,4.570313,5.333203,1.480938,4.125,5.99625,-1.070312,5.625,1,-1.070312,5.179688,2.28125,-1.070312,4.875,4.125,-1.070312,4.570313,5.78125,-1.070312,4.125,6.5,-1.070312,5.625,1,-1.462812,5.625,0.9225,-1.965703,5.179688,2.104453,-1.070312,5.179688,2.28125,-2.689375,4.875,3.805313,-1.070312,4.875,4.125,-3.339453,4.570313,5.333203,-1.070312,4.570313,5.78125,-3.621562,4.125,5.99625,-1.070312,4.125,6.5,-1.780312,5.625,0.71,-2.69,5.179688,1.619688,-3.999062,4.875,2.92875,-5.174999,4.570313,4.104687,-5.685312,4.125,4.615,-1.992812,5.625,0.3925,-3.174765,5.179688,0.895391,-4.875625,4.875,1.619062,-6.403516,4.570313,2.26914,-7.066563,4.125,2.55125,-2.070312,5.625,0,-3.351562,5.179688,0,-5.195313,4.875,0,-6.851563,4.570313,0,-7.570313,4.125,0,-2.070312,5.625,0,-1.992812,5.625,-0.3925,-3.174765,5.179688,-0.895391,-3.351562,5.179688,0,-4.875625,4.875,-1.619062,-5.195313,4.875,0,-6.403516,4.570313,-2.26914,-6.851563,4.570313,0,-7.066563,4.125,-2.55125,-7.570313,4.125,0,-1.780312,5.625,-0.71,-2.69,5.179688,-1.619688,-3.999062,4.875,-2.92875,-5.174999,4.570313,-4.104687,-5.685312,4.125,-4.615,-1.462812,5.625,-0.9225,-1.965703,5.179688,-2.104453,-2.689375,4.875,-3.805313,-3.339453,4.570313,-5.333203,-3.621562,4.125,-5.99625,-1.070312,5.625,-1,-1.070312,5.179688,-2.28125,-1.070312,4.875,-4.125,-1.070312,4.570313,-5.78125,-1.070312,4.125,-6.5,-1.070312,5.625,-1,-0.677812,5.625,-0.9225,-0.174922,5.179688,-2.104453,-1.070312,5.179688,-2.28125,0.54875,4.875,-3.805313,-1.070312,4.875,-4.125,1.198828,4.570313,-5.333203,-1.070312,4.570313,-5.78125,1.480938,4.125,-5.99625,-1.070312,4.125,-6.5,-0.360312,5.625,-0.71,0.549375,5.179688,-1.619688,1.858438,4.875,-2.92875,3.034375,4.570313,-4.104687,3.544688,4.125,-4.615,-0.147812,5.625,-0.3925,1.034141,5.179688,-0.895391,2.735,4.875,-1.619062,4.262891,4.570313,-2.26914,4.925938,4.125,-2.55125,-0.070312,5.625,0,1.210938,5.179688,0,3.054688,4.875,0,4.710938,4.570313,0,5.429688,4.125,0],
"normals" : [-0.966742,-0.255752,0,-0.893014,-0.256345,-0.369882,-0.893437,0.255996,-0.369102,-0.966824,0.255443,0,-0.083877,0.995843,-0.035507,-0.092052,0.995754,0,0.629724,0.73186,0.260439,0.68205,0.731305,0,0.803725,0.49337,0.332584,0.870301,0.492521,0,-0.683407,-0.256728,-0.683407,-0.683531,0.256068,-0.683531,-0.064925,0.995776,-0.064925,0.481399,0.732469,0.481399,0.614804,0.493997,0.614804,-0.369882,-0.256345,-0.893014,-0.369102,0.255996,-0.893437,-0.035507,0.995843,-0.083877,0.260439,0.73186,0.629724,0.332584,0.493369,0.803725,-0.002848,-0.257863,-0.966177,-0.001923,0.254736,-0.967009,-0.000266,0.995734,-0.09227,0.000024,0.731295,0.682061,0,0.492521,0.870301,-0.002848,-0.257863,-0.966177,0.379058,-0.3593,-0.852771,0.37711,0.149085,-0.914091,-0.001923,0.254736,-0.967009,0.027502,0.992081,-0.122552,-0.000266,0.995734,-0.09227,-0.26101,0.726762,0.635367,0.000024,0.731295,0.682061,-0.332485,0.492546,0.804271,0,0.492521,0.870301,0.663548,-0.41079,-0.625264,0.712664,0.073722,-0.697621,0.099726,0.987509,-0.121983,-0.48732,0.723754,0.488569,-0.615242,0.492602,0.615484,0.880028,-0.332906,-0.338709,0.917276,0.167113,-0.361493,0.113584,0.992365,-0.04807,-0.63415,0.727508,0.261889,-0.804126,0.492634,0.332705,0.96669,-0.255738,0.010454,0.967442,0.252962,0.008103,0.093436,0.995624,0.001281,-0.682167,0.731196,-0.000343,-0.870322,0.492483,-0.000054,0.96669,-0.255738,0.010454,0.893014,-0.256345,0.369882,0.893437,0.255996,0.369102,0.967442,0.252962,0.008103,0.083877,0.995843,0.035507,0.093436,0.995624,0.001281,-0.629724,0.73186,-0.260439,-0.682167,0.731196,-0.000343,-0.803725,0.49337,-0.332584,-0.870322,0.492483,-0.000054,0.683407,-0.256728,0.683407,0.683531,0.256068,0.683531,0.064925,0.995776,0.064925,-0.481399,0.732469,-0.481399,-0.614804,0.493997,-0.614804,0.369882,-0.256345,0.893014,0.369102,0.255996,0.893437,0.035507,0.995843,0.083877,-0.260439,0.73186,-0.629724,-0.332584,0.493369,-0.803725,0,-0.255752,0.966742,0,0.255443,0.966824,0,0.995754,0.092052,0,0.731305,-0.68205,0,0.492521,-0.870301,0,-0.255752,0.966742,-0.369882,-0.256345,0.893014,-0.369102,0.255996,0.893437,0,0.255443,0.966824,-0.035507,0.995843,0.083877,0,0.995754,0.092052,0.260439,0.73186,-0.629724,0,0.731305,-0.68205,0.332584,0.49337,-0.803725,0,0.492521,-0.870301,-0.683407,-0.256728,0.683407,-0.683531,0.256068,0.683531,-0.064925,0.995776,0.064925,0.481399,0.732469,-0.481399,0.614804,0.493997,-0.614804,-0.893014,-0.256345,0.369882,-0.893437,0.255996,0.369102,-0.083877,0.995843,0.035507,0.629724,0.73186,-0.260439,0.803725,0.493369,-0.332584,-0.966742,-0.255752,0,-0.966824,0.255443,0,-0.092052,0.995754,0,0.68205,0.731305,0,0.870301,0.492521,0,0.870301,0.492521,0,0.803725,0.49337,0.332584,0.845438,0.403546,0.349835,0.915321,0.402725,0,0.869996,0.336859,0.360047,0.941808,0.336151,0,0.904193,0.205791,0.37428,0.97869,0.205342,0,0.921879,-0.06637,0.381752,0.997804,-0.06624,0,0.614804,0.493997,0.614804,0.646802,0.404096,0.646802,0.665655,0.337351,0.665655,0.691923,0.20612,0.691923,0.705543,-0.06648,0.705542,0.332584,0.493369,0.803725,0.349835,0.403546,0.845438,0.360047,0.336859,0.869996,0.37428,0.205791,0.904193,0.381752,-0.066369,0.921879,0,0.492521,0.870301,0,0.402725,0.915321,0,0.336151,0.941808,0,0.205342,0.97869,0,-0.06624,0.997804,0,0.492521,0.870301,-0.332485,0.492546,0.804271,-0.349835,0.403546,0.845438,0,0.402725,0.915321,-0.360047,0.336859,0.869996,0,0.336151,0.941808,-0.37428,0.205791,0.904193,0,0.205342,0.97869,-0.381752,-0.06637,0.921879,0,-0.06624,0.997804,-0.615242,0.492602,0.615484,-0.646802,0.404096,0.646802,-0.665655,0.337351,0.665655,-0.691923,0.20612,0.691923,-0.705542,-0.06648,0.705543,-0.804126,0.492634,0.332705,-0.845438,0.403546,0.349835,-0.869996,0.336859,0.360047,-0.904193,0.205791,0.37428,-0.921879,-0.066369,0.381752,-0.870322,0.492483,-0.000054,-0.915321,0.402725,0,-0.941808,0.336151,0,-0.97869,0.205342,0,-0.997804,-0.06624,0,-0.870322,0.492483,-0.000054,-0.803725,0.49337,-0.332584,-0.845438,0.403546,-0.349835,-0.915321,0.402725,0,-0.869996,0.336859,-0.360047,-0.941808,0.336151,0,-0.904193,0.205791,-0.37428,-0.97869,0.205342,0,-0.921879,-0.06637,-0.381752,-0.997804,-0.06624,0,-0.614804,0.493997,-0.614804,-0.646802,0.404096,-0.646802,-0.665655,0.337351,-0.665655,-0.691923,0.20612,-0.691923,-0.705543,-0.06648,-0.705542,-0.332584,0.493369,-0.803725,-0.349835,0.403546,-0.845438,-0.360047,0.336859,-0.869996,-0.37428,0.205791,-0.904193,-0.381752,-0.066369,-0.921879,0,0.492521,-0.870301,0,0.402725,-0.915321,0,0.336151,-0.941808,0,0.205342,-0.97869,0,-0.06624,-0.997804,0,0.492521,-0.870301,0.332584,0.49337,-0.803725,0.349835,0.403546,-0.845438,0,0.402725,-0.915321,0.360047,0.336859,-0.869996,0,0.336151,-0.941808,0.37428,0.205791,-0.904193,0,0.205342,-0.97869,0.381752,-0.06637,-0.921879,0,-0.06624,-0.997804,0.614804,0.493997,-0.614804,0.646802,0.404096,-0.646802,0.665655,0.337351,-0.665655,0.691923,0.20612,-0.691923,0.705542,-0.06648,-0.705543,0.803725,0.493369,-0.332584,0.845438,0.403546,-0.349835,0.869996,0.336859,-0.360047,0.904193,0.205791,-0.37428,0.921879,-0.066369,-0.381752,0.870301,0.492521,0,0.915321,0.402725,0,0.941808,0.336151,0,0.97869,0.205342,0,0.997804,-0.06624,0,0.997804,-0.06624,0,0.921879,-0.06637,0.381752,0.831437,-0.43618,0.344179,0.900182,-0.435513,0,0.673512,-0.684666,0.278594,0.729611,-0.683863,0,0.640399,-0.720924,0.264874,0.693951,-0.720022,0,0.732949,-0.608995,0.303167,0.79395,-0.607983,0,0.705543,-0.06648,0.705542,0.636092,-0.436778,0.636092,0.514965,-0.68529,0.514965,0.489651,-0.721446,0.489651,0.560555,-0.609554,0.560555,0.381752,-0.066369,0.921879,0.344179,-0.43618,0.831437,0.278595,-0.684666,0.673512,0.264874,-0.720924,0.640399,0.303167,-0.608995,0.732949,0,-0.06624,0.997804,0,-0.435513,0.900182,0,-0.683863,0.729611,0,-0.720022,0.693951,0,-0.607983,0.79395,0,-0.06624,0.997804,-0.381752,-0.06637,0.921879,-0.344179,-0.43618,0.831437,0,-0.435513,0.900182,-0.278594,-0.684666,0.673512,0,-0.683863,0.729611,-0.264874,-0.720924,0.640399,0,-0.720022,0.693951,-0.303167,-0.608995,0.732949,0,-0.607983,0.79395,-0.705542,-0.06648,0.705543,-0.636092,-0.436778,0.636092,-0.514965,-0.68529,0.514965,-0.489651,-0.721446,0.489651,-0.560555,-0.609554,0.560555,-0.921879,-0.066369,0.381752,-0.831437,-0.43618,0.344179,-0.673512,-0.684666,0.278595,-0.640399,-0.720924,0.264874,-0.732949,-0.608995,0.303167,-0.997804,-0.06624,0,-0.900182,-0.435513,0,-0.729611,-0.683863,0,-0.693951,-0.720022,0,-0.79395,-0.607983,0,-0.997804,-0.06624,0,-0.921879,-0.06637,-0.381752,-0.831437,-0.43618,-0.344179,-0.900182,-0.435513,0,-0.673512,-0.684666,-0.278594,-0.729611,-0.683863,0,-0.640399,-0.720924,-0.264874,-0.693951,-0.720022,0,-0.732949,-0.608995,-0.303167,-0.79395,-0.607983,0,-0.705543,-0.06648,-0.705542,-0.636092,-0.436778,-0.636092,-0.514965,-0.68529,-0.514965,-0.489651,-0.721446,-0.489651,-0.560555,-0.609554,-0.560555,-0.381752,-0.066369,-0.921879,-0.344179,-0.43618,-0.831437,-0.278595,-0.684666,-0.673512,-0.264874,-0.720924,-0.640399,-0.303167,-0.608995,-0.732949,0,-0.06624,-0.997804,0,-0.435513,-0.900182,0,-0.683863,-0.729611,0,-0.720022,-0.693951,0,-0.607983,-0.79395,0,-0.06624,-0.997804,0.381752,-0.06637,-0.921879,0.344179,-0.43618,-0.831437,0,-0.435513,-0.900182,0.278594,-0.684666,-0.673512,0,-0.683863,-0.729611,0.264874,-0.720924,-0.640399,0,-0.720022,-0.693951,0.303167,-0.608995,-0.732949,0,-0.607983,-0.79395,0.705542,-0.06648,-0.705543,0.636092,-0.436778,-0.636092,0.514965,-0.68529,-0.514965,0.489651,-0.721446,-0.489651,0.560555,-0.609554,-0.560555,0.921879,-0.066369,-0.381752,0.831437,-0.43618,-0.344179,0.673512,-0.684666,-0.278595,0.640399,-0.720924,-0.264874,0.732949,-0.608995,-0.303167,0.997804,-0.06624,0,0.900182,-0.435513,0,0.729611,-0.683863,0,0.693951,-0.720022,0,0.79395,-0.607983,0,0.79395,-0.607983,0,0.732949,-0.608995,0.303167,0.57623,-0.781801,0.238217,0.62386,-0.781536,0,0.163628,-0.984208,0.067527,0.177291,-0.984159,0,0.045422,-0.998792,0.018736,0.049207,-0.998789,0,0,-1,0,0.560555,-0.609554,0.560555,0.440416,-0.782348,0.440416,0.124903,-0.984276,0.124903,0.034662,-0.998798,0.034662,0,-1,0,0.303167,-0.608995,0.732949,0.238217,-0.781801,0.57623,0.067527,-0.984208,0.163628,0.018736,-0.998792,0.045422,0,-1,0,0,-0.607983,0.79395,0,-0.781536,0.62386,0,-0.984159,0.177291,0,-0.998789,0.049207,0,-1,0,0,-0.607983,0.79395,-0.303167,-0.608995,0.732949,-0.238217,-0.781801,0.57623,0,-0.781536,0.62386,-0.067527,-0.984208,0.163628,0,-0.984159,0.177291,-0.018736,-0.998792,0.045422,0,-0.998789,0.049207,0,-1,0,-0.560555,-0.609554,0.560555,-0.440416,-0.782348,0.440416,-0.124903,-0.984276,0.124903,-0.034662,-0.998798,0.034662,0,-1,0,-0.732949,-0.608995,0.303167,-0.57623,-0.781801,0.238217,-0.163628,-0.984208,0.067527,-0.045422,-0.998792,0.018736,0,-1,0,-0.79395,-0.607983,0,-0.62386,-0.781536,0,-0.177291,-0.984159,0,-0.049207,-0.998789,0,0,-1,0,-0.79395,-0.607983,0,-0.732949,-0.608995,-0.303167,-0.57623,-0.781801,-0.238217,-0.62386,-0.781536,0,-0.163628,-0.984208,-0.067527,-0.177291,-0.984159,0,-0.045422,-0.998792,-0.018736,-0.049207,-0.998789,0,0,-1,0,-0.560555,-0.609554,-0.560555,-0.440416,-0.782348,-0.440416,-0.124903,-0.984276,-0.124903,-0.034662,-0.998798,-0.034662,0,-1,0,-0.303167,-0.608995,-0.732949,-0.238217,-0.781801,-0.57623,-0.067527,-0.984208,-0.163628,-0.018736,-0.998792,-0.045422,0,-1,0,0,-0.607983,-0.79395,0,-0.781536,-0.62386,0,-0.984159,-0.177291,0,-0.998789,-0.049207,0,-1,0,0,-0.607983,-0.79395,0.303167,-0.608995,-0.732949,0.238217,-0.781801,-0.57623,0,-0.781536,-0.62386,0.067527,-0.984208,-0.163628,0,-0.984159,-0.177291,0.018736,-0.998792,-0.045422,0,-0.998789,-0.049207,0,-1,0,0.560555,-0.609554,-0.560555,0.440416,-0.782348,-0.440416,0.124903,-0.984276,-0.124903,0.034662,-0.998798,-0.034662,0,-1,0,0.732949,-0.608995,-0.303167,0.57623,-0.781801,-0.238217,0.163628,-0.984208,-0.067527,0.045422,-0.998792,-0.018736,0,-1,0,0.79395,-0.607983,0,0.62386,-0.781536,0,0.177291,-0.984159,0,0.049207,-0.998789,0,0,-1,0,0.007786,-0.99997,-0.000216,0.007039,-0.812495,0.582926,0.036127,-0.837257,0.545614,0.039138,-0.999233,-0.000989,0.161846,-0.810421,0.563048,0.179512,-0.983746,-0.004369,0.482365,-0.595148,0.642746,0.612299,-0.790557,-0.01046,0.73872,-0.114594,0.664199,0.986152,-0.165708,-0.00667,-0.001909,0.162121,0.986769,0.002762,0.017107,0.99985,0.010533,0.073398,0.997247,-0.066041,0.13007,0.989303,-0.094427,0.016594,0.995393,-0.009203,0.871509,0.490293,-0.048606,0.840609,0.539457,-0.223298,0.80288,0.552739,-0.596365,0.559971,0.575135,-0.803337,0.068236,0.591603,-0.010561,0.999944,0.000103,-0.058798,0.99827,0.00071,-0.28071,0.959787,0.003269,-0.749723,0.661738,0.004268,-0.997351,0.072714,0.002059,-0.010561,0.999944,0.000103,-0.008792,0.871493,-0.49033,-0.046494,0.841178,-0.538756,-0.058798,0.99827,0.00071,-0.217909,0.806807,-0.549161,-0.28071,0.959787,0.003269,-0.597291,0.560026,-0.574121,-0.749723,0.661738,0.004268,-0.804,0.062913,-0.591292,-0.997351,0.072714,0.002059,-0.001806,0.161691,-0.98684,0.002031,0.014555,-0.999892,0.009215,0.060069,-0.998152,-0.059334,0.113865,-0.991723,-0.086899,0.01229,-0.996141,0.006418,-0.812379,-0.583095,0.033783,-0.837512,-0.545373,0.157113,-0.811947,-0.56219,0.484406,-0.589366,-0.646528,0.73887,-0.10132,-0.666187,0.007786,-0.99997,-0.000216,0.039138,-0.999233,-0.000989,0.179512,-0.983746,-0.004369,0.612299,-0.790557,-0.01046,0.986152,-0.165708,-0.00667,0.986152,-0.165708,-0.00667,0.73872,-0.114594,0.664199,0.725608,0.259351,0.637361,0.946512,0.32265,-0.003357,0.645945,0.461988,0.607719,0.82583,0.56387,-0.007452,0.531615,0.63666,0.558614,0.650011,0.759893,-0.006937,0.424964,0.681717,0.59554,0.532429,0.846459,-0.005245,-0.094427,0.016594,0.995393,-0.049562,-0.019755,0.998576,-0.037816,-0.035624,0.99865,-0.037914,-0.036512,0.998614,-0.168854,-0.297945,0.93953,-0.803337,0.068236,0.591603,-0.742342,-0.299166,0.599523,-0.619602,-0.529406,0.579502,-0.483708,-0.68576,0.543837,-0.445293,-0.794355,0.413177,-0.997351,0.072714,0.002059,-0.926513,-0.376258,0.001996,-0.75392,-0.656952,0.004317,-0.566224,-0.824244,0.003461,-0.481804,-0.876277,0.00185,-0.997351,0.072714,0.002059,-0.804,0.062913,-0.591292,-0.744675,-0.294425,-0.598977,-0.926513,-0.376258,0.001996,-0.621949,-0.528114,-0.578165,-0.75392,-0.656952,0.004317,-0.481171,-0.68834,-0.542828,-0.566224,-0.824244,0.003461,-0.438055,-0.797035,-0.415744,-0.481804,-0.876277,0.00185,-0.086899,0.01229,-0.996141,-0.044337,-0.017056,-0.998871,-0.026176,-0.028166,-0.99926,-0.025294,-0.028332,-0.999278,-0.157482,-0.289392,-0.944167,0.73887,-0.10132,-0.666187,0.728244,0.25241,-0.637142,0.647055,0.459725,-0.608254,0.522994,0.640657,-0.56217,0.409978,0.682857,-0.604669,0.986152,-0.165708,-0.00667,0.946512,0.32265,-0.003357,0.82583,0.56387,-0.007452,0.650011,0.759893,-0.006937,0.532429,0.846459,-0.005245,-0.230787,0.972982,-0.006523,-0.152877,0.687211,0.71019,-0.316721,0.63775,0.702113,-0.548936,0.835863,-0.001511,-0.601067,0.471452,0.64533,-0.875671,0.482806,0.009893,-0.635889,0.44609,0.629801,-0.877554,0.479097,0.019092,-0.435746,0.601008,0.670011,-0.69619,0.717439,0.024497,0.111113,-0.08507,0.99016,0.22331,0.00654,0.974726,0.190097,0.154964,0.969458,0.005271,0.189482,0.98187,-0.011752,0.246688,0.969024,0.343906,-0.722796,0.599412,0.572489,-0.567656,0.591627,0.787436,-0.256459,0.560512,0.647097,-0.306374,0.698141,0.427528,-0.499343,0.753576,0.410926,-0.911668,0.001284,0.67152,-0.740986,-0.000899,0.922026,-0.38706,-0.007253,0.84691,-0.531556,-0.013854,0.535924,-0.844201,-0.010505,0.410926,-0.911668,0.001284,0.341188,-0.722823,-0.600931,0.578664,-0.561139,-0.591838,0.67152,-0.740986,-0.000899,0.784869,-0.25102,-0.566542,0.922026,-0.38706,-0.007253,0.642681,-0.302257,-0.70399,0.84691,-0.531556,-0.013854,0.418589,-0.500042,-0.758117,0.535924,-0.844201,-0.010505,0.115806,-0.079139,-0.990114,0.232811,0.012565,-0.972441,0.206662,0.153601,-0.96628,0.0245,0.161443,-0.986578,0.003382,0.211115,-0.977455,-0.134912,0.687491,-0.713551,-0.31954,0.633073,-0.705063,-0.603902,0.461442,-0.649903,-0.631815,0.437169,-0.640072,-0.424306,0.612706,-0.66675,-0.230787,0.972982,-0.006523,-0.548936,0.835863,-0.001511,-0.875671,0.482806,0.009893,-0.877554,0.479097,0.019092,-0.69619,0.717439,0.024497,-0.69619,0.717439,0.024497,-0.435746,0.601008,0.670011,-0.259858,0.791937,0.552548,-0.425801,0.904753,0.010805,0.009539,0.99972,-0.021674,0.022046,0.999756,0.001623,0.410157,0.332912,-0.849082,0.999598,0.025875,0.011556,0.541523,-0.548619,-0.637001,0.709587,-0.704552,0.009672,-0.011752,0.246688,0.969024,0.046311,0.455223,0.889172,-0.010688,0.988794,0.1489,-0.044376,0.682946,-0.72912,0.122824,0.009233,-0.992385,0.427528,-0.499343,0.753576,0.481839,-0.18044,0.85748,0.455272,0.736752,0.499925,-0.220542,0.907193,-0.358277,-0.235919,0.65725,-0.715797,0.535924,-0.844201,-0.010505,0.728094,-0.6853,-0.015585,0.888738,0.458112,-0.016679,-0.260098,0.965582,0.0008,-0.371611,0.928378,-0.004418,0.535924,-0.844201,-0.010505,0.418589,-0.500042,-0.758117,0.480165,-0.178362,-0.858853,0.728094,-0.6853,-0.015585,0.488102,0.716802,-0.497947,0.888738,0.458112,-0.016679,-0.222004,0.905399,0.361892,-0.260098,0.965582,0.0008,-0.235405,0.66318,0.710477,-0.371611,0.928378,-0.004418,0.003382,0.211115,-0.977455,0.05872,0.437702,-0.8972,0.001326,0.986459,-0.164002,-0.04419,0.681675,0.730319,0.138801,-0.034188,0.98973,-0.424306,0.612706,-0.66675,-0.25889,0.797206,-0.54538,0.01227,0.999739,0.019287,0.398632,0.35489,0.845663,0.537564,-0.581398,0.610738,-0.69619,0.717439,0.024497,-0.425801,0.904753,0.010805,0.022046,0.999756,0.001623,0.999598,0.025875,0.011556,0.709587,-0.704552,0.009672,0.76264,0.565035,0.314825,0.82454,0.565804,0.000017,0,1,0,0.847982,-0.397998,0.350034,0.917701,-0.397272,0.000034,0.864141,-0.355261,0.356441,0.935269,-0.353939,0.000113,0.720992,0.625625,0.297933,0.780712,0.62489,0.000075,0.583357,0.565165,0.583338,0,1,0,0.648485,-0.398726,0.648448,0.660872,-0.355894,0.660748,0.551862,0.62529,0.55178,0.314824,0.565051,0.762629,0,1,0,0.350045,-0.397976,0.847988,0.356474,-0.355199,0.864153,0.297983,0.625515,0.721067,-0.000017,0.565804,0.82454,0,1,0,-0.000034,-0.397272,0.917701,-0.000113,-0.353939,0.935269,-0.000075,0.62489,0.780712,-0.314825,0.565035,0.76264,-0.000017,0.565804,0.82454,0,1,0,-0.350034,-0.397998,0.847982,-0.000034,-0.397272,0.917701,-0.356441,-0.355261,0.864141,-0.000113,-0.353939,0.935269,-0.297933,0.625625,0.720992,-0.000075,0.62489,0.780712,-0.583338,0.565165,0.583357,0,1,0,-0.648448,-0.398726,0.648485,-0.660748,-0.355894,0.660872,-0.55178,0.62529,0.551862,-0.762629,0.565051,0.314824,0,1,0,-0.847988,-0.397976,0.350045,-0.864153,-0.355199,0.356474,-0.721067,0.625515,0.297983,-0.82454,0.565804,-0.000017,0,1,0,-0.917701,-0.397272,-0.000034,-0.935269,-0.353939,-0.000113,-0.780712,0.62489,-0.000075,-0.76264,0.565035,-0.314825,-0.82454,0.565804,-0.000017,0,1,0,-0.847982,-0.397998,-0.350034,-0.917701,-0.397272,-0.000034,-0.864141,-0.355261,-0.356441,-0.935269,-0.353939,-0.000113,-0.720992,0.625625,-0.297933,-0.780712,0.62489,-0.000075,-0.583357,0.565165,-0.583338,0,1,0,-0.648485,-0.398726,-0.648448,-0.660872,-0.355894,-0.660748,-0.551862,0.62529,-0.55178,-0.314824,0.565051,-0.762629,0,1,0,-0.350045,-0.397976,-0.847988,-0.356474,-0.355199,-0.864153,-0.297983,0.625515,-0.721067,0.000017,0.565804,-0.82454,0,1,0,0.000034,-0.397272,-0.917701,0.000113,-0.353939,-0.935269,0.000075,0.62489,-0.780712,0.314825,0.565035,-0.76264,0.000017,0.565804,-0.82454,0,1,0,0.350034,-0.397998,-0.847982,0.000034,-0.397272,-0.917701,0.356441,-0.355261,-0.864141,0.000113,-0.353939,-0.935269,0.297933,0.625625,-0.720992,0.000075,0.62489,-0.780712,0.583338,0.565165,-0.583357,0,1,0,0.648448,-0.398726,-0.648485,0.660748,-0.355894,-0.660872,0.55178,0.62529,-0.551862,0.762629,0.565051,-0.314824,0,1,0,0.847988,-0.397976,-0.350045,0.864153,-0.355199,-0.356474,0.721067,0.625515,-0.297983,0.82454,0.565804,0.000017,0,1,0,0.917701,-0.397272,0.000034,0.935269,-0.353939,0.000113,0.780712,0.62489,0.000075,0.780712,0.62489,0.000075,0.720992,0.625625,0.297933,0.217978,0.971775,0.090216,0.236583,0.971611,0,0.159589,0.984977,0.065961,0.173084,0.984907,0,0.350498,0.925311,0.14474,0.379703,0.925108,0,0.48559,0.850653,0.201474,0.526673,0.850068,0,0.551862,0.62529,0.55178,0.166631,0.971838,0.166631,0.121908,0.985026,0.121908,0.267668,0.925585,0.267668,0.371315,0.851029,0.371315,0.297983,0.625515,0.721067,0.090216,0.971775,0.217978,0.065961,0.984977,0.159589,0.14474,0.925311,0.350498,0.201475,0.850653,0.48559,-0.000075,0.62489,0.780712,0,0.971611,0.236583,0,0.984907,0.173084,0,0.925108,0.379703,0,0.850068,0.526673,-0.000075,0.62489,0.780712,-0.297933,0.625625,0.720992,-0.090216,0.971775,0.217978,0,0.971611,0.236583,-0.065961,0.984977,0.159589,0,0.984907,0.173084,-0.14474,0.925311,0.350498,0,0.925108,0.379703,-0.201474,0.850653,0.48559,0,0.850068,0.526673,-0.55178,0.62529,0.551862,-0.166631,0.971838,0.166631,-0.121908,0.985026,0.121908,-0.267668,0.925585,0.267668,-0.371315,0.851029,0.371315,-0.721067,0.625515,0.297983,-0.217978,0.971775,0.090216,-0.159589,0.984977,0.065961,-0.350498,0.925311,0.14474,-0.48559,0.850653,0.201475,-0.780712,0.62489,-0.000075,-0.236583,0.971611,0,-0.173084,0.984907,0,-0.379703,0.925108,0,-0.526673,0.850068,0,-0.780712,0.62489,-0.000075,-0.720992,0.625625,-0.297933,-0.217978,0.971775,-0.090216,-0.236583,0.971611,0,-0.159589,0.984977,-0.065961,-0.173084,0.984907,0,-0.350498,0.925311,-0.14474,-0.379703,0.925108,0,-0.48559,0.850653,-0.201474,-0.526673,0.850068,0,-0.551862,0.62529,-0.55178,-0.166631,0.971838,-0.166631,-0.121908,0.985026,-0.121908,-0.267668,0.925585,-0.267668,-0.371315,0.851029,-0.371315,-0.297983,0.625515,-0.721067,-0.090216,0.971775,-0.217978,-0.065961,0.984977,-0.159589,-0.14474,0.925311,-0.350498,-0.201475,0.850653,-0.48559,0.000075,0.62489,-0.780712,0,0.971611,-0.236583,0,0.984907,-0.173084,0,0.925108,-0.379703,0,0.850068,-0.526673,0.000075,0.62489,-0.780712,0.297933,0.625625,-0.720992,0.090216,0.971775,-0.217978,0,0.971611,-0.236583,0.065961,0.984977,-0.159589,0,0.984907,-0.173084,0.14474,0.925311,-0.350498,0,0.925108,-0.379703,0.201474,0.850653,-0.48559,0,0.850068,-0.526673,0.55178,0.62529,-0.551862,0.166631,0.971838,-0.166631,0.121908,0.985026,-0.121908,0.267668,0.925585,-0.267668,0.371315,0.851029,-0.371315,0.721067,0.625515,-0.297983,0.217978,0.971775,-0.090216,0.159589,0.984977,-0.065961,0.350498,0.925311,-0.14474,0.48559,0.850653,-0.201475,0.780712,0.62489,0.000075,0.236583,0.971611,0,0.173084,0.984907,0,0.379703,0.925108,0,0.526673,0.850068,0],
"texCoords" : [2,2,1.75,2,1.75,1.975,2,1.975,1.75,1.95,2,1.95,1.75,1.925,2,1.925,1.75,1.9,2,1.9,1.5,2,1.5,1.975,1.5,1.95,1.5,1.925,1.5,1.9,1.25,2,1.25,1.975,1.25,1.95,1.25,1.925,1.25,1.9,1,2,1,1.975,1,1.95,1,1.925,1,1.9,1,2,0.75,2,0.75,1.975,1,1.975,0.75,1.95,1,1.95,0.75,1.925,1,1.925,0.75,1.9,1,1.9,0.5,2,0.5,1.975,0.5,1.95,0.5,1.925,0.5,1.9,0.25,2,0.25,1.975,0.25,1.95,0.25,1.925,0.25,1.9,0,2,0,1.975,0,1.95,0,1.925,0,1.9,2,2,1.75,2,1.75,1.975,2,1.975,1.75,1.95,2,1.95,1.75,1.925,2,1.925,1.75,1.9,2,1.9,1.5,2,1.5,1.975,1.5,1.95,1.5,1.925,1.5,1.9,1.25,2,1.25,1.975,1.25,1.95,1.25,1.925,1.25,1.9,1,2,1,1.975,1,1.95,1,1.925,1,1.9,1,2,0.75,2,0.75,1.975,1,1.975,0.75,1.95,1,1.95,0.75,1.925,1,1.925,0.75,1.9,1,1.9,0.5,2,0.5,1.975,0.5,1.95,0.5,1.925,0.5,1.9,0.25,2,0.25,1.975,0.25,1.95,0.25,1.925,0.25,1.9,0,2,0,1.975,0,1.95,0,1.925,0,1.9,2,1.9,1.75,1.9,1.75,1.675,2,1.675,1.75,1.45,2,1.45,1.75,1.225,2,1.225,1.75,1,2,1,1.5,1.9,1.5,1.675,1.5,1.45,1.5,1.225,1.5,1,1.25,1.9,1.25,1.675,1.25,1.45,1.25,1.225,1.25,1,1,1.9,1,1.675,1,1.45,1,1.225,1,1,1,1.9,0.75,1.9,0.75,1.675,1,1.675,0.75,1.45,1,1.45,0.75,1.225,1,1.225,0.75,1,1,1,0.5,1.9,0.5,1.675,0.5,1.45,0.5,1.225,0.5,1,0.25,1.9,0.25,1.675,0.25,1.45,0.25,1.225,0.25,1,0,1.9,0,1.675,0,1.45,0,1.225,0,1,2,1.9,1.75,1.9,1.75,1.675,2,1.675,1.75,1.45,2,1.45,1.75,1.225,2,1.225,1.75,1,2,1,1.5,1.9,1.5,1.675,1.5,1.45,1.5,1.225,1.5,1,1.25,1.9,1.25,1.675,1.25,1.45,1.25,1.225,1.25,1,1,1.9,1,1.675,1,1.45,1,1.225,1,1,1,1.9,0.75,1.9,0.75,1.675,1,1.675,0.75,1.45,1,1.45,0.75,1.225,1,1.225,0.75,1,1,1,0.5,1.9,0.5,1.675,0.5,1.45,0.5,1.225,0.5,1,0.25,1.9,0.25,1.675,0.25,1.45,0.25,1.225,0.25,1,0,1.9,0,1.675,0,1.45,0,1.225,0,1,2,1,1.75,1,1.75,0.85,2,0.85,1.75,0.7,2,0.7,1.75,0.55,2,0.55,1.75,0.4,2,0.4,1.5,1,1.5,0.85,1.5,0.7,1.5,0.55,1.5,0.4,1.25,1,1.25,0.85,1.25,0.7,1.25,0.55,1.25,0.4,1,1,1,0.85,1,0.7,1,0.55,1,0.4,1,1,0.75,1,0.75,0.85,1,0.85,0.75,0.7,1,0.7,0.75,0.55,1,0.55,0.75,0.4,1,0.4,0.5,1,0.5,0.85,0.5,0.7,0.5,0.55,0.5,0.4,0.25,1,0.25,0.85,0.25,0.7,0.25,0.55,0.25,0.4,0,1,0,0.85,0,0.7,0,0.55,0,0.4,2,1,1.75,1,1.75,0.85,2,0.85,1.75,0.7,2,0.7,1.75,0.55,2,0.55,1.75,0.4,2,0.4,1.5,1,1.5,0.85,1.5,0.7,1.5,0.55,1.5,0.4,1.25,1,1.25,0.85,1.25,0.7,1.25,0.55,1.25,0.4,1,1,1,0.85,1,0.7,1,0.55,1,0.4,1,1,0.75,1,0.75,0.85,1,0.85,0.75,0.7,1,0.7,0.75,0.55,1,0.55,0.75,0.4,1,0.4,0.5,1,0.5,0.85,0.5,0.7,0.5,0.55,0.5,0.4,0.25,1,0.25,0.85,0.25,0.7,0.25,0.55,0.25,0.4,0,1,0,0.85,0,0.7,0,0.55,0,0.4,2,0.4,1.75,0.4,1.75,0.3,2,0.3,1.75,0.2,2,0.2,1.75,0.1,2,0.1,1.75,0,1.5,0.4,1.5,0.3,1.5,0.2,1.5,0.1,1.5,0,1.25,0.4,1.25,0.3,1.25,0.2,1.25,0.1,1.25,0,1,0.4,1,0.3,1,0.2,1,0.1,1,0,1,0.4,0.75,0.4,0.75,0.3,1,0.3,0.75,0.2,1,0.2,0.75,0.1,1,0.1,0.75,0,0.5,0.4,0.5,0.3,0.5,0.2,0.5,0.1,0.5,0,0.25,0.4,0.25,0.3,0.25,0.2,0.25,0.1,0.25,0,0,0.4,0,0.3,0,0.2,0,0.1,0,0,2,0.4,1.75,0.4,1.75,0.3,2,0.3,1.75,0.2,2,0.2,1.75,0.1,2,0.1,1.75,0,1.5,0.4,1.5,0.3,1.5,0.2,1.5,0.1,1.5,0,1.25,0.4,1.25,0.3,1.25,0.2,1.25,0.1,1.25,0,1,0.4,1,0.3,1,0.2,1,0.1,1,0,1,0.4,0.75,0.4,0.75,0.3,1,0.3,0.75,0.2,1,0.2,0.75,0.1,1,0.1,0.75,0,0.5,0.4,0.5,0.3,0.5,0.2,0.5,0.1,0.5,0,0.25,0.4,0.25,0.3,0.25,0.2,0.25,0.1,0.25,0,0,0.4,0,0.3,0,0.2,0,0.1,0,0,1,1,0.875,1,0.875,0.875,1,0.875,0.875,0.75,1,0.75,0.875,0.625,1,0.625,0.875,0.5,1,0.5,0.75,1,0.75,0.875,0.75,0.75,0.75,0.625,0.75,0.5,0.625,1,0.625,0.875,0.625,0.75,0.625,0.625,0.625,0.5,0.5,1,0.5,0.875,0.5,0.75,0.5,0.625,0.5,0.5,0.5,1,0.375,1,0.375,0.875,0.5,0.875,0.375,0.75,0.5,0.75,0.375,0.625,0.5,0.625,0.375,0.5,0.5,0.5,0.25,1,0.25,0.875,0.25,0.75,0.25,0.625,0.25,0.5,0.125,1,0.125,0.875,0.125,0.75,0.125,0.625,0.125,0.5,0,1,0,0.875,0,0.75,0,0.625,0,0.5,1,0.5,0.875,0.5,0.875,0.375,1,0.375,0.875,0.25,1,0.25,0.875,0.125,1,0.125,0.875,0,1,0,0.75,0.5,0.75,0.375,0.75,0.25,0.75,0.125,0.75,0,0.625,0.5,0.625,0.375,0.625,0.25,0.625,0.125,0.625,0,0.5,0.5,0.5,0.375,0.5,0.25,0.5,0.125,0.5,0,0.5,0.5,0.375,0.5,0.375,0.375,0.5,0.375,0.375,0.25,0.5,0.25,0.375,0.125,0.5,0.125,0.375,0,0.5,0,0.25,0.5,0.25,0.375,0.25,0.25,0.25,0.125,0.25,0,0.125,0.5,0.125,0.375,0.125,0.25,0.125,0.125,0.125,0,0,0.5,0,0.375,0,0.25,0,0.125,0,0,0.5,0,0.625,0,0.625,0.225,0.5,0.225,0.625,0.45,0.5,0.45,0.625,0.675,0.5,0.675,0.625,0.9,0.5,0.9,0.75,0,0.75,0.225,0.75,0.45,0.75,0.675,0.75,0.9,0.875,0,0.875,0.225,0.875,0.45,0.875,0.675,0.875,0.9,1,0,1,0.225,1,0.45,1,0.675,1,0.9,0,0,0.125,0,0.125,0.225,0,0.225,0.125,0.45,0,0.45,0.125,0.675,0,0.675,0.125,0.9,0,0.9,0.25,0,0.25,0.225,0.25,0.45,0.25,0.675,0.25,0.9,0.375,0,0.375,0.225,0.375,0.45,0.375,0.675,0.375,0.9,0.5,0,0.5,0.225,0.5,0.45,0.5,0.675,0.5,0.9,0.5,0.9,0.625,0.9,0.625,0.925,0.5,0.925,0.625,0.95,0.5,0.95,0.625,0.975,0.5,0.975,0.625,1,0.5,1,0.75,0.9,0.75,0.925,0.75,0.95,0.75,0.975,0.75,1,0.875,0.9,0.875,0.925,0.875,0.95,0.875,0.975,0.875,1,1,0.9,1,0.925,1,0.95,1,0.975,1,1,0,0.9,0.125,0.9,0.125,0.925,0,0.925,0.125,0.95,0,0.95,0.125,0.975,0,0.975,0.125,1,0,1,0.25,0.9,0.25,0.925,0.25,0.95,0.25,0.975,0.25,1,0.375,0.9,0.375,0.925,0.375,0.95,0.375,0.975,0.375,1,0.5,0.9,0.5,0.925,0.5,0.95,0.5,0.975,0.5,1,0.875,0.75,1,0.75,1,1,0.875,0.5,1,0.5,0.875,0.25,1,0.25,0.875,0,1,0,0.75,0.75,0.875,1,0.75,0.5,0.75,0.25,0.75,0,0.625,0.75,0.75,1,0.625,0.5,0.625,0.25,0.625,0,0.5,0.75,0.625,1,0.5,0.5,0.5,0.25,0.5,0,0.375,0.75,0.5,0.75,0.5,1,0.375,0.5,0.5,0.5,0.375,0.25,0.5,0.25,0.375,0,0.5,0,0.25,0.75,0.375,1,0.25,0.5,0.25,0.25,0.25,0,0.125,0.75,0.25,1,0.125,0.5,0.125,0.25,0.125,0,0,0.75,0.125,1,0,0.5,0,0.25,0,0,0.875,0.75,1,0.75,1,1,0.875,0.5,1,0.5,0.875,0.25,1,0.25,0.875,0,1,0,0.75,0.75,0.875,1,0.75,0.5,0.75,0.25,0.75,0,0.625,0.75,0.75,1,0.625,0.5,0.625,0.25,0.625,0,0.5,0.75,0.625,1,0.5,0.5,0.5,0.25,0.5,0,0.375,0.75,0.5,0.75,0.5,1,0.375,0.5,0.5,0.5,0.375,0.25,0.5,0.25,0.375,0,0.5,0,0.25,0.75,0.375,1,0.25,0.5,0.25,0.25,0.25,0,0.125,0.75,0.25,1,0.125,0.5,0.125,0.25,0.125,0,0,0.75,0.125,1,0,0.5,0,0.25,0,0,1,1,0.875,1,0.875,0.75,1,0.75,0.875,0.5,1,0.5,0.875,0.25,1,0.25,0.875,0,1,0,0.75,1,0.75,0.75,0.75,0.5,0.75,0.25,0.75,0,0.625,1,0.625,0.75,0.625,0.5,0.625,0.25,0.625,0,0.5,1,0.5,0.75,0.5,0.5,0.5,0.25,0.5,0,0.5,1,0.375,1,0.375,0.75,0.5,0.75,0.375,0.5,0.5,0.5,0.375,0.25,0.5,0.25,0.375,0,0.5,0,0.25,1,0.25,0.75,0.25,0.5,0.25,0.25,0.25,0,0.125,1,0.125,0.75,0.125,0.5,0.125,0.25,0.125,0,0,1,0,0.75,0,0.5,0,0.25,0,0,1,1,0.875,1,0.875,0.75,1,0.75,0.875,0.5,1,0.5,0.875,0.25,1,0.25,0.875,0,1,0,0.75,1,0.75,0.75,0.75,0.5,0.75,0.25,0.75,0,0.625,1,0.625,0.75,0.625,0.5,0.625,0.25,0.625,0,0.5,1,0.5,0.75,0.5,0.5,0.5,0.25,0.5,0,0.5,1,0.375,1,0.375,0.75,0.5,0.75,0.375,0.5,0.5,0.5,0.375,0.25,0.5,0.25,0.375,0,0.5,0,0.25,1,0.25,0.75,0.25,0.5,0.25,0.25,0.25,0,0.125,1,0.125,0.75,0.125,0.5,0.125,0.25,0.125,0,0,1,0,0.75,0,0.5,0,0.25,0,0],
"indices" : [0,1,2,2,3,0,3,2,4,4,5,3,5,4,6,6,7,5,7,6,8,8,9,7,1,10,11,11,2,1,2,11,12,12,4,2,4,12,13,13,6,4,6,13,14,14,8,6,10,15,16,16,11,10,11,16,17,17,12,11,12,17,18,18,13,12,13,18,19,19,14,13,15,20,21,21,16,15,16,21,22,22,17,16,17,22,23,23,18,17,18,23,24,24,19,18,25,26,27,27,28,25,28,27,29,29,30,28,30,29,31,31,32,30,32,31,33,33,34,32,26,35,36,36,27,26,27,36,37,37,29,27,29,37,38,38,31,29,31,38,39,39,33,31,35,40,41,41,36,35,36,41,42,42,37,36,37,42,43,43,38,37,38,43,44,44,39,38,40,45,46,46,41,40,41,46,47,47,42,41,42,47,48,48,43,42,43,48,49,49,44,43,50,51,52,52,53,50,53,52,54,54,55,53,55,54,56,56,57,55,57,56,58,58,59,57,51,60,61,61,52,51,52,61,62,62,54,52,54,62,63,63,56,54,56,63,64,64,58,56,60,65,66,66,61,60,61,66,67,67,62,61,62,67,68,68,63,62,63,68,69,69,64,63,65,70,71,71,66,65,66,71,72,72,67,66,67,72,73,73,68,67,68,73,74,74,69,68,75,76,77,77,78,75,78,77,79,79,80,78,80,79,81,81,82,80,82,81,83,83,84,82,76,85,86,86,77,76,77,86,87,87,79,77,79,87,88,88,81,79,81,88,89,89,83,81,85,90,91,91,86,85,86,91,92,92,87,86,87,92,93,93,88,87,88,93,94,94,89,88,90,95,96,96,91,90,91,96,97,97,92,91,92,97,98,98,93,92,93,98,99,99,94,93,100,101,102,102,103,100,103,102,104,104,105,103,105,104,106,106,107,105,107,106,108,108,109,107,101,110,111,111,102,101,102,111,112,112,104,102,104,112,113,113,106,104,106,113,114,114,108,106,110,115,116,116,111,110,111,116,117,117,112,111,112,117,118,118,113,112,113,118,119,119,114,113,115,120,121,121,116,115,116,121,122,122,117,116,117,122,123,123,118,117,118,123,124,124,119,118,125,126,127,127,128,125,128,127,129,129,130,128,130,129,131,131,132,130,132,131,133,133,134,132,126,135,136,136,127,126,127,136,137,137,129,127,129,137,138,138,131,129,131,138,139,139,133,131,135,140,141,141,136,135,136,141,142,142,137,136,137,142,143,143,138,137,138,143,144,144,139,138,140,145,146,146,141,140,141,146,147,147,142,141,142,147,148,148,143,142,143,148,149,149,144,143,150,151,152,152,153,150,153,152,154,154,155,153,155,154,156,156,157,155,157,156,158,158,159,157,151,160,161,161,152,151,152,161,162,162,154,152,154,162,163,163,156,154,156,163,164,164,158,156,160,165,166,166,161,160,161,166,167,167,162,161,162,167,168,168,163,162,163,168,169,169,164,163,165,170,171,171,166,165,166,171,172,172,167,166,167,172,173,173,168,167,168,173,174,174,169,168,175,176,177,177,178,175,178,177,179,179,180,178,180,179,181,181,182,180,182,181,183,183,184,182,176,185,186,186,177,176,177,186,187,187,179,177,179,187,188,188,181,179,181,188,189,189,183,181,185,190,191,191,186,185,186,191,192,192,187,186,187,192,193,193,188,187,188,193,194,194,189,188,190,195,196,196,191,190,191,196,197,197,192,191,192,197,198,198,193,192,193,198,199,199,194,193,200,201,202,202,203,200,203,202,204,204,205,203,205,204,206,206,207,205,207,206,208,208,209,207,201,210,211,211,202,201,202,211,212,212,204,202,204,212,213,213,206,204,206,213,214,214,208,206,210,215,216,216,211,210,211,216,217,217,212,211,212,217,218,218,213,212,213,218,219,219,214,213,215,220,221,221,216,215,216,221,222,222,217,216,217,222,223,223,218,217,218,223,224,224,219,218,225,226,227,227,228,225,228,227,229,229,230,228,230,229,231,231,232,230,232,231,233,233,234,232,226,235,236,236,227,226,227,236,237,237,229,227,229,237,238,238,231,229,231,238,239,239,233,231,235,240,241,241,236,235,236,241,242,242,237,236,237,242,243,243,238,237,238,243,244,244,239,238,240,245,246,246,241,240,241,246,247,247,242,241,242,247,248,248,243,242,243,248,249,249,244,243,250,251,252,252,253,250,253,252,254,254,255,253,255,254,256,256,257,255,257,256,258,258,259,257,251,260,261,261,252,251,252,261,262,262,254,252,254,262,263,263,256,254,256,263,264,264,258,256,260,265,266,266,261,260,261,266,267,267,262,261,262,267,268,268,263,262,263,268,269,269,264,263,265,270,271,271,266,265,266,271,272,272,267,266,267,272,273,273,268,267,268,273,274,274,269,268,275,276,277,277,278,275,278,277,279,279,280,278,280,279,281,281,282,280,282,281,283,283,284,282,276,285,286,286,277,276,277,286,287,287,279,277,279,287,288,288,281,279,281,288,289,289,283,281,285,290,291,291,286,285,286,291,292,292,287,286,287,292,293,293,288,287,288,293,294,294,289,288,290,295,296,296,291,290,291,296,297,297,292,291,292,297,298,298,293,292,293,298,299,299,294,293,300,301,302,302,303,300,303,302,304,304,305,303,305,304,306,306,307,305,307,306,308,301,309,310,310,302,301,302,310,311,311,304,302,304,311,312,312,306,304,306,312,313,309,314,315,315,310,309,310,315,316,316,311,310,311,316,317,317,312,311,312,317,318,314,319,320,320,315,314,315,320,321,321,316,315,316,321,322,322,317,316,317,322,323,324,325,326,326,327,324,327,326,328,328,329,327,329,328,330,330,331,329,331,330,332,325,333,334,334,326,325,326,334,335,335,328,326,328,335,336,336,330,328,330,336,337,333,338,339,339,334,333,334,339,340,340,335,334,335,340,341,341,336,335,336,341,342,338,343,344,344,339,338,339,344,345,345,340,339,340,345,346,346,341,340,341,346,347,348,349,350,350,351,348,351,350,352,352,353,351,353,352,354,354,355,353,355,354,356,349,357,358,358,350,349,350,358,359,359,352,350,352,359,360,360,354,352,354,360,361,357,362,363,363,358,357,358,363,364,364,359,358,359,364,365,365,360,359,360,365,366,362,367,368,368,363,362,363,368,369,369,364,363,364,369,370,370,365,364,365,370,371,372,373,374,374,375,372,375,374,376,376,377,375,377,376,378,378,379,377,379,378,380,373,381,382,382,374,373,374,382,383,383,376,374,376,383,384,384,378,376,378,384,385,381,386,387,387,382,381,382,387,388,388,383,382,383,388,389,389,384,383,384,389,390,386,391,392,392,387,386,387,392,393,393,388,387,388,393,394,394,389,388,389,394,395,396,397,398,398,399,396,399,398,400,400,401,399,401,400,402,402,403,401,403,402,404,404,405,403,397,406,407,407,398,397,398,407,408,408,400,398,400,408,409,409,402,400,402,409,410,410,404,402,406,411,412,412,407,406,407,412,413,413,408,407,408,413,414,414,409,408,409,414,415,415,410,409,411,416,417,417,412,411,412,417,418,418,413,412,413,418,419,419,414,413,414,419,420,420,415,414,421,422,423,423,424,421,424,423,425,425,426,424,426,425,427,427,428,426,428,427,429,429,430,428,422,431,432,432,423,422,423,432,433,433,425,423,425,433,434,434,427,425,427,434,435,435,429,427,431,436,437,437,432,431,432,437,438,438,433,432,433,438,439,439,434,433,434,439,440,440,435,434,436,441,442,442,437,436,437,442,443,443,438,437,438,443,444,444,439,438,439,444,445,445,440,439,446,447,448,448,449,446,449,448,450,450,451,449,451,450,452,452,453,451,453,452,454,454,455,453,447,456,457,457,448,447,448,457,458,458,450,448,450,458,459,459,452,450,452,459,460,460,454,452,456,461,462,462,457,456,457,462,463,463,458,457,458,463,464,464,459,458,459,464,465,465,460,459,461,466,467,467,462,461,462,467,468,468,463,462,463,468,469,469,464,463,464,469,470,470,465,464,471,472,473,473,474,471,474,473,475,475,476,474,476,475,477,477,478,476,478,477,479,479,480,478,472,481,482,482,473,472,473,482,483,483,475,473,475,483,484,484,477,475,477,484,485,485,479,477,481,486,487,487,482,481,482,487,488,488,483,482,483,488,489,489,484,483,484,489,490,490,485,484,486,491,492,492,487,486,487,492,493,493,488,487,488,493,494,494,489,488,489,494,495,495,490,489,496,497,498,498,499,496,499,498,500,500,501,499,501,500,502,502,503,501,503,502,504,504,505,503,497,506,507,507,498,497,498,507,508,508,500,498,500,508,509,509,502,500,502,509,510,510,504,502,506,511,512,512,507,506,507,512,513,513,508,507,508,513,514,514,509,508,509,514,515,515,510,509,511,516,517,517,512,511,512,517,518,518,513,512,513,518,519,519,514,513,514,519,520,520,515,514,521,522,523,523,524,521,524,523,525,525,526,524,526,525,527,527,528,526,528,527,529,529,530,528,522,531,532,532,523,522,523,532,533,533,525,523,525,533,534,534,527,525,527,534,535,535,529,527,531,536,537,537,532,531,532,537,538,538,533,532,533,538,539,539,534,533,534,539,540,540,535,534,536,541,542,542,537,536,537,542,543,543,538,537,538,543,544,544,539,538,539,544,545,545,540,539,546,547,548,548,549,546,549,548,550,550,551,549,551,550,552,552,553,551,553,552,554,554,555,553,547,556,557,557,548,547,548,557,558,558,550,548,550,558,559,559,552,550,552,559,560,560,554,552,556,561,562,562,557,556,557,562,563,563,558,557,558,563,564,564,559,558,559,564,565,565,560,559,561,566,567,567,562,561,562,567,568,568,563,562,563,568,569,569,564,563,564,569,570,570,565,564,571,572,573,573,574,571,574,573,575,575,576,574,576,575,577,577,578,576,578,577,579,579,580,578,572,581,582,582,573,572,573,582,583,583,575,573,575,583,584,584,577,575,577,584,585,585,579,577,581,586,587,587,582,581,582,587,588,588,583,582,583,588,589,589,584,583,584,589,590,590,585,584,586,591,592,592,587,586,587,592,593,593,588,587,588,593,594,594,589,588,589,594,595,595,590,589,596,597,598,597,596,599,599,600,597,600,599,601,601,602,600,602,601,603,603,604,602,605,596,606,596,605,607,607,599,596,599,607,608,608,601,599,601,608,609,609,603,601,610,605,611,605,610,612,612,607,605,607,612,613,613,608,607,608,613,614,614,609,608,615,610,616,610,615,617,617,612,610,612,617,618,618,613,612,613,618,619,619,614,613,620,621,622,621,620,623,623,624,621,624,623,625,625,626,624,626,625,627,627,628,626,629,620,630,620,629,631,631,623,620,623,631,632,632,625,623,625,632,633,633,627,625,634,629,635,629,634,636,636,631,629,631,636,637,637,632,631,632,637,638,638,633,632,639,634,640,634,639,641,641,636,634,636,641,642,642,637,636,637,642,643,643,638,637,644,645,646,645,644,647,647,648,645,648,647,649,649,650,648,650,649,651,651,652,650,653,644,654,644,653,655,655,647,644,647,655,656,656,649,647,649,656,657,657,651,649,658,653,659,653,658,660,660,655,653,655,660,661,661,656,655,656,661,662,662,657,656,663,658,664,658,663,665,665,660,658,660,665,666,666,661,660,661,666,667,667,662,661,668,669,670,669,668,671,671,672,669,672,671,673,673,674,672,674,673,675,675,676,674,677,668,678,668,677,679,679,671,668,671,679,680,680,673,671,673,680,681,681,675,673,682,677,683,677,682,684,684,679,677,679,684,685,685,680,679,680,685,686,686,681,680,687,682,688,682,687,689,689,684,682,684,689,690,690,685,684,685,690,691,691,686,685,692,693,694,694,695,692,695,694,696,696,697,695,697,696,698,698,699,697,699,698,700,700,701,699,693,702,703,703,694,693,694,703,704,704,696,694,696,704,705,705,698,696,698,705,706,706,700,698,702,707,708,708,703,702,703,708,709,709,704,703,704,709,710,710,705,704,705,710,711,711,706,705,707,712,713,713,708,707,708,713,714,714,709,708,709,714,715,715,710,709,710,715,716,716,711,710,717,718,719,719,720,717,720,719,721,721,722,720,722,721,723,723,724,722,724,723,725,725,726,724,718,727,728,728,719,718,719,728,729,729,721,719,721,729,730,730,723,721,723,730,731,731,725,723,727,732,733,733,728,727,728,733,734,734,729,728,729,734,735,735,730,729,730,735,736,736,731,730,732,737,738,738,733,732,733,738,739,739,734,733,734,739,740,740,735,734,735,740,741,741,736,735,742,743,744,744,745,742,745,744,746,746,747,745,747,746,748,748,749,747,749,748,750,750,751,749,743,752,753,753,744,743,744,753,754,754,746,744,746,754,755,755,748,746,748,755,756,756,750,748,752,757,758,758,753,752,753,758,759,759,754,753,754,759,760,760,755,754,755,760,761,761,756,755,757,762,763,763,758,757,758,763,764,764,759,758,759,764,765,765,760,759,760,765,766,766,761,760,767,768,769,769,770,767,770,769,771,771,772,770,772,771,773,773,774,772,774,773,775,775,776,774,768,777,778,778,769,768,769,778,779,779,771,769,771,779,780,780,773,771,773,780,781,781,775,773,777,782,783,783,778,777,778,783,784,784,779,778,779,784,785,785,780,779,780,785,786,786,781,780,782,787,788,788,783,782,783,788,789,789,784,783,784,789,790,790,785,784,785,790,791,791,786,785]
}
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/14/app.js
|
import GL from '@luma.gl/constants';
import {
AnimationLoop,
Geometry,
Texture2D,
setParameters
} from '@luma.gl/core';
import {Matrix4, radians} from 'math.gl';
import { ModelNode } from '@luma.gl/experimental';
import { loadFile } from '@luma.gl/webgl';
const INFO_HTML = `
<p>
<a href="http://learningwebgl.com/blog/?p=1658" target="_blank">
Specular highlights and loading a JSON model
</a>
<p>
The classic WebGL Lessons in luma.gl
<div id="control-elements">
<input type="checkbox" id="specular" checked/> Show specular highlight<br/>
<input type="checkbox" id="lighting" checked/> Use lighting<br/>
Texture:
<select id="texture">
<option value="none">None</option>
<option selected value="galvanized">Galvanized</option>
<option value="earth">Earth</option>
</select>
<br/>
<h2>Material:</h2>
<div class="control-block">
<div class="control-row">
<div><b>Shininess:</b></div>
<input id="shininess" type="range" value="32.0" min="0.0" max="100.0" step="1"/>
</div>
</div>
<h2>Point light:</h2>
<div class="control-block">
<div class="control-row">
<div><b>Location:</b></div>
<div>X: <input type="text" id="lightPositionX" value="-10.0"/></div>
<div>Y: <input type="text" id="lightPositionY" value="4.0"/></div>
<div>Z: <input type="text" id="lightPositionZ" value="-20.0"/></div>
</div>
<div class="control-row">
<div><b>Specular colour:</b></div>
<div>R:
<input id="specularR" type="range" value="0.8" min="0.0" max="1.0" step="0.01"/>
</div>
<div>G:
<input id="specularG" type="range" value="0.8" min="0.0" max="1.0" step="0.01"/>
</div>
<div>B:
<input id="specularB" type="range" value="0.8" min="0.0" max="1.0" step="0.01"/>
</div>
</div>
<div class="control-row">
<div><b>Diffuse colour:</b></div>
<div>R:
<input id="diffuseR" type="range" value="0.8" min="0.0" max="1.0" step="0.01"/>
</div>
<div>G:
<input id="diffuseG" type="range" value="0.8" min="0.0" max="1.0" step="0.01"/>
</div>
<div>B:
<input id="diffuseB" type="range" value="0.8" min="0.0" max="1.0" step="0.01"/>
</div>
</div>
</div>
<h2>Ambient light:</h2>
<div class="control-block">
<div class="control-row">
<div><b>Colour:</b></div>
<div>R:
<input id="ambientR" type="range" value="0.2" min="0.0" max="1.0" step="0.01"/>
</div>
<div>G:
<input id="ambientG" type="range" value="0.2" min="0.0" max="1.0" step="0.01"/>
</div>
<div>B:
<input id="ambientB" type="range" value="0.2" min="0.0" max="1.0" step="0.01"/>
</div>
</div>
</div>
<br/>
Galvanized texture courtesy of
<a href="http://www.arroway-textures.com/">Arroway Textures</a>.<br/>
Earth texture courtesy of
<a href="http://www.esa.int/esaEO/SEMGSY2IU7E_index_0.html">
the European Space Agency/Envisat
</a>.<br/>
<br/>
The classic WebGL Lessons in luma.gl
</div>
`;
// Read Lighting form elements variables
function getHTMLControls() {
/* global document */
const $id = id => document.getElementById(id);
const $value = (id, defaultValue = 1) => ($id(id) ? Number($id(id).value) : defaultValue);
const $checked = id => ($id(id) ? $id(id).checked : true);
// Get lighting form elements
// const useLighting = lighting.checked;
// const useSpecular = specular.checked;
// const materialShininess = shininess.value;
// Get lighting form elements
const useSpecular = $checked('specular');
const useLighting = $checked('lighting');
const useTextures = $value('texture', 'none') !== 'none';
const shininess = $value('shininess');
const pointLightPosition = [
$value('lightPositionX', -10),
$value('lightPositionY', 4),
$value('lightPositionZ', -20)
];
const pointLightSpecularColor = [
$value('specularR', 0.8),
$value('specularG', 0.8),
$value('specularB', 0.8)
];
const pointLightDiffuseColor = [
$value('diffuseR', 0.8),
$value('diffuseG', 0.8),
$value('diffuseB', 0.8)
];
const ambientColor = [$value('ambientR', 0.2), $value('ambientG', 0.2), $value('ambientB', 0.2)];
return {
useLighting,
useSpecular,
useTextures,
shininess,
texture: $value('texture'),
ambientColor,
pointLightPosition,
pointLightSpecularColor,
pointLightDiffuseColor
};
}
const FRAGMENT_LIGHTING_VERTEX_SHADER = `\
precision highp float;
attribute vec3 positions;
attribute vec3 normals;
attribute vec2 texCoords;
uniform mat4 uMMatrix;
uniform mat4 uVMatrix;
uniform mat4 uPMatrix;
varying vec2 vTextureCoord;
varying vec4 vTransformedNormal;
varying vec4 vPosition;
void main(void) {
vPosition = uMMatrix * vec4(positions, 1.0);
gl_Position = uPMatrix * uVMatrix * vPosition;
vTextureCoord = texCoords;
vTransformedNormal = uMMatrix * vec4(normals, 0.0);
}
`;
const FRAGMENT_LIGHTING_FRAGMENT_SHADER = `\
precision highp float;
varying vec2 vTextureCoord;
varying vec4 vTransformedNormal;
varying vec4 vPosition;
uniform float uMaterialShininess;
uniform bool uShowSpecularHighlights;
uniform bool uUseLighting;
uniform bool uUseTextures;
uniform vec3 uAmbientColor;
uniform vec3 uPointLightingLocation;
uniform vec3 uPointLightingSpecularColor;
uniform vec3 uPointLightingDiffuseColor;
uniform sampler2D uSampler;
void main(void) {
vec3 lightWeighting;
if (!uUseLighting) {
lightWeighting = vec3(1.0, 1.0, 1.0);
} else {
vec3 lightDirection = normalize(uPointLightingLocation - vPosition.xyz);
vec3 normal = normalize(vTransformedNormal.xyz);
float specularLightWeighting = 0.0;
if (uShowSpecularHighlights) {
vec3 eyeDirection = normalize(-vPosition.xyz);
vec3 reflectionDirection = reflect(-lightDirection, normal);
specularLightWeighting =
pow(max(dot(reflectionDirection, eyeDirection), 0.0), uMaterialShininess);
}
float diffuseLightWeighting = max(dot(normal, lightDirection), 0.0);
lightWeighting = uAmbientColor
+ uPointLightingSpecularColor * specularLightWeighting
+ uPointLightingDiffuseColor * diffuseLightWeighting;
}
vec4 fragmentColor;
if (uUseTextures) {
fragmentColor = texture2D(uSampler, vec2(vTextureCoord.s, vTextureCoord.t));
} else {
fragmentColor = vec4(1.0, 1.0, 1.0, 1.0);
}
gl_FragColor = vec4(fragmentColor.rgb * lightWeighting, fragmentColor.a);
}
`;
const TEAPOT_UNIFORMS = {
uMaterialShininess: 20.0,
uShowSpecularHighlights: true,
uUseLighting: true,
uUseTextures: true
};
const LIGHT_UNIFORMS = {
uAmbientColor: [0.2, 0.2, 0.2],
uPointLightingLocation: [-10.0, 4.0, -20.0],
uPointLightingSpecularColor: [0.8, 0.8, 0.8],
uPointLightingDiffuseColor: [0.8, 0.8, 0.8]
};
export default class AppAnimationLoop extends AnimationLoop {
static getInfo() {
return INFO_HTML;
}
onInitialize({gl}) {
setParameters(gl, {
clearColor: [0, 0, 0, 1],
clearDepth: 1,
depthTest: true,
[GL.UNPACK_FLIP_Y_WEBGL]: true
});
return loadFile('Teapot.json').then(file => {
const teapotJson = JSON.parse(file);
const galvanizedTexture = new Texture2D(gl, {
data: 'arroway.de_metal+structure+06_d100_flat.jpg',
parameters: {
[gl.TEXTURE_MAG_FILTER]: gl.LINEAR,
[gl.TEXTURE_MIN_FILTER]: gl.LINEAR_MIPMAP_NEAREST,
[gl.TEXTURE_WRAP_S]: gl.REPEAT,
[gl.TEXTURE_WRAP_T]: gl.REPEAT
},
mipmap: true
});
const earthTexture = new Texture2D(gl, {
urls: 'earth.jpg',
parameters: {
[gl.TEXTURE_MAG_FILTER]: gl.LINEAR,
[gl.TEXTURE_MIN_FILTER]: gl.LINEAR_MIPMAP_NEAREST,
[gl.TEXTURE_WRAP_S]: gl.REPEAT,
[gl.TEXTURE_WRAP_T]: gl.REPEAT
},
mipmap: true
});
const teapot = new ModelNode(gl, {
id: 'teapot-model',
fs: FRAGMENT_LIGHTING_FRAGMENT_SHADER,
vs: FRAGMENT_LIGHTING_VERTEX_SHADER,
geometry: new Geometry({
id: 'teapot-geometry',
attributes: {
positions: new Float32Array(teapotJson.positions),
normals: new Float32Array(teapotJson.normals),
texCoords: new Float32Array(teapotJson.texCoords),
indices: new Uint16Array(teapotJson.indices)
},
drawMode: GL.TRIANGLES
}),
uniforms: Object.assign({uSampler: galvanizedTexture}, TEAPOT_UNIFORMS, LIGHT_UNIFORMS)
});
return {teapot, earthTexture, galvanizedTexture};
});
}
onRender({gl, tick, aspect, teapot, earthTexture, galvanizedTexture}) {
gl.clear(GL.COLOR_BUFFER_BIT | GL.DEPTH_BUFFER_BIT);
// set camera position
// const eyePos = new Matrix4().rotateX(radians(-30)).transformVector3([0, 0, 5]);
const eyePos = new Matrix4().rotateX(radians(-30)).transform([0, 0, 5]);
const uVMatrix = new Matrix4().lookAt({eye: eyePos, center: [0, 0, 0], up: [0, 1, 0]});
const {
useLighting,
useSpecular,
useTextures,
texture,
shininess,
ambientColor,
pointLightPosition,
pointLightSpecularColor,
pointLightDiffuseColor
} = getHTMLControls();
teapot.setUniforms({
uUseLighting: useLighting,
uUseTextures: useTextures,
uShowSpecularHighlights: useSpecular,
uMaterialShininess: shininess
});
if (useLighting) {
teapot.setUniforms({
uAmbientColor: ambientColor,
uPointLightingLocation: pointLightPosition,
uPointLightingSpecularColor: pointLightSpecularColor,
uPointLightingDiffuseColor: pointLightDiffuseColor
});
}
if (useTextures) {
const selectedTexture = texture;
teapot.setUniforms({
uSampler: selectedTexture === 'earth' ? earthTexture : galvanizedTexture
});
}
const phi = tick * 0.01;
return teapot
.setUniforms({
uMMatrix: new Matrix4().translate([0, -35, -68]).rotateY(phi),
uVMatrix,
uPMatrix: new Matrix4().perspective({
fov: (45 * Math.PI) / 180,
aspect,
near: 0.1,
far: 100
})
})
.draw();
}
}
/* global window */
if (typeof window !== 'undefined' && !window.website) {
const animationLoop = new AppAnimationLoop();
animationLoop.start();
}
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/08/package.json
|
{
"version": "0.0.1",
"private": true,
"name": "@rapidsai/demo-luma.gl-lessons-08",
"scripts": {
"start": "webpack-dev-server --progress --hot --open -d",
"start-local": "webpack-dev-server --env.local --progress --hot --open -d"
},
"dependencies": {
"@loaders.gl/images": "3.2.9",
"@luma.gl/constants": "8.5.16",
"@luma.gl/core": "8.5.16",
"@luma.gl/experimental": "8.5.16",
"@luma.gl/shadertools": "8.5.16",
"math.gl": "3.6.3"
}
}
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/08/app.js
|
/* eslint-disable max-statements, array-bracket-spacing, no-multi-spaces */
import GL from '@luma.gl/constants';
import {Matrix4} from 'math.gl';
import { Texture2D } from '@luma.gl/webgl';
import { AnimationLoop, setParameters, CubeGeometry } from '@luma.gl/core';
import { ModelNode } from '@luma.gl/experimental';
const INFO_HTML = `
<div>
<p>
<a href="http://learningwebgl.com/blog/?p=859" target="_blank">
Depth buffer, transparency and blending
</a>
</p>
Use arrow keys to spin the box and <code>+</code>/<code>-</code> to zoom in/out.
<br/>
<div>
<div>
<input type="checkbox" id="blending" checked/> <b>Blending</b>
<br/>
Alpha level
<input id="directionalR" type="range" value="0.5" min="0.0" max="1.0" step="0.01"/>
<br/>
</div>
<br/>
<div>
<input type="checkbox" id="lighting" checked/> <b>Directional Lighting</b>
<br/>
<div class="control-block">
<div class="control-row">
Direction:
<div>X:
<input id="lightDirectionX" type="range" value="0" min="-5" max="5" step="0.1"/>
</div>
<div>Y:
<input id="lightDirectionY" type="range" value="0" min="-5" max="5" step="0.1"/>
</div>
<div>Z:
<input id="lightDirectionZ" type="range" value="2" min="0" max="5" step="0.1"/>
</div>
</div>
<div class="control-row">
Colour:
<div>R:
<input id="directionalR" type="range" value="0.2" min="0.0" max="1.0" step="0.01"/>
</div>
<div>G:
<input id="directionalG" type="range" value="0.2" min="0.0" max="1.0" step="0.01"/>
</div>
<div>B:
<input id="directionalB" type="range" value="0.2" min="0.0" max="1.0" step="0.01"/>
</div>
</div>
</div>
</div>
</div>
<br/>
<div>
<div><b>Ambient Lighting</b></div>
<div class="control-block">
<div class="control-row">
Colour:
<div>R:
<input id="ambientR" type="range" value="0.2" min="0.0" max="1.0" step="0.01"/>
</div>
<div>G:
<input id="ambientG" type="range" value="0.2" min="0.0" max="1.0" step="0.01"/>
</div>
<div>B:
<input id="ambientB" type="range" value="0.2" min="0.0" max="1.0" step="0.01"/>
</div>
</div>
</div>
</div>
<br/>
The classic WebGL Lessons in luma.gl
</div>
`;
// Read Lighting form elements variables
function getHTMLControls() {
/* global document */
const $id = id => document.getElementById(id);
const $value = (id, defaultValue = 1) => ($id(id) ? Number($id(id).value) : defaultValue);
const $checked = id => ($id(id) ? $id(id).checked : true);
const blendingEnabled = $checked('blending');
const alpha = $value('alpha', 0.5);
// Get lighting form elements
const lightingEnabled = $checked('lighting');
const lightDirection = [
$value('lightDirectionX', 0),
$value('lightDirectionY', 0),
$value('lightDirectionZ', 1)
];
const lightColor = [$value('directionalR'), $value('directionalG'), $value('directionalB')];
const ambientColor = [$value('ambientR'), $value('ambientG'), $value('ambientB')];
return {
blendingEnabled,
alpha,
lightingEnabled,
lightDirection,
lightColor,
ambientColor
};
}
// Vertex shader with lighting
const VERTEX_SHADER = `\
attribute vec3 positions;
attribute vec2 texCoords;
attribute vec3 normals;
uniform mat4 uMVMatrix;
uniform mat4 uPMatrix;
uniform vec3 uAmbientColor;
uniform vec3 uLightingDirection;
uniform vec3 uDirectionalColor;
uniform bool uUseLighting;
varying vec2 vTextureCoord;
varying vec3 vLightWeighting;
void main(void) {
gl_Position = uPMatrix * uMVMatrix * vec4(positions, 1.0);
vTextureCoord = texCoords;
if (!uUseLighting) {
vLightWeighting = vec3(1.0, 1.0, 1.0);
} else {
// Perform lighting in world space
// we should use 'transpose(inverse(mat3(uMVMatrix)))', but
// 'inverse' matrix operation not supported in GLSL 1.0, for now use
// upper-left 3X3 matrix of model view matrix, it works since we are not
// doing any non-uniform scaling transormations in this example.
mat3 normalMatrix = mat3(uMVMatrix);
vec3 transformedNormal = normalMatrix * normals;
float directionalLightWeighting = max(dot(transformedNormal, uLightingDirection), 0.0);
vLightWeighting = uAmbientColor + uDirectionalColor * directionalLightWeighting;
}
}
`;
// Fragment shader
const FRAGMENT_SHADER = `\
precision highp float;
varying vec2 vTextureCoord;
varying vec3 vLightWeighting;
uniform sampler2D uSampler;
uniform float uAlpha;
void main(void) {
vec4 textureColor = texture2D(uSampler, vec2(vTextureCoord.s, vTextureCoord.t));
gl_FragColor = vec4(textureColor.rgb * vLightWeighting, textureColor.a * uAlpha);
}
`;
let xRot = 0;
let xSpeed = 0.01;
let yRot = 0;
let ySpeed = 0.0;
let cubePositionZ = -5.0;
export default class AppAnimationLoop extends AnimationLoop {
static getInfo() {
return INFO_HTML;
}
onInitialize({canvas, gl}) {
document.addEventListener('keydown', keyboardEventHandler);
setParameters(gl, {
clearColor: [0, 0, 0, 1],
clearDepth: 1,
blendFunc: [gl.SRC_ALPHA, gl.ONE],
blend: true
});
const texture = new Texture2D(gl, {
data: 'glass.gif',
mipmap: true,
parameters: {
[gl.TEXTURE_MIN_FILTER]: gl.LINEAR_MIPMAP_NEAREST,
[gl.TEXTURE_MAG_FILTER]: gl.LINEAR
}
});
return {
cube: new ModelNode(gl, {
geometry: new CubeGeometry(),
vs: VERTEX_SHADER,
fs: FRAGMENT_SHADER,
uniforms: {uSampler: texture}
})
};
}
onRender({gl, tick, aspect, cube}) {
xRot += xSpeed;
yRot += ySpeed;
gl.clear(GL.COLOR_BUFFER_BIT | GL.DEPTH_BUFFER_BIT);
// update element matrix to rotate cube on its center
cube.setRotation([xRot, yRot, 0]).updateMatrix();
const uMVMatrix = new Matrix4()
.lookAt({eye: [0, 0, 0]})
.translate([0, 0, cubePositionZ])
.rotateXYZ([tick * 0.01, tick * 0.01, tick * 0.01])
.multiplyRight(cube.matrix);
const {
blendingEnabled,
alpha,
lightingEnabled,
lightDirection,
lightColor,
ambientColor
} = getHTMLControls();
if (blendingEnabled) {
gl.disable(gl.DEPTH_TEST);
gl.enable(gl.BLEND);
gl.blendFunc(gl.SRC_ALPHA, gl.ONE);
cube.setUniforms({
alpha
});
} else {
gl.enable(gl.DEPTH_TEST);
gl.disable(gl.BLEND);
}
// Update scene config with light info
cube
.setUniforms({
uMVMatrix,
uPMatrix: new Matrix4().perspective({aspect}),
uAmbientColor: ambientColor,
uUseLighting: lightingEnabled,
uLightingDirection: lightDirection,
uDirectionalColor: lightColor,
uAlpha: Number(0.5)
})
.draw();
}
onFinalize() {
document.removeEventListener('keydown', keyboardEventHandler);
}
}
function keyboardEventHandler(e) {
switch (e.code) {
case 'ArrowUp':
xSpeed -= 0.02;
break;
case 'ArrowDown':
xSpeed += 0.02;
break;
case 'ArrowLeft':
ySpeed -= 0.02;
break;
case 'ArrowRight':
ySpeed += 0.02;
break;
case 'Equal': // '+'
cubePositionZ += 0.05;
break;
case 'Minus': // '-'
cubePositionZ -= 0.05;
break;
default:
}
}
/* global window */
if (typeof window !== 'undefined' && !window.website) {
const animationLoop = new AppAnimationLoop();
animationLoop.start();
}
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/12/package.json
|
{
"version": "0.0.1",
"private": true,
"name": "@rapidsai/demo-luma.gl-lessons-12",
"description": "The classic WebGL Lesson 12 ported to luma.gl.",
"contributors": [
"Jian Huang <[email protected]>"
],
"scripts": {
"start": "webpack-dev-server --progress --hot --open -d",
"start-local": "webpack-dev-server --env.local --progress --hot --open -d"
},
"dependencies": {
"@luma.gl/constants": "8.5.16",
"@luma.gl/core": "8.5.16",
"math.gl": "3.6.3"
}
}
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/12/app.js
|
import GL from '@luma.gl/constants';
import {
AnimationLoop,
Texture2D,
setParameters,
Model,
SphereGeometry,
CubeGeometry
} from '@luma.gl/core';
import {Vector3, Matrix4, radians} from 'math.gl';
/* eslint-disable complexity */
const VERTEX_SHADER = `\
attribute vec3 positions;
attribute vec3 normals;
attribute vec2 texCoords;
uniform mat4 uMMatrix;
uniform mat4 uVMatrix;
uniform mat4 uPMatrix;
uniform vec3 uAmbientColor;
uniform vec3 uPointLightingLocation;
uniform vec3 uPointLightingColor;
uniform bool uUseLighting;
varying vec2 vTextureCoord;
varying vec3 vLightWeighting;
void main(void) {
vec4 mPosition = uMMatrix * vec4(positions, 1.0);
gl_Position = uPMatrix * uVMatrix * mPosition;
vTextureCoord = texCoords;
if (!uUseLighting) {
vLightWeighting = vec3(1.0, 1.0, 1.0);
} else {
vec3 lightDirection = normalize(uPointLightingLocation - mPosition.xyz);
vec4 transformedNormal = uMMatrix * vec4(normals, 0.0);
float pointLightWeighting = max(dot(transformedNormal.xyz, lightDirection), 0.0);
vLightWeighting = uAmbientColor + uPointLightingColor * pointLightWeighting;
}
}
`;
const FRAGMENT_SHADER = `\
precision highp float;
varying vec2 vTextureCoord;
varying vec3 vLightWeighting;
uniform sampler2D uSampler;
void main(void) {
vec4 textureColor = texture2D(uSampler, vec2(1.0 - vTextureCoord.s, 1.0 - vTextureCoord.t));
gl_FragColor = vec4(textureColor.rgb * vLightWeighting, textureColor.a);
}
`;
const INFO_HTML = `
<p>
<a href="http://learningwebgl.com/blog/?p=1359" target="_blank">
Point lighting
</a>
<p>
The classic WebGL Lessons in luma.gl
`;
const appState = {
moonRotationMatrix: new Matrix4().rotateY(radians(180)).translate([5, 0, 0]),
cubeRotationMatrix: new Matrix4().translate([5, 0, 0]),
lastTime: 0
};
function animateAppState() {
const timeNow = Date.now();
if (appState.lastTime !== 0) {
const elapsed = timeNow - appState.lastTime;
const newMatrix = new Matrix4().rotateY(radians(elapsed / 20));
appState.moonRotationMatrix.multiplyLeft(newMatrix);
appState.cubeRotationMatrix.multiplyLeft(newMatrix);
}
appState.lastTime = timeNow;
}
export default class AppAnimationLoop extends AnimationLoop {
static getInfo() {
return INFO_HTML;
}
onInitialize({canvas, gl}) {
setParameters(gl, {
clearColor: [0, 0, 0, 1],
clearDepth: 1,
depthTest: true
});
return {
moon: new Model(gl, {
geometry: new SphereGeometry({
nlat: 30,
nlong: 30,
radius: 2
}),
fs: FRAGMENT_SHADER,
vs: VERTEX_SHADER,
uniforms: {
uSampler: new Texture2D(gl, 'moon.gif')
}
}),
cube: new Model(gl, {
geometry: new CubeGeometry(),
vs: VERTEX_SHADER,
fs: FRAGMENT_SHADER,
uniforms: {
uSampler: new Texture2D(gl, 'crate.gif')
}
})
};
}
onRender({gl, tick, aspect, moon, cube}) {
// eslint-disable-line complexity
// set camera position
const eyePos = [0, 0, 20];
gl.clear(GL.COLOR_BUFFER_BIT | GL.DEPTH_BUFFER_BIT);
const uVMatrix = new Matrix4().lookAt({eye: eyePos, center: [0, 0, 0], up: [0, 1, 0]});
/* global document */
function getElementValue(id, defaultValue) {
const element = document.getElementById(id);
return element ? element.value : defaultValue;
}
const element = document.getElementById('lighting');
const lighting = element ? element.checked : true;
moon.setUniforms({uUseLighting: lighting});
cube.setUniforms({uUseLighting: lighting});
if (lighting) {
const ambientColor = new Vector3(
parseFloat(getElementValue('ambientR', 0.2)),
parseFloat(getElementValue('ambientG', 0.2)),
parseFloat(getElementValue('ambientB', 0.2))
);
const pointLightingLocation = new Vector3(
parseFloat(getElementValue('lightPositionX', 0)),
parseFloat(getElementValue('lightPositionY', 0)),
parseFloat(getElementValue('lightPositionZ', 0))
);
const pointLightColor = new Vector3(
parseFloat(getElementValue('pointR', 0.8)),
parseFloat(getElementValue('pointG', 0.8)),
parseFloat(getElementValue('pointB', 0.8))
);
moon.setUniforms({
uAmbientColor: ambientColor,
uPointLightingLocation: pointLightingLocation,
uPointLightingColor: pointLightColor
});
cube.setUniforms({
uAmbientColor: ambientColor,
uPointLightingLocation: pointLightingLocation,
uPointLightingColor: pointLightColor
});
}
moon
.setUniforms({
uMMatrix: appState.moonRotationMatrix,
uVMatrix,
uPMatrix: new Matrix4().perspective({
fov: (45 * Math.PI) / 180,
aspect,
near: 0.1,
far: 100
})
})
.draw();
cube
.setUniforms({
uMMatrix: appState.cubeRotationMatrix,
uVMatrix,
uPMatrix: new Matrix4().perspective({
fov: (45 * Math.PI) / 180,
aspect,
near: 0.1,
far: 100
})
})
.draw();
animateAppState();
}
}
/* global window */
if (typeof window !== 'undefined' && !window.website) {
const animationLoop = new AppAnimationLoop();
animationLoop.start();
}
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/10/package.json
|
{
"version": "0.0.1",
"private": true,
"name": "@rapidsai/demo-luma.gl-lessons-10",
"description": "The classic WebGL Lesson 10 ported to luma.gl.",
"contributors": [
"Jian Huang <[email protected]>"
],
"scripts": {
"start": "webpack-dev-server --progress --hot --open -d",
"start-local": "webpack-dev-server --env.local --progress --hot --open -d"
},
"dependencies": {
"@loaders.gl/images": "3.2.9",
"@luma.gl/constants": "8.5.16",
"@luma.gl/core": "8.5.16",
"@luma.gl/experimental": "8.5.16",
"@luma.gl/shadertools": "8.5.16",
"math.gl": "3.6.3",
"mjolnir.js": "2.5.2"
}
}
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/10/world.js
|
import {Program, Geometry} from '@luma.gl/core';
import { ModelNode } from '@luma.gl/experimental';
const VERTEX_SHADER = `\
attribute vec3 positions;
attribute vec2 texCoords;
uniform mat4 uMVMatrix;
uniform mat4 uPMatrix;
varying vec2 vTextureCoord;
void main(void) {
gl_Position = uPMatrix * uMVMatrix * vec4(positions, 1.0);
vTextureCoord = texCoords;
}
`;
const FRAGMENT_SHADER = `\
precision highp float;
varying vec2 vTextureCoord;
uniform sampler2D uSampler;
void main(void) {
gl_FragColor = vec4(texture2D(uSampler, vec2(vTextureCoord.s, vTextureCoord.t)).rgb, 1.0);
}
`;
function loadWorldGeometry(data) {
const lines = data.split('\n');
const vertexPositions = [];
const vertexTextureCoords = [];
for (const i in lines) {
const vals = lines[i].replace(/^\s+/, '').split(/\s+/);
if (vals.length === 5 && vals[0] !== '//') {
// It is a line describing a vertex; get X, Y and Z first
vertexPositions.push(parseFloat(vals[0]));
vertexPositions.push(parseFloat(vals[1]));
vertexPositions.push(parseFloat(vals[2]));
// And then the texture coords
vertexTextureCoords.push(parseFloat(vals[3]));
vertexTextureCoords.push(parseFloat(vals[4]));
}
}
return new Geometry({
vertexCount: vertexPositions.length / 3,
attributes: {
positions: new Float32Array(vertexPositions),
texCoords: new Float32Array(vertexTextureCoords)
}
});
}
export class World extends ModelNode {
constructor(opts = {}) {
const program = new Program(opts.gl, {
fs: FRAGMENT_SHADER,
vs: VERTEX_SHADER
});
super(opts.gl, {
program,
geometry: opts.geometry,
uniforms: {
uSampler: opts.texture
}
});
}
}
export {loadWorldGeometry};
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/10/world.txt
|
NUMPOLLIES 36
// Floor 1
-3.0 0.0 -3.0 0.0 6.0
-3.0 0.0 3.0 0.0 0.0
3.0 0.0 3.0 6.0 0.0
-3.0 0.0 -3.0 0.0 6.0
3.0 0.0 -3.0 6.0 6.0
3.0 0.0 3.0 6.0 0.0
// Ceiling 1
-3.0 1.0 -3.0 0.0 6.0
-3.0 1.0 3.0 0.0 0.0
3.0 1.0 3.0 6.0 0.0
-3.0 1.0 -3.0 0.0 6.0
3.0 1.0 -3.0 6.0 6.0
3.0 1.0 3.0 6.0 0.0
// A1
-2.0 1.0 -2.0 0.0 1.0
-2.0 0.0 -2.0 0.0 0.0
-0.5 0.0 -2.0 1.5 0.0
-2.0 1.0 -2.0 0.0 1.0
-0.5 1.0 -2.0 1.5 1.0
-0.5 0.0 -2.0 1.5 0.0
// A2
2.0 1.0 -2.0 2.0 1.0
2.0 0.0 -2.0 2.0 0.0
0.5 0.0 -2.0 0.5 0.0
2.0 1.0 -2.0 2.0 1.0
0.5 1.0 -2.0 0.5 1.0
0.5 0.0 -2.0 0.5 0.0
// B1
-2.0 1.0 2.0 2.0 1.0
-2.0 0.0 2.0 2.0 0.0
-0.5 0.0 2.0 0.5 0.0
-2.0 1.0 2.0 2.0 1.0
-0.5 1.0 2.0 0.5 1.0
-0.5 0.0 2.0 0.5 0.0
// B2
2.0 1.0 2.0 2.0 1.0
2.0 0.0 2.0 2.0 0.0
0.5 0.0 2.0 0.5 0.0
2.0 1.0 2.0 2.0 1.0
0.5 1.0 2.0 0.5 1.0
0.5 0.0 2.0 0.5 0.0
// C1
-2.0 1.0 -2.0 0.0 1.0
-2.0 0.0 -2.0 0.0 0.0
-2.0 0.0 -0.5 1.5 0.0
-2.0 1.0 -2.0 0.0 1.0
-2.0 1.0 -0.5 1.5 1.0
-2.0 0.0 -0.5 1.5 0.0
// C2
-2.0 1.0 2.0 2.0 1.0
-2.0 0.0 2.0 2.0 0.0
-2.0 0.0 0.5 0.5 0.0
-2.0 1.0 2.0 2.0 1.0
-2.0 1.0 0.5 0.5 1.0
-2.0 0.0 0.5 0.5 0.0
// D1
2.0 1.0 -2.0 0.0 1.0
2.0 0.0 -2.0 0.0 0.0
2.0 0.0 -0.5 1.5 0.0
2.0 1.0 -2.0 0.0 1.0
2.0 1.0 -0.5 1.5 1.0
2.0 0.0 -0.5 1.5 0.0
// D2
2.0 1.0 2.0 2.0 1.0
2.0 0.0 2.0 2.0 0.0
2.0 0.0 0.5 0.5 0.0
2.0 1.0 2.0 2.0 1.0
2.0 1.0 0.5 0.5 1.0
2.0 0.0 0.5 0.5 0.0
// Upper hallway - L
-0.5 1.0 -3.0 0.0 1.0
-0.5 0.0 -3.0 0.0 0.0
-0.5 0.0 -2.0 1.0 0.0
-0.5 1.0 -3.0 0.0 1.0
-0.5 1.0 -2.0 1.0 1.0
-0.5 0.0 -2.0 1.0 0.0
// Upper hallway - R
0.5 1.0 -3.0 0.0 1.0
0.5 0.0 -3.0 0.0 0.0
0.5 0.0 -2.0 1.0 0.0
0.5 1.0 -3.0 0.0 1.0
0.5 1.0 -2.0 1.0 1.0
0.5 0.0 -2.0 1.0 0.0
// Lower hallway - L
-0.5 1.0 3.0 0.0 1.0
-0.5 0.0 3.0 0.0 0.0
-0.5 0.0 2.0 1.0 0.0
-0.5 1.0 3.0 0.0 1.0
-0.5 1.0 2.0 1.0 1.0
-0.5 0.0 2.0 1.0 0.0
// Lower hallway - R
0.5 1.0 3.0 0.0 1.0
0.5 0.0 3.0 0.0 0.0
0.5 0.0 2.0 1.0 0.0
0.5 1.0 3.0 0.0 1.0
0.5 1.0 2.0 1.0 1.0
0.5 0.0 2.0 1.0 0.0
// Left hallway - Lw
-3.0 1.0 0.5 1.0 1.0
-3.0 0.0 0.5 1.0 0.0
-2.0 0.0 0.5 0.0 0.0
-3.0 1.0 0.5 1.0 1.0
-2.0 1.0 0.5 0.0 1.0
-2.0 0.0 0.5 0.0 0.0
// Left hallway - Hi
-3.0 1.0 -0.5 1.0 1.0
-3.0 0.0 -0.5 1.0 0.0
-2.0 0.0 -0.5 0.0 0.0
-3.0 1.0 -0.5 1.0 1.0
-2.0 1.0 -0.5 0.0 1.0
-2.0 0.0 -0.5 0.0 0.0
// Right hallway - Lw
3.0 1.0 0.5 1.0 1.0
3.0 0.0 0.5 1.0 0.0
2.0 0.0 0.5 0.0 0.0
3.0 1.0 0.5 1.0 1.0
2.0 1.0 0.5 0.0 1.0
2.0 0.0 0.5 0.0 0.0
// Right hallway - Hi
3.0 1.0 -0.5 1.0 1.0
3.0 0.0 -0.5 1.0 0.0
2.0 0.0 -0.5 0.0 0.0
3.0 1.0 -0.5 1.0 1.0
2.0 1.0 -0.5 0.0 1.0
2.0 0.0 -0.5 0.0 0.0
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/10/app.js
|
import GL from '@luma.gl/constants';
import {AnimationLoop, Texture2D, loadFile, setParameters} from '@luma.gl/core';
import {Matrix4, radians} from 'math.gl';
import {loadWorldGeometry, World} from './world';
import {EventManager} from 'mjolnir.js';
/* eslint-disable complexity */
/*
Cave texture from: http://texturelib.com/texture/?path=/Textures/rock/cave/rock_cave_0019
"Free for personal and commercial use." http://texturelib.com/about/
*/
const INFO_HTML = `
<p>
<a href="http://learningwebgl.com/blog/?p=1067" target="_blank">
Loading a world, and the most basic kind of camera
</a>
</br>
</br>
Use the cursor keys or WASD to run around, and <code>+</code>/<code>-</code> to look up and down.
<p>
The classic WebGL Lessons in luma.gl
`;
const cameraInfo = {
pitch: 0,
pitchRate: 0,
yaw: 0,
yawRate: 0,
xPos: 0,
yPos: 0.4,
zPos: 0,
speed: 0,
joggingAngle: 0, // Used to make us "jog" up and down as we move forward.
direction: [0, 0, -1]
};
const timeLine = {
lastTime: 0
};
const currentlyPressedKeys = {};
export default class AppAnimationLoop extends AnimationLoop {
static getInfo() {
return INFO_HTML;
}
onInitialize({canvas, gl}) {
// Use mjolnir.js (hammer.js)'s EventManager to handle gestures on both
// desktop and mobile
this.eventManager = new EventManager(canvas);
addKeyboardHandler(this.eventManager);
addMouseHandler(this.eventManager);
setParameters(gl, {
clearColor: [0, 0, 0, 1],
clearDepth: 1,
depthTest: true
});
const texture = new Texture2D(gl, {
data: 'cave.jpg',
parameters: {
[gl.TEXTURE_WRAP_S]: gl.MIRRORED_REPEAT,
[gl.TEXTURE_WRAP_T]: gl.MIRRORED_REPEAT
}
});
return loadFile('world.txt').then(file => {
const geometry = loadWorldGeometry(file);
const world = new World({
gl,
geometry,
texture
});
return {world};
});
}
onRender({gl, tick, aspect, world}) {
// Update Camera Position
const eyePos = [cameraInfo.xPos, cameraInfo.yPos, cameraInfo.zPos];
const centerPos = new Matrix4()
.rotateX(radians(cameraInfo.pitch))
.rotateY(radians(cameraInfo.yaw))
// .transformVector3(cameraInfo.direction)
.transform(cameraInfo.direction)
.add(eyePos);
const uMVMatrix = new Matrix4().lookAt({eye: eyePos, center: centerPos, up: [0, 1, 0]});
handleKeys(cameraInfo, currentlyPressedKeys);
animate(cameraInfo, timeLine);
gl.clear(GL.COLOR_BUFFER_BIT | GL.DEPTH_BUFFER_BIT);
return world
.setUniforms({
uMVMatrix,
uPMatrix: new Matrix4().perspective({
fov: (45 * Math.PI) / 180,
aspect,
near: 0.1,
far: 100
})
})
.draw();
}
onFinalize() {
this.eventManager.destroy();
}
}
function addKeyboardHandler(eventManager) {
eventManager.on({
keydown(e) {
currentlyPressedKeys[e.srcEvent.code] = true;
},
keyup(e) {
currentlyPressedKeys[e.srcEvent.code] = false;
}
});
}
function addMouseHandler(eventManager) {
let mouseDown = false;
let currentX = 0;
let currentY = 0;
eventManager.on({
panstart(e) {
mouseDown = true;
currentX = e.offsetCenter.x;
currentY = e.offsetCenter.y;
},
panend() {
mouseDown = false;
},
panmove(e) {
if (!mouseDown) {
return;
}
const dx = e.offsetCenter.x - currentX;
const dy = e.offsetCenter.y - currentY;
cameraInfo.yaw += dx * 0.1;
cameraInfo.pitch += dy * 0.1;
currentX = e.offsetCenter.x;
currentY = e.offsetCenter.y;
}
});
}
function handleKeys() {
if (currentlyPressedKeys.PageUp || currentlyPressedKeys.Equal) {
cameraInfo.pitchRate = 0.1;
} else if (currentlyPressedKeys.PageDown || currentlyPressedKeys.Minus) {
cameraInfo.pitchRate = -0.1;
} else {
cameraInfo.pitchRate = 0;
}
if (currentlyPressedKeys.ArrowLeft || currentlyPressedKeys.KeyA) {
cameraInfo.yawRate = 0.1;
} else if (currentlyPressedKeys.ArrowRight || currentlyPressedKeys.KeyD) {
cameraInfo.yawRate = -0.1;
} else {
cameraInfo.yawRate = 0;
}
if (currentlyPressedKeys.ArrowUp || currentlyPressedKeys.KeyW) {
cameraInfo.speed = 0.003;
} else if (currentlyPressedKeys.ArrowDown || currentlyPressedKeys.KeyS) {
cameraInfo.speed = -0.003;
} else {
cameraInfo.speed = 0;
}
}
function animate() {
const timeNow = new Date().getTime();
if (timeLine.lastTime !== 0) {
const elapsed = timeNow - timeLine.lastTime;
if (cameraInfo.speed !== 0) {
cameraInfo.xPos -= Math.sin(radians(cameraInfo.yaw)) * cameraInfo.speed * elapsed;
cameraInfo.zPos -= Math.cos(radians(cameraInfo.yaw)) * cameraInfo.speed * elapsed;
cameraInfo.joggingAngle += elapsed * 0.6; // 0.6 "fiddle factor" - feel more realistic :-)
cameraInfo.yPos = Math.sin(radians(cameraInfo.joggingAngle)) / 20 + 0.4;
}
cameraInfo.yaw += cameraInfo.yawRate * elapsed;
cameraInfo.pitch += cameraInfo.pitchRate * elapsed;
}
timeLine.lastTime = timeNow;
}
/* global window */
if (typeof window !== 'undefined' && !window.website) {
const animationLoop = new AppAnimationLoop();
animationLoop.start();
}
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/15/package.json
|
{
"version": "0.0.1",
"private": true,
"name": "@rapidsai/demo-luma.gl-lessons-15",
"description": "The classic WebGL Lesson 15 ported to luma.gl.",
"contributors": [
"Xintong Xia <[email protected]>"
],
"scripts": {
"start": "webpack-dev-server --progress --hot --open -d",
"start-local": "webpack-dev-server --env.local --progress --hot --open -d"
},
"dependencies": {
"@luma.gl/constants": "8.5.16",
"@luma.gl/core": "8.5.16",
"math.gl": "3.6.3"
}
}
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/15/app.js
|
import GL from '@luma.gl/constants';
import {AnimationLoop, Texture2D, setParameters, Model, SphereGeometry} from '@luma.gl/core';
import {Matrix4} from 'math.gl';
const EARTH_UNIFORMS = {
uUseColorMap: true,
uUseSpecularMap: true,
uShowSpecularHighlights: true,
uUseLighting: true
};
const LIGHT_UNIFORMS = {
uAmbientColor: [0.4, 0.4, 0.4],
uPointLightingLocation: [-10.0, 4.0, -20.0],
uPointLightingSpecularColor: [5.0, 5.0, 5.0],
uPointLightingDiffuseColor: [0.8, 0.8, 0.8]
};
const FRAGMENT_LIGHTING_VERTEX_SHADER = `\
precision highp float;
attribute vec3 positions;
attribute vec3 normals;
attribute vec2 texCoords;
uniform mat4 uMMatrix;
uniform mat4 uVMatrix;
uniform mat4 uPMatrix;
varying vec2 vTextureCoord;
varying vec4 vTransformedNormal;
varying vec4 vPosition;
void main(void) {
vPosition = uMMatrix * vec4(positions, 1.0);
gl_Position = uPMatrix * uVMatrix * vPosition;
vTextureCoord = texCoords;
vTransformedNormal = uMMatrix * vec4(normals, 0.0);
}
`;
const FRAGMENT_LIGHTING_FRAGMENT_SHADER = `\
precision highp float;
varying vec2 vTextureCoord;
varying vec4 vTransformedNormal;
varying vec4 vPosition;
uniform bool uUseColorMap;
uniform bool uUseSpecularMap;
uniform bool uUseLighting;
uniform vec3 uAmbientColor;
uniform vec3 uPointLightingLocation;
uniform vec3 uPointLightingSpecularColor;
uniform vec3 uPointLightingDiffuseColor;
uniform sampler2D uSpecularMapSampler;
uniform sampler2D uColorMapSampler;
void main(void) {
vec3 lightWeighting;
if (!uUseLighting) {
lightWeighting = vec3(1.0, 1.0, 1.0);
} else {
vec3 lightDirection = normalize(uPointLightingLocation - vPosition.xyz);
vec3 normal = normalize(vTransformedNormal.xyz);
float specularLightWeighting = 0.0;
float shininess = 32.0;
if (uUseSpecularMap) {
shininess = texture2D(uSpecularMapSampler, vTextureCoord).r * 255.0;
}
if (shininess < 255.0) {
vec3 eyeDirection = normalize(-vPosition.xyz);
vec3 reflectionDirection = reflect(-lightDirection, normal);
specularLightWeighting = pow(max(dot(reflectionDirection, eyeDirection), 0.0), shininess);
}
float diffuseLightWeighting = max(dot(normal, lightDirection), 0.0);
lightWeighting = uAmbientColor
+ uPointLightingSpecularColor * specularLightWeighting
+ uPointLightingDiffuseColor * diffuseLightWeighting;
}
vec4 fragmentColor;
fragmentColor = uUseColorMap ?
texture2D(uColorMapSampler, vTextureCoord) : vec4(1.0, 1.0, 1.0, 1.0);
gl_FragColor = vec4(fragmentColor.rgb * lightWeighting, fragmentColor.a);
}
`;
const INFO_HTML = `
<p>
<a href="http://learningwebgl.com/blog/?p=1778" target="_blank">
Specular maps
</a>
<div id="controls-elements">
<input type="checkbox" id="color-map" checked/> Use color map<br/>
<input type="checkbox" id="specular-map" checked/> Use specular map<br/>
<input type="checkbox" id="lighting" checked/> Use lighting<br/>
<br/>
<h2>Point light:</h2>
<div class="control-block">
<div class="control-row">
<div><b>Location:</b></div>
<div>X: <input type="text" id="lightPositionX" value="-10.0"/></div>
<div>Y: <input type="text" id="lightPositionY" value="4.0"/></div>
<div>Z: <input type="text" id="lightPositionZ" value="-20.0"/></div>
</div>
<div class="control-row">
<div><b>Specular colour:</b></div>
<div>R:
<input id="specularR" type="range" value="0.8" min="0.0" max="1.0" step="0.01"/>
</div>
<div>G:
<input id="specularG" type="range" value="0.8" min="0.0" max="1.0" step="0.01"/>
</div>
<div>B:
<input id="specularB" type="range" value="0.8" min="0.0" max="1.0" step="0.01"/>
</div>
</div>
<div class="control-row">
<div><b>Diffuse colour:</b></div>
<div>R:
<input id="diffuseR" type="range" value="0.8" min="0.0" max="1.0" step="0.01"/>
</div>
<div>G:
<input id="diffuseG" type="range" value="0.8" min="0.0" max="1.0" step="0.01"/>
</div>
<div>B:
<input id="diffuseB" type="range" value="0.8" min="0.0" max="1.0" step="0.01"/>
</div>
</div>
</div>
<h2>Ambient light:</h2>
<div class="control-block">
<div class="control-row">
<div><b>Colour:</b></div>
<div>R:
<input id="ambientR" type="range" value="0.2" min="0.0" max="1.0" step="0.01"/>
</div>
<div>G:
<input id="ambientG" type="range" value="0.2" min="0.0" max="1.0" step="0.01"/>
</div>
<div>B:
<input id="ambientB" type="range" value="0.2" min="0.0" max="1.0" step="0.01"/>
</div>
</div>
</div>
<br/>
Earth texture courtesy of
<a href="http://www.esa.int/esaEO/SEMGSY2IU7E_index_0.html">
the European Space Agency/Envisat
</a>.<br/>
<br/>
</div>
<p>
The classic WebGL Lessons in luma.gl
`;
export default class AppAnimationLoop extends AnimationLoop {
static getInfo() {
return INFO_HTML;
}
onInitialize({canvas, gl}) {
setParameters(gl, {
clearColor: [0, 0, 0, 1],
clearDepth: 1,
depthTest: true
});
const specularTexture = new Texture2D(gl, {
data: 'earth-specular.gif',
parameters: {
[gl.TEXTURE_MAG_FILTER]: gl.LINEAR,
[gl.TEXTURE_MIN_FILTER]: gl.LINEAR_MIPMAP_NEAREST,
[gl.TEXTURE_WRAP_S]: gl.REPEAT,
[gl.TEXTURE_WRAP_T]: gl.REPEAT
},
mipmap: true
});
const colorTexture = new Texture2D(gl, {
data: 'earth.jpg',
parameters: {
[gl.TEXTURE_MAG_FILTER]: gl.LINEAR,
[gl.TEXTURE_MIN_FILTER]: gl.LINEAR_MIPMAP_NEAREST,
[gl.TEXTURE_WRAP_S]: gl.REPEAT,
[gl.TEXTURE_WRAP_T]: gl.REPEAT
},
mipmap: true
});
const earth = new Model(gl, {
geometry: new SphereGeometry({
nlat: 30,
nlong: 30,
radius: 13
}),
fs: FRAGMENT_LIGHTING_FRAGMENT_SHADER,
vs: FRAGMENT_LIGHTING_VERTEX_SHADER,
uniforms: Object.assign(
{
uColorMapSampler: colorTexture,
uSpecularMapSampler: specularTexture
},
EARTH_UNIFORMS,
LIGHT_UNIFORMS
)
});
return {earth, specularTexture, colorTexture};
}
onRender({gl, tick, aspect, earth}) {
gl.clear(GL.COLOR_BUFFER_BIT | GL.DEPTH_BUFFER_BIT);
// set camera position
const uVMatrix = new Matrix4().lookAt({eye: [0, 0, 10], center: [0, 0, 0], up: [-0.5, 1, 0]});
const {
useLighting,
useSpecularMap,
useColorMap,
ambientColor,
pointLightingLocation,
pointLightSpecularColor,
pointLightingDiffuseColor
} = getControlValues();
earth.setUniforms({
uUseSpecularMap: useSpecularMap,
uUseColorMap: useColorMap,
uUseLighting: useLighting
});
if (useLighting) {
earth.setUniforms({
uAmbientColor: ambientColor,
uPointLightingLocation: pointLightingLocation,
uPointLightingSpecularColor: pointLightSpecularColor,
uPointLightingDiffuseColor: pointLightingDiffuseColor
});
}
const phi = tick * 0.01;
return earth
.setUniforms({
uMMatrix: new Matrix4().translate([0, 0, -40]).rotateY(phi),
uVMatrix,
uPMatrix: new Matrix4().perspective({
fov: (45 * Math.PI) / 180,
aspect,
near: 0.1,
far: 100
})
})
.draw();
}
}
/* global document */
const $id = id => document.getElementById(id);
const $checked = id => ($id(id) ? $id(id).checked : true);
const $value = (id, defaultValue = 1) => {
const value = $id(id) ? Number($id(id).value) : defaultValue;
return isNaN(value) ? 0 : value;
};
// Read Light settings HTML form
function getControlValues() {
const useLighting = $checked('lighting');
const useSpecularMap = $checked('specular-map');
const useColorMap = $checked('color-map');
const point = {
position: [$value('lightPositionX'), $value('lightPositionY'), $value('lightPositionZ')],
specular: [$value('specularR'), $value('specularG'), $value('specularB')],
diffuse: [$value('diffuseR'), $value('diffuseG'), $value('diffuseB')]
};
const ambientColor = [$value('ambientR'), $value('ambientG'), $value('ambientB')];
return {
useLighting,
useSpecularMap,
useColorMap,
ambientColor: useLighting && ambientColor,
pointLightingLocation: useLighting && point.position,
pointLightSpecularColor: useLighting && point.specular,
pointLightingDiffuseColor: useLighting && point.diffuse
};
}
/* global window */
if (typeof window !== 'undefined' && !window.website) {
const animationLoop = new AppAnimationLoop();
animationLoop.start();
}
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/02/package.json
|
{
"version": "0.0.1",
"private": true,
"name": "@rapidsai/demo-luma.gl-lessons-02",
"scripts": {
"start": "webpack-dev-server --progress --hot --open -d",
"start-local": "webpack-dev-server --env.local --progress --hot --open -d"
},
"dependencies": {
"@luma.gl/core": "8.5.16",
"math.gl": "3.6.3"
}
}
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/02/app.js
|
import {AnimationLoop, setParameters} from '@luma.gl/core';
import {Program, VertexArray, Buffer} from '@luma.gl/webgl';
import {Matrix4} from 'math.gl';
const INFO_HTML = `
<p>
<a href="http://learningwebgl.com/blog/?p=134" target="_blank">
Adding Color
</a>
<p>
The classic WebGL Lessons in luma.gl
`;
const VERTEX_SHADER = `\
attribute vec3 positions;
attribute vec4 colors;
uniform mat4 uMVMatrix;
uniform mat4 uPMatrix;
varying vec4 vColor;
void main(void) {
gl_Position = uPMatrix * uMVMatrix * vec4(positions, 1.0);
vColor = colors;
}
`;
const FRAGMENT_SHADER = `\
precision highp float;
varying vec4 vColor;
void main(void) {
gl_FragColor = vColor;
}
`;
export default class AppAnimationLoop extends AnimationLoop {
static getInfo() {
return INFO_HTML;
}
onInitialize({gl, aspect, canvas}) {
const TRIANGLE_VERTS = [0, 1, 0, -1, -1, 0, 1, -1, 0];
const TRIANGLE_COLORS = [1, 0, 0, 1, 0, 1, 0, 1, 0, 0, 1, 1];
const SQUARE_VERTS = [1, 1, 0, -1, 1, 0, 1, -1, 0, -1, -1, 0];
const SQUARE_COLORS = [0.5, 0.5, 1, 1, 0.5, 0.5, 1, 1, 0.5, 0.5, 1, 1, 0.5, 0.5, 1, 1];
const program = new Program(gl, {
vs: VERTEX_SHADER,
fs: FRAGMENT_SHADER
});
const triangleVertexArray = new VertexArray(gl, {
program,
attributes: {
positions: new Buffer(gl, new Float32Array(TRIANGLE_VERTS)),
colors: new Buffer(gl, new Float32Array(TRIANGLE_COLORS))
}
});
const squareVertexArray = new VertexArray(gl, {
program,
attributes: {
positions: new Buffer(gl, new Float32Array(SQUARE_VERTS)),
colors: new Buffer(gl, new Float32Array(SQUARE_COLORS))
}
});
const view = new Matrix4().translate([-1.5, 0, -7]);
const projection = new Matrix4().perspective({aspect});
setParameters(gl, {
clearColor: [0, 0, 0, 1],
clearDepth: [1],
depthTest: true,
depthFunc: gl.LEQUAL
});
gl.clear(gl.COLOR_BUFFER_BIT | gl.DEPTH_BUFFER_BIT);
program
.setUniforms({
uMVMatrix: view,
uPMatrix: projection
})
.draw({
vertexArray: triangleVertexArray,
drawMode: gl.TRIANGLES,
vertexCount: 3
});
// Draw Square
view.translate([3, 0, 0]);
program
.setUniforms({
uMVMatrix: view,
uPMatrix: projection
})
.draw({
vertexArray: squareVertexArray,
drawMode: gl.TRIANGLE_STRIP,
vertexCount: 4
});
}
}
/* global window */
if (typeof window !== 'undefined' && !window.website) {
const animationLoop = new AppAnimationLoop();
animationLoop.start();
}
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/04/package.json
|
{
"version": "0.0.1",
"private": true,
"name": "@rapidsai/demo-luma.gl-lessons-04",
"scripts": {
"start": "webpack-dev-server --progress --hot --open -d",
"start-local": "webpack-dev-server --env.local --progress --hot --open -d"
},
"dependencies": {
"@luma.gl/constants": "8.5.16",
"@luma.gl/core": "8.5.16",
"math.gl": "3.6.3"
}
}
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/04/app.js
|
import GL from '@luma.gl/constants';
import {Matrix4} from 'math.gl';
import { setParameters } from '@luma.gl/core';
import { AnimationLoop, Model, Geometry, CubeGeometry } from '@luma.gl/engine';
const INFO_HTML = `
<p>
<a href="http://learningwebgl.com/blog/?p=370" target="_blank">
Some Real 3D Objects
</a>
<p>
The classic WebGL Lessons in luma.gl
`;
const VERTEX_SHADER = `\
attribute vec3 positions;
attribute vec4 colors;
uniform mat4 uMVMatrix;
uniform mat4 uPMatrix;
varying vec4 vColor;
void main(void) {
gl_Position = uPMatrix * uMVMatrix * vec4(positions, 1.0);
vColor = colors;
}
`;
const FRAGMENT_SHADER = `\
precision highp float;
varying vec4 vColor;
void main(void) {
gl_FragColor = vColor;
}
`;
// Makes a colored pyramid
class ColoredPyramidGeometry extends Geometry {
constructor(props) {
super({
...props,
attributes: {
/* eslint-disable indent, no-multi-spaces */
// prettier-ignore
positions: new Float32Array([
0, 1, 0,
-1, -1, 1,
1, -1, 1,
0, 1, 0,
1, -1, 1,
1, -1, -1,
0, 1, 0,
1, -1, -1,
-1, -1, -1,
0, 1, 0,
-1, -1, -1,
-1, -1, 1
]),
colors: {
size: 4,
// prettier-ignore
value: new Float32Array([
1, 0, 0, 1,
0, 1, 0, 1,
0, 0, 1, 1,
1, 0, 0, 1,
0, 0, 1, 1,
0, 1, 0, 1,
1, 0, 0, 1,
0, 1, 0, 1,
0, 0, 1, 1,
1, 0, 0, 1,
0, 0, 1, 1,
0, 1, 0, 1
])
}
}
});
}
}
// Make a colored cube
class ColoredCubeGeometry extends CubeGeometry {
constructor(props) {
super({
...props,
// Add one attribute to the geometry
attributes: {
colors: {
size: 4,
// prettier-ignore
value: new Float32Array([
1, 0, 0, 1,
1, 0, 0, 1,
1, 0, 0, 1,
1, 0, 0, 1,
1, 1, 0, 1,
1, 1, 0, 1,
1, 1, 0, 1,
1, 1, 0, 1,
0, 1, 0, 1,
0, 1, 0, 1,
0, 1, 0, 1,
0, 1, 0, 1,
1, 0.5, 0.5, 1,
1, 0.5, 0.5, 1,
1, 0.5, 0.5, 1,
1, 0.5, 0.5, 1,
1, 0, 1, 1,
1, 0, 1, 1,
1, 0, 1, 1,
1, 0, 1, 1,
0, 0, 1, 1,
0, 0, 1, 1,
0, 0, 1, 1,
0, 0, 1, 1
])
}
}
});
}
}
export default class AppAnimationLoop extends AnimationLoop {
// .context(() => createGLContext({canvas: 'lesson04-canvas'}))
static getInfo() {
return INFO_HTML;
}
onInitialize({gl}) {
setParameters(gl, {
clearColor: [0, 0, 0, 1],
clearDepth: 1,
depthTest: true,
depthFunc: GL.LEQUAL
});
return {
pyramid: new Model(gl, {
vs: VERTEX_SHADER,
fs: FRAGMENT_SHADER,
geometry: new ColoredPyramidGeometry()
}),
cube: new Model(gl, {
vs: VERTEX_SHADER,
fs: FRAGMENT_SHADER,
geometry: new ColoredCubeGeometry()
})
};
}
onRender({gl, tick, aspect, pyramid, cube}) {
gl.clear(GL.COLOR_BUFFER_BIT | GL.DEPTH_BUFFER_BIT);
const projection = new Matrix4().perspective({aspect});
const view = new Matrix4().lookAt({eye: [0, 0, 0]});
pyramid
.setUniforms({
uPMatrix: projection,
uMVMatrix: view
.clone()
.translate([-1.5, 0, -8])
.rotateY(tick * 0.01)
})
.draw();
const phi = tick * 0.01;
cube
.setUniforms({
uPMatrix: projection,
uMVMatrix: view
.clone()
.translate([1.5, 0, -8])
.rotateXYZ([phi, phi, phi])
})
.draw();
}
}
/* global window */
if (typeof window !== 'undefined' && !window.website) {
const animationLoop = new AppAnimationLoop();
animationLoop.start();
}
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/13/package.json
|
{
"version": "0.0.1",
"private": true,
"name": "@rapidsai/demo-luma.gl-lessons-13",
"description": "The classic WebGL Lesson 13 ported to luma.gl.",
"contributors": [
"Jian Huang <[email protected]>"
],
"scripts": {
"start": "webpack-dev-server --progress --hot --open -d",
"start-local": "webpack-dev-server --env.local --progress --hot --open -d"
},
"dependencies": {
"@luma.gl/constants": "8.5.16",
"@luma.gl/core": "8.5.16",
"math.gl": "3.6.3"
}
}
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/13/app.js
|
import GL from '@luma.gl/constants';
import {
AnimationLoop,
Texture2D,
setParameters,
Model,
SphereGeometry,
CubeGeometry
} from '@luma.gl/core';
import {Matrix4, radians} from 'math.gl';
const INFO_HTML = `
<p>
<a href="http://learningwebgl.com/blog/?p=1523" target="_blank">
Per-fragment lighting and multiple programs
</a>
<p>
The classic WebGL Lessons in luma.gl
`;
const FRAGMENT_LIGHTING_VERTEX_SHADER = `\
precision highp float;
attribute vec3 positions;
attribute vec3 normals;
attribute vec2 texCoords;
uniform mat4 uMMatrix;
uniform mat4 uVMatrix;
uniform mat4 uPMatrix;
varying vec2 vTextureCoord;
varying vec4 vTransformedNormal;
varying vec4 vPosition;
void main(void) {
vPosition = uMMatrix * vec4(positions, 1.0);
gl_Position = uPMatrix * uVMatrix * vPosition;
vTextureCoord = texCoords;
vTransformedNormal = uMMatrix * vec4(normals, 0.0);
}
`;
const FRAGMENT_LIGHTING_FRAGMENT_SHADER = `\
precision highp float;
uniform vec3 uAmbientColor;
uniform vec3 uPointLightingLocation;
uniform vec3 uPointLightingColor;
uniform bool uUseLighting;
uniform bool uUseTextures;
varying vec2 vTextureCoord;
varying vec4 vTransformedNormal;
varying vec4 vPosition;
uniform sampler2D uSampler;
void main(void) {
vec3 lightWeighting;
if (!uUseLighting) {
lightWeighting = vec3(1.0, 1.0, 1.0);
} else {
vec3 lightDirection = normalize(uPointLightingLocation - vPosition.xyz);
float pointLightWeighting = max(dot(vTransformedNormal.xyz, lightDirection), 0.0);
lightWeighting = uAmbientColor + uPointLightingColor * pointLightWeighting;
}
vec4 fragmentColor;
if (uUseTextures) {
fragmentColor = texture2D(uSampler, vec2(1.0 - vTextureCoord.s, 1.0 - vTextureCoord.t));
} else {
fragmentColor = vec4(1.0, 1.0, 1.0, 1.0);
}
gl_FragColor = vec4(fragmentColor.rgb * lightWeighting, fragmentColor.a);
}
`;
const appState = {
moonRotationMatrix: new Matrix4().rotateY(radians(180)).translate([2, 0, 0]),
cubeRotationMatrix: new Matrix4().translate([1.25, 0, 0]),
lastTime: 0
};
export default class AppAnimationLoop extends AnimationLoop {
static getInfo() {
return INFO_HTML;
}
onInitialize({canvas, gl}) {
setParameters(gl, {
clearColor: [0, 0, 0, 1],
clearDepth: 1,
depthTest: true
});
const moonTexture = new Texture2D(gl, 'moon.gif');
const crateTexture = new Texture2D(gl, 'crate.gif');
const moon = new Model(gl, {
fs: FRAGMENT_LIGHTING_FRAGMENT_SHADER,
vs: FRAGMENT_LIGHTING_VERTEX_SHADER,
geometry: new SphereGeometry({
nlat: 30,
nlong: 30,
radius: 2
}),
uniforms: {
uSampler: moonTexture
}
});
const cube = new Model(gl, {
fs: FRAGMENT_LIGHTING_FRAGMENT_SHADER,
vs: FRAGMENT_LIGHTING_VERTEX_SHADER,
geometry: new CubeGeometry(),
uniforms: {
uSampler: crateTexture
}
});
return {moon, cube};
}
// eslint-disable-next-line complexity
onRender({gl, tick, aspect, moon, cube}) {
gl.clear(GL.COLOR_BUFFER_BIT | GL.DEPTH_BUFFER_BIT);
// set camera position
const eyePos = new Matrix4().rotateX(radians(-30)).transform([0, 0, 10]);
// TypeError: (intermediate value).rotateX(...).transformVector3 is not a function
const uVMatrix = new Matrix4().lookAt({eye: eyePos, center: [0, 0, 0], up: [0, 1, 0]});
const useLighting = true;
const useTextures = true;
const ambientColor = [0.1, 0.1, 0.1];
const pointLightingLocation = [4, 4, 4];
const pointLightColor = [1.0, 0.8, 0.8];
moon.setUniforms({
uUseLighting: useLighting,
uUseTextures: useTextures
});
cube.setUniforms({
uUseLighting: useLighting,
uUseTextures: useTextures
});
if (useLighting) {
moon.setUniforms({
uAmbientColor: ambientColor,
uPointLightingLocation: pointLightingLocation,
uPointLightingColor: pointLightColor
});
cube.setUniforms({
uAmbientColor: ambientColor,
uPointLightingLocation: pointLightingLocation,
uPointLightingColor: pointLightColor
});
}
moon
.setUniforms({
uMMatrix: appState.moonRotationMatrix,
uVMatrix,
uPMatrix: new Matrix4().perspective({
fov: (45 * Math.PI) / 180,
aspect,
near: 0.1,
far: 100
})
})
.draw();
cube
.setUniforms({
uMMatrix: appState.cubeRotationMatrix,
uVMatrix,
uPMatrix: new Matrix4().perspective({
fov: (45 * Math.PI) / 180,
aspect,
near: 0.1,
far: 100
})
})
.draw();
animate(appState);
}
}
function animate(state) {
const timeNow = new Date().getTime();
if (state.lastTime !== 0) {
const elapsed = timeNow - state.lastTime;
const newMatrix = new Matrix4().rotateY(radians(elapsed / 20));
state.moonRotationMatrix.multiplyLeft(newMatrix);
state.cubeRotationMatrix.multiplyLeft(newMatrix);
}
state.lastTime = timeNow;
}
/* global window */
if (typeof window !== 'undefined' && !window.website) {
const animationLoop = new AppAnimationLoop();
animationLoop.start();
}
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/11/package.json
|
{
"version": "0.0.1",
"private": true,
"name": "@rapidsai/demo-luma.gl-lessons-11",
"description": "The classic WebGL Lesson 11 ported to luma.gl.",
"contributors": [
"Jian Huang <[email protected]>"
],
"scripts": {
"start": "webpack-dev-server --progress --hot --open -d",
"start-local": "webpack-dev-server --env.local --progress --hot --open -d"
},
"dependencies": {
"@luma.gl/constants": "8.5.16",
"@luma.gl/core": "8.5.16",
"math.gl": "3.6.3",
"mjolnir.js": "2.5.2"
}
}
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/11/app.js
|
import GL from '@luma.gl/constants';
import {AnimationLoop, setParameters, Texture2D, Model, SphereGeometry} from '@luma.gl/core';
import {Vector3, Matrix4} from 'math.gl';
import {EventManager} from 'mjolnir.js';
/* eslint-disable complexity */
const INFO_HTML = `
<p>
<a href="http://learningwebgl.com/blog/?p=1253" target="_blank">
Models, rotation matrices, and mouse events
</a>
<br/>
<br/>
(Rotate the moon with the mouse)
<p>
The classic WebGL Lessons in luma.gl
`;
const VERTEX_SHADER = `\
attribute vec3 positions;
attribute vec3 normals;
attribute vec2 texCoords;
uniform mat4 uMMatrix;
uniform mat4 uVMatrix;
uniform mat4 uPMatrix;
uniform vec3 uAmbientColor;
uniform vec3 uLightingDirection;
uniform vec3 uDirectionalColor;
uniform bool uUseLighting;
varying vec2 vTextureCoord;
varying vec3 vLightWeighting;
void main(void) {
gl_Position = uPMatrix * uVMatrix * uMMatrix * vec4(positions, 1.0);
vTextureCoord = texCoords;
if (!uUseLighting) {
vLightWeighting = vec3(1.0, 1.0, 1.0);
} else {
vec4 transformedNormal = uMMatrix * vec4(normals, 1.0);
vec3 newNormal = transformedNormal.xyz / transformedNormal.w;
float directionalLightWeighting = max(dot(newNormal, uLightingDirection), 0.0);
vLightWeighting = uAmbientColor + uDirectionalColor * directionalLightWeighting;
}
}
`;
const FRAGMENT_SHADER = `\
precision highp float;
varying vec2 vTextureCoord;
varying vec3 vLightWeighting;
uniform sampler2D uSampler;
void main(void) {
vec4 textureColor = texture2D(uSampler, vec2(1.0 - vTextureCoord.s, 1.0 - vTextureCoord.t));
gl_FragColor = vec4(textureColor.rgb * vLightWeighting, textureColor.a);
}
`;
const appState = {
mouseDown: false,
lastMouseX: null,
lastMouseY: null,
moonRotationMatrix: new Matrix4()
};
export default class AppAnimationLoop extends AnimationLoop {
static getInfo() {
return INFO_HTML;
}
onInitialize({canvas, gl}) {
// Use mjolnir.js (hammer.js)'s EventManager to handle gestures on both
// desktop and mobile
this.eventManager = new EventManager(canvas);
addMouseHandler(this.eventManager);
setParameters(gl, {
clearColor: [0, 0, 0, 1],
clearDepth: 1,
depthTest: true
});
return {
moon: new Model(gl, {
fs: FRAGMENT_SHADER,
vs: VERTEX_SHADER,
geometry: new SphereGeometry({
nlat: 30,
nlong: 30,
radius: 2
}),
uniforms: {
uSampler: new Texture2D(gl, 'moon.gif')
}
})
};
}
// eslint-disable-next-line complexity
onRender({gl, tick, aspect, moon}) {
// Update Camera Position
const eyePos = [0, 0, 6];
gl.clear(GL.COLOR_BUFFER_BIT | GL.DEPTH_BUFFER_BIT);
const uMMatrix = new Matrix4().multiplyRight(appState.moonRotationMatrix);
const uVMatrix = new Matrix4().lookAt({eye: eyePos, center: [0, 0, 0], up: [0, 1, 0]});
// Read controls
const {lighting, ambientColor, lightingDirection, directionalColor} = getControlValues();
moon.setUniforms({uUseLighting: lighting});
if (lighting) {
lightingDirection.normalize();
lightingDirection.scale(-1);
moon.setUniforms({
uAmbientColor: ambientColor,
uLightingDirection: lightingDirection,
uDirectionalColor: directionalColor
});
}
return moon
.setUniforms({
uMMatrix,
uVMatrix,
uPMatrix: new Matrix4().perspective({
fov: (45 * Math.PI) / 180,
aspect,
near: 0.1,
far: 100
})
})
.draw();
}
onFinalize() {
this.eventManager.destroy();
}
}
function addMouseHandler(eventManager) {
eventManager.on({
panstart(event) {
appState.mouseDown = true;
appState.lastMouseX = event.offsetCenter.x;
appState.lastMouseY = event.offsetCenter.y;
},
panmove(event) {
if (!appState.mouseDown) {
return;
}
if (appState.lastMouseX !== undefined) {
const radiansX = (event.offsetCenter.x - appState.lastMouseX) / 300;
const radiansY = (event.offsetCenter.y - appState.lastMouseY) / 300;
const newMatrix = new Matrix4().rotateX(radiansY).rotateY(radiansX);
appState.moonRotationMatrix.multiplyLeft(newMatrix);
}
appState.lastMouseX = event.offsetCenter.x;
appState.lastMouseY = event.offsetCenter.y;
},
panend(e) {
appState.mouseDown = false;
}
});
}
function getControlValues() {
/* global document */
function getElementValue(id, defaultValue) {
return defaultValue;
// const element = document.getElementById(id);
// return element ? parseFloat(element.value) : defaultValue;
}
const lighting = true;
// const element = document.getElementById('lighting');
// const lighting = element ? element.checked : true;
const ambientColor =
lighting &&
new Vector3(
getElementValue('ambientR', 0.2),
getElementValue('ambientG', 0.2),
getElementValue('ambientB', 0.2)
);
const lightingDirection =
lighting &&
new Vector3(
getElementValue('lightDirectionX', -1),
getElementValue('lightDirectionY', -1),
getElementValue('lightDirectionZ', -1)
);
const directionalColor =
lighting &&
new Vector3(
getElementValue('directionalR', 0.8),
getElementValue('directionalG', 0.8),
getElementValue('directionalB', 0.8)
);
return {lighting, ambientColor, lightingDirection, directionalColor};
}
/* global window */
if (typeof window !== 'undefined' && !window.website) {
const animationLoop = new AppAnimationLoop();
animationLoop.start();
}
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/01/package.json
|
{
"version": "0.0.1",
"private": true,
"name": "@rapidsai/demo-luma.gl-lessons-01",
"scripts": {
"start": "webpack-dev-server --progress --hot --open -d",
"start-local": "webpack-dev-server --env.local --progress --hot --open -d"
},
"dependencies": {
"@luma.gl/core": "8.5.16",
"math.gl": "3.6.3"
}
}
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/01/app.js
|
import {AnimationLoop, setParameters} from '@luma.gl/core';
import {Program, VertexArray, Buffer} from '@luma.gl/webgl';
import {Matrix4} from 'math.gl';
const INFO_HTML = `
<p>
<a href="http://learningwebgl.com/blog/?p=28" target="_blank">
A Triangle and a Square
</a>
<p>
The classic WebGL Lessons in luma.gl
`;
const VERTEX_SHADER = `\
attribute vec3 positions;
uniform mat4 uMVMatrix;
uniform mat4 uPMatrix;
void main(void) {
gl_Position = uPMatrix * uMVMatrix * vec4(positions, 1.0);
}
`;
const FRAGMENT_SHADER = `\
precision highp float;
void main(void) {
gl_FragColor = vec4(1.0, 1.0, 1.0, 1.0);
}
`;
export default class AppAnimationLoop extends AnimationLoop {
static getInfo() {
return INFO_HTML;
}
constructor(props = {}) {
super(Object.assign(props, {debug: true}));
}
onInitialize({gl, canvas, aspect}) {
const TRIANGLE_VERTS = [0, 1, 0, -1, -1, 0, 1, -1, 0]; // eslint-disable-line
const SQUARE_VERTS = [1, 1, 0, -1, 1, 0, 1, -1, 0, -1, -1, 0]; // eslint-disable-line
const program = new Program(gl, {
vs: VERTEX_SHADER,
fs: FRAGMENT_SHADER
});
const triangleVertexArray = new VertexArray(gl, {
program,
attributes: {
positions: new Buffer(gl, new Float32Array(TRIANGLE_VERTS))
}
});
const squareVertexArray = new VertexArray(gl, {
program,
attributes: {
positions: new Buffer(gl, new Float32Array(SQUARE_VERTS))
}
});
const view = new Matrix4().translate([-1.5, 0, -7]);
const projection = new Matrix4().perspective({aspect});
setParameters(gl, {
clearColor: [0, 0, 0, 1],
clearDepth: [1],
depthTest: true,
depthFunc: gl.LEQUAL
});
gl.clear(gl.COLOR_BUFFER_BIT | gl.DEPTH_BUFFER_BIT);
program
.setUniforms({
uMVMatrix: view,
uPMatrix: projection
})
.draw({
vertexArray: triangleVertexArray,
drawMode: gl.TRIANGLES,
vertexCount: 3
});
// Draw Square
view.translate([3, 0, 0]);
program
.setUniforms({
uMVMatrix: view,
uPMatrix: projection
})
.draw({
vertexArray: squareVertexArray,
drawMode: gl.TRIANGLE_STRIP,
vertexCount: 4
});
}
}
/* global window */
if (typeof window !== 'undefined' && !window.website) {
const animationLoop = new AppAnimationLoop();
animationLoop.start();
}
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/16/WebGLExport.py
|
#!BPY
"""
Name: 'WebGL JavaScript (.js)'
Blender: 244
Group: 'Export'
Tooltip: 'WebGL JavaScript'
"""
# --------------------------------------------------------------------------
# ***** BEGIN GPL LICENSE BLOCK *****
#
# Copyright (C) 2010 Dennis Ippel
#
# This program is free software; you can redistribute it and/or
# modify it under the terms of the GNU General Public License
# as published by the Free Software Foundation; either version 2
# of the License, or (at your option) any later version.
#
# This program is distributed in the hope that it will be useful,
# but WITHOUT ANY WARRANTY; without even the implied warranty of
# MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. See the
# GNU General Public License for more details.
#
# You should have received a copy of the GNU General Public License
# along with this program; if not, write to the Free Software Foundation,
# Inc., 59 Temple Place - Suite 330, Boston, MA 02111-1307, USA.
#
# ***** END GPL LICENCE BLOCK *****
# --------------------------------------------------------------------------
__author__ = "Dennis Ippel"
__url__ = ("http://www.rozengain.com")
__version__ = "0.2"
__bpydoc__ = """
For more information please go to:
http://www.rozengain.com
"""
import Blender
from Blender import *
import bpy
import bpy
import os
from Blender.BGL import *
EVENT_NOEVENT = 1
EVENT_DRAW = 2
EVENT_EXIT = 3
EVENT_EXPORT = 4
EVENT_BROWSEFILE = 5
file_button = Draw.Create("")
engine_menu = Draw.Create(1)
exp_all = Draw.Create(0)
exp_normals = Draw.Create(0)
animation_button = Draw.Create(0)
animation_start = Draw.Create(0)
animation_end = Draw.Create(0)
def export_scenejs(class_name, mesh):
s = "var BlenderExport = {};\n"
s += "BlenderExport.%s = function() {\n" % (class_name)
s += "return SceneJS.geometry({\n"
s += "type: \'%s\',\n" % (class_name)
vertices = "vertices : ["
indices = "indices : ["
indexcount = 0;
print len(mesh.faces)
for f in mesh.faces:
vertices += "[%.6f,%.6f,%.6f],[%.6f,%.6f,%.6f],[%.6f,%.6f,%.6f]," % (f.verts[0].co.x, f.verts[0].co.y, f.verts[0].co.z,f.verts[1].co.x, f.verts[1].co.y, f.verts[1].co.z,f.verts[2].co.x, f.verts[2].co.y, f.verts[2].co.z)
indices += "[%i,%i,%i]," % (indexcount,indexcount+1,indexcount+2)
indexcount += 3
indices += "],\n";
vertices += "],\n";
s += vertices
s += indices
if(exp_normals == 1):
s += "normals : ["
for v in mesh.verts:
s += "[%.6f, %.6f, %.6f]," % (v.no.x, v.no.y, v.no.z)
s += "],\n"
if (mesh.vertexColors):
s += "colors : ["
for face in mesh.faces:
for (vert, color) in zip(face.verts, face.col):
s += "[%.6f,%.6f,%.6f,%.6f]," % ( color.r / 255.0, color.g / 255.0, color.b / 255.0, color.a / 255.0)
s += "]\n"
if (mesh.faceUV):
s += "texCoords : ["
for face in mesh.faces:
s += "[%.6f,%.6f],[%.6f,%.6f],[%.6f,%.6f]," % (face.uv[0][0], face.uv[0][1], face.uv[1][0], face.uv[1][1], face.uv[2][0], face.uv[2][1])
s += "]\n"
s += "});\n};"
return s
def export_native(class_name, mesh, ob):
s = "var BlenderExport = {};\n"
s += "BlenderExport.%s = {};\n" % (class_name)
vertices = "BlenderExport.%s.vertices = [" % (class_name)
indices = "BlenderExport.%s.indices = [" % (class_name)
indexcount = 0;
for f in mesh.faces:
vertices += "%.6f,%.6f,%.6f,%.6f,%.6f,%.6f,%.6f,%.6f,%.6f," % (f.verts[0].co.x, f.verts[0].co.y, f.verts[0].co.z,f.verts[1].co.x, f.verts[1].co.y, f.verts[1].co.z,f.verts[2].co.x, f.verts[2].co.y, f.verts[2].co.z)
indexcount += 3
indices += "];\n";
vertices += "];\n";
s += vertices
s += indices
s += "for(var i=0;i<%s;i++) BlenderExport.%s.indices.push(i);\n" % (indexcount, class_name)
if(exp_normals == 1):
s += "BlenderExport.%s.normals = [" % (class_name)
for v in mesh.verts:
s += "%.6f, %.6f, %.6f," % (v.no.x, v.no.y, v.no.z)
s += "];\n"
if (mesh.vertexColors):
s += "BlenderExport.%s.colors = [" % (class_name)
for face in mesh.faces:
for (vert, color) in zip(face.verts, face.col):
s += "%.6f,%.6f,%.6f,%.6f," % ( color.r / 255.0, color.g / 255.0, color.b / 255.0, color.a / 255.0)
s += "];\n"
if (mesh.faceUV):
s += "BlenderExport.%s.texCoords = [" % (class_name)
for face in mesh.faces:
s += "%.6f,%.6f,%.6f,%.6f,%.6f,%.6f," % (face.uv[0][0], face.uv[0][1], face.uv[1][0], face.uv[1][1], face.uv[2][0], face.uv[2][1])
s += "];\n"
if animation_button.val:
s += "BlenderExport.%s.frames = [" % (class_name)
matrix = ob.getMatrix('worldspace')
for frame in xrange(animation_start.val, animation_end.val):
Blender.Set('curframe', frame)
tmpMesh = Mesh.New()
tmpMesh.getFromObject(ob.name)
tmpMesh.transform(matrix)
s+= "["
for f in tmpMesh.faces:
for v in f.verts:
s += "%.6f,%.6f,%.6f," % (v.co.x, v.co.y, v.co.z)
s += "],"
s += "];"
return s
def export_json(objects):
result = []
result.append('{\n')
for obj in objects:
mesh = Mesh.New()
mesh.getFromObject(obj, 0)
indexCount = 0
positions = []
normals = []
textureCoords = []
for face in mesh.faces:
for vertex in face.verts:
positions.extend(('%.6f' % value) for value in (vertex.co.x, vertex.co.y, vertex.co.z))
if exp_normals == 1:
normals.extend(('%.6f' % value) for value in (vertex.no.x, vertex.no.y, vertex.no.z))
if mesh.faceUV:
textureCoords.extend(('%.6f' % value) for value in (face.uv[0][0], face.uv[0][1], face.uv[1][0], face.uv[1][1], face.uv[2][0], face.uv[2][1]))
indexCount += 3
result.append('\t"%s" : {\n' % obj.name)
result.append('\t\t"vertexPositions" : [')
result.extend(', '.join(positions))
result.append('],\n')
if exp_normals == 1:
result.append('\t\t"vertexNormals" : [')
result.extend(', '.join(normals))
result.append('],\n')
result.append('\t\t"vertexTextureCoords" : [')
result.extend(', '.join(textureCoords))
result.append('],\n')
result.append('\t\t"indices" : [')
result.append(', '.join(str(i) for i in range(indexCount)))
result.append(']\n')
result.append('\t},\n')
result.append('}\n')
return ''.join(result)
def export_glge_js(class_name, mesh):
s = "var BlenderExport = {};\n"
s += "BlenderExport.%s = function() {\n" % (class_name)
s += "var obj=new GLGE.Object(\'%s\');\n" % (class_name)
s += "var mesh=new GLGE.Mesh();\n"
vertices = "mesh.setPositions(["
normals = "mesh.setNormals(["
uvs = "mesh.setUV(["
indices = "mesh.setFaces(["
indexcount = 0;
for f in mesh.faces:
vertices += "%.6f,%.6f,%.6f,%.6f,%.6f,%.6f,%.6f,%.6f,%.6f," % (f.verts[0].co.x, f.verts[0].co.y, f.verts[0].co.z,f.verts[1].co.x, f.verts[1].co.y, f.verts[1].co.z,f.verts[2].co.x, f.verts[2].co.y, f.verts[2].co.z)
if (f.smooth):
normals += "%.6f,%.6f,%.6f,%.6f,%.6f,%.6f,%.6f,%.6f,%.6f," % (f.verts[0].no.x, f.verts[0].no.y, f.verts[0].no.z,f.verts[1].no.x, f.verts[1].no.y, f.verts[1].no.z,f.verts[2].no.x, f.verts[2].no.y, f.verts[2].no.z)
else:
normals += "%.6f,%.6f,%.6f,%.6f,%.6f,%.6f,%.6f,%.6f,%.6f," % (f.no.x, f.no.y, f.no.z,f.no.x, f.no.y, f.no.z,f.no.x, f.no.y, f.no.z)
if (mesh.faceUV):
uvs += "%.6f,%.6f,%.6f,%.6f,%.6f,%.6f," % (f.uv[0][0], f.uv[0][1], f.uv[1][0], f.uv[1][1], f.uv[2][0], f.uv[2][1])
indices += "%i,%i,%i," % (indexcount,indexcount+1,indexcount+2)
indexcount += 3
indicies=indices[:len(indices)-1]
normals=normals[:len(normals)-1]
if (mesh.faceUV):
uvs=uvs[:len(uvs)-1]
vertices=vertices[:len(vertices)-1]
indices += "]);\n";
normals += "]);\n";
uvs += "]);\n";
vertices += "]);\n";
s += vertices
s += normals
if (mesh.faceUV):
s += uvs
s += indices
s += "var material=new GLGE.Material();\n"
s += "obj.setMaterial(material);\n"
s += "obj.setMesh(mesh);\n"
s += "return obj;\n};"
print s
return s
def export_glge_xml(class_name, mesh):
s = "<?xml version=\"1.0\" ?>\n"
s += "<glge>\n"
s += "<mesh id=\"%s\">\n" % (class_name)
vertices = "<positions>"
normals = "<normals>"
uvs = "<uv>"
indices = "<faces>"
indexcount = 0;
for f in mesh.faces:
vertices += "%.6f,%.6f,%.6f,%.6f,%.6f,%.6f,%.6f,%.6f,%.6f," % (f.verts[0].co.x, f.verts[0].co.y, f.verts[0].co.z,f.verts[1].co.x, f.verts[1].co.y, f.verts[1].co.z,f.verts[2].co.x, f.verts[2].co.y, f.verts[2].co.z)
if (f.smooth):
normals += "%.6f,%.6f,%.6f,%.6f,%.6f,%.6f,%.6f,%.6f,%.6f," % (f.verts[0].no.x, f.verts[0].no.y, f.verts[0].no.z,f.verts[1].no.x, f.verts[1].no.y, f.verts[1].no.z,f.verts[2].no.x, f.verts[2].no.y, f.verts[2].no.z)
else:
normals += "%.6f,%.6f,%.6f,%.6f,%.6f,%.6f,%.6f,%.6f,%.6f," % (f.no.x, f.no.y, f.no.z,f.no.x, f.no.y, f.no.z,f.no.x, f.no.y, f.no.z)
if (mesh.faceUV):
uvs += "%.6f,%.6f,%.6f,%.6f,%.6f,%.6f," % (f.uv[0][0], f.uv[0][1], f.uv[1][0], f.uv[1][1], f.uv[2][0], f.uv[2][1])
indices += "%i,%i,%i," % (indexcount,indexcount+1,indexcount+2)
indexcount += 3
indicies=indices[:len(indices)-1]
normals=normals[:len(normals)-1]
uvs=uvs[:len(uvs)-1]
vertices=vertices[:len(vertices)-1]
indices += "</faces>\n";
normals += "</normals>;\n";
uvs += "</uv>\n";
vertices += "</positions>\n";
s += vertices
s += normals
if (mesh.faceUV):
s += uvs
s += indices
s += "</mesh>\n"
s += "</glge>"
return s
def event(evt, val):
if (evt == Draw.QKEY and not val):
Draw.Exit()
def bevent(evt):
global EVENT_NOEVENT,EVENT_DRAW,EVENT_EXIT
if (evt == EVENT_EXIT):
Draw.Exit()
elif (evt== EVENT_DRAW):
Draw.Redraw()
elif (evt== EVENT_EXPORT):
sce = bpy.data.scenes.active
obs = None
if(exp_all == 1):
# export all scene objects
obs = [ob for ob in sce.objects if ob.type == 'Mesh']
else:
# export the selected objects
obs = [ob for ob in sce.objects.selected if ob.type == 'Mesh']
if (len(obs) == 0):
Draw.PupMenu("Nothing to export. Please select a Mesh.")
Draw.Exit()
return
if engine_menu.val == 6:
filename = file_button.val
if not filename.endswith(".json"):
filename += ".json"
out = open(filename, 'w')
out.write(export_json(obs))
out.close()
else:
# export all object names to separate files
for ob in obs:
me = Mesh.New()
me.getFromObject(ob,0)
class_name = ob.name.replace(".", "")
ext = ""
if(engine_menu.val ==4): ext = ".xml"
else: ext = ".js"
out = open(file_button.val+""+class_name+ext, 'w')#file(file_button.val, 'w')
data_string = ""
if (engine_menu.val == 1):
data_string = export_native(class_name, me, ob)
elif(engine_menu.val == 2):
data_string = export_scenejs(class_name, me)
elif(engine_menu.val == 3):
data_string = export_glge_js(class_name, me)
elif(engine_menu.val == 4):
data_string = export_glge_xml(class_name, me)
elif(engine_menu.val == 5):
data_string = export_copperlicht(class_name, me)
out.write(data_string)
out.close()
Draw.PupMenu("Export Successful")
elif (evt== EVENT_BROWSEFILE):
if (engine_menu.val == 4):
Window.FileSelector(FileSelected,"Export .xml", exp_file_name)
elif (engine_menu.val == 6):
Window.FileSelector(FileSelected,"Export .json", exp_file_name)
else:
Window.FileSelector(FileSelected,"Export .js", exp_file_name)
Draw.Redraw(1)
def FileSelected(file_name):
global file_button
if file_name != '':
file_button.val = file_name
else:
cutils.Debug.Debug('ERROR: filename is empty','ERROR')
def draw():
global file_button, exp_file_name, animation_button, animation_start, animation_end
global engine_menu, engine_name, exp_normals, exp_all
global EVENT_NOEVENT, EVENT_DRAW, EVENT_EXIT, EVENT_EXPORT
exp_file_name = ""
glClear(GL_COLOR_BUFFER_BIT)
glRasterPos2i(40, 240)
engine_name = "Native WebGL%x1|SceneJS%x2|GLGE JS%x3|GLGE XML%x4|JSON%x6"
engine_menu = Draw.Menu(engine_name, EVENT_NOEVENT, 40, 100, 200, 20, engine_menu.val, "Choose your engine")
file_button = Draw.String('File location: ', EVENT_NOEVENT, 40, 70, 250, 20, file_button.val, 255)
Draw.PushButton('...', EVENT_BROWSEFILE, 300, 70, 30, 20, 'browse file')
exp_normals = Draw.Toggle('Export normals', EVENT_NOEVENT, 250, 45, 100, 20, exp_normals.val)
anim_down = 0
if animation_button.val == 1:
anim_down = 1
animation_button = Draw.Toggle('Export animation frames (native WebGL only)', EVENT_NOEVENT, 400, 70, 300, 20, animation_button.val, 'Export keyframe animation')
animation_start = Draw.Number('Start frame', EVENT_NOEVENT, 400, 45, 160, 20, animation_start.val, 1, 9999)
animation_end = Draw.Number('End frame', EVENT_NOEVENT, 400, 20, 160, 20, animation_end.val, 2, 9999)
exp_all = Draw.Toggle('Export ALL scene objects', EVENT_NOEVENT, 40, 45, 200, 20, exp_all.val)
Draw.Button("Export",EVENT_EXPORT , 40, 20, 80, 18)
Draw.Button("Exit",EVENT_EXIT , 140, 20, 80, 18)
Draw.Register(draw, event, bevent)
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/16/package.json
|
{
"version": "0.0.1",
"private": true,
"name": "@rapidsai/demo-luma.gl-lessons-16",
"scripts": {
"start": "webpack-dev-server --progress --hot --open -d",
"start-local": "webpack-dev-server --env.local --progress --hot --open -d"
},
"dependencies": {
"@loaders.gl/images": "3.2.9",
"@luma.gl/constants": "8.5.16",
"@luma.gl/core": "8.5.16",
"@luma.gl/experimental": "8.5.16",
"@luma.gl/shadertools": "8.5.16",
"math.gl": "3.6.3"
}
}
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/16/macbook.json
|
{"vertices":[0.132473,-0.019556,0.061144,-0.223287,-0.019556,0.061144,-0.223287,-0.019556,0.074144,0.132473,-0.019556,0.074144,-0.223287,-0.019556,0.061144,-0.224575,-0.019715,0.061144,-0.224575,-0.019715,0.074144,-0.223287,-0.019556,0.061144,-0.224575,-0.019715,0.074144,-0.223287,-0.019556,0.074144,-0.224575,-0.019715,0.061144,-0.225759,-0.020166,0.061144,-0.225759,-0.020166,0.074144,-0.224575,-0.019715,0.074144,-0.225759,-0.020166,0.061144,-0.226803,-0.020875,0.061144,-0.226803,-0.020875,0.074144,-0.225759,-0.020166,0.061144,-0.226803,-0.020875,0.074144,-0.225759,-0.020166,0.074144,-0.226803,-0.020875,0.061144,-0.227674,-0.021804,0.061144,-0.227674,-0.021804,0.074144,-0.226803,-0.020875,0.061144,-0.227674,-0.021804,0.074144,-0.226803,-0.020875,0.074144,-0.227674,-0.021804,0.061144,-0.228339,-0.022919,0.061144,-0.228339,-0.022919,0.074144,-0.227674,-0.021804,0.074144,-0.228339,-0.022919,0.061144,-0.228762,-0.024181,0.061144,-0.228762,-0.024181,0.074144,-0.228339,-0.022919,0.061144,-0.228762,-0.024181,0.074144,-0.228339,-0.022919,0.074144,-0.228762,-0.024181,0.061144,-0.228911,-0.025556,0.061144,-0.228911,-0.025556,0.074144,-0.228762,-0.024181,0.061144,-0.228911,-0.025556,0.074144,-0.228762,-0.024181,0.074144,-0.228911,-0.025556,0.061144,-0.228911,-0.070704,0.061144,-0.228911,-0.070704,0.074144,-0.228911,-0.025556,0.074144,-0.228911,-0.070704,0.061144,-0.228762,-0.072079,0.061144,-0.228762,-0.072079,0.074144,-0.228911,-0.070704,0.074144,-0.228762,-0.072079,0.061144,-0.228339,-0.073341,0.061144,-0.228339,-0.073341,0.074144,-0.228762,-0.072079,0.061144,-0.228339,-0.073341,0.074144,-0.228762,-0.072079,0.074144,-0.228339,-0.073341,0.061144,-0.227674,-0.074455,0.061144,-0.227674,-0.074455,0.074144,-0.228339,-0.073341,0.074144,-0.227674,-0.074455,0.061144,-0.226803,-0.075385,0.061144,-0.226803,-0.075385,0.074144,-0.227674,-0.074455,0.074144,-0.226803,-0.075385,0.061144,-0.225759,-0.076094,0.061144,-0.225759,-0.076094,0.074144,-0.226803,-0.075385,0.074144,-0.225759,-0.076094,0.061144,-0.224575,-0.076545,0.061144,-0.224575,-0.076545,0.074144,-0.225759,-0.076094,0.061144,-0.224575,-0.076545,0.074144,-0.225759,-0.076094,0.074144,-0.224575,-0.076545,0.061144,-0.223287,-0.076704,0.061144,-0.223287,-0.076704,0.074144,-0.224575,-0.076545,0.061144,-0.223287,-0.076704,0.074144,-0.224575,-0.076545,0.074144,-0.223287,-0.076704,0.061144,0.132473,-0.076704,0.061144,0.132473,-0.076704,0.074144,-0.223287,-0.076704,0.074144,0.132473,-0.076704,0.061144,0.133761,-0.076545,0.061144,0.133761,-0.076545,0.074144,0.132473,-0.076704,0.061144,0.133761,-0.076545,0.074144,0.132473,-0.076704,0.074144,0.133761,-0.076545,0.061144,0.134945,-0.076093,0.061144,0.134945,-0.076093,0.074144,0.133761,-0.076545,0.074144,0.134945,-0.076093,0.061144,0.135989,-0.075385,0.061144,0.135989,-0.075385,0.074144,0.134945,-0.076093,0.061144,0.135989,-0.075385,0.074144,0.134945,-0.076093,0.074144,0.135989,-0.075385,0.061144,0.13686,-0.074455,0.061144,0.13686,-0.074455,0.074144,0.135989,-0.075385,0.074144,0.13686,-0.074455,0.061144,0.137525,-0.073341,0.061144,0.137525,-0.073341,0.074144,0.13686,-0.074455,0.074144,0.137525,-0.073341,0.061144,0.137948,-0.072079,0.061144,0.137948,-0.072079,0.074144,0.137525,-0.073341,0.074144,0.137948,-0.072079,0.061144,0.138097,-0.070704,0.061144,0.138097,-0.070704,0.074144,0.137948,-0.072079,0.074144,0.138097,-0.070704,0.061144,0.138097,-0.025556,0.061144,0.138097,-0.025556,0.074144,0.138097,-0.070704,0.074144,0.138097,-0.025556,0.061144,0.137948,-0.024181,0.061144,0.137948,-0.024181,0.074144,0.138097,-0.025556,0.074144,0.137948,-0.024181,0.061144,0.137525,-0.022919,0.061144,0.137525,-0.022919,0.074144,0.137948,-0.024181,0.061144,0.137525,-0.022919,0.074144,0.137948,-0.024181,0.074144,0.137525,-0.022919,0.061144,0.13686,-0.021804,0.061144,0.13686,-0.021804,0.074144,0.137525,-0.022919,0.061144,0.13686,-0.021804,0.074144,0.137525,-0.022919,0.074144,0.13686,-0.021804,0.061144,0.135989,-0.020875,0.061144,0.135989,-0.020875,0.074144,0.13686,-0.021804,0.074144,0.135989,-0.020875,0.061144,0.134945,-0.020166,0.061144,0.134945,-0.020166,0.074144,0.135989,-0.020875,0.061144,0.134945,-0.020166,0.074144,0.135989,-0.020875,0.074144,0.134945,-0.020166,0.061144,0.133761,-0.019714,0.061144,0.133761,-0.019714,0.074144,0.134945,-0.020166,0.061144,0.133761,-0.019714,0.074144,0.134945,-0.020166,0.074144,0.133761,-0.019714,0.061144,0.132473,-0.019556,0.061144,0.132473,-0.019556,0.074144,0.133761,-0.019714,0.061144,0.132473,-0.019556,0.074144,0.133761,-0.019714,0.074144,0.39215,0.312901,0.061144,0.390966,0.312449,0.061144,0.390966,0.312449,0.074144,0.39215,0.312901,0.061144,0.390966,0.312449,0.074144,0.39215,0.312901,0.074144,0.390966,0.312449,0.061144,0.389922,0.31174,0.061144,0.389922,0.31174,0.074144,0.390966,0.312449,0.074144,0.389922,0.31174,0.061144,0.389051,0.310811,0.061144,0.389051,0.310811,0.074144,0.389922,0.31174,0.074144,0.389051,0.310811,0.061144,0.388387,0.309697,0.061144,0.388387,0.309697,0.074144,0.389051,0.310811,0.074144,0.388387,0.309697,0.061144,0.387963,0.308434,0.061144,0.387963,0.308434,0.074144,0.388387,0.309697,0.074144,0.387963,0.308434,0.061144,0.387814,0.307059,0.061144,0.387814,0.307059,0.074144,0.387963,0.308434,0.074144,0.387814,0.307059,0.061144,0.387814,0.286911,0.061144,0.387814,0.286911,0.074144,0.387814,0.307059,0.074144,0.387814,0.286911,0.061144,0.387963,0.285536,0.061144,0.387963,0.285536,0.074144,0.387814,0.286911,0.074144,0.387963,0.285536,0.061144,0.388387,0.284274,0.061144,0.388387,0.284274,0.074144,0.387963,0.285536,0.074144,0.388387,0.284274,0.061144,0.389051,0.28316,0.061144,0.389051,0.28316,0.074144,0.388387,0.284274,0.074144,0.389051,0.28316,0.061144,0.389922,0.28223,0.061144,0.389922,0.28223,0.074144,0.389051,0.28316,0.074144,0.389922,0.28223,0.061144,0.390967,0.281522,0.061144,0.390967,0.281522,0.074144,0.389922,0.28223,0.074144,0.390967,0.281522,0.061144,0.39215,0.28107,0.061144,0.39215,0.28107,0.074144,0.390967,0.281522,0.074144,0.39215,0.28107,0.061144,0.393439,0.280911,0.061144,0.393439,0.280911,0.074144,0.39215,0.28107,0.074144,0.393439,0.280911,0.061144,0.443721,0.280911,0.061144,0.443721,0.280911,0.074144,0.393439,0.280911,0.074144,0.443721,0.280911,0.061144,0.44501,0.28107,0.061144,0.44501,0.28107,0.074144,0.443721,0.280911,0.074144,0.44501,0.28107,0.061144,0.446193,0.281522,0.061144,0.446193,0.281522,0.074144,0.44501,0.28107,0.074144,0.446193,0.281522,0.061144,0.447238,0.28223,0.061144,0.447238,0.28223,0.074144,0.446193,0.281522,0.074144,0.447238,0.28223,0.061144,0.448109,0.28316,0.061144,0.448109,0.28316,0.074144,0.447238,0.28223,0.074144,0.448109,0.28316,0.061144,0.448773,0.284274,0.061144,0.448773,0.284274,0.074144,0.448109,0.28316,0.074144,0.448773,0.284274,0.061144,0.449197,0.285536,0.061144,0.449197,0.285536,0.074144,0.448773,0.284274,0.074144,0.449197,0.285536,0.061144,0.449345,0.286911,0.061144,0.449345,0.286911,0.074144,0.449197,0.285536,0.074144,0.449345,0.286911,0.061144,0.449345,0.307059,0.061144,0.449345,0.307059,0.074144,0.449345,0.286911,0.074144,0.449345,0.307059,0.061144,0.449197,0.308434,0.061144,0.449197,0.308434,0.074144,0.449345,0.307059,0.074144,0.449197,0.308434,0.061144,0.448773,0.309697,0.061144,0.448773,0.309697,0.074144,0.449197,0.308434,0.074144,0.448773,0.309697,0.061144,0.448109,0.310811,0.061144,0.448109,0.310811,0.074144,0.448773,0.309697,0.074144,0.448109,0.310811,0.061144,0.447238,0.31174,0.061144,0.447238,0.31174,0.074144,0.448109,0.310811,0.074144,0.447238,0.31174,0.061144,0.446193,0.312449,0.061144,0.446193,0.312449,0.074144,0.447238,0.31174,0.074144,0.446193,0.312449,0.061144,0.44501,0.312901,0.061144,0.44501,0.312901,0.074144,0.446193,0.312449,0.074144,0.44501,0.312901,0.061144,0.443721,0.313059,0.061144,0.443721,0.313059,0.074144,0.44501,0.312901,0.074144,0.443721,0.313059,0.061144,0.393439,0.313059,0.061144,0.393439,0.313059,0.074144,0.443721,0.313059,0.074144,0.393439,0.313059,0.061144,0.39215,0.312901,0.061144,0.39215,0.312901,0.074144,0.393439,0.313059,0.061144,0.39215,0.312901,0.074144,0.393439,0.313059,0.074144,0.319892,0.312901,0.061144,0.318708,0.312449,0.061144,0.318708,0.312449,0.074144,0.319892,0.312901,0.074144,0.318708,0.312449,0.061144,0.317664,0.31174,0.061144,0.317664,0.31174,0.074144,0.318708,0.312449,0.074144,0.317664,0.31174,0.061144,0.316793,0.310811,0.061144,0.316793,0.310811,0.074144,0.317664,0.31174,0.074144,0.316793,0.310811,0.061144,0.316128,0.309697,0.061144,0.316128,0.309697,0.074144,0.316793,0.310811,0.074144,0.316128,0.309697,0.061144,0.315705,0.308434,0.061144,0.315705,0.308434,0.074144,0.316128,0.309697,0.061144,0.315705,0.308434,0.074144,0.316128,0.309697,0.074144,0.315705,0.308434,0.061144,0.315556,0.307059,0.061144,0.315556,0.307059,0.074144,0.315705,0.308434,0.061144,0.315556,0.307059,0.074144,0.315705,0.308434,0.074144,0.315556,0.307059,0.061144,0.315556,0.286911,0.061144,0.315556,0.286911,0.074144,0.315556,0.307059,0.074144,0.315556,0.286911,0.061144,0.315705,0.285536,0.061144,0.315705,0.285536,0.074144,0.315556,0.286911,0.074144,0.315705,0.285536,0.061144,0.316128,0.284274,0.061144,0.316128,0.284274,0.074144,0.315705,0.285536,0.074144,0.316128,0.284274,0.061144,0.316793,0.28316,0.061144,0.316793,0.28316,0.074144,0.316128,0.284274,0.074144,0.316793,0.28316,0.061144,0.317664,0.28223,0.061144,0.317664,0.28223,0.074144,0.316793,0.28316,0.061144,0.317664,0.28223,0.074144,0.316793,0.28316,0.074144,0.317664,0.28223,0.061144,0.318708,0.281522,0.061144,0.318708,0.281522,0.074144,0.317664,0.28223,0.074144,0.318708,0.281522,0.061144,0.319892,0.28107,0.061144,0.319892,0.28107,0.074144,0.318708,0.281522,0.061144,0.319892,0.28107,0.074144,0.318708,0.281522,0.074144,0.319892,0.28107,0.061144,0.32118,0.280911,0.061144,0.32118,0.280911,0.074144,0.319892,0.28107,0.074144,0.32118,0.280911,0.061144,0.371463,0.280911,0.061144,0.371463,0.280911,0.074144,0.32118,0.280911,0.074144,0.371463,0.280911,0.061144,0.372752,0.28107,0.061144,0.372752,0.28107,0.074144,0.371463,0.280911,0.074144,0.372752,0.28107,0.061144,0.373935,0.281522,0.061144,0.373935,0.281522,0.074144,0.372752,0.28107,0.074144,0.373935,0.281522,0.061144,0.37498,0.28223,0.061144,0.37498,0.28223,0.074144,0.373935,0.281522,0.074144,0.37498,0.28223,0.061144,0.375851,0.28316,0.061144,0.375851,0.28316,0.074144,0.37498,0.28223,0.074144,0.375851,0.28316,0.061144,0.376515,0.284274,0.061144,0.376515,0.284274,0.074144,0.375851,0.28316,0.074144,0.376515,0.284274,0.061144,0.376939,0.285536,0.061144,0.376939,0.285536,0.074144,0.376515,0.284274,0.074144,0.376939,0.285536,0.061144,0.377087,0.286911,0.061144,0.377087,0.286911,0.074144,0.376939,0.285536,0.074144,0.377087,0.286911,0.061144,0.377087,0.307059,0.061144,0.377087,0.307059,0.074144,0.377087,0.286911,0.074144,0.377087,0.307059,0.061144,0.376939,0.308434,0.061144,0.376939,0.308434,0.074144,0.377087,0.307059,0.074144,0.376939,0.308434,0.061144,0.376515,0.309697,0.061144,0.376515,0.309697,0.074144,0.376939,0.308434,0.074144,0.376515,0.309697,0.061144,0.375851,0.310811,0.061144,0.375851,0.310811,0.074144,0.376515,0.309697,0.074144,0.375851,0.310811,0.061144,0.37498,0.31174,0.061144,0.37498,0.31174,0.074144,0.375851,0.310811,0.074144,0.37498,0.31174,0.061144,0.373935,0.312449,0.061144,0.373935,0.312449,0.074144,0.37498,0.31174,0.074144,0.373935,0.312449,0.061144,0.372752,0.312901,0.061144,0.372752,0.312901,0.074144,0.373935,0.312449,0.074144,0.372752,0.312901,0.061144,0.371463,0.313059,0.061144,0.371463,0.313059,0.074144,0.372752,0.312901,0.074144,0.371463,0.313059,0.061144,0.32118,0.313059,0.061144,0.32118,0.313059,0.074144,0.371463,0.313059,0.074144,0.32118,0.313059,0.061144,0.319892,0.312901,0.061144,0.319892,0.312901,0.074144,0.32118,0.313059,0.074144,0.24132,0.312901,0.061144,0.240137,0.312449,0.061144,0.240137,0.312449,0.074144,0.24132,0.312901,0.074144,0.240137,0.312449,0.061144,0.239093,0.31174,0.061144,0.239093,0.31174,0.074144,0.240137,0.312449,0.074144,0.239093,0.31174,0.061144,0.238221,0.310811,0.061144,0.238221,0.310811,0.074144,0.239093,0.31174,0.074144,0.238221,0.310811,0.061144,0.237557,0.309697,0.061144,0.237557,0.309697,0.074144,0.238221,0.310811,0.074144,0.237557,0.309697,0.061144,0.237134,0.308434,0.061144,0.237134,0.308434,0.074144,0.237557,0.309697,0.074144,0.237134,0.308434,0.061144,0.236985,0.307059,0.061144,0.236985,0.307059,0.074144,0.237134,0.308434,0.074144,0.236985,0.307059,0.061144,0.236985,0.286911,0.061144,0.236985,0.286911,0.074144,0.236985,0.307059,0.074144,0.236985,0.286911,0.061144,0.237134,0.285536,0.061144,0.237134,0.285536,0.074144,0.236985,0.286911,0.074144,0.237134,0.285536,0.061144,0.237557,0.284274,0.061144,0.237557,0.284274,0.074144,0.237134,0.285536,0.074144,0.237557,0.284274,0.061144,0.238221,0.28316,0.061144,0.238221,0.28316,0.074144,0.237557,0.284274,0.074144,0.238221,0.28316,0.061144,0.239093,0.28223,0.061144,0.239093,0.28223,0.074144,0.238221,0.28316,0.074144,0.239093,0.28223,0.061144,0.240137,0.281522,0.061144,0.240137,0.281522,0.074144,0.239093,0.28223,0.074144,0.240137,0.281522,0.061144,0.24132,0.28107,0.061144,0.24132,0.28107,0.074144,0.240137,0.281522,0.074144,0.24132,0.28107,0.061144,0.242609,0.280911,0.061144,0.242609,0.280911,0.074144,0.24132,0.28107,0.074144,0.242609,0.280911,0.061144,0.292892,0.280911,0.061144,0.292892,0.280911,0.074144,0.242609,0.280911,0.061144,0.292892,0.280911,0.074144,0.242609,0.280911,0.074144,0.292892,0.280911,0.061144,0.29418,0.28107,0.061144,0.29418,0.28107,0.074144,0.292892,0.280911,0.074144,0.29418,0.28107,0.061144,0.295364,0.281522,0.061144,0.295364,0.281522,0.074144,0.29418,0.28107,0.074144,0.295364,0.281522,0.061144,0.296408,0.28223,0.061144,0.296408,0.28223,0.074144,0.295364,0.281522,0.074144,0.296408,0.28223,0.061144,0.297279,0.28316,0.061144,0.297279,0.28316,0.074144,0.296408,0.28223,0.074144,0.297279,0.28316,0.061144,0.297944,0.284274,0.061144,0.297944,0.284274,0.074144,0.297279,0.28316,0.074144,0.297944,0.284274,0.061144,0.298367,0.285536,0.061144,0.298367,0.285536,0.074144,0.297944,0.284274,0.074144,0.298367,0.285536,0.061144,0.298516,0.286911,0.061144,0.298516,0.286911,0.074144,0.298367,0.285536,0.074144,0.298516,0.286911,0.061144,0.298516,0.307059,0.061144,0.298516,0.307059,0.074144,0.298516,0.286911,0.074144,0.298516,0.307059,0.061144,0.298367,0.308434,0.061144,0.298367,0.308434,0.074144,0.298516,0.307059,0.074144,0.298367,0.308434,0.061144,0.297944,0.309697,0.061144,0.297944,0.309697,0.074144,0.298367,0.308434,0.074144,0.297944,0.309697,0.061144,0.297279,0.310811,0.061144,0.297279,0.310811,0.074144,0.297944,0.309697,0.074144,0.297279,0.310811,0.061144,0.296408,0.31174,0.061144,0.296408,0.31174,0.074144,0.297279,0.310811,0.074144,0.296408,0.31174,0.061144,0.295364,0.312449,0.061144,0.295364,0.312449,0.074144,0.296408,0.31174,0.074144,0.295364,0.312449,0.061144,0.29418,0.312901,0.061144,0.29418,0.312901,0.074144,0.295364,0.312449,0.074144,0.29418,0.312901,0.061144,0.292892,0.313059,0.061144,0.292892,0.313059,0.074144,0.29418,0.312901,0.074144,0.292892,0.313059,0.061144,0.242609,0.313059,0.061144,0.242609,0.313059,0.074144,0.292892,0.313059,0.061144,0.242609,0.313059,0.074144,0.292892,0.313059,0.074144,0.242609,0.313059,0.061144,0.24132,0.312901,0.061144,0.24132,0.312901,0.074144,0.242609,0.313059,0.074144,0.162749,0.312901,0.061144,0.161565,0.312449,0.061144,0.161565,0.312449,0.074144,0.162749,0.312901,0.074144,0.161565,0.312449,0.061144,0.160521,0.31174,0.061144,0.160521,0.31174,0.074144,0.161565,0.312449,0.074144,0.160521,0.31174,0.061144,0.15965,0.310811,0.061144,0.15965,0.310811,0.074144,0.160521,0.31174,0.074144,0.15965,0.310811,0.061144,0.158986,0.309697,0.061144,0.158986,0.309697,0.074144,0.15965,0.310811,0.074144,0.158986,0.309697,0.061144,0.158562,0.308434,0.061144,0.158562,0.308434,0.074144,0.158986,0.309697,0.061144,0.158562,0.308434,0.074144,0.158986,0.309697,0.074144,0.158562,0.308434,0.061144,0.158413,0.307059,0.061144,0.158413,0.307059,0.074144,0.158562,0.308434,0.061144,0.158413,0.307059,0.074144,0.158562,0.308434,0.074144,0.158413,0.307059,0.061144,0.158413,0.286911,0.061144,0.158413,0.286911,0.074144,0.158413,0.307059,0.074144,0.158413,0.286911,0.061144,0.158562,0.285536,0.061144,0.158562,0.285536,0.074144,0.158413,0.286911,0.074144,0.158562,0.285536,0.061144,0.158986,0.284274,0.061144,0.158986,0.284274,0.074144,0.158562,0.285536,0.074144,0.158986,0.284274,0.061144,0.15965,0.28316,0.061144,0.15965,0.28316,0.074144,0.158986,0.284274,0.074144,0.15965,0.28316,0.061144,0.160521,0.28223,0.061144,0.160521,0.28223,0.074144,0.15965,0.28316,0.061144,0.160521,0.28223,0.074144,0.15965,0.28316,0.074144,0.160521,0.28223,0.061144,0.161565,0.281522,0.061144,0.161565,0.281522,0.074144,0.160521,0.28223,0.074144,0.161565,0.281522,0.061144,0.162749,0.28107,0.061144,0.162749,0.28107,0.074144,0.161565,0.281522,0.061144,0.162749,0.28107,0.074144,0.161565,0.281522,0.074144,0.162749,0.28107,0.061144,0.164038,0.280911,0.061144,0.164038,0.280911,0.074144,0.162749,0.28107,0.074144,0.164038,0.280911,0.061144,0.21432,0.280911,0.061144,0.21432,0.280911,0.074144,0.164038,0.280911,0.074144,0.21432,0.280911,0.061144,0.215609,0.28107,0.061144,0.215609,0.28107,0.074144,0.21432,0.280911,0.074144,0.215609,0.28107,0.061144,0.216792,0.281522,0.061144,0.216792,0.281522,0.074144,0.215609,0.28107,0.074144,0.216792,0.281522,0.061144,0.217837,0.28223,0.061144,0.217837,0.28223,0.074144,0.216792,0.281522,0.074144,0.217837,0.28223,0.061144,0.218708,0.28316,0.061144,0.218708,0.28316,0.074144,0.217837,0.28223,0.074144,0.218708,0.28316,0.061144,0.219372,0.284274,0.061144,0.219372,0.284274,0.074144,0.218708,0.28316,0.074144,0.219372,0.284274,0.061144,0.219796,0.285536,0.061144,0.219796,0.285536,0.074144,0.219372,0.284274,0.074144,0.219796,0.285536,0.061144,0.219944,0.286911,0.061144,0.219944,0.286911,0.074144,0.219796,0.285536,0.074144,0.219944,0.286911,0.061144,0.219944,0.307059,0.061144,0.219944,0.307059,0.074144,0.219944,0.286911,0.074144,0.219944,0.307059,0.061144,0.219796,0.308434,0.061144,0.219796,0.308434,0.074144,0.219944,0.307059,0.074144,0.219796,0.308434,0.061144,0.219372,0.309697,0.061144,0.219372,0.309697,0.074144,0.219796,0.308434,0.074144,0.219372,0.309697,0.061144,0.218708,0.310811,0.061144,0.218708,0.310811,0.074144,0.219372,0.309697,0.074144,0.218708,0.310811,0.061144,0.217837,0.31174,0.061144,0.217837,0.31174,0.074144,0.218708,0.310811,0.074144,0.217837,0.31174,0.061144,0.216792,0.312449,0.061144,0.216792,0.312449,0.074144,0.217837,0.31174,0.074144,0.216792,0.312449,0.061144,0.215609,0.312901,0.061144,0.215609,0.312901,0.074144,0.216792,0.312449,0.074144,0.215609,0.312901,0.061144,0.21432,0.313059,0.061144,0.21432,0.313059,0.074144,0.215609,0.312901,0.074144,0.21432,0.313059,0.061144,0.164038,0.313059,0.061144,0.164038,0.313059,0.074144,0.21432,0.313059,0.074144,0.164038,0.313059,0.061144,0.162749,0.312901,0.061144,0.162749,0.312901,0.074144,0.164038,0.313059,0.074144,0.084177,0.312901,0.061144,0.082994,0.312449,0.061144,0.082994,0.312449,0.074144,0.084177,0.312901,0.074144,0.082994,0.312449,0.061144,0.08195,0.31174,0.061144,0.08195,0.31174,0.074144,0.082994,0.312449,0.061144,0.08195,0.31174,0.074144,0.082994,0.312449,0.074144,0.08195,0.31174,0.061144,0.081078,0.310811,0.061144,0.081078,0.310811,0.074144,0.08195,0.31174,0.061144,0.081078,0.310811,0.074144,0.08195,0.31174,0.074144,0.081078,0.310811,0.061144,0.080414,0.309697,0.061144,0.080414,0.309697,0.074144,0.081078,0.310811,0.074144,0.080414,0.309697,0.061144,0.079991,0.308434,0.061144,0.079991,0.308434,0.074144,0.080414,0.309697,0.074144,0.079991,0.308434,0.061144,0.079842,0.307059,0.061144,0.079842,0.307059,0.074144,0.079991,0.308434,0.074144,0.079842,0.307059,0.061144,0.079842,0.286911,0.061144,0.079842,0.286911,0.074144,0.079842,0.307059,0.074144,0.079842,0.286911,0.061144,0.079991,0.285536,0.061144,0.079991,0.285536,0.074144,0.079842,0.286911,0.074144,0.079991,0.285536,0.061144,0.080414,0.284274,0.061144,0.080414,0.284274,0.074144,0.079991,0.285536,0.061144,0.080414,0.284274,0.074144,0.079991,0.285536,0.074144,0.080414,0.284274,0.061144,0.081078,0.28316,0.061144,0.081078,0.28316,0.074144,0.080414,0.284274,0.061144,0.081078,0.28316,0.074144,0.080414,0.284274,0.074144,0.081078,0.28316,0.061144,0.08195,0.28223,0.061144,0.08195,0.28223,0.074144,0.081078,0.28316,0.074144,0.08195,0.28223,0.061144,0.082994,0.281522,0.061144,0.082994,0.281522,0.074144,0.08195,0.28223,0.074144,0.082994,0.281522,0.061144,0.084177,0.28107,0.061144,0.084177,0.28107,0.074144,0.082994,0.281522,0.074144,0.084177,0.28107,0.061144,0.085466,0.280911,0.061144,0.085466,0.280911,0.074144,0.084177,0.28107,0.061144,0.085466,0.280911,0.074144,0.084177,0.28107,0.074144,0.085466,0.280911,0.061144,0.135749,0.280911,0.061144,0.135749,0.280911,0.074144,0.085466,0.280911,0.061144,0.135749,0.280911,0.074144,0.085466,0.280911,0.074144,0.135749,0.280911,0.061144,0.137038,0.28107,0.061144,0.137038,0.28107,0.074144,0.135749,0.280911,0.074144,0.137038,0.28107,0.061144,0.138221,0.281522,0.061144,0.138221,0.281522,0.074144,0.137038,0.28107,0.074144,0.138221,0.281522,0.061144,0.139265,0.28223,0.061144,0.139265,0.28223,0.074144,0.138221,0.281522,0.074144,0.139265,0.28223,0.061144,0.140137,0.28316,0.061144,0.140137,0.28316,0.074144,0.139265,0.28223,0.074144,0.140137,0.28316,0.061144,0.140801,0.284274,0.061144,0.140801,0.284274,0.074144,0.140137,0.28316,0.074144,0.140801,0.284274,0.061144,0.141224,0.285536,0.061144,0.141224,0.285536,0.074144,0.140801,0.284274,0.074144,0.141224,0.285536,0.061144,0.141373,0.286911,0.061144,0.141373,0.286911,0.074144,0.141224,0.285536,0.074144,0.141373,0.286911,0.061144,0.141373,0.307059,0.061144,0.141373,0.307059,0.074144,0.141373,0.286911,0.074144,0.141373,0.307059,0.061144,0.141224,0.308434,0.061144,0.141224,0.308434,0.074144,0.141373,0.307059,0.074144,0.141224,0.308434,0.061144,0.140801,0.309697,0.061144,0.140801,0.309697,0.074144,0.141224,0.308434,0.074144,0.140801,0.309697,0.061144,0.140137,0.310811,0.061144,0.140137,0.310811,0.074144,0.140801,0.309697,0.074144,0.140137,0.310811,0.061144,0.139265,0.31174,0.061144,0.139265,0.31174,0.074144,0.140137,0.310811,0.074144,0.139265,0.31174,0.061144,0.138221,0.312449,0.061144,0.138221,0.312449,0.074144,0.139265,0.31174,0.074144,0.138221,0.312449,0.061144,0.137038,0.312901,0.061144,0.137038,0.312901,0.074144,0.138221,0.312449,0.074144,0.137038,0.312901,0.061144,0.135749,0.313059,0.061144,0.135749,0.313059,0.074144,0.137038,0.312901,0.074144,0.135749,0.313059,0.061144,0.085466,0.313059,0.061144,0.085466,0.313059,0.074144,0.135749,0.313059,0.074144,0.085466,0.313059,0.061144,0.084177,0.312901,0.061144,0.084177,0.312901,0.074144,0.085466,0.313059,0.074144,0.005606,0.312901,0.061144,0.004423,0.312449,0.061144,0.004423,0.312449,0.074144,0.005606,0.312901,0.074144,0.004423,0.312449,0.061144,0.003378,0.31174,0.061144,0.003378,0.31174,0.074144,0.004423,0.312449,0.074144,0.003378,0.31174,0.061144,0.002507,0.310811,0.061144,0.002507,0.310811,0.074144,0.003378,0.31174,0.074144,0.002507,0.310811,0.061144,0.001843,0.309697,0.061144,0.001843,0.309697,0.074144,0.002507,0.310811,0.061144,0.001843,0.309697,0.074144,0.002507,0.310811,0.074144,0.001843,0.309697,0.061144,0.001419,0.308434,0.061144,0.001419,0.308434,0.074144,0.001843,0.309697,0.061144,0.001419,0.308434,0.074144,0.001843,0.309697,0.074144,0.001419,0.308434,0.061144,0.001271,0.307059,0.061144,0.001271,0.307059,0.074144,0.001419,0.308434,0.061144,0.001271,0.307059,0.074144,0.001419,0.308434,0.074144,0.001271,0.307059,0.061144,0.001271,0.286911,0.061144,0.001271,0.286911,0.074144,0.001271,0.307059,0.074144,0.001271,0.286911,0.061144,0.001419,0.285536,0.061144,0.001419,0.285536,0.074144,0.001271,0.286911,0.061144,0.001419,0.285536,0.074144,0.001271,0.286911,0.074144,0.001419,0.285536,0.061144,0.001843,0.284274,0.061144,0.001843,0.284274,0.074144,0.001419,0.285536,0.074144,0.001843,0.284274,0.061144,0.002507,0.28316,0.061144,0.002507,0.28316,0.074144,0.001843,0.284274,0.074144,0.002507,0.28316,0.061144,0.003378,0.28223,0.061144,0.003378,0.28223,0.074144,0.002507,0.28316,0.074144,0.003378,0.28223,0.061144,0.004423,0.281522,0.061144,0.004423,0.281522,0.074144,0.003378,0.28223,0.074144,0.004423,0.281522,0.061144,0.005606,0.28107,0.061144,0.005606,0.28107,0.074144,0.004423,0.281522,0.074144,0.005606,0.28107,0.061144,0.006895,0.280911,0.061144,0.006895,0.280911,0.074144,0.005606,0.28107,0.074144,0.006895,0.280911,0.061144,0.057177,0.280911,0.061144,0.057177,0.280911,0.074144,0.006895,0.280911,0.074144,0.057177,0.280911,0.061144,0.058466,0.28107,0.061144,0.058466,0.28107,0.074144,0.057177,0.280911,0.074144,0.058466,0.28107,0.061144,0.05965,0.281522,0.061144,0.05965,0.281522,0.074144,0.058466,0.28107,0.074144,0.05965,0.281522,0.061144,0.060694,0.28223,0.061144,0.060694,0.28223,0.074144,0.05965,0.281522,0.074144,0.060694,0.28223,0.061144,0.061565,0.28316,0.061144,0.061565,0.28316,0.074144,0.060694,0.28223,0.074144,0.061565,0.28316,0.061144,0.062229,0.284274,0.061144,0.062229,0.284274,0.074144,0.061565,0.28316,0.074144,0.062229,0.284274,0.061144,0.062653,0.285536,0.061144,0.062653,0.285536,0.074144,0.062229,0.284274,0.074144,0.062653,0.285536,0.061144,0.062802,0.286911,0.061144,0.062802,0.286911,0.074144,0.062653,0.285536,0.074144,0.062802,0.286911,0.061144,0.062802,0.307059,0.061144,0.062802,0.307059,0.074144,0.062802,0.286911,0.074144,0.062802,0.307059,0.061144,0.062653,0.308434,0.061144,0.062653,0.308434,0.074144,0.062802,0.307059,0.074144,0.062653,0.308434,0.061144,0.062229,0.309697,0.061144,0.062229,0.309697,0.074144,0.062653,0.308434,0.074144,0.062229,0.309697,0.061144,0.061565,0.310811,0.061144,0.061565,0.310811,0.074144,0.062229,0.309697,0.074144,0.061565,0.310811,0.061144,0.060694,0.31174,0.061144,0.060694,0.31174,0.074144,0.061565,0.310811,0.074144,0.060694,0.31174,0.061144,0.05965,0.312449,0.061144,0.05965,0.312449,0.074144,0.060694,0.31174,0.074144,0.05965,0.312449,0.061144,0.058466,0.312901,0.061144,0.058466,0.312901,0.074144,0.05965,0.312449,0.074144,0.058466,0.312901,0.061144,0.057177,0.313059,0.061144,0.057177,0.313059,0.074144,0.058466,0.312901,0.074144,0.057177,0.313059,0.061144,0.006895,0.313059,0.061144,0.006895,0.313059,0.074144,0.057177,0.313059,0.074144,0.006895,0.313059,0.061144,0.005606,0.312901,0.061144,0.005606,0.312901,0.074144,0.006895,0.313059,0.074144,-0.072965,0.312901,0.061144,-0.074149,0.312449,0.061144,-0.074149,0.312449,0.074144,-0.072965,0.312901,0.074144,-0.074149,0.312449,0.061144,-0.075193,0.31174,0.061144,-0.075193,0.31174,0.074144,-0.074149,0.312449,0.061144,-0.075193,0.31174,0.074144,-0.074149,0.312449,0.074144,-0.075193,0.31174,0.061144,-0.076064,0.310811,0.061144,-0.076064,0.310811,0.074144,-0.075193,0.31174,0.061144,-0.076064,0.310811,0.074144,-0.075193,0.31174,0.074144,-0.076064,0.310811,0.061144,-0.076729,0.309697,0.061144,-0.076729,0.309697,0.074144,-0.076064,0.310811,0.074144,-0.076729,0.309697,0.061144,-0.077152,0.308434,0.061144,-0.077152,0.308434,0.074144,-0.076729,0.309697,0.074144,-0.077152,0.308434,0.061144,-0.077301,0.307059,0.061144,-0.077301,0.307059,0.074144,-0.077152,0.308434,0.074144,-0.077301,0.307059,0.061144,-0.077301,0.286911,0.061144,-0.077301,0.286911,0.074144,-0.077301,0.307059,0.074144,-0.077301,0.286911,0.061144,-0.077152,0.285536,0.061144,-0.077152,0.285536,0.074144,-0.077301,0.286911,0.074144,-0.077152,0.285536,0.061144,-0.076729,0.284274,0.061144,-0.076729,0.284274,0.074144,-0.077152,0.285536,0.061144,-0.076729,0.284274,0.074144,-0.077152,0.285536,0.074144,-0.076729,0.284274,0.061144,-0.076064,0.28316,0.061144,-0.076064,0.28316,0.074144,-0.076729,0.284274,0.061144,-0.076064,0.28316,0.074144,-0.076729,0.284274,0.074144,-0.076064,0.28316,0.061144,-0.075193,0.28223,0.061144,-0.075193,0.28223,0.074144,-0.076064,0.28316,0.074144,-0.075193,0.28223,0.061144,-0.074149,0.281522,0.061144,-0.074149,0.281522,0.074144,-0.075193,0.28223,0.074144,-0.074149,0.281522,0.061144,-0.072965,0.28107,0.061144,-0.072965,0.28107,0.074144,-0.074149,0.281522,0.074144,-0.072965,0.28107,0.061144,-0.071677,0.280911,0.061144,-0.071677,0.280911,0.074144,-0.072965,0.28107,0.074144,-0.071677,0.280911,0.061144,-0.021394,0.280911,0.061144,-0.021394,0.280911,0.074144,-0.071677,0.280911,0.074144,-0.021394,0.280911,0.061144,-0.020105,0.28107,0.061144,-0.020105,0.28107,0.074144,-0.021394,0.280911,0.074144,-0.020105,0.28107,0.061144,-0.018922,0.281522,0.061144,-0.018922,0.281522,0.074144,-0.020105,0.28107,0.074144,-0.018922,0.281522,0.061144,-0.017878,0.28223,0.061144,-0.017878,0.28223,0.074144,-0.018922,0.281522,0.074144,-0.017878,0.28223,0.061144,-0.017006,0.28316,0.061144,-0.017006,0.28316,0.074144,-0.017878,0.28223,0.074144,-0.017006,0.28316,0.061144,-0.016342,0.284274,0.061144,-0.016342,0.284274,0.074144,-0.017006,0.28316,0.074144,-0.016342,0.284274,0.061144,-0.015919,0.285536,0.061144,-0.015919,0.285536,0.074144,-0.016342,0.284274,0.074144,-0.015919,0.285536,0.061144,-0.01577,0.286911,0.061144,-0.01577,0.286911,0.074144,-0.015919,0.285536,0.074144,-0.01577,0.286911,0.061144,-0.01577,0.307059,0.061144,-0.01577,0.307059,0.074144,-0.01577,0.286911,0.074144,-0.01577,0.307059,0.061144,-0.015919,0.308434,0.061144,-0.015919,0.308434,0.074144,-0.01577,0.307059,0.074144,-0.015919,0.308434,0.061144,-0.016342,0.309697,0.061144,-0.016342,0.309697,0.074144,-0.015919,0.308434,0.074144,-0.016342,0.309697,0.061144,-0.017006,0.310811,0.061144,-0.017006,0.310811,0.074144,-0.016342,0.309697,0.074144,-0.017006,0.310811,0.061144,-0.017878,0.31174,0.061144,-0.017878,0.31174,0.074144,-0.017006,0.310811,0.074144,-0.017878,0.31174,0.061144,-0.018922,0.312449,0.061144,-0.018922,0.312449,0.074144,-0.017878,0.31174,0.074144,-0.018922,0.312449,0.061144,-0.020105,0.312901,0.061144,-0.020105,0.312901,0.074144,-0.018922,0.312449,0.074144,-0.020105,0.312901,0.061144,-0.021394,0.313059,0.061144,-0.021394,0.313059,0.074144,-0.020105,0.312901,0.074144,-0.021394,0.313059,0.061144,-0.071677,0.313059,0.061144,-0.071677,0.313059,0.074144,-0.021394,0.313059,0.074144,-0.071677,0.313059,0.061144,-0.072965,0.312901,0.061144,-0.072965,0.312901,0.074144,-0.071677,0.313059,0.074144,-0.151537,0.312901,0.061144,-0.15272,0.312449,0.061144,-0.15272,0.312449,0.074144,-0.151537,0.312901,0.074144,-0.15272,0.312449,0.061144,-0.153765,0.31174,0.061144,-0.153765,0.31174,0.074144,-0.15272,0.312449,0.074144,-0.153765,0.31174,0.061144,-0.154636,0.310811,0.061144,-0.154636,0.310811,0.074144,-0.153765,0.31174,0.074144,-0.154636,0.310811,0.061144,-0.1553,0.309697,0.061144,-0.1553,0.309697,0.074144,-0.154636,0.310811,0.061144,-0.1553,0.309697,0.074144,-0.154636,0.310811,0.074144,-0.1553,0.309697,0.061144,-0.155724,0.308434,0.061144,-0.155724,0.308434,0.074144,-0.1553,0.309697,0.061144,-0.155724,0.308434,0.074144,-0.1553,0.309697,0.074144,-0.155724,0.308434,0.061144,-0.155872,0.307059,0.061144,-0.155872,0.307059,0.074144,-0.155724,0.308434,0.061144,-0.155872,0.307059,0.074144,-0.155724,0.308434,0.074144,-0.155872,0.307059,0.061144,-0.155872,0.286911,0.061144,-0.155872,0.286911,0.074144,-0.155872,0.307059,0.074144,-0.155872,0.286911,0.061144,-0.155724,0.285536,0.061144,-0.155724,0.285536,0.074144,-0.155872,0.286911,0.061144,-0.155724,0.285536,0.074144,-0.155872,0.286911,0.074144,-0.155724,0.285536,0.061144,-0.1553,0.284274,0.061144,-0.1553,0.284274,0.074144,-0.155724,0.285536,0.074144,-0.1553,0.284274,0.061144,-0.154636,0.28316,0.061144,-0.154636,0.28316,0.074144,-0.1553,0.284274,0.074144,-0.154636,0.28316,0.061144,-0.153765,0.28223,0.061144,-0.153765,0.28223,0.074144,-0.154636,0.28316,0.074144,-0.153765,0.28223,0.061144,-0.15272,0.281522,0.061144,-0.15272,0.281522,0.074144,-0.153765,0.28223,0.074144,-0.15272,0.281522,0.061144,-0.151537,0.28107,0.061144,-0.151537,0.28107,0.074144,-0.15272,0.281522,0.074144,-0.151537,0.28107,0.061144,-0.150248,0.280911,0.061144,-0.150248,0.280911,0.074144,-0.151537,0.28107,0.074144,-0.150248,0.280911,0.061144,-0.099965,0.280911,0.061144,-0.099965,0.280911,0.074144,-0.150248,0.280911,0.074144,-0.099965,0.280911,0.061144,-0.098677,0.28107,0.061144,-0.098677,0.28107,0.074144,-0.099965,0.280911,0.074144,-0.098677,0.28107,0.061144,-0.097493,0.281522,0.061144,-0.097493,0.281522,0.074144,-0.098677,0.28107,0.074144,-0.097493,0.281522,0.061144,-0.096449,0.28223,0.061144,-0.096449,0.28223,0.074144,-0.097493,0.281522,0.074144,-0.096449,0.28223,0.061144,-0.095578,0.28316,0.061144,-0.095578,0.28316,0.074144,-0.096449,0.28223,0.074144,-0.095578,0.28316,0.061144,-0.094913,0.284274,0.061144,-0.094913,0.284274,0.074144,-0.095578,0.28316,0.074144,-0.094913,0.284274,0.061144,-0.09449,0.285536,0.061144,-0.09449,0.285536,0.074144,-0.094913,0.284274,0.074144,-0.09449,0.285536,0.061144,-0.094341,0.286911,0.061144,-0.094341,0.286911,0.074144,-0.09449,0.285536,0.074144,-0.094341,0.286911,0.061144,-0.094341,0.307059,0.061144,-0.094341,0.307059,0.074144,-0.094341,0.286911,0.074144,-0.094341,0.307059,0.061144,-0.09449,0.308434,0.061144,-0.09449,0.308434,0.074144,-0.094341,0.307059,0.074144,-0.09449,0.308434,0.061144,-0.094913,0.309697,0.061144,-0.094913,0.309697,0.074144,-0.09449,0.308434,0.074144,-0.094913,0.309697,0.061144,-0.095578,0.310811,0.061144,-0.095578,0.310811,0.074144,-0.094913,0.309697,0.074144,-0.095578,0.310811,0.061144,-0.096449,0.31174,0.061144,-0.096449,0.31174,0.074144,-0.095578,0.310811,0.074144,-0.096449,0.31174,0.061144,-0.097493,0.312449,0.061144,-0.097493,0.312449,0.074144,-0.096449,0.31174,0.074144,-0.097493,0.312449,0.061144,-0.098677,0.312901,0.061144,-0.098677,0.312901,0.074144,-0.097493,0.312449,0.074144,-0.098677,0.312901,0.061144,-0.099965,0.313059,0.061144,-0.099965,0.313059,0.074144,-0.098677,0.312901,0.074144,-0.099965,0.313059,0.061144,-0.150248,0.313059,0.061144,-0.150248,0.313059,0.074144,-0.099965,0.313059,0.074144,-0.150248,0.313059,0.061144,-0.151537,0.312901,0.061144,-0.151537,0.312901,0.074144,-0.150248,0.313059,0.074144,-0.230108,0.312901,0.061144,-0.231292,0.312449,0.061144,-0.231292,0.312449,0.074144,-0.230108,0.312901,0.074144,-0.231292,0.312449,0.061144,-0.232336,0.31174,0.061144,-0.232336,0.31174,0.074144,-0.231292,0.312449,0.074144,-0.232336,0.31174,0.061144,-0.233207,0.310811,0.061144,-0.233207,0.310811,0.074144,-0.232336,0.31174,0.074144,-0.233207,0.310811,0.061144,-0.233872,0.309697,0.061144,-0.233872,0.309697,0.074144,-0.233207,0.310811,0.074144,-0.233872,0.309697,0.061144,-0.234295,0.308434,0.061144,-0.234295,0.308434,0.074144,-0.233872,0.309697,0.074144,-0.234295,0.308434,0.061144,-0.234444,0.307059,0.061144,-0.234444,0.307059,0.074144,-0.234295,0.308434,0.074144,-0.234444,0.307059,0.061144,-0.234444,0.286911,0.061144,-0.234444,0.286911,0.074144,-0.234444,0.307059,0.074144,-0.234444,0.286911,0.061144,-0.234295,0.285536,0.061144,-0.234295,0.285536,0.074144,-0.234444,0.286911,0.061144,-0.234295,0.285536,0.074144,-0.234444,0.286911,0.074144,-0.234295,0.285536,0.061144,-0.233872,0.284274,0.061144,-0.233872,0.284274,0.074144,-0.234295,0.285536,0.061144,-0.233872,0.284274,0.074144,-0.234295,0.285536,0.074144,-0.233872,0.284274,0.061144,-0.233207,0.28316,0.061144,-0.233207,0.28316,0.074144,-0.233872,0.284274,0.061144,-0.233207,0.28316,0.074144,-0.233872,0.284274,0.074144,-0.233207,0.28316,0.061144,-0.232336,0.28223,0.061144,-0.232336,0.28223,0.074144,-0.233207,0.28316,0.061144,-0.232336,0.28223,0.074144,-0.233207,0.28316,0.074144,-0.232336,0.28223,0.061144,-0.231292,0.281522,0.061144,-0.231292,0.281522,0.074144,-0.232336,0.28223,0.074144,-0.231292,0.281522,0.061144,-0.230108,0.28107,0.061144,-0.230108,0.28107,0.074144,-0.231292,0.281522,0.074144,-0.230108,0.28107,0.061144,-0.22882,0.280911,0.061144,-0.22882,0.280911,0.074144,-0.230108,0.28107,0.074144,-0.22882,0.280911,0.061144,-0.178537,0.280911,0.061144,-0.178537,0.280911,0.074144,-0.22882,0.280911,0.074144,-0.178537,0.280911,0.061144,-0.177248,0.28107,0.061144,-0.177248,0.28107,0.074144,-0.178537,0.280911,0.074144,-0.177248,0.28107,0.061144,-0.176065,0.281522,0.061144,-0.176065,0.281522,0.074144,-0.177248,0.28107,0.074144,-0.176065,0.281522,0.061144,-0.17502,0.28223,0.061144,-0.17502,0.28223,0.074144,-0.176065,0.281522,0.074144,-0.17502,0.28223,0.061144,-0.174149,0.28316,0.061144,-0.174149,0.28316,0.074144,-0.17502,0.28223,0.074144,-0.174149,0.28316,0.061144,-0.173485,0.284274,0.061144,-0.173485,0.284274,0.074144,-0.174149,0.28316,0.074144,-0.173485,0.284274,0.061144,-0.173061,0.285536,0.061144,-0.173061,0.285536,0.074144,-0.173485,0.284274,0.074144,-0.173061,0.285536,0.061144,-0.172913,0.286911,0.061144,-0.172913,0.286911,0.074144,-0.173061,0.285536,0.074144,-0.172913,0.286911,0.061144,-0.172913,0.307059,0.061144,-0.172913,0.307059,0.074144,-0.172913,0.286911,0.074144,-0.172913,0.307059,0.061144,-0.173061,0.308434,0.061144,-0.173061,0.308434,0.074144,-0.172913,0.307059,0.074144,-0.173061,0.308434,0.061144,-0.173485,0.309697,0.061144,-0.173485,0.309697,0.074144,-0.173061,0.308434,0.074144,-0.173485,0.309697,0.061144,-0.174149,0.310811,0.061144,-0.174149,0.310811,0.074144,-0.173485,0.309697,0.074144,-0.174149,0.310811,0.061144,-0.17502,0.31174,0.061144,-0.17502,0.31174,0.074144,-0.174149,0.310811,0.074144,-0.17502,0.31174,0.061144,-0.176065,0.312449,0.061144,-0.176065,0.312449,0.074144,-0.17502,0.31174,0.074144,-0.176065,0.312449,0.061144,-0.177248,0.312901,0.061144,-0.177248,0.312901,0.074144,-0.176065,0.312449,0.074144,-0.177248,0.312901,0.061144,-0.178537,0.313059,0.061144,-0.178537,0.313059,0.074144,-0.177248,0.312901,0.074144,-0.178537,0.313059,0.061144,-0.22882,0.313059,0.061144,-0.22882,0.313059,0.074144,-0.178537,0.313059,0.074144,-0.22882,0.313059,0.061144,-0.230108,0.312901,0.061144,-0.230108,0.312901,0.074144,-0.22882,0.313059,0.074144,-0.30868,0.312901,0.061144,-0.309863,0.312449,0.061144,-0.309863,0.312449,0.074144,-0.30868,0.312901,0.061144,-0.309863,0.312449,0.074144,-0.30868,0.312901,0.074144,-0.309863,0.312449,0.061144,-0.310907,0.31174,0.061144,-0.310907,0.31174,0.074144,-0.309863,0.312449,0.074144,-0.310907,0.31174,0.061144,-0.311779,0.310811,0.061144,-0.311779,0.310811,0.074144,-0.310907,0.31174,0.061144,-0.311779,0.310811,0.074144,-0.310907,0.31174,0.074144,-0.311779,0.310811,0.061144,-0.312443,0.309697,0.061144,-0.312443,0.309697,0.074144,-0.311779,0.310811,0.061144,-0.312443,0.309697,0.074144,-0.311779,0.310811,0.074144,-0.312443,0.309697,0.061144,-0.312867,0.308434,0.061144,-0.312867,0.308434,0.074144,-0.312443,0.309697,0.061144,-0.312867,0.308434,0.074144,-0.312443,0.309697,0.074144,-0.312867,0.308434,0.061144,-0.313015,0.307059,0.061144,-0.313015,0.307059,0.074144,-0.312867,0.308434,0.061144,-0.313015,0.307059,0.074144,-0.312867,0.308434,0.074144,-0.313015,0.307059,0.061144,-0.313015,0.286911,0.061144,-0.313015,0.286911,0.074144,-0.313015,0.307059,0.074144,-0.313015,0.286911,0.061144,-0.312867,0.285536,0.061144,-0.312867,0.285536,0.074144,-0.313015,0.286911,0.061144,-0.312867,0.285536,0.074144,-0.313015,0.286911,0.074144,-0.312867,0.285536,0.061144,-0.312443,0.284274,0.061144,-0.312443,0.284274,0.074144,-0.312867,0.285536,0.061144,-0.312443,0.284274,0.074144,-0.312867,0.285536,0.074144,-0.312443,0.284274,0.061144,-0.311779,0.28316,0.061144,-0.311779,0.28316,0.074144,-0.312443,0.284274,0.074144,-0.311779,0.28316,0.061144,-0.310907,0.28223,0.061144,-0.310907,0.28223,0.074144,-0.311779,0.28316,0.074144,-0.310907,0.28223,0.061144,-0.309863,0.281522,0.061144,-0.309863,0.281522,0.074144,-0.310907,0.28223,0.074144,-0.309863,0.281522,0.061144,-0.30868,0.28107,0.061144,-0.30868,0.28107,0.074144,-0.309863,0.281522,0.061144,-0.30868,0.28107,0.074144,-0.309863,0.281522,0.074144,-0.30868,0.28107,0.061144,-0.307391,0.280911,0.061144,-0.307391,0.280911,0.074144,-0.30868,0.28107,0.061144,-0.307391,0.280911,0.074144,-0.30868,0.28107,0.074144,-0.307391,0.280911,0.061144,-0.257108,0.280911,0.061144,-0.257108,0.280911,0.074144,-0.307391,0.280911,0.061144,-0.257108,0.280911,0.074144,-0.307391,0.280911,0.074144,-0.257108,0.280911,0.061144,-0.25582,0.28107,0.061144,-0.25582,0.28107,0.074144,-0.257108,0.280911,0.074144,-0.25582,0.28107,0.061144,-0.254636,0.281522,0.061144,-0.254636,0.281522,0.074144,-0.25582,0.28107,0.074144,-0.254636,0.281522,0.061144,-0.253592,0.28223,0.061144,-0.253592,0.28223,0.074144,-0.254636,0.281522,0.074144,-0.253592,0.28223,0.061144,-0.252721,0.28316,0.061144,-0.252721,0.28316,0.074144,-0.253592,0.28223,0.074144,-0.252721,0.28316,0.061144,-0.252056,0.284274,0.061144,-0.252056,0.284274,0.074144,-0.252721,0.28316,0.074144,-0.252056,0.284274,0.061144,-0.251633,0.285536,0.061144,-0.251633,0.285536,0.074144,-0.252056,0.284274,0.074144,-0.251633,0.285536,0.061144,-0.251484,0.286911,0.061144,-0.251484,0.286911,0.074144,-0.251633,0.285536,0.074144,-0.251484,0.286911,0.061144,-0.251484,0.307059,0.061144,-0.251484,0.307059,0.074144,-0.251484,0.286911,0.074144,-0.251484,0.307059,0.061144,-0.251633,0.308434,0.061144,-0.251633,0.308434,0.074144,-0.251484,0.307059,0.074144,-0.251633,0.308434,0.061144,-0.252056,0.309697,0.061144,-0.252056,0.309697,0.074144,-0.251633,0.308434,0.074144,-0.252056,0.309697,0.061144,-0.252721,0.310811,0.061144,-0.252721,0.310811,0.074144,-0.252056,0.309697,0.074144,-0.252721,0.310811,0.061144,-0.253592,0.31174,0.061144,-0.253592,0.31174,0.074144,-0.252721,0.310811,0.074144,-0.253592,0.31174,0.061144,-0.254636,0.312449,0.061144,-0.254636,0.312449,0.074144,-0.253592,0.31174,0.074144,-0.254636,0.312449,0.061144,-0.25582,0.312901,0.061144,-0.25582,0.312901,0.074144,-0.254636,0.312449,0.074144,-0.25582,0.312901,0.061144,-0.257108,0.313059,0.061144,-0.257108,0.313059,0.074144,-0.25582,0.312901,0.074144,-0.257108,0.313059,0.061144,-0.307391,0.313059,0.061144,-0.307391,0.313059,0.074144,-0.257108,0.313059,0.061144,-0.307391,0.313059,0.074144,-0.257108,0.313059,0.074144,-0.307391,0.313059,0.061144,-0.30868,0.312901,0.061144,-0.30868,0.312901,0.074144,-0.307391,0.313059,0.061144,-0.30868,0.312901,0.074144,-0.307391,0.313059,0.074144,-0.387251,0.312901,0.061144,-0.388435,0.312449,0.061144,-0.388435,0.312449,0.074144,-0.387251,0.312901,0.074144,-0.388435,0.312449,0.061144,-0.389479,0.31174,0.061144,-0.389479,0.31174,0.074144,-0.388435,0.312449,0.074144,-0.389479,0.31174,0.061144,-0.39035,0.310811,0.061144,-0.39035,0.310811,0.074144,-0.389479,0.31174,0.074144,-0.39035,0.310811,0.061144,-0.391015,0.309697,0.061144,-0.391015,0.309697,0.074144,-0.39035,0.310811,0.074144,-0.391015,0.309697,0.061144,-0.391438,0.308434,0.061144,-0.391438,0.308434,0.074144,-0.391015,0.309697,0.074144,-0.391438,0.308434,0.061144,-0.391587,0.307059,0.061144,-0.391587,0.307059,0.074144,-0.391438,0.308434,0.074144,-0.391587,0.307059,0.061144,-0.391587,0.286911,0.061144,-0.391587,0.286911,0.074144,-0.391587,0.307059,0.074144,-0.391587,0.286911,0.061144,-0.391438,0.285536,0.061144,-0.391438,0.285536,0.074144,-0.391587,0.286911,0.061144,-0.391438,0.285536,0.074144,-0.391587,0.286911,0.074144,-0.391438,0.285536,0.061144,-0.391014,0.284274,0.061144,-0.391014,0.284274,0.074144,-0.391438,0.285536,0.061144,-0.391014,0.284274,0.074144,-0.391438,0.285536,0.074144,-0.391014,0.284274,0.061144,-0.39035,0.28316,0.061144,-0.39035,0.28316,0.074144,-0.391014,0.284274,0.061144,-0.39035,0.28316,0.074144,-0.391014,0.284274,0.074144,-0.39035,0.28316,0.061144,-0.389479,0.28223,0.061144,-0.389479,0.28223,0.074144,-0.39035,0.28316,0.061144,-0.389479,0.28223,0.074144,-0.39035,0.28316,0.074144,-0.389479,0.28223,0.061144,-0.388435,0.281522,0.061144,-0.388435,0.281522,0.074144,-0.389479,0.28223,0.074144,-0.388435,0.281522,0.061144,-0.387251,0.28107,0.061144,-0.387251,0.28107,0.074144,-0.388435,0.281522,0.074144,-0.387251,0.28107,0.061144,-0.385962,0.280911,0.061144,-0.385962,0.280911,0.074144,-0.387251,0.28107,0.074144,-0.385962,0.280911,0.061144,-0.33568,0.280911,0.061144,-0.33568,0.280911,0.074144,-0.385962,0.280911,0.074144,-0.33568,0.280911,0.061144,-0.334391,0.28107,0.061144,-0.334391,0.28107,0.074144,-0.33568,0.280911,0.074144,-0.334391,0.28107,0.061144,-0.333208,0.281522,0.061144,-0.333208,0.281522,0.074144,-0.334391,0.28107,0.074144,-0.333208,0.281522,0.061144,-0.332163,0.28223,0.061144,-0.332163,0.28223,0.074144,-0.333208,0.281522,0.074144,-0.332163,0.28223,0.061144,-0.331292,0.28316,0.061144,-0.331292,0.28316,0.074144,-0.332163,0.28223,0.074144,-0.331292,0.28316,0.061144,-0.330628,0.284274,0.061144,-0.330628,0.284274,0.074144,-0.331292,0.28316,0.074144,-0.330628,0.284274,0.061144,-0.330204,0.285536,0.061144,-0.330204,0.285536,0.074144,-0.330628,0.284274,0.074144,-0.330204,0.285536,0.061144,-0.330056,0.286911,0.061144,-0.330056,0.286911,0.074144,-0.330204,0.285536,0.074144,-0.330056,0.286911,0.061144,-0.330056,0.307059,0.061144,-0.330056,0.307059,0.074144,-0.330056,0.286911,0.074144,-0.330056,0.307059,0.061144,-0.330204,0.308434,0.061144,-0.330204,0.308434,0.074144,-0.330056,0.307059,0.074144,-0.330204,0.308434,0.061144,-0.330628,0.309697,0.061144,-0.330628,0.309697,0.074144,-0.330204,0.308434,0.074144,-0.330628,0.309697,0.061144,-0.331292,0.310811,0.061144,-0.331292,0.310811,0.074144,-0.330628,0.309697,0.074144,-0.331292,0.310811,0.061144,-0.332163,0.31174,0.061144,-0.332163,0.31174,0.074144,-0.331292,0.310811,0.074144,-0.332163,0.31174,0.061144,-0.333208,0.312449,0.061144,-0.333208,0.312449,0.074144,-0.332163,0.31174,0.074144,-0.333208,0.312449,0.061144,-0.334391,0.312901,0.061144,-0.334391,0.312901,0.074144,-0.333208,0.312449,0.074144,-0.334391,0.312901,0.061144,-0.33568,0.313059,0.061144,-0.33568,0.313059,0.074144,-0.334391,0.312901,0.074144,-0.33568,0.313059,0.061144,-0.385962,0.313059,0.061144,-0.385962,0.313059,0.074144,-0.33568,0.313059,0.074144,-0.385962,0.313059,0.061144,-0.387251,0.312901,0.061144,-0.387251,0.312901,0.074144,-0.385962,0.313059,0.074144,-0.465823,0.312901,0.061144,-0.467006,0.312449,0.061144,-0.467006,0.312449,0.074144,-0.465823,0.312901,0.074144,-0.467006,0.312449,0.061144,-0.46805,0.31174,0.061144,-0.46805,0.31174,0.074144,-0.467006,0.312449,0.074144,-0.46805,0.31174,0.061144,-0.468922,0.310811,0.061144,-0.468922,0.310811,0.074144,-0.46805,0.31174,0.074144,-0.468922,0.310811,0.061144,-0.469586,0.309697,0.061144,-0.469586,0.309697,0.074144,-0.468922,0.310811,0.074144,-0.469586,0.309697,0.061144,-0.470009,0.308434,0.061144,-0.470009,0.308434,0.074144,-0.469586,0.309697,0.074144,-0.470009,0.308434,0.061144,-0.470158,0.307059,0.061144,-0.470158,0.307059,0.074144,-0.470009,0.308434,0.074144,-0.470158,0.307059,0.061144,-0.470158,0.286911,0.061144,-0.470158,0.286911,0.074144,-0.470158,0.307059,0.074144,-0.470158,0.286911,0.061144,-0.470009,0.285536,0.061144,-0.470009,0.285536,0.074144,-0.470158,0.286911,0.074144,-0.470009,0.285536,0.061144,-0.469586,0.284274,0.061144,-0.469586,0.284274,0.074144,-0.470009,0.285536,0.074144,-0.469586,0.284274,0.061144,-0.468922,0.28316,0.061144,-0.468922,0.28316,0.074144,-0.469586,0.284274,0.074144,-0.468922,0.28316,0.061144,-0.46805,0.28223,0.061144,-0.46805,0.28223,0.074144,-0.468922,0.28316,0.074144,-0.46805,0.28223,0.061144,-0.467006,0.281522,0.061144,-0.467006,0.281522,0.074144,-0.46805,0.28223,0.074144,-0.467006,0.281522,0.061144,-0.465823,0.28107,0.061144,-0.465823,0.28107,0.074144,-0.467006,0.281522,0.074144,-0.465823,0.28107,0.061144,-0.464534,0.280911,0.061144,-0.464534,0.280911,0.074144,-0.465823,0.28107,0.074144,-0.464534,0.280911,0.061144,-0.414251,0.280911,0.061144,-0.414251,0.280911,0.074144,-0.464534,0.280911,0.074144,-0.414251,0.280911,0.061144,-0.412963,0.28107,0.061144,-0.412963,0.28107,0.074144,-0.414251,0.280911,0.074144,-0.412963,0.28107,0.061144,-0.411779,0.281522,0.061144,-0.411779,0.281522,0.074144,-0.412963,0.28107,0.074144,-0.411779,0.281522,0.061144,-0.410735,0.28223,0.061144,-0.410735,0.28223,0.074144,-0.411779,0.281522,0.074144,-0.410735,0.28223,0.061144,-0.409864,0.28316,0.061144,-0.409864,0.28316,0.074144,-0.410735,0.28223,0.074144,-0.409864,0.28316,0.061144,-0.409199,0.284274,0.061144,-0.409199,0.284274,0.074144,-0.409864,0.28316,0.074144,-0.409199,0.284274,0.061144,-0.408776,0.285536,0.061144,-0.408776,0.285536,0.074144,-0.409199,0.284274,0.074144,-0.408776,0.285536,0.061144,-0.408627,0.286911,0.061144,-0.408627,0.286911,0.074144,-0.408776,0.285536,0.074144,-0.408627,0.286911,0.061144,-0.408627,0.307059,0.061144,-0.408627,0.307059,0.074144,-0.408627,0.286911,0.074144,-0.408627,0.307059,0.061144,-0.408776,0.308434,0.061144,-0.408776,0.308434,0.074144,-0.408627,0.307059,0.074144,-0.408776,0.308434,0.061144,-0.409199,0.309697,0.061144,-0.409199,0.309697,0.074144,-0.408776,0.308434,0.074144,-0.409199,0.309697,0.061144,-0.409864,0.310811,0.061144,-0.409864,0.310811,0.074144,-0.409199,0.309697,0.074144,-0.409864,0.310811,0.061144,-0.410735,0.31174,0.061144,-0.410735,0.31174,0.074144,-0.409864,0.310811,0.074144,-0.410735,0.31174,0.061144,-0.411779,0.312449,0.061144,-0.411779,0.312449,0.074144,-0.410735,0.31174,0.074144,-0.411779,0.312449,0.061144,-0.412963,0.312901,0.061144,-0.412963,0.312901,0.074144,-0.411779,0.312449,0.074144,-0.412963,0.312901,0.061144,-0.414251,0.313059,0.061144,-0.414251,0.313059,0.074144,-0.412963,0.312901,0.074144,-0.414251,0.313059,0.061144,-0.464534,0.313059,0.061144,-0.464534,0.313059,0.074144,-0.414251,0.313059,0.074144,-0.464534,0.313059,0.061144,-0.465823,0.312901,0.061144,-0.465823,0.312901,0.074144,-0.464534,0.313059,0.074144,-0.544394,0.312901,0.061144,-0.545577,0.312449,0.061144,-0.545577,0.312449,0.074144,-0.544394,0.312901,0.074144,-0.545577,0.312449,0.061144,-0.546622,0.31174,0.061144,-0.546622,0.31174,0.074144,-0.545577,0.312449,0.074144,-0.546622,0.31174,0.061144,-0.547493,0.310811,0.061144,-0.547493,0.310811,0.074144,-0.546622,0.31174,0.074144,-0.547493,0.310811,0.061144,-0.548157,0.309697,0.061144,-0.548157,0.309697,0.074144,-0.547493,0.310811,0.074144,-0.548157,0.309697,0.061144,-0.548581,0.308434,0.061144,-0.548581,0.308434,0.074144,-0.548157,0.309697,0.061144,-0.548581,0.308434,0.074144,-0.548157,0.309697,0.074144,-0.548581,0.308434,0.061144,-0.54873,0.307059,0.061144,-0.54873,0.307059,0.074144,-0.548581,0.308434,0.061144,-0.54873,0.307059,0.074144,-0.548581,0.308434,0.074144,-0.54873,0.307059,0.061144,-0.54873,0.286911,0.061144,-0.54873,0.286911,0.074144,-0.54873,0.307059,0.074144,-0.54873,0.286911,0.061144,-0.548581,0.285536,0.061144,-0.548581,0.285536,0.074144,-0.54873,0.286911,0.074144,-0.548581,0.285536,0.061144,-0.548157,0.284274,0.061144,-0.548157,0.284274,0.074144,-0.548581,0.285536,0.074144,-0.548157,0.284274,0.061144,-0.547493,0.28316,0.061144,-0.547493,0.28316,0.074144,-0.548157,0.284274,0.074144,-0.547493,0.28316,0.061144,-0.546622,0.28223,0.061144,-0.546622,0.28223,0.074144,-0.547493,0.28316,0.061144,-0.546622,0.28223,0.074144,-0.547493,0.28316,0.074144,-0.546622,0.28223,0.061144,-0.545578,0.281522,0.061144,-0.545578,0.281522,0.074144,-0.546622,0.28223,0.061144,-0.545578,0.281522,0.074144,-0.546622,0.28223,0.074144,-0.545578,0.281522,0.061144,-0.544394,0.28107,0.061144,-0.544394,0.28107,0.074144,-0.545578,0.281522,0.074144,-0.544394,0.28107,0.061144,-0.543105,0.280911,0.061144,-0.543105,0.280911,0.074144,-0.544394,0.28107,0.074144,-0.543105,0.280911,0.061144,-0.492823,0.280911,0.061144,-0.492823,0.280911,0.074144,-0.543105,0.280911,0.074144,-0.492823,0.280911,0.061144,-0.491534,0.28107,0.061144,-0.491534,0.28107,0.074144,-0.492823,0.280911,0.074144,-0.491534,0.28107,0.061144,-0.49035,0.281521,0.061144,-0.49035,0.281521,0.074144,-0.491534,0.28107,0.074144,-0.49035,0.281521,0.061144,-0.489306,0.28223,0.061144,-0.489306,0.28223,0.074144,-0.49035,0.281521,0.074144,-0.489306,0.28223,0.061144,-0.488435,0.28316,0.061144,-0.488435,0.28316,0.074144,-0.489306,0.28223,0.074144,-0.488435,0.28316,0.061144,-0.487771,0.284274,0.061144,-0.487771,0.284274,0.074144,-0.488435,0.28316,0.074144,-0.487771,0.284274,0.061144,-0.487347,0.285536,0.061144,-0.487347,0.285536,0.074144,-0.487771,0.284274,0.074144,-0.487347,0.285536,0.061144,-0.487199,0.286911,0.061144,-0.487199,0.286911,0.074144,-0.487347,0.285536,0.074144,-0.487199,0.286911,0.061144,-0.487199,0.307059,0.061144,-0.487199,0.307059,0.074144,-0.487199,0.286911,0.074144,-0.487199,0.307059,0.061144,-0.487347,0.308434,0.061144,-0.487347,0.308434,0.074144,-0.487199,0.307059,0.074144,-0.487347,0.308434,0.061144,-0.487771,0.309696,0.061144,-0.487771,0.309696,0.074144,-0.487347,0.308434,0.074144,-0.487771,0.309696,0.061144,-0.488435,0.310811,0.061144,-0.488435,0.310811,0.074144,-0.487771,0.309696,0.074144,-0.488435,0.310811,0.061144,-0.489306,0.31174,0.061144,-0.489306,0.31174,0.074144,-0.488435,0.310811,0.074144,-0.489306,0.31174,0.061144,-0.490351,0.312449,0.061144,-0.490351,0.312449,0.074144,-0.489306,0.31174,0.074144,-0.490351,0.312449,0.061144,-0.491534,0.312901,0.061144,-0.491534,0.312901,0.074144,-0.490351,0.312449,0.074144,-0.491534,0.312901,0.061144,-0.492823,0.313059,0.061144,-0.492823,0.313059,0.074144,-0.491534,0.312901,0.074144,-0.492823,0.313059,0.061144,-0.543105,0.313059,0.061144,-0.543105,0.313059,0.074144,-0.492823,0.313059,0.074144,-0.543105,0.313059,0.061144,-0.544394,0.312901,0.061144,-0.544394,0.312901,0.074144,-0.543105,0.313059,0.074144,-0.622966,0.312901,0.061144,-0.624149,0.312449,0.061144,-0.624149,0.312449,0.074144,-0.622966,0.312901,0.074144,-0.624149,0.312449,0.061144,-0.625193,0.31174,0.061144,-0.625193,0.31174,0.074144,-0.624149,0.312449,0.074144,-0.625193,0.31174,0.061144,-0.626064,0.310811,0.061144,-0.626064,0.310811,0.074144,-0.625193,0.31174,0.074144,-0.626064,0.310811,0.061144,-0.626729,0.309697,0.061144,-0.626729,0.309697,0.074144,-0.626064,0.310811,0.074144,-0.626729,0.309697,0.061144,-0.627152,0.308434,0.061144,-0.627152,0.308434,0.074144,-0.626729,0.309697,0.074144,-0.627152,0.308434,0.061144,-0.627301,0.307059,0.061144,-0.627301,0.307059,0.074144,-0.627152,0.308434,0.074144,-0.627301,0.307059,0.061144,-0.627301,0.286911,0.061144,-0.627301,0.286911,0.074144,-0.627301,0.307059,0.074144,-0.627301,0.286911,0.061144,-0.627152,0.285536,0.061144,-0.627152,0.285536,0.074144,-0.627301,0.286911,0.074144,-0.627152,0.285536,0.061144,-0.626729,0.284274,0.061144,-0.626729,0.284274,0.074144,-0.627152,0.285536,0.074144,-0.626729,0.284274,0.061144,-0.626064,0.28316,0.061144,-0.626064,0.28316,0.074144,-0.626729,0.284274,0.074144,-0.626064,0.28316,0.061144,-0.625193,0.28223,0.061144,-0.625193,0.28223,0.074144,-0.626064,0.28316,0.074144,-0.625193,0.28223,0.061144,-0.624149,0.281522,0.061144,-0.624149,0.281522,0.074144,-0.625193,0.28223,0.074144,-0.624149,0.281522,0.061144,-0.622966,0.28107,0.061144,-0.622966,0.28107,0.074144,-0.624149,0.281522,0.074144,-0.622966,0.28107,0.061144,-0.621677,0.280911,0.061144,-0.621677,0.280911,0.074144,-0.622966,0.28107,0.074144,-0.621677,0.280911,0.061144,-0.571394,0.280911,0.061144,-0.571394,0.280911,0.074144,-0.621677,0.280911,0.074144,-0.571394,0.280911,0.061144,-0.570105,0.28107,0.061144,-0.570105,0.28107,0.074144,-0.571394,0.280911,0.074144,-0.570105,0.28107,0.061144,-0.568922,0.281521,0.061144,-0.568922,0.281521,0.074144,-0.570105,0.28107,0.074144,-0.568922,0.281521,0.061144,-0.567878,0.28223,0.061144,-0.567878,0.28223,0.074144,-0.568922,0.281521,0.074144,-0.567878,0.28223,0.061144,-0.567006,0.28316,0.061144,-0.567006,0.28316,0.074144,-0.567878,0.28223,0.074144,-0.567006,0.28316,0.061144,-0.566342,0.284274,0.061144,-0.566342,0.284274,0.074144,-0.567006,0.28316,0.074144,-0.566342,0.284274,0.061144,-0.565919,0.285536,0.061144,-0.565919,0.285536,0.074144,-0.566342,0.284274,0.074144,-0.565919,0.285536,0.061144,-0.56577,0.286911,0.061144,-0.56577,0.286911,0.074144,-0.565919,0.285536,0.074144,-0.56577,0.286911,0.061144,-0.56577,0.307059,0.061144,-0.56577,0.307059,0.074144,-0.56577,0.286911,0.074144,-0.56577,0.307059,0.061144,-0.565919,0.308434,0.061144,-0.565919,0.308434,0.074144,-0.56577,0.307059,0.074144,-0.565919,0.308434,0.061144,-0.566342,0.309696,0.061144,-0.566342,0.309696,0.074144,-0.565919,0.308434,0.074144,-0.566342,0.309696,0.061144,-0.567006,0.310811,0.061144,-0.567006,0.310811,0.074144,-0.566342,0.309696,0.074144,-0.567006,0.310811,0.061144,-0.567878,0.31174,0.061144,-0.567878,0.31174,0.074144,-0.567006,0.310811,0.074144,-0.567878,0.31174,0.061144,-0.568922,0.312449,0.061144,-0.568922,0.312449,0.074144,-0.567878,0.31174,0.074144,-0.568922,0.312449,0.061144,-0.570105,0.312901,0.061144,-0.570105,0.312901,0.074144,-0.568922,0.312449,0.074144,-0.570105,0.312901,0.061144,-0.571394,0.313059,0.061144,-0.571394,0.313059,0.074144,-0.570105,0.312901,0.074144,-0.571394,0.313059,0.061144,-0.621677,0.313059,0.061144,-0.621677,0.313059,0.074144,-0.571394,0.313059,0.074144,-0.621677,0.313059,0.061144,-0.622966,0.312901,0.061144,-0.622966,0.312901,0.074144,-0.621677,0.313059,0.074144,0.396004,0.270109,0.061144,0.39482,0.269658,0.061144,0.39482,0.269658,0.074144,0.396004,0.270109,0.074144,0.39482,0.269658,0.061144,0.393776,0.268949,0.061144,0.393776,0.268949,0.074144,0.39482,0.269658,0.074144,0.393776,0.268949,0.061144,0.392905,0.26802,0.061144,0.392905,0.26802,0.074144,0.393776,0.268949,0.074144,0.392905,0.26802,0.061144,0.392241,0.266905,0.061144,0.392241,0.266905,0.074144,0.392905,0.26802,0.074144,0.392241,0.266905,0.061144,0.391817,0.265643,0.061144,0.391817,0.265643,0.074144,0.392241,0.266905,0.074144,0.391817,0.265643,0.061144,0.391668,0.264268,0.061144,0.391668,0.264268,0.074144,0.391817,0.265643,0.074144,0.391668,0.264268,0.061144,0.391668,0.21912,0.061144,0.391668,0.21912,0.074144,0.391668,0.264268,0.074144,0.391668,0.21912,0.061144,0.391817,0.217745,0.061144,0.391817,0.217745,0.074144,0.391668,0.21912,0.074144,0.391817,0.217745,0.061144,0.392241,0.216483,0.061144,0.392241,0.216483,0.074144,0.391817,0.217745,0.074144,0.392241,0.216483,0.061144,0.392905,0.215369,0.061144,0.392905,0.215369,0.074144,0.392241,0.216483,0.074144,0.392905,0.215369,0.061144,0.393776,0.214439,0.061144,0.393776,0.214439,0.074144,0.392905,0.215369,0.074144,0.393776,0.214439,0.061144,0.394821,0.21373,0.061144,0.394821,0.21373,0.074144,0.393776,0.214439,0.074144,0.394821,0.21373,0.061144,0.396004,0.213279,0.061144,0.396004,0.213279,0.074144,0.394821,0.21373,0.074144,0.396004,0.213279,0.061144,0.397293,0.21312,0.061144,0.397293,0.21312,0.074144,0.396004,0.213279,0.074144,0.397293,0.21312,0.061144,0.443721,0.21312,0.061144,0.443721,0.21312,0.074144,0.397293,0.21312,0.074144,0.443721,0.21312,0.061144,0.44501,0.213279,0.061144,0.44501,0.213279,0.074144,0.443721,0.21312,0.061144,0.44501,0.213279,0.074144,0.443721,0.21312,0.074144,0.44501,0.213279,0.061144,0.446194,0.21373,0.061144,0.446194,0.21373,0.074144,0.44501,0.213279,0.061144,0.446194,0.21373,0.074144,0.44501,0.213279,0.074144,0.446194,0.21373,0.061144,0.447238,0.214439,0.061144,0.447238,0.214439,0.074144,0.446194,0.21373,0.061144,0.447238,0.214439,0.074144,0.446194,0.21373,0.074144,0.447238,0.214439,0.061144,0.448109,0.215369,0.061144,0.448109,0.215369,0.074144,0.447238,0.214439,0.074144,0.448109,0.215369,0.061144,0.448773,0.216483,0.061144,0.448773,0.216483,0.074144,0.448109,0.215369,0.074144,0.448773,0.216483,0.061144,0.449197,0.217745,0.061144,0.449197,0.217745,0.074144,0.448773,0.216483,0.061144,0.449197,0.217745,0.074144,0.448773,0.216483,0.074144,0.449197,0.217745,0.061144,0.449346,0.21912,0.061144,0.449346,0.21912,0.074144,0.449197,0.217745,0.061144,0.449346,0.21912,0.074144,0.449197,0.217745,0.074144,0.449346,0.21912,0.061144,0.449345,0.264268,0.061144,0.449345,0.264268,0.074144,0.449346,0.21912,0.074144,0.449345,0.264268,0.061144,0.449197,0.265643,0.061144,0.449197,0.265643,0.074144,0.449345,0.264268,0.074144,0.449197,0.265643,0.061144,0.448773,0.266905,0.061144,0.448773,0.266905,0.074144,0.449197,0.265643,0.074144,0.448773,0.266905,0.061144,0.448109,0.268019,0.061144,0.448109,0.268019,0.074144,0.448773,0.266905,0.074144,0.448109,0.268019,0.061144,0.447238,0.268949,0.061144,0.447238,0.268949,0.074144,0.448109,0.268019,0.074144,0.447238,0.268949,0.061144,0.446194,0.269658,0.061144,0.446194,0.269658,0.074144,0.447238,0.268949,0.074144,0.446194,0.269658,0.061144,0.44501,0.270109,0.061144,0.44501,0.270109,0.074144,0.446194,0.269658,0.074144,0.44501,0.270109,0.061144,0.443721,0.270268,0.061144,0.443721,0.270268,0.074144,0.44501,0.270109,0.074144,0.443721,0.270268,0.061144,0.397293,0.270268,0.061144,0.397293,0.270268,0.074144,0.443721,0.270268,0.061144,0.397293,0.270268,0.074144,0.443721,0.270268,0.074144,0.397293,0.270268,0.061144,0.396004,0.270109,0.061144,0.396004,0.270109,0.074144,0.397293,0.270268,0.061144,0.396004,0.270109,0.074144,0.397293,0.270268,0.074144,0.330478,0.270109,0.061144,0.329295,0.269658,0.061144,0.329295,0.269658,0.074144,0.330478,0.270109,0.074144,0.329295,0.269658,0.061144,0.328251,0.268949,0.061144,0.328251,0.268949,0.074144,0.329295,0.269658,0.074144,0.328251,0.268949,0.061144,0.327379,0.268019,0.061144,0.327379,0.268019,0.074144,0.328251,0.268949,0.074144,0.327379,0.268019,0.061144,0.326715,0.266905,0.061144,0.326715,0.266905,0.074144,0.327379,0.268019,0.074144,0.326715,0.266905,0.061144,0.326292,0.265643,0.061144,0.326292,0.265643,0.074144,0.326715,0.266905,0.074144,0.326292,0.265643,0.061144,0.326143,0.264268,0.061144,0.326143,0.264268,0.074144,0.326292,0.265643,0.074144,0.326143,0.264268,0.061144,0.326143,0.21912,0.061144,0.326143,0.21912,0.074144,0.326143,0.264268,0.074144,0.326143,0.21912,0.061144,0.326292,0.217745,0.061144,0.326292,0.217745,0.074144,0.326143,0.21912,0.074144,0.326292,0.217745,0.061144,0.326715,0.216483,0.061144,0.326715,0.216483,0.074144,0.326292,0.217745,0.074144,0.326715,0.216483,0.061144,0.327379,0.215369,0.061144,0.327379,0.215369,0.074144,0.326715,0.216483,0.074144,0.327379,0.215369,0.061144,0.328251,0.214439,0.061144,0.328251,0.214439,0.074144,0.327379,0.215369,0.074144,0.328251,0.214439,0.061144,0.329295,0.21373,0.061144,0.329295,0.21373,0.074144,0.328251,0.214439,0.074144,0.329295,0.21373,0.061144,0.330478,0.213279,0.061144,0.330478,0.213279,0.074144,0.329295,0.21373,0.074144,0.330478,0.213279,0.061144,0.331767,0.21312,0.061144,0.331767,0.21312,0.074144,0.330478,0.213279,0.074144,0.331767,0.21312,0.061144,0.378196,0.21312,0.061144,0.378196,0.21312,0.074144,0.331767,0.21312,0.074144,0.378196,0.21312,0.061144,0.379485,0.213279,0.061144,0.379485,0.213279,0.074144,0.378196,0.21312,0.074144,0.379485,0.213279,0.061144,0.380668,0.21373,0.061144,0.380668,0.21373,0.074144,0.379485,0.213279,0.074144,0.380668,0.21373,0.061144,0.381712,0.214439,0.061144,0.381712,0.214439,0.074144,0.380668,0.21373,0.074144,0.381712,0.214439,0.061144,0.382584,0.215369,0.061144,0.382584,0.215369,0.074144,0.381712,0.214439,0.074144,0.382584,0.215369,0.061144,0.383248,0.216483,0.061144,0.383248,0.216483,0.074144,0.382584,0.215369,0.074144,0.383248,0.216483,0.061144,0.383671,0.217745,0.061144,0.383671,0.217745,0.074144,0.383248,0.216483,0.074144,0.383671,0.217745,0.061144,0.38382,0.21912,0.061144,0.38382,0.21912,0.074144,0.383671,0.217745,0.074144,0.38382,0.21912,0.061144,0.38382,0.264268,0.061144,0.38382,0.264268,0.074144,0.38382,0.21912,0.074144,0.38382,0.264268,0.061144,0.383671,0.265643,0.061144,0.383671,0.265643,0.074144,0.38382,0.264268,0.074144,0.383671,0.265643,0.061144,0.383248,0.266905,0.061144,0.383248,0.266905,0.074144,0.383671,0.265643,0.074144,0.383248,0.266905,0.061144,0.382584,0.268019,0.061144,0.382584,0.268019,0.074144,0.383248,0.266905,0.074144,0.382584,0.268019,0.061144,0.381712,0.268949,0.061144,0.381712,0.268949,0.074144,0.382584,0.268019,0.074144,0.381712,0.268949,0.061144,0.380668,0.269658,0.061144,0.380668,0.269658,0.074144,0.381712,0.268949,0.074144,0.380668,0.269658,0.061144,0.379485,0.270109,0.061144,0.379485,0.270109,0.074144,0.380668,0.269658,0.074144,0.379485,0.270109,0.061144,0.378196,0.270268,0.061144,0.378196,0.270268,0.074144,0.379485,0.270109,0.074144,0.378196,0.270268,0.061144,0.331767,0.270268,0.061144,0.331767,0.270268,0.074144,0.378196,0.270268,0.074144,0.331767,0.270268,0.061144,0.330478,0.270109,0.061144,0.330478,0.270109,0.074144,0.331767,0.270268,0.074144,0.256828,0.270109,0.061144,0.255645,0.269658,0.061144,0.255645,0.269658,0.074144,0.256828,0.270109,0.074144,0.255645,0.269658,0.061144,0.254601,0.268949,0.061144,0.254601,0.268949,0.074144,0.255645,0.269658,0.074144,0.254601,0.268949,0.061144,0.253729,0.268019,0.061144,0.253729,0.268019,0.074144,0.254601,0.268949,0.074144,0.253729,0.268019,0.061144,0.253065,0.266905,0.061144,0.253065,0.266905,0.074144,0.253729,0.268019,0.074144,0.253065,0.266905,0.061144,0.252642,0.265643,0.061144,0.252642,0.265643,0.074144,0.253065,0.266905,0.074144,0.252642,0.265643,0.061144,0.252493,0.264268,0.061144,0.252493,0.264268,0.074144,0.252642,0.265643,0.074144,0.252493,0.264268,0.061144,0.252493,0.21912,0.061144,0.252493,0.21912,0.074144,0.252493,0.264268,0.074144,0.252493,0.21912,0.061144,0.252642,0.217745,0.061144,0.252642,0.217745,0.074144,0.252493,0.21912,0.074144,0.252642,0.217745,0.061144,0.253065,0.216483,0.061144,0.253065,0.216483,0.074144,0.252642,0.217745,0.074144,0.253065,0.216483,0.061144,0.253729,0.215369,0.061144,0.253729,0.215369,0.074144,0.253065,0.216483,0.061144,0.253729,0.215369,0.074144,0.253065,0.216483,0.074144,0.253729,0.215369,0.061144,0.254601,0.214439,0.061144,0.254601,0.214439,0.074144,0.253729,0.215369,0.074144,0.254601,0.214439,0.061144,0.255645,0.21373,0.061144,0.255645,0.21373,0.074144,0.254601,0.214439,0.074144,0.255645,0.21373,0.061144,0.256828,0.213279,0.061144,0.256828,0.213279,0.074144,0.255645,0.21373,0.061144,0.256828,0.213279,0.074144,0.255645,0.21373,0.074144,0.256828,0.213279,0.061144,0.258117,0.21312,0.061144,0.258117,0.21312,0.074144,0.256828,0.213279,0.074144,0.258117,0.21312,0.061144,0.304546,0.21312,0.061144,0.304546,0.21312,0.074144,0.258117,0.21312,0.061144,0.304546,0.21312,0.074144,0.258117,0.21312,0.074144,0.304546,0.21312,0.061144,0.305834,0.213279,0.061144,0.305834,0.213279,0.074144,0.304546,0.21312,0.074144,0.305834,0.213279,0.061144,0.307018,0.21373,0.061144,0.307018,0.21373,0.074144,0.305834,0.213279,0.074144,0.307018,0.21373,0.061144,0.308062,0.214439,0.061144,0.308062,0.214439,0.074144,0.307018,0.21373,0.074144,0.308062,0.214439,0.061144,0.308934,0.215369,0.061144,0.308934,0.215369,0.074144,0.308062,0.214439,0.061144,0.308934,0.215369,0.074144,0.308062,0.214439,0.074144,0.308934,0.215369,0.061144,0.309598,0.216483,0.061144,0.309598,0.216483,0.074144,0.308934,0.215369,0.074144,0.309598,0.216483,0.061144,0.310021,0.217745,0.061144,0.310021,0.217745,0.074144,0.309598,0.216483,0.061144,0.310021,0.217745,0.074144,0.309598,0.216483,0.074144,0.310021,0.217745,0.061144,0.31017,0.21912,0.061144,0.31017,0.21912,0.074144,0.310021,0.217745,0.074144,0.31017,0.21912,0.061144,0.31017,0.264268,0.061144,0.31017,0.264268,0.074144,0.31017,0.21912,0.074144,0.31017,0.264268,0.061144,0.310021,0.265643,0.061144,0.310021,0.265643,0.074144,0.31017,0.264268,0.074144,0.310021,0.265643,0.061144,0.309598,0.266905,0.061144,0.309598,0.266905,0.074144,0.310021,0.265643,0.074144,0.309598,0.266905,0.061144,0.308933,0.268019,0.061144,0.308933,0.268019,0.074144,0.309598,0.266905,0.074144,0.308933,0.268019,0.061144,0.308062,0.268949,0.061144,0.308062,0.268949,0.074144,0.308933,0.268019,0.074144,0.308062,0.268949,0.061144,0.307018,0.269658,0.061144,0.307018,0.269658,0.074144,0.308062,0.268949,0.074144,0.307018,0.269658,0.061144,0.305834,0.270109,0.061144,0.305834,0.270109,0.074144,0.307018,0.269658,0.074144,0.305834,0.270109,0.061144,0.304546,0.270268,0.061144,0.304546,0.270268,0.074144,0.305834,0.270109,0.074144,0.304546,0.270268,0.061144,0.258117,0.270268,0.061144,0.258117,0.270268,0.074144,0.304546,0.270268,0.074144,0.258117,0.270268,0.061144,0.256828,0.270109,0.061144,0.256828,0.270109,0.074144,0.258117,0.270268,0.074144,0.183178,0.270109,0.061144,0.181995,0.269658,0.061144,0.181995,0.269658,0.074144,0.183178,0.270109,0.074144,0.181995,0.269658,0.061144,0.18095,0.268949,0.061144,0.18095,0.268949,0.074144,0.181995,0.269658,0.074144,0.18095,0.268949,0.061144,0.180079,0.268019,0.061144,0.180079,0.268019,0.074144,0.18095,0.268949,0.074144,0.180079,0.268019,0.061144,0.179415,0.266905,0.061144,0.179415,0.266905,0.074144,0.180079,0.268019,0.074144,0.179415,0.266905,0.061144,0.178991,0.265643,0.061144,0.178991,0.265643,0.074144,0.179415,0.266905,0.074144,0.178991,0.265643,0.061144,0.178843,0.264268,0.061144,0.178843,0.264268,0.074144,0.178991,0.265643,0.074144,0.178843,0.264268,0.061144,0.178843,0.21912,0.061144,0.178843,0.21912,0.074144,0.178843,0.264268,0.074144,0.178843,0.21912,0.061144,0.178991,0.217745,0.061144,0.178991,0.217745,0.074144,0.178843,0.21912,0.061144,0.178991,0.217745,0.074144,0.178843,0.21912,0.074144,0.178991,0.217745,0.061144,0.179415,0.216483,0.061144,0.179415,0.216483,0.074144,0.178991,0.217745,0.074144,0.179415,0.216483,0.061144,0.180079,0.215369,0.061144,0.180079,0.215369,0.074144,0.179415,0.216483,0.061144,0.180079,0.215369,0.074144,0.179415,0.216483,0.074144,0.180079,0.215369,0.061144,0.180951,0.214439,0.061144,0.180951,0.214439,0.074144,0.180079,0.215369,0.074144,0.180951,0.214439,0.061144,0.181995,0.21373,0.061144,0.181995,0.21373,0.074144,0.180951,0.214439,0.074144,0.181995,0.21373,0.061144,0.183178,0.213279,0.061144,0.183178,0.213279,0.074144,0.181995,0.21373,0.074144,0.183178,0.213279,0.061144,0.184467,0.21312,0.061144,0.184467,0.21312,0.074144,0.183178,0.213279,0.074144,0.184467,0.21312,0.061144,0.230896,0.21312,0.061144,0.230896,0.21312,0.074144,0.184467,0.21312,0.074144,0.230896,0.21312,0.061144,0.232184,0.213279,0.061144,0.232184,0.213279,0.074144,0.230896,0.21312,0.074144,0.232184,0.213279,0.061144,0.233368,0.21373,0.061144,0.233368,0.21373,0.074144,0.232184,0.213279,0.074144,0.233368,0.21373,0.061144,0.234412,0.214439,0.061144,0.234412,0.214439,0.074144,0.233368,0.21373,0.074144,0.234412,0.214439,0.061144,0.235283,0.215369,0.061144,0.235283,0.215369,0.074144,0.234412,0.214439,0.074144,0.235283,0.215369,0.061144,0.235948,0.216483,0.061144,0.235948,0.216483,0.074144,0.235283,0.215369,0.074144,0.235948,0.216483,0.061144,0.236371,0.217745,0.061144,0.236371,0.217745,0.074144,0.235948,0.216483,0.074144,0.236371,0.217745,0.061144,0.23652,0.21912,0.061144,0.23652,0.21912,0.074144,0.236371,0.217745,0.074144,0.23652,0.21912,0.061144,0.23652,0.264268,0.061144,0.23652,0.264268,0.074144,0.23652,0.21912,0.074144,0.23652,0.264268,0.061144,0.236371,0.265643,0.061144,0.236371,0.265643,0.074144,0.23652,0.264268,0.074144,0.236371,0.265643,0.061144,0.235948,0.266905,0.061144,0.235948,0.266905,0.074144,0.236371,0.265643,0.074144,0.235948,0.266905,0.061144,0.235283,0.268019,0.061144,0.235283,0.268019,0.074144,0.235948,0.266905,0.074144,0.235283,0.268019,0.061144,0.234412,0.268949,0.061144,0.234412,0.268949,0.074144,0.235283,0.268019,0.074144,0.234412,0.268949,0.061144,0.233368,0.269658,0.061144,0.233368,0.269658,0.074144,0.234412,0.268949,0.061144,0.233368,0.269658,0.074144,0.234412,0.268949,0.074144,0.233368,0.269658,0.061144,0.232184,0.270109,0.061144,0.232184,0.270109,0.074144,0.233368,0.269658,0.074144,0.232184,0.270109,0.061144,0.230896,0.270268,0.061144,0.230896,0.270268,0.074144,0.232184,0.270109,0.074144,0.230896,0.270268,0.061144,0.184467,0.270268,0.061144,0.184467,0.270268,0.074144,0.230896,0.270268,0.074144,0.184467,0.270268,0.061144,0.183178,0.270109,0.061144,0.183178,0.270109,0.074144,0.184467,0.270268,0.074144,0.109528,0.270109,0.061144,0.108345,0.269658,0.061144,0.108345,0.269658,0.074144,0.109528,0.270109,0.074144,0.108345,0.269658,0.061144,0.1073,0.268949,0.061144,0.1073,0.268949,0.074144,0.108345,0.269658,0.074144,0.1073,0.268949,0.061144,0.106429,0.268019,0.061144,0.106429,0.268019,0.074144,0.1073,0.268949,0.074144,0.106429,0.268019,0.061144,0.105765,0.266905,0.061144,0.105765,0.266905,0.074144,0.106429,0.268019,0.074144,0.105765,0.266905,0.061144,0.105341,0.265643,0.061144,0.105341,0.265643,0.074144,0.105765,0.266905,0.074144,0.105341,0.265643,0.061144,0.105193,0.264268,0.061144,0.105193,0.264268,0.074144,0.105341,0.265643,0.074144,0.105193,0.264268,0.061144,0.105193,0.21912,0.061144,0.105193,0.21912,0.074144,0.105193,0.264268,0.074144,0.105193,0.21912,0.061144,0.105341,0.217745,0.061144,0.105341,0.217745,0.074144,0.105193,0.21912,0.074144,0.105341,0.217745,0.061144,0.105765,0.216483,0.061144,0.105765,0.216483,0.074144,0.105341,0.217745,0.074144,0.105765,0.216483,0.061144,0.106429,0.215369,0.061144,0.106429,0.215369,0.074144,0.105765,0.216483,0.074144,0.106429,0.215369,0.061144,0.1073,0.214439,0.061144,0.1073,0.214439,0.074144,0.106429,0.215369,0.074144,0.1073,0.214439,0.061144,0.108345,0.21373,0.061144,0.108345,0.21373,0.074144,0.1073,0.214439,0.074144,0.108345,0.21373,0.061144,0.109528,0.213279,0.061144,0.109528,0.213279,0.074144,0.108345,0.21373,0.074144,0.109528,0.213279,0.061144,0.110817,0.21312,0.061144,0.110817,0.21312,0.074144,0.109528,0.213279,0.074144,0.110817,0.21312,0.061144,0.157246,0.21312,0.061144,0.157246,0.21312,0.074144,0.110817,0.21312,0.074144,0.157246,0.21312,0.061144,0.158534,0.213279,0.061144,0.158534,0.213279,0.074144,0.157246,0.21312,0.074144,0.158534,0.213279,0.061144,0.159718,0.21373,0.061144,0.159718,0.21373,0.074144,0.158534,0.213279,0.074144,0.159718,0.21373,0.061144,0.160762,0.214439,0.061144,0.160762,0.214439,0.074144,0.159718,0.21373,0.074144,0.160762,0.214439,0.061144,0.161633,0.215369,0.061144,0.161633,0.215369,0.074144,0.160762,0.214439,0.074144,0.161633,0.215369,0.061144,0.162298,0.216483,0.061144,0.162298,0.216483,0.074144,0.161633,0.215369,0.074144,0.162298,0.216483,0.061144,0.162721,0.217745,0.061144,0.162721,0.217745,0.074144,0.162298,0.216483,0.074144,0.162721,0.217745,0.061144,0.16287,0.21912,0.061144,0.16287,0.21912,0.074144,0.162721,0.217745,0.074144,0.16287,0.21912,0.061144,0.16287,0.264268,0.061144,0.16287,0.264268,0.074144,0.16287,0.21912,0.074144,0.16287,0.264268,0.061144,0.162721,0.265643,0.061144,0.162721,0.265643,0.074144,0.16287,0.264268,0.074144,0.162721,0.265643,0.061144,0.162298,0.266905,0.061144,0.162298,0.266905,0.074144,0.162721,0.265643,0.074144,0.162298,0.266905,0.061144,0.161633,0.268019,0.061144,0.161633,0.268019,0.074144,0.162298,0.266905,0.061144,0.161633,0.268019,0.074144,0.162298,0.266905,0.074144,0.161633,0.268019,0.061144,0.160762,0.268949,0.061144,0.160762,0.268949,0.074144,0.161633,0.268019,0.074144,0.160762,0.268949,0.061144,0.159718,0.269658,0.061144,0.159718,0.269658,0.074144,0.160762,0.268949,0.061144,0.159718,0.269658,0.074144,0.160762,0.268949,0.074144,0.159718,0.269658,0.061144,0.158534,0.270109,0.061144,0.158534,0.270109,0.074144,0.159718,0.269658,0.061144,0.158534,0.270109,0.074144,0.159718,0.269658,0.074144,0.158534,0.270109,0.061144,0.157246,0.270268,0.061144,0.157246,0.270268,0.074144,0.158534,0.270109,0.061144,0.157246,0.270268,0.074144,0.158534,0.270109,0.074144,0.157246,0.270268,0.061144,0.110817,0.270268,0.061144,0.110817,0.270268,0.074144,0.157246,0.270268,0.074144,0.110817,0.270268,0.061144,0.109528,0.270109,0.061144,0.109528,0.270109,0.074144,0.110817,0.270268,0.074144,0.035878,0.270109,0.061144,0.034695,0.269658,0.061144,0.034695,0.269658,0.074144,0.035878,0.270109,0.074144,0.034695,0.269658,0.061144,0.03365,0.268949,0.061144,0.03365,0.268949,0.074144,0.034695,0.269658,0.074144,0.03365,0.268949,0.061144,0.032779,0.268019,0.061144,0.032779,0.268019,0.074144,0.03365,0.268949,0.074144,0.032779,0.268019,0.061144,0.032115,0.266905,0.061144,0.032115,0.266905,0.074144,0.032779,0.268019,0.074144,0.032115,0.266905,0.061144,0.031691,0.265643,0.061144,0.031691,0.265643,0.074144,0.032115,0.266905,0.074144,0.031691,0.265643,0.061144,0.031543,0.264268,0.061144,0.031543,0.264268,0.074144,0.031691,0.265643,0.074144,0.031543,0.264268,0.061144,0.031543,0.21912,0.061144,0.031543,0.21912,0.074144,0.031543,0.264268,0.074144,0.031543,0.21912,0.061144,0.031691,0.217745,0.061144,0.031691,0.217745,0.074144,0.031543,0.21912,0.061144,0.031691,0.217745,0.074144,0.031543,0.21912,0.074144,0.031691,0.217745,0.061144,0.032115,0.216483,0.061144,0.032115,0.216483,0.074144,0.031691,0.217745,0.074144,0.032115,0.216483,0.061144,0.032779,0.215369,0.061144,0.032779,0.215369,0.074144,0.032115,0.216483,0.074144,0.032779,0.215369,0.061144,0.03365,0.214439,0.061144,0.03365,0.214439,0.074144,0.032779,0.215369,0.074144,0.03365,0.214439,0.061144,0.034695,0.21373,0.061144,0.034695,0.21373,0.074144,0.03365,0.214439,0.074144,0.034695,0.21373,0.061144,0.035878,0.213279,0.061144,0.035878,0.213279,0.074144,0.034695,0.21373,0.074144,0.035878,0.213279,0.061144,0.037167,0.21312,0.061144,0.037167,0.21312,0.074144,0.035878,0.213279,0.074144,0.037167,0.21312,0.061144,0.083595,0.21312,0.061144,0.083595,0.21312,0.074144,0.037167,0.21312,0.061144,0.083595,0.21312,0.074144,0.037167,0.21312,0.074144,0.083595,0.21312,0.061144,0.084884,0.213279,0.061144,0.084884,0.213279,0.074144,0.083595,0.21312,0.074144,0.084884,0.213279,0.061144,0.086068,0.21373,0.061144,0.086068,0.21373,0.074144,0.084884,0.213279,0.074144,0.086068,0.21373,0.061144,0.087112,0.214439,0.061144,0.087112,0.214439,0.074144,0.086068,0.21373,0.074144,0.087112,0.214439,0.061144,0.087983,0.215369,0.061144,0.087983,0.215369,0.074144,0.087112,0.214439,0.074144,0.087983,0.215369,0.061144,0.088647,0.216483,0.061144,0.088647,0.216483,0.074144,0.087983,0.215369,0.074144,0.088647,0.216483,0.061144,0.089071,0.217745,0.061144,0.089071,0.217745,0.074144,0.088647,0.216483,0.074144,0.089071,0.217745,0.061144,0.08922,0.21912,0.061144,0.08922,0.21912,0.074144,0.089071,0.217745,0.074144,0.08922,0.21912,0.061144,0.08922,0.264268,0.061144,0.08922,0.264268,0.074144,0.08922,0.21912,0.074144,0.08922,0.264268,0.061144,0.089071,0.265643,0.061144,0.089071,0.265643,0.074144,0.08922,0.264268,0.074144,0.089071,0.265643,0.061144,0.088647,0.266905,0.061144,0.088647,0.266905,0.074144,0.089071,0.265643,0.074144,0.088647,0.266905,0.061144,0.087983,0.268019,0.061144,0.087983,0.268019,0.074144,0.088647,0.266905,0.074144,0.087983,0.268019,0.061144,0.087112,0.268949,0.061144,0.087112,0.268949,0.074144,0.087983,0.268019,0.074144,0.087112,0.268949,0.061144,0.086068,0.269658,0.061144,0.086068,0.269658,0.074144,0.087112,0.268949,0.074144,0.086068,0.269658,0.061144,0.084884,0.270109,0.061144,0.084884,0.270109,0.074144,0.086068,0.269658,0.074144,0.084884,0.270109,0.061144,0.083595,0.270268,0.061144,0.083595,0.270268,0.074144,0.084884,0.270109,0.074144,0.083595,0.270268,0.061144,0.037167,0.270268,0.061144,0.037167,0.270268,0.074144,0.083595,0.270268,0.074144,0.037167,0.270268,0.061144,0.035878,0.270109,0.061144,0.035878,0.270109,0.074144,0.037167,0.270268,0.074144,-0.037772,0.270109,0.061144,-0.038956,0.269658,0.061144,-0.038956,0.269658,0.074144,-0.037772,0.270109,0.074144,-0.038956,0.269658,0.061144,-0.04,0.268949,0.061144,-0.04,0.268949,0.074144,-0.038956,0.269658,0.074144,-0.04,0.268949,0.061144,-0.040871,0.268019,0.061144,-0.040871,0.268019,0.074144,-0.04,0.268949,0.061144,-0.040871,0.268019,0.074144,-0.04,0.268949,0.074144,-0.040871,0.268019,0.061144,-0.041536,0.266905,0.061144,-0.041536,0.266905,0.074144,-0.040871,0.268019,0.074144,-0.041536,0.266905,0.061144,-0.041959,0.265643,0.061144,-0.041959,0.265643,0.074144,-0.041536,0.266905,0.074144,-0.041959,0.265643,0.061144,-0.042108,0.264268,0.061144,-0.042108,0.264268,0.074144,-0.041959,0.265643,0.074144,-0.042108,0.264268,0.061144,-0.042108,0.21912,0.061144,-0.042108,0.21912,0.074144,-0.042108,0.264268,0.074144,-0.042108,0.21912,0.061144,-0.041959,0.217745,0.061144,-0.041959,0.217745,0.074144,-0.042108,0.21912,0.074144,-0.041959,0.217745,0.061144,-0.041536,0.216483,0.061144,-0.041536,0.216483,0.074144,-0.041959,0.217745,0.074144,-0.041536,0.216483,0.061144,-0.040871,0.215369,0.061144,-0.040871,0.215369,0.074144,-0.041536,0.216483,0.074144,-0.040871,0.215369,0.061144,-0.04,0.214439,0.061144,-0.04,0.214439,0.074144,-0.040871,0.215369,0.074144,-0.04,0.214439,0.061144,-0.038956,0.21373,0.061144,-0.038956,0.21373,0.074144,-0.04,0.214439,0.074144,-0.038956,0.21373,0.061144,-0.037772,0.213279,0.061144,-0.037772,0.213279,0.074144,-0.038956,0.21373,0.074144,-0.037772,0.213279,0.061144,-0.036483,0.21312,0.061144,-0.036483,0.21312,0.074144,-0.037772,0.213279,0.074144,-0.036483,0.21312,0.061144,0.009945,0.21312,0.061144,0.009945,0.21312,0.074144,-0.036483,0.21312,0.074144,0.009945,0.21312,0.061144,0.011234,0.213279,0.061144,0.011234,0.213279,0.074144,0.009945,0.21312,0.074144,0.011234,0.213279,0.061144,0.012417,0.21373,0.061144,0.012417,0.21373,0.074144,0.011234,0.213279,0.074144,0.012417,0.21373,0.061144,0.013462,0.214439,0.061144,0.013462,0.214439,0.074144,0.012417,0.21373,0.074144,0.013462,0.214439,0.061144,0.014333,0.215369,0.061144,0.014333,0.215369,0.074144,0.013462,0.214439,0.074144,0.014333,0.215369,0.061144,0.014997,0.216483,0.061144,0.014997,0.216483,0.074144,0.014333,0.215369,0.074144,0.014997,0.216483,0.061144,0.015421,0.217745,0.061144,0.015421,0.217745,0.074144,0.014997,0.216483,0.074144,0.015421,0.217745,0.061144,0.015569,0.21912,0.061144,0.015569,0.21912,0.074144,0.015421,0.217745,0.074144,0.015569,0.21912,0.061144,0.015569,0.264268,0.061144,0.015569,0.264268,0.074144,0.015569,0.21912,0.074144,0.015569,0.264268,0.061144,0.015421,0.265643,0.061144,0.015421,0.265643,0.074144,0.015569,0.264268,0.074144,0.015421,0.265643,0.061144,0.014997,0.266905,0.061144,0.014997,0.266905,0.074144,0.015421,0.265643,0.074144,0.014997,0.266905,0.061144,0.014333,0.268019,0.061144,0.014333,0.268019,0.074144,0.014997,0.266905,0.074144,0.014333,0.268019,0.061144,0.013462,0.268949,0.061144,0.013462,0.268949,0.074144,0.014333,0.268019,0.074144,0.013462,0.268949,0.061144,0.012417,0.269658,0.061144,0.012417,0.269658,0.074144,0.013462,0.268949,0.074144,0.012417,0.269658,0.061144,0.011234,0.270109,0.061144,0.011234,0.270109,0.074144,0.012417,0.269658,0.074144,0.011234,0.270109,0.061144,0.009945,0.270268,0.061144,0.009945,0.270268,0.074144,0.011234,0.270109,0.074144,0.009945,0.270268,0.061144,-0.036483,0.270268,0.061144,-0.036483,0.270268,0.074144,0.009945,0.270268,0.061144,-0.036483,0.270268,0.074144,0.009945,0.270268,0.074144,-0.036483,0.270268,0.061144,-0.037772,0.270109,0.061144,-0.037772,0.270109,0.074144,-0.036483,0.270268,0.074144,-0.111422,0.270109,0.061144,-0.112606,0.269658,0.061144,-0.112606,0.269658,0.074144,-0.111422,0.270109,0.074144,-0.112606,0.269658,0.061144,-0.11365,0.268949,0.061144,-0.11365,0.268949,0.074144,-0.112606,0.269658,0.074144,-0.11365,0.268949,0.061144,-0.114521,0.268019,0.061144,-0.114521,0.268019,0.074144,-0.11365,0.268949,0.074144,-0.114521,0.268019,0.061144,-0.115186,0.266905,0.061144,-0.115186,0.266905,0.074144,-0.114521,0.268019,0.074144,-0.115186,0.266905,0.061144,-0.115609,0.265643,0.061144,-0.115609,0.265643,0.074144,-0.115186,0.266905,0.074144,-0.115609,0.265643,0.061144,-0.115758,0.264268,0.061144,-0.115758,0.264268,0.074144,-0.115609,0.265643,0.074144,-0.115758,0.264268,0.061144,-0.115758,0.21912,0.061144,-0.115758,0.21912,0.074144,-0.115758,0.264268,0.074144,-0.115758,0.21912,0.061144,-0.115609,0.217745,0.061144,-0.115609,0.217745,0.074144,-0.115758,0.21912,0.074144,-0.115609,0.217745,0.061144,-0.115186,0.216483,0.061144,-0.115186,0.216483,0.074144,-0.115609,0.217745,0.074144,-0.115186,0.216483,0.061144,-0.114521,0.215369,0.061144,-0.114521,0.215369,0.074144,-0.115186,0.216483,0.074144,-0.114521,0.215369,0.061144,-0.11365,0.214439,0.061144,-0.11365,0.214439,0.074144,-0.114521,0.215369,0.074144,-0.11365,0.214439,0.061144,-0.112606,0.21373,0.061144,-0.112606,0.21373,0.074144,-0.11365,0.214439,0.074144,-0.112606,0.21373,0.061144,-0.111422,0.213279,0.061144,-0.111422,0.213279,0.074144,-0.112606,0.21373,0.074144,-0.111422,0.213279,0.061144,-0.110134,0.21312,0.061144,-0.110134,0.21312,0.074144,-0.111422,0.213279,0.074144,-0.110134,0.21312,0.061144,-0.063705,0.21312,0.061144,-0.063705,0.21312,0.074144,-0.110134,0.21312,0.074144,-0.063705,0.21312,0.061144,-0.062416,0.213279,0.061144,-0.062416,0.213279,0.074144,-0.063705,0.21312,0.061144,-0.062416,0.213279,0.074144,-0.063705,0.21312,0.074144,-0.062416,0.213279,0.061144,-0.061233,0.21373,0.061144,-0.061233,0.21373,0.074144,-0.062416,0.213279,0.061144,-0.061233,0.21373,0.074144,-0.062416,0.213279,0.074144,-0.061233,0.21373,0.061144,-0.060188,0.214439,0.061144,-0.060188,0.214439,0.074144,-0.061233,0.21373,0.074144,-0.060188,0.214439,0.061144,-0.059317,0.215369,0.061144,-0.059317,0.215369,0.074144,-0.060188,0.214439,0.074144,-0.059317,0.215369,0.061144,-0.058653,0.216483,0.061144,-0.058653,0.216483,0.074144,-0.059317,0.215369,0.074144,-0.058653,0.216483,0.061144,-0.058229,0.217745,0.061144,-0.058229,0.217745,0.074144,-0.058653,0.216483,0.074144,-0.058229,0.217745,0.061144,-0.058081,0.21912,0.061144,-0.058081,0.21912,0.074144,-0.058229,0.217745,0.061144,-0.058081,0.21912,0.074144,-0.058229,0.217745,0.074144,-0.058081,0.21912,0.061144,-0.058081,0.264268,0.061144,-0.058081,0.264268,0.074144,-0.058081,0.21912,0.074144,-0.058081,0.264268,0.061144,-0.058229,0.265643,0.061144,-0.058229,0.265643,0.074144,-0.058081,0.264268,0.074144,-0.058229,0.265643,0.061144,-0.058653,0.266905,0.061144,-0.058653,0.266905,0.074144,-0.058229,0.265643,0.074144,-0.058653,0.266905,0.061144,-0.059317,0.268019,0.061144,-0.059317,0.268019,0.074144,-0.058653,0.266905,0.074144,-0.059317,0.268019,0.061144,-0.060188,0.268949,0.061144,-0.060188,0.268949,0.074144,-0.059317,0.268019,0.074144,-0.060188,0.268949,0.061144,-0.061233,0.269658,0.061144,-0.061233,0.269658,0.074144,-0.060188,0.268949,0.074144,-0.061233,0.269658,0.061144,-0.062416,0.270109,0.061144,-0.062416,0.270109,0.074144,-0.061233,0.269658,0.074144,-0.062416,0.270109,0.061144,-0.063705,0.270268,0.061144,-0.063705,0.270268,0.074144,-0.062416,0.270109,0.074144,-0.063705,0.270268,0.061144,-0.110134,0.270268,0.061144,-0.110134,0.270268,0.074144,-0.063705,0.270268,0.074144,-0.110134,0.270268,0.061144,-0.111422,0.270109,0.061144,-0.111422,0.270109,0.074144,-0.110134,0.270268,0.074144,-0.185072,0.270109,0.061144,-0.186256,0.269658,0.061144,-0.186256,0.269658,0.074144,-0.185072,0.270109,0.074144,-0.186256,0.269658,0.061144,-0.1873,0.268949,0.061144,-0.1873,0.268949,0.074144,-0.186256,0.269658,0.074144,-0.1873,0.268949,0.061144,-0.188171,0.268019,0.061144,-0.188171,0.268019,0.074144,-0.1873,0.268949,0.074144,-0.188171,0.268019,0.061144,-0.188836,0.266905,0.061144,-0.188836,0.266905,0.074144,-0.188171,0.268019,0.074144,-0.188836,0.266905,0.061144,-0.189259,0.265643,0.061144,-0.189259,0.265643,0.074144,-0.188836,0.266905,0.074144,-0.189259,0.265643,0.061144,-0.189408,0.264268,0.061144,-0.189408,0.264268,0.074144,-0.189259,0.265643,0.074144,-0.189408,0.264268,0.061144,-0.189408,0.21912,0.061144,-0.189408,0.21912,0.074144,-0.189408,0.264268,0.074144,-0.189408,0.21912,0.061144,-0.189259,0.217745,0.061144,-0.189259,0.217745,0.074144,-0.189408,0.21912,0.074144,-0.189259,0.217745,0.061144,-0.188836,0.216483,0.061144,-0.188836,0.216483,0.074144,-0.189259,0.217745,0.074144,-0.188836,0.216483,0.061144,-0.188171,0.215369,0.061144,-0.188171,0.215369,0.074144,-0.188836,0.216483,0.074144,-0.188171,0.215369,0.061144,-0.1873,0.214439,0.061144,-0.1873,0.214439,0.074144,-0.188171,0.215369,0.074144,-0.1873,0.214439,0.061144,-0.186256,0.21373,0.061144,-0.186256,0.21373,0.074144,-0.1873,0.214439,0.074144,-0.186256,0.21373,0.061144,-0.185072,0.213279,0.061144,-0.185072,0.213279,0.074144,-0.186256,0.21373,0.074144,-0.185072,0.213279,0.061144,-0.183784,0.21312,0.061144,-0.183784,0.21312,0.074144,-0.185072,0.213279,0.074144,-0.183784,0.21312,0.061144,-0.137355,0.21312,0.061144,-0.137355,0.21312,0.074144,-0.183784,0.21312,0.074144,-0.137355,0.21312,0.061144,-0.136066,0.213279,0.061144,-0.136066,0.213279,0.074144,-0.137355,0.21312,0.061144,-0.136066,0.213279,0.074144,-0.137355,0.21312,0.074144,-0.136066,0.213279,0.061144,-0.134883,0.21373,0.061144,-0.134883,0.21373,0.074144,-0.136066,0.213279,0.061144,-0.134883,0.21373,0.074144,-0.136066,0.213279,0.074144,-0.134883,0.21373,0.061144,-0.133839,0.214439,0.061144,-0.133839,0.214439,0.074144,-0.134883,0.21373,0.074144,-0.133839,0.214439,0.061144,-0.132967,0.215369,0.061144,-0.132967,0.215369,0.074144,-0.133839,0.214439,0.074144,-0.132967,0.215369,0.061144,-0.132303,0.216483,0.061144,-0.132303,0.216483,0.074144,-0.132967,0.215369,0.074144,-0.132303,0.216483,0.061144,-0.13188,0.217745,0.061144,-0.13188,0.217745,0.074144,-0.132303,0.216483,0.074144,-0.13188,0.217745,0.061144,-0.131731,0.21912,0.061144,-0.131731,0.21912,0.074144,-0.13188,0.217745,0.074144,-0.131731,0.21912,0.061144,-0.131731,0.264268,0.061144,-0.131731,0.264268,0.074144,-0.131731,0.21912,0.074144,-0.131731,0.264268,0.061144,-0.13188,0.265643,0.061144,-0.13188,0.265643,0.074144,-0.131731,0.264268,0.074144,-0.13188,0.265643,0.061144,-0.132303,0.266905,0.061144,-0.132303,0.266905,0.074144,-0.13188,0.265643,0.074144,-0.132303,0.266905,0.061144,-0.132967,0.268019,0.061144,-0.132967,0.268019,0.074144,-0.132303,0.266905,0.074144,-0.132967,0.268019,0.061144,-0.133839,0.268949,0.061144,-0.133839,0.268949,0.074144,-0.132967,0.268019,0.074144,-0.133839,0.268949,0.061144,-0.134883,0.269658,0.061144,-0.134883,0.269658,0.074144,-0.133839,0.268949,0.074144,-0.134883,0.269658,0.061144,-0.136066,0.270109,0.061144,-0.136066,0.270109,0.074144,-0.134883,0.269658,0.074144,-0.136066,0.270109,0.061144,-0.137355,0.270268,0.061144,-0.137355,0.270268,0.074144,-0.136066,0.270109,0.074144,-0.137355,0.270268,0.061144,-0.183784,0.270268,0.061144,-0.183784,0.270268,0.074144,-0.137355,0.270268,0.074144,-0.183784,0.270268,0.061144,-0.185072,0.270109,0.061144,-0.185072,0.270109,0.074144,-0.183784,0.270268,0.074144,-0.258723,0.270109,0.061144,-0.259906,0.269658,0.061144,-0.259906,0.269658,0.074144,-0.258723,0.270109,0.074144,-0.259906,0.269658,0.061144,-0.26095,0.268949,0.061144,-0.26095,0.268949,0.074144,-0.259906,0.269658,0.074144,-0.26095,0.268949,0.061144,-0.261822,0.268019,0.061144,-0.261822,0.268019,0.074144,-0.26095,0.268949,0.074144,-0.261822,0.268019,0.061144,-0.262486,0.266905,0.061144,-0.262486,0.266905,0.074144,-0.261822,0.268019,0.074144,-0.262486,0.266905,0.061144,-0.262909,0.265643,0.061144,-0.262909,0.265643,0.074144,-0.262486,0.266905,0.074144,-0.262909,0.265643,0.061144,-0.263058,0.264268,0.061144,-0.263058,0.264268,0.074144,-0.262909,0.265643,0.074144,-0.263058,0.264268,0.061144,-0.263058,0.21912,0.061144,-0.263058,0.21912,0.074144,-0.263058,0.264268,0.074144,-0.263058,0.21912,0.061144,-0.262909,0.217745,0.061144,-0.262909,0.217745,0.074144,-0.263058,0.21912,0.074144,-0.262909,0.217745,0.061144,-0.262486,0.216483,0.061144,-0.262486,0.216483,0.074144,-0.262909,0.217745,0.074144,-0.262486,0.216483,0.061144,-0.261822,0.215369,0.061144,-0.261822,0.215369,0.074144,-0.262486,0.216483,0.074144,-0.261822,0.215369,0.061144,-0.26095,0.214439,0.061144,-0.26095,0.214439,0.074144,-0.261822,0.215369,0.074144,-0.26095,0.214439,0.061144,-0.259906,0.21373,0.061144,-0.259906,0.21373,0.074144,-0.26095,0.214439,0.061144,-0.259906,0.21373,0.074144,-0.26095,0.214439,0.074144,-0.259906,0.21373,0.061144,-0.258723,0.213279,0.061144,-0.258723,0.213279,0.074144,-0.259906,0.21373,0.061144,-0.258723,0.213279,0.074144,-0.259906,0.21373,0.074144,-0.258723,0.213279,0.061144,-0.257434,0.21312,0.061144,-0.257434,0.21312,0.074144,-0.258723,0.213279,0.074144,-0.257434,0.21312,0.061144,-0.211005,0.21312,0.061144,-0.211005,0.21312,0.074144,-0.257434,0.21312,0.074144,-0.211005,0.21312,0.061144,-0.209716,0.213279,0.061144,-0.209716,0.213279,0.074144,-0.211005,0.21312,0.074144,-0.209716,0.213279,0.061144,-0.208533,0.21373,0.061144,-0.208533,0.21373,0.074144,-0.209716,0.213279,0.074144,-0.208533,0.21373,0.061144,-0.207489,0.214439,0.061144,-0.207489,0.214439,0.074144,-0.208533,0.21373,0.074144,-0.207489,0.214439,0.061144,-0.206617,0.215369,0.061144,-0.206617,0.215369,0.074144,-0.207489,0.214439,0.074144,-0.206617,0.215369,0.061144,-0.205953,0.216483,0.061144,-0.205953,0.216483,0.074144,-0.206617,0.215369,0.074144,-0.205953,0.216483,0.061144,-0.20553,0.217745,0.061144,-0.20553,0.217745,0.074144,-0.205953,0.216483,0.074144,-0.20553,0.217745,0.061144,-0.205381,0.21912,0.061144,-0.205381,0.21912,0.074144,-0.20553,0.217745,0.074144,-0.205381,0.21912,0.061144,-0.205381,0.264268,0.061144,-0.205381,0.264268,0.074144,-0.205381,0.21912,0.074144,-0.205381,0.264268,0.061144,-0.20553,0.265643,0.061144,-0.20553,0.265643,0.074144,-0.205381,0.264268,0.074144,-0.20553,0.265643,0.061144,-0.205953,0.266905,0.061144,-0.205953,0.266905,0.074144,-0.20553,0.265643,0.074144,-0.205953,0.266905,0.061144,-0.206617,0.268019,0.061144,-0.206617,0.268019,0.074144,-0.205953,0.266905,0.074144,-0.206617,0.268019,0.061144,-0.207489,0.268949,0.061144,-0.207489,0.268949,0.074144,-0.206617,0.268019,0.074144,-0.207489,0.268949,0.061144,-0.208533,0.269658,0.061144,-0.208533,0.269658,0.074144,-0.207489,0.268949,0.074144,-0.208533,0.269658,0.061144,-0.209716,0.270109,0.061144,-0.209716,0.270109,0.074144,-0.208533,0.269658,0.074144,-0.209716,0.270109,0.061144,-0.211005,0.270268,0.061144,-0.211005,0.270268,0.074144,-0.209716,0.270109,0.074144,-0.211005,0.270268,0.061144,-0.257434,0.270268,0.061144,-0.257434,0.270268,0.074144,-0.211005,0.270268,0.074144,-0.257434,0.270268,0.061144,-0.258723,0.270109,0.061144,-0.258723,0.270109,0.074144,-0.257434,0.270268,0.074144,-0.332373,0.270109,0.061144,-0.333556,0.269658,0.061144,-0.333556,0.269658,0.074144,-0.332373,0.270109,0.074144,-0.333556,0.269658,0.061144,-0.3346,0.268949,0.061144,-0.3346,0.268949,0.074144,-0.333556,0.269658,0.074144,-0.3346,0.268949,0.061144,-0.335472,0.268019,0.061144,-0.335472,0.268019,0.074144,-0.3346,0.268949,0.074144,-0.335472,0.268019,0.061144,-0.336136,0.266905,0.061144,-0.336136,0.266905,0.074144,-0.335472,0.268019,0.074144,-0.336136,0.266905,0.061144,-0.33656,0.265643,0.061144,-0.33656,0.265643,0.074144,-0.336136,0.266905,0.074144,-0.33656,0.265643,0.061144,-0.336708,0.264268,0.061144,-0.336708,0.264268,0.074144,-0.33656,0.265643,0.074144,-0.336708,0.264268,0.061144,-0.336708,0.21912,0.061144,-0.336708,0.21912,0.074144,-0.336708,0.264268,0.074144,-0.336708,0.21912,0.061144,-0.33656,0.217745,0.061144,-0.33656,0.217745,0.074144,-0.336708,0.21912,0.061144,-0.33656,0.217745,0.074144,-0.336708,0.21912,0.074144,-0.33656,0.217745,0.061144,-0.336136,0.216483,0.061144,-0.336136,0.216483,0.074144,-0.33656,0.217745,0.074144,-0.336136,0.216483,0.061144,-0.335472,0.215369,0.061144,-0.335472,0.215369,0.074144,-0.336136,0.216483,0.061144,-0.335472,0.215369,0.074144,-0.336136,0.216483,0.074144,-0.335472,0.215369,0.061144,-0.3346,0.214439,0.061144,-0.3346,0.214439,0.074144,-0.335472,0.215369,0.074144,-0.3346,0.214439,0.061144,-0.333556,0.21373,0.061144,-0.333556,0.21373,0.074144,-0.3346,0.214439,0.074144,-0.333556,0.21373,0.061144,-0.332373,0.213279,0.061144,-0.332373,0.213279,0.074144,-0.333556,0.21373,0.074144,-0.332373,0.213279,0.061144,-0.331084,0.21312,0.061144,-0.331084,0.21312,0.074144,-0.332373,0.213279,0.074144,-0.331084,0.21312,0.061144,-0.284655,0.21312,0.061144,-0.284655,0.21312,0.074144,-0.331084,0.21312,0.074144,-0.284655,0.21312,0.061144,-0.283367,0.213279,0.061144,-0.283367,0.213279,0.074144,-0.284655,0.21312,0.074144,-0.283367,0.213279,0.061144,-0.282183,0.21373,0.061144,-0.282183,0.21373,0.074144,-0.283367,0.213279,0.074144,-0.282183,0.21373,0.061144,-0.281139,0.214439,0.061144,-0.281139,0.214439,0.074144,-0.282183,0.21373,0.074144,-0.281139,0.214439,0.061144,-0.280268,0.215369,0.061144,-0.280268,0.215369,0.074144,-0.281139,0.214439,0.074144,-0.280268,0.215369,0.061144,-0.279603,0.216483,0.061144,-0.279603,0.216483,0.074144,-0.280268,0.215369,0.074144,-0.279603,0.216483,0.061144,-0.27918,0.217745,0.061144,-0.27918,0.217745,0.074144,-0.279603,0.216483,0.074144,-0.27918,0.217745,0.061144,-0.279031,0.21912,0.061144,-0.279031,0.21912,0.074144,-0.27918,0.217745,0.074144,-0.279031,0.21912,0.061144,-0.279031,0.264268,0.061144,-0.279031,0.264268,0.074144,-0.279031,0.21912,0.074144,-0.279031,0.264268,0.061144,-0.27918,0.265643,0.061144,-0.27918,0.265643,0.074144,-0.279031,0.264268,0.074144,-0.27918,0.265643,0.061144,-0.279603,0.266905,0.061144,-0.279603,0.266905,0.074144,-0.27918,0.265643,0.074144,-0.279603,0.266905,0.061144,-0.280268,0.268019,0.061144,-0.280268,0.268019,0.074144,-0.279603,0.266905,0.074144,-0.280268,0.268019,0.061144,-0.281139,0.268949,0.061144,-0.281139,0.268949,0.074144,-0.280268,0.268019,0.074144,-0.281139,0.268949,0.061144,-0.282183,0.269658,0.061144,-0.282183,0.269658,0.074144,-0.281139,0.268949,0.074144,-0.282183,0.269658,0.061144,-0.283367,0.270109,0.061144,-0.283367,0.270109,0.074144,-0.282183,0.269658,0.074144,-0.283367,0.270109,0.061144,-0.284655,0.270268,0.061144,-0.284655,0.270268,0.074144,-0.283367,0.270109,0.074144,-0.284655,0.270268,0.061144,-0.331084,0.270268,0.061144,-0.331084,0.270268,0.074144,-0.284655,0.270268,0.074144,-0.331084,0.270268,0.061144,-0.332373,0.270109,0.061144,-0.332373,0.270109,0.074144,-0.331084,0.270268,0.074144,-0.406023,0.270109,0.061144,-0.407206,0.269658,0.061144,-0.407206,0.269658,0.074144,-0.406023,0.270109,0.074144,-0.407206,0.269658,0.061144,-0.408251,0.268949,0.061144,-0.408251,0.268949,0.074144,-0.407206,0.269658,0.074144,-0.408251,0.268949,0.061144,-0.409122,0.268019,0.061144,-0.409122,0.268019,0.074144,-0.408251,0.268949,0.074144,-0.409122,0.268019,0.061144,-0.409786,0.266905,0.061144,-0.409786,0.266905,0.074144,-0.409122,0.268019,0.074144,-0.409786,0.266905,0.061144,-0.41021,0.265643,0.061144,-0.41021,0.265643,0.074144,-0.409786,0.266905,0.074144,-0.41021,0.265643,0.061144,-0.410358,0.264268,0.061144,-0.410358,0.264268,0.074144,-0.41021,0.265643,0.074144,-0.410358,0.264268,0.061144,-0.410358,0.21912,0.061144,-0.410358,0.21912,0.074144,-0.410358,0.264268,0.074144,-0.410358,0.21912,0.061144,-0.41021,0.217745,0.061144,-0.41021,0.217745,0.074144,-0.410358,0.21912,0.074144,-0.41021,0.217745,0.061144,-0.409786,0.216483,0.061144,-0.409786,0.216483,0.074144,-0.41021,0.217745,0.074144,-0.409786,0.216483,0.061144,-0.409122,0.215369,0.061144,-0.409122,0.215369,0.074144,-0.409786,0.216483,0.074144,-0.409122,0.215369,0.061144,-0.408251,0.214439,0.061144,-0.408251,0.214439,0.074144,-0.409122,0.215369,0.074144,-0.408251,0.214439,0.061144,-0.407206,0.21373,0.061144,-0.407206,0.21373,0.074144,-0.408251,0.214439,0.074144,-0.407206,0.21373,0.061144,-0.406023,0.213279,0.061144,-0.406023,0.213279,0.074144,-0.407206,0.21373,0.074144,-0.406023,0.213279,0.061144,-0.404734,0.21312,0.061144,-0.404734,0.21312,0.074144,-0.406023,0.213279,0.074144,-0.404734,0.21312,0.061144,-0.358305,0.21312,0.061144,-0.358305,0.21312,0.074144,-0.404734,0.21312,0.074144,-0.358305,0.21312,0.061144,-0.357017,0.213279,0.061144,-0.357017,0.213279,0.074144,-0.358305,0.21312,0.074144,-0.357017,0.213279,0.061144,-0.355833,0.21373,0.061144,-0.355833,0.21373,0.074144,-0.357017,0.213279,0.074144,-0.355833,0.21373,0.061144,-0.354789,0.214439,0.061144,-0.354789,0.214439,0.074144,-0.355833,0.21373,0.061144,-0.354789,0.214439,0.074144,-0.355833,0.21373,0.074144,-0.354789,0.214439,0.061144,-0.353918,0.215369,0.061144,-0.353918,0.215369,0.074144,-0.354789,0.214439,0.061144,-0.353918,0.215369,0.074144,-0.354789,0.214439,0.074144,-0.353918,0.215369,0.061144,-0.353253,0.216483,0.061144,-0.353253,0.216483,0.074144,-0.353918,0.215369,0.074144,-0.353253,0.216483,0.061144,-0.35283,0.217745,0.061144,-0.35283,0.217745,0.074144,-0.353253,0.216483,0.074144,-0.35283,0.217745,0.061144,-0.352681,0.21912,0.061144,-0.352681,0.21912,0.074144,-0.35283,0.217745,0.074144,-0.352681,0.21912,0.061144,-0.352681,0.264268,0.061144,-0.352681,0.264268,0.074144,-0.352681,0.21912,0.074144,-0.352681,0.264268,0.061144,-0.35283,0.265643,0.061144,-0.35283,0.265643,0.074144,-0.352681,0.264268,0.074144,-0.35283,0.265643,0.061144,-0.353253,0.266905,0.061144,-0.353253,0.266905,0.074144,-0.35283,0.265643,0.074144,-0.353253,0.266905,0.061144,-0.353918,0.268019,0.061144,-0.353918,0.268019,0.074144,-0.353253,0.266905,0.061144,-0.353918,0.268019,0.074144,-0.353253,0.266905,0.074144,-0.353918,0.268019,0.061144,-0.354789,0.268949,0.061144,-0.354789,0.268949,0.074144,-0.353918,0.268019,0.061144,-0.354789,0.268949,0.074144,-0.353918,0.268019,0.074144,-0.354789,0.268949,0.061144,-0.355833,0.269658,0.061144,-0.355833,0.269658,0.074144,-0.354789,0.268949,0.074144,-0.355833,0.269658,0.061144,-0.357017,0.270109,0.061144,-0.357017,0.270109,0.074144,-0.355833,0.269658,0.074144,-0.357017,0.270109,0.061144,-0.358305,0.270268,0.061144,-0.358305,0.270268,0.074144,-0.357017,0.270109,0.061144,-0.358305,0.270268,0.074144,-0.357017,0.270109,0.074144,-0.358305,0.270268,0.061144,-0.404734,0.270268,0.061144,-0.404734,0.270268,0.074144,-0.358305,0.270268,0.074144,-0.404734,0.270268,0.061144,-0.406023,0.270109,0.061144,-0.406023,0.270109,0.074144,-0.404734,0.270268,0.074144,-0.479673,0.270109,0.061144,-0.480856,0.269658,0.061144,-0.480856,0.269658,0.074144,-0.479673,0.270109,0.074144,-0.480856,0.269658,0.061144,-0.481901,0.268949,0.061144,-0.481901,0.268949,0.074144,-0.480856,0.269658,0.074144,-0.481901,0.268949,0.061144,-0.482772,0.268019,0.061144,-0.482772,0.268019,0.074144,-0.481901,0.268949,0.074144,-0.482772,0.268019,0.061144,-0.483436,0.266905,0.061144,-0.483436,0.266905,0.074144,-0.482772,0.268019,0.074144,-0.483436,0.266905,0.061144,-0.48386,0.265643,0.061144,-0.48386,0.265643,0.074144,-0.483436,0.266905,0.074144,-0.48386,0.265643,0.061144,-0.484008,0.264268,0.061144,-0.484008,0.264268,0.074144,-0.48386,0.265643,0.074144,-0.484008,0.264268,0.061144,-0.484008,0.21912,0.061144,-0.484008,0.21912,0.074144,-0.484008,0.264268,0.074144,-0.484008,0.21912,0.061144,-0.48386,0.217745,0.061144,-0.48386,0.217745,0.074144,-0.484008,0.21912,0.074144,-0.48386,0.217745,0.061144,-0.483436,0.216483,0.061144,-0.483436,0.216483,0.074144,-0.48386,0.217745,0.074144,-0.483436,0.216483,0.061144,-0.482772,0.215369,0.061144,-0.482772,0.215369,0.074144,-0.483436,0.216483,0.074144,-0.482772,0.215369,0.061144,-0.481901,0.214439,0.061144,-0.481901,0.214439,0.074144,-0.482772,0.215369,0.074144,-0.481901,0.214439,0.061144,-0.480856,0.21373,0.061144,-0.480856,0.21373,0.074144,-0.481901,0.214439,0.074144,-0.480856,0.21373,0.061144,-0.479673,0.213279,0.061144,-0.479673,0.213279,0.074144,-0.480856,0.21373,0.074144,-0.479673,0.213279,0.061144,-0.478384,0.21312,0.061144,-0.478384,0.21312,0.074144,-0.479673,0.213279,0.074144,-0.478384,0.21312,0.061144,-0.431956,0.21312,0.061144,-0.431956,0.21312,0.074144,-0.478384,0.21312,0.074144,-0.431956,0.21312,0.061144,-0.430667,0.213279,0.061144,-0.430667,0.213279,0.074144,-0.431956,0.21312,0.074144,-0.430667,0.213279,0.061144,-0.429483,0.21373,0.061144,-0.429483,0.21373,0.074144,-0.430667,0.213279,0.074144,-0.429483,0.21373,0.061144,-0.428439,0.214439,0.061144,-0.428439,0.214439,0.074144,-0.429483,0.21373,0.074144,-0.428439,0.214439,0.061144,-0.427568,0.215369,0.061144,-0.427568,0.215369,0.074144,-0.428439,0.214439,0.074144,-0.427568,0.215369,0.061144,-0.426904,0.216483,0.061144,-0.426904,0.216483,0.074144,-0.427568,0.215369,0.074144,-0.426904,0.216483,0.061144,-0.42648,0.217745,0.061144,-0.42648,0.217745,0.074144,-0.426904,0.216483,0.074144,-0.42648,0.217745,0.061144,-0.426331,0.21912,0.061144,-0.426331,0.21912,0.074144,-0.42648,0.217745,0.074144,-0.426331,0.21912,0.061144,-0.426331,0.264268,0.061144,-0.426331,0.264268,0.074144,-0.426331,0.21912,0.074144,-0.426331,0.264268,0.061144,-0.42648,0.265643,0.061144,-0.42648,0.265643,0.074144,-0.426331,0.264268,0.061144,-0.42648,0.265643,0.074144,-0.426331,0.264268,0.074144,-0.42648,0.265643,0.061144,-0.426904,0.266905,0.061144,-0.426904,0.266905,0.074144,-0.42648,0.265643,0.061144,-0.426904,0.266905,0.074144,-0.42648,0.265643,0.074144,-0.426904,0.266905,0.061144,-0.427568,0.268019,0.061144,-0.427568,0.268019,0.074144,-0.426904,0.266905,0.074144,-0.427568,0.268019,0.061144,-0.428439,0.268949,0.061144,-0.428439,0.268949,0.074144,-0.427568,0.268019,0.074144,-0.428439,0.268949,0.061144,-0.429483,0.269658,0.061144,-0.429483,0.269658,0.074144,-0.428439,0.268949,0.074144,-0.429483,0.269658,0.061144,-0.430667,0.270109,0.061144,-0.430667,0.270109,0.074144,-0.429483,0.269658,0.074144,-0.430667,0.270109,0.061144,-0.431956,0.270268,0.061144,-0.431956,0.270268,0.074144,-0.430667,0.270109,0.074144,-0.431956,0.270268,0.061144,-0.478384,0.270268,0.061144,-0.478384,0.270268,0.074144,-0.431956,0.270268,0.074144,-0.478384,0.270268,0.061144,-0.479673,0.270109,0.061144,-0.479673,0.270109,0.074144,-0.478384,0.270268,0.074144,-0.614841,0.268609,0.061144,-0.616024,0.268158,0.061144,-0.616024,0.268158,0.074144,-0.614841,0.268609,0.074144,-0.616024,0.268158,0.061144,-0.617069,0.267449,0.061144,-0.617069,0.267449,0.074144,-0.616024,0.268158,0.074144,-0.617069,0.267449,0.061144,-0.61794,0.266519,0.061144,-0.61794,0.266519,0.074144,-0.617069,0.267449,0.074144,-0.61794,0.266519,0.061144,-0.618604,0.265405,0.061144,-0.618604,0.265405,0.074144,-0.61794,0.266519,0.074144,-0.618604,0.265405,0.061144,-0.619028,0.264143,0.061144,-0.619028,0.264143,0.074144,-0.618604,0.265405,0.074144,-0.619028,0.264143,0.061144,-0.619176,0.262768,0.061144,-0.619176,0.262768,0.074144,-0.619028,0.264143,0.074144,-0.619176,0.262768,0.061144,-0.619176,0.22062,0.061144,-0.619176,0.22062,0.074144,-0.619176,0.262768,0.074144,-0.619176,0.22062,0.061144,-0.619028,0.219245,0.061144,-0.619028,0.219245,0.074144,-0.619176,0.22062,0.074144,-0.619028,0.219245,0.061144,-0.618604,0.217983,0.061144,-0.618604,0.217983,0.074144,-0.619028,0.219245,0.061144,-0.618604,0.217983,0.074144,-0.619028,0.219245,0.074144,-0.618604,0.217983,0.061144,-0.61794,0.216869,0.061144,-0.61794,0.216869,0.074144,-0.618604,0.217983,0.074144,-0.61794,0.216869,0.061144,-0.617069,0.215939,0.061144,-0.617069,0.215939,0.074144,-0.61794,0.216869,0.074144,-0.617069,0.215939,0.061144,-0.616024,0.21523,0.061144,-0.616024,0.21523,0.074144,-0.617069,0.215939,0.074144,-0.616024,0.21523,0.061144,-0.614841,0.214779,0.061144,-0.614841,0.214779,0.074144,-0.616024,0.21523,0.074144,-0.614841,0.214779,0.061144,-0.613552,0.21462,0.061144,-0.613552,0.21462,0.074144,-0.614841,0.214779,0.074144,-0.613552,0.21462,0.061144,-0.508379,0.21462,0.061144,-0.508379,0.21462,0.074144,-0.613552,0.21462,0.061144,-0.508379,0.21462,0.074144,-0.613552,0.21462,0.074144,-0.508379,0.21462,0.061144,-0.507091,0.214779,0.061144,-0.507091,0.214779,0.074144,-0.508379,0.21462,0.074144,-0.507091,0.214779,0.061144,-0.505907,0.21523,0.061144,-0.505907,0.21523,0.074144,-0.507091,0.214779,0.074144,-0.505907,0.21523,0.061144,-0.504863,0.215939,0.061144,-0.504863,0.215939,0.074144,-0.505907,0.21523,0.061144,-0.504863,0.215939,0.074144,-0.505907,0.21523,0.074144,-0.504863,0.215939,0.061144,-0.503991,0.216869,0.061144,-0.503991,0.216869,0.074144,-0.504863,0.215939,0.074144,-0.503991,0.216869,0.061144,-0.503327,0.217983,0.061144,-0.503327,0.217983,0.074144,-0.503991,0.216869,0.074144,-0.503327,0.217983,0.061144,-0.502904,0.219245,0.061144,-0.502904,0.219245,0.074144,-0.503327,0.217983,0.074144,-0.502904,0.219245,0.061144,-0.502755,0.22062,0.061144,-0.502755,0.22062,0.074144,-0.502904,0.219245,0.074144,-0.502755,0.22062,0.061144,-0.502755,0.262768,0.061144,-0.502755,0.262768,0.074144,-0.502755,0.22062,0.074144,-0.502755,0.262768,0.061144,-0.502904,0.264143,0.061144,-0.502904,0.264143,0.074144,-0.502755,0.262768,0.074144,-0.502904,0.264143,0.061144,-0.503327,0.265405,0.061144,-0.503327,0.265405,0.074144,-0.502904,0.264143,0.074144,-0.503327,0.265405,0.061144,-0.503991,0.266519,0.061144,-0.503991,0.266519,0.074144,-0.503327,0.265405,0.074144,-0.503991,0.266519,0.061144,-0.504863,0.267449,0.061144,-0.504863,0.267449,0.074144,-0.503991,0.266519,0.074144,-0.504863,0.267449,0.061144,-0.505907,0.268158,0.061144,-0.505907,0.268158,0.074144,-0.504863,0.267449,0.074144,-0.505907,0.268158,0.061144,-0.507091,0.268609,0.061144,-0.507091,0.268609,0.074144,-0.505907,0.268158,0.074144,-0.507091,0.268609,0.061144,-0.508379,0.268768,0.061144,-0.508379,0.268768,0.074144,-0.507091,0.268609,0.074144,-0.508379,0.268768,0.061144,-0.613552,0.268768,0.061144,-0.613552,0.268768,0.074144,-0.508379,0.268768,0.074144,-0.613552,0.268768,0.061144,-0.614841,0.268609,0.061144,-0.614841,0.268609,0.074144,-0.613552,0.268768,0.074144,-0.575248,0.198619,0.061144,-0.621677,0.198619,0.061144,-0.621677,0.198619,0.074144,-0.575248,0.198619,0.074144,-0.621677,0.198619,0.061144,-0.622965,0.198461,0.061144,-0.622965,0.198461,0.074144,-0.621677,0.198619,0.074144,-0.622965,0.198461,0.061144,-0.624149,0.198009,0.061144,-0.624149,0.198009,0.074144,-0.622965,0.198461,0.074144,-0.624149,0.198009,0.061144,-0.625193,0.1973,0.061144,-0.625193,0.1973,0.074144,-0.624149,0.198009,0.074144,-0.625193,0.1973,0.061144,-0.626064,0.196371,0.061144,-0.626064,0.196371,0.074144,-0.625193,0.1973,0.074144,-0.626064,0.196371,0.061144,-0.626729,0.195257,0.061144,-0.626729,0.195257,0.074144,-0.626064,0.196371,0.074144,-0.626729,0.195257,0.061144,-0.627152,0.193994,0.061144,-0.627152,0.193994,0.074144,-0.626729,0.195257,0.074144,-0.627152,0.193994,0.061144,-0.627301,0.192619,0.061144,-0.627301,0.192619,0.074144,-0.627152,0.193994,0.061144,-0.627301,0.192619,0.074144,-0.627152,0.193994,0.074144,-0.627301,0.192619,0.061144,-0.627301,0.147471,0.061144,-0.627301,0.147471,0.074144,-0.627301,0.192619,0.074144,-0.627301,0.147471,0.061144,-0.627152,0.146096,0.061144,-0.627152,0.146096,0.074144,-0.627301,0.147471,0.061144,-0.627152,0.146096,0.074144,-0.627301,0.147471,0.074144,-0.627152,0.146096,0.061144,-0.626729,0.144834,0.061144,-0.626729,0.144834,0.074144,-0.627152,0.146096,0.074144,-0.626729,0.144834,0.061144,-0.626064,0.14372,0.061144,-0.626064,0.14372,0.074144,-0.626729,0.144834,0.074144,-0.626064,0.14372,0.061144,-0.625193,0.14279,0.061144,-0.625193,0.14279,0.074144,-0.626064,0.14372,0.074144,-0.625193,0.14279,0.061144,-0.624149,0.142082,0.061144,-0.624149,0.142082,0.074144,-0.625193,0.14279,0.074144,-0.624149,0.142082,0.061144,-0.622965,0.14163,0.061144,-0.622965,0.14163,0.074144,-0.624149,0.142082,0.061144,-0.622965,0.14163,0.074144,-0.624149,0.142082,0.074144,-0.622965,0.14163,0.061144,-0.621677,0.141471,0.061144,-0.621677,0.141471,0.074144,-0.622965,0.14163,0.061144,-0.621677,0.141471,0.074144,-0.622965,0.14163,0.074144,-0.621677,0.141471,0.061144,-0.575248,0.141471,0.061144,-0.575248,0.141471,0.074144,-0.621677,0.141471,0.074144,-0.575248,0.141471,0.061144,-0.573959,0.14163,0.061144,-0.573959,0.14163,0.074144,-0.575248,0.141471,0.074144,-0.573959,0.14163,0.061144,-0.572776,0.142082,0.061144,-0.572776,0.142082,0.074144,-0.573959,0.14163,0.074144,-0.572776,0.142082,0.061144,-0.571732,0.14279,0.061144,-0.571732,0.14279,0.074144,-0.572776,0.142082,0.074144,-0.571732,0.14279,0.061144,-0.57086,0.14372,0.061144,-0.57086,0.14372,0.074144,-0.571732,0.14279,0.074144,-0.57086,0.14372,0.061144,-0.570196,0.144834,0.061144,-0.570196,0.144834,0.074144,-0.57086,0.14372,0.074144,-0.570196,0.144834,0.061144,-0.569773,0.146096,0.061144,-0.569773,0.146096,0.074144,-0.570196,0.144834,0.074144,-0.569773,0.146096,0.061144,-0.569624,0.147471,0.061144,-0.569624,0.147471,0.074144,-0.569773,0.146096,0.074144,-0.569624,0.147471,0.061144,-0.569624,0.192619,0.061144,-0.569624,0.192619,0.074144,-0.569624,0.147471,0.074144,-0.569624,0.192619,0.061144,-0.569773,0.193994,0.061144,-0.569773,0.193994,0.074144,-0.569624,0.192619,0.061144,-0.569773,0.193994,0.074144,-0.569624,0.192619,0.074144,-0.569773,0.193994,0.061144,-0.570196,0.195257,0.061144,-0.570196,0.195257,0.074144,-0.569773,0.193994,0.074144,-0.570196,0.195257,0.061144,-0.57086,0.196371,0.061144,-0.57086,0.196371,0.074144,-0.570196,0.195257,0.061144,-0.57086,0.196371,0.074144,-0.570196,0.195257,0.074144,-0.57086,0.196371,0.061144,-0.571732,0.1973,0.061144,-0.571732,0.1973,0.074144,-0.57086,0.196371,0.074144,-0.571732,0.1973,0.061144,-0.572776,0.198009,0.061144,-0.572776,0.198009,0.074144,-0.571732,0.1973,0.074144,-0.572776,0.198009,0.061144,-0.573959,0.198461,0.061144,-0.573959,0.198461,0.074144,-0.572776,0.198009,0.074144,-0.573959,0.198461,0.061144,-0.575248,0.198619,0.061144,-0.575248,0.198619,0.074144,-0.573959,0.198461,0.074144,-0.502595,0.198619,0.061144,-0.549024,0.198619,0.061144,-0.549024,0.198619,0.074144,-0.502595,0.198619,0.074144,-0.549024,0.198619,0.061144,-0.550313,0.198461,0.061144,-0.550313,0.198461,0.074144,-0.549024,0.198619,0.074144,-0.550313,0.198461,0.061144,-0.551496,0.198009,0.061144,-0.551496,0.198009,0.074144,-0.550313,0.198461,0.074144,-0.551496,0.198009,0.061144,-0.55254,0.1973,0.061144,-0.55254,0.1973,0.074144,-0.551496,0.198009,0.061144,-0.55254,0.1973,0.074144,-0.551496,0.198009,0.074144,-0.55254,0.1973,0.061144,-0.553412,0.196371,0.061144,-0.553412,0.196371,0.074144,-0.55254,0.1973,0.061144,-0.553412,0.196371,0.074144,-0.55254,0.1973,0.074144,-0.553412,0.196371,0.061144,-0.554076,0.195257,0.061144,-0.554076,0.195257,0.074144,-0.553412,0.196371,0.074144,-0.554076,0.195257,0.061144,-0.554499,0.193994,0.061144,-0.554499,0.193994,0.074144,-0.554076,0.195257,0.074144,-0.554499,0.193994,0.061144,-0.554648,0.192619,0.061144,-0.554648,0.192619,0.074144,-0.554499,0.193994,0.074144,-0.554648,0.192619,0.061144,-0.554648,0.147471,0.061144,-0.554648,0.147471,0.074144,-0.554648,0.192619,0.074144,-0.554648,0.147471,0.061144,-0.554499,0.146096,0.061144,-0.554499,0.146096,0.074144,-0.554648,0.147471,0.074144,-0.554499,0.146096,0.061144,-0.554076,0.144834,0.061144,-0.554076,0.144834,0.074144,-0.554499,0.146096,0.074144,-0.554076,0.144834,0.061144,-0.553412,0.14372,0.061144,-0.553412,0.14372,0.074144,-0.554076,0.144834,0.074144,-0.553412,0.14372,0.061144,-0.55254,0.14279,0.061144,-0.55254,0.14279,0.074144,-0.553412,0.14372,0.074144,-0.55254,0.14279,0.061144,-0.551496,0.142082,0.061144,-0.551496,0.142082,0.074144,-0.55254,0.14279,0.074144,-0.551496,0.142082,0.061144,-0.550313,0.14163,0.061144,-0.550313,0.14163,0.074144,-0.551496,0.142082,0.061144,-0.550313,0.14163,0.074144,-0.551496,0.142082,0.074144,-0.550313,0.14163,0.061144,-0.549024,0.141471,0.061144,-0.549024,0.141471,0.074144,-0.550313,0.14163,0.061144,-0.549024,0.141471,0.074144,-0.550313,0.14163,0.074144,-0.549024,0.141471,0.061144,-0.502595,0.141471,0.061144,-0.502595,0.141471,0.074144,-0.549024,0.141471,0.074144,-0.502595,0.141471,0.061144,-0.501306,0.14163,0.061144,-0.501306,0.14163,0.074144,-0.502595,0.141471,0.074144,-0.501306,0.14163,0.061144,-0.500123,0.142082,0.061144,-0.500123,0.142082,0.074144,-0.501306,0.14163,0.074144,-0.500123,0.142082,0.061144,-0.499079,0.14279,0.061144,-0.499079,0.14279,0.074144,-0.500123,0.142082,0.074144,-0.499079,0.14279,0.061144,-0.498207,0.14372,0.061144,-0.498207,0.14372,0.074144,-0.499079,0.14279,0.074144,-0.498207,0.14372,0.061144,-0.497543,0.144834,0.061144,-0.497543,0.144834,0.074144,-0.498207,0.14372,0.074144,-0.497543,0.144834,0.061144,-0.49712,0.146096,0.061144,-0.49712,0.146096,0.074144,-0.497543,0.144834,0.074144,-0.49712,0.146096,0.061144,-0.496971,0.147471,0.061144,-0.496971,0.147471,0.074144,-0.49712,0.146096,0.074144,-0.496971,0.147471,0.061144,-0.496971,0.192619,0.061144,-0.496971,0.192619,0.074144,-0.496971,0.147471,0.074144,-0.496971,0.192619,0.061144,-0.49712,0.193994,0.061144,-0.49712,0.193994,0.074144,-0.496971,0.192619,0.074144,-0.49712,0.193994,0.061144,-0.497543,0.195257,0.061144,-0.497543,0.195257,0.074144,-0.49712,0.193994,0.074144,-0.497543,0.195257,0.061144,-0.498207,0.196371,0.061144,-0.498207,0.196371,0.074144,-0.497543,0.195257,0.074144,-0.498207,0.196371,0.061144,-0.499079,0.1973,0.061144,-0.499079,0.1973,0.074144,-0.498207,0.196371,0.074144,-0.499079,0.1973,0.061144,-0.500123,0.198009,0.061144,-0.500123,0.198009,0.074144,-0.499079,0.1973,0.074144,-0.500123,0.198009,0.061144,-0.501306,0.198461,0.061144,-0.501306,0.198461,0.074144,-0.500123,0.198009,0.074144,-0.501306,0.198461,0.061144,-0.502595,0.198619,0.061144,-0.502595,0.198619,0.074144,-0.501306,0.198461,0.074144,-0.428945,0.198619,0.061144,-0.475374,0.198619,0.061144,-0.475374,0.198619,0.074144,-0.428945,0.198619,0.074144,-0.475374,0.198619,0.061144,-0.476662,0.198461,0.061144,-0.476662,0.198461,0.074144,-0.475374,0.198619,0.074144,-0.476662,0.198461,0.061144,-0.477846,0.198009,0.061144,-0.477846,0.198009,0.074144,-0.476662,0.198461,0.074144,-0.477846,0.198009,0.061144,-0.47889,0.1973,0.061144,-0.47889,0.1973,0.074144,-0.477846,0.198009,0.074144,-0.47889,0.1973,0.061144,-0.479761,0.196371,0.061144,-0.479761,0.196371,0.074144,-0.47889,0.1973,0.074144,-0.479761,0.196371,0.061144,-0.480426,0.195257,0.061144,-0.480426,0.195257,0.074144,-0.479761,0.196371,0.074144,-0.480426,0.195257,0.061144,-0.480849,0.193994,0.061144,-0.480849,0.193994,0.074144,-0.480426,0.195257,0.074144,-0.480849,0.193994,0.061144,-0.480998,0.192619,0.061144,-0.480998,0.192619,0.074144,-0.480849,0.193994,0.074144,-0.480998,0.192619,0.061144,-0.480998,0.147471,0.061144,-0.480998,0.147471,0.074144,-0.480998,0.192619,0.074144,-0.480998,0.147471,0.061144,-0.480849,0.146096,0.061144,-0.480849,0.146096,0.074144,-0.480998,0.147471,0.074144,-0.480849,0.146096,0.061144,-0.480426,0.144834,0.061144,-0.480426,0.144834,0.074144,-0.480849,0.146096,0.061144,-0.480426,0.144834,0.074144,-0.480849,0.146096,0.074144,-0.480426,0.144834,0.061144,-0.479761,0.14372,0.061144,-0.479761,0.14372,0.074144,-0.480426,0.144834,0.074144,-0.479761,0.14372,0.061144,-0.47889,0.14279,0.061144,-0.47889,0.14279,0.074144,-0.479761,0.14372,0.061144,-0.47889,0.14279,0.074144,-0.479761,0.14372,0.074144,-0.47889,0.14279,0.061144,-0.477846,0.142082,0.061144,-0.477846,0.142082,0.074144,-0.47889,0.14279,0.074144,-0.477846,0.142082,0.061144,-0.476662,0.14163,0.061144,-0.476662,0.14163,0.074144,-0.477846,0.142082,0.074144,-0.476662,0.14163,0.061144,-0.475374,0.141471,0.061144,-0.475374,0.141471,0.074144,-0.476662,0.14163,0.074144,-0.475374,0.141471,0.061144,-0.428945,0.141471,0.061144,-0.428945,0.141471,0.074144,-0.475374,0.141471,0.061144,-0.428945,0.141471,0.074144,-0.475374,0.141471,0.074144,-0.428945,0.141471,0.061144,-0.427656,0.14163,0.061144,-0.427656,0.14163,0.074144,-0.428945,0.141471,0.061144,-0.427656,0.14163,0.074144,-0.428945,0.141471,0.074144,-0.427656,0.14163,0.061144,-0.426473,0.142082,0.061144,-0.426473,0.142082,0.074144,-0.427656,0.14163,0.074144,-0.426473,0.142082,0.061144,-0.425429,0.14279,0.061144,-0.425429,0.14279,0.074144,-0.426473,0.142082,0.074144,-0.425429,0.14279,0.061144,-0.424557,0.14372,0.061144,-0.424557,0.14372,0.074144,-0.425429,0.14279,0.074144,-0.424557,0.14372,0.061144,-0.423893,0.144834,0.061144,-0.423893,0.144834,0.074144,-0.424557,0.14372,0.061144,-0.423893,0.144834,0.074144,-0.424557,0.14372,0.074144,-0.423893,0.144834,0.061144,-0.423469,0.146096,0.061144,-0.423469,0.146096,0.074144,-0.423893,0.144834,0.061144,-0.423469,0.146096,0.074144,-0.423893,0.144834,0.074144,-0.423469,0.146096,0.061144,-0.423321,0.147471,0.061144,-0.423321,0.147471,0.074144,-0.423469,0.146096,0.074144,-0.423321,0.147471,0.061144,-0.423321,0.192619,0.061144,-0.423321,0.192619,0.074144,-0.423321,0.147471,0.074144,-0.423321,0.192619,0.061144,-0.423469,0.193994,0.061144,-0.423469,0.193994,0.074144,-0.423321,0.192619,0.074144,-0.423469,0.193994,0.061144,-0.423893,0.195257,0.061144,-0.423893,0.195257,0.074144,-0.423469,0.193994,0.074144,-0.423893,0.195257,0.061144,-0.424557,0.196371,0.061144,-0.424557,0.196371,0.074144,-0.423893,0.195257,0.074144,-0.424557,0.196371,0.061144,-0.425428,0.1973,0.061144,-0.425428,0.1973,0.074144,-0.424557,0.196371,0.074144,-0.425428,0.1973,0.061144,-0.426473,0.198009,0.061144,-0.426473,0.198009,0.074144,-0.425428,0.1973,0.074144,-0.426473,0.198009,0.061144,-0.427656,0.198461,0.061144,-0.427656,0.198461,0.074144,-0.426473,0.198009,0.074144,-0.427656,0.198461,0.061144,-0.428945,0.198619,0.061144,-0.428945,0.198619,0.074144,-0.427656,0.198461,0.074144,-0.355295,0.198619,0.061144,-0.401724,0.198619,0.061144,-0.401724,0.198619,0.074144,-0.355295,0.198619,0.061144,-0.401724,0.198619,0.074144,-0.355295,0.198619,0.074144,-0.401724,0.198619,0.061144,-0.403012,0.198461,0.061144,-0.403012,0.198461,0.074144,-0.401724,0.198619,0.074144,-0.403012,0.198461,0.061144,-0.404196,0.198009,0.061144,-0.404196,0.198009,0.074144,-0.403012,0.198461,0.074144,-0.404196,0.198009,0.061144,-0.40524,0.1973,0.061144,-0.40524,0.1973,0.074144,-0.404196,0.198009,0.074144,-0.40524,0.1973,0.061144,-0.406111,0.196371,0.061144,-0.406111,0.196371,0.074144,-0.40524,0.1973,0.074144,-0.406111,0.196371,0.061144,-0.406776,0.195257,0.061144,-0.406776,0.195257,0.074144,-0.406111,0.196371,0.074144,-0.406776,0.195257,0.061144,-0.407199,0.193994,0.061144,-0.407199,0.193994,0.074144,-0.406776,0.195257,0.074144,-0.407199,0.193994,0.061144,-0.407348,0.192619,0.061144,-0.407348,0.192619,0.074144,-0.407199,0.193994,0.074144,-0.407348,0.192619,0.061144,-0.407348,0.147471,0.061144,-0.407348,0.147471,0.074144,-0.407348,0.192619,0.074144,-0.407348,0.147471,0.061144,-0.407199,0.146096,0.061144,-0.407199,0.146096,0.074144,-0.407348,0.147471,0.061144,-0.407199,0.146096,0.074144,-0.407348,0.147471,0.074144,-0.407199,0.146096,0.061144,-0.406776,0.144834,0.061144,-0.406776,0.144834,0.074144,-0.407199,0.146096,0.061144,-0.406776,0.144834,0.074144,-0.407199,0.146096,0.074144,-0.406776,0.144834,0.061144,-0.406111,0.14372,0.061144,-0.406111,0.14372,0.074144,-0.406776,0.144834,0.074144,-0.406111,0.14372,0.061144,-0.40524,0.14279,0.061144,-0.40524,0.14279,0.074144,-0.406111,0.14372,0.061144,-0.40524,0.14279,0.074144,-0.406111,0.14372,0.074144,-0.40524,0.14279,0.061144,-0.404196,0.142082,0.061144,-0.404196,0.142082,0.074144,-0.40524,0.14279,0.061144,-0.404196,0.142082,0.074144,-0.40524,0.14279,0.074144,-0.404196,0.142082,0.061144,-0.403012,0.14163,0.061144,-0.403012,0.14163,0.074144,-0.404196,0.142082,0.074144,-0.403012,0.14163,0.061144,-0.401724,0.141471,0.061144,-0.401724,0.141471,0.074144,-0.403012,0.14163,0.061144,-0.401724,0.141471,0.074144,-0.403012,0.14163,0.074144,-0.401724,0.141471,0.061144,-0.355295,0.141471,0.061144,-0.355295,0.141471,0.074144,-0.401724,0.141471,0.074144,-0.355295,0.141471,0.061144,-0.354006,0.14163,0.061144,-0.354006,0.14163,0.074144,-0.355295,0.141471,0.074144,-0.354006,0.14163,0.061144,-0.352823,0.142082,0.061144,-0.352823,0.142082,0.074144,-0.354006,0.14163,0.074144,-0.352823,0.142082,0.061144,-0.351778,0.14279,0.061144,-0.351778,0.14279,0.074144,-0.352823,0.142082,0.061144,-0.351778,0.14279,0.074144,-0.352823,0.142082,0.074144,-0.351778,0.14279,0.061144,-0.350907,0.14372,0.061144,-0.350907,0.14372,0.074144,-0.351778,0.14279,0.074144,-0.350907,0.14372,0.061144,-0.350243,0.144834,0.061144,-0.350243,0.144834,0.074144,-0.350907,0.14372,0.061144,-0.350243,0.144834,0.074144,-0.350907,0.14372,0.074144,-0.350243,0.144834,0.061144,-0.349819,0.146096,0.061144,-0.349819,0.146096,0.074144,-0.350243,0.144834,0.074144,-0.349819,0.146096,0.061144,-0.349671,0.147471,0.061144,-0.349671,0.147471,0.074144,-0.349819,0.146096,0.074144,-0.349671,0.147471,0.061144,-0.349671,0.192619,0.061144,-0.349671,0.192619,0.074144,-0.349671,0.147471,0.074144,-0.349671,0.192619,0.061144,-0.349819,0.193994,0.061144,-0.349819,0.193994,0.074144,-0.349671,0.192619,0.074144,-0.349819,0.193994,0.061144,-0.350243,0.195257,0.061144,-0.350243,0.195257,0.074144,-0.349819,0.193994,0.074144,-0.350243,0.195257,0.061144,-0.350907,0.196371,0.061144,-0.350907,0.196371,0.074144,-0.350243,0.195257,0.074144,-0.350907,0.196371,0.061144,-0.351778,0.1973,0.061144,-0.351778,0.1973,0.074144,-0.350907,0.196371,0.074144,-0.351778,0.1973,0.061144,-0.352823,0.198009,0.061144,-0.352823,0.198009,0.074144,-0.351778,0.1973,0.074144,-0.352823,0.198009,0.061144,-0.354006,0.198461,0.061144,-0.354006,0.198461,0.074144,-0.352823,0.198009,0.074144,-0.354006,0.198461,0.061144,-0.355295,0.198619,0.061144,-0.355295,0.198619,0.074144,-0.354006,0.198461,0.061144,-0.355295,0.198619,0.074144,-0.354006,0.198461,0.074144,-0.281645,0.198619,0.061144,-0.328073,0.198619,0.061144,-0.328073,0.198619,0.074144,-0.281645,0.198619,0.074144,-0.328073,0.198619,0.061144,-0.329362,0.198461,0.061144,-0.329362,0.198461,0.074144,-0.328073,0.198619,0.074144,-0.329362,0.198461,0.061144,-0.330546,0.198009,0.061144,-0.330546,0.198009,0.074144,-0.329362,0.198461,0.074144,-0.330546,0.198009,0.061144,-0.33159,0.1973,0.061144,-0.33159,0.1973,0.074144,-0.330546,0.198009,0.074144,-0.33159,0.1973,0.061144,-0.332461,0.196371,0.061144,-0.332461,0.196371,0.074144,-0.33159,0.1973,0.061144,-0.332461,0.196371,0.074144,-0.33159,0.1973,0.074144,-0.332461,0.196371,0.061144,-0.333125,0.195257,0.061144,-0.333125,0.195257,0.074144,-0.332461,0.196371,0.061144,-0.333125,0.195257,0.074144,-0.332461,0.196371,0.074144,-0.333125,0.195257,0.061144,-0.333549,0.193994,0.061144,-0.333549,0.193994,0.074144,-0.333125,0.195257,0.074144,-0.333549,0.193994,0.061144,-0.333698,0.192619,0.061144,-0.333698,0.192619,0.074144,-0.333549,0.193994,0.074144,-0.333698,0.192619,0.061144,-0.333698,0.147471,0.061144,-0.333698,0.147471,0.074144,-0.333698,0.192619,0.074144,-0.333698,0.147471,0.061144,-0.333549,0.146096,0.061144,-0.333549,0.146096,0.074144,-0.333698,0.147471,0.074144,-0.333549,0.146096,0.061144,-0.333126,0.144834,0.061144,-0.333126,0.144834,0.074144,-0.333549,0.146096,0.074144,-0.333126,0.144834,0.061144,-0.332461,0.14372,0.061144,-0.332461,0.14372,0.074144,-0.333126,0.144834,0.074144,-0.332461,0.14372,0.061144,-0.33159,0.14279,0.061144,-0.33159,0.14279,0.074144,-0.332461,0.14372,0.074144,-0.33159,0.14279,0.061144,-0.330546,0.142082,0.061144,-0.330546,0.142082,0.074144,-0.33159,0.14279,0.074144,-0.330546,0.142082,0.061144,-0.329362,0.14163,0.061144,-0.329362,0.14163,0.074144,-0.330546,0.142082,0.061144,-0.329362,0.14163,0.074144,-0.330546,0.142082,0.074144,-0.329362,0.14163,0.061144,-0.328073,0.141471,0.061144,-0.328073,0.141471,0.074144,-0.329362,0.14163,0.061144,-0.328073,0.141471,0.074144,-0.329362,0.14163,0.074144,-0.328073,0.141471,0.061144,-0.281645,0.141471,0.061144,-0.281645,0.141471,0.074144,-0.328073,0.141471,0.074144,-0.281645,0.141471,0.061144,-0.280356,0.14163,0.061144,-0.280356,0.14163,0.074144,-0.281645,0.141471,0.074144,-0.280356,0.14163,0.061144,-0.279173,0.142082,0.061144,-0.279173,0.142082,0.074144,-0.280356,0.14163,0.074144,-0.279173,0.142082,0.061144,-0.278128,0.14279,0.061144,-0.278128,0.14279,0.074144,-0.279173,0.142082,0.061144,-0.278128,0.14279,0.074144,-0.279173,0.142082,0.074144,-0.278128,0.14279,0.061144,-0.277257,0.14372,0.061144,-0.277257,0.14372,0.074144,-0.278128,0.14279,0.074144,-0.277257,0.14372,0.061144,-0.276593,0.144834,0.061144,-0.276593,0.144834,0.074144,-0.277257,0.14372,0.061144,-0.276593,0.144834,0.074144,-0.277257,0.14372,0.074144,-0.276593,0.144834,0.061144,-0.276169,0.146096,0.061144,-0.276169,0.146096,0.074144,-0.276593,0.144834,0.074144,-0.276169,0.146096,0.061144,-0.276021,0.147471,0.061144,-0.276021,0.147471,0.074144,-0.276169,0.146096,0.074144,-0.276021,0.147471,0.061144,-0.276021,0.192619,0.061144,-0.276021,0.192619,0.074144,-0.276021,0.147471,0.074144,-0.276021,0.192619,0.061144,-0.276169,0.193994,0.061144,-0.276169,0.193994,0.074144,-0.276021,0.192619,0.061144,-0.276169,0.193994,0.074144,-0.276021,0.192619,0.074144,-0.276169,0.193994,0.061144,-0.276593,0.195257,0.061144,-0.276593,0.195257,0.074144,-0.276169,0.193994,0.074144,-0.276593,0.195257,0.061144,-0.277257,0.196371,0.061144,-0.277257,0.196371,0.074144,-0.276593,0.195257,0.074144,-0.277257,0.196371,0.061144,-0.278128,0.1973,0.061144,-0.278128,0.1973,0.074144,-0.277257,0.196371,0.074144,-0.278128,0.1973,0.061144,-0.279173,0.198009,0.061144,-0.279173,0.198009,0.074144,-0.278128,0.1973,0.074144,-0.279173,0.198009,0.061144,-0.280356,0.198461,0.061144,-0.280356,0.198461,0.074144,-0.279173,0.198009,0.074144,-0.280356,0.198461,0.061144,-0.281645,0.198619,0.061144,-0.281645,0.198619,0.074144,-0.280356,0.198461,0.074144,-0.207995,0.198619,0.061144,-0.254423,0.198619,0.061144,-0.254423,0.198619,0.074144,-0.207995,0.198619,0.061144,-0.254423,0.198619,0.074144,-0.207995,0.198619,0.074144,-0.254423,0.198619,0.061144,-0.255712,0.198461,0.061144,-0.255712,0.198461,0.074144,-0.254423,0.198619,0.061144,-0.255712,0.198461,0.074144,-0.254423,0.198619,0.074144,-0.255712,0.198461,0.061144,-0.256895,0.198009,0.061144,-0.256895,0.198009,0.074144,-0.255712,0.198461,0.061144,-0.256895,0.198009,0.074144,-0.255712,0.198461,0.074144,-0.256895,0.198009,0.061144,-0.25794,0.1973,0.061144,-0.25794,0.1973,0.074144,-0.256895,0.198009,0.061144,-0.25794,0.1973,0.074144,-0.256895,0.198009,0.074144,-0.25794,0.1973,0.061144,-0.258811,0.196371,0.061144,-0.258811,0.196371,0.074144,-0.25794,0.1973,0.074144,-0.258811,0.196371,0.061144,-0.259475,0.195257,0.061144,-0.259475,0.195257,0.074144,-0.258811,0.196371,0.074144,-0.259475,0.195257,0.061144,-0.259899,0.193994,0.061144,-0.259899,0.193994,0.074144,-0.259475,0.195257,0.074144,-0.259899,0.193994,0.061144,-0.260047,0.192619,0.061144,-0.260047,0.192619,0.074144,-0.259899,0.193994,0.074144,-0.260047,0.192619,0.061144,-0.260047,0.147471,0.061144,-0.260047,0.147471,0.074144,-0.260047,0.192619,0.074144,-0.260047,0.147471,0.061144,-0.259899,0.146096,0.061144,-0.259899,0.146096,0.074144,-0.260047,0.147471,0.074144,-0.259899,0.146096,0.061144,-0.259475,0.144834,0.061144,-0.259475,0.144834,0.074144,-0.259899,0.146096,0.074144,-0.259475,0.144834,0.061144,-0.258811,0.14372,0.061144,-0.258811,0.14372,0.074144,-0.259475,0.144834,0.074144,-0.258811,0.14372,0.061144,-0.25794,0.14279,0.061144,-0.25794,0.14279,0.074144,-0.258811,0.14372,0.074144,-0.25794,0.14279,0.061144,-0.256895,0.142082,0.061144,-0.256895,0.142082,0.074144,-0.25794,0.14279,0.074144,-0.256895,0.142082,0.061144,-0.255712,0.14163,0.061144,-0.255712,0.14163,0.074144,-0.256895,0.142082,0.074144,-0.255712,0.14163,0.061144,-0.254423,0.141471,0.061144,-0.254423,0.141471,0.074144,-0.255712,0.14163,0.074144,-0.254423,0.141471,0.061144,-0.207995,0.141471,0.061144,-0.207995,0.141471,0.074144,-0.254423,0.141471,0.061144,-0.207995,0.141471,0.074144,-0.254423,0.141471,0.074144,-0.207995,0.141471,0.061144,-0.206706,0.14163,0.061144,-0.206706,0.14163,0.074144,-0.207995,0.141471,0.061144,-0.206706,0.14163,0.074144,-0.207995,0.141471,0.074144,-0.206706,0.14163,0.061144,-0.205522,0.142082,0.061144,-0.205522,0.142082,0.074144,-0.206706,0.14163,0.074144,-0.205522,0.142082,0.061144,-0.204478,0.14279,0.061144,-0.204478,0.14279,0.074144,-0.205522,0.142082,0.074144,-0.204478,0.14279,0.061144,-0.203607,0.14372,0.061144,-0.203607,0.14372,0.074144,-0.204478,0.14279,0.074144,-0.203607,0.14372,0.061144,-0.202943,0.144834,0.061144,-0.202943,0.144834,0.074144,-0.203607,0.14372,0.061144,-0.202943,0.144834,0.074144,-0.203607,0.14372,0.074144,-0.202943,0.144834,0.061144,-0.202519,0.146096,0.061144,-0.202519,0.146096,0.074144,-0.202943,0.144834,0.074144,-0.202519,0.146096,0.061144,-0.20237,0.147471,0.061144,-0.20237,0.147471,0.074144,-0.202519,0.146096,0.061144,-0.20237,0.147471,0.074144,-0.202519,0.146096,0.074144,-0.20237,0.147471,0.061144,-0.20237,0.192619,0.061144,-0.20237,0.192619,0.074144,-0.20237,0.147471,0.074144,-0.20237,0.192619,0.061144,-0.202519,0.193994,0.061144,-0.202519,0.193994,0.074144,-0.20237,0.192619,0.074144,-0.202519,0.193994,0.061144,-0.202943,0.195257,0.061144,-0.202943,0.195257,0.074144,-0.202519,0.193994,0.074144,-0.202943,0.195257,0.061144,-0.203607,0.196371,0.061144,-0.203607,0.196371,0.074144,-0.202943,0.195257,0.074144,-0.203607,0.196371,0.061144,-0.204478,0.1973,0.061144,-0.204478,0.1973,0.074144,-0.203607,0.196371,0.074144,-0.204478,0.1973,0.061144,-0.205522,0.198009,0.061144,-0.205522,0.198009,0.074144,-0.204478,0.1973,0.074144,-0.205522,0.198009,0.061144,-0.206706,0.198461,0.061144,-0.206706,0.198461,0.074144,-0.205522,0.198009,0.074144,-0.206706,0.198461,0.061144,-0.207995,0.198619,0.061144,-0.207995,0.198619,0.074144,-0.206706,0.198461,0.074144,-0.134344,0.198619,0.061144,-0.180773,0.198619,0.061144,-0.180773,0.198619,0.074144,-0.134344,0.198619,0.074144,-0.180773,0.198619,0.061144,-0.182062,0.198461,0.061144,-0.182062,0.198461,0.074144,-0.180773,0.198619,0.074144,-0.182062,0.198461,0.061144,-0.183245,0.198009,0.061144,-0.183245,0.198009,0.074144,-0.182062,0.198461,0.074144,-0.183245,0.198009,0.061144,-0.18429,0.1973,0.061144,-0.18429,0.1973,0.074144,-0.183245,0.198009,0.074144,-0.18429,0.1973,0.061144,-0.185161,0.196371,0.061144,-0.185161,0.196371,0.074144,-0.18429,0.1973,0.074144,-0.185161,0.196371,0.061144,-0.185825,0.195257,0.061144,-0.185825,0.195257,0.074144,-0.185161,0.196371,0.074144,-0.185825,0.195257,0.061144,-0.186249,0.193994,0.061144,-0.186249,0.193994,0.074144,-0.185825,0.195257,0.074144,-0.186249,0.193994,0.061144,-0.186397,0.192619,0.061144,-0.186397,0.192619,0.074144,-0.186249,0.193994,0.074144,-0.186397,0.192619,0.061144,-0.186397,0.147471,0.061144,-0.186397,0.147471,0.074144,-0.186397,0.192619,0.074144,-0.186397,0.147471,0.061144,-0.186249,0.146096,0.061144,-0.186249,0.146096,0.074144,-0.186397,0.147471,0.074144,-0.186249,0.146096,0.061144,-0.185825,0.144834,0.061144,-0.185825,0.144834,0.074144,-0.186249,0.146096,0.074144,-0.185825,0.144834,0.061144,-0.185161,0.14372,0.061144,-0.185161,0.14372,0.074144,-0.185825,0.144834,0.074144,-0.185161,0.14372,0.061144,-0.18429,0.14279,0.061144,-0.18429,0.14279,0.074144,-0.185161,0.14372,0.074144,-0.18429,0.14279,0.061144,-0.183245,0.142082,0.061144,-0.183245,0.142082,0.074144,-0.18429,0.14279,0.074144,-0.183245,0.142082,0.061144,-0.182062,0.14163,0.061144,-0.182062,0.14163,0.074144,-0.183245,0.142082,0.074144,-0.182062,0.14163,0.061144,-0.180773,0.141471,0.061144,-0.180773,0.141471,0.074144,-0.182062,0.14163,0.074144,-0.180773,0.141471,0.061144,-0.134344,0.141471,0.061144,-0.134344,0.141471,0.074144,-0.180773,0.141471,0.061144,-0.134344,0.141471,0.074144,-0.180773,0.141471,0.074144,-0.134344,0.141471,0.061144,-0.133056,0.14163,0.061144,-0.133056,0.14163,0.074144,-0.134344,0.141471,0.074144,-0.133056,0.14163,0.061144,-0.131872,0.142082,0.061144,-0.131872,0.142082,0.074144,-0.133056,0.14163,0.074144,-0.131872,0.142082,0.061144,-0.130828,0.14279,0.061144,-0.130828,0.14279,0.074144,-0.131872,0.142082,0.074144,-0.130828,0.14279,0.061144,-0.129957,0.14372,0.061144,-0.129957,0.14372,0.074144,-0.130828,0.14279,0.074144,-0.129957,0.14372,0.061144,-0.129292,0.144834,0.061144,-0.129292,0.144834,0.074144,-0.129957,0.14372,0.074144,-0.129292,0.144834,0.061144,-0.128869,0.146096,0.061144,-0.128869,0.146096,0.074144,-0.129292,0.144834,0.074144,-0.128869,0.146096,0.061144,-0.12872,0.147471,0.061144,-0.12872,0.147471,0.074144,-0.128869,0.146096,0.061144,-0.12872,0.147471,0.074144,-0.128869,0.146096,0.074144,-0.12872,0.147471,0.061144,-0.12872,0.192619,0.061144,-0.12872,0.192619,0.074144,-0.12872,0.147471,0.074144,-0.12872,0.192619,0.061144,-0.128869,0.193994,0.061144,-0.128869,0.193994,0.074144,-0.12872,0.192619,0.074144,-0.128869,0.193994,0.061144,-0.129292,0.195257,0.061144,-0.129292,0.195257,0.074144,-0.128869,0.193994,0.074144,-0.129292,0.195257,0.061144,-0.129957,0.196371,0.061144,-0.129957,0.196371,0.074144,-0.129292,0.195257,0.074144,-0.129957,0.196371,0.061144,-0.130828,0.1973,0.061144,-0.130828,0.1973,0.074144,-0.129957,0.196371,0.074144,-0.130828,0.1973,0.061144,-0.131872,0.198009,0.061144,-0.131872,0.198009,0.074144,-0.130828,0.1973,0.074144,-0.131872,0.198009,0.061144,-0.133056,0.198461,0.061144,-0.133056,0.198461,0.074144,-0.131872,0.198009,0.074144,-0.133056,0.198461,0.061144,-0.134344,0.198619,0.061144,-0.134344,0.198619,0.074144,-0.133056,0.198461,0.074144,-0.060694,0.198619,0.061144,-0.107123,0.198619,0.061144,-0.107123,0.198619,0.074144,-0.060694,0.198619,0.061144,-0.107123,0.198619,0.074144,-0.060694,0.198619,0.074144,-0.107123,0.198619,0.061144,-0.108412,0.198461,0.061144,-0.108412,0.198461,0.074144,-0.107123,0.198619,0.061144,-0.108412,0.198461,0.074144,-0.107123,0.198619,0.074144,-0.108412,0.198461,0.061144,-0.109595,0.198009,0.061144,-0.109595,0.198009,0.074144,-0.108412,0.198461,0.074144,-0.109595,0.198009,0.061144,-0.110639,0.1973,0.061144,-0.110639,0.1973,0.074144,-0.109595,0.198009,0.074144,-0.110639,0.1973,0.061144,-0.111511,0.196371,0.061144,-0.111511,0.196371,0.074144,-0.110639,0.1973,0.074144,-0.111511,0.196371,0.061144,-0.112175,0.195257,0.061144,-0.112175,0.195257,0.074144,-0.111511,0.196371,0.074144,-0.112175,0.195257,0.061144,-0.112599,0.193994,0.061144,-0.112599,0.193994,0.074144,-0.112175,0.195257,0.074144,-0.112599,0.193994,0.061144,-0.112747,0.192619,0.061144,-0.112747,0.192619,0.074144,-0.112599,0.193994,0.074144,-0.112747,0.192619,0.061144,-0.112747,0.147471,0.061144,-0.112747,0.147471,0.074144,-0.112747,0.192619,0.074144,-0.112747,0.147471,0.061144,-0.112599,0.146096,0.061144,-0.112599,0.146096,0.074144,-0.112747,0.147471,0.061144,-0.112599,0.146096,0.074144,-0.112747,0.147471,0.074144,-0.112599,0.146096,0.061144,-0.112175,0.144834,0.061144,-0.112175,0.144834,0.074144,-0.112599,0.146096,0.074144,-0.112175,0.144834,0.061144,-0.111511,0.14372,0.061144,-0.111511,0.14372,0.074144,-0.112175,0.144834,0.074144,-0.111511,0.14372,0.061144,-0.110639,0.14279,0.061144,-0.110639,0.14279,0.074144,-0.111511,0.14372,0.074144,-0.110639,0.14279,0.061144,-0.109595,0.142082,0.061144,-0.109595,0.142082,0.074144,-0.110639,0.14279,0.074144,-0.109595,0.142082,0.061144,-0.108412,0.14163,0.061144,-0.108412,0.14163,0.074144,-0.109595,0.142082,0.061144,-0.108412,0.14163,0.074144,-0.109595,0.142082,0.074144,-0.108412,0.14163,0.061144,-0.107123,0.141471,0.061144,-0.107123,0.141471,0.074144,-0.108412,0.14163,0.061144,-0.107123,0.141471,0.074144,-0.108412,0.14163,0.074144,-0.107123,0.141471,0.061144,-0.060694,0.141471,0.061144,-0.060694,0.141471,0.074144,-0.107123,0.141471,0.074144,-0.060694,0.141471,0.061144,-0.059406,0.14163,0.061144,-0.059406,0.14163,0.074144,-0.060694,0.141471,0.074144,-0.059406,0.14163,0.061144,-0.058222,0.142082,0.061144,-0.058222,0.142082,0.074144,-0.059406,0.14163,0.074144,-0.058222,0.142082,0.061144,-0.057178,0.14279,0.061144,-0.057178,0.14279,0.074144,-0.058222,0.142082,0.074144,-0.057178,0.14279,0.061144,-0.056307,0.14372,0.061144,-0.056307,0.14372,0.074144,-0.057178,0.14279,0.074144,-0.056307,0.14372,0.061144,-0.055642,0.144834,0.061144,-0.055642,0.144834,0.074144,-0.056307,0.14372,0.074144,-0.055642,0.144834,0.061144,-0.055219,0.146096,0.061144,-0.055219,0.146096,0.074144,-0.055642,0.144834,0.074144,-0.055219,0.146096,0.061144,-0.05507,0.147471,0.061144,-0.05507,0.147471,0.074144,-0.055219,0.146096,0.074144,-0.05507,0.147471,0.061144,-0.05507,0.192619,0.061144,-0.05507,0.192619,0.074144,-0.05507,0.147471,0.074144,-0.05507,0.192619,0.061144,-0.055219,0.193994,0.061144,-0.055219,0.193994,0.074144,-0.05507,0.192619,0.061144,-0.055219,0.193994,0.074144,-0.05507,0.192619,0.074144,-0.055219,0.193994,0.061144,-0.055642,0.195257,0.061144,-0.055642,0.195257,0.074144,-0.055219,0.193994,0.074144,-0.055642,0.195257,0.061144,-0.056307,0.196371,0.061144,-0.056307,0.196371,0.074144,-0.055642,0.195257,0.061144,-0.056307,0.196371,0.074144,-0.055642,0.195257,0.074144,-0.056307,0.196371,0.061144,-0.057178,0.1973,0.061144,-0.057178,0.1973,0.074144,-0.056307,0.196371,0.074144,-0.057178,0.1973,0.061144,-0.058222,0.198009,0.061144,-0.058222,0.198009,0.074144,-0.057178,0.1973,0.074144,-0.058222,0.198009,0.061144,-0.059406,0.198461,0.061144,-0.059406,0.198461,0.074144,-0.058222,0.198009,0.074144,-0.059406,0.198461,0.061144,-0.060694,0.198619,0.061144,-0.060694,0.198619,0.074144,-0.059406,0.198461,0.074144,0.012956,0.198619,0.061144,-0.033473,0.198619,0.061144,-0.033473,0.198619,0.074144,0.012956,0.198619,0.074144,-0.033473,0.198619,0.061144,-0.034762,0.198461,0.061144,-0.034762,0.198461,0.074144,-0.033473,0.198619,0.074144,-0.034762,0.198461,0.061144,-0.035945,0.198009,0.061144,-0.035945,0.198009,0.074144,-0.034762,0.198461,0.074144,-0.035945,0.198009,0.061144,-0.036989,0.1973,0.061144,-0.036989,0.1973,0.074144,-0.035945,0.198009,0.061144,-0.036989,0.1973,0.074144,-0.035945,0.198009,0.074144,-0.036989,0.1973,0.061144,-0.037861,0.196371,0.061144,-0.037861,0.196371,0.074144,-0.036989,0.1973,0.061144,-0.037861,0.196371,0.074144,-0.036989,0.1973,0.074144,-0.037861,0.196371,0.061144,-0.038525,0.195257,0.061144,-0.038525,0.195257,0.074144,-0.037861,0.196371,0.074144,-0.038525,0.195257,0.061144,-0.038948,0.193994,0.061144,-0.038948,0.193994,0.074144,-0.038525,0.195257,0.074144,-0.038948,0.193994,0.061144,-0.039097,0.192619,0.061144,-0.039097,0.192619,0.074144,-0.038948,0.193994,0.074144,-0.039097,0.192619,0.061144,-0.039097,0.147471,0.061144,-0.039097,0.147471,0.074144,-0.039097,0.192619,0.074144,-0.039097,0.147471,0.061144,-0.038948,0.146096,0.061144,-0.038948,0.146096,0.074144,-0.039097,0.147471,0.074144,-0.038948,0.146096,0.061144,-0.038525,0.144834,0.061144,-0.038525,0.144834,0.074144,-0.038948,0.146096,0.074144,-0.038525,0.144834,0.061144,-0.037861,0.14372,0.061144,-0.037861,0.14372,0.074144,-0.038525,0.144834,0.074144,-0.037861,0.14372,0.061144,-0.036989,0.14279,0.061144,-0.036989,0.14279,0.074144,-0.037861,0.14372,0.074144,-0.036989,0.14279,0.061144,-0.035945,0.142082,0.061144,-0.035945,0.142082,0.074144,-0.036989,0.14279,0.074144,-0.035945,0.142082,0.061144,-0.034762,0.14163,0.061144,-0.034762,0.14163,0.074144,-0.035945,0.142082,0.074144,-0.034762,0.14163,0.061144,-0.033473,0.141471,0.061144,-0.033473,0.141471,0.074144,-0.034762,0.14163,0.074144,-0.033473,0.141471,0.061144,0.012956,0.141471,0.061144,0.012956,0.141471,0.074144,-0.033473,0.141471,0.074144,0.012956,0.141471,0.061144,0.014245,0.14163,0.061144,0.014245,0.14163,0.074144,0.012956,0.141471,0.074144,0.014245,0.14163,0.061144,0.015428,0.142082,0.061144,0.015428,0.142082,0.074144,0.014245,0.14163,0.074144,0.015428,0.142082,0.061144,0.016472,0.14279,0.061144,0.016472,0.14279,0.074144,0.015428,0.142082,0.074144,0.016472,0.14279,0.061144,0.017344,0.14372,0.061144,0.017344,0.14372,0.074144,0.016472,0.14279,0.074144,0.017344,0.14372,0.061144,0.018008,0.144834,0.061144,0.018008,0.144834,0.074144,0.017344,0.14372,0.074144,0.018008,0.144834,0.061144,0.018431,0.146096,0.061144,0.018431,0.146096,0.074144,0.018008,0.144834,0.074144,0.018431,0.146096,0.061144,0.01858,0.147471,0.061144,0.01858,0.147471,0.074144,0.018431,0.146096,0.074144,0.01858,0.147471,0.061144,0.01858,0.192619,0.061144,0.01858,0.192619,0.074144,0.01858,0.147471,0.074144,0.01858,0.192619,0.061144,0.018431,0.193994,0.061144,0.018431,0.193994,0.074144,0.01858,0.192619,0.074144,0.018431,0.193994,0.061144,0.018008,0.195257,0.061144,0.018008,0.195257,0.074144,0.018431,0.193994,0.074144,0.018008,0.195257,0.061144,0.017344,0.196371,0.061144,0.017344,0.196371,0.074144,0.018008,0.195257,0.074144,0.017344,0.196371,0.061144,0.016472,0.1973,0.061144,0.016472,0.1973,0.074144,0.017344,0.196371,0.074144,0.016472,0.1973,0.061144,0.015428,0.198009,0.061144,0.015428,0.198009,0.074144,0.016472,0.1973,0.074144,0.015428,0.198009,0.061144,0.014245,0.198461,0.061144,0.014245,0.198461,0.074144,0.015428,0.198009,0.074144,0.014245,0.198461,0.061144,0.012956,0.198619,0.061144,0.012956,0.198619,0.074144,0.014245,0.198461,0.074144,0.086606,0.198619,0.061144,0.040177,0.198619,0.061144,0.040177,0.198619,0.074144,0.086606,0.198619,0.061144,0.040177,0.198619,0.074144,0.086606,0.198619,0.074144,0.040177,0.198619,0.061144,0.038889,0.198461,0.061144,0.038889,0.198461,0.074144,0.040177,0.198619,0.074144,0.038889,0.198461,0.061144,0.037705,0.198009,0.061144,0.037705,0.198009,0.074144,0.038889,0.198461,0.074144,0.037705,0.198009,0.061144,0.036661,0.1973,0.061144,0.036661,0.1973,0.074144,0.037705,0.198009,0.074144,0.036661,0.1973,0.061144,0.03579,0.196371,0.061144,0.03579,0.196371,0.074144,0.036661,0.1973,0.074144,0.03579,0.196371,0.061144,0.035125,0.195257,0.061144,0.035125,0.195257,0.074144,0.03579,0.196371,0.074144,0.035125,0.195257,0.061144,0.034702,0.193994,0.061144,0.034702,0.193994,0.074144,0.035125,0.195257,0.061144,0.034702,0.193994,0.074144,0.035125,0.195257,0.074144,0.034702,0.193994,0.061144,0.034553,0.192619,0.061144,0.034553,0.192619,0.074144,0.034702,0.193994,0.061144,0.034553,0.192619,0.074144,0.034702,0.193994,0.074144,0.034553,0.192619,0.061144,0.034553,0.147471,0.061144,0.034553,0.147471,0.074144,0.034553,0.192619,0.074144,0.034553,0.147471,0.061144,0.034702,0.146096,0.061144,0.034702,0.146096,0.074144,0.034553,0.147471,0.074144,0.034702,0.146096,0.061144,0.035125,0.144834,0.061144,0.035125,0.144834,0.074144,0.034702,0.146096,0.074144,0.035125,0.144834,0.061144,0.03579,0.14372,0.061144,0.03579,0.14372,0.074144,0.035125,0.144834,0.074144,0.03579,0.14372,0.061144,0.036661,0.14279,0.061144,0.036661,0.14279,0.074144,0.03579,0.14372,0.074144,0.036661,0.14279,0.061144,0.037705,0.142082,0.061144,0.037705,0.142082,0.074144,0.036661,0.14279,0.074144,0.037705,0.142082,0.061144,0.038889,0.14163,0.061144,0.038889,0.14163,0.074144,0.037705,0.142082,0.074144,0.038889,0.14163,0.061144,0.040177,0.141471,0.061144,0.040177,0.141471,0.074144,0.038889,0.14163,0.074144,0.040177,0.141471,0.061144,0.086606,0.141471,0.061144,0.086606,0.141471,0.074144,0.040177,0.141471,0.061144,0.086606,0.141471,0.074144,0.040177,0.141471,0.074144,0.086606,0.141471,0.061144,0.087895,0.14163,0.061144,0.087895,0.14163,0.074144,0.086606,0.141471,0.061144,0.087895,0.14163,0.074144,0.086606,0.141471,0.074144,0.087895,0.14163,0.061144,0.089078,0.142082,0.061144,0.089078,0.142082,0.074144,0.087895,0.14163,0.074144,0.089078,0.142082,0.061144,0.090122,0.14279,0.061144,0.090122,0.14279,0.074144,0.089078,0.142082,0.074144,0.090122,0.14279,0.061144,0.090994,0.14372,0.061144,0.090994,0.14372,0.074144,0.090122,0.14279,0.074144,0.090994,0.14372,0.061144,0.091658,0.144834,0.061144,0.091658,0.144834,0.074144,0.090994,0.14372,0.074144,0.091658,0.144834,0.061144,0.092081,0.146096,0.061144,0.092081,0.146096,0.074144,0.091658,0.144834,0.074144,0.092081,0.146096,0.061144,0.09223,0.147471,0.061144,0.09223,0.147471,0.074144,0.092081,0.146096,0.074144,0.09223,0.147471,0.061144,0.09223,0.192619,0.061144,0.09223,0.192619,0.074144,0.09223,0.147471,0.074144,0.09223,0.192619,0.061144,0.092081,0.193994,0.061144,0.092081,0.193994,0.074144,0.09223,0.192619,0.074144,0.092081,0.193994,0.061144,0.091658,0.195257,0.061144,0.091658,0.195257,0.074144,0.092081,0.193994,0.074144,0.091658,0.195257,0.061144,0.090994,0.196371,0.061144,0.090994,0.196371,0.074144,0.091658,0.195257,0.074144,0.090994,0.196371,0.061144,0.090122,0.1973,0.061144,0.090122,0.1973,0.074144,0.090994,0.196371,0.074144,0.090122,0.1973,0.061144,0.089078,0.198009,0.061144,0.089078,0.198009,0.074144,0.090122,0.1973,0.074144,0.089078,0.198009,0.061144,0.087895,0.198461,0.061144,0.087895,0.198461,0.074144,0.089078,0.198009,0.074144,0.087895,0.198461,0.061144,0.086606,0.198619,0.061144,0.086606,0.198619,0.074144,0.087895,0.198461,0.074144,0.160256,0.198619,0.061144,0.113827,0.198619,0.061144,0.113827,0.198619,0.074144,0.160256,0.198619,0.074144,0.113827,0.198619,0.061144,0.112539,0.198461,0.061144,0.112539,0.198461,0.074144,0.113827,0.198619,0.074144,0.112539,0.198461,0.061144,0.111355,0.198009,0.061144,0.111355,0.198009,0.074144,0.112539,0.198461,0.074144,0.111355,0.198009,0.061144,0.110311,0.1973,0.061144,0.110311,0.1973,0.074144,0.111355,0.198009,0.074144,0.110311,0.1973,0.061144,0.10944,0.196371,0.061144,0.10944,0.196371,0.074144,0.110311,0.1973,0.074144,0.10944,0.196371,0.061144,0.108775,0.195257,0.061144,0.108775,0.195257,0.074144,0.10944,0.196371,0.074144,0.108775,0.195257,0.061144,0.108352,0.193994,0.061144,0.108352,0.193994,0.074144,0.108775,0.195257,0.074144,0.108352,0.193994,0.061144,0.108203,0.192619,0.061144,0.108203,0.192619,0.074144,0.108352,0.193994,0.074144,0.108203,0.192619,0.061144,0.108203,0.147471,0.061144,0.108203,0.147471,0.074144,0.108203,0.192619,0.074144,0.108203,0.147471,0.061144,0.108352,0.146096,0.061144,0.108352,0.146096,0.074144,0.108203,0.147471,0.061144,0.108352,0.146096,0.074144,0.108203,0.147471,0.074144,0.108352,0.146096,0.061144,0.108775,0.144834,0.061144,0.108775,0.144834,0.074144,0.108352,0.146096,0.074144,0.108775,0.144834,0.061144,0.10944,0.14372,0.061144,0.10944,0.14372,0.074144,0.108775,0.144834,0.074144,0.10944,0.14372,0.061144,0.110311,0.14279,0.061144,0.110311,0.14279,0.074144,0.10944,0.14372,0.074144,0.110311,0.14279,0.061144,0.111355,0.142082,0.061144,0.111355,0.142082,0.074144,0.110311,0.14279,0.074144,0.111355,0.142082,0.061144,0.112539,0.14163,0.061144,0.112539,0.14163,0.074144,0.111355,0.142082,0.074144,0.112539,0.14163,0.061144,0.113827,0.141471,0.061144,0.113827,0.141471,0.074144,0.112539,0.14163,0.074144,0.113827,0.141471,0.061144,0.160256,0.141471,0.061144,0.160256,0.141471,0.074144,0.113827,0.141471,0.074144,0.160256,0.141471,0.061144,0.161545,0.14163,0.061144,0.161545,0.14163,0.074144,0.160256,0.141471,0.074144,0.161545,0.14163,0.061144,0.162728,0.142082,0.061144,0.162728,0.142082,0.074144,0.161545,0.14163,0.061144,0.162728,0.142082,0.074144,0.161545,0.14163,0.074144,0.162728,0.142082,0.061144,0.163773,0.14279,0.061144,0.163773,0.14279,0.074144,0.162728,0.142082,0.074144,0.163773,0.14279,0.061144,0.164644,0.14372,0.061144,0.164644,0.14372,0.074144,0.163773,0.14279,0.074144,0.164644,0.14372,0.061144,0.165308,0.144834,0.061144,0.165308,0.144834,0.074144,0.164644,0.14372,0.061144,0.165308,0.144834,0.074144,0.164644,0.14372,0.074144,0.165308,0.144834,0.061144,0.165732,0.146096,0.061144,0.165732,0.146096,0.074144,0.165308,0.144834,0.074144,0.165732,0.146096,0.061144,0.16588,0.147471,0.061144,0.16588,0.147471,0.074144,0.165732,0.146096,0.074144,0.16588,0.147471,0.061144,0.16588,0.192619,0.061144,0.16588,0.192619,0.074144,0.16588,0.147471,0.074144,0.16588,0.192619,0.061144,0.165732,0.193994,0.061144,0.165732,0.193994,0.074144,0.16588,0.192619,0.074144,0.165732,0.193994,0.061144,0.165308,0.195257,0.061144,0.165308,0.195257,0.074144,0.165732,0.193994,0.074144,0.165308,0.195257,0.061144,0.164644,0.196371,0.061144,0.164644,0.196371,0.074144,0.165308,0.195257,0.074144,0.164644,0.196371,0.061144,0.163773,0.1973,0.061144,0.163773,0.1973,0.074144,0.164644,0.196371,0.061144,0.163773,0.1973,0.074144,0.164644,0.196371,0.074144,0.163773,0.1973,0.061144,0.162728,0.198009,0.061144,0.162728,0.198009,0.074144,0.163773,0.1973,0.074144,0.162728,0.198009,0.061144,0.161545,0.198461,0.061144,0.161545,0.198461,0.074144,0.162728,0.198009,0.074144,0.161545,0.198461,0.061144,0.160256,0.198619,0.061144,0.160256,0.198619,0.074144,0.161545,0.198461,0.074144,0.233906,0.198619,0.061144,0.187478,0.198619,0.061144,0.187478,0.198619,0.074144,0.233906,0.198619,0.074144,0.187478,0.198619,0.061144,0.186189,0.198461,0.061144,0.186189,0.198461,0.074144,0.187478,0.198619,0.074144,0.186189,0.198461,0.061144,0.185005,0.198009,0.061144,0.185005,0.198009,0.074144,0.186189,0.198461,0.074144,0.185005,0.198009,0.061144,0.183961,0.1973,0.061144,0.183961,0.1973,0.074144,0.185005,0.198009,0.074144,0.183961,0.1973,0.061144,0.18309,0.196371,0.061144,0.18309,0.196371,0.074144,0.183961,0.1973,0.074144,0.18309,0.196371,0.061144,0.182426,0.195257,0.061144,0.182426,0.195257,0.074144,0.18309,0.196371,0.074144,0.182426,0.195257,0.061144,0.182002,0.193994,0.061144,0.182002,0.193994,0.074144,0.182426,0.195257,0.074144,0.182002,0.193994,0.061144,0.181853,0.192619,0.061144,0.181853,0.192619,0.074144,0.182002,0.193994,0.074144,0.181853,0.192619,0.061144,0.181853,0.147471,0.061144,0.181853,0.147471,0.074144,0.181853,0.192619,0.074144,0.181853,0.147471,0.061144,0.182002,0.146097,0.061144,0.182002,0.146097,0.074144,0.181853,0.147471,0.074144,0.182002,0.146097,0.061144,0.182426,0.144834,0.061144,0.182426,0.144834,0.074144,0.182002,0.146097,0.074144,0.182426,0.144834,0.061144,0.18309,0.14372,0.061144,0.18309,0.14372,0.074144,0.182426,0.144834,0.074144,0.18309,0.14372,0.061144,0.183961,0.14279,0.061144,0.183961,0.14279,0.074144,0.18309,0.14372,0.074144,0.183961,0.14279,0.061144,0.185005,0.142082,0.061144,0.185005,0.142082,0.074144,0.183961,0.14279,0.074144,0.185005,0.142082,0.061144,0.186189,0.14163,0.061144,0.186189,0.14163,0.074144,0.185005,0.142082,0.074144,0.186189,0.14163,0.061144,0.187478,0.141471,0.061144,0.187478,0.141471,0.074144,0.186189,0.14163,0.074144,0.187478,0.141471,0.061144,0.233906,0.141471,0.061144,0.233906,0.141471,0.074144,0.187478,0.141471,0.074144,0.233906,0.141471,0.061144,0.235195,0.14163,0.061144,0.235195,0.14163,0.074144,0.233906,0.141471,0.074144,0.235195,0.14163,0.061144,0.236378,0.142082,0.061144,0.236378,0.142082,0.074144,0.235195,0.14163,0.074144,0.236378,0.142082,0.061144,0.237423,0.14279,0.061144,0.237423,0.14279,0.074144,0.236378,0.142082,0.074144,0.237423,0.14279,0.061144,0.238294,0.14372,0.061144,0.238294,0.14372,0.074144,0.237423,0.14279,0.074144,0.238294,0.14372,0.061144,0.238958,0.144834,0.061144,0.238958,0.144834,0.074144,0.238294,0.14372,0.074144,0.238958,0.144834,0.061144,0.239382,0.146096,0.061144,0.239382,0.146096,0.074144,0.238958,0.144834,0.074144,0.239382,0.146096,0.061144,0.23953,0.147471,0.061144,0.23953,0.147471,0.074144,0.239382,0.146096,0.074144,0.23953,0.147471,0.061144,0.23953,0.192619,0.061144,0.23953,0.192619,0.074144,0.23953,0.147471,0.074144,0.23953,0.192619,0.061144,0.239382,0.193994,0.061144,0.239382,0.193994,0.074144,0.23953,0.192619,0.061144,0.239382,0.193994,0.074144,0.23953,0.192619,0.074144,0.239382,0.193994,0.061144,0.238958,0.195257,0.061144,0.238958,0.195257,0.074144,0.239382,0.193994,0.074144,0.238958,0.195257,0.061144,0.238294,0.196371,0.061144,0.238294,0.196371,0.074144,0.238958,0.195257,0.074144,0.238294,0.196371,0.061144,0.237423,0.1973,0.061144,0.237423,0.1973,0.074144,0.238294,0.196371,0.074144,0.237423,0.1973,0.061144,0.236378,0.198009,0.061144,0.236378,0.198009,0.074144,0.237423,0.1973,0.074144,0.236378,0.198009,0.061144,0.235195,0.198461,0.061144,0.235195,0.198461,0.074144,0.236378,0.198009,0.074144,0.235195,0.198461,0.061144,0.233906,0.198619,0.061144,0.233906,0.198619,0.074144,0.235195,0.198461,0.074144,0.307556,0.198619,0.061144,0.261128,0.198619,0.061144,0.261128,0.198619,0.074144,0.307556,0.198619,0.074144,0.261128,0.198619,0.061144,0.259839,0.198461,0.061144,0.259839,0.198461,0.074144,0.261128,0.198619,0.061144,0.259839,0.198461,0.074144,0.261128,0.198619,0.074144,0.259839,0.198461,0.061144,0.258656,0.198009,0.061144,0.258656,0.198009,0.074144,0.259839,0.198461,0.061144,0.258656,0.198009,0.074144,0.259839,0.198461,0.074144,0.258656,0.198009,0.061144,0.257611,0.1973,0.061144,0.257611,0.1973,0.074144,0.258656,0.198009,0.061144,0.257611,0.1973,0.074144,0.258656,0.198009,0.074144,0.257611,0.1973,0.061144,0.25674,0.196371,0.061144,0.25674,0.196371,0.074144,0.257611,0.1973,0.074144,0.25674,0.196371,0.061144,0.256076,0.195257,0.061144,0.256076,0.195257,0.074144,0.25674,0.196371,0.061144,0.256076,0.195257,0.074144,0.25674,0.196371,0.074144,0.256076,0.195257,0.061144,0.255652,0.193994,0.061144,0.255652,0.193994,0.074144,0.256076,0.195257,0.061144,0.255652,0.193994,0.074144,0.256076,0.195257,0.074144,0.255652,0.193994,0.061144,0.255504,0.192619,0.061144,0.255504,0.192619,0.074144,0.255652,0.193994,0.074144,0.255504,0.192619,0.061144,0.255504,0.147471,0.061144,0.255504,0.147471,0.074144,0.255504,0.192619,0.074144,0.255504,0.147471,0.061144,0.255652,0.146097,0.061144,0.255652,0.146097,0.074144,0.255504,0.147471,0.074144,0.255652,0.146097,0.061144,0.256076,0.144834,0.061144,0.256076,0.144834,0.074144,0.255652,0.146097,0.074144,0.256076,0.144834,0.061144,0.25674,0.14372,0.061144,0.25674,0.14372,0.074144,0.256076,0.144834,0.074144,0.25674,0.14372,0.061144,0.257611,0.14279,0.061144,0.257611,0.14279,0.074144,0.25674,0.14372,0.074144,0.257611,0.14279,0.061144,0.258656,0.142082,0.061144,0.258656,0.142082,0.074144,0.257611,0.14279,0.074144,0.258656,0.142082,0.061144,0.259839,0.14163,0.061144,0.259839,0.14163,0.074144,0.258656,0.142082,0.074144,0.259839,0.14163,0.061144,0.261128,0.141471,0.061144,0.261128,0.141471,0.074144,0.259839,0.14163,0.061144,0.261128,0.141471,0.074144,0.259839,0.14163,0.074144,0.261128,0.141471,0.061144,0.307556,0.141471,0.061144,0.307556,0.141471,0.074144,0.261128,0.141471,0.061144,0.307556,0.141471,0.074144,0.261128,0.141471,0.074144,0.307556,0.141471,0.061144,0.308845,0.14163,0.061144,0.308845,0.14163,0.074144,0.307556,0.141471,0.074144,0.308845,0.14163,0.061144,0.310029,0.142082,0.061144,0.310029,0.142082,0.074144,0.308845,0.14163,0.074144,0.310029,0.142082,0.061144,0.311073,0.14279,0.061144,0.311073,0.14279,0.074144,0.310029,0.142082,0.074144,0.311073,0.14279,0.061144,0.311944,0.14372,0.061144,0.311944,0.14372,0.074144,0.311073,0.14279,0.074144,0.311944,0.14372,0.061144,0.312608,0.144834,0.061144,0.312608,0.144834,0.074144,0.311944,0.14372,0.074144,0.312608,0.144834,0.061144,0.313032,0.146096,0.061144,0.313032,0.146096,0.074144,0.312608,0.144834,0.074144,0.313032,0.146096,0.061144,0.313181,0.147471,0.061144,0.313181,0.147471,0.074144,0.313032,0.146096,0.074144,0.313181,0.147471,0.061144,0.313181,0.192619,0.061144,0.313181,0.192619,0.074144,0.313181,0.147471,0.074144,0.313181,0.192619,0.061144,0.313032,0.193994,0.061144,0.313032,0.193994,0.074144,0.313181,0.192619,0.074144,0.313032,0.193994,0.061144,0.312609,0.195257,0.061144,0.312609,0.195257,0.074144,0.313032,0.193994,0.074144,0.312609,0.195257,0.061144,0.311944,0.196371,0.061144,0.311944,0.196371,0.074144,0.312609,0.195257,0.074144,0.311944,0.196371,0.061144,0.311073,0.1973,0.061144,0.311073,0.1973,0.074144,0.311944,0.196371,0.061144,0.311073,0.1973,0.074144,0.311944,0.196371,0.074144,0.311073,0.1973,0.061144,0.310029,0.198009,0.061144,0.310029,0.198009,0.074144,0.311073,0.1973,0.061144,0.310029,0.198009,0.074144,0.311073,0.1973,0.074144,0.310029,0.198009,0.061144,0.308845,0.198461,0.061144,0.308845,0.198461,0.074144,0.310029,0.198009,0.074144,0.308845,0.198461,0.061144,0.307556,0.198619,0.061144,0.307556,0.198619,0.074144,0.308845,0.198461,0.074144,0.443721,0.197119,0.061144,0.338548,0.197119,0.061144,0.338548,0.197119,0.074144,0.443721,0.197119,0.061144,0.338548,0.197119,0.074144,0.443721,0.197119,0.074144,0.338548,0.197119,0.061144,0.33726,0.196961,0.061144,0.33726,0.196961,0.074144,0.338548,0.197119,0.074144,0.33726,0.196961,0.061144,0.336076,0.196509,0.061144,0.336076,0.196509,0.074144,0.33726,0.196961,0.074144,0.336076,0.196509,0.061144,0.335032,0.1958,0.061144,0.335032,0.1958,0.074144,0.336076,0.196509,0.074144,0.335032,0.1958,0.061144,0.334161,0.194871,0.061144,0.334161,0.194871,0.074144,0.335032,0.1958,0.074144,0.334161,0.194871,0.061144,0.333496,0.193757,0.061144,0.333496,0.193757,0.074144,0.334161,0.194871,0.074144,0.333496,0.193757,0.061144,0.333073,0.192494,0.061144,0.333073,0.192494,0.074144,0.333496,0.193757,0.074144,0.333073,0.192494,0.061144,0.332924,0.191119,0.061144,0.332924,0.191119,0.074144,0.333073,0.192494,0.074144,0.332924,0.191119,0.061144,0.332924,0.148971,0.061144,0.332924,0.148971,0.074144,0.332924,0.191119,0.074144,0.332924,0.148971,0.061144,0.333073,0.147596,0.061144,0.333073,0.147596,0.074144,0.332924,0.148971,0.074144,0.333073,0.147596,0.061144,0.333496,0.146334,0.061144,0.333496,0.146334,0.074144,0.333073,0.147596,0.074144,0.333496,0.146334,0.061144,0.334161,0.14522,0.061144,0.334161,0.14522,0.074144,0.333496,0.146334,0.074144,0.334161,0.14522,0.061144,0.335032,0.14429,0.061144,0.335032,0.14429,0.074144,0.334161,0.14522,0.074144,0.335032,0.14429,0.061144,0.336076,0.143582,0.061144,0.336076,0.143582,0.074144,0.335032,0.14429,0.061144,0.336076,0.143582,0.074144,0.335032,0.14429,0.074144,0.336076,0.143582,0.061144,0.33726,0.14313,0.061144,0.33726,0.14313,0.074144,0.336076,0.143582,0.074144,0.33726,0.14313,0.061144,0.338548,0.142971,0.061144,0.338548,0.142971,0.074144,0.33726,0.14313,0.074144,0.338548,0.142971,0.061144,0.443721,0.142971,0.061144,0.443721,0.142971,0.074144,0.338548,0.142971,0.061144,0.443721,0.142971,0.074144,0.338548,0.142971,0.074144,0.443721,0.142971,0.061144,0.44501,0.14313,0.061144,0.44501,0.14313,0.074144,0.443721,0.142971,0.074144,0.44501,0.14313,0.061144,0.446193,0.143582,0.061144,0.446193,0.143582,0.074144,0.44501,0.14313,0.074144,0.446193,0.143582,0.061144,0.447238,0.14429,0.061144,0.447238,0.14429,0.074144,0.446193,0.143582,0.074144,0.447238,0.14429,0.061144,0.448109,0.14522,0.061144,0.448109,0.14522,0.074144,0.447238,0.14429,0.074144,0.448109,0.14522,0.061144,0.448773,0.146334,0.061144,0.448773,0.146334,0.074144,0.448109,0.14522,0.074144,0.448773,0.146334,0.061144,0.449197,0.147597,0.061144,0.449197,0.147597,0.074144,0.448773,0.146334,0.074144,0.449197,0.147597,0.061144,0.449346,0.148971,0.061144,0.449346,0.148971,0.074144,0.449197,0.147597,0.074144,0.449346,0.148971,0.061144,0.449346,0.191119,0.061144,0.449346,0.191119,0.074144,0.449346,0.148971,0.074144,0.449346,0.191119,0.061144,0.449197,0.192494,0.061144,0.449197,0.192494,0.074144,0.449346,0.191119,0.061144,0.449197,0.192494,0.074144,0.449346,0.191119,0.074144,0.449197,0.192494,0.061144,0.448773,0.193757,0.061144,0.448773,0.193757,0.074144,0.449197,0.192494,0.074144,0.448773,0.193757,0.061144,0.448109,0.194871,0.061144,0.448109,0.194871,0.074144,0.448773,0.193757,0.074144,0.448109,0.194871,0.061144,0.447238,0.1958,0.061144,0.447238,0.1958,0.074144,0.448109,0.194871,0.074144,0.447238,0.1958,0.061144,0.446193,0.196509,0.061144,0.446193,0.196509,0.074144,0.447238,0.1958,0.074144,0.446193,0.196509,0.061144,0.44501,0.196961,0.061144,0.44501,0.196961,0.074144,0.446193,0.196509,0.061144,0.44501,0.196961,0.074144,0.446193,0.196509,0.074144,0.44501,0.196961,0.061144,0.443721,0.197119,0.061144,0.443721,0.197119,0.074144,0.44501,0.196961,0.061144,0.443721,0.197119,0.074144,0.44501,0.196961,0.074144,-0.445041,0.125739,0.061144,-0.49147,0.125739,0.061144,-0.49147,0.125739,0.074144,-0.445041,0.125739,0.074144,-0.49147,0.125739,0.061144,-0.492758,0.12558,0.061144,-0.492758,0.12558,0.074144,-0.49147,0.125739,0.074144,-0.492758,0.12558,0.061144,-0.493942,0.125129,0.061144,-0.493942,0.125129,0.074144,-0.492758,0.12558,0.074144,-0.493942,0.125129,0.061144,-0.494986,0.12442,0.061144,-0.494986,0.12442,0.074144,-0.493942,0.125129,0.074144,-0.494986,0.12442,0.061144,-0.495857,0.12349,0.061144,-0.495857,0.12349,0.074144,-0.494986,0.12442,0.074144,-0.495857,0.12349,0.061144,-0.496522,0.122376,0.061144,-0.496522,0.122376,0.074144,-0.495857,0.12349,0.074144,-0.496522,0.122376,0.061144,-0.496945,0.121114,0.061144,-0.496945,0.121114,0.074144,-0.496522,0.122376,0.074144,-0.496945,0.121114,0.061144,-0.497094,0.119739,0.061144,-0.497094,0.119739,0.074144,-0.496945,0.121114,0.061144,-0.497094,0.119739,0.074144,-0.496945,0.121114,0.074144,-0.497094,0.119739,0.061144,-0.497094,0.074591,0.061144,-0.497094,0.074591,0.074144,-0.497094,0.119739,0.074144,-0.497094,0.074591,0.061144,-0.496945,0.073216,0.061144,-0.496945,0.073216,0.074144,-0.497094,0.074591,0.074144,-0.496945,0.073216,0.061144,-0.496522,0.071954,0.061144,-0.496522,0.071954,0.074144,-0.496945,0.073216,0.061144,-0.496522,0.071954,0.074144,-0.496945,0.073216,0.074144,-0.496522,0.071954,0.061144,-0.495857,0.07084,0.061144,-0.495857,0.07084,0.074144,-0.496522,0.071954,0.061144,-0.495857,0.07084,0.074144,-0.496522,0.071954,0.074144,-0.495857,0.07084,0.061144,-0.494986,0.06991,0.061144,-0.494986,0.06991,0.074144,-0.495857,0.07084,0.061144,-0.494986,0.06991,0.074144,-0.495857,0.07084,0.074144,-0.494986,0.06991,0.061144,-0.493942,0.069201,0.061144,-0.493942,0.069201,0.074144,-0.494986,0.06991,0.074144,-0.493942,0.069201,0.061144,-0.492758,0.06875,0.061144,-0.492758,0.06875,0.074144,-0.493942,0.069201,0.074144,-0.492758,0.06875,0.061144,-0.49147,0.068591,0.061144,-0.49147,0.068591,0.074144,-0.492758,0.06875,0.061144,-0.49147,0.068591,0.074144,-0.492758,0.06875,0.074144,-0.49147,0.068591,0.061144,-0.445041,0.068591,0.061144,-0.445041,0.068591,0.074144,-0.49147,0.068591,0.061144,-0.445041,0.068591,0.074144,-0.49147,0.068591,0.074144,-0.445041,0.068591,0.061144,-0.443752,0.06875,0.061144,-0.443752,0.06875,0.074144,-0.445041,0.068591,0.074144,-0.443752,0.06875,0.061144,-0.442569,0.069201,0.061144,-0.442569,0.069201,0.074144,-0.443752,0.06875,0.074144,-0.442569,0.069201,0.061144,-0.441525,0.06991,0.061144,-0.441525,0.06991,0.074144,-0.442569,0.069201,0.074144,-0.441525,0.06991,0.061144,-0.440653,0.07084,0.061144,-0.440653,0.07084,0.074144,-0.441525,0.06991,0.074144,-0.440653,0.07084,0.061144,-0.439989,0.071954,0.061144,-0.439989,0.071954,0.074144,-0.440653,0.07084,0.074144,-0.439989,0.071954,0.061144,-0.439566,0.073216,0.061144,-0.439566,0.073216,0.074144,-0.439989,0.071954,0.074144,-0.439566,0.073216,0.061144,-0.439417,0.074591,0.061144,-0.439417,0.074591,0.074144,-0.439566,0.073216,0.074144,-0.439417,0.074591,0.061144,-0.439417,0.119739,0.061144,-0.439417,0.119739,0.074144,-0.439417,0.074591,0.074144,-0.439417,0.119739,0.061144,-0.439566,0.121114,0.061144,-0.439566,0.121114,0.074144,-0.439417,0.119739,0.074144,-0.439566,0.121114,0.061144,-0.439989,0.122376,0.061144,-0.439989,0.122376,0.074144,-0.439566,0.121114,0.074144,-0.439989,0.122376,0.061144,-0.440653,0.12349,0.061144,-0.440653,0.12349,0.074144,-0.439989,0.122376,0.074144,-0.440653,0.12349,0.061144,-0.441525,0.12442,0.061144,-0.441525,0.12442,0.074144,-0.440653,0.12349,0.074144,-0.441525,0.12442,0.061144,-0.442569,0.125129,0.061144,-0.442569,0.125129,0.074144,-0.441525,0.12442,0.074144,-0.442569,0.125129,0.061144,-0.443752,0.12558,0.061144,-0.443752,0.12558,0.074144,-0.442569,0.125129,0.074144,-0.443752,0.12558,0.061144,-0.445041,0.125739,0.061144,-0.445041,0.125739,0.074144,-0.443752,0.12558,0.074144,-0.371391,0.125739,0.061144,-0.41782,0.125739,0.061144,-0.41782,0.125739,0.074144,-0.371391,0.125739,0.074144,-0.41782,0.125739,0.061144,-0.419108,0.12558,0.061144,-0.419108,0.12558,0.074144,-0.41782,0.125739,0.074144,-0.419108,0.12558,0.061144,-0.420292,0.125129,0.061144,-0.420292,0.125129,0.074144,-0.419108,0.12558,0.074144,-0.420292,0.125129,0.061144,-0.421336,0.12442,0.061144,-0.421336,0.12442,0.074144,-0.420292,0.125129,0.074144,-0.421336,0.12442,0.061144,-0.422207,0.12349,0.061144,-0.422207,0.12349,0.074144,-0.421336,0.12442,0.074144,-0.422207,0.12349,0.061144,-0.422872,0.122376,0.061144,-0.422872,0.122376,0.074144,-0.422207,0.12349,0.074144,-0.422872,0.122376,0.061144,-0.423295,0.121114,0.061144,-0.423295,0.121114,0.074144,-0.422872,0.122376,0.074144,-0.423295,0.121114,0.061144,-0.423444,0.119739,0.061144,-0.423444,0.119739,0.074144,-0.423295,0.121114,0.074144,-0.423444,0.119739,0.061144,-0.423444,0.074591,0.061144,-0.423444,0.074591,0.074144,-0.423444,0.119739,0.074144,-0.423444,0.074591,0.061144,-0.423295,0.073216,0.061144,-0.423295,0.073216,0.074144,-0.423444,0.074591,0.061144,-0.423295,0.073216,0.074144,-0.423444,0.074591,0.074144,-0.423295,0.073216,0.061144,-0.422872,0.071954,0.061144,-0.422872,0.071954,0.074144,-0.423295,0.073216,0.061144,-0.422872,0.071954,0.074144,-0.423295,0.073216,0.074144,-0.422872,0.071954,0.061144,-0.422207,0.07084,0.061144,-0.422207,0.07084,0.074144,-0.422872,0.071954,0.074144,-0.422207,0.07084,0.061144,-0.421336,0.06991,0.061144,-0.421336,0.06991,0.074144,-0.422207,0.07084,0.061144,-0.421336,0.06991,0.074144,-0.422207,0.07084,0.074144,-0.421336,0.06991,0.061144,-0.420292,0.069201,0.061144,-0.420292,0.069201,0.074144,-0.421336,0.06991,0.061144,-0.420292,0.069201,0.074144,-0.421336,0.06991,0.074144,-0.420292,0.069201,0.061144,-0.419108,0.06875,0.061144,-0.419108,0.06875,0.074144,-0.420292,0.069201,0.074144,-0.419108,0.06875,0.061144,-0.41782,0.068591,0.061144,-0.41782,0.068591,0.074144,-0.419108,0.06875,0.061144,-0.41782,0.068591,0.074144,-0.419108,0.06875,0.074144,-0.41782,0.068591,0.061144,-0.371391,0.068591,0.061144,-0.371391,0.068591,0.074144,-0.41782,0.068591,0.061144,-0.371391,0.068591,0.074144,-0.41782,0.068591,0.074144,-0.371391,0.068591,0.061144,-0.370102,0.06875,0.061144,-0.370102,0.06875,0.074144,-0.371391,0.068591,0.074144,-0.370102,0.06875,0.061144,-0.368919,0.069201,0.061144,-0.368919,0.069201,0.074144,-0.370102,0.06875,0.061144,-0.368919,0.069201,0.074144,-0.370102,0.06875,0.074144,-0.368919,0.069201,0.061144,-0.367874,0.06991,0.061144,-0.367874,0.06991,0.074144,-0.368919,0.069201,0.061144,-0.367874,0.06991,0.074144,-0.368919,0.069201,0.074144,-0.367874,0.06991,0.061144,-0.367003,0.07084,0.061144,-0.367003,0.07084,0.074144,-0.367874,0.06991,0.061144,-0.367003,0.07084,0.074144,-0.367874,0.06991,0.074144,-0.367003,0.07084,0.061144,-0.366339,0.071954,0.061144,-0.366339,0.071954,0.074144,-0.367003,0.07084,0.061144,-0.366339,0.071954,0.074144,-0.367003,0.07084,0.074144,-0.366339,0.071954,0.061144,-0.365915,0.073216,0.061144,-0.365915,0.073216,0.074144,-0.366339,0.071954,0.074144,-0.365915,0.073216,0.061144,-0.365767,0.074591,0.061144,-0.365767,0.074591,0.074144,-0.365915,0.073216,0.074144,-0.365767,0.074591,0.061144,-0.365767,0.119739,0.061144,-0.365767,0.119739,0.074144,-0.365767,0.074591,0.074144,-0.365767,0.119739,0.061144,-0.365915,0.121114,0.061144,-0.365915,0.121114,0.074144,-0.365767,0.119739,0.074144,-0.365915,0.121114,0.061144,-0.366339,0.122376,0.061144,-0.366339,0.122376,0.074144,-0.365915,0.121114,0.074144,-0.366339,0.122376,0.061144,-0.367003,0.12349,0.061144,-0.367003,0.12349,0.074144,-0.366339,0.122376,0.074144,-0.367003,0.12349,0.061144,-0.367874,0.12442,0.061144,-0.367874,0.12442,0.074144,-0.367003,0.12349,0.074144,-0.367874,0.12442,0.061144,-0.368919,0.125129,0.061144,-0.368919,0.125129,0.074144,-0.367874,0.12442,0.061144,-0.368919,0.125129,0.074144,-0.367874,0.12442,0.074144,-0.368919,0.125129,0.061144,-0.370102,0.12558,0.061144,-0.370102,0.12558,0.074144,-0.368919,0.125129,0.061144,-0.370102,0.12558,0.074144,-0.368919,0.125129,0.074144,-0.370102,0.12558,0.061144,-0.371391,0.125739,0.061144,-0.371391,0.125739,0.074144,-0.370102,0.12558,0.074144,-0.297741,0.125739,0.061144,-0.344169,0.125739,0.061144,-0.344169,0.125739,0.074144,-0.297741,0.125739,0.074144,-0.344169,0.125739,0.061144,-0.345458,0.12558,0.061144,-0.345458,0.12558,0.074144,-0.344169,0.125739,0.074144,-0.345458,0.12558,0.061144,-0.346642,0.125129,0.061144,-0.346642,0.125129,0.074144,-0.345458,0.12558,0.061144,-0.346642,0.125129,0.074144,-0.345458,0.12558,0.074144,-0.346642,0.125129,0.061144,-0.347686,0.12442,0.061144,-0.347686,0.12442,0.074144,-0.346642,0.125129,0.061144,-0.347686,0.12442,0.074144,-0.346642,0.125129,0.074144,-0.347686,0.12442,0.061144,-0.348557,0.12349,0.061144,-0.348557,0.12349,0.074144,-0.347686,0.12442,0.074144,-0.348557,0.12349,0.061144,-0.349221,0.122376,0.061144,-0.349221,0.122376,0.074144,-0.348557,0.12349,0.061144,-0.349221,0.122376,0.074144,-0.348557,0.12349,0.074144,-0.349221,0.122376,0.061144,-0.349645,0.121114,0.061144,-0.349645,0.121114,0.074144,-0.349221,0.122376,0.061144,-0.349645,0.121114,0.074144,-0.349221,0.122376,0.074144,-0.349645,0.121114,0.061144,-0.349794,0.119739,0.061144,-0.349794,0.119739,0.074144,-0.349645,0.121114,0.074144,-0.349794,0.119739,0.061144,-0.349794,0.074591,0.061144,-0.349794,0.074591,0.074144,-0.349794,0.119739,0.074144,-0.349794,0.074591,0.061144,-0.349645,0.073216,0.061144,-0.349645,0.073216,0.074144,-0.349794,0.074591,0.074144,-0.349645,0.073216,0.061144,-0.349221,0.071954,0.061144,-0.349221,0.071954,0.074144,-0.349645,0.073216,0.074144,-0.349221,0.071954,0.061144,-0.348557,0.07084,0.061144,-0.348557,0.07084,0.074144,-0.349221,0.071954,0.074144,-0.348557,0.07084,0.061144,-0.347686,0.06991,0.061144,-0.347686,0.06991,0.074144,-0.348557,0.07084,0.074144,-0.347686,0.06991,0.061144,-0.346642,0.069201,0.061144,-0.346642,0.069201,0.074144,-0.347686,0.06991,0.061144,-0.346642,0.069201,0.074144,-0.347686,0.06991,0.074144,-0.346642,0.069201,0.061144,-0.345458,0.06875,0.061144,-0.345458,0.06875,0.074144,-0.346642,0.069201,0.074144,-0.345458,0.06875,0.061144,-0.344169,0.068591,0.061144,-0.344169,0.068591,0.074144,-0.345458,0.06875,0.061144,-0.344169,0.068591,0.074144,-0.345458,0.06875,0.074144,-0.344169,0.068591,0.061144,-0.297741,0.068591,0.061144,-0.297741,0.068591,0.074144,-0.344169,0.068591,0.061144,-0.297741,0.068591,0.074144,-0.344169,0.068591,0.074144,-0.297741,0.068591,0.061144,-0.296452,0.06875,0.061144,-0.296452,0.06875,0.074144,-0.297741,0.068591,0.061144,-0.296452,0.06875,0.074144,-0.297741,0.068591,0.074144,-0.296452,0.06875,0.061144,-0.295269,0.069201,0.061144,-0.295269,0.069201,0.074144,-0.296452,0.06875,0.074144,-0.295269,0.069201,0.061144,-0.294224,0.06991,0.061144,-0.294224,0.06991,0.074144,-0.295269,0.069201,0.061144,-0.294224,0.06991,0.074144,-0.295269,0.069201,0.074144,-0.294224,0.06991,0.061144,-0.293353,0.07084,0.061144,-0.293353,0.07084,0.074144,-0.294224,0.06991,0.061144,-0.293353,0.07084,0.074144,-0.294224,0.06991,0.074144,-0.293353,0.07084,0.061144,-0.292689,0.071954,0.061144,-0.292689,0.071954,0.074144,-0.293353,0.07084,0.061144,-0.292689,0.071954,0.074144,-0.293353,0.07084,0.074144,-0.292689,0.071954,0.061144,-0.292265,0.073216,0.061144,-0.292265,0.073216,0.074144,-0.292689,0.071954,0.074144,-0.292265,0.073216,0.061144,-0.292117,0.074591,0.061144,-0.292117,0.074591,0.074144,-0.292265,0.073216,0.061144,-0.292117,0.074591,0.074144,-0.292265,0.073216,0.074144,-0.292117,0.074591,0.061144,-0.292117,0.119739,0.061144,-0.292117,0.119739,0.074144,-0.292117,0.074591,0.074144,-0.292117,0.119739,0.061144,-0.292265,0.121114,0.061144,-0.292265,0.121114,0.074144,-0.292117,0.119739,0.074144,-0.292265,0.121114,0.061144,-0.292689,0.122376,0.061144,-0.292689,0.122376,0.074144,-0.292265,0.121114,0.074144,-0.292689,0.122376,0.061144,-0.293353,0.12349,0.061144,-0.293353,0.12349,0.074144,-0.292689,0.122376,0.074144,-0.293353,0.12349,0.061144,-0.294224,0.12442,0.061144,-0.294224,0.12442,0.074144,-0.293353,0.12349,0.074144,-0.294224,0.12442,0.061144,-0.295269,0.125129,0.061144,-0.295269,0.125129,0.074144,-0.294224,0.12442,0.074144,-0.295269,0.125129,0.061144,-0.296452,0.12558,0.061144,-0.296452,0.12558,0.074144,-0.295269,0.125129,0.074144,-0.296452,0.12558,0.061144,-0.297741,0.125739,0.061144,-0.297741,0.125739,0.074144,-0.296452,0.12558,0.074144,-0.224091,0.125739,0.061144,-0.270519,0.125739,0.061144,-0.270519,0.125739,0.074144,-0.224091,0.125739,0.061144,-0.270519,0.125739,0.074144,-0.224091,0.125739,0.074144,-0.270519,0.125739,0.061144,-0.271808,0.12558,0.061144,-0.271808,0.12558,0.074144,-0.270519,0.125739,0.061144,-0.271808,0.12558,0.074144,-0.270519,0.125739,0.074144,-0.271808,0.12558,0.061144,-0.272991,0.125129,0.061144,-0.272991,0.125129,0.074144,-0.271808,0.12558,0.074144,-0.272991,0.125129,0.061144,-0.274036,0.12442,0.061144,-0.274036,0.12442,0.074144,-0.272991,0.125129,0.061144,-0.274036,0.12442,0.074144,-0.272991,0.125129,0.074144,-0.274036,0.12442,0.061144,-0.274907,0.12349,0.061144,-0.274907,0.12349,0.074144,-0.274036,0.12442,0.074144,-0.274907,0.12349,0.061144,-0.275571,0.122376,0.061144,-0.275571,0.122376,0.074144,-0.274907,0.12349,0.074144,-0.275571,0.122376,0.061144,-0.275995,0.121114,0.061144,-0.275995,0.121114,0.074144,-0.275571,0.122376,0.061144,-0.275995,0.121114,0.074144,-0.275571,0.122376,0.074144,-0.275995,0.121114,0.061144,-0.276143,0.119739,0.061144,-0.276143,0.119739,0.074144,-0.275995,0.121114,0.061144,-0.276143,0.119739,0.074144,-0.275995,0.121114,0.074144,-0.276143,0.119739,0.061144,-0.276143,0.074591,0.061144,-0.276143,0.074591,0.074144,-0.276143,0.119739,0.074144,-0.276143,0.074591,0.061144,-0.275995,0.073216,0.061144,-0.275995,0.073216,0.074144,-0.276143,0.074591,0.061144,-0.275995,0.073216,0.074144,-0.276143,0.074591,0.074144,-0.275995,0.073216,0.061144,-0.275571,0.071954,0.061144,-0.275571,0.071954,0.074144,-0.275995,0.073216,0.074144,-0.275571,0.071954,0.061144,-0.274907,0.07084,0.061144,-0.274907,0.07084,0.074144,-0.275571,0.071954,0.074144,-0.274907,0.07084,0.061144,-0.274036,0.06991,0.061144,-0.274036,0.06991,0.074144,-0.274907,0.07084,0.061144,-0.274036,0.06991,0.074144,-0.274907,0.07084,0.074144,-0.274036,0.06991,0.061144,-0.272991,0.069201,0.061144,-0.272991,0.069201,0.074144,-0.274036,0.06991,0.074144,-0.272991,0.069201,0.061144,-0.271808,0.06875,0.061144,-0.271808,0.06875,0.074144,-0.272991,0.069201,0.074144,-0.271808,0.06875,0.061144,-0.270519,0.068591,0.061144,-0.270519,0.068591,0.074144,-0.271808,0.06875,0.074144,-0.270519,0.068591,0.061144,-0.224091,0.068591,0.061144,-0.224091,0.068591,0.074144,-0.270519,0.068591,0.074144,-0.224091,0.068591,0.061144,-0.222802,0.06875,0.061144,-0.222802,0.06875,0.074144,-0.224091,0.068591,0.074144,-0.222802,0.06875,0.061144,-0.221618,0.069201,0.061144,-0.221618,0.069201,0.074144,-0.222802,0.06875,0.074144,-0.221618,0.069201,0.061144,-0.220574,0.06991,0.061144,-0.220574,0.06991,0.074144,-0.221618,0.069201,0.074144,-0.220574,0.06991,0.061144,-0.219703,0.07084,0.061144,-0.219703,0.07084,0.074144,-0.220574,0.06991,0.074144,-0.219703,0.07084,0.061144,-0.219039,0.071954,0.061144,-0.219039,0.071954,0.074144,-0.219703,0.07084,0.074144,-0.219039,0.071954,0.061144,-0.218615,0.073216,0.061144,-0.218615,0.073216,0.074144,-0.219039,0.071954,0.074144,-0.218615,0.073216,0.061144,-0.218466,0.074591,0.061144,-0.218466,0.074591,0.074144,-0.218615,0.073216,0.061144,-0.218466,0.074591,0.074144,-0.218615,0.073216,0.074144,-0.218466,0.074591,0.061144,-0.218466,0.119739,0.061144,-0.218466,0.119739,0.074144,-0.218466,0.074591,0.074144,-0.218466,0.119739,0.061144,-0.218615,0.121114,0.061144,-0.218615,0.121114,0.074144,-0.218466,0.119739,0.074144,-0.218615,0.121114,0.061144,-0.219039,0.122376,0.061144,-0.219039,0.122376,0.074144,-0.218615,0.121114,0.074144,-0.219039,0.122376,0.061144,-0.219703,0.12349,0.061144,-0.219703,0.12349,0.074144,-0.219039,0.122376,0.074144,-0.219703,0.12349,0.061144,-0.220574,0.12442,0.061144,-0.220574,0.12442,0.074144,-0.219703,0.12349,0.074144,-0.220574,0.12442,0.061144,-0.221618,0.125129,0.061144,-0.221618,0.125129,0.074144,-0.220574,0.12442,0.074144,-0.221618,0.125129,0.061144,-0.222802,0.12558,0.061144,-0.222802,0.12558,0.074144,-0.221618,0.125129,0.074144,-0.222802,0.12558,0.061144,-0.224091,0.125739,0.061144,-0.224091,0.125739,0.074144,-0.222802,0.12558,0.074144,-0.15044,0.125739,0.061144,-0.196869,0.125739,0.061144,-0.196869,0.125739,0.074144,-0.15044,0.125739,0.074144,-0.196869,0.125739,0.061144,-0.198158,0.12558,0.061144,-0.198158,0.12558,0.074144,-0.196869,0.125739,0.061144,-0.198158,0.12558,0.074144,-0.196869,0.125739,0.074144,-0.198158,0.12558,0.061144,-0.199341,0.125129,0.061144,-0.199341,0.125129,0.074144,-0.198158,0.12558,0.074144,-0.199341,0.125129,0.061144,-0.200386,0.12442,0.061144,-0.200386,0.12442,0.074144,-0.199341,0.125129,0.061144,-0.200386,0.12442,0.074144,-0.199341,0.125129,0.074144,-0.200386,0.12442,0.061144,-0.201257,0.12349,0.061144,-0.201257,0.12349,0.074144,-0.200386,0.12442,0.074144,-0.201257,0.12349,0.061144,-0.201921,0.122376,0.061144,-0.201921,0.122376,0.074144,-0.201257,0.12349,0.074144,-0.201921,0.122376,0.061144,-0.202345,0.121114,0.061144,-0.202345,0.121114,0.074144,-0.201921,0.122376,0.074144,-0.202345,0.121114,0.061144,-0.202493,0.119739,0.061144,-0.202493,0.119739,0.074144,-0.202345,0.121114,0.074144,-0.202493,0.119739,0.061144,-0.202493,0.074591,0.061144,-0.202493,0.074591,0.074144,-0.202493,0.119739,0.074144,-0.202493,0.074591,0.061144,-0.202345,0.073216,0.061144,-0.202345,0.073216,0.074144,-0.202493,0.074591,0.074144,-0.202345,0.073216,0.061144,-0.201921,0.071954,0.061144,-0.201921,0.071954,0.074144,-0.202345,0.073216,0.074144,-0.201921,0.071954,0.061144,-0.201257,0.07084,0.061144,-0.201257,0.07084,0.074144,-0.201921,0.071954,0.074144,-0.201257,0.07084,0.061144,-0.200386,0.06991,0.061144,-0.200386,0.06991,0.074144,-0.201257,0.07084,0.061144,-0.200386,0.06991,0.074144,-0.201257,0.07084,0.074144,-0.200386,0.06991,0.061144,-0.199341,0.069201,0.061144,-0.199341,0.069201,0.074144,-0.200386,0.06991,0.061144,-0.199341,0.069201,0.074144,-0.200386,0.06991,0.074144,-0.199341,0.069201,0.061144,-0.198158,0.06875,0.061144,-0.198158,0.06875,0.074144,-0.199341,0.069201,0.074144,-0.198158,0.06875,0.061144,-0.196869,0.068591,0.061144,-0.196869,0.068591,0.074144,-0.198158,0.06875,0.074144,-0.196869,0.068591,0.061144,-0.15044,0.068591,0.061144,-0.15044,0.068591,0.074144,-0.196869,0.068591,0.061144,-0.15044,0.068591,0.074144,-0.196869,0.068591,0.074144,-0.15044,0.068591,0.061144,-0.149152,0.06875,0.061144,-0.149152,0.06875,0.074144,-0.15044,0.068591,0.061144,-0.149152,0.06875,0.074144,-0.15044,0.068591,0.074144,-0.149152,0.06875,0.061144,-0.147968,0.069201,0.061144,-0.147968,0.069201,0.074144,-0.149152,0.06875,0.061144,-0.147968,0.069201,0.074144,-0.149152,0.06875,0.074144,-0.147968,0.069201,0.061144,-0.146924,0.06991,0.061144,-0.146924,0.06991,0.074144,-0.147968,0.069201,0.061144,-0.146924,0.06991,0.074144,-0.147968,0.069201,0.074144,-0.146924,0.06991,0.061144,-0.146053,0.07084,0.061144,-0.146053,0.07084,0.074144,-0.146924,0.06991,0.061144,-0.146053,0.07084,0.074144,-0.146924,0.06991,0.074144,-0.146053,0.07084,0.061144,-0.145388,0.071954,0.061144,-0.145388,0.071954,0.074144,-0.146053,0.07084,0.074144,-0.145388,0.071954,0.061144,-0.144965,0.073216,0.061144,-0.144965,0.073216,0.074144,-0.145388,0.071954,0.061144,-0.144965,0.073216,0.074144,-0.145388,0.071954,0.074144,-0.144965,0.073216,0.061144,-0.144816,0.074591,0.061144,-0.144816,0.074591,0.074144,-0.144965,0.073216,0.074144,-0.144816,0.074591,0.061144,-0.144816,0.119739,0.061144,-0.144816,0.119739,0.074144,-0.144816,0.074591,0.074144,-0.144816,0.119739,0.061144,-0.144965,0.121114,0.061144,-0.144965,0.121114,0.074144,-0.144816,0.119739,0.061144,-0.144965,0.121114,0.074144,-0.144816,0.119739,0.074144,-0.144965,0.121114,0.061144,-0.145388,0.122376,0.061144,-0.145388,0.122376,0.074144,-0.144965,0.121114,0.061144,-0.145388,0.122376,0.074144,-0.144965,0.121114,0.074144,-0.145388,0.122376,0.061144,-0.146053,0.12349,0.061144,-0.146053,0.12349,0.074144,-0.145388,0.122376,0.061144,-0.146053,0.12349,0.074144,-0.145388,0.122376,0.074144,-0.146053,0.12349,0.061144,-0.146924,0.12442,0.061144,-0.146924,0.12442,0.074144,-0.146053,0.12349,0.074144,-0.146924,0.12442,0.061144,-0.147968,0.125129,0.061144,-0.147968,0.125129,0.074144,-0.146924,0.12442,0.061144,-0.147968,0.125129,0.074144,-0.146924,0.12442,0.074144,-0.147968,0.125129,0.061144,-0.149152,0.12558,0.061144,-0.149152,0.12558,0.074144,-0.147968,0.125129,0.061144,-0.149152,0.12558,0.074144,-0.147968,0.125129,0.074144,-0.149152,0.12558,0.061144,-0.15044,0.125739,0.061144,-0.15044,0.125739,0.074144,-0.149152,0.12558,0.074144,-0.07679,0.125739,0.061144,-0.123219,0.125739,0.061144,-0.123219,0.125739,0.074144,-0.07679,0.125739,0.074144,-0.123219,0.125739,0.061144,-0.124508,0.12558,0.061144,-0.124508,0.12558,0.074144,-0.123219,0.125739,0.074144,-0.124508,0.12558,0.061144,-0.125691,0.125129,0.061144,-0.125691,0.125129,0.074144,-0.124508,0.12558,0.074144,-0.125691,0.125129,0.061144,-0.126735,0.12442,0.061144,-0.126735,0.12442,0.074144,-0.125691,0.125129,0.074144,-0.126735,0.12442,0.061144,-0.127607,0.12349,0.061144,-0.127607,0.12349,0.074144,-0.126735,0.12442,0.074144,-0.127607,0.12349,0.061144,-0.128271,0.122376,0.061144,-0.128271,0.122376,0.074144,-0.127607,0.12349,0.074144,-0.128271,0.122376,0.061144,-0.128694,0.121114,0.061144,-0.128694,0.121114,0.074144,-0.128271,0.122376,0.074144,-0.128694,0.121114,0.061144,-0.128843,0.119739,0.061144,-0.128843,0.119739,0.074144,-0.128694,0.121114,0.074144,-0.128843,0.119739,0.061144,-0.128843,0.074591,0.061144,-0.128843,0.074591,0.074144,-0.128843,0.119739,0.074144,-0.128843,0.074591,0.061144,-0.128694,0.073216,0.061144,-0.128694,0.073216,0.074144,-0.128843,0.074591,0.074144,-0.128694,0.073216,0.061144,-0.128271,0.071954,0.061144,-0.128271,0.071954,0.074144,-0.128694,0.073216,0.074144,-0.128271,0.071954,0.061144,-0.127607,0.07084,0.061144,-0.127607,0.07084,0.074144,-0.128271,0.071954,0.061144,-0.127607,0.07084,0.074144,-0.128271,0.071954,0.074144,-0.127607,0.07084,0.061144,-0.126735,0.06991,0.061144,-0.126735,0.06991,0.074144,-0.127607,0.07084,0.061144,-0.126735,0.06991,0.074144,-0.127607,0.07084,0.074144,-0.126735,0.06991,0.061144,-0.125691,0.069201,0.061144,-0.125691,0.069201,0.074144,-0.126735,0.06991,0.061144,-0.125691,0.069201,0.074144,-0.126735,0.06991,0.074144,-0.125691,0.069201,0.061144,-0.124508,0.06875,0.061144,-0.124508,0.06875,0.074144,-0.125691,0.069201,0.074144,-0.124508,0.06875,0.061144,-0.123219,0.068591,0.061144,-0.123219,0.068591,0.074144,-0.124508,0.06875,0.061144,-0.123219,0.068591,0.074144,-0.124508,0.06875,0.074144,-0.123219,0.068591,0.061144,-0.07679,0.068591,0.061144,-0.07679,0.068591,0.074144,-0.123219,0.068591,0.074144,-0.07679,0.068591,0.061144,-0.075502,0.06875,0.061144,-0.075502,0.06875,0.074144,-0.07679,0.068591,0.074144,-0.075502,0.06875,0.061144,-0.074318,0.069201,0.061144,-0.074318,0.069201,0.074144,-0.075502,0.06875,0.074144,-0.074318,0.069201,0.061144,-0.073274,0.06991,0.061144,-0.073274,0.06991,0.074144,-0.074318,0.069201,0.061144,-0.073274,0.06991,0.074144,-0.074318,0.069201,0.074144,-0.073274,0.06991,0.061144,-0.072403,0.07084,0.061144,-0.072403,0.07084,0.074144,-0.073274,0.06991,0.061144,-0.072403,0.07084,0.074144,-0.073274,0.06991,0.074144,-0.072403,0.07084,0.061144,-0.071738,0.071954,0.061144,-0.071738,0.071954,0.074144,-0.072403,0.07084,0.061144,-0.071738,0.071954,0.074144,-0.072403,0.07084,0.074144,-0.071738,0.071954,0.061144,-0.071315,0.073216,0.061144,-0.071315,0.073216,0.074144,-0.071738,0.071954,0.061144,-0.071315,0.073216,0.074144,-0.071738,0.071954,0.074144,-0.071315,0.073216,0.061144,-0.071166,0.074591,0.061144,-0.071166,0.074591,0.074144,-0.071315,0.073216,0.074144,-0.071166,0.074591,0.061144,-0.071166,0.119739,0.061144,-0.071166,0.119739,0.074144,-0.071166,0.074591,0.074144,-0.071166,0.119739,0.061144,-0.071315,0.121114,0.061144,-0.071315,0.121114,0.074144,-0.071166,0.119739,0.074144,-0.071315,0.121114,0.061144,-0.071738,0.122376,0.061144,-0.071738,0.122376,0.074144,-0.071315,0.121114,0.074144,-0.071738,0.122376,0.061144,-0.072403,0.12349,0.061144,-0.072403,0.12349,0.074144,-0.071738,0.122376,0.074144,-0.072403,0.12349,0.061144,-0.073274,0.12442,0.061144,-0.073274,0.12442,0.074144,-0.072403,0.12349,0.074144,-0.073274,0.12442,0.061144,-0.074318,0.125129,0.061144,-0.074318,0.125129,0.074144,-0.073274,0.12442,0.061144,-0.074318,0.125129,0.074144,-0.073274,0.12442,0.074144,-0.074318,0.125129,0.061144,-0.075502,0.12558,0.061144,-0.075502,0.12558,0.074144,-0.074318,0.125129,0.074144,-0.075502,0.12558,0.061144,-0.07679,0.125739,0.061144,-0.07679,0.125739,0.074144,-0.075502,0.12558,0.074144,-0.00314,0.125739,0.061144,-0.049569,0.125739,0.061144,-0.049569,0.125739,0.074144,-0.00314,0.125739,0.061144,-0.049569,0.125739,0.074144,-0.00314,0.125739,0.074144,-0.049569,0.125739,0.061144,-0.050858,0.12558,0.061144,-0.050858,0.12558,0.074144,-0.049569,0.125739,0.074144,-0.050858,0.12558,0.061144,-0.052041,0.125129,0.061144,-0.052041,0.125129,0.074144,-0.050858,0.12558,0.074144,-0.052041,0.125129,0.061144,-0.053085,0.12442,0.061144,-0.053085,0.12442,0.074144,-0.052041,0.125129,0.074144,-0.053085,0.12442,0.061144,-0.053957,0.12349,0.061144,-0.053957,0.12349,0.074144,-0.053085,0.12442,0.074144,-0.053957,0.12349,0.061144,-0.054621,0.122376,0.061144,-0.054621,0.122376,0.074144,-0.053957,0.12349,0.061144,-0.054621,0.122376,0.074144,-0.053957,0.12349,0.074144,-0.054621,0.122376,0.061144,-0.055044,0.121114,0.061144,-0.055044,0.121114,0.074144,-0.054621,0.122376,0.061144,-0.055044,0.121114,0.074144,-0.054621,0.122376,0.074144,-0.055044,0.121114,0.061144,-0.055193,0.119739,0.061144,-0.055193,0.119739,0.074144,-0.055044,0.121114,0.074144,-0.055193,0.119739,0.061144,-0.055193,0.074591,0.061144,-0.055193,0.074591,0.074144,-0.055193,0.119739,0.074144,-0.055193,0.074591,0.061144,-0.055044,0.073216,0.061144,-0.055044,0.073216,0.074144,-0.055193,0.074591,0.074144,-0.055044,0.073216,0.061144,-0.054621,0.071954,0.061144,-0.054621,0.071954,0.074144,-0.055044,0.073216,0.074144,-0.054621,0.071954,0.061144,-0.053957,0.07084,0.061144,-0.053957,0.07084,0.074144,-0.054621,0.071954,0.061144,-0.053957,0.07084,0.074144,-0.054621,0.071954,0.074144,-0.053957,0.07084,0.061144,-0.053085,0.06991,0.061144,-0.053085,0.06991,0.074144,-0.053957,0.07084,0.074144,-0.053085,0.06991,0.061144,-0.052041,0.069201,0.061144,-0.052041,0.069201,0.074144,-0.053085,0.06991,0.074144,-0.052041,0.069201,0.061144,-0.050858,0.06875,0.061144,-0.050858,0.06875,0.074144,-0.052041,0.069201,0.074144,-0.050858,0.06875,0.061144,-0.049569,0.068591,0.061144,-0.049569,0.068591,0.074144,-0.050858,0.06875,0.061144,-0.049569,0.068591,0.074144,-0.050858,0.06875,0.074144,-0.049569,0.068591,0.061144,-0.00314,0.068591,0.061144,-0.00314,0.068591,0.074144,-0.049569,0.068591,0.061144,-0.00314,0.068591,0.074144,-0.049569,0.068591,0.074144,-0.00314,0.068591,0.061144,-0.001851,0.06875,0.061144,-0.001851,0.06875,0.074144,-0.00314,0.068591,0.061144,-0.001851,0.06875,0.074144,-0.00314,0.068591,0.074144,-0.001851,0.06875,0.061144,-0.000668,0.069201,0.061144,-0.000668,0.069201,0.074144,-0.001851,0.06875,0.061144,-0.000668,0.069201,0.074144,-0.001851,0.06875,0.074144,-0.000668,0.069201,0.061144,0.000376,0.06991,0.061144,0.000376,0.06991,0.074144,-0.000668,0.069201,0.074144,0.000376,0.06991,0.061144,0.001248,0.07084,0.061144,0.001248,0.07084,0.074144,0.000376,0.06991,0.074144,0.001248,0.07084,0.061144,0.001912,0.071954,0.061144,0.001912,0.071954,0.074144,0.001248,0.07084,0.074144,0.001912,0.071954,0.061144,0.002335,0.073216,0.061144,0.002335,0.073216,0.074144,0.001912,0.071954,0.074144,0.002335,0.073216,0.061144,0.002484,0.074591,0.061144,0.002484,0.074591,0.074144,0.002335,0.073216,0.061144,0.002484,0.074591,0.074144,0.002335,0.073216,0.074144,0.002484,0.074591,0.061144,0.002484,0.119739,0.061144,0.002484,0.119739,0.074144,0.002484,0.074591,0.074144,0.002484,0.119739,0.061144,0.002335,0.121114,0.061144,0.002335,0.121114,0.074144,0.002484,0.119739,0.074144,0.002335,0.121114,0.061144,0.001912,0.122376,0.061144,0.001912,0.122376,0.074144,0.002335,0.121114,0.074144,0.001912,0.122376,0.061144,0.001248,0.12349,0.061144,0.001248,0.12349,0.074144,0.001912,0.122376,0.074144,0.001248,0.12349,0.061144,0.000376,0.12442,0.061144,0.000376,0.12442,0.074144,0.001248,0.12349,0.074144,0.000376,0.12442,0.061144,-0.000668,0.125129,0.061144,-0.000668,0.125129,0.074144,0.000376,0.12442,0.061144,-0.000668,0.125129,0.074144,0.000376,0.12442,0.074144,-0.000668,0.125129,0.061144,-0.001851,0.12558,0.061144,-0.001851,0.12558,0.074144,-0.000668,0.125129,0.074144,-0.001851,0.12558,0.061144,-0.00314,0.125739,0.061144,-0.00314,0.125739,0.074144,-0.001851,0.12558,0.061144,-0.00314,0.125739,0.074144,-0.001851,0.12558,0.074144,0.07051,0.125739,0.061144,0.024081,0.125739,0.061144,0.024081,0.125739,0.074144,0.07051,0.125739,0.074144,0.024081,0.125739,0.061144,0.022793,0.12558,0.061144,0.022793,0.12558,0.074144,0.024081,0.125739,0.074144,0.022793,0.12558,0.061144,0.021609,0.125129,0.061144,0.021609,0.125129,0.074144,0.022793,0.12558,0.074144,0.021609,0.125129,0.061144,0.020565,0.12442,0.061144,0.020565,0.12442,0.074144,0.021609,0.125129,0.074144,0.020565,0.12442,0.061144,0.019694,0.12349,0.061144,0.019694,0.12349,0.074144,0.020565,0.12442,0.074144,0.019694,0.12349,0.061144,0.019029,0.122376,0.061144,0.019029,0.122376,0.074144,0.019694,0.12349,0.074144,0.019029,0.122376,0.061144,0.018606,0.121114,0.061144,0.018606,0.121114,0.074144,0.019029,0.122376,0.074144,0.018606,0.121114,0.061144,0.018457,0.119739,0.061144,0.018457,0.119739,0.074144,0.018606,0.121114,0.074144,0.018457,0.119739,0.061144,0.018457,0.074591,0.061144,0.018457,0.074591,0.074144,0.018457,0.119739,0.074144,0.018457,0.074591,0.061144,0.018606,0.073216,0.061144,0.018606,0.073216,0.074144,0.018457,0.074591,0.061144,0.018606,0.073216,0.074144,0.018457,0.074591,0.074144,0.018606,0.073216,0.061144,0.019029,0.071954,0.061144,0.019029,0.071954,0.074144,0.018606,0.073216,0.074144,0.019029,0.071954,0.061144,0.019694,0.07084,0.061144,0.019694,0.07084,0.074144,0.019029,0.071954,0.074144,0.019694,0.07084,0.061144,0.020565,0.06991,0.061144,0.020565,0.06991,0.074144,0.019694,0.07084,0.074144,0.020565,0.06991,0.061144,0.021609,0.069201,0.061144,0.021609,0.069201,0.074144,0.020565,0.06991,0.061144,0.021609,0.069201,0.074144,0.020565,0.06991,0.074144,0.021609,0.069201,0.061144,0.022793,0.06875,0.061144,0.022793,0.06875,0.074144,0.021609,0.069201,0.074144,0.022793,0.06875,0.061144,0.024081,0.068591,0.061144,0.024081,0.068591,0.074144,0.022793,0.06875,0.061144,0.024081,0.068591,0.074144,0.022793,0.06875,0.074144,0.024081,0.068591,0.061144,0.07051,0.068591,0.061144,0.07051,0.068591,0.074144,0.024081,0.068591,0.061144,0.07051,0.068591,0.074144,0.024081,0.068591,0.074144,0.07051,0.068591,0.061144,0.071799,0.06875,0.061144,0.071799,0.06875,0.074144,0.07051,0.068591,0.061144,0.071799,0.06875,0.074144,0.07051,0.068591,0.074144,0.071799,0.06875,0.061144,0.072982,0.069201,0.061144,0.072982,0.069201,0.074144,0.071799,0.06875,0.074144,0.072982,0.069201,0.061144,0.074026,0.06991,0.061144,0.074026,0.06991,0.074144,0.072982,0.069201,0.074144,0.074026,0.06991,0.061144,0.074898,0.07084,0.061144,0.074898,0.07084,0.074144,0.074026,0.06991,0.061144,0.074898,0.07084,0.074144,0.074026,0.06991,0.074144,0.074898,0.07084,0.061144,0.075562,0.071954,0.061144,0.075562,0.071954,0.074144,0.074898,0.07084,0.074144,0.075562,0.071954,0.061144,0.075985,0.073216,0.061144,0.075985,0.073216,0.074144,0.075562,0.071954,0.061144,0.075985,0.073216,0.074144,0.075562,0.071954,0.074144,0.075985,0.073216,0.061144,0.076134,0.074591,0.061144,0.076134,0.074591,0.074144,0.075985,0.073216,0.074144,0.076134,0.074591,0.061144,0.076134,0.119739,0.061144,0.076134,0.119739,0.074144,0.076134,0.074591,0.074144,0.076134,0.119739,0.061144,0.075985,0.121114,0.061144,0.075985,0.121114,0.074144,0.076134,0.119739,0.074144,0.075985,0.121114,0.061144,0.075562,0.122376,0.061144,0.075562,0.122376,0.074144,0.075985,0.121114,0.074144,0.075562,0.122376,0.061144,0.074898,0.12349,0.061144,0.074898,0.12349,0.074144,0.075562,0.122376,0.061144,0.074898,0.12349,0.074144,0.075562,0.122376,0.074144,0.074898,0.12349,0.061144,0.074026,0.12442,0.061144,0.074026,0.12442,0.074144,0.074898,0.12349,0.074144,0.074026,0.12442,0.061144,0.072982,0.125129,0.061144,0.072982,0.125129,0.074144,0.074026,0.12442,0.061144,0.072982,0.125129,0.074144,0.074026,0.12442,0.074144,0.072982,0.125129,0.061144,0.071799,0.12558,0.061144,0.071799,0.12558,0.074144,0.072982,0.125129,0.061144,0.071799,0.12558,0.074144,0.072982,0.125129,0.074144,0.071799,0.12558,0.061144,0.07051,0.125739,0.061144,0.07051,0.125739,0.074144,0.071799,0.12558,0.074144,0.14416,0.125739,0.061144,0.097731,0.125739,0.061144,0.097731,0.125739,0.074144,0.14416,0.125739,0.074144,0.097731,0.125739,0.061144,0.096443,0.12558,0.061144,0.096443,0.12558,0.074144,0.097731,0.125739,0.074144,0.096443,0.12558,0.061144,0.095259,0.125129,0.061144,0.095259,0.125129,0.074144,0.096443,0.12558,0.074144,0.095259,0.125129,0.061144,0.094215,0.12442,0.061144,0.094215,0.12442,0.074144,0.095259,0.125129,0.074144,0.094215,0.12442,0.061144,0.093344,0.12349,0.061144,0.093344,0.12349,0.074144,0.094215,0.12442,0.074144,0.093344,0.12349,0.061144,0.092679,0.122376,0.061144,0.092679,0.122376,0.074144,0.093344,0.12349,0.074144,0.092679,0.122376,0.061144,0.092256,0.121114,0.061144,0.092256,0.121114,0.074144,0.092679,0.122376,0.074144,0.092256,0.121114,0.061144,0.092107,0.119739,0.061144,0.092107,0.119739,0.074144,0.092256,0.121114,0.074144,0.092107,0.119739,0.061144,0.092107,0.074591,0.061144,0.092107,0.074591,0.074144,0.092107,0.119739,0.074144,0.092107,0.074591,0.061144,0.092256,0.073216,0.061144,0.092256,0.073216,0.074144,0.092107,0.074591,0.061144,0.092256,0.073216,0.074144,0.092107,0.074591,0.074144,0.092256,0.073216,0.061144,0.092679,0.071954,0.061144,0.092679,0.071954,0.074144,0.092256,0.073216,0.074144,0.092679,0.071954,0.061144,0.093344,0.07084,0.061144,0.093344,0.07084,0.074144,0.092679,0.071954,0.061144,0.093344,0.07084,0.074144,0.092679,0.071954,0.074144,0.093344,0.07084,0.061144,0.094215,0.06991,0.061144,0.094215,0.06991,0.074144,0.093344,0.07084,0.061144,0.094215,0.06991,0.074144,0.093344,0.07084,0.074144,0.094215,0.06991,0.061144,0.095259,0.069201,0.061144,0.095259,0.069201,0.074144,0.094215,0.06991,0.061144,0.095259,0.069201,0.074144,0.094215,0.06991,0.074144,0.095259,0.069201,0.061144,0.096443,0.06875,0.061144,0.096443,0.06875,0.074144,0.095259,0.069201,0.074144,0.096443,0.06875,0.061144,0.097731,0.068591,0.061144,0.097731,0.068591,0.074144,0.096443,0.06875,0.061144,0.097731,0.068591,0.074144,0.096443,0.06875,0.074144,0.097731,0.068591,0.061144,0.14416,0.068591,0.061144,0.14416,0.068591,0.074144,0.097731,0.068591,0.074144,0.14416,0.068591,0.061144,0.145449,0.06875,0.061144,0.145449,0.06875,0.074144,0.14416,0.068591,0.074144,0.145449,0.06875,0.061144,0.146632,0.069201,0.061144,0.146632,0.069201,0.074144,0.145449,0.06875,0.074144,0.146632,0.069201,0.061144,0.147677,0.06991,0.061144,0.147677,0.06991,0.074144,0.146632,0.069201,0.061144,0.147677,0.06991,0.074144,0.146632,0.069201,0.074144,0.147677,0.06991,0.061144,0.148548,0.07084,0.061144,0.148548,0.07084,0.074144,0.147677,0.06991,0.061144,0.148548,0.07084,0.074144,0.147677,0.06991,0.074144,0.148548,0.07084,0.061144,0.149212,0.071954,0.061144,0.149212,0.071954,0.074144,0.148548,0.07084,0.074144,0.149212,0.071954,0.061144,0.149636,0.073216,0.061144,0.149636,0.073216,0.074144,0.149212,0.071954,0.074144,0.149636,0.073216,0.061144,0.149784,0.074591,0.061144,0.149784,0.074591,0.074144,0.149636,0.073216,0.061144,0.149784,0.074591,0.074144,0.149636,0.073216,0.074144,0.149784,0.074591,0.061144,0.149784,0.119739,0.061144,0.149784,0.119739,0.074144,0.149784,0.074591,0.074144,0.149784,0.119739,0.061144,0.149636,0.121114,0.061144,0.149636,0.121114,0.074144,0.149784,0.119739,0.061144,0.149636,0.121114,0.074144,0.149784,0.119739,0.074144,0.149636,0.121114,0.061144,0.149212,0.122376,0.061144,0.149212,0.122376,0.074144,0.149636,0.121114,0.074144,0.149212,0.122376,0.061144,0.148548,0.12349,0.061144,0.148548,0.12349,0.074144,0.149212,0.122376,0.061144,0.148548,0.12349,0.074144,0.149212,0.122376,0.074144,0.148548,0.12349,0.061144,0.147677,0.12442,0.061144,0.147677,0.12442,0.074144,0.148548,0.12349,0.074144,0.147677,0.12442,0.061144,0.146632,0.125129,0.061144,0.146632,0.125129,0.074144,0.147677,0.12442,0.061144,0.146632,0.125129,0.074144,0.147677,0.12442,0.074144,0.146632,0.125129,0.061144,0.145449,0.12558,0.061144,0.145449,0.12558,0.074144,0.146632,0.125129,0.061144,0.145449,0.12558,0.074144,0.146632,0.125129,0.074144,0.145449,0.12558,0.061144,0.14416,0.125739,0.061144,0.14416,0.125739,0.074144,0.145449,0.12558,0.074144,0.21781,0.125739,0.061144,0.171382,0.125739,0.061144,0.171382,0.125739,0.074144,0.21781,0.125739,0.074144,0.171382,0.125739,0.061144,0.170093,0.12558,0.061144,0.170093,0.12558,0.074144,0.171382,0.125739,0.074144,0.170093,0.12558,0.061144,0.168909,0.125129,0.061144,0.168909,0.125129,0.074144,0.170093,0.12558,0.074144,0.168909,0.125129,0.061144,0.167865,0.12442,0.061144,0.167865,0.12442,0.074144,0.168909,0.125129,0.061144,0.167865,0.12442,0.074144,0.168909,0.125129,0.074144,0.167865,0.12442,0.061144,0.166994,0.12349,0.061144,0.166994,0.12349,0.074144,0.167865,0.12442,0.061144,0.166994,0.12349,0.074144,0.167865,0.12442,0.074144,0.166994,0.12349,0.061144,0.16633,0.122376,0.061144,0.16633,0.122376,0.074144,0.166994,0.12349,0.074144,0.16633,0.122376,0.061144,0.165906,0.121114,0.061144,0.165906,0.121114,0.074144,0.16633,0.122376,0.074144,0.165906,0.121114,0.061144,0.165757,0.119739,0.061144,0.165757,0.119739,0.074144,0.165906,0.121114,0.074144,0.165757,0.119739,0.061144,0.165757,0.074591,0.061144,0.165757,0.074591,0.074144,0.165757,0.119739,0.074144,0.165757,0.074591,0.061144,0.165906,0.073216,0.061144,0.165906,0.073216,0.074144,0.165757,0.074591,0.074144,0.165906,0.073216,0.061144,0.16633,0.071954,0.061144,0.16633,0.071954,0.074144,0.165906,0.073216,0.061144,0.16633,0.071954,0.074144,0.165906,0.073216,0.074144,0.16633,0.071954,0.061144,0.166994,0.07084,0.061144,0.166994,0.07084,0.074144,0.16633,0.071954,0.061144,0.166994,0.07084,0.074144,0.16633,0.071954,0.074144,0.166994,0.07084,0.061144,0.167865,0.06991,0.061144,0.167865,0.06991,0.074144,0.166994,0.07084,0.061144,0.167865,0.06991,0.074144,0.166994,0.07084,0.074144,0.167865,0.06991,0.061144,0.168909,0.069201,0.061144,0.168909,0.069201,0.074144,0.167865,0.06991,0.061144,0.168909,0.069201,0.074144,0.167865,0.06991,0.074144,0.168909,0.069201,0.061144,0.170093,0.06875,0.061144,0.170093,0.06875,0.074144,0.168909,0.069201,0.074144,0.170093,0.06875,0.061144,0.171382,0.068591,0.061144,0.171382,0.068591,0.074144,0.170093,0.06875,0.074144,0.171382,0.068591,0.061144,0.21781,0.068591,0.061144,0.21781,0.068591,0.074144,0.171382,0.068591,0.074144,0.21781,0.068591,0.061144,0.219099,0.06875,0.061144,0.219099,0.06875,0.074144,0.21781,0.068591,0.061144,0.219099,0.06875,0.074144,0.21781,0.068591,0.074144,0.219099,0.06875,0.061144,0.220282,0.069201,0.061144,0.220282,0.069201,0.074144,0.219099,0.06875,0.061144,0.220282,0.069201,0.074144,0.219099,0.06875,0.074144,0.220282,0.069201,0.061144,0.221327,0.06991,0.061144,0.221327,0.06991,0.074144,0.220282,0.069201,0.074144,0.221327,0.06991,0.061144,0.222198,0.07084,0.061144,0.222198,0.07084,0.074144,0.221327,0.06991,0.074144,0.222198,0.07084,0.061144,0.222862,0.071954,0.061144,0.222862,0.071954,0.074144,0.222198,0.07084,0.074144,0.222862,0.071954,0.061144,0.223286,0.073216,0.061144,0.223286,0.073216,0.074144,0.222862,0.071954,0.074144,0.223286,0.073216,0.061144,0.223434,0.074591,0.061144,0.223434,0.074591,0.074144,0.223286,0.073216,0.074144,0.223434,0.074591,0.061144,0.223434,0.119739,0.061144,0.223434,0.119739,0.074144,0.223434,0.074591,0.074144,0.223434,0.119739,0.061144,0.223286,0.121114,0.061144,0.223286,0.121114,0.074144,0.223434,0.119739,0.074144,0.223286,0.121114,0.061144,0.222862,0.122376,0.061144,0.222862,0.122376,0.074144,0.223286,0.121114,0.074144,0.222862,0.122376,0.061144,0.222198,0.12349,0.061144,0.222198,0.12349,0.074144,0.222862,0.122376,0.074144,0.222198,0.12349,0.061144,0.221327,0.12442,0.061144,0.221327,0.12442,0.074144,0.222198,0.12349,0.074144,0.221327,0.12442,0.061144,0.220282,0.125129,0.061144,0.220282,0.125129,0.074144,0.221327,0.12442,0.074144,0.220282,0.125129,0.061144,0.219099,0.12558,0.061144,0.219099,0.12558,0.074144,0.220282,0.125129,0.074144,0.219099,0.12558,0.061144,0.21781,0.125739,0.061144,0.21781,0.125739,0.074144,0.219099,0.12558,0.074144,0.29146,0.125739,0.061144,0.245032,0.125739,0.061144,0.245032,0.125739,0.074144,0.29146,0.125739,0.074144,0.245032,0.125739,0.061144,0.243743,0.12558,0.061144,0.243743,0.12558,0.074144,0.245032,0.125739,0.061144,0.243743,0.12558,0.074144,0.245032,0.125739,0.074144,0.243743,0.12558,0.061144,0.24256,0.125129,0.061144,0.24256,0.125129,0.074144,0.243743,0.12558,0.061144,0.24256,0.125129,0.074144,0.243743,0.12558,0.074144,0.24256,0.125129,0.061144,0.241515,0.12442,0.061144,0.241515,0.12442,0.074144,0.24256,0.125129,0.074144,0.241515,0.12442,0.061144,0.240644,0.12349,0.061144,0.240644,0.12349,0.074144,0.241515,0.12442,0.074144,0.240644,0.12349,0.061144,0.23998,0.122376,0.061144,0.23998,0.122376,0.074144,0.240644,0.12349,0.074144,0.23998,0.122376,0.061144,0.239556,0.121114,0.061144,0.239556,0.121114,0.074144,0.23998,0.122376,0.061144,0.239556,0.121114,0.074144,0.23998,0.122376,0.074144,0.239556,0.121114,0.061144,0.239408,0.119739,0.061144,0.239408,0.119739,0.074144,0.239556,0.121114,0.061144,0.239408,0.119739,0.074144,0.239556,0.121114,0.074144,0.239408,0.119739,0.061144,0.239408,0.074591,0.061144,0.239408,0.074591,0.074144,0.239408,0.119739,0.074144,0.239408,0.074591,0.061144,0.239556,0.073216,0.061144,0.239556,0.073216,0.074144,0.239408,0.074591,0.061144,0.239556,0.073216,0.074144,0.239408,0.074591,0.074144,0.239556,0.073216,0.061144,0.23998,0.071954,0.061144,0.23998,0.071954,0.074144,0.239556,0.073216,0.074144,0.23998,0.071954,0.061144,0.240644,0.07084,0.061144,0.240644,0.07084,0.074144,0.23998,0.071954,0.074144,0.240644,0.07084,0.061144,0.241515,0.06991,0.061144,0.241515,0.06991,0.074144,0.240644,0.07084,0.074144,0.241515,0.06991,0.061144,0.24256,0.069201,0.061144,0.24256,0.069201,0.074144,0.241515,0.06991,0.061144,0.24256,0.069201,0.074144,0.241515,0.06991,0.074144,0.24256,0.069201,0.061144,0.243743,0.06875,0.061144,0.243743,0.06875,0.074144,0.24256,0.069201,0.074144,0.243743,0.06875,0.061144,0.245032,0.068591,0.061144,0.245032,0.068591,0.074144,0.243743,0.06875,0.061144,0.245032,0.068591,0.074144,0.243743,0.06875,0.074144,0.245032,0.068591,0.061144,0.29146,0.068591,0.061144,0.29146,0.068591,0.074144,0.245032,0.068591,0.074144,0.29146,0.068591,0.061144,0.292749,0.06875,0.061144,0.292749,0.06875,0.074144,0.29146,0.068591,0.074144,0.292749,0.06875,0.061144,0.293933,0.069201,0.061144,0.293933,0.069201,0.074144,0.292749,0.06875,0.074144,0.293933,0.069201,0.061144,0.294977,0.06991,0.061144,0.294977,0.06991,0.074144,0.293933,0.069201,0.061144,0.294977,0.06991,0.074144,0.293933,0.069201,0.074144,0.294977,0.06991,0.061144,0.295848,0.07084,0.061144,0.295848,0.07084,0.074144,0.294977,0.06991,0.061144,0.295848,0.07084,0.074144,0.294977,0.06991,0.074144,0.295848,0.07084,0.061144,0.296513,0.071954,0.061144,0.296513,0.071954,0.074144,0.295848,0.07084,0.061144,0.296513,0.071954,0.074144,0.295848,0.07084,0.074144,0.296513,0.071954,0.061144,0.296936,0.073216,0.061144,0.296936,0.073216,0.074144,0.296513,0.071954,0.061144,0.296936,0.073216,0.074144,0.296513,0.071954,0.074144,0.296936,0.073216,0.061144,0.297085,0.074591,0.061144,0.297085,0.074591,0.074144,0.296936,0.073216,0.074144,0.297085,0.074591,0.061144,0.297085,0.119739,0.061144,0.297085,0.119739,0.074144,0.297085,0.074591,0.074144,0.297085,0.119739,0.061144,0.296936,0.121114,0.061144,0.296936,0.121114,0.074144,0.297085,0.119739,0.074144,0.296936,0.121114,0.061144,0.296512,0.122376,0.061144,0.296512,0.122376,0.074144,0.296936,0.121114,0.074144,0.296512,0.122376,0.061144,0.295848,0.12349,0.061144,0.295848,0.12349,0.074144,0.296512,0.122376,0.074144,0.295848,0.12349,0.061144,0.294977,0.12442,0.061144,0.294977,0.12442,0.074144,0.295848,0.12349,0.074144,0.294977,0.12442,0.061144,0.293933,0.125129,0.061144,0.293933,0.125129,0.074144,0.294977,0.12442,0.074144,0.293933,0.125129,0.061144,0.292749,0.12558,0.061144,0.292749,0.12558,0.074144,0.293933,0.125129,0.074144,0.292749,0.12558,0.061144,0.29146,0.125739,0.061144,0.29146,0.125739,0.074144,0.292749,0.12558,0.074144,0.443721,0.124239,0.061144,0.316428,0.124239,0.061144,0.316428,0.124239,0.074144,0.443721,0.124239,0.074144,0.316428,0.124239,0.061144,0.31514,0.12408,0.061144,0.31514,0.12408,0.074144,0.316428,0.124239,0.074144,0.31514,0.12408,0.061144,0.313956,0.123629,0.061144,0.313956,0.123629,0.074144,0.31514,0.12408,0.074144,0.313956,0.123629,0.061144,0.312912,0.12292,0.061144,0.312912,0.12292,0.074144,0.313956,0.123629,0.074144,0.312912,0.12292,0.061144,0.312041,0.12199,0.061144,0.312041,0.12199,0.074144,0.312912,0.12292,0.074144,0.312041,0.12199,0.061144,0.311376,0.120876,0.061144,0.311376,0.120876,0.074144,0.312041,0.12199,0.074144,0.311376,0.120876,0.061144,0.310953,0.119614,0.061144,0.310953,0.119614,0.074144,0.311376,0.120876,0.074144,0.310953,0.119614,0.061144,0.310804,0.118239,0.061144,0.310804,0.118239,0.074144,0.310953,0.119614,0.061144,0.310804,0.118239,0.074144,0.310953,0.119614,0.074144,0.310804,0.118239,0.061144,0.310804,0.076091,0.061144,0.310804,0.076091,0.074144,0.310804,0.118239,0.074144,0.310804,0.076091,0.061144,0.310953,0.074716,0.061144,0.310953,0.074716,0.074144,0.310804,0.076091,0.074144,0.310953,0.074716,0.061144,0.311376,0.073454,0.061144,0.311376,0.073454,0.074144,0.310953,0.074716,0.074144,0.311376,0.073454,0.061144,0.312041,0.07234,0.061144,0.312041,0.07234,0.074144,0.311376,0.073454,0.074144,0.312041,0.07234,0.061144,0.312912,0.07141,0.061144,0.312912,0.07141,0.074144,0.312041,0.07234,0.074144,0.312912,0.07141,0.061144,0.313956,0.070701,0.061144,0.313956,0.070701,0.074144,0.312912,0.07141,0.061144,0.313956,0.070701,0.074144,0.312912,0.07141,0.074144,0.313956,0.070701,0.061144,0.31514,0.07025,0.061144,0.31514,0.07025,0.074144,0.313956,0.070701,0.061144,0.31514,0.07025,0.074144,0.313956,0.070701,0.074144,0.31514,0.07025,0.061144,0.316428,0.070091,0.061144,0.316428,0.070091,0.074144,0.31514,0.07025,0.074144,0.316428,0.070091,0.061144,0.443721,0.070091,0.061144,0.443721,0.070091,0.074144,0.316428,0.070091,0.074144,0.443721,0.070091,0.061144,0.44501,0.07025,0.061144,0.44501,0.07025,0.074144,0.443721,0.070091,0.074144,0.44501,0.07025,0.061144,0.446194,0.070701,0.061144,0.446194,0.070701,0.074144,0.44501,0.07025,0.074144,0.446194,0.070701,0.061144,0.447238,0.07141,0.061144,0.447238,0.07141,0.074144,0.446194,0.070701,0.074144,0.447238,0.07141,0.061144,0.448109,0.07234,0.061144,0.448109,0.07234,0.074144,0.447238,0.07141,0.074144,0.448109,0.07234,0.061144,0.448773,0.073454,0.061144,0.448773,0.073454,0.074144,0.448109,0.07234,0.074144,0.448773,0.073454,0.061144,0.449197,0.074716,0.061144,0.449197,0.074716,0.074144,0.448773,0.073454,0.074144,0.449197,0.074716,0.061144,0.449346,0.076091,0.061144,0.449346,0.076091,0.074144,0.449197,0.074716,0.074144,0.449346,0.076091,0.061144,0.449346,0.118239,0.061144,0.449346,0.118239,0.074144,0.449346,0.076091,0.074144,0.449346,0.118239,0.061144,0.449197,0.119614,0.061144,0.449197,0.119614,0.074144,0.449346,0.118239,0.074144,0.449197,0.119614,0.061144,0.448774,0.120876,0.061144,0.448774,0.120876,0.074144,0.449197,0.119614,0.074144,0.448774,0.120876,0.061144,0.448109,0.12199,0.061144,0.448109,0.12199,0.074144,0.448774,0.120876,0.074144,0.448109,0.12199,0.061144,0.447238,0.12292,0.061144,0.447238,0.12292,0.074144,0.448109,0.12199,0.074144,0.447238,0.12292,0.061144,0.446194,0.123629,0.061144,0.446194,0.123629,0.074144,0.447238,0.12292,0.074144,0.446194,0.123629,0.061144,0.44501,0.12408,0.061144,0.44501,0.12408,0.074144,0.446194,0.123629,0.074144,0.44501,0.12408,0.061144,0.443721,0.124239,0.061144,0.443721,0.124239,0.074144,0.44501,0.12408,0.074144,-0.622965,0.12408,0.061144,-0.624149,0.123629,0.061144,-0.624149,0.123629,0.074144,-0.622965,0.12408,0.074144,-0.624149,0.123629,0.061144,-0.625193,0.12292,0.061144,-0.625193,0.12292,0.074144,-0.624149,0.123629,0.074144,-0.625193,0.12292,0.061144,-0.626064,0.12199,0.061144,-0.626064,0.12199,0.074144,-0.625193,0.12292,0.074144,-0.626064,0.12199,0.061144,-0.626729,0.120876,0.061144,-0.626729,0.120876,0.074144,-0.626064,0.12199,0.074144,-0.626729,0.120876,0.061144,-0.627152,0.119614,0.061144,-0.627152,0.119614,0.074144,-0.626729,0.120876,0.074144,-0.627152,0.119614,0.061144,-0.627301,0.118239,0.061144,-0.627301,0.118239,0.074144,-0.627152,0.119614,0.074144,-0.627301,0.118239,0.061144,-0.627301,0.076091,0.061144,-0.627301,0.076091,0.074144,-0.627301,0.118239,0.074144,-0.627301,0.076091,0.061144,-0.627152,0.074716,0.061144,-0.627152,0.074716,0.074144,-0.627301,0.076091,0.061144,-0.627152,0.074716,0.074144,-0.627301,0.076091,0.074144,-0.627152,0.074716,0.061144,-0.626729,0.073454,0.061144,-0.626729,0.073454,0.074144,-0.627152,0.074716,0.074144,-0.626729,0.073454,0.061144,-0.626064,0.07234,0.061144,-0.626064,0.07234,0.074144,-0.626729,0.073454,0.074144,-0.626064,0.07234,0.061144,-0.625193,0.07141,0.061144,-0.625193,0.07141,0.074144,-0.626064,0.07234,0.074144,-0.625193,0.07141,0.061144,-0.624149,0.070701,0.061144,-0.624149,0.070701,0.074144,-0.625193,0.07141,0.074144,-0.624149,0.070701,0.061144,-0.622965,0.07025,0.061144,-0.622965,0.07025,0.074144,-0.624149,0.070701,0.074144,-0.622965,0.07025,0.061144,-0.621677,0.070091,0.061144,-0.621677,0.070091,0.074144,-0.622965,0.07025,0.074144,-0.621677,0.070091,0.061144,-0.516504,0.070091,0.061144,-0.516504,0.070091,0.074144,-0.621677,0.070091,0.074144,-0.516504,0.070091,0.061144,-0.515215,0.07025,0.061144,-0.515215,0.07025,0.074144,-0.516504,0.070091,0.074144,-0.515215,0.07025,0.061144,-0.514032,0.070701,0.061144,-0.514032,0.070701,0.074144,-0.515215,0.07025,0.061144,-0.514032,0.070701,0.074144,-0.515215,0.07025,0.074144,-0.514032,0.070701,0.061144,-0.512987,0.07141,0.061144,-0.512987,0.07141,0.074144,-0.514032,0.070701,0.061144,-0.512987,0.07141,0.074144,-0.514032,0.070701,0.074144,-0.512987,0.07141,0.061144,-0.512116,0.07234,0.061144,-0.512116,0.07234,0.074144,-0.512987,0.07141,0.074144,-0.512116,0.07234,0.061144,-0.511452,0.073454,0.061144,-0.511452,0.073454,0.074144,-0.512116,0.07234,0.061144,-0.511452,0.073454,0.074144,-0.512116,0.07234,0.074144,-0.511452,0.073454,0.061144,-0.511028,0.074716,0.061144,-0.511028,0.074716,0.074144,-0.511452,0.073454,0.074144,-0.511028,0.074716,0.061144,-0.51088,0.076091,0.061144,-0.51088,0.076091,0.074144,-0.511028,0.074716,0.074144,-0.51088,0.076091,0.061144,-0.51088,0.118239,0.061144,-0.51088,0.118239,0.074144,-0.51088,0.076091,0.074144,-0.51088,0.118239,0.061144,-0.511028,0.119614,0.061144,-0.511028,0.119614,0.074144,-0.51088,0.118239,0.061144,-0.511028,0.119614,0.074144,-0.51088,0.118239,0.074144,-0.511028,0.119614,0.061144,-0.511452,0.120876,0.061144,-0.511452,0.120876,0.074144,-0.511028,0.119614,0.074144,-0.511452,0.120876,0.061144,-0.512116,0.12199,0.061144,-0.512116,0.12199,0.074144,-0.511452,0.120876,0.074144,-0.512116,0.12199,0.061144,-0.512987,0.12292,0.061144,-0.512987,0.12292,0.074144,-0.512116,0.12199,0.074144,-0.512987,0.12292,0.061144,-0.514032,0.123629,0.061144,-0.514032,0.123629,0.074144,-0.512987,0.12292,0.074144,-0.514032,0.123629,0.061144,-0.515215,0.12408,0.061144,-0.515215,0.12408,0.074144,-0.514032,0.123629,0.074144,-0.515215,0.12408,0.061144,-0.516504,0.124239,0.061144,-0.516504,0.124239,0.074144,-0.515215,0.12408,0.074144,-0.516504,0.124239,0.061144,-0.621677,0.124239,0.061144,-0.621677,0.124239,0.074144,-0.516504,0.124239,0.074144,-0.621677,0.124239,0.061144,-0.622965,0.12408,0.061144,-0.622965,0.12408,0.074144,-0.621677,0.124239,0.074144,-0.391659,0.0532,0.061144,-0.438088,0.0532,0.061144,-0.438088,0.0532,0.074144,-0.391659,0.0532,0.074144,-0.438088,0.0532,0.061144,-0.439377,0.053042,0.061144,-0.439377,0.053042,0.074144,-0.438088,0.0532,0.074144,-0.439377,0.053042,0.061144,-0.44056,0.05259,0.061144,-0.44056,0.05259,0.074144,-0.439377,0.053042,0.074144,-0.44056,0.05259,0.061144,-0.441605,0.051881,0.061144,-0.441605,0.051881,0.074144,-0.44056,0.05259,0.061144,-0.441605,0.051881,0.074144,-0.44056,0.05259,0.074144,-0.441605,0.051881,0.061144,-0.442476,0.050952,0.061144,-0.442476,0.050952,0.074144,-0.441605,0.051881,0.074144,-0.442476,0.050952,0.061144,-0.44314,0.049838,0.061144,-0.44314,0.049838,0.074144,-0.442476,0.050952,0.061144,-0.44314,0.049838,0.074144,-0.442476,0.050952,0.074144,-0.44314,0.049838,0.061144,-0.443564,0.048575,0.061144,-0.443564,0.048575,0.074144,-0.44314,0.049838,0.074144,-0.443564,0.048575,0.061144,-0.443712,0.0472,0.061144,-0.443712,0.0472,0.074144,-0.443564,0.048575,0.061144,-0.443712,0.0472,0.074144,-0.443564,0.048575,0.074144,-0.443712,0.0472,0.061144,-0.443712,0.002052,0.061144,-0.443712,0.002052,0.074144,-0.443712,0.0472,0.074144,-0.443712,0.002052,0.061144,-0.443564,0.000678,0.061144,-0.443564,0.000678,0.074144,-0.443712,0.002052,0.074144,-0.443564,0.000678,0.061144,-0.44314,-0.000585,0.061144,-0.44314,-0.000585,0.074144,-0.443564,0.000678,0.074144,-0.44314,-0.000585,0.061144,-0.442476,-0.001699,0.061144,-0.442476,-0.001699,0.074144,-0.44314,-0.000585,0.074144,-0.442476,-0.001699,0.061144,-0.441605,-0.002629,0.061144,-0.441605,-0.002629,0.074144,-0.442476,-0.001699,0.061144,-0.441605,-0.002629,0.074144,-0.442476,-0.001699,0.074144,-0.441605,-0.002629,0.061144,-0.44056,-0.003337,0.061144,-0.44056,-0.003337,0.074144,-0.441605,-0.002629,0.061144,-0.44056,-0.003337,0.074144,-0.441605,-0.002629,0.074144,-0.44056,-0.003337,0.061144,-0.439377,-0.003789,0.061144,-0.439377,-0.003789,0.074144,-0.44056,-0.003337,0.074144,-0.439377,-0.003789,0.061144,-0.438088,-0.003948,0.061144,-0.438088,-0.003948,0.074144,-0.439377,-0.003789,0.061144,-0.438088,-0.003948,0.074144,-0.439377,-0.003789,0.074144,-0.438088,-0.003948,0.061144,-0.391659,-0.003948,0.061144,-0.391659,-0.003948,0.074144,-0.438088,-0.003948,0.061144,-0.391659,-0.003948,0.074144,-0.438088,-0.003948,0.074144,-0.391659,-0.003948,0.061144,-0.390371,-0.003789,0.061144,-0.390371,-0.003789,0.074144,-0.391659,-0.003948,0.074144,-0.390371,-0.003789,0.061144,-0.389187,-0.003337,0.061144,-0.389187,-0.003337,0.074144,-0.390371,-0.003789,0.074144,-0.389187,-0.003337,0.061144,-0.388143,-0.002629,0.061144,-0.388143,-0.002629,0.074144,-0.389187,-0.003337,0.074144,-0.388143,-0.002629,0.061144,-0.387272,-0.001699,0.061144,-0.387272,-0.001699,0.074144,-0.388143,-0.002629,0.061144,-0.387272,-0.001699,0.074144,-0.388143,-0.002629,0.074144,-0.387272,-0.001699,0.061144,-0.386607,-0.000585,0.061144,-0.386607,-0.000585,0.074144,-0.387272,-0.001699,0.074144,-0.386607,-0.000585,0.061144,-0.386184,0.000678,0.061144,-0.386184,0.000678,0.074144,-0.386607,-0.000585,0.074144,-0.386184,0.000678,0.061144,-0.386035,0.002052,0.061144,-0.386035,0.002052,0.074144,-0.386184,0.000678,0.074144,-0.386035,0.002052,0.061144,-0.386035,0.0472,0.061144,-0.386035,0.0472,0.074144,-0.386035,0.002052,0.074144,-0.386035,0.0472,0.061144,-0.386184,0.048575,0.061144,-0.386184,0.048575,0.074144,-0.386035,0.0472,0.074144,-0.386184,0.048575,0.061144,-0.386607,0.049838,0.061144,-0.386607,0.049838,0.074144,-0.386184,0.048575,0.074144,-0.386607,0.049838,0.061144,-0.387272,0.050952,0.061144,-0.387272,0.050952,0.074144,-0.386607,0.049838,0.074144,-0.387272,0.050952,0.061144,-0.388143,0.051881,0.061144,-0.388143,0.051881,0.074144,-0.387272,0.050952,0.074144,-0.388143,0.051881,0.061144,-0.389187,0.05259,0.061144,-0.389187,0.05259,0.074144,-0.388143,0.051881,0.074144,-0.389187,0.05259,0.061144,-0.390371,0.053042,0.061144,-0.390371,0.053042,0.074144,-0.389187,0.05259,0.074144,-0.390371,0.053042,0.061144,-0.391659,0.0532,0.061144,-0.391659,0.0532,0.074144,-0.390371,0.053042,0.061144,-0.391659,0.0532,0.074144,-0.390371,0.053042,0.074144,-0.318009,0.0532,0.061144,-0.364438,0.0532,0.061144,-0.364438,0.0532,0.074144,-0.318009,0.0532,0.074144,-0.364438,0.0532,0.061144,-0.365727,0.053042,0.061144,-0.365727,0.053042,0.074144,-0.364438,0.0532,0.061144,-0.365727,0.053042,0.074144,-0.364438,0.0532,0.074144,-0.365727,0.053042,0.061144,-0.36691,0.05259,0.061144,-0.36691,0.05259,0.074144,-0.365727,0.053042,0.074144,-0.36691,0.05259,0.061144,-0.367954,0.051881,0.061144,-0.367954,0.051881,0.074144,-0.36691,0.05259,0.074144,-0.367954,0.051881,0.061144,-0.368826,0.050952,0.061144,-0.368826,0.050952,0.074144,-0.367954,0.051881,0.061144,-0.368826,0.050952,0.074144,-0.367954,0.051881,0.074144,-0.368826,0.050952,0.061144,-0.36949,0.049838,0.061144,-0.36949,0.049838,0.074144,-0.368826,0.050952,0.074144,-0.36949,0.049838,0.061144,-0.369914,0.048575,0.061144,-0.369914,0.048575,0.074144,-0.36949,0.049838,0.074144,-0.369914,0.048575,0.061144,-0.370062,0.0472,0.061144,-0.370062,0.0472,0.074144,-0.369914,0.048575,0.074144,-0.370062,0.0472,0.061144,-0.370062,0.002052,0.061144,-0.370062,0.002052,0.074144,-0.370062,0.0472,0.074144,-0.370062,0.002052,0.061144,-0.369914,0.000678,0.061144,-0.369914,0.000678,0.074144,-0.370062,0.002052,0.074144,-0.369914,0.000678,0.061144,-0.36949,-0.000585,0.061144,-0.36949,-0.000585,0.074144,-0.369914,0.000678,0.074144,-0.36949,-0.000585,0.061144,-0.368826,-0.001699,0.061144,-0.368826,-0.001699,0.074144,-0.36949,-0.000585,0.074144,-0.368826,-0.001699,0.061144,-0.367954,-0.002629,0.061144,-0.367954,-0.002629,0.074144,-0.368826,-0.001699,0.061144,-0.367954,-0.002629,0.074144,-0.368826,-0.001699,0.074144,-0.367954,-0.002629,0.061144,-0.36691,-0.003337,0.061144,-0.36691,-0.003337,0.074144,-0.367954,-0.002629,0.061144,-0.36691,-0.003337,0.074144,-0.367954,-0.002629,0.074144,-0.36691,-0.003337,0.061144,-0.365727,-0.003789,0.061144,-0.365727,-0.003789,0.074144,-0.36691,-0.003337,0.074144,-0.365727,-0.003789,0.061144,-0.364438,-0.003948,0.061144,-0.364438,-0.003948,0.074144,-0.365727,-0.003789,0.061144,-0.364438,-0.003948,0.074144,-0.365727,-0.003789,0.074144,-0.364438,-0.003948,0.061144,-0.318009,-0.003948,0.061144,-0.318009,-0.003948,0.074144,-0.364438,-0.003948,0.074144,-0.318009,-0.003948,0.061144,-0.316721,-0.003789,0.061144,-0.316721,-0.003789,0.074144,-0.318009,-0.003948,0.074144,-0.316721,-0.003789,0.061144,-0.315537,-0.003337,0.061144,-0.315537,-0.003337,0.074144,-0.316721,-0.003789,0.074144,-0.315537,-0.003337,0.061144,-0.314493,-0.002629,0.061144,-0.314493,-0.002629,0.074144,-0.315537,-0.003337,0.074144,-0.314493,-0.002629,0.061144,-0.313622,-0.001699,0.061144,-0.313622,-0.001699,0.074144,-0.314493,-0.002629,0.074144,-0.313622,-0.001699,0.061144,-0.312957,-0.000585,0.061144,-0.312957,-0.000585,0.074144,-0.313622,-0.001699,0.074144,-0.312957,-0.000585,0.061144,-0.312534,0.000678,0.061144,-0.312534,0.000678,0.074144,-0.312957,-0.000585,0.074144,-0.312534,0.000678,0.061144,-0.312385,0.002052,0.061144,-0.312385,0.002052,0.074144,-0.312534,0.000678,0.074144,-0.312385,0.002052,0.061144,-0.312385,0.0472,0.061144,-0.312385,0.0472,0.074144,-0.312385,0.002052,0.074144,-0.312385,0.0472,0.061144,-0.312534,0.048575,0.061144,-0.312534,0.048575,0.074144,-0.312385,0.0472,0.074144,-0.312534,0.048575,0.061144,-0.312957,0.049838,0.061144,-0.312957,0.049838,0.074144,-0.312534,0.048575,0.074144,-0.312957,0.049838,0.061144,-0.313622,0.050952,0.061144,-0.313622,0.050952,0.074144,-0.312957,0.049838,0.074144,-0.313622,0.050952,0.061144,-0.314493,0.051881,0.061144,-0.314493,0.051881,0.074144,-0.313622,0.050952,0.061144,-0.314493,0.051881,0.074144,-0.313622,0.050952,0.074144,-0.314493,0.051881,0.061144,-0.315537,0.05259,0.061144,-0.315537,0.05259,0.074144,-0.314493,0.051881,0.061144,-0.315537,0.05259,0.074144,-0.314493,0.051881,0.074144,-0.315537,0.05259,0.061144,-0.316721,0.053042,0.061144,-0.316721,0.053042,0.074144,-0.315537,0.05259,0.074144,-0.316721,0.053042,0.061144,-0.318009,0.0532,0.061144,-0.318009,0.0532,0.074144,-0.316721,0.053042,0.074144,-0.244359,0.0532,0.061144,-0.290788,0.0532,0.061144,-0.290788,0.0532,0.074144,-0.244359,0.0532,0.074144,-0.290788,0.0532,0.061144,-0.292077,0.053042,0.061144,-0.292077,0.053042,0.074144,-0.290788,0.0532,0.074144,-0.292077,0.053042,0.061144,-0.29326,0.05259,0.061144,-0.29326,0.05259,0.074144,-0.292077,0.053042,0.074144,-0.29326,0.05259,0.061144,-0.294304,0.051881,0.061144,-0.294304,0.051881,0.074144,-0.29326,0.05259,0.061144,-0.294304,0.051881,0.074144,-0.29326,0.05259,0.074144,-0.294304,0.051881,0.061144,-0.295176,0.050952,0.061144,-0.295176,0.050952,0.074144,-0.294304,0.051881,0.074144,-0.295176,0.050952,0.061144,-0.29584,0.049838,0.061144,-0.29584,0.049838,0.074144,-0.295176,0.050952,0.061144,-0.29584,0.049838,0.074144,-0.295176,0.050952,0.074144,-0.29584,0.049838,0.061144,-0.296263,0.048575,0.061144,-0.296263,0.048575,0.074144,-0.29584,0.049838,0.074144,-0.296263,0.048575,0.061144,-0.296412,0.0472,0.061144,-0.296412,0.0472,0.074144,-0.296263,0.048575,0.074144,-0.296412,0.0472,0.061144,-0.296412,0.002052,0.061144,-0.296412,0.002052,0.074144,-0.296412,0.0472,0.074144,-0.296412,0.002052,0.061144,-0.296263,0.000678,0.061144,-0.296263,0.000678,0.074144,-0.296412,0.002052,0.074144,-0.296263,0.000678,0.061144,-0.29584,-0.000585,0.061144,-0.29584,-0.000585,0.074144,-0.296263,0.000678,0.074144,-0.29584,-0.000585,0.061144,-0.295176,-0.001699,0.061144,-0.295176,-0.001699,0.074144,-0.29584,-0.000585,0.061144,-0.295176,-0.001699,0.074144,-0.29584,-0.000585,0.074144,-0.295176,-0.001699,0.061144,-0.294304,-0.002629,0.061144,-0.294304,-0.002629,0.074144,-0.295176,-0.001699,0.061144,-0.294304,-0.002629,0.074144,-0.295176,-0.001699,0.074144,-0.294304,-0.002629,0.061144,-0.29326,-0.003337,0.061144,-0.29326,-0.003337,0.074144,-0.294304,-0.002629,0.074144,-0.29326,-0.003337,0.061144,-0.292077,-0.003789,0.061144,-0.292077,-0.003789,0.074144,-0.29326,-0.003337,0.074144,-0.292077,-0.003789,0.061144,-0.290788,-0.003948,0.061144,-0.290788,-0.003948,0.074144,-0.292077,-0.003789,0.061144,-0.290788,-0.003948,0.074144,-0.292077,-0.003789,0.074144,-0.290788,-0.003948,0.061144,-0.244359,-0.003948,0.061144,-0.244359,-0.003948,0.074144,-0.290788,-0.003948,0.061144,-0.244359,-0.003948,0.074144,-0.290788,-0.003948,0.074144,-0.244359,-0.003948,0.061144,-0.243071,-0.003789,0.061144,-0.243071,-0.003789,0.074144,-0.244359,-0.003948,0.061144,-0.243071,-0.003789,0.074144,-0.244359,-0.003948,0.074144,-0.243071,-0.003789,0.061144,-0.241887,-0.003337,0.061144,-0.241887,-0.003337,0.074144,-0.243071,-0.003789,0.061144,-0.241887,-0.003337,0.074144,-0.243071,-0.003789,0.074144,-0.241887,-0.003337,0.061144,-0.240843,-0.002629,0.061144,-0.240843,-0.002629,0.074144,-0.241887,-0.003337,0.061144,-0.240843,-0.002629,0.074144,-0.241887,-0.003337,0.074144,-0.240843,-0.002629,0.061144,-0.239971,-0.001699,0.061144,-0.239971,-0.001699,0.074144,-0.240843,-0.002629,0.061144,-0.239971,-0.001699,0.074144,-0.240843,-0.002629,0.074144,-0.239971,-0.001699,0.061144,-0.239307,-0.000585,0.061144,-0.239307,-0.000585,0.074144,-0.239971,-0.001699,0.074144,-0.239307,-0.000585,0.061144,-0.238884,0.000678,0.061144,-0.238884,0.000678,0.074144,-0.239307,-0.000585,0.074144,-0.238884,0.000678,0.061144,-0.238735,0.002052,0.061144,-0.238735,0.002052,0.074144,-0.238884,0.000678,0.074144,-0.238735,0.002052,0.061144,-0.238735,0.0472,0.061144,-0.238735,0.0472,0.074144,-0.238735,0.002052,0.074144,-0.238735,0.0472,0.061144,-0.238884,0.048575,0.061144,-0.238884,0.048575,0.074144,-0.238735,0.0472,0.074144,-0.238884,0.048575,0.061144,-0.239307,0.049838,0.061144,-0.239307,0.049838,0.074144,-0.238884,0.048575,0.061144,-0.239307,0.049838,0.074144,-0.238884,0.048575,0.074144,-0.239307,0.049838,0.061144,-0.239971,0.050952,0.061144,-0.239971,0.050952,0.074144,-0.239307,0.049838,0.061144,-0.239971,0.050952,0.074144,-0.239307,0.049838,0.074144,-0.239971,0.050952,0.061144,-0.240843,0.051881,0.061144,-0.240843,0.051881,0.074144,-0.239971,0.050952,0.061144,-0.240843,0.051881,0.074144,-0.239971,0.050952,0.074144,-0.240843,0.051881,0.061144,-0.241887,0.05259,0.061144,-0.241887,0.05259,0.074144,-0.240843,0.051881,0.074144,-0.241887,0.05259,0.061144,-0.243071,0.053042,0.061144,-0.243071,0.053042,0.074144,-0.241887,0.05259,0.061144,-0.243071,0.053042,0.074144,-0.241887,0.05259,0.074144,-0.243071,0.053042,0.061144,-0.244359,0.0532,0.061144,-0.244359,0.0532,0.074144,-0.243071,0.053042,0.074144,-0.170709,0.0532,0.061144,-0.217138,0.0532,0.061144,-0.217138,0.0532,0.074144,-0.170709,0.0532,0.074144,-0.217138,0.0532,0.061144,-0.218426,0.053042,0.061144,-0.218426,0.053042,0.074144,-0.217138,0.0532,0.061144,-0.218426,0.053042,0.074144,-0.217138,0.0532,0.074144,-0.218426,0.053042,0.061144,-0.21961,0.05259,0.061144,-0.21961,0.05259,0.074144,-0.218426,0.053042,0.074144,-0.21961,0.05259,0.061144,-0.220654,0.051881,0.061144,-0.220654,0.051881,0.074144,-0.21961,0.05259,0.074144,-0.220654,0.051881,0.061144,-0.221525,0.050952,0.061144,-0.221525,0.050952,0.074144,-0.220654,0.051881,0.061144,-0.221525,0.050952,0.074144,-0.220654,0.051881,0.074144,-0.221525,0.050952,0.061144,-0.22219,0.049838,0.061144,-0.22219,0.049838,0.074144,-0.221525,0.050952,0.061144,-0.22219,0.049838,0.074144,-0.221525,0.050952,0.074144,-0.22219,0.049838,0.061144,-0.222613,0.048575,0.061144,-0.222613,0.048575,0.074144,-0.22219,0.049838,0.061144,-0.222613,0.048575,0.074144,-0.22219,0.049838,0.074144,-0.222613,0.048575,0.061144,-0.222762,0.0472,0.061144,-0.222762,0.0472,0.074144,-0.222613,0.048575,0.074144,-0.222762,0.0472,0.061144,-0.222762,0.002052,0.061144,-0.222762,0.002052,0.074144,-0.222762,0.0472,0.074144,-0.222762,0.002052,0.061144,-0.222613,0.000678,0.061144,-0.222613,0.000678,0.074144,-0.222762,0.002052,0.061144,-0.222613,0.000678,0.074144,-0.222762,0.002052,0.074144,-0.222613,0.000678,0.061144,-0.22219,-0.000585,0.061144,-0.22219,-0.000585,0.074144,-0.222613,0.000678,0.074144,-0.22219,-0.000585,0.061144,-0.221526,-0.001699,0.061144,-0.221526,-0.001699,0.074144,-0.22219,-0.000585,0.074144,-0.221526,-0.001699,0.061144,-0.220654,-0.002629,0.061144,-0.220654,-0.002629,0.074144,-0.221526,-0.001699,0.061144,-0.220654,-0.002629,0.074144,-0.221526,-0.001699,0.074144,-0.220654,-0.002629,0.061144,-0.21961,-0.003337,0.061144,-0.21961,-0.003337,0.074144,-0.220654,-0.002629,0.074144,-0.21961,-0.003337,0.061144,-0.218426,-0.003789,0.061144,-0.218426,-0.003789,0.074144,-0.21961,-0.003337,0.074144,-0.218426,-0.003789,0.061144,-0.217138,-0.003948,0.061144,-0.217138,-0.003948,0.074144,-0.218426,-0.003789,0.061144,-0.217138,-0.003948,0.074144,-0.218426,-0.003789,0.074144,-0.217138,-0.003948,0.061144,-0.170709,-0.003948,0.061144,-0.170709,-0.003948,0.074144,-0.217138,-0.003948,0.061144,-0.170709,-0.003948,0.074144,-0.217138,-0.003948,0.074144,-0.170709,-0.003948,0.061144,-0.16942,-0.003789,0.061144,-0.16942,-0.003789,0.074144,-0.170709,-0.003948,0.061144,-0.16942,-0.003789,0.074144,-0.170709,-0.003948,0.074144,-0.16942,-0.003789,0.061144,-0.168237,-0.003337,0.061144,-0.168237,-0.003337,0.074144,-0.16942,-0.003789,0.061144,-0.168237,-0.003337,0.074144,-0.16942,-0.003789,0.074144,-0.168237,-0.003337,0.061144,-0.167193,-0.002629,0.061144,-0.167193,-0.002629,0.074144,-0.168237,-0.003337,0.061144,-0.167193,-0.002629,0.074144,-0.168237,-0.003337,0.074144,-0.167193,-0.002629,0.061144,-0.166321,-0.001699,0.061144,-0.166321,-0.001699,0.074144,-0.167193,-0.002629,0.074144,-0.166321,-0.001699,0.061144,-0.165657,-0.000585,0.061144,-0.165657,-0.000585,0.074144,-0.166321,-0.001699,0.074144,-0.165657,-0.000585,0.061144,-0.165234,0.000678,0.061144,-0.165234,0.000678,0.074144,-0.165657,-0.000585,0.074144,-0.165234,0.000678,0.061144,-0.165085,0.002052,0.061144,-0.165085,0.002052,0.074144,-0.165234,0.000678,0.074144,-0.165085,0.002052,0.061144,-0.165085,0.0472,0.061144,-0.165085,0.0472,0.074144,-0.165085,0.002052,0.074144,-0.165085,0.0472,0.061144,-0.165234,0.048575,0.061144,-0.165234,0.048575,0.074144,-0.165085,0.0472,0.074144,-0.165234,0.048575,0.061144,-0.165657,0.049838,0.061144,-0.165657,0.049838,0.074144,-0.165234,0.048575,0.074144,-0.165657,0.049838,0.061144,-0.166321,0.050952,0.061144,-0.166321,0.050952,0.074144,-0.165657,0.049838,0.074144,-0.166321,0.050952,0.061144,-0.167193,0.051881,0.061144,-0.167193,0.051881,0.074144,-0.166321,0.050952,0.074144,-0.167193,0.051881,0.061144,-0.168237,0.05259,0.061144,-0.168237,0.05259,0.074144,-0.167193,0.051881,0.074144,-0.168237,0.05259,0.061144,-0.16942,0.053042,0.061144,-0.16942,0.053042,0.074144,-0.168237,0.05259,0.074144,-0.16942,0.053042,0.061144,-0.170709,0.0532,0.061144,-0.170709,0.0532,0.074144,-0.16942,0.053042,0.074144,-0.097059,0.0532,0.061144,-0.143488,0.0532,0.061144,-0.143488,0.0532,0.074144,-0.097059,0.0532,0.074144,-0.143488,0.0532,0.061144,-0.144776,0.053042,0.061144,-0.144776,0.053042,0.074144,-0.143488,0.0532,0.074144,-0.144776,0.053042,0.061144,-0.14596,0.05259,0.061144,-0.14596,0.05259,0.074144,-0.144776,0.053042,0.074144,-0.14596,0.05259,0.061144,-0.147004,0.051881,0.061144,-0.147004,0.051881,0.074144,-0.14596,0.05259,0.061144,-0.147004,0.051881,0.074144,-0.14596,0.05259,0.074144,-0.147004,0.051881,0.061144,-0.147875,0.050952,0.061144,-0.147875,0.050952,0.074144,-0.147004,0.051881,0.074144,-0.147875,0.050952,0.061144,-0.14854,0.049838,0.061144,-0.14854,0.049838,0.074144,-0.147875,0.050952,0.061144,-0.14854,0.049838,0.074144,-0.147875,0.050952,0.074144,-0.14854,0.049838,0.061144,-0.148963,0.048575,0.061144,-0.148963,0.048575,0.074144,-0.14854,0.049838,0.074144,-0.148963,0.048575,0.061144,-0.149112,0.0472,0.061144,-0.149112,0.0472,0.074144,-0.148963,0.048575,0.074144,-0.149112,0.0472,0.061144,-0.149112,0.002052,0.061144,-0.149112,0.002052,0.074144,-0.149112,0.0472,0.074144,-0.149112,0.002052,0.061144,-0.148963,0.000678,0.061144,-0.148963,0.000678,0.074144,-0.149112,0.002052,0.074144,-0.148963,0.000678,0.061144,-0.14854,-0.000585,0.061144,-0.14854,-0.000585,0.074144,-0.148963,0.000678,0.074144,-0.14854,-0.000585,0.061144,-0.147875,-0.001699,0.061144,-0.147875,-0.001699,0.074144,-0.14854,-0.000585,0.074144,-0.147875,-0.001699,0.061144,-0.147004,-0.002629,0.061144,-0.147004,-0.002629,0.074144,-0.147875,-0.001699,0.061144,-0.147004,-0.002629,0.074144,-0.147875,-0.001699,0.074144,-0.147004,-0.002629,0.061144,-0.14596,-0.003337,0.061144,-0.14596,-0.003337,0.074144,-0.147004,-0.002629,0.074144,-0.14596,-0.003337,0.061144,-0.144776,-0.003789,0.061144,-0.144776,-0.003789,0.074144,-0.14596,-0.003337,0.074144,-0.144776,-0.003789,0.061144,-0.143488,-0.003948,0.061144,-0.143488,-0.003948,0.074144,-0.144776,-0.003789,0.074144,-0.143488,-0.003948,0.061144,-0.097059,-0.003948,0.061144,-0.097059,-0.003948,0.074144,-0.143488,-0.003948,0.061144,-0.097059,-0.003948,0.074144,-0.143488,-0.003948,0.074144,-0.097059,-0.003948,0.061144,-0.09577,-0.003789,0.061144,-0.09577,-0.003789,0.074144,-0.097059,-0.003948,0.061144,-0.09577,-0.003789,0.074144,-0.097059,-0.003948,0.074144,-0.09577,-0.003789,0.061144,-0.094587,-0.003337,0.061144,-0.094587,-0.003337,0.074144,-0.09577,-0.003789,0.074144,-0.094587,-0.003337,0.061144,-0.093542,-0.002629,0.061144,-0.093542,-0.002629,0.074144,-0.094587,-0.003337,0.074144,-0.093542,-0.002629,0.061144,-0.092671,-0.001699,0.061144,-0.092671,-0.001699,0.074144,-0.093542,-0.002629,0.061144,-0.092671,-0.001699,0.074144,-0.093542,-0.002629,0.074144,-0.092671,-0.001699,0.061144,-0.092007,-0.000585,0.061144,-0.092007,-0.000585,0.074144,-0.092671,-0.001699,0.074144,-0.092007,-0.000585,0.061144,-0.091583,0.000678,0.061144,-0.091583,0.000678,0.074144,-0.092007,-0.000585,0.074144,-0.091583,0.000678,0.061144,-0.091435,0.002052,0.061144,-0.091435,0.002052,0.074144,-0.091583,0.000678,0.074144,-0.091435,0.002052,0.061144,-0.091435,0.0472,0.061144,-0.091435,0.0472,0.074144,-0.091435,0.002052,0.074144,-0.091435,0.0472,0.061144,-0.091583,0.048575,0.061144,-0.091583,0.048575,0.074144,-0.091435,0.0472,0.074144,-0.091583,0.048575,0.061144,-0.092007,0.049838,0.061144,-0.092007,0.049838,0.074144,-0.091583,0.048575,0.074144,-0.092007,0.049838,0.061144,-0.092671,0.050952,0.061144,-0.092671,0.050952,0.074144,-0.092007,0.049838,0.074144,-0.092671,0.050952,0.061144,-0.093542,0.051881,0.061144,-0.093542,0.051881,0.074144,-0.092671,0.050952,0.074144,-0.093542,0.051881,0.061144,-0.094587,0.05259,0.061144,-0.094587,0.05259,0.074144,-0.093542,0.051881,0.074144,-0.094587,0.05259,0.061144,-0.09577,0.053042,0.061144,-0.09577,0.053042,0.074144,-0.094587,0.05259,0.074144,-0.09577,0.053042,0.061144,-0.097059,0.0532,0.061144,-0.097059,0.0532,0.074144,-0.09577,0.053042,0.061144,-0.097059,0.0532,0.074144,-0.09577,0.053042,0.074144,-0.023409,0.0532,0.061144,-0.069837,0.0532,0.061144,-0.069837,0.0532,0.074144,-0.023409,0.0532,0.074144,-0.069837,0.0532,0.061144,-0.071126,0.053042,0.061144,-0.071126,0.053042,0.074144,-0.069837,0.0532,0.061144,-0.071126,0.053042,0.074144,-0.069837,0.0532,0.074144,-0.071126,0.053042,0.061144,-0.07231,0.05259,0.061144,-0.07231,0.05259,0.074144,-0.071126,0.053042,0.074144,-0.07231,0.05259,0.061144,-0.073354,0.051881,0.061144,-0.073354,0.051881,0.074144,-0.07231,0.05259,0.074144,-0.073354,0.051881,0.061144,-0.074225,0.050952,0.061144,-0.074225,0.050952,0.074144,-0.073354,0.051881,0.061144,-0.074225,0.050952,0.074144,-0.073354,0.051881,0.074144,-0.074225,0.050952,0.061144,-0.07489,0.049838,0.061144,-0.07489,0.049838,0.074144,-0.074225,0.050952,0.074144,-0.07489,0.049838,0.061144,-0.075313,0.048575,0.061144,-0.075313,0.048575,0.074144,-0.07489,0.049838,0.074144,-0.075313,0.048575,0.061144,-0.075462,0.0472,0.061144,-0.075462,0.0472,0.074144,-0.075313,0.048575,0.074144,-0.075462,0.0472,0.061144,-0.075462,0.002052,0.061144,-0.075462,0.002052,0.074144,-0.075462,0.0472,0.074144,-0.075462,0.002052,0.061144,-0.075313,0.000678,0.061144,-0.075313,0.000678,0.074144,-0.075462,0.002052,0.074144,-0.075313,0.000678,0.061144,-0.07489,-0.000585,0.061144,-0.07489,-0.000585,0.074144,-0.075313,0.000678,0.074144,-0.07489,-0.000585,0.061144,-0.074225,-0.001699,0.061144,-0.074225,-0.001699,0.074144,-0.07489,-0.000585,0.074144,-0.074225,-0.001699,0.061144,-0.073354,-0.002629,0.061144,-0.073354,-0.002629,0.074144,-0.074225,-0.001699,0.074144,-0.073354,-0.002629,0.061144,-0.07231,-0.003337,0.061144,-0.07231,-0.003337,0.074144,-0.073354,-0.002629,0.061144,-0.07231,-0.003337,0.074144,-0.073354,-0.002629,0.074144,-0.07231,-0.003337,0.061144,-0.071126,-0.003789,0.061144,-0.071126,-0.003789,0.074144,-0.07231,-0.003337,0.061144,-0.071126,-0.003789,0.074144,-0.07231,-0.003337,0.074144,-0.071126,-0.003789,0.061144,-0.069837,-0.003948,0.061144,-0.069837,-0.003948,0.074144,-0.071126,-0.003789,0.061144,-0.069837,-0.003948,0.074144,-0.071126,-0.003789,0.074144,-0.069837,-0.003948,0.061144,-0.023409,-0.003948,0.061144,-0.023409,-0.003948,0.074144,-0.069837,-0.003948,0.074144,-0.023409,-0.003948,0.061144,-0.02212,-0.003789,0.061144,-0.02212,-0.003789,0.074144,-0.023409,-0.003948,0.061144,-0.02212,-0.003789,0.074144,-0.023409,-0.003948,0.074144,-0.02212,-0.003789,0.061144,-0.020937,-0.003337,0.061144,-0.020937,-0.003337,0.074144,-0.02212,-0.003789,0.061144,-0.020937,-0.003337,0.074144,-0.02212,-0.003789,0.074144,-0.020937,-0.003337,0.061144,-0.019892,-0.002629,0.061144,-0.019892,-0.002629,0.074144,-0.020937,-0.003337,0.074144,-0.019892,-0.002629,0.061144,-0.019021,-0.001699,0.061144,-0.019021,-0.001699,0.074144,-0.019892,-0.002629,0.061144,-0.019021,-0.001699,0.074144,-0.019892,-0.002629,0.074144,-0.019021,-0.001699,0.061144,-0.018357,-0.000585,0.061144,-0.018357,-0.000585,0.074144,-0.019021,-0.001699,0.074144,-0.018357,-0.000585,0.061144,-0.017933,0.000678,0.061144,-0.017933,0.000678,0.074144,-0.018357,-0.000585,0.074144,-0.017933,0.000678,0.061144,-0.017785,0.002052,0.061144,-0.017785,0.002052,0.074144,-0.017933,0.000678,0.074144,-0.017785,0.002052,0.061144,-0.017785,0.0472,0.061144,-0.017785,0.0472,0.074144,-0.017785,0.002052,0.074144,-0.017785,0.0472,0.061144,-0.017933,0.048575,0.061144,-0.017933,0.048575,0.074144,-0.017785,0.0472,0.074144,-0.017933,0.048575,0.061144,-0.018357,0.049838,0.061144,-0.018357,0.049838,0.074144,-0.017933,0.048575,0.074144,-0.018357,0.049838,0.061144,-0.019021,0.050952,0.061144,-0.019021,0.050952,0.074144,-0.018357,0.049838,0.074144,-0.019021,0.050952,0.061144,-0.019892,0.051881,0.061144,-0.019892,0.051881,0.074144,-0.019021,0.050952,0.061144,-0.019892,0.051881,0.074144,-0.019021,0.050952,0.074144,-0.019892,0.051881,0.061144,-0.020937,0.05259,0.061144,-0.020937,0.05259,0.074144,-0.019892,0.051881,0.061144,-0.020937,0.05259,0.074144,-0.019892,0.051881,0.074144,-0.020937,0.05259,0.061144,-0.02212,0.053042,0.061144,-0.02212,0.053042,0.074144,-0.020937,0.05259,0.074144,-0.02212,0.053042,0.061144,-0.023409,0.0532,0.061144,-0.023409,0.0532,0.074144,-0.02212,0.053042,0.074144,0.050241,0.0532,0.061144,0.003813,0.0532,0.061144,0.003813,0.0532,0.074144,0.050241,0.0532,0.074144,0.003813,0.0532,0.061144,0.002524,0.053042,0.061144,0.002524,0.053042,0.074144,0.003813,0.0532,0.074144,0.002524,0.053042,0.061144,0.001341,0.05259,0.061144,0.001341,0.05259,0.074144,0.002524,0.053042,0.074144,0.001341,0.05259,0.061144,0.000296,0.051881,0.061144,0.000296,0.051881,0.074144,0.001341,0.05259,0.074144,0.000296,0.051881,0.061144,-0.000575,0.050952,0.061144,-0.000575,0.050952,0.074144,0.000296,0.051881,0.061144,-0.000575,0.050952,0.074144,0.000296,0.051881,0.074144,-0.000575,0.050952,0.061144,-0.001239,0.049838,0.061144,-0.001239,0.049838,0.074144,-0.000575,0.050952,0.061144,-0.001239,0.049838,0.074144,-0.000575,0.050952,0.074144,-0.001239,0.049838,0.061144,-0.001663,0.048575,0.061144,-0.001663,0.048575,0.074144,-0.001239,0.049838,0.074144,-0.001663,0.048575,0.061144,-0.001812,0.0472,0.061144,-0.001812,0.0472,0.074144,-0.001663,0.048575,0.074144,-0.001812,0.0472,0.061144,-0.001812,0.002052,0.061144,-0.001812,0.002052,0.074144,-0.001812,0.0472,0.074144,-0.001812,0.002052,0.061144,-0.001663,0.000678,0.061144,-0.001663,0.000678,0.074144,-0.001812,0.002052,0.074144,-0.001663,0.000678,0.061144,-0.001239,-0.000585,0.061144,-0.001239,-0.000585,0.074144,-0.001663,0.000678,0.074144,-0.001239,-0.000585,0.061144,-0.000575,-0.001699,0.061144,-0.000575,-0.001699,0.074144,-0.001239,-0.000585,0.074144,-0.000575,-0.001699,0.061144,0.000296,-0.002629,0.061144,0.000296,-0.002629,0.074144,-0.000575,-0.001699,0.074144,0.000296,-0.002629,0.061144,0.001341,-0.003337,0.061144,0.001341,-0.003337,0.074144,0.000296,-0.002629,0.061144,0.001341,-0.003337,0.074144,0.000296,-0.002629,0.074144,0.001341,-0.003337,0.061144,0.002524,-0.003789,0.061144,0.002524,-0.003789,0.074144,0.001341,-0.003337,0.074144,0.002524,-0.003789,0.061144,0.003813,-0.003948,0.061144,0.003813,-0.003948,0.074144,0.002524,-0.003789,0.061144,0.003813,-0.003948,0.074144,0.002524,-0.003789,0.074144,0.003813,-0.003948,0.061144,0.050241,-0.003948,0.061144,0.050241,-0.003948,0.074144,0.003813,-0.003948,0.074144,0.050241,-0.003948,0.061144,0.05153,-0.003789,0.061144,0.05153,-0.003789,0.074144,0.050241,-0.003948,0.074144,0.05153,-0.003789,0.061144,0.052714,-0.003337,0.061144,0.052714,-0.003337,0.074144,0.05153,-0.003789,0.074144,0.052714,-0.003337,0.061144,0.053758,-0.002629,0.061144,0.053758,-0.002629,0.074144,0.052714,-0.003337,0.074144,0.053758,-0.002629,0.061144,0.054629,-0.001699,0.061144,0.054629,-0.001699,0.074144,0.053758,-0.002629,0.061144,0.054629,-0.001699,0.074144,0.053758,-0.002629,0.074144,0.054629,-0.001699,0.061144,0.055293,-0.000585,0.061144,0.055293,-0.000585,0.074144,0.054629,-0.001699,0.074144,0.055293,-0.000585,0.061144,0.055717,0.000678,0.061144,0.055717,0.000678,0.074144,0.055293,-0.000585,0.074144,0.055717,0.000678,0.061144,0.055866,0.002052,0.061144,0.055866,0.002052,0.074144,0.055717,0.000678,0.074144,0.055866,0.002052,0.061144,0.055866,0.0472,0.061144,0.055866,0.0472,0.074144,0.055866,0.002052,0.074144,0.055866,0.0472,0.061144,0.055717,0.048575,0.061144,0.055717,0.048575,0.074144,0.055866,0.0472,0.074144,0.055717,0.048575,0.061144,0.055293,0.049838,0.061144,0.055293,0.049838,0.074144,0.055717,0.048575,0.061144,0.055293,0.049838,0.074144,0.055717,0.048575,0.074144,0.055293,0.049838,0.061144,0.054629,0.050952,0.061144,0.054629,0.050952,0.074144,0.055293,0.049838,0.061144,0.054629,0.050952,0.074144,0.055293,0.049838,0.074144,0.054629,0.050952,0.061144,0.053758,0.051881,0.061144,0.053758,0.051881,0.074144,0.054629,0.050952,0.061144,0.053758,0.051881,0.074144,0.054629,0.050952,0.074144,0.053758,0.051881,0.061144,0.052713,0.05259,0.061144,0.052713,0.05259,0.074144,0.053758,0.051881,0.074144,0.052713,0.05259,0.061144,0.05153,0.053042,0.061144,0.05153,0.053042,0.074144,0.052713,0.05259,0.061144,0.05153,0.053042,0.074144,0.052713,0.05259,0.074144,0.05153,0.053042,0.061144,0.050241,0.0532,0.061144,0.050241,0.0532,0.074144,0.05153,0.053042,0.074144,0.123892,0.0532,0.061144,0.077463,0.0532,0.061144,0.077463,0.0532,0.074144,0.123892,0.0532,0.074144,0.077463,0.0532,0.061144,0.076174,0.053042,0.061144,0.076174,0.053042,0.074144,0.077463,0.0532,0.061144,0.076174,0.053042,0.074144,0.077463,0.0532,0.074144,0.076174,0.053042,0.061144,0.074991,0.05259,0.061144,0.074991,0.05259,0.074144,0.076174,0.053042,0.074144,0.074991,0.05259,0.061144,0.073946,0.051881,0.061144,0.073946,0.051881,0.074144,0.074991,0.05259,0.074144,0.073946,0.051881,0.061144,0.073075,0.050952,0.061144,0.073075,0.050952,0.074144,0.073946,0.051881,0.074144,0.073075,0.050952,0.061144,0.072411,0.049838,0.061144,0.072411,0.049838,0.074144,0.073075,0.050952,0.074144,0.072411,0.049838,0.061144,0.071987,0.048575,0.061144,0.071987,0.048575,0.074144,0.072411,0.049838,0.061144,0.071987,0.048575,0.074144,0.072411,0.049838,0.074144,0.071987,0.048575,0.061144,0.071839,0.0472,0.061144,0.071839,0.0472,0.074144,0.071987,0.048575,0.074144,0.071839,0.0472,0.061144,0.071839,0.002052,0.061144,0.071839,0.002052,0.074144,0.071839,0.0472,0.074144,0.071839,0.002052,0.061144,0.071987,0.000678,0.061144,0.071987,0.000678,0.074144,0.071839,0.002052,0.074144,0.071987,0.000678,0.061144,0.072411,-0.000585,0.061144,0.072411,-0.000585,0.074144,0.071987,0.000678,0.074144,0.072411,-0.000585,0.061144,0.073075,-0.001699,0.061144,0.073075,-0.001699,0.074144,0.072411,-0.000585,0.074144,0.073075,-0.001699,0.061144,0.073946,-0.002629,0.061144,0.073946,-0.002629,0.074144,0.073075,-0.001699,0.074144,0.073946,-0.002629,0.061144,0.074991,-0.003337,0.061144,0.074991,-0.003337,0.074144,0.073946,-0.002629,0.061144,0.074991,-0.003337,0.074144,0.073946,-0.002629,0.074144,0.074991,-0.003337,0.061144,0.076174,-0.003789,0.061144,0.076174,-0.003789,0.074144,0.074991,-0.003337,0.061144,0.076174,-0.003789,0.074144,0.074991,-0.003337,0.074144,0.076174,-0.003789,0.061144,0.077463,-0.003948,0.061144,0.077463,-0.003948,0.074144,0.076174,-0.003789,0.061144,0.077463,-0.003948,0.074144,0.076174,-0.003789,0.074144,0.077463,-0.003948,0.061144,0.123892,-0.003948,0.061144,0.123892,-0.003948,0.074144,0.077463,-0.003948,0.074144,0.123892,-0.003948,0.061144,0.12518,-0.003789,0.061144,0.12518,-0.003789,0.074144,0.123892,-0.003948,0.061144,0.12518,-0.003789,0.074144,0.123892,-0.003948,0.074144,0.12518,-0.003789,0.061144,0.126364,-0.003337,0.061144,0.126364,-0.003337,0.074144,0.12518,-0.003789,0.074144,0.126364,-0.003337,0.061144,0.127408,-0.002629,0.061144,0.127408,-0.002629,0.074144,0.126364,-0.003337,0.074144,0.127408,-0.002629,0.061144,0.128279,-0.001699,0.061144,0.128279,-0.001699,0.074144,0.127408,-0.002629,0.061144,0.128279,-0.001699,0.074144,0.127408,-0.002629,0.074144,0.128279,-0.001699,0.061144,0.128944,-0.000585,0.061144,0.128944,-0.000585,0.074144,0.128279,-0.001699,0.074144,0.128944,-0.000585,0.061144,0.129367,0.000678,0.061144,0.129367,0.000678,0.074144,0.128944,-0.000585,0.074144,0.129367,0.000678,0.061144,0.129516,0.002052,0.061144,0.129516,0.002052,0.074144,0.129367,0.000678,0.074144,0.129516,0.002052,0.061144,0.129516,0.0472,0.061144,0.129516,0.0472,0.074144,0.129516,0.002052,0.074144,0.129516,0.0472,0.061144,0.129367,0.048575,0.061144,0.129367,0.048575,0.074144,0.129516,0.0472,0.074144,0.129367,0.048575,0.061144,0.128944,0.049838,0.061144,0.128944,0.049838,0.074144,0.129367,0.048575,0.074144,0.128944,0.049838,0.061144,0.128279,0.050952,0.061144,0.128279,0.050952,0.074144,0.128944,0.049838,0.074144,0.128279,0.050952,0.061144,0.127408,0.051881,0.061144,0.127408,0.051881,0.074144,0.128279,0.050952,0.074144,0.127408,0.051881,0.061144,0.126364,0.05259,0.061144,0.126364,0.05259,0.074144,0.127408,0.051881,0.074144,0.126364,0.05259,0.061144,0.12518,0.053042,0.061144,0.12518,0.053042,0.074144,0.126364,0.05259,0.074144,0.12518,0.053042,0.061144,0.123892,0.0532,0.061144,0.123892,0.0532,0.074144,0.12518,0.053042,0.074144,0.197542,0.0532,0.061144,0.151113,0.0532,0.061144,0.151113,0.0532,0.074144,0.197542,0.0532,0.074144,0.151113,0.0532,0.061144,0.149824,0.053042,0.061144,0.149824,0.053042,0.074144,0.151113,0.0532,0.074144,0.149824,0.053042,0.061144,0.148641,0.05259,0.061144,0.148641,0.05259,0.074144,0.149824,0.053042,0.074144,0.148641,0.05259,0.061144,0.147596,0.051881,0.061144,0.147596,0.051881,0.074144,0.148641,0.05259,0.061144,0.147596,0.051881,0.074144,0.148641,0.05259,0.074144,0.147596,0.051881,0.061144,0.146725,0.050952,0.061144,0.146725,0.050952,0.074144,0.147596,0.051881,0.074144,0.146725,0.050952,0.061144,0.146061,0.049838,0.061144,0.146061,0.049838,0.074144,0.146725,0.050952,0.061144,0.146061,0.049838,0.074144,0.146725,0.050952,0.074144,0.146061,0.049838,0.061144,0.145637,0.048575,0.061144,0.145637,0.048575,0.074144,0.146061,0.049838,0.061144,0.145637,0.048575,0.074144,0.146061,0.049838,0.074144,0.145637,0.048575,0.061144,0.145489,0.0472,0.061144,0.145489,0.0472,0.074144,0.145637,0.048575,0.061144,0.145489,0.0472,0.074144,0.145637,0.048575,0.074144,0.145489,0.0472,0.061144,0.145489,0.002052,0.061144,0.145489,0.002052,0.074144,0.145489,0.0472,0.074144,0.145489,0.002052,0.061144,0.145637,0.000678,0.061144,0.145637,0.000678,0.074144,0.145489,0.002052,0.074144,0.145637,0.000678,0.061144,0.146061,-0.000585,0.061144,0.146061,-0.000585,0.074144,0.145637,0.000678,0.074144,0.146061,-0.000585,0.061144,0.146725,-0.001699,0.061144,0.146725,-0.001699,0.074144,0.146061,-0.000585,0.074144,0.146725,-0.001699,0.061144,0.147597,-0.002629,0.061144,0.147597,-0.002629,0.074144,0.146725,-0.001699,0.074144,0.147597,-0.002629,0.061144,0.148641,-0.003337,0.061144,0.148641,-0.003337,0.074144,0.147597,-0.002629,0.061144,0.148641,-0.003337,0.074144,0.147597,-0.002629,0.074144,0.148641,-0.003337,0.061144,0.149824,-0.003789,0.061144,0.149824,-0.003789,0.074144,0.148641,-0.003337,0.074144,0.149824,-0.003789,0.061144,0.151113,-0.003948,0.061144,0.151113,-0.003948,0.074144,0.149824,-0.003789,0.061144,0.151113,-0.003948,0.074144,0.149824,-0.003789,0.074144,0.151113,-0.003948,0.061144,0.197542,-0.003948,0.061144,0.197542,-0.003948,0.074144,0.151113,-0.003948,0.074144,0.197542,-0.003948,0.061144,0.19883,-0.003789,0.061144,0.19883,-0.003789,0.074144,0.197542,-0.003948,0.061144,0.19883,-0.003789,0.074144,0.197542,-0.003948,0.074144,0.19883,-0.003789,0.061144,0.200014,-0.003337,0.061144,0.200014,-0.003337,0.074144,0.19883,-0.003789,0.061144,0.200014,-0.003337,0.074144,0.19883,-0.003789,0.074144,0.200014,-0.003337,0.061144,0.201058,-0.002628,0.061144,0.201058,-0.002629,0.074144,0.200014,-0.003337,0.061144,0.201058,-0.002629,0.074144,0.200014,-0.003337,0.074144,0.201058,-0.002628,0.061144,0.201929,-0.001699,0.061144,0.201929,-0.001699,0.074144,0.201058,-0.002628,0.061144,0.201929,-0.001699,0.074144,0.201058,-0.002629,0.074144,0.201929,-0.001699,0.061144,0.202594,-0.000585,0.061144,0.202594,-0.000585,0.074144,0.201929,-0.001699,0.074144,0.202594,-0.000585,0.061144,0.203017,0.000678,0.061144,0.203017,0.000678,0.074144,0.202594,-0.000585,0.074144,0.203017,0.000678,0.061144,0.203166,0.002052,0.061144,0.203166,0.002052,0.074144,0.203017,0.000678,0.074144,0.203166,0.002052,0.061144,0.203166,0.0472,0.061144,0.203166,0.0472,0.074144,0.203166,0.002052,0.074144,0.203166,0.0472,0.061144,0.203017,0.048575,0.061144,0.203017,0.048575,0.074144,0.203166,0.0472,0.074144,0.203017,0.048575,0.061144,0.202594,0.049838,0.061144,0.202594,0.049838,0.074144,0.203017,0.048575,0.061144,0.202594,0.049838,0.074144,0.203017,0.048575,0.074144,0.202594,0.049838,0.061144,0.201929,0.050952,0.061144,0.201929,0.050952,0.074144,0.202594,0.049838,0.074144,0.201929,0.050952,0.061144,0.201058,0.051881,0.061144,0.201058,0.051881,0.074144,0.201929,0.050952,0.074144,0.201058,0.051881,0.061144,0.200014,0.05259,0.061144,0.200014,0.05259,0.074144,0.201058,0.051881,0.074144,0.200014,0.05259,0.061144,0.19883,0.053042,0.061144,0.19883,0.053042,0.074144,0.200014,0.05259,0.074144,0.19883,0.053042,0.061144,0.197542,0.0532,0.061144,0.197542,0.0532,0.074144,0.19883,0.053042,0.061144,0.197542,0.0532,0.074144,0.19883,0.053042,0.074144,0.271192,0.0532,0.061144,0.224763,0.0532,0.061144,0.224763,0.0532,0.074144,0.271192,0.0532,0.074144,0.224763,0.0532,0.061144,0.223474,0.053042,0.061144,0.223474,0.053042,0.074144,0.224763,0.0532,0.061144,0.223474,0.053042,0.074144,0.224763,0.0532,0.074144,0.223474,0.053042,0.061144,0.222291,0.05259,0.061144,0.222291,0.05259,0.074144,0.223474,0.053042,0.074144,0.222291,0.05259,0.061144,0.221247,0.051881,0.061144,0.221247,0.051881,0.074144,0.222291,0.05259,0.074144,0.221247,0.051881,0.061144,0.220375,0.050952,0.061144,0.220375,0.050952,0.074144,0.221247,0.051881,0.061144,0.220375,0.050952,0.074144,0.221247,0.051881,0.074144,0.220375,0.050952,0.061144,0.219711,0.049838,0.061144,0.219711,0.049838,0.074144,0.220375,0.050952,0.074144,0.219711,0.049838,0.061144,0.219288,0.048575,0.061144,0.219288,0.048575,0.074144,0.219711,0.049838,0.074144,0.219288,0.048575,0.061144,0.219139,0.0472,0.061144,0.219139,0.0472,0.074144,0.219288,0.048575,0.074144,0.219139,0.0472,0.061144,0.219139,0.002052,0.061144,0.219139,0.002052,0.074144,0.219139,0.0472,0.074144,0.219139,0.002052,0.061144,0.219288,0.000678,0.061144,0.219288,0.000678,0.074144,0.219139,0.002052,0.074144,0.219288,0.000678,0.061144,0.219711,-0.000585,0.061144,0.219711,-0.000585,0.074144,0.219288,0.000678,0.074144,0.219711,-0.000585,0.061144,0.220375,-0.001699,0.061144,0.220375,-0.001699,0.074144,0.219711,-0.000585,0.074144,0.220375,-0.001699,0.061144,0.221247,-0.002628,0.061144,0.221247,-0.002628,0.074144,0.220375,-0.001699,0.061144,0.221247,-0.002628,0.074144,0.220375,-0.001699,0.074144,0.221247,-0.002628,0.061144,0.222291,-0.003337,0.061144,0.222291,-0.003337,0.074144,0.221247,-0.002628,0.074144,0.222291,-0.003337,0.061144,0.223474,-0.003789,0.061144,0.223474,-0.003789,0.074144,0.222291,-0.003337,0.074144,0.223474,-0.003789,0.061144,0.224763,-0.003948,0.061144,0.224763,-0.003948,0.074144,0.223474,-0.003789,0.074144,0.224763,-0.003948,0.061144,0.271192,-0.003948,0.061144,0.271192,-0.003948,0.074144,0.224763,-0.003948,0.074144,0.271192,-0.003948,0.061144,0.27248,-0.003789,0.061144,0.27248,-0.003789,0.074144,0.271192,-0.003948,0.061144,0.27248,-0.003789,0.074144,0.271192,-0.003948,0.074144,0.27248,-0.003789,0.061144,0.273664,-0.003337,0.061144,0.273664,-0.003337,0.074144,0.27248,-0.003789,0.061144,0.273664,-0.003337,0.074144,0.27248,-0.003789,0.074144,0.273664,-0.003337,0.061144,0.274708,-0.002628,0.061144,0.274708,-0.002629,0.074144,0.273664,-0.003337,0.061144,0.274708,-0.002629,0.074144,0.273664,-0.003337,0.074144,0.274708,-0.002628,0.061144,0.27558,-0.001699,0.061144,0.27558,-0.001699,0.074144,0.274708,-0.002628,0.061144,0.27558,-0.001699,0.074144,0.274708,-0.002629,0.074144,0.27558,-0.001699,0.061144,0.276244,-0.000585,0.061144,0.276244,-0.000585,0.074144,0.27558,-0.001699,0.074144,0.276244,-0.000585,0.061144,0.276667,0.000678,0.061144,0.276667,0.000678,0.074144,0.276244,-0.000585,0.074144,0.276667,0.000678,0.061144,0.276816,0.002052,0.061144,0.276816,0.002052,0.074144,0.276667,0.000678,0.074144,0.276816,0.002052,0.061144,0.276816,0.0472,0.061144,0.276816,0.0472,0.074144,0.276816,0.002052,0.074144,0.276816,0.0472,0.061144,0.276667,0.048575,0.061144,0.276667,0.048575,0.074144,0.276816,0.0472,0.074144,0.276667,0.048575,0.061144,0.276244,0.049838,0.061144,0.276244,0.049838,0.074144,0.276667,0.048575,0.074144,0.276244,0.049838,0.061144,0.27558,0.050952,0.061144,0.27558,0.050952,0.074144,0.276244,0.049838,0.074144,0.27558,0.050952,0.061144,0.274708,0.051881,0.061144,0.274708,0.051881,0.074144,0.27558,0.050952,0.074144,0.274708,0.051881,0.061144,0.273664,0.05259,0.061144,0.273664,0.05259,0.074144,0.274708,0.051881,0.061144,0.273664,0.05259,0.074144,0.274708,0.051881,0.074144,0.273664,0.05259,0.061144,0.272481,0.053042,0.061144,0.272481,0.053042,0.074144,0.273664,0.05259,0.061144,0.272481,0.053042,0.074144,0.273664,0.05259,0.074144,0.272481,0.053042,0.061144,0.271192,0.0532,0.061144,0.271192,0.0532,0.074144,0.272481,0.053042,0.061144,0.271192,0.0532,0.074144,0.272481,0.053042,0.074144,-0.622787,0.052919,0.061144,-0.62397,0.052467,0.061144,-0.62397,0.052467,0.074144,-0.622787,0.052919,0.074144,-0.62397,0.052467,0.061144,-0.625014,0.051759,0.061144,-0.625014,0.051759,0.074144,-0.62397,0.052467,0.074144,-0.625014,0.051759,0.061144,-0.625886,0.050829,0.061144,-0.625886,0.050829,0.074144,-0.625014,0.051759,0.074144,-0.625886,0.050829,0.061144,-0.62655,0.049715,0.061144,-0.62655,0.049715,0.074144,-0.625886,0.050829,0.074144,-0.62655,0.049715,0.061144,-0.626974,0.048453,0.061144,-0.626974,0.048453,0.074144,-0.62655,0.049715,0.074144,-0.626974,0.048453,0.061144,-0.627122,0.047078,0.061144,-0.627122,0.047078,0.074144,-0.626974,0.048453,0.074144,-0.627122,0.047078,0.061144,-0.627122,0.001978,0.061144,-0.627122,0.001978,0.074144,-0.627122,0.047078,0.074144,-0.627122,0.001978,0.061144,-0.626974,0.000603,0.061144,-0.626974,0.000603,0.074144,-0.627122,0.001978,0.074144,-0.626974,0.000603,0.061144,-0.62655,-0.00066,0.061144,-0.62655,-0.00066,0.074144,-0.626974,0.000603,0.061144,-0.62655,-0.00066,0.074144,-0.626974,0.000603,0.074144,-0.62655,-0.00066,0.061144,-0.625886,-0.001774,0.061144,-0.625886,-0.001774,0.074144,-0.62655,-0.00066,0.074144,-0.625886,-0.001774,0.061144,-0.625015,-0.002703,0.061144,-0.625015,-0.002703,0.074144,-0.625886,-0.001774,0.061144,-0.625015,-0.002703,0.074144,-0.625886,-0.001774,0.074144,-0.625015,-0.002703,0.061144,-0.62397,-0.003412,0.061144,-0.62397,-0.003412,0.074144,-0.625015,-0.002703,0.074144,-0.62397,-0.003412,0.061144,-0.622787,-0.003864,0.061144,-0.622787,-0.003864,0.074144,-0.62397,-0.003412,0.074144,-0.622787,-0.003864,0.061144,-0.621498,-0.004022,0.061144,-0.621498,-0.004022,0.074144,-0.622787,-0.003864,0.074144,-0.621498,-0.004022,0.061144,-0.464448,-0.004022,0.061144,-0.464448,-0.004022,0.074144,-0.621498,-0.004022,0.074144,-0.464448,-0.004022,0.061144,-0.463159,-0.003864,0.061144,-0.463159,-0.003864,0.074144,-0.464448,-0.004022,0.074144,-0.463159,-0.003864,0.061144,-0.461976,-0.003412,0.061144,-0.461976,-0.003412,0.074144,-0.463159,-0.003864,0.074144,-0.461976,-0.003412,0.061144,-0.460931,-0.002703,0.061144,-0.460931,-0.002703,0.074144,-0.461976,-0.003412,0.074144,-0.460931,-0.002703,0.061144,-0.46006,-0.001774,0.061144,-0.46006,-0.001774,0.074144,-0.460931,-0.002703,0.061144,-0.46006,-0.001774,0.074144,-0.460931,-0.002703,0.074144,-0.46006,-0.001774,0.061144,-0.459396,-0.00066,0.061144,-0.459396,-0.00066,0.074144,-0.46006,-0.001774,0.074144,-0.459396,-0.00066,0.061144,-0.458972,0.000603,0.061144,-0.458972,0.000603,0.074144,-0.459396,-0.00066,0.074144,-0.458972,0.000603,0.061144,-0.458824,0.001978,0.061144,-0.458824,0.001978,0.074144,-0.458972,0.000603,0.074144,-0.458824,0.001978,0.061144,-0.458824,0.047078,0.061144,-0.458824,0.047078,0.074144,-0.458824,0.001978,0.074144,-0.458824,0.047078,0.061144,-0.458972,0.048453,0.061144,-0.458972,0.048453,0.074144,-0.458824,0.047078,0.074144,-0.458972,0.048453,0.061144,-0.459396,0.049715,0.061144,-0.459396,0.049715,0.074144,-0.458972,0.048453,0.074144,-0.459396,0.049715,0.061144,-0.46006,0.050829,0.061144,-0.46006,0.050829,0.074144,-0.459396,0.049715,0.074144,-0.46006,0.050829,0.061144,-0.460931,0.051759,0.061144,-0.460931,0.051759,0.074144,-0.46006,0.050829,0.074144,-0.460931,0.051759,0.061144,-0.461976,0.052467,0.061144,-0.461976,0.052467,0.074144,-0.460931,0.051759,0.061144,-0.461976,0.052467,0.074144,-0.460931,0.051759,0.074144,-0.461976,0.052467,0.061144,-0.463159,0.052919,0.061144,-0.463159,0.052919,0.074144,-0.461976,0.052467,0.074144,-0.463159,0.052919,0.061144,-0.464448,0.053078,0.061144,-0.464448,0.053078,0.074144,-0.463159,0.052919,0.074144,-0.464448,0.053078,0.061144,-0.621498,0.053078,0.061144,-0.621498,0.053078,0.074144,-0.464448,0.053078,0.074144,-0.621498,0.053078,0.061144,-0.622787,0.052919,0.061144,-0.622787,0.052919,0.074144,-0.621498,0.053078,0.061144,-0.622787,0.052919,0.074144,-0.621498,0.053078,0.074144,0.293266,0.052919,0.061144,0.292083,0.052467,0.061144,0.292083,0.052467,0.074144,0.293266,0.052919,0.074144,0.292083,0.052467,0.061144,0.291038,0.051759,0.061144,0.291038,0.051759,0.074144,0.292083,0.052467,0.074144,0.291038,0.051759,0.061144,0.290167,0.050829,0.061144,0.290167,0.050829,0.074144,0.291038,0.051759,0.074144,0.290167,0.050829,0.061144,0.289503,0.049715,0.061144,0.289503,0.049715,0.074144,0.290167,0.050829,0.074144,0.289503,0.049715,0.061144,0.289079,0.048453,0.061144,0.289079,0.048453,0.074144,0.289503,0.049715,0.074144,0.289079,0.048453,0.061144,0.288931,0.047078,0.061144,0.288931,0.047078,0.074144,0.289079,0.048453,0.074144,0.288931,0.047078,0.061144,0.288931,0.001978,0.061144,0.288931,0.001978,0.074144,0.288931,0.047078,0.074144,0.288931,0.001978,0.061144,0.289079,0.000603,0.061144,0.289079,0.000603,0.074144,0.288931,0.001978,0.074144,0.289079,0.000603,0.061144,0.289503,-0.00066,0.061144,0.289503,-0.00066,0.074144,0.289079,0.000603,0.074144,0.289503,-0.00066,0.061144,0.290167,-0.001774,0.061144,0.290167,-0.001774,0.074144,0.289503,-0.00066,0.074144,0.290167,-0.001774,0.061144,0.291038,-0.002703,0.061144,0.291038,-0.002703,0.074144,0.290167,-0.001774,0.061144,0.291038,-0.002703,0.074144,0.290167,-0.001774,0.074144,0.291038,-0.002703,0.061144,0.292083,-0.003412,0.061144,0.292083,-0.003412,0.074144,0.291038,-0.002703,0.061144,0.292083,-0.003412,0.074144,0.291038,-0.002703,0.074144,0.292083,-0.003412,0.061144,0.293266,-0.003864,0.061144,0.293266,-0.003864,0.074144,0.292083,-0.003412,0.074144,0.293266,-0.003864,0.061144,0.294555,-0.004022,0.061144,0.294555,-0.004022,0.074144,0.293266,-0.003864,0.074144,0.294555,-0.004022,0.061144,0.443325,-0.004022,0.061144,0.443325,-0.004022,0.074144,0.294555,-0.004022,0.074144,0.443325,-0.004022,0.061144,0.444613,-0.003864,0.061144,0.444613,-0.003864,0.074144,0.443325,-0.004022,0.061144,0.444613,-0.003864,0.074144,0.443325,-0.004022,0.074144,0.444613,-0.003864,0.061144,0.445797,-0.003412,0.061144,0.445797,-0.003412,0.074144,0.444613,-0.003864,0.061144,0.445797,-0.003412,0.074144,0.444613,-0.003864,0.074144,0.445797,-0.003412,0.061144,0.446841,-0.002703,0.061144,0.446841,-0.002703,0.074144,0.445797,-0.003412,0.061144,0.446841,-0.002703,0.074144,0.445797,-0.003412,0.074144,0.446841,-0.002703,0.061144,0.447712,-0.001774,0.061144,0.447712,-0.001774,0.074144,0.446841,-0.002703,0.061144,0.447712,-0.001774,0.074144,0.446841,-0.002703,0.074144,0.447712,-0.001774,0.061144,0.448377,-0.00066,0.061144,0.448377,-0.00066,0.074144,0.447712,-0.001774,0.074144,0.448377,-0.00066,0.061144,0.4488,0.000603,0.061144,0.4488,0.000603,0.074144,0.448377,-0.00066,0.074144,0.4488,0.000603,0.061144,0.448949,0.001978,0.061144,0.448949,0.001978,0.074144,0.4488,0.000603,0.074144,0.448949,0.001978,0.061144,0.448949,0.047078,0.061144,0.448949,0.047078,0.074144,0.448949,0.001978,0.074144,0.448949,0.047078,0.061144,0.4488,0.048453,0.061144,0.4488,0.048453,0.074144,0.448949,0.047078,0.074144,0.4488,0.048453,0.061144,0.448377,0.049715,0.061144,0.448377,0.049715,0.074144,0.4488,0.048453,0.074144,0.448377,0.049715,0.061144,0.447712,0.050829,0.061144,0.447712,0.050829,0.074144,0.448377,0.049715,0.074144,0.447712,0.050829,0.061144,0.446841,0.051759,0.061144,0.446841,0.051759,0.074144,0.447712,0.050829,0.061144,0.446841,0.051759,0.074144,0.447712,0.050829,0.074144,0.446841,0.051759,0.061144,0.445797,0.052467,0.061144,0.445797,0.052467,0.074144,0.446841,0.051759,0.074144,0.445797,0.052467,0.061144,0.444613,0.052919,0.061144,0.444613,0.052919,0.074144,0.445797,0.052467,0.074144,0.444613,0.052919,0.061144,0.443325,0.053078,0.061144,0.443325,0.053078,0.074144,0.444613,0.052919,0.074144,0.443325,0.053078,0.061144,0.294555,0.053078,0.061144,0.294555,0.053078,0.074144,0.443325,0.053078,0.074144,0.294555,0.053078,0.061144,0.293266,0.052919,0.061144,0.293266,0.052919,0.074144,0.294555,0.053078,0.061144,0.293266,0.052919,0.074144,0.294555,0.053078,0.074144,-0.337076,-0.019556,0.061144,-0.383504,-0.019556,0.061144,-0.383504,-0.019556,0.074144,-0.337076,-0.019556,0.074144,-0.383504,-0.019556,0.061144,-0.384793,-0.019715,0.061144,-0.384793,-0.019715,0.074144,-0.383504,-0.019556,0.061144,-0.384793,-0.019715,0.074144,-0.383504,-0.019556,0.074144,-0.384793,-0.019715,0.061144,-0.385977,-0.020166,0.061144,-0.385977,-0.020166,0.074144,-0.384793,-0.019715,0.074144,-0.385977,-0.020166,0.061144,-0.387021,-0.020875,0.061144,-0.387021,-0.020875,0.074144,-0.385977,-0.020166,0.061144,-0.387021,-0.020875,0.074144,-0.385977,-0.020166,0.074144,-0.387021,-0.020875,0.061144,-0.387892,-0.021804,0.061144,-0.387892,-0.021804,0.074144,-0.387021,-0.020875,0.061144,-0.387892,-0.021804,0.074144,-0.387021,-0.020875,0.074144,-0.387892,-0.021804,0.061144,-0.388556,-0.022919,0.061144,-0.388556,-0.022919,0.074144,-0.387892,-0.021804,0.074144,-0.388556,-0.022919,0.061144,-0.38898,-0.024181,0.061144,-0.38898,-0.024181,0.074144,-0.388556,-0.022919,0.074144,-0.38898,-0.024181,0.061144,-0.389129,-0.025556,0.061144,-0.389129,-0.025556,0.074144,-0.38898,-0.024181,0.074144,-0.389129,-0.025556,0.061144,-0.389129,-0.070704,0.061144,-0.389129,-0.070704,0.074144,-0.389129,-0.025556,0.074144,-0.389129,-0.070704,0.061144,-0.38898,-0.072079,0.061144,-0.38898,-0.072079,0.074144,-0.389129,-0.070704,0.074144,-0.38898,-0.072079,0.061144,-0.388557,-0.073341,0.061144,-0.388557,-0.073341,0.074144,-0.38898,-0.072079,0.074144,-0.388557,-0.073341,0.061144,-0.387892,-0.074455,0.061144,-0.387892,-0.074455,0.074144,-0.388557,-0.073341,0.061144,-0.387892,-0.074455,0.074144,-0.388557,-0.073341,0.074144,-0.387892,-0.074455,0.061144,-0.387021,-0.075385,0.061144,-0.387021,-0.075385,0.074144,-0.387892,-0.074455,0.061144,-0.387021,-0.075385,0.074144,-0.387892,-0.074455,0.074144,-0.387021,-0.075385,0.061144,-0.385977,-0.076094,0.061144,-0.385977,-0.076094,0.074144,-0.387021,-0.075385,0.074144,-0.385977,-0.076094,0.061144,-0.384793,-0.076545,0.061144,-0.384793,-0.076545,0.074144,-0.385977,-0.076094,0.074144,-0.384793,-0.076545,0.061144,-0.383504,-0.076704,0.061144,-0.383504,-0.076704,0.074144,-0.384793,-0.076545,0.074144,-0.383504,-0.076704,0.061144,-0.337076,-0.076704,0.061144,-0.337076,-0.076704,0.074144,-0.383504,-0.076704,0.074144,-0.337076,-0.076704,0.061144,-0.335787,-0.076545,0.061144,-0.335787,-0.076545,0.074144,-0.337076,-0.076704,0.074144,-0.335787,-0.076545,0.061144,-0.334604,-0.076094,0.061144,-0.334604,-0.076094,0.074144,-0.335787,-0.076545,0.061144,-0.334604,-0.076094,0.074144,-0.335787,-0.076545,0.074144,-0.334604,-0.076094,0.061144,-0.333559,-0.075385,0.061144,-0.333559,-0.075385,0.074144,-0.334604,-0.076094,0.061144,-0.333559,-0.075385,0.074144,-0.334604,-0.076094,0.074144,-0.333559,-0.075385,0.061144,-0.332688,-0.074455,0.061144,-0.332688,-0.074455,0.074144,-0.333559,-0.075385,0.074144,-0.332688,-0.074455,0.061144,-0.332024,-0.073341,0.061144,-0.332024,-0.073341,0.074144,-0.332688,-0.074455,0.074144,-0.332024,-0.073341,0.061144,-0.3316,-0.072079,0.061144,-0.3316,-0.072079,0.074144,-0.332024,-0.073341,0.074144,-0.3316,-0.072079,0.061144,-0.331452,-0.070704,0.061144,-0.331452,-0.070704,0.074144,-0.3316,-0.072079,0.074144,-0.331452,-0.070704,0.061144,-0.331452,-0.025556,0.061144,-0.331452,-0.025556,0.074144,-0.331452,-0.070704,0.074144,-0.331452,-0.025556,0.061144,-0.3316,-0.024181,0.061144,-0.3316,-0.024181,0.074144,-0.331452,-0.025556,0.074144,-0.3316,-0.024181,0.061144,-0.332024,-0.022919,0.061144,-0.332024,-0.022919,0.074144,-0.3316,-0.024181,0.061144,-0.332024,-0.022919,0.074144,-0.3316,-0.024181,0.074144,-0.332024,-0.022919,0.061144,-0.332688,-0.021804,0.061144,-0.332688,-0.021804,0.074144,-0.332024,-0.022919,0.061144,-0.332688,-0.021804,0.074144,-0.332024,-0.022919,0.074144,-0.332688,-0.021804,0.061144,-0.333559,-0.020875,0.061144,-0.333559,-0.020875,0.074144,-0.332688,-0.021804,0.061144,-0.333559,-0.020875,0.074144,-0.332688,-0.021804,0.074144,-0.333559,-0.020875,0.061144,-0.334604,-0.020166,0.061144,-0.334604,-0.020166,0.074144,-0.333559,-0.020875,0.061144,-0.334604,-0.020166,0.074144,-0.333559,-0.020875,0.074144,-0.334604,-0.020166,0.061144,-0.335787,-0.019715,0.061144,-0.335787,-0.019715,0.074144,-0.334604,-0.020166,0.061144,-0.335787,-0.019715,0.074144,-0.334604,-0.020166,0.074144,-0.335787,-0.019715,0.061144,-0.337076,-0.019556,0.061144,-0.337076,-0.019556,0.074144,-0.335787,-0.019715,0.074144,0.224801,-0.019556,0.061144,0.15775,-0.019556,0.061144,0.15775,-0.019556,0.074144,0.224801,-0.019556,0.074144,0.15775,-0.019556,0.061144,0.156462,-0.019714,0.061144,0.156462,-0.019714,0.074144,0.15775,-0.019556,0.074144,0.156462,-0.019714,0.061144,0.155278,-0.020166,0.061144,0.155278,-0.020166,0.074144,0.156462,-0.019714,0.074144,0.155278,-0.020166,0.061144,0.154234,-0.020875,0.061144,0.154234,-0.020875,0.074144,0.155278,-0.020166,0.074144,0.154234,-0.020875,0.061144,0.153363,-0.021804,0.061144,0.153363,-0.021804,0.074144,0.154234,-0.020875,0.074144,0.153363,-0.021804,0.061144,0.152698,-0.022919,0.061144,0.152698,-0.022919,0.074144,0.153363,-0.021804,0.074144,0.152698,-0.022919,0.061144,0.152275,-0.024181,0.061144,0.152275,-0.024181,0.074144,0.152698,-0.022919,0.074144,0.152275,-0.024181,0.061144,0.152126,-0.025556,0.061144,0.152126,-0.025556,0.074144,0.152275,-0.024181,0.074144,0.152126,-0.025556,0.061144,0.152126,-0.070704,0.061144,0.152126,-0.070704,0.074144,0.152126,-0.025556,0.074144,0.152126,-0.070704,0.061144,0.152275,-0.072079,0.061144,0.152275,-0.072079,0.074144,0.152126,-0.070704,0.061144,0.152275,-0.072079,0.074144,0.152126,-0.070704,0.074144,0.152275,-0.072079,0.061144,0.152698,-0.073341,0.061144,0.152698,-0.073341,0.074144,0.152275,-0.072079,0.074144,0.152698,-0.073341,0.061144,0.153363,-0.074455,0.061144,0.153363,-0.074455,0.074144,0.152698,-0.073341,0.074144,0.153363,-0.074455,0.061144,0.154234,-0.075385,0.061144,0.154234,-0.075385,0.074144,0.153363,-0.074455,0.061144,0.154234,-0.075385,0.074144,0.153363,-0.074455,0.074144,0.154234,-0.075385,0.061144,0.155278,-0.076093,0.061144,0.155278,-0.076093,0.074144,0.154234,-0.075385,0.074144,0.155278,-0.076093,0.061144,0.156462,-0.076545,0.061144,0.156462,-0.076545,0.074144,0.155278,-0.076093,0.061144,0.156462,-0.076545,0.074144,0.155278,-0.076093,0.074144,0.156462,-0.076545,0.061144,0.15775,-0.076704,0.061144,0.15775,-0.076704,0.074144,0.156462,-0.076545,0.074144,0.15775,-0.076704,0.061144,0.224801,-0.076704,0.061144,0.224801,-0.076704,0.074144,0.15775,-0.076704,0.074144,0.224801,-0.076704,0.061144,0.22609,-0.076545,0.061144,0.22609,-0.076545,0.074144,0.224801,-0.076704,0.074144,0.22609,-0.076545,0.061144,0.227273,-0.076093,0.061144,0.227273,-0.076093,0.074144,0.22609,-0.076545,0.061144,0.227273,-0.076093,0.074144,0.22609,-0.076545,0.074144,0.227273,-0.076093,0.061144,0.228318,-0.075385,0.061144,0.228318,-0.075385,0.074144,0.227273,-0.076093,0.074144,0.228318,-0.075385,0.061144,0.229189,-0.074455,0.061144,0.229189,-0.074455,0.074144,0.228318,-0.075385,0.061144,0.229189,-0.074455,0.074144,0.228318,-0.075385,0.074144,0.229189,-0.074455,0.061144,0.229853,-0.073341,0.061144,0.229853,-0.073341,0.074144,0.229189,-0.074455,0.074144,0.229853,-0.073341,0.061144,0.230277,-0.072079,0.061144,0.230277,-0.072079,0.074144,0.229853,-0.073341,0.074144,0.230277,-0.072079,0.061144,0.230425,-0.070704,0.061144,0.230425,-0.070704,0.074144,0.230277,-0.072079,0.074144,0.230425,-0.070704,0.061144,0.230425,-0.025556,0.061144,0.230425,-0.025556,0.074144,0.230425,-0.070704,0.074144,0.230425,-0.025556,0.061144,0.230277,-0.024181,0.061144,0.230277,-0.024181,0.074144,0.230425,-0.025556,0.074144,0.230277,-0.024181,0.061144,0.229853,-0.022919,0.061144,0.229853,-0.022919,0.074144,0.230277,-0.024181,0.074144,0.229853,-0.022919,0.061144,0.229189,-0.021804,0.061144,0.229189,-0.021804,0.074144,0.229853,-0.022919,0.061144,0.229189,-0.021804,0.074144,0.229853,-0.022919,0.074144,0.229189,-0.021804,0.061144,0.228318,-0.020875,0.061144,0.228318,-0.020875,0.074144,0.229189,-0.021804,0.061144,0.228318,-0.020875,0.074144,0.229189,-0.021804,0.074144,0.228318,-0.020875,0.061144,0.227273,-0.020166,0.061144,0.227273,-0.020166,0.074144,0.228318,-0.020875,0.074144,0.227273,-0.020166,0.061144,0.22609,-0.019714,0.061144,0.22609,-0.019714,0.074144,0.227273,-0.020166,0.061144,0.22609,-0.019714,0.074144,0.227273,-0.020166,0.074144,0.22609,-0.019714,0.061144,0.224801,-0.019556,0.061144,0.224801,-0.019556,0.074144,0.22609,-0.019714,0.074144,0.295517,-0.019556,0.061144,0.249088,-0.019556,0.061144,0.249088,-0.019556,0.074144,0.295517,-0.019556,0.074144,0.249088,-0.019556,0.061144,0.2478,-0.019714,0.061144,0.2478,-0.019714,0.074144,0.249088,-0.019556,0.061144,0.2478,-0.019714,0.074144,0.249088,-0.019556,0.074144,0.2478,-0.019714,0.061144,0.246616,-0.020166,0.061144,0.246616,-0.020166,0.074144,0.2478,-0.019714,0.061144,0.246616,-0.020166,0.074144,0.2478,-0.019714,0.074144,0.246616,-0.020166,0.061144,0.245572,-0.020875,0.061144,0.245572,-0.020875,0.074144,0.246616,-0.020166,0.074144,0.245572,-0.020875,0.061144,0.244701,-0.021804,0.061144,0.244701,-0.021804,0.074144,0.245572,-0.020875,0.074144,0.244701,-0.021804,0.061144,0.244036,-0.022919,0.061144,0.244036,-0.022919,0.074144,0.244701,-0.021804,0.061144,0.244036,-0.022919,0.074144,0.244701,-0.021804,0.074144,0.244036,-0.022919,0.061144,0.243613,-0.024181,0.061144,0.243613,-0.024181,0.074144,0.244036,-0.022919,0.061144,0.243613,-0.024181,0.074144,0.244036,-0.022919,0.074144,0.243613,-0.024181,0.061144,0.243464,-0.025556,0.061144,0.243464,-0.025556,0.074144,0.243613,-0.024181,0.061144,0.243464,-0.025556,0.074144,0.243613,-0.024181,0.074144,0.243464,-0.025556,0.061144,0.243464,-0.070704,0.061144,0.243464,-0.070704,0.074144,0.243464,-0.025556,0.074144,0.243464,-0.070704,0.061144,0.243613,-0.072079,0.061144,0.243613,-0.072079,0.074144,0.243464,-0.070704,0.074144,0.243613,-0.072079,0.061144,0.244036,-0.073341,0.061144,0.244036,-0.073341,0.074144,0.243613,-0.072079,0.074144,0.244036,-0.073341,0.061144,0.244701,-0.074455,0.061144,0.244701,-0.074455,0.074144,0.244036,-0.073341,0.061144,0.244701,-0.074455,0.074144,0.244036,-0.073341,0.074144,0.244701,-0.074455,0.061144,0.245572,-0.075385,0.061144,0.245572,-0.075385,0.074144,0.244701,-0.074455,0.074144,0.245572,-0.075385,0.061144,0.246616,-0.076093,0.061144,0.246616,-0.076093,0.074144,0.245572,-0.075385,0.074144,0.246616,-0.076093,0.061144,0.2478,-0.076545,0.061144,0.2478,-0.076545,0.074144,0.246616,-0.076093,0.074144,0.2478,-0.076545,0.061144,0.249088,-0.076704,0.061144,0.249088,-0.076704,0.074144,0.2478,-0.076545,0.074144,0.249088,-0.076704,0.061144,0.295517,-0.076704,0.061144,0.295517,-0.076704,0.074144,0.249088,-0.076704,0.074144,0.295517,-0.076704,0.061144,0.296806,-0.076545,0.061144,0.296806,-0.076545,0.074144,0.295517,-0.076704,0.074144,0.296806,-0.076545,0.061144,0.297989,-0.076093,0.061144,0.297989,-0.076093,0.074144,0.296806,-0.076545,0.074144,0.297989,-0.076093,0.061144,0.299034,-0.075385,0.061144,0.299034,-0.075385,0.074144,0.297989,-0.076093,0.074144,0.299034,-0.075385,0.061144,0.299905,-0.074455,0.061144,0.299905,-0.074455,0.074144,0.299034,-0.075385,0.061144,0.299905,-0.074455,0.074144,0.299034,-0.075385,0.074144,0.299905,-0.074455,0.061144,0.300569,-0.073341,0.061144,0.300569,-0.073341,0.074144,0.299905,-0.074455,0.061144,0.300569,-0.073341,0.074144,0.299905,-0.074455,0.074144,0.300569,-0.073341,0.061144,0.300993,-0.072079,0.061144,0.300993,-0.072079,0.074144,0.300569,-0.073341,0.061144,0.300993,-0.072079,0.074144,0.300569,-0.073341,0.074144,0.300993,-0.072079,0.061144,0.301141,-0.070704,0.061144,0.301141,-0.070704,0.074144,0.300993,-0.072079,0.074144,0.301141,-0.070704,0.061144,0.301141,-0.025556,0.061144,0.301141,-0.025556,0.074144,0.301141,-0.070704,0.074144,0.301141,-0.025556,0.061144,0.300993,-0.024181,0.061144,0.300993,-0.024181,0.074144,0.301141,-0.025556,0.074144,0.300993,-0.024181,0.061144,0.300569,-0.022919,0.061144,0.300569,-0.022919,0.074144,0.300993,-0.024181,0.074144,0.300569,-0.022919,0.061144,0.299905,-0.021804,0.061144,0.299905,-0.021804,0.074144,0.300569,-0.022919,0.074144,0.299905,-0.021804,0.061144,0.299034,-0.020875,0.061144,0.299034,-0.020875,0.074144,0.299905,-0.021804,0.074144,0.299034,-0.020875,0.061144,0.297989,-0.020166,0.061144,0.297989,-0.020166,0.074144,0.299034,-0.020875,0.074144,0.297989,-0.020166,0.061144,0.296806,-0.019714,0.061144,0.296806,-0.019714,0.074144,0.297989,-0.020166,0.074144,0.296806,-0.019714,0.061144,0.295517,-0.019556,0.061144,0.295517,-0.019556,0.074144,0.296806,-0.019714,0.061144,0.295517,-0.019556,0.074144,0.296806,-0.019714,0.074144,0.369167,-0.019556,0.061144,0.322739,-0.019556,0.061144,0.322739,-0.019556,0.074144,0.369167,-0.019556,0.061144,0.322739,-0.019556,0.074144,0.369167,-0.019556,0.074144,0.322739,-0.019556,0.061144,0.32145,-0.019714,0.061144,0.32145,-0.019714,0.074144,0.322739,-0.019556,0.061144,0.32145,-0.019714,0.074144,0.322739,-0.019556,0.074144,0.32145,-0.019714,0.061144,0.320266,-0.020166,0.061144,0.320266,-0.020166,0.074144,0.32145,-0.019714,0.074144,0.320266,-0.020166,0.061144,0.319222,-0.020875,0.061144,0.319222,-0.020875,0.074144,0.320266,-0.020166,0.061144,0.319222,-0.020875,0.074144,0.320266,-0.020166,0.074144,0.319222,-0.020875,0.061144,0.318351,-0.021804,0.061144,0.318351,-0.021804,0.074144,0.319222,-0.020875,0.061144,0.318351,-0.021804,0.074144,0.319222,-0.020875,0.074144,0.318351,-0.021804,0.061144,0.317686,-0.022919,0.061144,0.317686,-0.022919,0.074144,0.318351,-0.021804,0.074144,0.317686,-0.022919,0.061144,0.317263,-0.024181,0.061144,0.317263,-0.024181,0.074144,0.317686,-0.022919,0.074144,0.317263,-0.024181,0.061144,0.317114,-0.025556,0.061144,0.317114,-0.025556,0.074144,0.317263,-0.024181,0.074144,0.317114,-0.025556,0.061144,0.317114,-0.070704,0.061144,0.317114,-0.070704,0.074144,0.317114,-0.025556,0.074144,0.317114,-0.070704,0.061144,0.317263,-0.072079,0.061144,0.317263,-0.072079,0.074144,0.317114,-0.070704,0.074144,0.317263,-0.072079,0.061144,0.317686,-0.073341,0.061144,0.317686,-0.073341,0.074144,0.317263,-0.072079,0.074144,0.317686,-0.073341,0.061144,0.318351,-0.074455,0.061144,0.318351,-0.074455,0.074144,0.317686,-0.073341,0.061144,0.318351,-0.074455,0.074144,0.317686,-0.073341,0.074144,0.318351,-0.074455,0.061144,0.319222,-0.075385,0.061144,0.319222,-0.075385,0.074144,0.318351,-0.074455,0.074144,0.319222,-0.075385,0.061144,0.320266,-0.076093,0.061144,0.320266,-0.076093,0.074144,0.319222,-0.075385,0.074144,0.320266,-0.076093,0.061144,0.32145,-0.076545,0.061144,0.32145,-0.076545,0.074144,0.320266,-0.076093,0.074144,0.32145,-0.076545,0.061144,0.322739,-0.076704,0.061144,0.322739,-0.076704,0.074144,0.32145,-0.076545,0.061144,0.322739,-0.076704,0.074144,0.32145,-0.076545,0.074144,0.322739,-0.076704,0.061144,0.369167,-0.076704,0.061144,0.369167,-0.076704,0.074144,0.322739,-0.076704,0.074144,0.369167,-0.076704,0.061144,0.370456,-0.076545,0.061144,0.370456,-0.076545,0.074144,0.369167,-0.076704,0.061144,0.370456,-0.076545,0.074144,0.369167,-0.076704,0.074144,0.370456,-0.076545,0.061144,0.371639,-0.076093,0.061144,0.371639,-0.076093,0.074144,0.370456,-0.076545,0.074144,0.371639,-0.076093,0.061144,0.372684,-0.075385,0.061144,0.372684,-0.075385,0.074144,0.371639,-0.076093,0.061144,0.372684,-0.075385,0.074144,0.371639,-0.076093,0.074144,0.372684,-0.075385,0.061144,0.373555,-0.074455,0.061144,0.373555,-0.074455,0.074144,0.372684,-0.075385,0.061144,0.373555,-0.074455,0.074144,0.372684,-0.075385,0.074144,0.373555,-0.074455,0.061144,0.374219,-0.073341,0.061144,0.374219,-0.073341,0.074144,0.373555,-0.074455,0.061144,0.374219,-0.073341,0.074144,0.373555,-0.074455,0.074144,0.374219,-0.073341,0.061144,0.374643,-0.072079,0.061144,0.374643,-0.072079,0.074144,0.374219,-0.073341,0.074144,0.374643,-0.072079,0.061144,0.374791,-0.070704,0.061144,0.374791,-0.070704,0.074144,0.374643,-0.072079,0.074144,0.374791,-0.070704,0.061144,0.374791,-0.025556,0.061144,0.374791,-0.025556,0.074144,0.374791,-0.070704,0.074144,0.374791,-0.025556,0.061144,0.374643,-0.024181,0.061144,0.374643,-0.024181,0.074144,0.374791,-0.025556,0.074144,0.374643,-0.024181,0.061144,0.374219,-0.022918,0.061144,0.374219,-0.022919,0.074144,0.374643,-0.024181,0.061144,0.374219,-0.022919,0.074144,0.374643,-0.024181,0.074144,0.374219,-0.022918,0.061144,0.373555,-0.021804,0.061144,0.373555,-0.021804,0.074144,0.374219,-0.022919,0.074144,0.373555,-0.021804,0.061144,0.372684,-0.020875,0.061144,0.372684,-0.020875,0.074144,0.373555,-0.021804,0.061144,0.372684,-0.020875,0.074144,0.373555,-0.021804,0.074144,0.372684,-0.020875,0.061144,0.371639,-0.020166,0.061144,0.371639,-0.020166,0.074144,0.372684,-0.020875,0.061144,0.371639,-0.020166,0.074144,0.372684,-0.020875,0.074144,0.371639,-0.020166,0.061144,0.370456,-0.019714,0.061144,0.370456,-0.019714,0.074144,0.371639,-0.020166,0.061144,0.370456,-0.019714,0.074144,0.371639,-0.020166,0.074144,0.370456,-0.019714,0.061144,0.369167,-0.019556,0.061144,0.369167,-0.019556,0.074144,0.370456,-0.019714,0.074144,0.442817,-0.019556,0.061144,0.396389,-0.019556,0.061144,0.396389,-0.019556,0.074144,0.442817,-0.019556,0.061144,0.396389,-0.019556,0.074144,0.442817,-0.019556,0.074144,0.396389,-0.019556,0.061144,0.3951,-0.019714,0.061144,0.3951,-0.019714,0.074144,0.396389,-0.019556,0.061144,0.3951,-0.019714,0.074144,0.396389,-0.019556,0.074144,0.3951,-0.019714,0.061144,0.393917,-0.020166,0.061144,0.393917,-0.020166,0.074144,0.3951,-0.019714,0.074144,0.393917,-0.020166,0.061144,0.392872,-0.020875,0.061144,0.392872,-0.020875,0.074144,0.393917,-0.020166,0.074144,0.392872,-0.020875,0.061144,0.392001,-0.021804,0.061144,0.392001,-0.021804,0.074144,0.392872,-0.020875,0.074144,0.392001,-0.021804,0.061144,0.391337,-0.022919,0.061144,0.391337,-0.022919,0.074144,0.392001,-0.021804,0.074144,0.391337,-0.022919,0.061144,0.390913,-0.024181,0.061144,0.390913,-0.024181,0.074144,0.391337,-0.022919,0.074144,0.390913,-0.024181,0.061144,0.390765,-0.025556,0.061144,0.390765,-0.025556,0.074144,0.390913,-0.024181,0.074144,0.390765,-0.025556,0.061144,0.390765,-0.070704,0.061144,0.390765,-0.070704,0.074144,0.390765,-0.025556,0.074144,0.390765,-0.070704,0.061144,0.390913,-0.072079,0.061144,0.390913,-0.072079,0.074144,0.390765,-0.070704,0.074144,0.390913,-0.072079,0.061144,0.391337,-0.073341,0.061144,0.391337,-0.073341,0.074144,0.390913,-0.072079,0.074144,0.391337,-0.073341,0.061144,0.392001,-0.074455,0.061144,0.392001,-0.074455,0.074144,0.391337,-0.073341,0.074144,0.392001,-0.074455,0.061144,0.392872,-0.075385,0.061144,0.392872,-0.075385,0.074144,0.392001,-0.074455,0.074144,0.392872,-0.075385,0.061144,0.393917,-0.076093,0.061144,0.393917,-0.076093,0.074144,0.392872,-0.075385,0.074144,0.393917,-0.076093,0.061144,0.3951,-0.076545,0.061144,0.3951,-0.076545,0.074144,0.393917,-0.076093,0.074144,0.3951,-0.076545,0.061144,0.396389,-0.076704,0.061144,0.396389,-0.076704,0.074144,0.3951,-0.076545,0.074144,0.396389,-0.076704,0.061144,0.442817,-0.076704,0.061144,0.442817,-0.076704,0.074144,0.396389,-0.076704,0.061144,0.442817,-0.076704,0.074144,0.396389,-0.076704,0.074144,0.442817,-0.076704,0.061144,0.444106,-0.076545,0.061144,0.444106,-0.076545,0.074144,0.442817,-0.076704,0.061144,0.444106,-0.076545,0.074144,0.442817,-0.076704,0.074144,0.444106,-0.076545,0.061144,0.44529,-0.076093,0.061144,0.44529,-0.076093,0.074144,0.444106,-0.076545,0.074144,0.44529,-0.076093,0.061144,0.446334,-0.075385,0.061144,0.446334,-0.075385,0.074144,0.44529,-0.076093,0.061144,0.446334,-0.075385,0.074144,0.44529,-0.076093,0.074144,0.446334,-0.075385,0.061144,0.447205,-0.074455,0.061144,0.447205,-0.074455,0.074144,0.446334,-0.075385,0.061144,0.447205,-0.074455,0.074144,0.446334,-0.075385,0.074144,0.447205,-0.074455,0.061144,0.447869,-0.073341,0.061144,0.447869,-0.073341,0.074144,0.447205,-0.074455,0.061144,0.447869,-0.073341,0.074144,0.447205,-0.074455,0.074144,0.447869,-0.073341,0.061144,0.448293,-0.072079,0.061144,0.448293,-0.072079,0.074144,0.447869,-0.073341,0.074144,0.448293,-0.072079,0.061144,0.448442,-0.070704,0.061144,0.448442,-0.070704,0.074144,0.448293,-0.072079,0.061144,0.448442,-0.070704,0.074144,0.448293,-0.072079,0.074144,0.448442,-0.070704,0.061144,0.448442,-0.025556,0.061144,0.448442,-0.025556,0.074144,0.448442,-0.070704,0.074144,0.448442,-0.025556,0.061144,0.448293,-0.024181,0.061144,0.448293,-0.024181,0.074144,0.448442,-0.025556,0.074144,0.448293,-0.024181,0.061144,0.447869,-0.022918,0.061144,0.447869,-0.022918,0.074144,0.448293,-0.024181,0.061144,0.447869,-0.022918,0.074144,0.448293,-0.024181,0.074144,0.447869,-0.022918,0.061144,0.447205,-0.021804,0.061144,0.447205,-0.021804,0.074144,0.447869,-0.022918,0.061144,0.447205,-0.021804,0.074144,0.447869,-0.022918,0.074144,0.447205,-0.021804,0.061144,0.446334,-0.020875,0.061144,0.446334,-0.020875,0.074144,0.447205,-0.021804,0.061144,0.446334,-0.020875,0.074144,0.447205,-0.021804,0.074144,0.446334,-0.020875,0.061144,0.44529,-0.020166,0.061144,0.44529,-0.020166,0.074144,0.446334,-0.020875,0.061144,0.44529,-0.020166,0.074144,0.446334,-0.020875,0.074144,0.44529,-0.020166,0.061144,0.444106,-0.019714,0.061144,0.444106,-0.019714,0.074144,0.44529,-0.020166,0.061144,0.444106,-0.019714,0.074144,0.44529,-0.020166,0.074144,0.444106,-0.019714,0.061144,0.442817,-0.019556,0.061144,0.442817,-0.019556,0.074144,0.444106,-0.019714,0.074144,-0.247372,-0.019556,0.061144,-0.314423,-0.019556,0.061144,-0.314423,-0.019556,0.074144,-0.247372,-0.019556,0.074144,-0.314423,-0.019556,0.061144,-0.315711,-0.019715,0.061144,-0.315711,-0.019715,0.074144,-0.314423,-0.019556,0.074144,-0.315711,-0.019715,0.061144,-0.316895,-0.020166,0.061144,-0.316895,-0.020166,0.074144,-0.315711,-0.019715,0.074144,-0.316895,-0.020166,0.061144,-0.317939,-0.020875,0.061144,-0.317939,-0.020875,0.074144,-0.316895,-0.020166,0.061144,-0.317939,-0.020875,0.074144,-0.316895,-0.020166,0.074144,-0.317939,-0.020875,0.061144,-0.31881,-0.021804,0.061144,-0.31881,-0.021804,0.074144,-0.317939,-0.020875,0.061144,-0.31881,-0.021804,0.074144,-0.317939,-0.020875,0.074144,-0.31881,-0.021804,0.061144,-0.319475,-0.022919,0.061144,-0.319475,-0.022919,0.074144,-0.31881,-0.021804,0.061144,-0.319475,-0.022919,0.074144,-0.31881,-0.021804,0.074144,-0.319475,-0.022919,0.061144,-0.319898,-0.024181,0.061144,-0.319898,-0.024181,0.074144,-0.319475,-0.022919,0.074144,-0.319898,-0.024181,0.061144,-0.320047,-0.025556,0.061144,-0.320047,-0.025556,0.074144,-0.319898,-0.024181,0.074144,-0.320047,-0.025556,0.061144,-0.320047,-0.070704,0.061144,-0.320047,-0.070704,0.074144,-0.320047,-0.025556,0.074144,-0.320047,-0.070704,0.061144,-0.319898,-0.072079,0.061144,-0.319898,-0.072079,0.074144,-0.320047,-0.070704,0.061144,-0.319898,-0.072079,0.074144,-0.320047,-0.070704,0.074144,-0.319898,-0.072079,0.061144,-0.319475,-0.073341,0.061144,-0.319475,-0.073341,0.074144,-0.319898,-0.072079,0.074144,-0.319475,-0.073341,0.061144,-0.31881,-0.074455,0.061144,-0.31881,-0.074455,0.074144,-0.319475,-0.073341,0.061144,-0.31881,-0.074455,0.074144,-0.319475,-0.073341,0.074144,-0.31881,-0.074455,0.061144,-0.317939,-0.075385,0.061144,-0.317939,-0.075385,0.074144,-0.31881,-0.074455,0.074144,-0.317939,-0.075385,0.061144,-0.316895,-0.076094,0.061144,-0.316895,-0.076094,0.074144,-0.317939,-0.075385,0.074144,-0.316895,-0.076094,0.061144,-0.315711,-0.076545,0.061144,-0.315711,-0.076545,0.074144,-0.316895,-0.076094,0.074144,-0.315711,-0.076545,0.061144,-0.314422,-0.076704,0.061144,-0.314422,-0.076704,0.074144,-0.315711,-0.076545,0.074144,-0.314422,-0.076704,0.061144,-0.247372,-0.076704,0.061144,-0.247372,-0.076704,0.074144,-0.314422,-0.076704,0.074144,-0.247372,-0.076704,0.061144,-0.246083,-0.076545,0.061144,-0.246083,-0.076545,0.074144,-0.247372,-0.076704,0.074144,-0.246083,-0.076545,0.061144,-0.2449,-0.076094,0.061144,-0.2449,-0.076094,0.074144,-0.246083,-0.076545,0.074144,-0.2449,-0.076094,0.061144,-0.243855,-0.075385,0.061144,-0.243855,-0.075385,0.074144,-0.2449,-0.076094,0.061144,-0.243855,-0.075385,0.074144,-0.2449,-0.076094,0.074144,-0.243855,-0.075385,0.061144,-0.242984,-0.074455,0.061144,-0.242984,-0.074455,0.074144,-0.243855,-0.075385,0.061144,-0.242984,-0.074455,0.074144,-0.243855,-0.075385,0.074144,-0.242984,-0.074455,0.061144,-0.24232,-0.073341,0.061144,-0.24232,-0.073341,0.074144,-0.242984,-0.074455,0.061144,-0.24232,-0.073341,0.074144,-0.242984,-0.074455,0.074144,-0.24232,-0.073341,0.061144,-0.241896,-0.072079,0.061144,-0.241896,-0.072079,0.074144,-0.24232,-0.073341,0.074144,-0.241896,-0.072079,0.061144,-0.241748,-0.070704,0.061144,-0.241748,-0.070704,0.074144,-0.241896,-0.072079,0.061144,-0.241748,-0.070704,0.074144,-0.241896,-0.072079,0.074144,-0.241748,-0.070704,0.061144,-0.241748,-0.025556,0.061144,-0.241748,-0.025556,0.074144,-0.241748,-0.070704,0.074144,-0.241748,-0.025556,0.061144,-0.241896,-0.024181,0.061144,-0.241896,-0.024181,0.074144,-0.241748,-0.025556,0.074144,-0.241896,-0.024181,0.061144,-0.24232,-0.022919,0.061144,-0.24232,-0.022919,0.074144,-0.241896,-0.024181,0.061144,-0.24232,-0.022919,0.074144,-0.241896,-0.024181,0.074144,-0.24232,-0.022919,0.061144,-0.242984,-0.021804,0.061144,-0.242984,-0.021804,0.074144,-0.24232,-0.022919,0.061144,-0.242984,-0.021804,0.074144,-0.24232,-0.022919,0.074144,-0.242984,-0.021804,0.061144,-0.243855,-0.020875,0.061144,-0.243855,-0.020875,0.074144,-0.242984,-0.021804,0.061144,-0.243855,-0.020875,0.074144,-0.242984,-0.021804,0.074144,-0.243855,-0.020875,0.061144,-0.2449,-0.020166,0.061144,-0.2449,-0.020166,0.074144,-0.243855,-0.020875,0.061144,-0.2449,-0.020166,0.074144,-0.243855,-0.020875,0.074144,-0.2449,-0.020166,0.061144,-0.246083,-0.019715,0.061144,-0.246083,-0.019715,0.074144,-0.2449,-0.020166,0.061144,-0.246083,-0.019715,0.074144,-0.2449,-0.020166,0.074144,-0.246083,-0.019715,0.061144,-0.247372,-0.019556,0.061144,-0.247372,-0.019556,0.074144,-0.246083,-0.019715,0.074144,-0.41671,-0.047125,0.061144,-0.463138,-0.047125,0.061144,-0.463138,-0.047125,0.074144,-0.41671,-0.047125,0.074144,-0.463138,-0.047125,0.061144,-0.464427,-0.047283,0.061144,-0.464427,-0.047283,0.074144,-0.463138,-0.047125,0.061144,-0.464427,-0.047283,0.074144,-0.463138,-0.047125,0.074144,-0.464427,-0.047283,0.061144,-0.465611,-0.047735,0.061144,-0.465611,-0.047735,0.074144,-0.464427,-0.047283,0.061144,-0.465611,-0.047735,0.074144,-0.464427,-0.047283,0.074144,-0.465611,-0.047735,0.061144,-0.466655,-0.048444,0.061144,-0.466655,-0.048444,0.074144,-0.465611,-0.047735,0.074144,-0.466655,-0.048444,0.061144,-0.467526,-0.049373,0.061144,-0.467526,-0.049373,0.074144,-0.466655,-0.048444,0.074144,-0.467526,-0.049373,0.061144,-0.46819,-0.050487,0.061144,-0.46819,-0.050487,0.074144,-0.467526,-0.049373,0.074144,-0.46819,-0.050487,0.061144,-0.468614,-0.05175,0.061144,-0.468614,-0.05175,0.074144,-0.46819,-0.050487,0.061144,-0.468614,-0.05175,0.074144,-0.46819,-0.050487,0.074144,-0.468614,-0.05175,0.061144,-0.468763,-0.053125,0.061144,-0.468763,-0.053125,0.074144,-0.468614,-0.05175,0.074144,-0.468763,-0.053125,0.061144,-0.468763,-0.070273,0.061144,-0.468763,-0.070273,0.074144,-0.468763,-0.053125,0.074144,-0.468763,-0.070273,0.061144,-0.468614,-0.071647,0.061144,-0.468614,-0.071647,0.074144,-0.468763,-0.070273,0.074144,-0.468614,-0.071647,0.061144,-0.46819,-0.07291,0.061144,-0.46819,-0.07291,0.074144,-0.468614,-0.071647,0.061144,-0.46819,-0.07291,0.074144,-0.468614,-0.071647,0.074144,-0.46819,-0.07291,0.061144,-0.467526,-0.074024,0.061144,-0.467526,-0.074024,0.074144,-0.46819,-0.07291,0.061144,-0.467526,-0.074024,0.074144,-0.46819,-0.07291,0.074144,-0.467526,-0.074024,0.061144,-0.466655,-0.074954,0.061144,-0.466655,-0.074954,0.074144,-0.467526,-0.074024,0.061144,-0.466655,-0.074954,0.074144,-0.467526,-0.074024,0.074144,-0.466655,-0.074954,0.061144,-0.465611,-0.075662,0.061144,-0.465611,-0.075662,0.074144,-0.466655,-0.074954,0.074144,-0.465611,-0.075662,0.061144,-0.464427,-0.076114,0.061144,-0.464427,-0.076114,0.074144,-0.465611,-0.075662,0.074144,-0.464427,-0.076114,0.061144,-0.463138,-0.076273,0.061144,-0.463138,-0.076273,0.074144,-0.464427,-0.076114,0.074144,-0.463138,-0.076273,0.061144,-0.41671,-0.076273,0.061144,-0.41671,-0.076273,0.074144,-0.463138,-0.076273,0.074144,-0.41671,-0.076273,0.061144,-0.415421,-0.076114,0.061144,-0.415421,-0.076114,0.074144,-0.41671,-0.076273,0.074144,-0.415421,-0.076114,0.061144,-0.414238,-0.075662,0.061144,-0.414238,-0.075662,0.074144,-0.415421,-0.076114,0.061144,-0.414238,-0.075662,0.074144,-0.415421,-0.076114,0.074144,-0.414238,-0.075662,0.061144,-0.413193,-0.074954,0.061144,-0.413193,-0.074954,0.074144,-0.414238,-0.075662,0.074144,-0.413193,-0.074954,0.061144,-0.412322,-0.074024,0.061144,-0.412322,-0.074024,0.074144,-0.413193,-0.074954,0.061144,-0.412322,-0.074024,0.074144,-0.413193,-0.074954,0.074144,-0.412322,-0.074024,0.061144,-0.411658,-0.07291,0.061144,-0.411658,-0.07291,0.074144,-0.412322,-0.074024,0.074144,-0.411658,-0.07291,0.061144,-0.411234,-0.071647,0.061144,-0.411234,-0.071647,0.074144,-0.411658,-0.07291,0.074144,-0.411234,-0.071647,0.061144,-0.411085,-0.070273,0.061144,-0.411085,-0.070273,0.074144,-0.411234,-0.071647,0.074144,-0.411085,-0.070273,0.061144,-0.411085,-0.053125,0.061144,-0.411085,-0.053125,0.074144,-0.411085,-0.070273,0.074144,-0.411085,-0.053125,0.061144,-0.411234,-0.05175,0.061144,-0.411234,-0.05175,0.074144,-0.411085,-0.053125,0.061144,-0.411234,-0.05175,0.074144,-0.411085,-0.053125,0.074144,-0.411234,-0.05175,0.061144,-0.411658,-0.050487,0.061144,-0.411658,-0.050487,0.074144,-0.411234,-0.05175,0.061144,-0.411658,-0.050487,0.074144,-0.411234,-0.05175,0.074144,-0.411658,-0.050487,0.061144,-0.412322,-0.049373,0.061144,-0.412322,-0.049373,0.074144,-0.411658,-0.050487,0.074144,-0.412322,-0.049373,0.061144,-0.413193,-0.048444,0.061144,-0.413193,-0.048444,0.074144,-0.412322,-0.049373,0.061144,-0.413193,-0.048444,0.074144,-0.412322,-0.049373,0.074144,-0.413193,-0.048444,0.061144,-0.414237,-0.047735,0.061144,-0.414237,-0.047735,0.074144,-0.413193,-0.048444,0.061144,-0.414237,-0.047735,0.074144,-0.413193,-0.048444,0.074144,-0.414237,-0.047735,0.061144,-0.415421,-0.047283,0.061144,-0.415421,-0.047283,0.074144,-0.414237,-0.047735,0.061144,-0.415421,-0.047283,0.074144,-0.414237,-0.047735,0.074144,-0.415421,-0.047283,0.061144,-0.41671,-0.047125,0.061144,-0.41671,-0.047125,0.074144,-0.415421,-0.047283,0.074144,-0.489191,-0.047125,0.061144,-0.535619,-0.047125,0.061144,-0.535619,-0.047125,0.074144,-0.489191,-0.047125,0.074144,-0.535619,-0.047125,0.061144,-0.536908,-0.047283,0.061144,-0.536908,-0.047283,0.074144,-0.535619,-0.047125,0.061144,-0.536908,-0.047283,0.074144,-0.535619,-0.047125,0.074144,-0.536908,-0.047283,0.061144,-0.538091,-0.047735,0.061144,-0.538091,-0.047735,0.074144,-0.536908,-0.047283,0.061144,-0.538091,-0.047735,0.074144,-0.536908,-0.047283,0.074144,-0.538091,-0.047735,0.061144,-0.539136,-0.048444,0.061144,-0.539136,-0.048444,0.074144,-0.538091,-0.047735,0.061144,-0.539136,-0.048444,0.074144,-0.538091,-0.047735,0.074144,-0.539136,-0.048444,0.061144,-0.540007,-0.049373,0.061144,-0.540007,-0.049373,0.074144,-0.539136,-0.048444,0.074144,-0.540007,-0.049373,0.061144,-0.540671,-0.050487,0.061144,-0.540671,-0.050487,0.074144,-0.540007,-0.049373,0.061144,-0.540671,-0.050487,0.074144,-0.540007,-0.049373,0.074144,-0.540671,-0.050487,0.061144,-0.541095,-0.05175,0.061144,-0.541095,-0.05175,0.074144,-0.540671,-0.050487,0.074144,-0.541095,-0.05175,0.061144,-0.541243,-0.053125,0.061144,-0.541243,-0.053125,0.074144,-0.541095,-0.05175,0.061144,-0.541243,-0.053125,0.074144,-0.541095,-0.05175,0.074144,-0.541243,-0.053125,0.061144,-0.541243,-0.070273,0.061144,-0.541243,-0.070273,0.074144,-0.541243,-0.053125,0.074144,-0.541243,-0.070273,0.061144,-0.541095,-0.071647,0.061144,-0.541095,-0.071647,0.074144,-0.541243,-0.070273,0.074144,-0.541095,-0.071647,0.061144,-0.540671,-0.07291,0.061144,-0.540671,-0.07291,0.074144,-0.541095,-0.071647,0.074144,-0.540671,-0.07291,0.061144,-0.540007,-0.074024,0.061144,-0.540007,-0.074024,0.074144,-0.540671,-0.07291,0.074144,-0.540007,-0.074024,0.061144,-0.539136,-0.074954,0.061144,-0.539136,-0.074954,0.074144,-0.540007,-0.074024,0.074144,-0.539136,-0.074954,0.061144,-0.538091,-0.075662,0.061144,-0.538091,-0.075662,0.074144,-0.539136,-0.074954,0.061144,-0.538091,-0.075662,0.074144,-0.539136,-0.074954,0.074144,-0.538091,-0.075662,0.061144,-0.536908,-0.076114,0.061144,-0.536908,-0.076114,0.074144,-0.538091,-0.075662,0.074144,-0.536908,-0.076114,0.061144,-0.535619,-0.076273,0.061144,-0.535619,-0.076273,0.074144,-0.536908,-0.076114,0.061144,-0.535619,-0.076273,0.074144,-0.536908,-0.076114,0.074144,-0.535619,-0.076273,0.061144,-0.489191,-0.076273,0.061144,-0.489191,-0.076273,0.074144,-0.535619,-0.076273,0.074144,-0.489191,-0.076273,0.061144,-0.487902,-0.076114,0.061144,-0.487902,-0.076114,0.074144,-0.489191,-0.076273,0.074144,-0.487902,-0.076114,0.061144,-0.486718,-0.075662,0.061144,-0.486718,-0.075662,0.074144,-0.487902,-0.076114,0.074144,-0.486718,-0.075662,0.061144,-0.485674,-0.074954,0.061144,-0.485674,-0.074954,0.074144,-0.486718,-0.075662,0.074144,-0.485674,-0.074954,0.061144,-0.484803,-0.074024,0.061144,-0.484803,-0.074024,0.074144,-0.485674,-0.074954,0.074144,-0.484803,-0.074024,0.061144,-0.484139,-0.07291,0.061144,-0.484139,-0.07291,0.074144,-0.484803,-0.074024,0.074144,-0.484139,-0.07291,0.061144,-0.483715,-0.071647,0.061144,-0.483715,-0.071647,0.074144,-0.484139,-0.07291,0.061144,-0.483715,-0.071647,0.074144,-0.484139,-0.07291,0.074144,-0.483715,-0.071647,0.061144,-0.483566,-0.070273,0.061144,-0.483566,-0.070273,0.074144,-0.483715,-0.071647,0.074144,-0.483566,-0.070273,0.061144,-0.483566,-0.053125,0.061144,-0.483566,-0.053125,0.074144,-0.483566,-0.070273,0.074144,-0.483566,-0.053125,0.061144,-0.483715,-0.05175,0.061144,-0.483715,-0.05175,0.074144,-0.483566,-0.053125,0.061144,-0.483715,-0.05175,0.074144,-0.483566,-0.053125,0.074144,-0.483715,-0.05175,0.061144,-0.484139,-0.050487,0.061144,-0.484139,-0.050487,0.074144,-0.483715,-0.05175,0.061144,-0.484139,-0.050487,0.074144,-0.483715,-0.05175,0.074144,-0.484139,-0.050487,0.061144,-0.484803,-0.049373,0.061144,-0.484803,-0.049373,0.074144,-0.484139,-0.050487,0.061144,-0.484803,-0.049373,0.074144,-0.484139,-0.050487,0.074144,-0.484803,-0.049373,0.061144,-0.485674,-0.048444,0.061144,-0.485674,-0.048444,0.074144,-0.484803,-0.049373,0.061144,-0.485674,-0.048444,0.074144,-0.484803,-0.049373,0.074144,-0.485674,-0.048444,0.061144,-0.486718,-0.047735,0.061144,-0.486718,-0.047735,0.074144,-0.485674,-0.048444,0.061144,-0.486718,-0.047735,0.074144,-0.485674,-0.048444,0.074144,-0.486718,-0.047735,0.061144,-0.487902,-0.047283,0.061144,-0.487902,-0.047283,0.074144,-0.486718,-0.047735,0.061144,-0.487902,-0.047283,0.074144,-0.486718,-0.047735,0.074144,-0.487902,-0.047283,0.061144,-0.489191,-0.047125,0.061144,-0.489191,-0.047125,0.074144,-0.487902,-0.047283,0.061144,-0.489191,-0.047125,0.074144,-0.487902,-0.047283,0.074144,-0.561671,-0.047125,0.061144,-0.6081,-0.047125,0.061144,-0.6081,-0.047125,0.074144,-0.561671,-0.047125,0.074144,-0.6081,-0.047125,0.061144,-0.609389,-0.047283,0.061144,-0.609389,-0.047283,0.074144,-0.6081,-0.047125,0.074144,-0.609389,-0.047283,0.061144,-0.610572,-0.047735,0.061144,-0.610572,-0.047735,0.074144,-0.609389,-0.047283,0.074144,-0.610572,-0.047735,0.061144,-0.611617,-0.048444,0.061144,-0.611617,-0.048444,0.074144,-0.610572,-0.047735,0.061144,-0.611617,-0.048444,0.074144,-0.610572,-0.047735,0.074144,-0.611617,-0.048444,0.061144,-0.612488,-0.049373,0.061144,-0.612488,-0.049373,0.074144,-0.611617,-0.048444,0.061144,-0.612488,-0.049373,0.074144,-0.611617,-0.048444,0.074144,-0.612488,-0.049373,0.061144,-0.613152,-0.050487,0.061144,-0.613152,-0.050487,0.074144,-0.612488,-0.049373,0.061144,-0.613152,-0.050487,0.074144,-0.612488,-0.049373,0.074144,-0.613152,-0.050487,0.061144,-0.613576,-0.05175,0.061144,-0.613576,-0.05175,0.074144,-0.613152,-0.050487,0.074144,-0.613576,-0.05175,0.061144,-0.613724,-0.053125,0.061144,-0.613724,-0.053125,0.074144,-0.613576,-0.05175,0.061144,-0.613724,-0.053125,0.074144,-0.613576,-0.05175,0.074144,-0.613724,-0.053125,0.061144,-0.613724,-0.070273,0.061144,-0.613724,-0.070273,0.074144,-0.613724,-0.053125,0.074144,-0.613724,-0.070273,0.061144,-0.613576,-0.071647,0.061144,-0.613576,-0.071647,0.074144,-0.613724,-0.070273,0.074144,-0.613576,-0.071647,0.061144,-0.613152,-0.07291,0.061144,-0.613152,-0.07291,0.074144,-0.613576,-0.071647,0.061144,-0.613152,-0.07291,0.074144,-0.613576,-0.071647,0.074144,-0.613152,-0.07291,0.061144,-0.612488,-0.074024,0.061144,-0.612488,-0.074024,0.074144,-0.613152,-0.07291,0.074144,-0.612488,-0.074024,0.061144,-0.611617,-0.074954,0.061144,-0.611617,-0.074954,0.074144,-0.612488,-0.074024,0.074144,-0.611617,-0.074954,0.061144,-0.610572,-0.075662,0.061144,-0.610572,-0.075662,0.074144,-0.611617,-0.074954,0.074144,-0.610572,-0.075662,0.061144,-0.609389,-0.076114,0.061144,-0.609389,-0.076114,0.074144,-0.610572,-0.075662,0.074144,-0.609389,-0.076114,0.061144,-0.6081,-0.076273,0.061144,-0.6081,-0.076273,0.074144,-0.609389,-0.076114,0.061144,-0.6081,-0.076273,0.074144,-0.609389,-0.076114,0.074144,-0.6081,-0.076273,0.061144,-0.561671,-0.076273,0.061144,-0.561671,-0.076273,0.074144,-0.6081,-0.076273,0.074144,-0.561671,-0.076273,0.061144,-0.560383,-0.076114,0.061144,-0.560383,-0.076114,0.074144,-0.561671,-0.076273,0.061144,-0.560383,-0.076114,0.074144,-0.561671,-0.076273,0.074144,-0.560383,-0.076114,0.061144,-0.559199,-0.075662,0.061144,-0.559199,-0.075662,0.074144,-0.560383,-0.076114,0.074144,-0.559199,-0.075662,0.061144,-0.558155,-0.074954,0.061144,-0.558155,-0.074954,0.074144,-0.559199,-0.075662,0.074144,-0.558155,-0.074954,0.061144,-0.557284,-0.074024,0.061144,-0.557284,-0.074024,0.074144,-0.558155,-0.074954,0.074144,-0.557284,-0.074024,0.061144,-0.556619,-0.07291,0.061144,-0.556619,-0.07291,0.074144,-0.557284,-0.074024,0.061144,-0.556619,-0.07291,0.074144,-0.557284,-0.074024,0.074144,-0.556619,-0.07291,0.061144,-0.556196,-0.071647,0.061144,-0.556196,-0.071647,0.074144,-0.556619,-0.07291,0.061144,-0.556196,-0.071647,0.074144,-0.556619,-0.07291,0.074144,-0.556196,-0.071647,0.061144,-0.556047,-0.070273,0.061144,-0.556047,-0.070273,0.074144,-0.556196,-0.071647,0.074144,-0.556047,-0.070273,0.061144,-0.556047,-0.053125,0.061144,-0.556047,-0.053125,0.074144,-0.556047,-0.070273,0.074144,-0.556047,-0.053125,0.061144,-0.556196,-0.05175,0.061144,-0.556196,-0.05175,0.074144,-0.556047,-0.053125,0.074144,-0.556196,-0.05175,0.061144,-0.55662,-0.050487,0.061144,-0.55662,-0.050487,0.074144,-0.556196,-0.05175,0.061144,-0.55662,-0.050487,0.074144,-0.556196,-0.05175,0.074144,-0.55662,-0.050487,0.061144,-0.557284,-0.049373,0.061144,-0.557284,-0.049373,0.074144,-0.55662,-0.050487,0.061144,-0.557284,-0.049373,0.074144,-0.55662,-0.050487,0.074144,-0.557284,-0.049373,0.061144,-0.558155,-0.048444,0.061144,-0.558155,-0.048444,0.074144,-0.557284,-0.049373,0.074144,-0.558155,-0.048444,0.061144,-0.559199,-0.047735,0.061144,-0.559199,-0.047735,0.074144,-0.558155,-0.048444,0.074144,-0.559199,-0.047735,0.061144,-0.560383,-0.047283,0.061144,-0.560383,-0.047283,0.074144,-0.559199,-0.047735,0.074144,-0.560383,-0.047283,0.061144,-0.561671,-0.047125,0.061144,-0.561671,-0.047125,0.074144,-0.560383,-0.047283,0.061144,-0.561671,-0.047125,0.074144,-0.560383,-0.047283,0.074144,-0.489191,-0.017433,0.061144,-0.535619,-0.017433,0.061144,-0.535619,-0.017433,0.074144,-0.489191,-0.017433,0.074144,-0.535619,-0.017433,0.061144,-0.536908,-0.017592,0.061144,-0.536908,-0.017592,0.074144,-0.535619,-0.017433,0.061144,-0.536908,-0.017592,0.074144,-0.535619,-0.017433,0.074144,-0.536908,-0.017592,0.061144,-0.538091,-0.018043,0.061144,-0.538091,-0.018043,0.074144,-0.536908,-0.017592,0.061144,-0.538091,-0.018043,0.074144,-0.536908,-0.017592,0.074144,-0.538091,-0.018043,0.061144,-0.539136,-0.018752,0.061144,-0.539136,-0.018752,0.074144,-0.538091,-0.018043,0.074144,-0.539136,-0.018752,0.061144,-0.540007,-0.019681,0.061144,-0.540007,-0.019681,0.074144,-0.539136,-0.018752,0.061144,-0.540007,-0.019681,0.074144,-0.539136,-0.018752,0.074144,-0.540007,-0.019681,0.061144,-0.540671,-0.020796,0.061144,-0.540671,-0.020796,0.074144,-0.540007,-0.019681,0.061144,-0.540671,-0.020796,0.074144,-0.540007,-0.019681,0.074144,-0.540671,-0.020796,0.061144,-0.541095,-0.022058,0.061144,-0.541095,-0.022058,0.074144,-0.540671,-0.020796,0.074144,-0.541095,-0.022058,0.061144,-0.541243,-0.023433,0.061144,-0.541243,-0.023433,0.074144,-0.541095,-0.022058,0.074144,-0.541243,-0.023433,0.061144,-0.541243,-0.040581,0.061144,-0.541243,-0.040581,0.074144,-0.541243,-0.023433,0.074144,-0.541243,-0.040581,0.061144,-0.541095,-0.041956,0.061144,-0.541095,-0.041956,0.074144,-0.541243,-0.040581,0.061144,-0.541095,-0.041956,0.074144,-0.541243,-0.040581,0.074144,-0.541095,-0.041956,0.061144,-0.540671,-0.043218,0.061144,-0.540671,-0.043218,0.074144,-0.541095,-0.041956,0.061144,-0.540671,-0.043218,0.074144,-0.541095,-0.041956,0.074144,-0.540671,-0.043218,0.061144,-0.540007,-0.044332,0.061144,-0.540007,-0.044332,0.074144,-0.540671,-0.043218,0.061144,-0.540007,-0.044332,0.074144,-0.540671,-0.043218,0.074144,-0.540007,-0.044332,0.061144,-0.539136,-0.045262,0.061144,-0.539136,-0.045262,0.074144,-0.540007,-0.044332,0.061144,-0.539136,-0.045262,0.074144,-0.540007,-0.044332,0.074144,-0.539136,-0.045262,0.061144,-0.538091,-0.045971,0.061144,-0.538091,-0.045971,0.074144,-0.539136,-0.045262,0.074144,-0.538091,-0.045971,0.061144,-0.536908,-0.046422,0.061144,-0.536908,-0.046422,0.074144,-0.538091,-0.045971,0.074144,-0.536908,-0.046422,0.061144,-0.535619,-0.046581,0.061144,-0.535619,-0.046581,0.074144,-0.536908,-0.046422,0.074144,-0.535619,-0.046581,0.061144,-0.489191,-0.046581,0.061144,-0.489191,-0.046581,0.074144,-0.535619,-0.046581,0.074144,-0.489191,-0.046581,0.061144,-0.487902,-0.046422,0.061144,-0.487902,-0.046422,0.074144,-0.489191,-0.046581,0.074144,-0.487902,-0.046422,0.061144,-0.486718,-0.045971,0.061144,-0.486718,-0.045971,0.074144,-0.487902,-0.046422,0.074144,-0.486718,-0.045971,0.061144,-0.485674,-0.045262,0.061144,-0.485674,-0.045262,0.074144,-0.486718,-0.045971,0.061144,-0.485674,-0.045262,0.074144,-0.486718,-0.045971,0.074144,-0.485674,-0.045262,0.061144,-0.484803,-0.044332,0.061144,-0.484803,-0.044332,0.074144,-0.485674,-0.045262,0.061144,-0.484803,-0.044332,0.074144,-0.485674,-0.045262,0.074144,-0.484803,-0.044332,0.061144,-0.484139,-0.043218,0.061144,-0.484139,-0.043218,0.074144,-0.484803,-0.044332,0.074144,-0.484139,-0.043218,0.061144,-0.483715,-0.041956,0.061144,-0.483715,-0.041956,0.074144,-0.484139,-0.043218,0.061144,-0.483715,-0.041956,0.074144,-0.484139,-0.043218,0.074144,-0.483715,-0.041956,0.061144,-0.483566,-0.040581,0.061144,-0.483566,-0.040581,0.074144,-0.483715,-0.041956,0.074144,-0.483566,-0.040581,0.061144,-0.483566,-0.023433,0.061144,-0.483566,-0.023433,0.074144,-0.483566,-0.040581,0.074144,-0.483566,-0.023433,0.061144,-0.483715,-0.022058,0.061144,-0.483715,-0.022058,0.074144,-0.483566,-0.023433,0.074144,-0.483715,-0.022058,0.061144,-0.484139,-0.020796,0.061144,-0.484139,-0.020796,0.074144,-0.483715,-0.022058,0.074144,-0.484139,-0.020796,0.061144,-0.484803,-0.019681,0.061144,-0.484803,-0.019681,0.074144,-0.484139,-0.020796,0.061144,-0.484803,-0.019681,0.074144,-0.484139,-0.020796,0.074144,-0.484803,-0.019681,0.061144,-0.485674,-0.018752,0.061144,-0.485674,-0.018752,0.074144,-0.484803,-0.019681,0.074144,-0.485674,-0.018752,0.061144,-0.486718,-0.018043,0.061144,-0.486718,-0.018043,0.074144,-0.485674,-0.018752,0.074144,-0.486718,-0.018043,0.061144,-0.487902,-0.017592,0.061144,-0.487902,-0.017592,0.074144,-0.486718,-0.018043,0.074144,-0.487902,-0.017592,0.061144,-0.489191,-0.017433,0.061144,-0.489191,-0.017433,0.074144,-0.487902,-0.017592,0.061144,-0.489191,-0.017433,0.074144,-0.487902,-0.017592,0.074144,0.137525,-0.073341,0.061144,0.138097,-0.070704,0.061144,0.137948,-0.072079,0.061144,0.13686,-0.074455,0.061144,0.138097,-0.070704,0.061144,0.137525,-0.073341,0.061144,0.135989,-0.075385,0.061144,0.138097,-0.070704,0.061144,0.13686,-0.074455,0.061144,0.134945,-0.076093,0.061144,0.138097,-0.070704,0.061144,0.135989,-0.075385,0.061144,0.133761,-0.076545,0.061144,0.138097,-0.070704,0.061144,0.134945,-0.076093,0.061144,0.132473,-0.076704,0.061144,-0.223287,-0.076704,0.061144,-0.223287,-0.076704,0.061144,0.138097,-0.025556,0.061144,0.138097,-0.070704,0.061144,0.137948,-0.024181,0.061144,0.137525,-0.022919,0.061144,0.13686,-0.021804,0.061144,0.135989,-0.020875,0.061144,0.134945,-0.020166,0.061144,0.133761,-0.019714,0.061144,0.132473,-0.019556,0.061144,-0.223287,-0.019556,0.061144,-0.224575,-0.019715,0.061144,-0.225759,-0.020166,0.061144,-0.226803,-0.020875,0.061144,-0.227674,-0.021804,0.061144,-0.223287,-0.076704,0.061144,-0.228339,-0.022919,0.061144,-0.227674,-0.021804,0.061144,-0.228762,-0.024181,0.061144,-0.223287,-0.076704,0.061144,-0.228911,-0.025556,0.061144,-0.228762,-0.024181,0.061144,-0.228911,-0.070704,0.061144,-0.228911,-0.025556,0.061144,-0.224575,-0.076545,0.061144,-0.228911,-0.070704,0.061144,-0.224575,-0.076545,0.061144,-0.228762,-0.072079,0.061144,-0.228911,-0.070704,0.061144,-0.225759,-0.076094,0.061144,-0.228762,-0.072079,0.061144,-0.224575,-0.076545,0.061144,-0.228339,-0.073341,0.061144,-0.226803,-0.075385,0.061144,-0.227674,-0.074455,0.061144,0.446193,0.312449,0.061144,0.443721,0.313059,0.061144,0.44501,0.312901,0.061144,0.447238,0.31174,0.061144,0.448109,0.310811,0.061144,0.448773,0.309697,0.061144,0.449197,0.308434,0.061144,0.449345,0.307059,0.061144,0.449345,0.286911,0.061144,0.393439,0.313059,0.061144,0.449197,0.285536,0.061144,0.448773,0.284274,0.061144,0.448109,0.28316,0.061144,0.447238,0.28223,0.061144,0.446193,0.281522,0.061144,0.44501,0.28107,0.061144,0.443721,0.280911,0.061144,0.393439,0.280911,0.061144,0.39215,0.28107,0.061144,0.390967,0.281522,0.061144,0.389922,0.28223,0.061144,0.389051,0.28316,0.061144,0.388387,0.284274,0.061144,0.387963,0.285536,0.061144,0.387814,0.286911,0.061144,0.387814,0.307059,0.061144,0.387963,0.308434,0.061144,0.39215,0.312901,0.061144,0.390966,0.312449,0.061144,0.388387,0.309697,0.061144,0.389922,0.31174,0.061144,0.389051,0.310811,0.061144,0.377087,0.307059,0.061144,0.376515,0.309697,0.061144,0.376939,0.308434,0.061144,0.375851,0.310811,0.061144,0.37498,0.31174,0.061144,0.373935,0.312449,0.061144,0.372752,0.312901,0.061144,0.371463,0.313059,0.061144,0.377087,0.286911,0.061144,0.32118,0.313059,0.061144,0.376939,0.285536,0.061144,0.376515,0.284274,0.061144,0.375851,0.28316,0.061144,0.37498,0.28223,0.061144,0.373935,0.281522,0.061144,0.372752,0.28107,0.061144,0.371463,0.280911,0.061144,0.32118,0.280911,0.061144,0.319892,0.28107,0.061144,0.318708,0.281522,0.061144,0.317664,0.28223,0.061144,0.316793,0.28316,0.061144,0.316128,0.284274,0.061144,0.315705,0.285536,0.061144,0.315556,0.286911,0.061144,0.315556,0.307059,0.061144,0.315705,0.308434,0.061144,0.319892,0.312901,0.061144,0.316128,0.309697,0.061144,0.318708,0.312449,0.061144,0.317664,0.31174,0.061144,0.316793,0.310811,0.061144,0.298516,0.307059,0.061144,0.297944,0.309697,0.061144,0.298367,0.308434,0.061144,0.297279,0.310811,0.061144,0.296408,0.31174,0.061144,0.295364,0.312449,0.061144,0.29418,0.312901,0.061144,0.292892,0.313059,0.061144,0.298516,0.286911,0.061144,0.242609,0.313059,0.061144,0.298367,0.285536,0.061144,0.297944,0.284274,0.061144,0.297279,0.28316,0.061144,0.296408,0.28223,0.061144,0.295364,0.281522,0.061144,0.29418,0.28107,0.061144,0.292892,0.280911,0.061144,0.242609,0.280911,0.061144,0.24132,0.28107,0.061144,0.240137,0.281522,0.061144,0.239093,0.28223,0.061144,0.238221,0.28316,0.061144,0.237557,0.284274,0.061144,0.237134,0.285536,0.061144,0.236985,0.286911,0.061144,0.236985,0.307059,0.061144,0.237134,0.308434,0.061144,0.24132,0.312901,0.061144,0.240137,0.312449,0.061144,0.237557,0.309697,0.061144,0.239093,0.31174,0.061144,0.238221,0.310811,0.061144,0.216792,0.312449,0.061144,0.21432,0.313059,0.061144,0.215609,0.312901,0.061144,0.217837,0.31174,0.061144,0.218708,0.310811,0.061144,0.219372,0.309697,0.061144,0.219796,0.308434,0.061144,0.219944,0.307059,0.061144,0.219944,0.286911,0.061144,0.164038,0.313059,0.061144,0.219796,0.285536,0.061144,0.219372,0.284274,0.061144,0.218708,0.28316,0.061144,0.217837,0.28223,0.061144,0.216792,0.281522,0.061144,0.215609,0.28107,0.061144,0.21432,0.280911,0.061144,0.164038,0.280911,0.061144,0.162749,0.28107,0.061144,0.161565,0.281522,0.061144,0.160521,0.28223,0.061144,0.15965,0.28316,0.061144,0.158986,0.284274,0.061144,0.158562,0.285536,0.061144,0.158413,0.286911,0.061144,0.158413,0.307059,0.061144,0.158562,0.308434,0.061144,0.162749,0.312901,0.061144,0.161565,0.312449,0.061144,0.158986,0.309697,0.061144,0.15965,0.310811,0.061144,0.160521,0.31174,0.061144,0.138221,0.312449,0.061144,0.135749,0.313059,0.061144,0.137038,0.312901,0.061144,0.139265,0.31174,0.061144,0.140137,0.310811,0.061144,0.140801,0.309697,0.061144,0.141224,0.308434,0.061144,0.141373,0.307059,0.061144,0.141373,0.286911,0.061144,0.085466,0.313059,0.061144,0.141224,0.285536,0.061144,0.140801,0.284274,0.061144,0.140137,0.28316,0.061144,0.139265,0.28223,0.061144,0.138221,0.281522,0.061144,0.137038,0.28107,0.061144,0.135749,0.280911,0.061144,0.085466,0.280911,0.061144,0.084177,0.28107,0.061144,0.082994,0.281522,0.061144,0.08195,0.28223,0.061144,0.081078,0.28316,0.061144,0.080414,0.284274,0.061144,0.079991,0.285536,0.061144,0.079842,0.286911,0.061144,0.079842,0.307059,0.061144,0.079991,0.308434,0.061144,0.084177,0.312901,0.061144,0.082994,0.312449,0.061144,0.080414,0.309697,0.061144,0.081078,0.310811,0.061144,0.08195,0.31174,0.061144,0.05965,0.312449,0.061144,0.057177,0.313059,0.061144,0.058466,0.312901,0.061144,0.060694,0.31174,0.061144,0.061565,0.310811,0.061144,0.062229,0.309697,0.061144,0.062653,0.308434,0.061144,0.062802,0.307059,0.061144,0.062802,0.286911,0.061144,0.006895,0.313059,0.061144,0.062653,0.285536,0.061144,0.062229,0.284274,0.061144,0.061565,0.28316,0.061144,0.060694,0.28223,0.061144,0.05965,0.281522,0.061144,0.058466,0.28107,0.061144,0.057177,0.280911,0.061144,0.006895,0.280911,0.061144,0.005606,0.28107,0.061144,0.004423,0.281522,0.061144,0.003378,0.28223,0.061144,0.002507,0.28316,0.061144,0.001843,0.284274,0.061144,0.001419,0.285536,0.061144,0.001271,0.286911,0.061144,0.001271,0.307059,0.061144,0.001419,0.308434,0.061144,0.005606,0.312901,0.061144,0.004423,0.312449,0.061144,0.001843,0.309697,0.061144,0.002507,0.310811,0.061144,0.003378,0.31174,0.061144,-0.018922,0.312449,0.061144,-0.021394,0.313059,0.061144,-0.020105,0.312901,0.061144,-0.017878,0.31174,0.061144,-0.017006,0.310811,0.061144,-0.016342,0.309697,0.061144,-0.015919,0.308434,0.061144,-0.01577,0.307059,0.061144,-0.01577,0.286911,0.061144,-0.071677,0.313059,0.061144,-0.015919,0.285536,0.061144,-0.016342,0.284274,0.061144,-0.017006,0.28316,0.061144,-0.017878,0.28223,0.061144,-0.018922,0.281522,0.061144,-0.020105,0.28107,0.061144,-0.021394,0.280911,0.061144,-0.071677,0.280911,0.061144,-0.072965,0.28107,0.061144,-0.074149,0.281522,0.061144,-0.075193,0.28223,0.061144,-0.076064,0.28316,0.061144,-0.076729,0.284274,0.061144,-0.077152,0.285536,0.061144,-0.077301,0.286911,0.061144,-0.077301,0.307059,0.061144,-0.077152,0.308434,0.061144,-0.072965,0.312901,0.061144,-0.074149,0.312449,0.061144,-0.076729,0.309697,0.061144,-0.076064,0.310811,0.061144,-0.075193,0.31174,0.061144,-0.097493,0.312449,0.061144,-0.099965,0.313059,0.061144,-0.098677,0.312901,0.061144,-0.096449,0.31174,0.061144,-0.095578,0.310811,0.061144,-0.094913,0.309697,0.061144,-0.09449,0.308434,0.061144,-0.094341,0.307059,0.061144,-0.094341,0.286911,0.061144,-0.150248,0.313059,0.061144,-0.09449,0.285536,0.061144,-0.094913,0.284274,0.061144,-0.095578,0.28316,0.061144,-0.096449,0.28223,0.061144,-0.097493,0.281522,0.061144,-0.098677,0.28107,0.061144,-0.099965,0.280911,0.061144,-0.150248,0.280911,0.061144,-0.151537,0.28107,0.061144,-0.15272,0.281522,0.061144,-0.153765,0.28223,0.061144,-0.154636,0.28316,0.061144,-0.1553,0.284274,0.061144,-0.155724,0.285536,0.061144,-0.155872,0.286911,0.061144,-0.155872,0.307059,0.061144,-0.155724,0.308434,0.061144,-0.151537,0.312901,0.061144,-0.15272,0.312449,0.061144,-0.1553,0.309697,0.061144,-0.154636,0.310811,0.061144,-0.153765,0.31174,0.061144,-0.176065,0.312449,0.061144,-0.178537,0.313059,0.061144,-0.177248,0.312901,0.061144,-0.17502,0.31174,0.061144,-0.174149,0.310811,0.061144,-0.173485,0.309697,0.061144,-0.173061,0.308434,0.061144,-0.172913,0.307059,0.061144,-0.172913,0.286911,0.061144,-0.22882,0.313059,0.061144,-0.173061,0.285536,0.061144,-0.173485,0.284274,0.061144,-0.174149,0.28316,0.061144,-0.17502,0.28223,0.061144,-0.176065,0.281522,0.061144,-0.177248,0.28107,0.061144,-0.178537,0.280911,0.061144,-0.22882,0.280911,0.061144,-0.230108,0.28107,0.061144,-0.231292,0.281522,0.061144,-0.232336,0.28223,0.061144,-0.233207,0.28316,0.061144,-0.233872,0.284274,0.061144,-0.234295,0.285536,0.061144,-0.234444,0.286911,0.061144,-0.234444,0.307059,0.061144,-0.234295,0.308434,0.061144,-0.230108,0.312901,0.061144,-0.231292,0.312449,0.061144,-0.233872,0.309697,0.061144,-0.233207,0.310811,0.061144,-0.232336,0.31174,0.061144,-0.254636,0.312449,0.061144,-0.257108,0.313059,0.061144,-0.25582,0.312901,0.061144,-0.253592,0.31174,0.061144,-0.252721,0.310811,0.061144,-0.252056,0.309697,0.061144,-0.251633,0.308434,0.061144,-0.251484,0.307059,0.061144,-0.251484,0.286911,0.061144,-0.307391,0.313059,0.061144,-0.251633,0.285536,0.061144,-0.252056,0.284274,0.061144,-0.252721,0.28316,0.061144,-0.253592,0.28223,0.061144,-0.254636,0.281522,0.061144,-0.25582,0.28107,0.061144,-0.257108,0.280911,0.061144,-0.307391,0.280911,0.061144,-0.30868,0.28107,0.061144,-0.309863,0.281522,0.061144,-0.310907,0.28223,0.061144,-0.311779,0.28316,0.061144,-0.312443,0.284274,0.061144,-0.312867,0.285536,0.061144,-0.313015,0.286911,0.061144,-0.313015,0.307059,0.061144,-0.312867,0.308434,0.061144,-0.30868,0.312901,0.061144,-0.309863,0.312449,0.061144,-0.312443,0.309697,0.061144,-0.311779,0.310811,0.061144,-0.310907,0.31174,0.061144,-0.333208,0.312449,0.061144,-0.33568,0.313059,0.061144,-0.334391,0.312901,0.061144,-0.332163,0.31174,0.061144,-0.331292,0.310811,0.061144,-0.330628,0.309697,0.061144,-0.330204,0.308434,0.061144,-0.330056,0.307059,0.061144,-0.330056,0.286911,0.061144,-0.385962,0.313059,0.061144,-0.330204,0.285536,0.061144,-0.330628,0.284274,0.061144,-0.331292,0.28316,0.061144,-0.332163,0.28223,0.061144,-0.333208,0.281522,0.061144,-0.334391,0.28107,0.061144,-0.33568,0.280911,0.061144,-0.385962,0.280911,0.061144,-0.387251,0.28107,0.061144,-0.388435,0.281522,0.061144,-0.389479,0.28223,0.061144,-0.39035,0.28316,0.061144,-0.391014,0.284274,0.061144,-0.391438,0.285536,0.061144,-0.391587,0.286911,0.061144,-0.391587,0.307059,0.061144,-0.387251,0.312901,0.061144,-0.391438,0.308434,0.061144,-0.388435,0.312449,0.061144,-0.391015,0.309697,0.061144,-0.39035,0.310811,0.061144,-0.389479,0.31174,0.061144,-0.411779,0.312449,0.061144,-0.414251,0.313059,0.061144,-0.412963,0.312901,0.061144,-0.410735,0.31174,0.061144,-0.409864,0.310811,0.061144,-0.409199,0.309697,0.061144,-0.408776,0.308434,0.061144,-0.408627,0.307059,0.061144,-0.408627,0.286911,0.061144,-0.464534,0.313059,0.061144,-0.408776,0.285536,0.061144,-0.409199,0.284274,0.061144,-0.409864,0.28316,0.061144,-0.410735,0.28223,0.061144,-0.411779,0.281522,0.061144,-0.412963,0.28107,0.061144,-0.414251,0.280911,0.061144,-0.464534,0.280911,0.061144,-0.465823,0.28107,0.061144,-0.467006,0.281522,0.061144,-0.46805,0.28223,0.061144,-0.468922,0.28316,0.061144,-0.469586,0.284274,0.061144,-0.470009,0.285536,0.061144,-0.470158,0.286911,0.061144,-0.470158,0.307059,0.061144,-0.470009,0.308434,0.061144,-0.465823,0.312901,0.061144,-0.467006,0.312449,0.061144,-0.469586,0.309697,0.061144,-0.468922,0.310811,0.061144,-0.46805,0.31174,0.061144,-0.543105,0.313059,0.061144,-0.545577,0.312449,0.061144,-0.544394,0.312901,0.061144,-0.546622,0.31174,0.061144,-0.547493,0.310811,0.061144,-0.548157,0.309697,0.061144,-0.548581,0.308434,0.061144,-0.54873,0.307059,0.061144,-0.492823,0.313059,0.061144,-0.54873,0.286911,0.061144,-0.548581,0.285536,0.061144,-0.548157,0.284274,0.061144,-0.547493,0.28316,0.061144,-0.546622,0.28223,0.061144,-0.545578,0.281522,0.061144,-0.544394,0.28107,0.061144,-0.543105,0.280911,0.061144,-0.492823,0.280911,0.061144,-0.491534,0.28107,0.061144,-0.49035,0.281521,0.061144,-0.489306,0.28223,0.061144,-0.488435,0.28316,0.061144,-0.487771,0.284274,0.061144,-0.487347,0.285536,0.061144,-0.487199,0.286911,0.061144,-0.487199,0.307059,0.061144,-0.487347,0.308434,0.061144,-0.491534,0.312901,0.061144,-0.490351,0.312449,0.061144,-0.487771,0.309696,0.061144,-0.488435,0.310811,0.061144,-0.489306,0.31174,0.061144,-0.627301,0.286911,0.061144,-0.626729,0.284274,0.061144,-0.627152,0.285536,0.061144,-0.626064,0.28316,0.061144,-0.625193,0.28223,0.061144,-0.624149,0.281522,0.061144,-0.622966,0.28107,0.061144,-0.621677,0.280911,0.061144,-0.627301,0.307059,0.061144,-0.571394,0.280911,0.061144,-0.627152,0.308434,0.061144,-0.626729,0.309697,0.061144,-0.626064,0.310811,0.061144,-0.625193,0.31174,0.061144,-0.624149,0.312449,0.061144,-0.622966,0.312901,0.061144,-0.621677,0.313059,0.061144,-0.571394,0.313059,0.061144,-0.570105,0.28107,0.061144,-0.568922,0.281521,0.061144,-0.567878,0.28223,0.061144,-0.567006,0.28316,0.061144,-0.566342,0.284274,0.061144,-0.565919,0.285536,0.061144,-0.56577,0.286911,0.061144,-0.56577,0.307059,0.061144,-0.565919,0.308434,0.061144,-0.570105,0.312901,0.061144,-0.568922,0.312449,0.061144,-0.566342,0.309696,0.061144,-0.567878,0.31174,0.061144,-0.567006,0.310811,0.061144,0.449345,0.264268,0.061144,0.448773,0.266905,0.061144,0.449197,0.265643,0.061144,0.448109,0.268019,0.061144,0.447238,0.268949,0.061144,0.446194,0.269658,0.061144,0.44501,0.270109,0.061144,0.449345,0.264268,0.061144,0.443721,0.270268,0.061144,0.44501,0.270109,0.061144,0.449346,0.21912,0.061144,0.443721,0.270268,0.061144,0.449345,0.264268,0.061144,0.449346,0.21912,0.061144,0.397293,0.270268,0.061144,0.443721,0.270268,0.061144,0.449197,0.217745,0.061144,0.397293,0.270268,0.061144,0.449346,0.21912,0.061144,0.448773,0.216483,0.061144,0.449197,0.217745,0.061144,0.448109,0.215369,0.061144,0.447238,0.214439,0.061144,0.446194,0.21373,0.061144,0.44501,0.213279,0.061144,0.443721,0.21312,0.061144,0.397293,0.21312,0.061144,0.396004,0.213279,0.061144,0.394821,0.21373,0.061144,0.393776,0.214439,0.061144,0.392905,0.215369,0.061144,0.392241,0.216483,0.061144,0.391817,0.217745,0.061144,0.391668,0.21912,0.061144,0.397293,0.270268,0.061144,0.391817,0.217745,0.061144,0.391668,0.264268,0.061144,0.397293,0.270268,0.061144,0.391668,0.21912,0.061144,0.391817,0.265643,0.061144,0.391817,0.265643,0.061144,0.396004,0.270109,0.061144,0.397293,0.270268,0.061144,0.392241,0.266905,0.061144,0.396004,0.270109,0.061144,0.391817,0.265643,0.061144,0.39482,0.269658,0.061144,0.393776,0.268949,0.061144,0.392905,0.26802,0.061144,0.38382,0.264268,0.061144,0.383248,0.266905,0.061144,0.383671,0.265643,0.061144,0.382584,0.268019,0.061144,0.381712,0.268949,0.061144,0.380668,0.269658,0.061144,0.379485,0.270109,0.061144,0.38382,0.264268,0.061144,0.378196,0.270268,0.061144,0.379485,0.270109,0.061144,0.38382,0.21912,0.061144,0.378196,0.270268,0.061144,0.38382,0.264268,0.061144,0.38382,0.21912,0.061144,0.331767,0.270268,0.061144,0.378196,0.270268,0.061144,0.383671,0.217745,0.061144,0.331767,0.270268,0.061144,0.38382,0.21912,0.061144,0.383248,0.216483,0.061144,0.383671,0.217745,0.061144,0.382584,0.215369,0.061144,0.381712,0.214439,0.061144,0.380668,0.21373,0.061144,0.379485,0.213279,0.061144,0.378196,0.21312,0.061144,0.331767,0.21312,0.061144,0.330478,0.213279,0.061144,0.329295,0.21373,0.061144,0.328251,0.214439,0.061144,0.327379,0.215369,0.061144,0.326715,0.216483,0.061144,0.326292,0.217745,0.061144,0.326143,0.21912,0.061144,0.331767,0.270268,0.061144,0.326292,0.217745,0.061144,0.326143,0.264268,0.061144,0.331767,0.270268,0.061144,0.326143,0.21912,0.061144,0.326292,0.265643,0.061144,0.326292,0.265643,0.061144,0.330478,0.270109,0.061144,0.331767,0.270268,0.061144,0.326715,0.266905,0.061144,0.330478,0.270109,0.061144,0.326292,0.265643,0.061144,0.329295,0.269658,0.061144,0.327379,0.268019,0.061144,0.328251,0.268949,0.061144,0.31017,0.264268,0.061144,0.309598,0.266905,0.061144,0.310021,0.265643,0.061144,0.308933,0.268019,0.061144,0.308062,0.268949,0.061144,0.307018,0.269658,0.061144,0.305834,0.270109,0.061144,0.31017,0.264268,0.061144,0.304546,0.270268,0.061144,0.305834,0.270109,0.061144,0.31017,0.21912,0.061144,0.304546,0.270268,0.061144,0.31017,0.264268,0.061144,0.31017,0.21912,0.061144,0.258117,0.270268,0.061144,0.304546,0.270268,0.061144,0.310021,0.217745,0.061144,0.258117,0.270268,0.061144,0.31017,0.21912,0.061144,0.309598,0.216483,0.061144,0.310021,0.217745,0.061144,0.308934,0.215369,0.061144,0.308062,0.214439,0.061144,0.307018,0.21373,0.061144,0.305834,0.213279,0.061144,0.304546,0.21312,0.061144,0.258117,0.21312,0.061144,0.256828,0.213279,0.061144,0.255645,0.21373,0.061144,0.254601,0.214439,0.061144,0.253729,0.215369,0.061144,0.253065,0.216483,0.061144,0.252642,0.217745,0.061144,0.252493,0.21912,0.061144,0.258117,0.270268,0.061144,0.252642,0.217745,0.061144,0.252493,0.264268,0.061144,0.258117,0.270268,0.061144,0.252493,0.21912,0.061144,0.252642,0.265643,0.061144,0.252642,0.265643,0.061144,0.256828,0.270109,0.061144,0.258117,0.270268,0.061144,0.253065,0.266905,0.061144,0.256828,0.270109,0.061144,0.252642,0.265643,0.061144,0.255645,0.269658,0.061144,0.253729,0.268019,0.061144,0.254601,0.268949,0.061144,0.23652,0.264268,0.061144,0.235948,0.266905,0.061144,0.236371,0.265643,0.061144,0.235283,0.268019,0.061144,0.234412,0.268949,0.061144,0.233368,0.269658,0.061144,0.232184,0.270109,0.061144,0.23652,0.264268,0.061144,0.230896,0.270268,0.061144,0.232184,0.270109,0.061144,0.23652,0.21912,0.061144,0.230896,0.270268,0.061144,0.23652,0.264268,0.061144,0.23652,0.21912,0.061144,0.184467,0.270268,0.061144,0.230896,0.270268,0.061144,0.236371,0.217745,0.061144,0.184467,0.270268,0.061144,0.23652,0.21912,0.061144,0.235948,0.216483,0.061144,0.236371,0.217745,0.061144,0.235283,0.215369,0.061144,0.234412,0.214439,0.061144,0.233368,0.21373,0.061144,0.232184,0.213279,0.061144,0.230896,0.21312,0.061144,0.184467,0.21312,0.061144,0.183178,0.213279,0.061144,0.181995,0.21373,0.061144,0.180951,0.214439,0.061144,0.180079,0.215369,0.061144,0.179415,0.216483,0.061144,0.178991,0.217745,0.061144,0.178843,0.21912,0.061144,0.184467,0.270268,0.061144,0.178991,0.217745,0.061144,0.178843,0.264268,0.061144,0.184467,0.270268,0.061144,0.178843,0.21912,0.061144,0.178843,0.264268,0.061144,0.183178,0.270109,0.061144,0.184467,0.270268,0.061144,0.178991,0.265643,0.061144,0.183178,0.270109,0.061144,0.178843,0.264268,0.061144,0.179415,0.266905,0.061144,0.181995,0.269658,0.061144,0.180079,0.268019,0.061144,0.18095,0.268949,0.061144,0.162298,0.216483,0.061144,0.16287,0.21912,0.061144,0.162721,0.217745,0.061144,0.161633,0.215369,0.061144,0.16287,0.21912,0.061144,0.162298,0.216483,0.061144,0.160762,0.214439,0.061144,0.16287,0.21912,0.061144,0.161633,0.215369,0.061144,0.159718,0.21373,0.061144,0.16287,0.21912,0.061144,0.160762,0.214439,0.061144,0.158534,0.213279,0.061144,0.16287,0.21912,0.061144,0.159718,0.21373,0.061144,0.157246,0.21312,0.061144,0.110817,0.21312,0.061144,0.110817,0.21312,0.061144,0.16287,0.264268,0.061144,0.16287,0.21912,0.061144,0.162721,0.265643,0.061144,0.162298,0.266905,0.061144,0.161633,0.268019,0.061144,0.160762,0.268949,0.061144,0.159718,0.269658,0.061144,0.158534,0.270109,0.061144,0.110817,0.21312,0.061144,0.157246,0.270268,0.061144,0.158534,0.270109,0.061144,0.110817,0.270268,0.061144,0.157246,0.270268,0.061144,0.109528,0.213279,0.061144,0.108345,0.21373,0.061144,0.1073,0.214439,0.061144,0.106429,0.215369,0.061144,0.105765,0.216483,0.061144,0.105341,0.217745,0.061144,0.105193,0.21912,0.061144,0.110817,0.270268,0.061144,0.105341,0.217745,0.061144,0.105193,0.264268,0.061144,0.110817,0.270268,0.061144,0.105193,0.21912,0.061144,0.105341,0.265643,0.061144,0.105341,0.265643,0.061144,0.109528,0.270109,0.061144,0.110817,0.270268,0.061144,0.105765,0.266905,0.061144,0.109528,0.270109,0.061144,0.105341,0.265643,0.061144,0.108345,0.269658,0.061144,0.1073,0.268949,0.061144,0.106429,0.268019,0.061144,0.086068,0.269658,0.061144,0.083595,0.270268,0.061144,0.084884,0.270109,0.061144,0.087112,0.268949,0.061144,0.083595,0.270268,0.061144,0.086068,0.269658,0.061144,0.087983,0.268019,0.061144,0.083595,0.270268,0.061144,0.087112,0.268949,0.061144,0.088647,0.266905,0.061144,0.083595,0.270268,0.061144,0.087983,0.268019,0.061144,0.089071,0.265643,0.061144,0.083595,0.270268,0.061144,0.088647,0.266905,0.061144,0.08922,0.264268,0.061144,0.08922,0.21912,0.061144,0.08922,0.21912,0.061144,0.037167,0.270268,0.061144,0.083595,0.270268,0.061144,0.089071,0.217745,0.061144,0.037167,0.270268,0.061144,0.08922,0.21912,0.061144,0.088647,0.216483,0.061144,0.089071,0.217745,0.061144,0.087983,0.215369,0.061144,0.087112,0.214439,0.061144,0.086068,0.21373,0.061144,0.084884,0.213279,0.061144,0.083595,0.21312,0.061144,0.037167,0.21312,0.061144,0.035878,0.213279,0.061144,0.034695,0.21373,0.061144,0.03365,0.214439,0.061144,0.032779,0.215369,0.061144,0.032115,0.216483,0.061144,0.031691,0.217745,0.061144,0.031543,0.21912,0.061144,0.037167,0.270268,0.061144,0.031691,0.217745,0.061144,0.031543,0.264268,0.061144,0.037167,0.270268,0.061144,0.031543,0.21912,0.061144,0.031691,0.265643,0.061144,0.031691,0.265643,0.061144,0.035878,0.270109,0.061144,0.037167,0.270268,0.061144,0.031691,0.265643,0.061144,0.034695,0.269658,0.061144,0.035878,0.270109,0.061144,0.032115,0.266905,0.061144,0.03365,0.268949,0.061144,0.032779,0.268019,0.061144,0.012417,0.269658,0.061144,0.009945,0.270268,0.061144,0.011234,0.270109,0.061144,0.013462,0.268949,0.061144,0.009945,0.270268,0.061144,0.012417,0.269658,0.061144,0.014333,0.268019,0.061144,0.009945,0.270268,0.061144,0.013462,0.268949,0.061144,0.014997,0.266905,0.061144,0.009945,0.270268,0.061144,0.014333,0.268019,0.061144,0.015421,0.265643,0.061144,0.009945,0.270268,0.061144,0.014997,0.266905,0.061144,0.015569,0.264268,0.061144,0.015569,0.21912,0.061144,0.015569,0.21912,0.061144,-0.036483,0.270268,0.061144,0.009945,0.270268,0.061144,0.015421,0.217745,0.061144,-0.036483,0.270268,0.061144,0.015569,0.21912,0.061144,0.014997,0.216483,0.061144,0.015421,0.217745,0.061144,0.014333,0.215369,0.061144,0.013462,0.214439,0.061144,0.012417,0.21373,0.061144,0.011234,0.213279,0.061144,0.009945,0.21312,0.061144,-0.036483,0.21312,0.061144,-0.037772,0.213279,0.061144,-0.038956,0.21373,0.061144,-0.04,0.214439,0.061144,-0.040871,0.215369,0.061144,-0.041536,0.216483,0.061144,-0.041959,0.217745,0.061144,-0.042108,0.21912,0.061144,-0.036483,0.270268,0.061144,-0.041959,0.217745,0.061144,-0.042108,0.264268,0.061144,-0.036483,0.270268,0.061144,-0.042108,0.21912,0.061144,-0.042108,0.264268,0.061144,-0.037772,0.270109,0.061144,-0.036483,0.270268,0.061144,-0.041959,0.265643,0.061144,-0.037772,0.270109,0.061144,-0.042108,0.264268,0.061144,-0.038956,0.269658,0.061144,-0.041536,0.266905,0.061144,-0.04,0.268949,0.061144,-0.040871,0.268019,0.061144,-0.061233,0.269658,0.061144,-0.063705,0.270268,0.061144,-0.062416,0.270109,0.061144,-0.060188,0.268949,0.061144,-0.063705,0.270268,0.061144,-0.061233,0.269658,0.061144,-0.059317,0.268019,0.061144,-0.063705,0.270268,0.061144,-0.060188,0.268949,0.061144,-0.058653,0.266905,0.061144,-0.063705,0.270268,0.061144,-0.059317,0.268019,0.061144,-0.058229,0.265643,0.061144,-0.063705,0.270268,0.061144,-0.058653,0.266905,0.061144,-0.058081,0.264268,0.061144,-0.058081,0.21912,0.061144,-0.058081,0.21912,0.061144,-0.110134,0.270268,0.061144,-0.063705,0.270268,0.061144,-0.058229,0.217745,0.061144,-0.110134,0.270268,0.061144,-0.058081,0.21912,0.061144,-0.058653,0.216483,0.061144,-0.058229,0.217745,0.061144,-0.059317,0.215369,0.061144,-0.060188,0.214439,0.061144,-0.061233,0.21373,0.061144,-0.062416,0.213279,0.061144,-0.063705,0.21312,0.061144,-0.110134,0.21312,0.061144,-0.111422,0.213279,0.061144,-0.112606,0.21373,0.061144,-0.11365,0.214439,0.061144,-0.114521,0.215369,0.061144,-0.115186,0.216483,0.061144,-0.115609,0.217745,0.061144,-0.115758,0.21912,0.061144,-0.110134,0.270268,0.061144,-0.115609,0.217745,0.061144,-0.115758,0.264268,0.061144,-0.110134,0.270268,0.061144,-0.115758,0.21912,0.061144,-0.115609,0.265643,0.061144,-0.115609,0.265643,0.061144,-0.111422,0.270109,0.061144,-0.110134,0.270268,0.061144,-0.115609,0.265643,0.061144,-0.112606,0.269658,0.061144,-0.111422,0.270109,0.061144,-0.115186,0.266905,0.061144,-0.11365,0.268949,0.061144,-0.114521,0.268019,0.061144,-0.134883,0.269658,0.061144,-0.137355,0.270268,0.061144,-0.136066,0.270109,0.061144,-0.133839,0.268949,0.061144,-0.137355,0.270268,0.061144,-0.134883,0.269658,0.061144,-0.132967,0.268019,0.061144,-0.137355,0.270268,0.061144,-0.133839,0.268949,0.061144,-0.132303,0.266905,0.061144,-0.137355,0.270268,0.061144,-0.132967,0.268019,0.061144,-0.13188,0.265643,0.061144,-0.137355,0.270268,0.061144,-0.132303,0.266905,0.061144,-0.131731,0.264268,0.061144,-0.131731,0.21912,0.061144,-0.131731,0.21912,0.061144,-0.183784,0.270268,0.061144,-0.137355,0.270268,0.061144,-0.13188,0.217745,0.061144,-0.183784,0.270268,0.061144,-0.131731,0.21912,0.061144,-0.132303,0.216483,0.061144,-0.13188,0.217745,0.061144,-0.132967,0.215369,0.061144,-0.133839,0.214439,0.061144,-0.134883,0.21373,0.061144,-0.136066,0.213279,0.061144,-0.137355,0.21312,0.061144,-0.183784,0.21312,0.061144,-0.185072,0.213279,0.061144,-0.186256,0.21373,0.061144,-0.1873,0.214439,0.061144,-0.188171,0.215369,0.061144,-0.188836,0.216483,0.061144,-0.189259,0.217745,0.061144,-0.189408,0.21912,0.061144,-0.183784,0.270268,0.061144,-0.189259,0.217745,0.061144,-0.189408,0.264268,0.061144,-0.183784,0.270268,0.061144,-0.189408,0.21912,0.061144,-0.189408,0.264268,0.061144,-0.185072,0.270109,0.061144,-0.183784,0.270268,0.061144,-0.189259,0.265643,0.061144,-0.185072,0.270109,0.061144,-0.189408,0.264268,0.061144,-0.186256,0.269658,0.061144,-0.188836,0.266905,0.061144,-0.188171,0.268019,0.061144,-0.1873,0.268949,0.061144,-0.208533,0.269658,0.061144,-0.211005,0.270268,0.061144,-0.209716,0.270109,0.061144,-0.207489,0.268949,0.061144,-0.211005,0.270268,0.061144,-0.208533,0.269658,0.061144,-0.206617,0.268019,0.061144,-0.211005,0.270268,0.061144,-0.207489,0.268949,0.061144,-0.205953,0.266905,0.061144,-0.211005,0.270268,0.061144,-0.206617,0.268019,0.061144,-0.20553,0.265643,0.061144,-0.211005,0.270268,0.061144,-0.205953,0.266905,0.061144,-0.205381,0.264268,0.061144,-0.205381,0.21912,0.061144,-0.205381,0.21912,0.061144,-0.257434,0.270268,0.061144,-0.211005,0.270268,0.061144,-0.20553,0.217745,0.061144,-0.257434,0.270268,0.061144,-0.205381,0.21912,0.061144,-0.205953,0.216483,0.061144,-0.20553,0.217745,0.061144,-0.206617,0.215369,0.061144,-0.207489,0.214439,0.061144,-0.208533,0.21373,0.061144,-0.209716,0.213279,0.061144,-0.211005,0.21312,0.061144,-0.257434,0.21312,0.061144,-0.258723,0.213279,0.061144,-0.259906,0.21373,0.061144,-0.26095,0.214439,0.061144,-0.261822,0.215369,0.061144,-0.262486,0.216483,0.061144,-0.262909,0.217745,0.061144,-0.263058,0.21912,0.061144,-0.257434,0.270268,0.061144,-0.262909,0.217745,0.061144,-0.263058,0.264268,0.061144,-0.257434,0.270268,0.061144,-0.263058,0.21912,0.061144,-0.263058,0.264268,0.061144,-0.258723,0.270109,0.061144,-0.257434,0.270268,0.061144,-0.262909,0.265643,0.061144,-0.258723,0.270109,0.061144,-0.263058,0.264268,0.061144,-0.259906,0.269658,0.061144,-0.262486,0.266905,0.061144,-0.261822,0.268019,0.061144,-0.26095,0.268949,0.061144,-0.336136,0.266905,0.061144,-0.336708,0.264268,0.061144,-0.33656,0.265643,0.061144,-0.335472,0.268019,0.061144,-0.3346,0.268949,0.061144,-0.333556,0.269658,0.061144,-0.332373,0.270109,0.061144,-0.331084,0.270268,0.061144,-0.336708,0.264268,0.061144,-0.332373,0.270109,0.061144,-0.284655,0.270268,0.061144,-0.336708,0.264268,0.061144,-0.331084,0.270268,0.061144,-0.284655,0.270268,0.061144,-0.336708,0.21912,0.061144,-0.284655,0.270268,0.061144,-0.33656,0.217745,0.061144,-0.336708,0.21912,0.061144,-0.336136,0.216483,0.061144,-0.33656,0.217745,0.061144,-0.335472,0.215369,0.061144,-0.3346,0.214439,0.061144,-0.333556,0.21373,0.061144,-0.332373,0.213279,0.061144,-0.331084,0.21312,0.061144,-0.284655,0.21312,0.061144,-0.283367,0.213279,0.061144,-0.282183,0.21373,0.061144,-0.281139,0.214439,0.061144,-0.280268,0.215369,0.061144,-0.279603,0.216483,0.061144,-0.27918,0.217745,0.061144,-0.284655,0.270268,0.061144,-0.279031,0.21912,0.061144,-0.27918,0.217745,0.061144,-0.284655,0.270268,0.061144,-0.279031,0.264268,0.061144,-0.279031,0.21912,0.061144,-0.27918,0.265643,0.061144,-0.283367,0.270109,0.061144,-0.27918,0.265643,0.061144,-0.284655,0.270268,0.061144,-0.282183,0.269658,0.061144,-0.27918,0.265643,0.061144,-0.283367,0.270109,0.061144,-0.279603,0.266905,0.061144,-0.281139,0.268949,0.061144,-0.280268,0.268019,0.061144,-0.410358,0.21912,0.061144,-0.409786,0.216483,0.061144,-0.41021,0.217745,0.061144,-0.410358,0.21912,0.061144,-0.409122,0.215369,0.061144,-0.409786,0.216483,0.061144,-0.410358,0.21912,0.061144,-0.408251,0.214439,0.061144,-0.409122,0.215369,0.061144,-0.410358,0.21912,0.061144,-0.407206,0.21373,0.061144,-0.408251,0.214439,0.061144,-0.410358,0.21912,0.061144,-0.406023,0.213279,0.061144,-0.407206,0.21373,0.061144,-0.404734,0.21312,0.061144,-0.410358,0.264268,0.061144,-0.404734,0.21312,0.061144,-0.410358,0.21912,0.061144,-0.410358,0.264268,0.061144,-0.358305,0.21312,0.061144,-0.404734,0.21312,0.061144,-0.41021,0.265643,0.061144,-0.409786,0.266905,0.061144,-0.409122,0.268019,0.061144,-0.408251,0.268949,0.061144,-0.407206,0.269658,0.061144,-0.406023,0.270109,0.061144,-0.404734,0.270268,0.061144,-0.358305,0.21312,0.061144,-0.406023,0.270109,0.061144,-0.358305,0.270268,0.061144,-0.404734,0.270268,0.061144,-0.357017,0.213279,0.061144,-0.355833,0.21373,0.061144,-0.354789,0.214439,0.061144,-0.353918,0.215369,0.061144,-0.353253,0.216483,0.061144,-0.35283,0.217745,0.061144,-0.358305,0.270268,0.061144,-0.352681,0.21912,0.061144,-0.35283,0.217745,0.061144,-0.358305,0.270268,0.061144,-0.352681,0.264268,0.061144,-0.352681,0.21912,0.061144,-0.35283,0.265643,0.061144,-0.357017,0.270109,0.061144,-0.35283,0.265643,0.061144,-0.358305,0.270268,0.061144,-0.355833,0.269658,0.061144,-0.35283,0.265643,0.061144,-0.357017,0.270109,0.061144,-0.353253,0.266905,0.061144,-0.354789,0.268949,0.061144,-0.353918,0.268019,0.061144,-0.426904,0.216483,0.061144,-0.426331,0.21912,0.061144,-0.42648,0.217745,0.061144,-0.427568,0.215369,0.061144,-0.426331,0.21912,0.061144,-0.426904,0.216483,0.061144,-0.428439,0.214439,0.061144,-0.426331,0.21912,0.061144,-0.427568,0.215369,0.061144,-0.429483,0.21373,0.061144,-0.426331,0.21912,0.061144,-0.428439,0.214439,0.061144,-0.430667,0.213279,0.061144,-0.426331,0.21912,0.061144,-0.429483,0.21373,0.061144,-0.431956,0.21312,0.061144,-0.478384,0.21312,0.061144,-0.478384,0.21312,0.061144,-0.426331,0.264268,0.061144,-0.426331,0.21912,0.061144,-0.42648,0.265643,0.061144,-0.426904,0.266905,0.061144,-0.427568,0.268019,0.061144,-0.428439,0.268949,0.061144,-0.429483,0.269658,0.061144,-0.430667,0.270109,0.061144,-0.478384,0.21312,0.061144,-0.431956,0.270268,0.061144,-0.430667,0.270109,0.061144,-0.478384,0.270268,0.061144,-0.431956,0.270268,0.061144,-0.479673,0.213279,0.061144,-0.480856,0.21373,0.061144,-0.481901,0.214439,0.061144,-0.482772,0.215369,0.061144,-0.483436,0.216483,0.061144,-0.48386,0.217745,0.061144,-0.484008,0.21912,0.061144,-0.478384,0.270268,0.061144,-0.48386,0.217745,0.061144,-0.484008,0.264268,0.061144,-0.478384,0.270268,0.061144,-0.484008,0.21912,0.061144,-0.484008,0.264268,0.061144,-0.479673,0.270109,0.061144,-0.478384,0.270268,0.061144,-0.48386,0.265643,0.061144,-0.479673,0.270109,0.061144,-0.484008,0.264268,0.061144,-0.480856,0.269658,0.061144,-0.483436,0.266905,0.061144,-0.481901,0.268949,0.061144,-0.482772,0.268019,0.061144,-0.613552,0.268768,0.061144,-0.616024,0.268158,0.061144,-0.614841,0.268609,0.061144,-0.617069,0.267449,0.061144,-0.61794,0.266519,0.061144,-0.618604,0.265405,0.061144,-0.619028,0.264143,0.061144,-0.619176,0.262768,0.061144,-0.508379,0.268768,0.061144,-0.619176,0.22062,0.061144,-0.619028,0.219245,0.061144,-0.508379,0.268768,0.061144,-0.618604,0.217983,0.061144,-0.619028,0.219245,0.061144,-0.61794,0.216869,0.061144,-0.618604,0.217983,0.061144,-0.617069,0.215939,0.061144,-0.616024,0.21523,0.061144,-0.614841,0.214779,0.061144,-0.613552,0.21462,0.061144,-0.508379,0.21462,0.061144,-0.507091,0.214779,0.061144,-0.505907,0.21523,0.061144,-0.504863,0.215939,0.061144,-0.503991,0.216869,0.061144,-0.503327,0.217983,0.061144,-0.508379,0.268768,0.061144,-0.502904,0.219245,0.061144,-0.503327,0.217983,0.061144,-0.508379,0.268768,0.061144,-0.502755,0.22062,0.061144,-0.502904,0.219245,0.061144,-0.502755,0.262768,0.061144,-0.502755,0.22062,0.061144,-0.502904,0.264143,0.061144,-0.507091,0.268609,0.061144,-0.505907,0.268158,0.061144,-0.503327,0.265405,0.061144,-0.503991,0.266519,0.061144,-0.504863,0.267449,0.061144,-0.626729,0.195257,0.061144,-0.627301,0.192619,0.061144,-0.627152,0.193994,0.061144,-0.626064,0.196371,0.061144,-0.625193,0.1973,0.061144,-0.624149,0.198009,0.061144,-0.622965,0.198461,0.061144,-0.621677,0.198619,0.061144,-0.575248,0.198619,0.061144,-0.627301,0.147471,0.061144,-0.627152,0.146096,0.061144,-0.626729,0.144834,0.061144,-0.626064,0.14372,0.061144,-0.625193,0.14279,0.061144,-0.624149,0.142082,0.061144,-0.622965,0.14163,0.061144,-0.621677,0.141471,0.061144,-0.575248,0.141471,0.061144,-0.573959,0.14163,0.061144,-0.572776,0.142082,0.061144,-0.571732,0.14279,0.061144,-0.57086,0.14372,0.061144,-0.570196,0.144834,0.061144,-0.569773,0.146096,0.061144,-0.575248,0.198619,0.061144,-0.569624,0.147471,0.061144,-0.569773,0.146096,0.061144,-0.569624,0.192619,0.061144,-0.569624,0.147471,0.061144,-0.569773,0.193994,0.061144,-0.573959,0.198461,0.061144,-0.570196,0.195257,0.061144,-0.572776,0.198009,0.061144,-0.571732,0.1973,0.061144,-0.57086,0.196371,0.061144,-0.554076,0.195257,0.061144,-0.554648,0.192619,0.061144,-0.554499,0.193994,0.061144,-0.553412,0.196371,0.061144,-0.55254,0.1973,0.061144,-0.551496,0.198009,0.061144,-0.550313,0.198461,0.061144,-0.549024,0.198619,0.061144,-0.502595,0.198619,0.061144,-0.554648,0.147471,0.061144,-0.554499,0.146096,0.061144,-0.554076,0.144834,0.061144,-0.553412,0.14372,0.061144,-0.55254,0.14279,0.061144,-0.551496,0.142082,0.061144,-0.550313,0.14163,0.061144,-0.549024,0.141471,0.061144,-0.502595,0.141471,0.061144,-0.501306,0.14163,0.061144,-0.500123,0.142082,0.061144,-0.499079,0.14279,0.061144,-0.498207,0.14372,0.061144,-0.497543,0.144834,0.061144,-0.49712,0.146096,0.061144,-0.502595,0.198619,0.061144,-0.496971,0.147471,0.061144,-0.49712,0.146096,0.061144,-0.496971,0.192619,0.061144,-0.496971,0.147471,0.061144,-0.49712,0.193994,0.061144,-0.501306,0.198461,0.061144,-0.500123,0.198009,0.061144,-0.497543,0.195257,0.061144,-0.499079,0.1973,0.061144,-0.498207,0.196371,0.061144,-0.480426,0.195257,0.061144,-0.480998,0.192619,0.061144,-0.480849,0.193994,0.061144,-0.479761,0.196371,0.061144,-0.47889,0.1973,0.061144,-0.477846,0.198009,0.061144,-0.476662,0.198461,0.061144,-0.475374,0.198619,0.061144,-0.428945,0.198619,0.061144,-0.480998,0.147471,0.061144,-0.480849,0.146096,0.061144,-0.480426,0.144834,0.061144,-0.479761,0.14372,0.061144,-0.47889,0.14279,0.061144,-0.477846,0.142082,0.061144,-0.476662,0.14163,0.061144,-0.475374,0.141471,0.061144,-0.428945,0.141471,0.061144,-0.427656,0.14163,0.061144,-0.426473,0.142082,0.061144,-0.425429,0.14279,0.061144,-0.424557,0.14372,0.061144,-0.423893,0.144834,0.061144,-0.423469,0.146096,0.061144,-0.428945,0.198619,0.061144,-0.423321,0.147471,0.061144,-0.423469,0.146096,0.061144,-0.423321,0.192619,0.061144,-0.423321,0.147471,0.061144,-0.423469,0.193994,0.061144,-0.427656,0.198461,0.061144,-0.426473,0.198009,0.061144,-0.423893,0.195257,0.061144,-0.424557,0.196371,0.061144,-0.425428,0.1973,0.061144,-0.406776,0.195257,0.061144,-0.407348,0.192619,0.061144,-0.407199,0.193994,0.061144,-0.406111,0.196371,0.061144,-0.40524,0.1973,0.061144,-0.404196,0.198009,0.061144,-0.403012,0.198461,0.061144,-0.401724,0.198619,0.061144,-0.355295,0.198619,0.061144,-0.407348,0.147471,0.061144,-0.407199,0.146096,0.061144,-0.406776,0.144834,0.061144,-0.406111,0.14372,0.061144,-0.40524,0.14279,0.061144,-0.404196,0.142082,0.061144,-0.403012,0.14163,0.061144,-0.401724,0.141471,0.061144,-0.355295,0.141471,0.061144,-0.354006,0.14163,0.061144,-0.352823,0.142082,0.061144,-0.351778,0.14279,0.061144,-0.350907,0.14372,0.061144,-0.350243,0.144834,0.061144,-0.349819,0.146096,0.061144,-0.355295,0.198619,0.061144,-0.349671,0.147471,0.061144,-0.349819,0.146096,0.061144,-0.349671,0.192619,0.061144,-0.349671,0.147471,0.061144,-0.349819,0.193994,0.061144,-0.354006,0.198461,0.061144,-0.352823,0.198009,0.061144,-0.350243,0.195257,0.061144,-0.350907,0.196371,0.061144,-0.351778,0.1973,0.061144,-0.333125,0.195257,0.061144,-0.333698,0.192619,0.061144,-0.333549,0.193994,0.061144,-0.332461,0.196371,0.061144,-0.33159,0.1973,0.061144,-0.330546,0.198009,0.061144,-0.329362,0.198461,0.061144,-0.328073,0.198619,0.061144,-0.281645,0.198619,0.061144,-0.333698,0.147471,0.061144,-0.333549,0.146096,0.061144,-0.333126,0.144834,0.061144,-0.332461,0.14372,0.061144,-0.33159,0.14279,0.061144,-0.330546,0.142082,0.061144,-0.329362,0.14163,0.061144,-0.328073,0.141471,0.061144,-0.281645,0.141471,0.061144,-0.280356,0.14163,0.061144,-0.279173,0.142082,0.061144,-0.278128,0.14279,0.061144,-0.277257,0.14372,0.061144,-0.276593,0.144834,0.061144,-0.276169,0.146096,0.061144,-0.281645,0.198619,0.061144,-0.276021,0.147471,0.061144,-0.276169,0.146096,0.061144,-0.276021,0.192619,0.061144,-0.276021,0.147471,0.061144,-0.276169,0.193994,0.061144,-0.280356,0.198461,0.061144,-0.279173,0.198009,0.061144,-0.276593,0.195257,0.061144,-0.278128,0.1973,0.061144,-0.277257,0.196371,0.061144,-0.205522,0.198009,0.061144,-0.207995,0.198619,0.061144,-0.206706,0.198461,0.061144,-0.204478,0.1973,0.061144,-0.203607,0.196371,0.061144,-0.202943,0.195257,0.061144,-0.202519,0.193994,0.061144,-0.20237,0.192619,0.061144,-0.20237,0.147471,0.061144,-0.254423,0.198619,0.061144,-0.202519,0.146096,0.061144,-0.202943,0.144834,0.061144,-0.203607,0.14372,0.061144,-0.204478,0.14279,0.061144,-0.205522,0.142082,0.061144,-0.206706,0.14163,0.061144,-0.207995,0.141471,0.061144,-0.254423,0.141471,0.061144,-0.255712,0.14163,0.061144,-0.256895,0.142082,0.061144,-0.25794,0.14279,0.061144,-0.258811,0.14372,0.061144,-0.259475,0.144834,0.061144,-0.259899,0.146096,0.061144,-0.260047,0.147471,0.061144,-0.254423,0.198619,0.061144,-0.259899,0.146096,0.061144,-0.260047,0.192619,0.061144,-0.260047,0.147471,0.061144,-0.259899,0.193994,0.061144,-0.255712,0.198461,0.061144,-0.259475,0.195257,0.061144,-0.256895,0.198009,0.061144,-0.25794,0.1973,0.061144,-0.258811,0.196371,0.061144,-0.131872,0.198009,0.061144,-0.134344,0.198619,0.061144,-0.133056,0.198461,0.061144,-0.130828,0.1973,0.061144,-0.129957,0.196371,0.061144,-0.129292,0.195257,0.061144,-0.128869,0.193994,0.061144,-0.12872,0.192619,0.061144,-0.12872,0.147471,0.061144,-0.180773,0.198619,0.061144,-0.128869,0.146096,0.061144,-0.129292,0.144834,0.061144,-0.129957,0.14372,0.061144,-0.130828,0.14279,0.061144,-0.131872,0.142082,0.061144,-0.133056,0.14163,0.061144,-0.134344,0.141471,0.061144,-0.180773,0.141471,0.061144,-0.182062,0.198461,0.061144,-0.183245,0.198009,0.061144,-0.18429,0.1973,0.061144,-0.185161,0.196371,0.061144,-0.185825,0.195257,0.061144,-0.186249,0.193994,0.061144,-0.180773,0.141471,0.061144,-0.186397,0.192619,0.061144,-0.186249,0.193994,0.061144,-0.186397,0.147471,0.061144,-0.186397,0.192619,0.061144,-0.182062,0.14163,0.061144,-0.186249,0.146096,0.061144,-0.185825,0.144834,0.061144,-0.183245,0.142082,0.061144,-0.185161,0.14372,0.061144,-0.18429,0.14279,0.061144,-0.058222,0.198009,0.061144,-0.060694,0.198619,0.061144,-0.059406,0.198461,0.061144,-0.057178,0.1973,0.061144,-0.056307,0.196371,0.061144,-0.055642,0.195257,0.061144,-0.055219,0.193994,0.061144,-0.05507,0.192619,0.061144,-0.05507,0.147471,0.061144,-0.107123,0.198619,0.061144,-0.055219,0.146096,0.061144,-0.055642,0.144834,0.061144,-0.056307,0.14372,0.061144,-0.057178,0.14279,0.061144,-0.058222,0.142082,0.061144,-0.059406,0.14163,0.061144,-0.060694,0.141471,0.061144,-0.107123,0.141471,0.061144,-0.108412,0.14163,0.061144,-0.109595,0.142082,0.061144,-0.110639,0.14279,0.061144,-0.111511,0.14372,0.061144,-0.112175,0.144834,0.061144,-0.112599,0.146096,0.061144,-0.112747,0.147471,0.061144,-0.107123,0.198619,0.061144,-0.112599,0.146096,0.061144,-0.112747,0.192619,0.061144,-0.112747,0.147471,0.061144,-0.108412,0.198461,0.061144,-0.112599,0.193994,0.061144,-0.112175,0.195257,0.061144,-0.109595,0.198009,0.061144,-0.111511,0.196371,0.061144,-0.110639,0.1973,0.061144,0.015428,0.198009,0.061144,0.012956,0.198619,0.061144,0.014245,0.198461,0.061144,0.016472,0.1973,0.061144,0.017344,0.196371,0.061144,0.018008,0.195257,0.061144,0.018431,0.193994,0.061144,0.01858,0.192619,0.061144,0.01858,0.147471,0.061144,-0.033473,0.198619,0.061144,0.018431,0.146096,0.061144,0.018008,0.144834,0.061144,0.017344,0.14372,0.061144,0.016472,0.14279,0.061144,0.015428,0.142082,0.061144,0.014245,0.14163,0.061144,0.012956,0.141471,0.061144,-0.033473,0.141471,0.061144,-0.034762,0.14163,0.061144,-0.035945,0.142082,0.061144,-0.036989,0.14279,0.061144,-0.037861,0.14372,0.061144,-0.038525,0.144834,0.061144,-0.038948,0.146096,0.061144,-0.039097,0.147471,0.061144,-0.033473,0.198619,0.061144,-0.038948,0.146096,0.061144,-0.039097,0.192619,0.061144,-0.039097,0.147471,0.061144,-0.034762,0.198461,0.061144,-0.038948,0.193994,0.061144,-0.038525,0.195257,0.061144,-0.035945,0.198009,0.061144,-0.037861,0.196371,0.061144,-0.036989,0.1973,0.061144,0.089078,0.198009,0.061144,0.086606,0.198619,0.061144,0.087895,0.198461,0.061144,0.090122,0.1973,0.061144,0.090994,0.196371,0.061144,0.091658,0.195257,0.061144,0.092081,0.193994,0.061144,0.09223,0.192619,0.061144,0.09223,0.147471,0.061144,0.040177,0.198619,0.061144,0.092081,0.146096,0.061144,0.091658,0.144834,0.061144,0.090994,0.14372,0.061144,0.090122,0.14279,0.061144,0.089078,0.142082,0.061144,0.087895,0.14163,0.061144,0.086606,0.141471,0.061144,0.040177,0.141471,0.061144,0.038889,0.14163,0.061144,0.037705,0.142082,0.061144,0.036661,0.14279,0.061144,0.03579,0.14372,0.061144,0.035125,0.144834,0.061144,0.034702,0.146096,0.061144,0.034553,0.147471,0.061144,0.040177,0.198619,0.061144,0.034702,0.146096,0.061144,0.034553,0.192619,0.061144,0.034553,0.147471,0.061144,0.038889,0.198461,0.061144,0.034702,0.193994,0.061144,0.035125,0.195257,0.061144,0.037705,0.198009,0.061144,0.03579,0.196371,0.061144,0.036661,0.1973,0.061144,0.162728,0.198009,0.061144,0.160256,0.198619,0.061144,0.161545,0.198461,0.061144,0.163773,0.1973,0.061144,0.164644,0.196371,0.061144,0.165308,0.195257,0.061144,0.165732,0.193994,0.061144,0.16588,0.192619,0.061144,0.16588,0.147471,0.061144,0.113827,0.198619,0.061144,0.165732,0.146096,0.061144,0.165308,0.144834,0.061144,0.164644,0.14372,0.061144,0.163773,0.14279,0.061144,0.162728,0.142082,0.061144,0.161545,0.14163,0.061144,0.160256,0.141471,0.061144,0.113827,0.141471,0.061144,0.112539,0.198461,0.061144,0.111355,0.198009,0.061144,0.110311,0.1973,0.061144,0.10944,0.196371,0.061144,0.108775,0.195257,0.061144,0.108352,0.193994,0.061144,0.113827,0.141471,0.061144,0.108203,0.192619,0.061144,0.108352,0.193994,0.061144,0.108203,0.147471,0.061144,0.108203,0.192619,0.061144,0.108352,0.146096,0.061144,0.112539,0.14163,0.061144,0.108775,0.144834,0.061144,0.111355,0.142082,0.061144,0.110311,0.14279,0.061144,0.10944,0.14372,0.061144,0.236378,0.198009,0.061144,0.233906,0.198619,0.061144,0.235195,0.198461,0.061144,0.237423,0.1973,0.061144,0.238294,0.196371,0.061144,0.238958,0.195257,0.061144,0.239382,0.193994,0.061144,0.23953,0.192619,0.061144,0.23953,0.147471,0.061144,0.187478,0.198619,0.061144,0.239382,0.146096,0.061144,0.238958,0.144834,0.061144,0.238294,0.14372,0.061144,0.237423,0.14279,0.061144,0.236378,0.142082,0.061144,0.235195,0.14163,0.061144,0.233906,0.141471,0.061144,0.187478,0.141471,0.061144,0.186189,0.14163,0.061144,0.185005,0.142082,0.061144,0.183961,0.14279,0.061144,0.18309,0.14372,0.061144,0.182426,0.144834,0.061144,0.182002,0.146097,0.061144,0.181853,0.147471,0.061144,0.187478,0.198619,0.061144,0.182002,0.146097,0.061144,0.181853,0.192619,0.061144,0.181853,0.147471,0.061144,0.182002,0.193994,0.061144,0.186189,0.198461,0.061144,0.185005,0.198009,0.061144,0.182426,0.195257,0.061144,0.18309,0.196371,0.061144,0.183961,0.1973,0.061144,0.310029,0.198009,0.061144,0.307556,0.198619,0.061144,0.308845,0.198461,0.061144,0.311073,0.1973,0.061144,0.311944,0.196371,0.061144,0.312609,0.195257,0.061144,0.313032,0.193994,0.061144,0.313181,0.192619,0.061144,0.313181,0.147471,0.061144,0.261128,0.198619,0.061144,0.313032,0.146096,0.061144,0.312608,0.144834,0.061144,0.311944,0.14372,0.061144,0.311073,0.14279,0.061144,0.310029,0.142082,0.061144,0.308845,0.14163,0.061144,0.307556,0.141471,0.061144,0.261128,0.141471,0.061144,0.259839,0.14163,0.061144,0.258656,0.142082,0.061144,0.257611,0.14279,0.061144,0.25674,0.14372,0.061144,0.256076,0.144834,0.061144,0.255652,0.146097,0.061144,0.255504,0.147471,0.061144,0.261128,0.198619,0.061144,0.255652,0.146097,0.061144,0.255504,0.192619,0.061144,0.255504,0.147471,0.061144,0.255652,0.193994,0.061144,0.259839,0.198461,0.061144,0.258656,0.198009,0.061144,0.256076,0.195257,0.061144,0.25674,0.196371,0.061144,0.257611,0.1973,0.061144,0.446193,0.196509,0.061144,0.443721,0.197119,0.061144,0.44501,0.196961,0.061144,0.447238,0.1958,0.061144,0.448109,0.194871,0.061144,0.448773,0.193757,0.061144,0.449197,0.192494,0.061144,0.449346,0.191119,0.061144,0.449346,0.148971,0.061144,0.338548,0.197119,0.061144,0.449197,0.147597,0.061144,0.448773,0.146334,0.061144,0.448109,0.14522,0.061144,0.447238,0.14429,0.061144,0.446193,0.143582,0.061144,0.44501,0.14313,0.061144,0.443721,0.142971,0.061144,0.338548,0.142971,0.061144,0.33726,0.14313,0.061144,0.336076,0.143582,0.061144,0.335032,0.14429,0.061144,0.334161,0.14522,0.061144,0.333496,0.146334,0.061144,0.333073,0.147596,0.061144,0.332924,0.148971,0.061144,0.338548,0.197119,0.061144,0.333073,0.147596,0.061144,0.332924,0.191119,0.061144,0.332924,0.148971,0.061144,0.333073,0.192494,0.061144,0.33726,0.196961,0.061144,0.336076,0.196509,0.061144,0.333496,0.193757,0.061144,0.335032,0.1958,0.061144,0.334161,0.194871,0.061144,-0.496522,0.122376,0.061144,-0.497094,0.119739,0.061144,-0.496945,0.121114,0.061144,-0.495857,0.12349,0.061144,-0.497094,0.119739,0.061144,-0.496522,0.122376,0.061144,-0.494986,0.12442,0.061144,-0.497094,0.119739,0.061144,-0.495857,0.12349,0.061144,-0.493942,0.125129,0.061144,-0.497094,0.119739,0.061144,-0.494986,0.12442,0.061144,-0.492758,0.12558,0.061144,-0.497094,0.119739,0.061144,-0.493942,0.125129,0.061144,-0.49147,0.125739,0.061144,-0.497094,0.119739,0.061144,-0.492758,0.12558,0.061144,-0.445041,0.125739,0.061144,-0.445041,0.125739,0.061144,-0.497094,0.074591,0.061144,-0.497094,0.119739,0.061144,-0.496945,0.073216,0.061144,-0.496522,0.071954,0.061144,-0.495857,0.07084,0.061144,-0.494986,0.06991,0.061144,-0.493942,0.069201,0.061144,-0.492758,0.06875,0.061144,-0.49147,0.068591,0.061144,-0.445041,0.068591,0.061144,-0.443752,0.06875,0.061144,-0.442569,0.069201,0.061144,-0.441525,0.06991,0.061144,-0.440653,0.07084,0.061144,-0.439989,0.071954,0.061144,-0.439566,0.073216,0.061144,-0.445041,0.125739,0.061144,-0.439417,0.074591,0.061144,-0.439566,0.073216,0.061144,-0.445041,0.125739,0.061144,-0.439417,0.119739,0.061144,-0.439417,0.074591,0.061144,-0.439566,0.121114,0.061144,-0.443752,0.12558,0.061144,-0.439566,0.121114,0.061144,-0.445041,0.125739,0.061144,-0.442569,0.125129,0.061144,-0.439566,0.121114,0.061144,-0.443752,0.12558,0.061144,-0.442569,0.125129,0.061144,-0.439989,0.122376,0.061144,-0.439566,0.121114,0.061144,-0.442569,0.125129,0.061144,-0.440653,0.12349,0.061144,-0.439989,0.122376,0.061144,-0.441525,0.12442,0.061144,-0.422872,0.122376,0.061144,-0.423444,0.119739,0.061144,-0.423295,0.121114,0.061144,-0.422207,0.12349,0.061144,-0.423444,0.119739,0.061144,-0.422872,0.122376,0.061144,-0.421336,0.12442,0.061144,-0.423444,0.119739,0.061144,-0.422207,0.12349,0.061144,-0.420292,0.125129,0.061144,-0.423444,0.119739,0.061144,-0.421336,0.12442,0.061144,-0.419108,0.12558,0.061144,-0.423444,0.119739,0.061144,-0.420292,0.125129,0.061144,-0.41782,0.125739,0.061144,-0.423444,0.119739,0.061144,-0.419108,0.12558,0.061144,-0.371391,0.125739,0.061144,-0.371391,0.125739,0.061144,-0.423444,0.074591,0.061144,-0.423444,0.119739,0.061144,-0.423295,0.073216,0.061144,-0.422872,0.071954,0.061144,-0.422207,0.07084,0.061144,-0.421336,0.06991,0.061144,-0.420292,0.069201,0.061144,-0.419108,0.06875,0.061144,-0.41782,0.068591,0.061144,-0.371391,0.068591,0.061144,-0.370102,0.12558,0.061144,-0.368919,0.125129,0.061144,-0.367874,0.12442,0.061144,-0.367003,0.12349,0.061144,-0.366339,0.122376,0.061144,-0.365915,0.121114,0.061144,-0.371391,0.068591,0.061144,-0.366339,0.122376,0.061144,-0.365767,0.119739,0.061144,-0.365915,0.121114,0.061144,-0.365767,0.074591,0.061144,-0.365915,0.073216,0.061144,-0.370102,0.06875,0.061144,-0.368919,0.069201,0.061144,-0.366339,0.071954,0.061144,-0.367003,0.07084,0.061144,-0.367874,0.06991,0.061144,-0.349221,0.122376,0.061144,-0.349794,0.119739,0.061144,-0.349645,0.121114,0.061144,-0.348557,0.12349,0.061144,-0.349794,0.119739,0.061144,-0.349221,0.122376,0.061144,-0.347686,0.12442,0.061144,-0.349794,0.119739,0.061144,-0.348557,0.12349,0.061144,-0.346642,0.125129,0.061144,-0.349794,0.119739,0.061144,-0.347686,0.12442,0.061144,-0.345458,0.12558,0.061144,-0.349794,0.119739,0.061144,-0.346642,0.125129,0.061144,-0.344169,0.125739,0.061144,-0.349794,0.119739,0.061144,-0.345458,0.12558,0.061144,-0.297741,0.125739,0.061144,-0.297741,0.125739,0.061144,-0.349794,0.074591,0.061144,-0.349794,0.119739,0.061144,-0.349645,0.073216,0.061144,-0.349221,0.071954,0.061144,-0.348557,0.07084,0.061144,-0.347686,0.06991,0.061144,-0.346642,0.069201,0.061144,-0.345458,0.06875,0.061144,-0.344169,0.068591,0.061144,-0.297741,0.068591,0.061144,-0.296452,0.12558,0.061144,-0.295269,0.125129,0.061144,-0.294224,0.12442,0.061144,-0.293353,0.12349,0.061144,-0.292689,0.122376,0.061144,-0.292265,0.121114,0.061144,-0.297741,0.068591,0.061144,-0.292689,0.122376,0.061144,-0.292117,0.119739,0.061144,-0.292265,0.121114,0.061144,-0.292117,0.074591,0.061144,-0.292265,0.073216,0.061144,-0.296452,0.06875,0.061144,-0.295269,0.069201,0.061144,-0.292689,0.071954,0.061144,-0.293353,0.07084,0.061144,-0.294224,0.06991,0.061144,-0.276143,0.074591,0.061144,-0.275571,0.071954,0.061144,-0.275995,0.073216,0.061144,-0.274907,0.07084,0.061144,-0.274036,0.06991,0.061144,-0.272991,0.069201,0.061144,-0.271808,0.06875,0.061144,-0.270519,0.068591,0.061144,-0.276143,0.119739,0.061144,-0.224091,0.068591,0.061144,-0.275995,0.121114,0.061144,-0.275571,0.122376,0.061144,-0.224091,0.068591,0.061144,-0.275995,0.121114,0.061144,-0.274907,0.12349,0.061144,-0.275571,0.122376,0.061144,-0.274036,0.12442,0.061144,-0.272991,0.125129,0.061144,-0.271808,0.12558,0.061144,-0.270519,0.125739,0.061144,-0.224091,0.125739,0.061144,-0.222802,0.06875,0.061144,-0.221618,0.069201,0.061144,-0.220574,0.06991,0.061144,-0.219703,0.07084,0.061144,-0.219039,0.071954,0.061144,-0.218615,0.073216,0.061144,-0.224091,0.125739,0.061144,-0.218466,0.074591,0.061144,-0.218615,0.073216,0.061144,-0.224091,0.125739,0.061144,-0.218466,0.119739,0.061144,-0.218466,0.074591,0.061144,-0.218615,0.121114,0.061144,-0.222802,0.12558,0.061144,-0.218615,0.121114,0.061144,-0.224091,0.125739,0.061144,-0.222802,0.12558,0.061144,-0.219039,0.122376,0.061144,-0.218615,0.121114,0.061144,-0.221618,0.125129,0.061144,-0.219039,0.122376,0.061144,-0.222802,0.12558,0.061144,-0.219703,0.12349,0.061144,-0.220574,0.12442,0.061144,-0.15044,0.068591,0.061144,-0.147968,0.069201,0.061144,-0.149152,0.06875,0.061144,-0.146924,0.06991,0.061144,-0.146053,0.07084,0.061144,-0.145388,0.071954,0.061144,-0.144965,0.073216,0.061144,-0.144816,0.074591,0.061144,-0.196869,0.068591,0.061144,-0.144816,0.119739,0.061144,-0.144965,0.121114,0.061144,-0.196869,0.068591,0.061144,-0.145388,0.122376,0.061144,-0.144965,0.121114,0.061144,-0.146053,0.12349,0.061144,-0.145388,0.122376,0.061144,-0.146924,0.12442,0.061144,-0.147968,0.125129,0.061144,-0.149152,0.12558,0.061144,-0.15044,0.125739,0.061144,-0.196869,0.125739,0.061144,-0.198158,0.06875,0.061144,-0.199341,0.069201,0.061144,-0.200386,0.06991,0.061144,-0.201257,0.07084,0.061144,-0.201921,0.071954,0.061144,-0.202345,0.073216,0.061144,-0.202493,0.074591,0.061144,-0.196869,0.125739,0.061144,-0.202345,0.073216,0.061144,-0.202493,0.119739,0.061144,-0.196869,0.125739,0.061144,-0.202493,0.074591,0.061144,-0.202345,0.121114,0.061144,-0.202345,0.121114,0.061144,-0.198158,0.12558,0.061144,-0.196869,0.125739,0.061144,-0.201921,0.122376,0.061144,-0.198158,0.12558,0.061144,-0.202345,0.121114,0.061144,-0.201921,0.122376,0.061144,-0.199341,0.125129,0.061144,-0.198158,0.12558,0.061144,-0.200386,0.12442,0.061144,-0.201257,0.12349,0.061144,-0.07679,0.068591,0.061144,-0.074318,0.069201,0.061144,-0.075502,0.06875,0.061144,-0.073274,0.06991,0.061144,-0.072403,0.07084,0.061144,-0.071738,0.071954,0.061144,-0.071315,0.073216,0.061144,-0.071166,0.074591,0.061144,-0.071166,0.119739,0.061144,-0.123219,0.068591,0.061144,-0.071315,0.121114,0.061144,-0.123219,0.068591,0.061144,-0.071738,0.122376,0.061144,-0.071315,0.121114,0.061144,-0.072403,0.12349,0.061144,-0.071738,0.122376,0.061144,-0.073274,0.12442,0.061144,-0.074318,0.125129,0.061144,-0.075502,0.12558,0.061144,-0.07679,0.125739,0.061144,-0.123219,0.125739,0.061144,-0.124508,0.06875,0.061144,-0.125691,0.069201,0.061144,-0.126735,0.06991,0.061144,-0.127607,0.07084,0.061144,-0.128271,0.071954,0.061144,-0.128694,0.073216,0.061144,-0.128843,0.074591,0.061144,-0.123219,0.125739,0.061144,-0.128694,0.073216,0.061144,-0.128843,0.119739,0.061144,-0.123219,0.125739,0.061144,-0.128843,0.074591,0.061144,-0.128694,0.121114,0.061144,-0.128694,0.121114,0.061144,-0.124508,0.12558,0.061144,-0.123219,0.125739,0.061144,-0.128271,0.122376,0.061144,-0.124508,0.12558,0.061144,-0.128694,0.121114,0.061144,-0.128271,0.122376,0.061144,-0.125691,0.125129,0.061144,-0.124508,0.12558,0.061144,-0.126735,0.12442,0.061144,-0.127607,0.12349,0.061144,-0.00314,0.068591,0.061144,-0.000668,0.069201,0.061144,-0.001851,0.06875,0.061144,0.000376,0.06991,0.061144,0.001248,0.07084,0.061144,0.001912,0.071954,0.061144,0.002335,0.073216,0.061144,0.002484,0.074591,0.061144,-0.049569,0.068591,0.061144,0.002484,0.119739,0.061144,0.002335,0.121114,0.061144,-0.049569,0.068591,0.061144,0.001912,0.122376,0.061144,0.002335,0.121114,0.061144,0.001248,0.12349,0.061144,0.001912,0.122376,0.061144,0.000376,0.12442,0.061144,-0.000668,0.125129,0.061144,-0.001851,0.12558,0.061144,-0.00314,0.125739,0.061144,-0.049569,0.125739,0.061144,-0.050858,0.06875,0.061144,-0.052041,0.069201,0.061144,-0.053085,0.06991,0.061144,-0.053957,0.07084,0.061144,-0.054621,0.071954,0.061144,-0.055044,0.073216,0.061144,-0.055193,0.074591,0.061144,-0.049569,0.125739,0.061144,-0.055044,0.073216,0.061144,-0.055193,0.119739,0.061144,-0.049569,0.125739,0.061144,-0.055193,0.074591,0.061144,-0.055044,0.121114,0.061144,-0.055044,0.121114,0.061144,-0.050858,0.12558,0.061144,-0.049569,0.125739,0.061144,-0.054621,0.122376,0.061144,-0.050858,0.12558,0.061144,-0.055044,0.121114,0.061144,-0.054621,0.122376,0.061144,-0.052041,0.125129,0.061144,-0.050858,0.12558,0.061144,-0.053085,0.12442,0.061144,-0.053957,0.12349,0.061144,0.07051,0.068591,0.061144,0.072982,0.069201,0.061144,0.071799,0.06875,0.061144,0.074026,0.06991,0.061144,0.074898,0.07084,0.061144,0.075562,0.071954,0.061144,0.075985,0.073216,0.061144,0.076134,0.074591,0.061144,0.024081,0.068591,0.061144,0.076134,0.119739,0.061144,0.075985,0.121114,0.061144,0.024081,0.068591,0.061144,0.075562,0.122376,0.061144,0.075985,0.121114,0.061144,0.074898,0.12349,0.061144,0.075562,0.122376,0.061144,0.074026,0.12442,0.061144,0.072982,0.125129,0.061144,0.071799,0.12558,0.061144,0.07051,0.125739,0.061144,0.024081,0.125739,0.061144,0.022793,0.06875,0.061144,0.021609,0.069201,0.061144,0.020565,0.06991,0.061144,0.019694,0.07084,0.061144,0.019029,0.071954,0.061144,0.018606,0.073216,0.061144,0.018457,0.074591,0.061144,0.024081,0.125739,0.061144,0.018606,0.073216,0.061144,0.018457,0.119739,0.061144,0.024081,0.125739,0.061144,0.018457,0.074591,0.061144,0.018606,0.121114,0.061144,0.018606,0.121114,0.061144,0.022793,0.12558,0.061144,0.024081,0.125739,0.061144,0.019029,0.122376,0.061144,0.022793,0.12558,0.061144,0.018606,0.121114,0.061144,0.019029,0.122376,0.061144,0.021609,0.125129,0.061144,0.022793,0.12558,0.061144,0.020565,0.12442,0.061144,0.019694,0.12349,0.061144,0.149784,0.119739,0.061144,0.149212,0.122376,0.061144,0.149636,0.121114,0.061144,0.149784,0.119739,0.061144,0.148548,0.12349,0.061144,0.149212,0.122376,0.061144,0.149784,0.119739,0.061144,0.147677,0.12442,0.061144,0.148548,0.12349,0.061144,0.149784,0.119739,0.061144,0.146632,0.125129,0.061144,0.147677,0.12442,0.061144,0.149784,0.119739,0.061144,0.145449,0.12558,0.061144,0.146632,0.125129,0.061144,0.149784,0.119739,0.061144,0.14416,0.125739,0.061144,0.145449,0.12558,0.061144,0.149784,0.074591,0.061144,0.14416,0.125739,0.061144,0.149784,0.119739,0.061144,0.149784,0.074591,0.061144,0.097731,0.125739,0.061144,0.14416,0.125739,0.061144,0.149636,0.073216,0.061144,0.149212,0.071954,0.061144,0.148548,0.07084,0.061144,0.147677,0.06991,0.061144,0.146632,0.069201,0.061144,0.145449,0.06875,0.061144,0.14416,0.068591,0.061144,0.097731,0.068591,0.061144,0.096443,0.06875,0.061144,0.095259,0.069201,0.061144,0.094215,0.06991,0.061144,0.093344,0.07084,0.061144,0.092679,0.071954,0.061144,0.092256,0.073216,0.061144,0.092107,0.074591,0.061144,0.097731,0.125739,0.061144,0.092256,0.073216,0.061144,0.092107,0.119739,0.061144,0.097731,0.125739,0.061144,0.092107,0.074591,0.061144,0.092256,0.121114,0.061144,0.092256,0.121114,0.061144,0.096443,0.12558,0.061144,0.097731,0.125739,0.061144,0.092256,0.121114,0.061144,0.095259,0.125129,0.061144,0.096443,0.12558,0.061144,0.092679,0.122376,0.061144,0.095259,0.125129,0.061144,0.092256,0.121114,0.061144,0.092679,0.122376,0.061144,0.094215,0.12442,0.061144,0.095259,0.125129,0.061144,0.093344,0.12349,0.061144,0.223434,0.119739,0.061144,0.222862,0.122376,0.061144,0.223286,0.121114,0.061144,0.223434,0.119739,0.061144,0.222198,0.12349,0.061144,0.222862,0.122376,0.061144,0.223434,0.119739,0.061144,0.221327,0.12442,0.061144,0.222198,0.12349,0.061144,0.223434,0.119739,0.061144,0.220282,0.125129,0.061144,0.221327,0.12442,0.061144,0.223434,0.119739,0.061144,0.219099,0.12558,0.061144,0.220282,0.125129,0.061144,0.223434,0.119739,0.061144,0.21781,0.125739,0.061144,0.219099,0.12558,0.061144,0.223434,0.074591,0.061144,0.21781,0.125739,0.061144,0.223434,0.119739,0.061144,0.223434,0.074591,0.061144,0.171382,0.125739,0.061144,0.21781,0.125739,0.061144,0.223286,0.073216,0.061144,0.222862,0.071954,0.061144,0.222198,0.07084,0.061144,0.221327,0.06991,0.061144,0.220282,0.069201,0.061144,0.219099,0.06875,0.061144,0.21781,0.068591,0.061144,0.171382,0.068591,0.061144,0.170093,0.06875,0.061144,0.168909,0.069201,0.061144,0.167865,0.06991,0.061144,0.166994,0.07084,0.061144,0.16633,0.071954,0.061144,0.165906,0.073216,0.061144,0.165757,0.074591,0.061144,0.171382,0.125739,0.061144,0.165906,0.073216,0.061144,0.165757,0.119739,0.061144,0.171382,0.125739,0.061144,0.165757,0.074591,0.061144,0.165906,0.121114,0.061144,0.165906,0.121114,0.061144,0.170093,0.12558,0.061144,0.171382,0.125739,0.061144,0.16633,0.122376,0.061144,0.170093,0.12558,0.061144,0.165906,0.121114,0.061144,0.16633,0.122376,0.061144,0.168909,0.125129,0.061144,0.170093,0.12558,0.061144,0.167865,0.12442,0.061144,0.166994,0.12349,0.061144,0.297085,0.119739,0.061144,0.296512,0.122376,0.061144,0.296936,0.121114,0.061144,0.297085,0.119739,0.061144,0.295848,0.12349,0.061144,0.296512,0.122376,0.061144,0.297085,0.119739,0.061144,0.294977,0.12442,0.061144,0.295848,0.12349,0.061144,0.297085,0.119739,0.061144,0.293933,0.125129,0.061144,0.294977,0.12442,0.061144,0.297085,0.119739,0.061144,0.292749,0.12558,0.061144,0.293933,0.125129,0.061144,0.297085,0.119739,0.061144,0.29146,0.125739,0.061144,0.292749,0.12558,0.061144,0.297085,0.074591,0.061144,0.29146,0.125739,0.061144,0.297085,0.119739,0.061144,0.297085,0.074591,0.061144,0.245032,0.125739,0.061144,0.29146,0.125739,0.061144,0.296936,0.073216,0.061144,0.296513,0.071954,0.061144,0.295848,0.07084,0.061144,0.294977,0.06991,0.061144,0.293933,0.069201,0.061144,0.292749,0.06875,0.061144,0.29146,0.068591,0.061144,0.245032,0.068591,0.061144,0.243743,0.06875,0.061144,0.24256,0.069201,0.061144,0.241515,0.06991,0.061144,0.240644,0.07084,0.061144,0.23998,0.071954,0.061144,0.239556,0.073216,0.061144,0.239408,0.074591,0.061144,0.245032,0.125739,0.061144,0.239556,0.073216,0.061144,0.239408,0.119739,0.061144,0.245032,0.125739,0.061144,0.239408,0.074591,0.061144,0.239556,0.121114,0.061144,0.239556,0.121114,0.061144,0.243743,0.12558,0.061144,0.245032,0.125739,0.061144,0.239556,0.121114,0.061144,0.24256,0.125129,0.061144,0.243743,0.12558,0.061144,0.23998,0.122376,0.061144,0.24256,0.125129,0.061144,0.239556,0.121114,0.061144,0.23998,0.122376,0.061144,0.241515,0.12442,0.061144,0.24256,0.125129,0.061144,0.240644,0.12349,0.061144,0.448773,0.073454,0.061144,0.449346,0.076091,0.061144,0.449197,0.074716,0.061144,0.448109,0.07234,0.061144,0.447238,0.07141,0.061144,0.446194,0.070701,0.061144,0.44501,0.07025,0.061144,0.443721,0.070091,0.061144,0.316428,0.070091,0.061144,0.449346,0.118239,0.061144,0.449197,0.119614,0.061144,0.448774,0.120876,0.061144,0.448109,0.12199,0.061144,0.316428,0.070091,0.061144,0.447238,0.12292,0.061144,0.448109,0.12199,0.061144,0.446194,0.123629,0.061144,0.447238,0.12292,0.061144,0.44501,0.12408,0.061144,0.443721,0.124239,0.061144,0.316428,0.124239,0.061144,0.31514,0.07025,0.061144,0.313956,0.070701,0.061144,0.312912,0.07141,0.061144,0.312041,0.07234,0.061144,0.311376,0.073454,0.061144,0.310953,0.074716,0.061144,0.310804,0.076091,0.061144,0.316428,0.124239,0.061144,0.310953,0.074716,0.061144,0.310804,0.118239,0.061144,0.316428,0.124239,0.061144,0.310804,0.076091,0.061144,0.310953,0.119614,0.061144,0.310953,0.119614,0.061144,0.31514,0.12408,0.061144,0.316428,0.124239,0.061144,0.310953,0.119614,0.061144,0.313956,0.123629,0.061144,0.31514,0.12408,0.061144,0.311376,0.120876,0.061144,0.313956,0.123629,0.061144,0.310953,0.119614,0.061144,0.311376,0.120876,0.061144,0.312912,0.12292,0.061144,0.313956,0.123629,0.061144,0.312041,0.12199,0.061144,0.312912,0.12292,0.061144,0.311376,0.120876,0.061144,-0.627301,0.076091,0.061144,-0.626729,0.073454,0.061144,-0.627152,0.074716,0.061144,-0.626064,0.07234,0.061144,-0.625193,0.07141,0.061144,-0.624149,0.070701,0.061144,-0.622965,0.07025,0.061144,-0.621677,0.070091,0.061144,-0.627301,0.118239,0.061144,-0.516504,0.070091,0.061144,-0.627152,0.119614,0.061144,-0.626729,0.120876,0.061144,-0.626064,0.12199,0.061144,-0.625193,0.12292,0.061144,-0.516504,0.070091,0.061144,-0.626064,0.12199,0.061144,-0.624149,0.123629,0.061144,-0.625193,0.12292,0.061144,-0.622965,0.12408,0.061144,-0.621677,0.124239,0.061144,-0.516504,0.124239,0.061144,-0.515215,0.07025,0.061144,-0.514032,0.070701,0.061144,-0.512987,0.07141,0.061144,-0.512116,0.07234,0.061144,-0.511452,0.073454,0.061144,-0.511028,0.074716,0.061144,-0.516504,0.124239,0.061144,-0.51088,0.076091,0.061144,-0.511028,0.074716,0.061144,-0.516504,0.124239,0.061144,-0.51088,0.118239,0.061144,-0.51088,0.076091,0.061144,-0.511028,0.119614,0.061144,-0.515215,0.12408,0.061144,-0.511028,0.119614,0.061144,-0.516504,0.124239,0.061144,-0.514032,0.123629,0.061144,-0.511028,0.119614,0.061144,-0.515215,0.12408,0.061144,-0.514032,0.123629,0.061144,-0.511452,0.120876,0.061144,-0.511028,0.119614,0.061144,-0.514032,0.123629,0.061144,-0.512116,0.12199,0.061144,-0.511452,0.120876,0.061144,-0.512987,0.12292,0.061144,-0.512116,0.12199,0.061144,-0.514032,0.123629,0.061144,-0.44314,0.049838,0.061144,-0.443712,0.0472,0.061144,-0.443564,0.048575,0.061144,-0.442476,0.050952,0.061144,-0.443712,0.0472,0.061144,-0.44314,0.049838,0.061144,-0.441605,0.051881,0.061144,-0.443712,0.0472,0.061144,-0.442476,0.050952,0.061144,-0.44056,0.05259,0.061144,-0.443712,0.0472,0.061144,-0.441605,0.051881,0.061144,-0.439377,0.053042,0.061144,-0.443712,0.0472,0.061144,-0.44056,0.05259,0.061144,-0.438088,0.0532,0.061144,-0.391659,0.0532,0.061144,-0.391659,0.0532,0.061144,-0.443712,0.002052,0.061144,-0.443712,0.0472,0.061144,-0.443564,0.000678,0.061144,-0.391659,0.0532,0.061144,-0.44314,-0.000585,0.061144,-0.443564,0.000678,0.061144,-0.442476,-0.001699,0.061144,-0.44314,-0.000585,0.061144,-0.441605,-0.002629,0.061144,-0.44056,-0.003337,0.061144,-0.439377,-0.003789,0.061144,-0.438088,-0.003948,0.061144,-0.391659,-0.003948,0.061144,-0.390371,-0.003789,0.061144,-0.389187,-0.003337,0.061144,-0.388143,-0.002629,0.061144,-0.387272,-0.001699,0.061144,-0.391659,0.0532,0.061144,-0.386607,-0.000585,0.061144,-0.387272,-0.001699,0.061144,-0.391659,0.0532,0.061144,-0.386184,0.000678,0.061144,-0.386607,-0.000585,0.061144,-0.386035,0.002052,0.061144,-0.386184,0.000678,0.061144,-0.386035,0.0472,0.061144,-0.386184,0.048575,0.061144,-0.390371,0.053042,0.061144,-0.386184,0.048575,0.061144,-0.390371,0.053042,0.061144,-0.386607,0.049838,0.061144,-0.386184,0.048575,0.061144,-0.389187,0.05259,0.061144,-0.386607,0.049838,0.061144,-0.390371,0.053042,0.061144,-0.388143,0.051881,0.061144,-0.387272,0.050952,0.061144,-0.36949,0.049838,0.061144,-0.370062,0.0472,0.061144,-0.369914,0.048575,0.061144,-0.368826,0.050952,0.061144,-0.370062,0.0472,0.061144,-0.36949,0.049838,0.061144,-0.367954,0.051881,0.061144,-0.370062,0.0472,0.061144,-0.368826,0.050952,0.061144,-0.36691,0.05259,0.061144,-0.370062,0.0472,0.061144,-0.367954,0.051881,0.061144,-0.365727,0.053042,0.061144,-0.370062,0.0472,0.061144,-0.36691,0.05259,0.061144,-0.364438,0.0532,0.061144,-0.318009,0.0532,0.061144,-0.318009,0.0532,0.061144,-0.370062,0.002052,0.061144,-0.370062,0.0472,0.061144,-0.369914,0.000678,0.061144,-0.318009,0.0532,0.061144,-0.36949,-0.000585,0.061144,-0.369914,0.000678,0.061144,-0.368826,-0.001699,0.061144,-0.36949,-0.000585,0.061144,-0.367954,-0.002629,0.061144,-0.36691,-0.003337,0.061144,-0.365727,-0.003789,0.061144,-0.364438,-0.003948,0.061144,-0.318009,-0.003948,0.061144,-0.316721,-0.003789,0.061144,-0.315537,-0.003337,0.061144,-0.314493,-0.002629,0.061144,-0.313622,-0.001699,0.061144,-0.318009,0.0532,0.061144,-0.312957,-0.000585,0.061144,-0.313622,-0.001699,0.061144,-0.318009,0.0532,0.061144,-0.312534,0.000678,0.061144,-0.312957,-0.000585,0.061144,-0.312385,0.002052,0.061144,-0.312534,0.000678,0.061144,-0.312385,0.0472,0.061144,-0.312534,0.048575,0.061144,-0.316721,0.053042,0.061144,-0.312534,0.048575,0.061144,-0.316721,0.053042,0.061144,-0.312957,0.049838,0.061144,-0.312534,0.048575,0.061144,-0.315537,0.05259,0.061144,-0.312957,0.049838,0.061144,-0.316721,0.053042,0.061144,-0.313622,0.050952,0.061144,-0.314493,0.051881,0.061144,-0.29584,0.049838,0.061144,-0.296412,0.0472,0.061144,-0.296263,0.048575,0.061144,-0.295176,0.050952,0.061144,-0.296412,0.0472,0.061144,-0.29584,0.049838,0.061144,-0.294304,0.051881,0.061144,-0.296412,0.0472,0.061144,-0.295176,0.050952,0.061144,-0.29326,0.05259,0.061144,-0.296412,0.0472,0.061144,-0.294304,0.051881,0.061144,-0.292077,0.053042,0.061144,-0.296412,0.0472,0.061144,-0.29326,0.05259,0.061144,-0.290788,0.0532,0.061144,-0.244359,0.0532,0.061144,-0.244359,0.0532,0.061144,-0.296412,0.002052,0.061144,-0.296412,0.0472,0.061144,-0.296263,0.000678,0.061144,-0.244359,0.0532,0.061144,-0.29584,-0.000585,0.061144,-0.296263,0.000678,0.061144,-0.295176,-0.001699,0.061144,-0.29584,-0.000585,0.061144,-0.294304,-0.002629,0.061144,-0.29326,-0.003337,0.061144,-0.292077,-0.003789,0.061144,-0.290788,-0.003948,0.061144,-0.244359,-0.003948,0.061144,-0.243071,-0.003789,0.061144,-0.241887,-0.003337,0.061144,-0.240843,-0.002629,0.061144,-0.239971,-0.001699,0.061144,-0.244359,0.0532,0.061144,-0.239307,-0.000585,0.061144,-0.239971,-0.001699,0.061144,-0.244359,0.0532,0.061144,-0.238884,0.000678,0.061144,-0.239307,-0.000585,0.061144,-0.238735,0.002052,0.061144,-0.238884,0.000678,0.061144,-0.238735,0.0472,0.061144,-0.238884,0.048575,0.061144,-0.243071,0.053042,0.061144,-0.238884,0.048575,0.061144,-0.243071,0.053042,0.061144,-0.239307,0.049838,0.061144,-0.238884,0.048575,0.061144,-0.241887,0.05259,0.061144,-0.239307,0.049838,0.061144,-0.243071,0.053042,0.061144,-0.240843,0.051881,0.061144,-0.239971,0.050952,0.061144,-0.22219,0.049838,0.061144,-0.222762,0.0472,0.061144,-0.222613,0.048575,0.061144,-0.221525,0.050952,0.061144,-0.222762,0.0472,0.061144,-0.22219,0.049838,0.061144,-0.220654,0.051881,0.061144,-0.222762,0.0472,0.061144,-0.221525,0.050952,0.061144,-0.21961,0.05259,0.061144,-0.222762,0.0472,0.061144,-0.220654,0.051881,0.061144,-0.218426,0.053042,0.061144,-0.222762,0.0472,0.061144,-0.21961,0.05259,0.061144,-0.217138,0.0532,0.061144,-0.170709,0.0532,0.061144,-0.170709,0.0532,0.061144,-0.222762,0.002052,0.061144,-0.222762,0.0472,0.061144,-0.222613,0.000678,0.061144,-0.170709,0.0532,0.061144,-0.22219,-0.000585,0.061144,-0.222613,0.000678,0.061144,-0.221526,-0.001699,0.061144,-0.22219,-0.000585,0.061144,-0.220654,-0.002629,0.061144,-0.21961,-0.003337,0.061144,-0.218426,-0.003789,0.061144,-0.217138,-0.003948,0.061144,-0.170709,-0.003948,0.061144,-0.16942,-0.003789,0.061144,-0.168237,-0.003337,0.061144,-0.167193,-0.002629,0.061144,-0.166321,-0.001699,0.061144,-0.170709,0.0532,0.061144,-0.165657,-0.000585,0.061144,-0.166321,-0.001699,0.061144,-0.170709,0.0532,0.061144,-0.165234,0.000678,0.061144,-0.165657,-0.000585,0.061144,-0.165085,0.002052,0.061144,-0.165234,0.000678,0.061144,-0.165085,0.0472,0.061144,-0.16942,0.053042,0.061144,-0.165085,0.0472,0.061144,-0.16942,0.053042,0.061144,-0.165234,0.048575,0.061144,-0.16942,0.053042,0.061144,-0.165657,0.049838,0.061144,-0.165234,0.048575,0.061144,-0.168237,0.05259,0.061144,-0.165657,0.049838,0.061144,-0.16942,0.053042,0.061144,-0.167193,0.051881,0.061144,-0.166321,0.050952,0.061144,-0.14854,0.049838,0.061144,-0.149112,0.0472,0.061144,-0.148963,0.048575,0.061144,-0.147875,0.050952,0.061144,-0.149112,0.0472,0.061144,-0.14854,0.049838,0.061144,-0.147004,0.051881,0.061144,-0.149112,0.0472,0.061144,-0.147875,0.050952,0.061144,-0.14596,0.05259,0.061144,-0.149112,0.0472,0.061144,-0.147004,0.051881,0.061144,-0.144776,0.053042,0.061144,-0.149112,0.0472,0.061144,-0.14596,0.05259,0.061144,-0.143488,0.0532,0.061144,-0.097059,0.0532,0.061144,-0.097059,0.0532,0.061144,-0.149112,0.002052,0.061144,-0.149112,0.0472,0.061144,-0.148963,0.000678,0.061144,-0.097059,0.0532,0.061144,-0.14854,-0.000585,0.061144,-0.148963,0.000678,0.061144,-0.147875,-0.001699,0.061144,-0.14854,-0.000585,0.061144,-0.147004,-0.002629,0.061144,-0.14596,-0.003337,0.061144,-0.144776,-0.003789,0.061144,-0.143488,-0.003948,0.061144,-0.097059,-0.003948,0.061144,-0.09577,-0.003789,0.061144,-0.094587,-0.003337,0.061144,-0.093542,-0.002629,0.061144,-0.092671,-0.001699,0.061144,-0.097059,0.0532,0.061144,-0.092007,-0.000585,0.061144,-0.092671,-0.001699,0.061144,-0.097059,0.0532,0.061144,-0.091583,0.000678,0.061144,-0.092007,-0.000585,0.061144,-0.091435,0.002052,0.061144,-0.091583,0.000678,0.061144,-0.091435,0.0472,0.061144,-0.091583,0.048575,0.061144,-0.09577,0.053042,0.061144,-0.091583,0.048575,0.061144,-0.094587,0.05259,0.061144,-0.094587,0.05259,0.061144,-0.092007,0.049838,0.061144,-0.091583,0.048575,0.061144,-0.094587,0.05259,0.061144,-0.092671,0.050952,0.061144,-0.092007,0.049838,0.061144,-0.093542,0.051881,0.061144,-0.020937,0.05259,0.061144,-0.023409,0.0532,0.061144,-0.02212,0.053042,0.061144,-0.019892,0.051881,0.061144,-0.019021,0.050952,0.061144,-0.018357,0.049838,0.061144,-0.017933,0.048575,0.061144,-0.023409,0.0532,0.061144,-0.018357,0.049838,0.061144,-0.017785,0.0472,0.061144,-0.023409,0.0532,0.061144,-0.017933,0.048575,0.061144,-0.017785,0.002052,0.061144,-0.017785,0.002052,0.061144,-0.069837,0.0532,0.061144,-0.017933,0.000678,0.061144,-0.018357,-0.000585,0.061144,-0.069837,0.0532,0.061144,-0.017933,0.000678,0.061144,-0.019021,-0.001699,0.061144,-0.018357,-0.000585,0.061144,-0.019892,-0.002629,0.061144,-0.020937,-0.003337,0.061144,-0.02212,-0.003789,0.061144,-0.023409,-0.003948,0.061144,-0.069837,-0.003948,0.061144,-0.071126,-0.003789,0.061144,-0.07231,-0.003337,0.061144,-0.073354,-0.002629,0.061144,-0.074225,-0.001699,0.061144,-0.07489,-0.000585,0.061144,-0.069837,0.0532,0.061144,-0.074225,-0.001699,0.061144,-0.075313,0.000678,0.061144,-0.069837,0.0532,0.061144,-0.07489,-0.000585,0.061144,-0.075462,0.002052,0.061144,-0.075313,0.000678,0.061144,-0.075462,0.0472,0.061144,-0.075462,0.0472,0.061144,-0.071126,0.053042,0.061144,-0.069837,0.0532,0.061144,-0.075313,0.048575,0.061144,-0.071126,0.053042,0.061144,-0.07489,0.049838,0.061144,-0.071126,0.053042,0.061144,-0.075313,0.048575,0.061144,-0.07489,0.049838,0.061144,-0.07231,0.05259,0.061144,-0.071126,0.053042,0.061144,-0.073354,0.051881,0.061144,-0.074225,0.050952,0.061144,0.055293,-0.000585,0.061144,0.055866,0.002052,0.061144,0.055717,0.000678,0.061144,0.054629,-0.001699,0.061144,0.055866,0.002052,0.061144,0.055293,-0.000585,0.061144,0.053758,-0.002629,0.061144,0.055866,0.002052,0.061144,0.054629,-0.001699,0.061144,0.052714,-0.003337,0.061144,0.055866,0.002052,0.061144,0.053758,-0.002629,0.061144,0.05153,-0.003789,0.061144,0.055866,0.002052,0.061144,0.052714,-0.003337,0.061144,0.050241,-0.003948,0.061144,0.055866,0.002052,0.061144,0.05153,-0.003789,0.061144,0.003813,-0.003948,0.061144,0.003813,-0.003948,0.061144,0.055866,0.0472,0.061144,0.055866,0.002052,0.061144,0.055717,0.048575,0.061144,0.003813,-0.003948,0.061144,0.055293,0.049838,0.061144,0.055717,0.048575,0.061144,0.054629,0.050952,0.061144,0.055293,0.049838,0.061144,0.053758,0.051881,0.061144,0.052713,0.05259,0.061144,0.05153,0.053042,0.061144,0.050241,0.0532,0.061144,0.003813,0.0532,0.061144,0.002524,-0.003789,0.061144,0.001341,-0.003337,0.061144,0.000296,-0.002629,0.061144,-0.000575,-0.001699,0.061144,-0.001239,-0.000585,0.061144,0.003813,0.0532,0.061144,-0.000575,-0.001699,0.061144,-0.001663,0.000678,0.061144,0.003813,0.0532,0.061144,-0.001239,-0.000585,0.061144,-0.001812,0.002052,0.061144,-0.001663,0.000678,0.061144,-0.001812,0.0472,0.061144,-0.001812,0.0472,0.061144,0.002524,0.053042,0.061144,0.003813,0.0532,0.061144,-0.001663,0.048575,0.061144,0.002524,0.053042,0.061144,-0.001239,0.049838,0.061144,0.002524,0.053042,0.061144,-0.001663,0.048575,0.061144,-0.001239,0.049838,0.061144,0.001341,0.05259,0.061144,0.002524,0.053042,0.061144,0.000296,0.051881,0.061144,-0.000575,0.050952,0.061144,0.128944,-0.000585,0.061144,0.129516,0.002052,0.061144,0.129367,0.000678,0.061144,0.128279,-0.001699,0.061144,0.129516,0.002052,0.061144,0.128944,-0.000585,0.061144,0.127408,-0.002629,0.061144,0.129516,0.002052,0.061144,0.128279,-0.001699,0.061144,0.126364,-0.003337,0.061144,0.129516,0.002052,0.061144,0.127408,-0.002629,0.061144,0.12518,-0.003789,0.061144,0.129516,0.002052,0.061144,0.126364,-0.003337,0.061144,0.123892,-0.003948,0.061144,0.129516,0.002052,0.061144,0.12518,-0.003789,0.061144,0.077463,-0.003948,0.061144,0.077463,-0.003948,0.061144,0.129516,0.0472,0.061144,0.129516,0.002052,0.061144,0.129367,0.048575,0.061144,0.077463,-0.003948,0.061144,0.128944,0.049838,0.061144,0.129367,0.048575,0.061144,0.128279,0.050952,0.061144,0.128944,0.049838,0.061144,0.127408,0.051881,0.061144,0.126364,0.05259,0.061144,0.12518,0.053042,0.061144,0.123892,0.0532,0.061144,0.077463,0.0532,0.061144,0.076174,-0.003789,0.061144,0.074991,-0.003337,0.061144,0.073946,-0.002629,0.061144,0.073075,-0.001699,0.061144,0.072411,-0.000585,0.061144,0.077463,0.0532,0.061144,0.073075,-0.001699,0.061144,0.071987,0.000678,0.061144,0.077463,0.0532,0.061144,0.072411,-0.000585,0.061144,0.071839,0.002052,0.061144,0.071987,0.000678,0.061144,0.071839,0.0472,0.061144,0.071987,0.048575,0.061144,0.071987,0.048575,0.061144,0.076174,0.053042,0.061144,0.077463,0.0532,0.061144,0.074991,0.05259,0.061144,0.072411,0.049838,0.061144,0.074991,0.05259,0.061144,0.071987,0.048575,0.061144,0.073075,0.050952,0.061144,0.074991,0.05259,0.061144,0.072411,0.049838,0.061144,0.073946,0.051881,0.061144,0.145489,0.002052,0.061144,0.146061,-0.000585,0.061144,0.145637,0.000678,0.061144,0.145489,0.002052,0.061144,0.146725,-0.001699,0.061144,0.146061,-0.000585,0.061144,0.145489,0.002052,0.061144,0.147597,-0.002629,0.061144,0.146725,-0.001699,0.061144,0.145489,0.002052,0.061144,0.148641,-0.003337,0.061144,0.147597,-0.002629,0.061144,0.145489,0.002052,0.061144,0.149824,-0.003789,0.061144,0.148641,-0.003337,0.061144,0.145489,0.002052,0.061144,0.151113,-0.003948,0.061144,0.149824,-0.003789,0.061144,0.197542,-0.003948,0.061144,0.145489,0.0472,0.061144,0.197542,-0.003948,0.061144,0.145489,0.002052,0.061144,0.145637,0.048575,0.061144,0.146061,0.049838,0.061144,0.197542,-0.003948,0.061144,0.145637,0.048575,0.061144,0.146725,0.050952,0.061144,0.146061,0.049838,0.061144,0.147596,0.051881,0.061144,0.148641,0.05259,0.061144,0.149824,0.053042,0.061144,0.151113,0.0532,0.061144,0.197542,0.0532,0.061144,0.19883,-0.003789,0.061144,0.200014,-0.003337,0.061144,0.201058,-0.002628,0.061144,0.201929,-0.001699,0.061144,0.197542,0.0532,0.061144,0.202594,-0.000585,0.061144,0.201929,-0.001699,0.061144,0.197542,0.0532,0.061144,0.203017,0.000678,0.061144,0.202594,-0.000585,0.061144,0.203166,0.002052,0.061144,0.203017,0.000678,0.061144,0.203166,0.0472,0.061144,0.19883,0.053042,0.061144,0.203166,0.0472,0.061144,0.197542,0.0532,0.061144,0.19883,0.053042,0.061144,0.203017,0.048575,0.061144,0.200014,0.05259,0.061144,0.203017,0.048575,0.061144,0.200014,0.05259,0.061144,0.202594,0.049838,0.061144,0.203017,0.048575,0.061144,0.200014,0.05259,0.061144,0.201929,0.050952,0.061144,0.202594,0.049838,0.061144,0.201058,0.051881,0.061144,0.276244,-0.000585,0.061144,0.276816,0.002052,0.061144,0.276667,0.000678,0.061144,0.27558,-0.001699,0.061144,0.276816,0.002052,0.061144,0.276244,-0.000585,0.061144,0.274708,-0.002628,0.061144,0.276816,0.002052,0.061144,0.27558,-0.001699,0.061144,0.273664,-0.003337,0.061144,0.276816,0.002052,0.061144,0.274708,-0.002628,0.061144,0.27248,-0.003789,0.061144,0.276816,0.002052,0.061144,0.273664,-0.003337,0.061144,0.271192,-0.003948,0.061144,0.276816,0.002052,0.061144,0.27248,-0.003789,0.061144,0.224763,-0.003948,0.061144,0.224763,-0.003948,0.061144,0.276816,0.0472,0.061144,0.276816,0.002052,0.061144,0.276667,0.048575,0.061144,0.224763,-0.003948,0.061144,0.276244,0.049838,0.061144,0.276667,0.048575,0.061144,0.27558,0.050952,0.061144,0.276244,0.049838,0.061144,0.274708,0.051881,0.061144,0.273664,0.05259,0.061144,0.272481,0.053042,0.061144,0.271192,0.0532,0.061144,0.224763,0.0532,0.061144,0.223474,-0.003789,0.061144,0.222291,-0.003337,0.061144,0.221247,-0.002628,0.061144,0.220375,-0.001699,0.061144,0.219711,-0.000585,0.061144,0.224763,0.0532,0.061144,0.220375,-0.001699,0.061144,0.219288,0.000678,0.061144,0.224763,0.0532,0.061144,0.219711,-0.000585,0.061144,0.219139,0.002052,0.061144,0.219288,0.000678,0.061144,0.219139,0.0472,0.061144,0.219288,0.048575,0.061144,0.219288,0.048575,0.061144,0.223474,0.053042,0.061144,0.224763,0.0532,0.061144,0.222291,0.05259,0.061144,0.219711,0.049838,0.061144,0.222291,0.05259,0.061144,0.219288,0.048575,0.061144,0.220375,0.050952,0.061144,0.222291,0.05259,0.061144,0.219711,0.049838,0.061144,0.221247,0.051881,0.061144,-0.627122,0.001978,0.061144,-0.62655,-0.00066,0.061144,-0.626974,0.000603,0.061144,-0.627122,0.001978,0.061144,-0.625886,-0.001774,0.061144,-0.62655,-0.00066,0.061144,-0.627122,0.001978,0.061144,-0.625015,-0.002703,0.061144,-0.625886,-0.001774,0.061144,-0.627122,0.001978,0.061144,-0.62397,-0.003412,0.061144,-0.625015,-0.002703,0.061144,-0.627122,0.001978,0.061144,-0.622787,-0.003864,0.061144,-0.62397,-0.003412,0.061144,-0.627122,0.001978,0.061144,-0.621498,-0.004022,0.061144,-0.622787,-0.003864,0.061144,-0.627122,0.047078,0.061144,-0.621498,-0.004022,0.061144,-0.627122,0.001978,0.061144,-0.627122,0.047078,0.061144,-0.464448,-0.004022,0.061144,-0.621498,-0.004022,0.061144,-0.626974,0.048453,0.061144,-0.62655,0.049715,0.061144,-0.464448,-0.004022,0.061144,-0.626974,0.048453,0.061144,-0.625886,0.050829,0.061144,-0.62655,0.049715,0.061144,-0.625014,0.051759,0.061144,-0.62397,0.052467,0.061144,-0.622787,0.052919,0.061144,-0.621498,0.053078,0.061144,-0.464448,0.053078,0.061144,-0.463159,-0.003864,0.061144,-0.461976,-0.003412,0.061144,-0.460931,-0.002703,0.061144,-0.46006,-0.001774,0.061144,-0.464448,0.053078,0.061144,-0.459396,-0.00066,0.061144,-0.46006,-0.001774,0.061144,-0.464448,0.053078,0.061144,-0.458972,0.000603,0.061144,-0.459396,-0.00066,0.061144,-0.458824,0.001978,0.061144,-0.458972,0.000603,0.061144,-0.458824,0.047078,0.061144,-0.458972,0.048453,0.061144,-0.463159,0.052919,0.061144,-0.458972,0.048453,0.061144,-0.464448,0.053078,0.061144,-0.461976,0.052467,0.061144,-0.461976,0.052467,0.061144,-0.459396,0.049715,0.061144,-0.458972,0.048453,0.061144,-0.460931,0.051759,0.061144,-0.459396,0.049715,0.061144,-0.461976,0.052467,0.061144,-0.46006,0.050829,0.061144,0.448949,0.047078,0.061144,0.448377,0.049715,0.061144,0.4488,0.048453,0.061144,0.448949,0.047078,0.061144,0.447712,0.050829,0.061144,0.448377,0.049715,0.061144,0.448949,0.047078,0.061144,0.446841,0.051759,0.061144,0.447712,0.050829,0.061144,0.448949,0.047078,0.061144,0.445797,0.052467,0.061144,0.446841,0.051759,0.061144,0.448949,0.047078,0.061144,0.444613,0.052919,0.061144,0.445797,0.052467,0.061144,0.443325,0.053078,0.061144,0.448949,0.001978,0.061144,0.443325,0.053078,0.061144,0.448949,0.047078,0.061144,0.448949,0.001978,0.061144,0.294555,0.053078,0.061144,0.443325,0.053078,0.061144,0.4488,0.000603,0.061144,0.448377,-0.00066,0.061144,0.294555,0.053078,0.061144,0.4488,0.000603,0.061144,0.447712,-0.001774,0.061144,0.448377,-0.00066,0.061144,0.446841,-0.002703,0.061144,0.445797,-0.003412,0.061144,0.444613,-0.003864,0.061144,0.443325,-0.004022,0.061144,0.294555,-0.004022,0.061144,0.293266,-0.003864,0.061144,0.292083,-0.003412,0.061144,0.291038,-0.002703,0.061144,0.290167,-0.001774,0.061144,0.289503,-0.00066,0.061144,0.294555,0.053078,0.061144,0.290167,-0.001774,0.061144,0.289079,0.000603,0.061144,0.294555,0.053078,0.061144,0.289503,-0.00066,0.061144,0.288931,0.001978,0.061144,0.289079,0.000603,0.061144,0.288931,0.047078,0.061144,0.288931,0.047078,0.061144,0.293266,0.052919,0.061144,0.294555,0.053078,0.061144,0.289079,0.048453,0.061144,0.293266,0.052919,0.061144,0.289503,0.049715,0.061144,0.293266,0.052919,0.061144,0.289079,0.048453,0.061144,0.289503,0.049715,0.061144,0.292083,0.052467,0.061144,0.293266,0.052919,0.061144,0.290167,0.050829,0.061144,0.291038,0.051759,0.061144,-0.388556,-0.022919,0.061144,-0.389129,-0.025556,0.061144,-0.38898,-0.024181,0.061144,-0.387892,-0.021804,0.061144,-0.387021,-0.020875,0.061144,-0.385977,-0.020166,0.061144,-0.384793,-0.019715,0.061144,-0.383504,-0.019556,0.061144,-0.337076,-0.019556,0.061144,-0.389129,-0.070704,0.061144,-0.337076,-0.019556,0.061144,-0.38898,-0.072079,0.061144,-0.389129,-0.070704,0.061144,-0.388557,-0.073341,0.061144,-0.38898,-0.072079,0.061144,-0.387892,-0.074455,0.061144,-0.387021,-0.075385,0.061144,-0.385977,-0.076094,0.061144,-0.384793,-0.076545,0.061144,-0.383504,-0.076704,0.061144,-0.337076,-0.076704,0.061144,-0.335787,-0.076545,0.061144,-0.334604,-0.076094,0.061144,-0.333559,-0.075385,0.061144,-0.332688,-0.074455,0.061144,-0.337076,-0.019556,0.061144,-0.332024,-0.073341,0.061144,-0.332688,-0.074455,0.061144,-0.3316,-0.072079,0.061144,-0.337076,-0.019556,0.061144,-0.331452,-0.070704,0.061144,-0.3316,-0.072079,0.061144,-0.331452,-0.025556,0.061144,-0.331452,-0.070704,0.061144,-0.335787,-0.019715,0.061144,-0.3316,-0.024181,0.061144,-0.332024,-0.022919,0.061144,-0.334604,-0.020166,0.061144,-0.332688,-0.021804,0.061144,-0.333559,-0.020875,0.061144,0.227273,-0.020166,0.061144,0.224801,-0.019556,0.061144,0.22609,-0.019714,0.061144,0.228318,-0.020875,0.061144,0.229189,-0.021804,0.061144,0.229853,-0.022919,0.061144,0.230277,-0.024181,0.061144,0.230425,-0.025556,0.061144,0.15775,-0.019556,0.061144,0.230425,-0.070704,0.061144,0.230277,-0.072079,0.061144,0.15775,-0.019556,0.061144,0.230425,-0.070704,0.061144,0.229853,-0.073341,0.061144,0.230277,-0.072079,0.061144,0.229189,-0.074455,0.061144,0.228318,-0.075385,0.061144,0.227273,-0.076093,0.061144,0.22609,-0.076545,0.061144,0.224801,-0.076704,0.061144,0.15775,-0.076704,0.061144,0.156462,-0.019714,0.061144,0.155278,-0.020166,0.061144,0.154234,-0.020875,0.061144,0.153363,-0.021804,0.061144,0.15775,-0.076704,0.061144,0.152698,-0.022919,0.061144,0.153363,-0.021804,0.061144,0.152275,-0.024181,0.061144,0.15775,-0.076704,0.061144,0.152126,-0.025556,0.061144,0.152275,-0.024181,0.061144,0.152126,-0.070704,0.061144,0.152126,-0.025556,0.061144,0.15775,-0.076704,0.061144,0.152275,-0.072079,0.061144,0.152126,-0.070704,0.061144,0.156462,-0.076545,0.061144,0.152275,-0.072079,0.061144,0.155278,-0.076093,0.061144,0.152698,-0.073341,0.061144,0.154234,-0.075385,0.061144,0.153363,-0.074455,0.061144,0.300569,-0.073341,0.061144,0.301141,-0.070704,0.061144,0.300993,-0.072079,0.061144,0.299905,-0.074455,0.061144,0.301141,-0.070704,0.061144,0.300569,-0.073341,0.061144,0.299034,-0.075385,0.061144,0.301141,-0.070704,0.061144,0.299905,-0.074455,0.061144,0.297989,-0.076093,0.061144,0.301141,-0.070704,0.061144,0.299034,-0.075385,0.061144,0.296806,-0.076545,0.061144,0.301141,-0.070704,0.061144,0.297989,-0.076093,0.061144,0.295517,-0.076704,0.061144,0.249088,-0.076704,0.061144,0.249088,-0.076704,0.061144,0.301141,-0.025556,0.061144,0.301141,-0.070704,0.061144,0.300993,-0.024181,0.061144,0.300569,-0.022919,0.061144,0.299905,-0.021804,0.061144,0.299034,-0.020875,0.061144,0.297989,-0.020166,0.061144,0.296806,-0.019714,0.061144,0.295517,-0.019556,0.061144,0.249088,-0.019556,0.061144,0.2478,-0.019714,0.061144,0.246616,-0.020166,0.061144,0.245572,-0.020875,0.061144,0.244701,-0.021804,0.061144,0.249088,-0.076704,0.061144,0.244036,-0.022919,0.061144,0.244701,-0.021804,0.061144,0.243613,-0.024181,0.061144,0.249088,-0.076704,0.061144,0.243464,-0.025556,0.061144,0.243613,-0.024181,0.061144,0.243464,-0.070704,0.061144,0.243464,-0.025556,0.061144,0.249088,-0.076704,0.061144,0.243613,-0.072079,0.061144,0.243464,-0.070704,0.061144,0.2478,-0.076545,0.061144,0.243613,-0.072079,0.061144,0.244036,-0.073341,0.061144,0.246616,-0.076093,0.061144,0.244701,-0.074455,0.061144,0.245572,-0.075385,0.061144,0.374219,-0.073341,0.061144,0.374791,-0.070704,0.061144,0.374643,-0.072079,0.061144,0.373555,-0.074455,0.061144,0.374791,-0.070704,0.061144,0.374219,-0.073341,0.061144,0.372684,-0.075385,0.061144,0.374791,-0.070704,0.061144,0.373555,-0.074455,0.061144,0.371639,-0.076093,0.061144,0.374791,-0.070704,0.061144,0.372684,-0.075385,0.061144,0.370456,-0.076545,0.061144,0.374791,-0.070704,0.061144,0.371639,-0.076093,0.061144,0.369167,-0.076704,0.061144,0.322739,-0.076704,0.061144,0.322739,-0.076704,0.061144,0.374791,-0.025556,0.061144,0.374791,-0.070704,0.061144,0.374643,-0.024181,0.061144,0.374219,-0.022918,0.061144,0.373555,-0.021804,0.061144,0.372684,-0.020875,0.061144,0.371639,-0.020166,0.061144,0.370456,-0.019714,0.061144,0.369167,-0.019556,0.061144,0.322739,-0.019556,0.061144,0.32145,-0.019714,0.061144,0.320266,-0.020166,0.061144,0.319222,-0.020875,0.061144,0.318351,-0.021804,0.061144,0.322739,-0.076704,0.061144,0.317686,-0.022919,0.061144,0.318351,-0.021804,0.061144,0.317263,-0.024181,0.061144,0.322739,-0.076704,0.061144,0.317114,-0.025556,0.061144,0.317263,-0.024181,0.061144,0.317114,-0.070704,0.061144,0.317114,-0.025556,0.061144,0.322739,-0.076704,0.061144,0.317263,-0.072079,0.061144,0.317114,-0.070704,0.061144,0.32145,-0.076545,0.061144,0.317263,-0.072079,0.061144,0.317686,-0.073341,0.061144,0.320266,-0.076093,0.061144,0.319222,-0.075385,0.061144,0.318351,-0.074455,0.061144,0.447869,-0.073341,0.061144,0.448442,-0.070704,0.061144,0.448293,-0.072079,0.061144,0.447205,-0.074455,0.061144,0.448442,-0.070704,0.061144,0.447869,-0.073341,0.061144,0.446334,-0.075385,0.061144,0.448442,-0.070704,0.061144,0.447205,-0.074455,0.061144,0.44529,-0.076093,0.061144,0.448442,-0.070704,0.061144,0.446334,-0.075385,0.061144,0.444106,-0.076545,0.061144,0.448442,-0.070704,0.061144,0.44529,-0.076093,0.061144,0.442817,-0.076704,0.061144,0.396389,-0.076704,0.061144,0.396389,-0.076704,0.061144,0.448442,-0.025556,0.061144,0.448442,-0.070704,0.061144,0.448293,-0.024181,0.061144,0.447869,-0.022918,0.061144,0.447205,-0.021804,0.061144,0.446334,-0.020875,0.061144,0.44529,-0.020166,0.061144,0.444106,-0.019714,0.061144,0.442817,-0.019556,0.061144,0.396389,-0.019556,0.061144,0.3951,-0.019714,0.061144,0.393917,-0.020166,0.061144,0.392872,-0.020875,0.061144,0.392001,-0.021804,0.061144,0.396389,-0.076704,0.061144,0.391337,-0.022919,0.061144,0.392001,-0.021804,0.061144,0.390913,-0.024181,0.061144,0.396389,-0.076704,0.061144,0.390765,-0.025556,0.061144,0.390913,-0.024181,0.061144,0.390765,-0.070704,0.061144,0.390765,-0.025556,0.061144,0.396389,-0.076704,0.061144,0.390913,-0.072079,0.061144,0.390765,-0.070704,0.061144,0.3951,-0.076545,0.061144,0.390913,-0.072079,0.061144,0.391337,-0.073341,0.061144,0.393917,-0.076093,0.061144,0.392872,-0.075385,0.061144,0.392001,-0.074455,0.061144,-0.320047,-0.070704,0.061144,-0.319475,-0.073341,0.061144,-0.319898,-0.072079,0.061144,-0.320047,-0.070704,0.061144,-0.31881,-0.074455,0.061144,-0.319475,-0.073341,0.061144,-0.320047,-0.070704,0.061144,-0.317939,-0.075385,0.061144,-0.31881,-0.074455,0.061144,-0.320047,-0.070704,0.061144,-0.316895,-0.076094,0.061144,-0.317939,-0.075385,0.061144,-0.320047,-0.070704,0.061144,-0.315711,-0.076545,0.061144,-0.316895,-0.076094,0.061144,-0.314422,-0.076704,0.061144,-0.247372,-0.076704,0.061144,-0.320047,-0.025556,0.061144,-0.247372,-0.076704,0.061144,-0.320047,-0.070704,0.061144,-0.319898,-0.024181,0.061144,-0.319475,-0.022919,0.061144,-0.31881,-0.021804,0.061144,-0.317939,-0.020875,0.061144,-0.316895,-0.020166,0.061144,-0.315711,-0.019715,0.061144,-0.314423,-0.019556,0.061144,-0.247372,-0.019556,0.061144,-0.246083,-0.076545,0.061144,-0.2449,-0.076094,0.061144,-0.243855,-0.075385,0.061144,-0.242984,-0.074455,0.061144,-0.247372,-0.019556,0.061144,-0.24232,-0.073341,0.061144,-0.242984,-0.074455,0.061144,-0.241896,-0.072079,0.061144,-0.247372,-0.019556,0.061144,-0.241748,-0.070704,0.061144,-0.241896,-0.072079,0.061144,-0.241748,-0.025556,0.061144,-0.241748,-0.070704,0.061144,-0.246083,-0.019715,0.061144,-0.241896,-0.024181,0.061144,-0.24232,-0.022919,0.061144,-0.2449,-0.020166,0.061144,-0.243855,-0.020875,0.061144,-0.242984,-0.021804,0.061144,-0.465611,-0.075662,0.061144,-0.463138,-0.076273,0.061144,-0.464427,-0.076114,0.061144,-0.466655,-0.074954,0.061144,-0.467526,-0.074024,0.061144,-0.46819,-0.07291,0.061144,-0.468614,-0.071647,0.061144,-0.468763,-0.070273,0.061144,-0.463138,-0.076273,0.061144,-0.468614,-0.071647,0.061144,-0.468763,-0.070273,0.061144,-0.41671,-0.076273,0.061144,-0.463138,-0.076273,0.061144,-0.468763,-0.053125,0.061144,-0.468614,-0.05175,0.061144,-0.41671,-0.076273,0.061144,-0.468763,-0.053125,0.061144,-0.46819,-0.050487,0.061144,-0.467526,-0.049373,0.061144,-0.466655,-0.048444,0.061144,-0.465611,-0.047735,0.061144,-0.464427,-0.047283,0.061144,-0.463138,-0.047125,0.061144,-0.41671,-0.047125,0.061144,-0.463138,-0.047125,0.061144,-0.415421,-0.047283,0.061144,-0.414237,-0.047735,0.061144,-0.413193,-0.048444,0.061144,-0.414237,-0.047735,0.061144,-0.412322,-0.049373,0.061144,-0.41671,-0.076273,0.061144,-0.413193,-0.048444,0.061144,-0.411658,-0.050487,0.061144,-0.411234,-0.05175,0.061144,-0.411085,-0.053125,0.061144,-0.41671,-0.076273,0.061144,-0.411234,-0.05175,0.061144,-0.411085,-0.070273,0.061144,-0.411085,-0.053125,0.061144,-0.411234,-0.071647,0.061144,-0.41671,-0.076273,0.061144,-0.411085,-0.070273,0.061144,-0.411234,-0.071647,0.061144,-0.415421,-0.076114,0.061144,-0.414238,-0.075662,0.061144,-0.411658,-0.07291,0.061144,-0.412322,-0.074024,0.061144,-0.413193,-0.074954,0.061144,-0.540671,-0.050487,0.061144,-0.541243,-0.053125,0.061144,-0.541095,-0.05175,0.061144,-0.540007,-0.049373,0.061144,-0.539136,-0.048444,0.061144,-0.538091,-0.047735,0.061144,-0.536908,-0.047283,0.061144,-0.535619,-0.047125,0.061144,-0.489191,-0.047125,0.061144,-0.489191,-0.047125,0.061144,-0.541243,-0.070273,0.061144,-0.541243,-0.053125,0.061144,-0.489191,-0.047125,0.061144,-0.541095,-0.071647,0.061144,-0.541243,-0.070273,0.061144,-0.540671,-0.07291,0.061144,-0.541095,-0.071647,0.061144,-0.540007,-0.074024,0.061144,-0.539136,-0.074954,0.061144,-0.538091,-0.075662,0.061144,-0.536908,-0.076114,0.061144,-0.535619,-0.076273,0.061144,-0.489191,-0.076273,0.061144,-0.535619,-0.076273,0.061144,-0.487902,-0.047283,0.061144,-0.486718,-0.047735,0.061144,-0.485674,-0.048444,0.061144,-0.489191,-0.076273,0.061144,-0.486718,-0.047735,0.061144,-0.484803,-0.049373,0.061144,-0.489191,-0.076273,0.061144,-0.485674,-0.048444,0.061144,-0.484139,-0.050487,0.061144,-0.483715,-0.05175,0.061144,-0.483566,-0.053125,0.061144,-0.489191,-0.076273,0.061144,-0.483715,-0.05175,0.061144,-0.483566,-0.070273,0.061144,-0.483566,-0.053125,0.061144,-0.483715,-0.071647,0.061144,-0.489191,-0.076273,0.061144,-0.483566,-0.070273,0.061144,-0.483715,-0.071647,0.061144,-0.487902,-0.076114,0.061144,-0.486718,-0.075662,0.061144,-0.484139,-0.07291,0.061144,-0.485674,-0.074954,0.061144,-0.484803,-0.074024,0.061144,-0.556047,-0.053125,0.061144,-0.55662,-0.050487,0.061144,-0.556196,-0.05175,0.061144,-0.557284,-0.049373,0.061144,-0.558155,-0.048444,0.061144,-0.559199,-0.047735,0.061144,-0.560383,-0.047283,0.061144,-0.561671,-0.047125,0.061144,-0.6081,-0.047125,0.061144,-0.556047,-0.070273,0.061144,-0.6081,-0.047125,0.061144,-0.556047,-0.053125,0.061144,-0.556196,-0.071647,0.061144,-0.6081,-0.047125,0.061144,-0.556047,-0.070273,0.061144,-0.556619,-0.07291,0.061144,-0.556196,-0.071647,0.061144,-0.557284,-0.074024,0.061144,-0.558155,-0.074954,0.061144,-0.559199,-0.075662,0.061144,-0.560383,-0.076114,0.061144,-0.561671,-0.076273,0.061144,-0.6081,-0.076273,0.061144,-0.561671,-0.076273,0.061144,-0.609389,-0.047283,0.061144,-0.610572,-0.047735,0.061144,-0.6081,-0.076273,0.061144,-0.611617,-0.048444,0.061144,-0.610572,-0.047735,0.061144,-0.6081,-0.076273,0.061144,-0.612488,-0.049373,0.061144,-0.611617,-0.048444,0.061144,-0.613152,-0.050487,0.061144,-0.613576,-0.05175,0.061144,-0.6081,-0.076273,0.061144,-0.613724,-0.053125,0.061144,-0.613576,-0.05175,0.061144,-0.613724,-0.070273,0.061144,-0.613724,-0.053125,0.061144,-0.609389,-0.076114,0.061144,-0.609389,-0.076114,0.061144,-0.613576,-0.071647,0.061144,-0.613724,-0.070273,0.061144,-0.610572,-0.075662,0.061144,-0.613576,-0.071647,0.061144,-0.609389,-0.076114,0.061144,-0.613152,-0.07291,0.061144,-0.612488,-0.074024,0.061144,-0.611617,-0.074954,0.061144,-0.540671,-0.020796,0.061144,-0.541243,-0.023433,0.061144,-0.541095,-0.022058,0.061144,-0.540007,-0.019681,0.061144,-0.539136,-0.018752,0.061144,-0.538091,-0.018043,0.061144,-0.536908,-0.017592,0.061144,-0.535619,-0.017433,0.061144,-0.489191,-0.017433,0.061144,-0.541243,-0.040581,0.061144,-0.541095,-0.041956,0.061144,-0.540671,-0.043218,0.061144,-0.540007,-0.044332,0.061144,-0.539136,-0.045262,0.061144,-0.538091,-0.045971,0.061144,-0.536908,-0.046422,0.061144,-0.535619,-0.046581,0.061144,-0.489191,-0.046581,0.061144,-0.487902,-0.046422,0.061144,-0.486718,-0.045971,0.061144,-0.485674,-0.045262,0.061144,-0.484803,-0.044332,0.061144,-0.484139,-0.043218,0.061144,-0.483715,-0.041956,0.061144,-0.483566,-0.040581,0.061144,-0.483566,-0.023433,0.061144,-0.483715,-0.022058,0.061144,-0.487902,-0.017592,0.061144,-0.486718,-0.018043,0.061144,-0.484139,-0.020796,0.061144,-0.485674,-0.018752,0.061144,-0.484803,-0.019681,0.061144,0.137525,-0.073341,0.074144,0.137948,-0.072079,0.074144,0.138097,-0.070704,0.074144,0.13686,-0.074455,0.074144,0.135989,-0.075385,0.074144,0.134945,-0.076093,0.074144,0.133761,-0.076545,0.074144,0.132473,-0.076704,0.074144,-0.223287,-0.076704,0.074144,0.138097,-0.025556,0.074144,0.137948,-0.024181,0.074144,0.137525,-0.022919,0.074144,0.13686,-0.021804,0.074144,0.135989,-0.020875,0.074144,0.134945,-0.020166,0.074144,0.133761,-0.019714,0.074144,0.132473,-0.019556,0.074144,-0.223287,-0.019556,0.074144,-0.224575,-0.019715,0.074144,-0.225759,-0.020166,0.074144,-0.226803,-0.020875,0.074144,-0.227674,-0.021804,0.074144,-0.228339,-0.022919,0.074144,-0.228762,-0.024181,0.074144,-0.228911,-0.025556,0.074144,-0.228911,-0.070704,0.074144,-0.224575,-0.076545,0.074144,-0.228762,-0.072079,0.074144,-0.225759,-0.076094,0.074144,-0.228339,-0.073341,0.074144,-0.226803,-0.075385,0.074144,-0.227674,-0.074455,0.074144,0.446193,0.312449,0.074144,0.44501,0.312901,0.074144,0.443721,0.313059,0.074144,0.447238,0.31174,0.074144,0.448109,0.310811,0.074144,0.448773,0.309697,0.074144,0.449197,0.308434,0.074144,0.449345,0.307059,0.074144,0.449345,0.286911,0.074144,0.393439,0.313059,0.074144,0.449197,0.285536,0.074144,0.448773,0.284274,0.074144,0.448109,0.28316,0.074144,0.447238,0.28223,0.074144,0.446193,0.281522,0.074144,0.44501,0.28107,0.074144,0.443721,0.280911,0.074144,0.393439,0.280911,0.074144,0.39215,0.28107,0.074144,0.390967,0.281522,0.074144,0.389922,0.28223,0.074144,0.389051,0.28316,0.074144,0.388387,0.284274,0.074144,0.387963,0.285536,0.074144,0.387814,0.286911,0.074144,0.387814,0.307059,0.074144,0.387963,0.308434,0.074144,0.39215,0.312901,0.074144,0.390966,0.312449,0.074144,0.388387,0.309697,0.074144,0.389922,0.31174,0.074144,0.389051,0.310811,0.074144,0.377087,0.307059,0.074144,0.376939,0.308434,0.074144,0.376515,0.309697,0.074144,0.375851,0.310811,0.074144,0.37498,0.31174,0.074144,0.373935,0.312449,0.074144,0.372752,0.312901,0.074144,0.371463,0.313059,0.074144,0.377087,0.286911,0.074144,0.32118,0.313059,0.074144,0.376939,0.285536,0.074144,0.376515,0.284274,0.074144,0.375851,0.28316,0.074144,0.37498,0.28223,0.074144,0.373935,0.281522,0.074144,0.372752,0.28107,0.074144,0.371463,0.280911,0.074144,0.32118,0.280911,0.074144,0.319892,0.28107,0.074144,0.318708,0.281522,0.074144,0.317664,0.28223,0.074144,0.316793,0.28316,0.074144,0.316128,0.284274,0.074144,0.315705,0.285536,0.074144,0.315556,0.286911,0.074144,0.315556,0.307059,0.074144,0.315705,0.308434,0.074144,0.319892,0.312901,0.074144,0.316128,0.309697,0.074144,0.318708,0.312449,0.074144,0.317664,0.31174,0.074144,0.316793,0.310811,0.074144,0.298516,0.307059,0.074144,0.298367,0.308434,0.074144,0.297944,0.309697,0.074144,0.297279,0.310811,0.074144,0.296408,0.31174,0.074144,0.295364,0.312449,0.074144,0.29418,0.312901,0.074144,0.292892,0.313059,0.074144,0.298516,0.286911,0.074144,0.242609,0.313059,0.074144,0.298367,0.285536,0.074144,0.297944,0.284274,0.074144,0.297279,0.28316,0.074144,0.296408,0.28223,0.074144,0.295364,0.281522,0.074144,0.29418,0.28107,0.074144,0.292892,0.280911,0.074144,0.242609,0.280911,0.074144,0.24132,0.28107,0.074144,0.240137,0.281522,0.074144,0.239093,0.28223,0.074144,0.238221,0.28316,0.074144,0.237557,0.284274,0.074144,0.237134,0.285536,0.074144,0.236985,0.286911,0.074144,0.236985,0.307059,0.074144,0.237134,0.308434,0.074144,0.24132,0.312901,0.074144,0.240137,0.312449,0.074144,0.237557,0.309697,0.074144,0.239093,0.31174,0.074144,0.238221,0.310811,0.074144,0.216792,0.312449,0.074144,0.215609,0.312901,0.074144,0.21432,0.313059,0.074144,0.217837,0.31174,0.074144,0.218708,0.310811,0.074144,0.219372,0.309697,0.074144,0.219796,0.308434,0.074144,0.219944,0.307059,0.074144,0.219944,0.286911,0.074144,0.164038,0.313059,0.074144,0.219796,0.285536,0.074144,0.219372,0.284274,0.074144,0.218708,0.28316,0.074144,0.217837,0.28223,0.074144,0.216792,0.281522,0.074144,0.215609,0.28107,0.074144,0.21432,0.280911,0.074144,0.164038,0.280911,0.074144,0.162749,0.28107,0.074144,0.161565,0.281522,0.074144,0.160521,0.28223,0.074144,0.15965,0.28316,0.074144,0.158986,0.284274,0.074144,0.158562,0.285536,0.074144,0.158413,0.286911,0.074144,0.158413,0.307059,0.074144,0.158562,0.308434,0.074144,0.162749,0.312901,0.074144,0.161565,0.312449,0.074144,0.158986,0.309697,0.074144,0.15965,0.310811,0.074144,0.160521,0.31174,0.074144,0.138221,0.312449,0.074144,0.137038,0.312901,0.074144,0.135749,0.313059,0.074144,0.139265,0.31174,0.074144,0.140137,0.310811,0.074144,0.140801,0.309697,0.074144,0.141224,0.308434,0.074144,0.141373,0.307059,0.074144,0.141373,0.286911,0.074144,0.085466,0.313059,0.074144,0.141224,0.285536,0.074144,0.140801,0.284274,0.074144,0.140137,0.28316,0.074144,0.139265,0.28223,0.074144,0.138221,0.281522,0.074144,0.137038,0.28107,0.074144,0.135749,0.280911,0.074144,0.085466,0.280911,0.074144,0.084177,0.28107,0.074144,0.082994,0.281522,0.074144,0.08195,0.28223,0.074144,0.081078,0.28316,0.074144,0.080414,0.284274,0.074144,0.079991,0.285536,0.074144,0.079842,0.286911,0.074144,0.079842,0.307059,0.074144,0.079991,0.308434,0.074144,0.084177,0.312901,0.074144,0.082994,0.312449,0.074144,0.080414,0.309697,0.074144,0.081078,0.310811,0.074144,0.08195,0.31174,0.074144,0.05965,0.312449,0.074144,0.058466,0.312901,0.074144,0.057177,0.313059,0.074144,0.060694,0.31174,0.074144,0.061565,0.310811,0.074144,0.062229,0.309697,0.074144,0.062653,0.308434,0.074144,0.062802,0.307059,0.074144,0.062802,0.286911,0.074144,0.006895,0.313059,0.074144,0.062653,0.285536,0.074144,0.062229,0.284274,0.074144,0.061565,0.28316,0.074144,0.060694,0.28223,0.074144,0.05965,0.281522,0.074144,0.058466,0.28107,0.074144,0.057177,0.280911,0.074144,0.006895,0.280911,0.074144,0.005606,0.28107,0.074144,0.004423,0.281522,0.074144,0.003378,0.28223,0.074144,0.002507,0.28316,0.074144,0.001843,0.284274,0.074144,0.001419,0.285536,0.074144,0.001271,0.286911,0.074144,0.001271,0.307059,0.074144,0.001419,0.308434,0.074144,0.005606,0.312901,0.074144,0.004423,0.312449,0.074144,0.001843,0.309697,0.074144,0.002507,0.310811,0.074144,0.003378,0.31174,0.074144,-0.018922,0.312449,0.074144,-0.020105,0.312901,0.074144,-0.021394,0.313059,0.074144,-0.017878,0.31174,0.074144,-0.017006,0.310811,0.074144,-0.016342,0.309697,0.074144,-0.015919,0.308434,0.074144,-0.01577,0.307059,0.074144,-0.01577,0.286911,0.074144,-0.071677,0.313059,0.074144,-0.015919,0.285536,0.074144,-0.016342,0.284274,0.074144,-0.017006,0.28316,0.074144,-0.017878,0.28223,0.074144,-0.018922,0.281522,0.074144,-0.020105,0.28107,0.074144,-0.021394,0.280911,0.074144,-0.071677,0.280911,0.074144,-0.072965,0.28107,0.074144,-0.074149,0.281522,0.074144,-0.075193,0.28223,0.074144,-0.076064,0.28316,0.074144,-0.076729,0.284274,0.074144,-0.077152,0.285536,0.074144,-0.077301,0.286911,0.074144,-0.077301,0.307059,0.074144,-0.077152,0.308434,0.074144,-0.072965,0.312901,0.074144,-0.074149,0.312449,0.074144,-0.076729,0.309697,0.074144,-0.076064,0.310811,0.074144,-0.075193,0.31174,0.074144,-0.097493,0.312449,0.074144,-0.098677,0.312901,0.074144,-0.099965,0.313059,0.074144,-0.096449,0.31174,0.074144,-0.095578,0.310811,0.074144,-0.094913,0.309697,0.074144,-0.09449,0.308434,0.074144,-0.094341,0.307059,0.074144,-0.094341,0.286911,0.074144,-0.150248,0.313059,0.074144,-0.09449,0.285536,0.074144,-0.094913,0.284274,0.074144,-0.095578,0.28316,0.074144,-0.096449,0.28223,0.074144,-0.097493,0.281522,0.074144,-0.098677,0.28107,0.074144,-0.099965,0.280911,0.074144,-0.150248,0.280911,0.074144,-0.151537,0.28107,0.074144,-0.15272,0.281522,0.074144,-0.153765,0.28223,0.074144,-0.154636,0.28316,0.074144,-0.1553,0.284274,0.074144,-0.155724,0.285536,0.074144,-0.155872,0.286911,0.074144,-0.155872,0.307059,0.074144,-0.155724,0.308434,0.074144,-0.151537,0.312901,0.074144,-0.15272,0.312449,0.074144,-0.1553,0.309697,0.074144,-0.154636,0.310811,0.074144,-0.153765,0.31174,0.074144,-0.176065,0.312449,0.074144,-0.177248,0.312901,0.074144,-0.178537,0.313059,0.074144,-0.17502,0.31174,0.074144,-0.174149,0.310811,0.074144,-0.173485,0.309697,0.074144,-0.173061,0.308434,0.074144,-0.172913,0.307059,0.074144,-0.172913,0.286911,0.074144,-0.22882,0.313059,0.074144,-0.173061,0.285536,0.074144,-0.173485,0.284274,0.074144,-0.174149,0.28316,0.074144,-0.17502,0.28223,0.074144,-0.176065,0.281522,0.074144,-0.177248,0.28107,0.074144,-0.178537,0.280911,0.074144,-0.22882,0.280911,0.074144,-0.230108,0.28107,0.074144,-0.231292,0.281522,0.074144,-0.232336,0.28223,0.074144,-0.233207,0.28316,0.074144,-0.233872,0.284274,0.074144,-0.234295,0.285536,0.074144,-0.234444,0.286911,0.074144,-0.234444,0.307059,0.074144,-0.234295,0.308434,0.074144,-0.230108,0.312901,0.074144,-0.231292,0.312449,0.074144,-0.233872,0.309697,0.074144,-0.233207,0.310811,0.074144,-0.232336,0.31174,0.074144,-0.254636,0.312449,0.074144,-0.25582,0.312901,0.074144,-0.257108,0.313059,0.074144,-0.253592,0.31174,0.074144,-0.252721,0.310811,0.074144,-0.252056,0.309697,0.074144,-0.251633,0.308434,0.074144,-0.251484,0.307059,0.074144,-0.251484,0.286911,0.074144,-0.307391,0.313059,0.074144,-0.251633,0.285536,0.074144,-0.252056,0.284274,0.074144,-0.252721,0.28316,0.074144,-0.253592,0.28223,0.074144,-0.254636,0.281522,0.074144,-0.25582,0.28107,0.074144,-0.257108,0.280911,0.074144,-0.307391,0.280911,0.074144,-0.30868,0.28107,0.074144,-0.309863,0.281522,0.074144,-0.310907,0.28223,0.074144,-0.311779,0.28316,0.074144,-0.312443,0.284274,0.074144,-0.312867,0.285536,0.074144,-0.313015,0.286911,0.074144,-0.313015,0.307059,0.074144,-0.312867,0.308434,0.074144,-0.30868,0.312901,0.074144,-0.309863,0.312449,0.074144,-0.312443,0.309697,0.074144,-0.311779,0.310811,0.074144,-0.310907,0.31174,0.074144,-0.333208,0.312449,0.074144,-0.334391,0.312901,0.074144,-0.33568,0.313059,0.074144,-0.332163,0.31174,0.074144,-0.331292,0.310811,0.074144,-0.330628,0.309697,0.074144,-0.330204,0.308434,0.074144,-0.330056,0.307059,0.074144,-0.330056,0.286911,0.074144,-0.385962,0.313059,0.074144,-0.330204,0.285536,0.074144,-0.330628,0.284274,0.074144,-0.331292,0.28316,0.074144,-0.332163,0.28223,0.074144,-0.333208,0.281522,0.074144,-0.334391,0.28107,0.074144,-0.33568,0.280911,0.074144,-0.385962,0.280911,0.074144,-0.387251,0.28107,0.074144,-0.388435,0.281522,0.074144,-0.389479,0.28223,0.074144,-0.39035,0.28316,0.074144,-0.391014,0.284274,0.074144,-0.391438,0.285536,0.074144,-0.391587,0.286911,0.074144,-0.391587,0.307059,0.074144,-0.387251,0.312901,0.074144,-0.391438,0.308434,0.074144,-0.388435,0.312449,0.074144,-0.391015,0.309697,0.074144,-0.39035,0.310811,0.074144,-0.389479,0.31174,0.074144,-0.411779,0.312449,0.074144,-0.412963,0.312901,0.074144,-0.414251,0.313059,0.074144,-0.410735,0.31174,0.074144,-0.409864,0.310811,0.074144,-0.409199,0.309697,0.074144,-0.408776,0.308434,0.074144,-0.408627,0.307059,0.074144,-0.408627,0.286911,0.074144,-0.464534,0.313059,0.074144,-0.408776,0.285536,0.074144,-0.409199,0.284274,0.074144,-0.409864,0.28316,0.074144,-0.410735,0.28223,0.074144,-0.411779,0.281522,0.074144,-0.412963,0.28107,0.074144,-0.414251,0.280911,0.074144,-0.464534,0.280911,0.074144,-0.465823,0.28107,0.074144,-0.467006,0.281522,0.074144,-0.46805,0.28223,0.074144,-0.468922,0.28316,0.074144,-0.469586,0.284274,0.074144,-0.470009,0.285536,0.074144,-0.470158,0.286911,0.074144,-0.470158,0.307059,0.074144,-0.470009,0.308434,0.074144,-0.465823,0.312901,0.074144,-0.467006,0.312449,0.074144,-0.469586,0.309697,0.074144,-0.468922,0.310811,0.074144,-0.46805,0.31174,0.074144,-0.543105,0.313059,0.074144,-0.544394,0.312901,0.074144,-0.545577,0.312449,0.074144,-0.546622,0.31174,0.074144,-0.547493,0.310811,0.074144,-0.548157,0.309697,0.074144,-0.548581,0.308434,0.074144,-0.54873,0.307059,0.074144,-0.492823,0.313059,0.074144,-0.54873,0.286911,0.074144,-0.548581,0.285536,0.074144,-0.548157,0.284274,0.074144,-0.547493,0.28316,0.074144,-0.546622,0.28223,0.074144,-0.545578,0.281522,0.074144,-0.544394,0.28107,0.074144,-0.543105,0.280911,0.074144,-0.492823,0.280911,0.074144,-0.491534,0.28107,0.074144,-0.49035,0.281521,0.074144,-0.489306,0.28223,0.074144,-0.488435,0.28316,0.074144,-0.487771,0.284274,0.074144,-0.487347,0.285536,0.074144,-0.487199,0.286911,0.074144,-0.487199,0.307059,0.074144,-0.487347,0.308434,0.074144,-0.491534,0.312901,0.074144,-0.490351,0.312449,0.074144,-0.487771,0.309696,0.074144,-0.488435,0.310811,0.074144,-0.489306,0.31174,0.074144,-0.627301,0.286911,0.074144,-0.627152,0.285536,0.074144,-0.626729,0.284274,0.074144,-0.626064,0.28316,0.074144,-0.625193,0.28223,0.074144,-0.624149,0.281522,0.074144,-0.622966,0.28107,0.074144,-0.621677,0.280911,0.074144,-0.627301,0.307059,0.074144,-0.571394,0.280911,0.074144,-0.627152,0.308434,0.074144,-0.626729,0.309697,0.074144,-0.626064,0.310811,0.074144,-0.625193,0.31174,0.074144,-0.624149,0.312449,0.074144,-0.622966,0.312901,0.074144,-0.621677,0.313059,0.074144,-0.571394,0.313059,0.074144,-0.570105,0.28107,0.074144,-0.568922,0.281521,0.074144,-0.567878,0.28223,0.074144,-0.567006,0.28316,0.074144,-0.566342,0.284274,0.074144,-0.565919,0.285536,0.074144,-0.56577,0.286911,0.074144,-0.56577,0.307059,0.074144,-0.565919,0.308434,0.074144,-0.570105,0.312901,0.074144,-0.568922,0.312449,0.074144,-0.566342,0.309696,0.074144,-0.567878,0.31174,0.074144,-0.567006,0.310811,0.074144,0.449345,0.264268,0.074144,0.449197,0.265643,0.074144,0.448773,0.266905,0.074144,0.448109,0.268019,0.074144,0.447238,0.268949,0.074144,0.446194,0.269658,0.074144,0.44501,0.270109,0.074144,0.443721,0.270268,0.074144,0.449346,0.21912,0.074144,0.397293,0.270268,0.074144,0.449197,0.217745,0.074144,0.448773,0.216483,0.074144,0.448109,0.215369,0.074144,0.447238,0.214439,0.074144,0.446194,0.21373,0.074144,0.44501,0.213279,0.074144,0.443721,0.21312,0.074144,0.397293,0.21312,0.074144,0.396004,0.213279,0.074144,0.394821,0.21373,0.074144,0.393776,0.214439,0.074144,0.392905,0.215369,0.074144,0.392241,0.216483,0.074144,0.391817,0.217745,0.074144,0.391668,0.21912,0.074144,0.391817,0.217745,0.074144,0.397293,0.270268,0.074144,0.391668,0.264268,0.074144,0.391668,0.21912,0.074144,0.391817,0.265643,0.074144,0.396004,0.270109,0.074144,0.392241,0.266905,0.074144,0.39482,0.269658,0.074144,0.393776,0.268949,0.074144,0.392905,0.26802,0.074144,0.38382,0.264268,0.074144,0.383671,0.265643,0.074144,0.383248,0.266905,0.074144,0.382584,0.268019,0.074144,0.381712,0.268949,0.074144,0.380668,0.269658,0.074144,0.379485,0.270109,0.074144,0.378196,0.270268,0.074144,0.38382,0.21912,0.074144,0.331767,0.270268,0.074144,0.383671,0.217745,0.074144,0.383248,0.216483,0.074144,0.382584,0.215369,0.074144,0.381712,0.214439,0.074144,0.380668,0.21373,0.074144,0.379485,0.213279,0.074144,0.378196,0.21312,0.074144,0.331767,0.21312,0.074144,0.330478,0.213279,0.074144,0.329295,0.21373,0.074144,0.328251,0.214439,0.074144,0.327379,0.215369,0.074144,0.326715,0.216483,0.074144,0.326292,0.217745,0.074144,0.326143,0.21912,0.074144,0.326292,0.217745,0.074144,0.331767,0.270268,0.074144,0.326143,0.264268,0.074144,0.326143,0.21912,0.074144,0.326292,0.265643,0.074144,0.330478,0.270109,0.074144,0.326715,0.266905,0.074144,0.329295,0.269658,0.074144,0.327379,0.268019,0.074144,0.328251,0.268949,0.074144,0.31017,0.264268,0.074144,0.310021,0.265643,0.074144,0.309598,0.266905,0.074144,0.308933,0.268019,0.074144,0.308062,0.268949,0.074144,0.307018,0.269658,0.074144,0.305834,0.270109,0.074144,0.304546,0.270268,0.074144,0.31017,0.21912,0.074144,0.258117,0.270268,0.074144,0.310021,0.217745,0.074144,0.309598,0.216483,0.074144,0.308934,0.215369,0.074144,0.308062,0.214439,0.074144,0.307018,0.21373,0.074144,0.305834,0.213279,0.074144,0.304546,0.21312,0.074144,0.258117,0.21312,0.074144,0.256828,0.213279,0.074144,0.255645,0.21373,0.074144,0.254601,0.214439,0.074144,0.253729,0.215369,0.074144,0.253065,0.216483,0.074144,0.252642,0.217745,0.074144,0.252493,0.21912,0.074144,0.252642,0.217745,0.074144,0.258117,0.270268,0.074144,0.252493,0.264268,0.074144,0.252493,0.21912,0.074144,0.252642,0.265643,0.074144,0.256828,0.270109,0.074144,0.253065,0.266905,0.074144,0.255645,0.269658,0.074144,0.253729,0.268019,0.074144,0.254601,0.268949,0.074144,0.23652,0.264268,0.074144,0.236371,0.265643,0.074144,0.235948,0.266905,0.074144,0.235283,0.268019,0.074144,0.234412,0.268949,0.074144,0.233368,0.269658,0.074144,0.232184,0.270109,0.074144,0.230896,0.270268,0.074144,0.23652,0.21912,0.074144,0.184467,0.270268,0.074144,0.236371,0.217745,0.074144,0.235948,0.216483,0.074144,0.235283,0.215369,0.074144,0.234412,0.214439,0.074144,0.233368,0.21373,0.074144,0.232184,0.213279,0.074144,0.230896,0.21312,0.074144,0.184467,0.21312,0.074144,0.183178,0.213279,0.074144,0.181995,0.21373,0.074144,0.180951,0.214439,0.074144,0.180079,0.215369,0.074144,0.179415,0.216483,0.074144,0.178991,0.217745,0.074144,0.178843,0.21912,0.074144,0.178991,0.217745,0.074144,0.184467,0.270268,0.074144,0.178843,0.264268,0.074144,0.178843,0.21912,0.074144,0.183178,0.270109,0.074144,0.178991,0.265643,0.074144,0.179415,0.266905,0.074144,0.181995,0.269658,0.074144,0.180079,0.268019,0.074144,0.18095,0.268949,0.074144,0.162298,0.216483,0.074144,0.162721,0.217745,0.074144,0.16287,0.21912,0.074144,0.161633,0.215369,0.074144,0.160762,0.214439,0.074144,0.159718,0.21373,0.074144,0.158534,0.213279,0.074144,0.157246,0.21312,0.074144,0.110817,0.21312,0.074144,0.16287,0.264268,0.074144,0.162721,0.265643,0.074144,0.162298,0.266905,0.074144,0.161633,0.268019,0.074144,0.160762,0.268949,0.074144,0.159718,0.269658,0.074144,0.158534,0.270109,0.074144,0.157246,0.270268,0.074144,0.110817,0.270268,0.074144,0.109528,0.213279,0.074144,0.108345,0.21373,0.074144,0.1073,0.214439,0.074144,0.106429,0.215369,0.074144,0.105765,0.216483,0.074144,0.105341,0.217745,0.074144,0.105193,0.21912,0.074144,0.105341,0.217745,0.074144,0.110817,0.270268,0.074144,0.105193,0.264268,0.074144,0.105193,0.21912,0.074144,0.105341,0.265643,0.074144,0.109528,0.270109,0.074144,0.105765,0.266905,0.074144,0.108345,0.269658,0.074144,0.1073,0.268949,0.074144,0.106429,0.268019,0.074144,0.086068,0.269658,0.074144,0.084884,0.270109,0.074144,0.083595,0.270268,0.074144,0.087112,0.268949,0.074144,0.087983,0.268019,0.074144,0.088647,0.266905,0.074144,0.089071,0.265643,0.074144,0.08922,0.264268,0.074144,0.08922,0.21912,0.074144,0.037167,0.270268,0.074144,0.089071,0.217745,0.074144,0.088647,0.216483,0.074144,0.087983,0.215369,0.074144,0.087112,0.214439,0.074144,0.086068,0.21373,0.074144,0.084884,0.213279,0.074144,0.083595,0.21312,0.074144,0.037167,0.21312,0.074144,0.035878,0.213279,0.074144,0.034695,0.21373,0.074144,0.03365,0.214439,0.074144,0.032779,0.215369,0.074144,0.032115,0.216483,0.074144,0.031691,0.217745,0.074144,0.031543,0.21912,0.074144,0.031691,0.217745,0.074144,0.037167,0.270268,0.074144,0.031543,0.264268,0.074144,0.031543,0.21912,0.074144,0.031691,0.265643,0.074144,0.035878,0.270109,0.074144,0.034695,0.269658,0.074144,0.032115,0.266905,0.074144,0.03365,0.268949,0.074144,0.032779,0.268019,0.074144,0.012417,0.269658,0.074144,0.011234,0.270109,0.074144,0.009945,0.270268,0.074144,0.013462,0.268949,0.074144,0.014333,0.268019,0.074144,0.014997,0.266905,0.074144,0.015421,0.265643,0.074144,0.015569,0.264268,0.074144,0.015569,0.21912,0.074144,-0.036483,0.270268,0.074144,0.015421,0.217745,0.074144,0.014997,0.216483,0.074144,0.014333,0.215369,0.074144,0.013462,0.214439,0.074144,0.012417,0.21373,0.074144,0.011234,0.213279,0.074144,0.009945,0.21312,0.074144,-0.036483,0.21312,0.074144,-0.037772,0.213279,0.074144,-0.038956,0.21373,0.074144,-0.04,0.214439,0.074144,-0.040871,0.215369,0.074144,-0.041536,0.216483,0.074144,-0.041959,0.217745,0.074144,-0.042108,0.21912,0.074144,-0.041959,0.217745,0.074144,-0.036483,0.270268,0.074144,-0.042108,0.264268,0.074144,-0.042108,0.21912,0.074144,-0.037772,0.270109,0.074144,-0.041959,0.265643,0.074144,-0.038956,0.269658,0.074144,-0.041536,0.266905,0.074144,-0.04,0.268949,0.074144,-0.040871,0.268019,0.074144,-0.061233,0.269658,0.074144,-0.062416,0.270109,0.074144,-0.063705,0.270268,0.074144,-0.060188,0.268949,0.074144,-0.059317,0.268019,0.074144,-0.058653,0.266905,0.074144,-0.058229,0.265643,0.074144,-0.058081,0.264268,0.074144,-0.058081,0.21912,0.074144,-0.110134,0.270268,0.074144,-0.058229,0.217745,0.074144,-0.058653,0.216483,0.074144,-0.059317,0.215369,0.074144,-0.060188,0.214439,0.074144,-0.061233,0.21373,0.074144,-0.062416,0.213279,0.074144,-0.063705,0.21312,0.074144,-0.110134,0.21312,0.074144,-0.111422,0.213279,0.074144,-0.112606,0.21373,0.074144,-0.11365,0.214439,0.074144,-0.114521,0.215369,0.074144,-0.115186,0.216483,0.074144,-0.115609,0.217745,0.074144,-0.115758,0.21912,0.074144,-0.115609,0.217745,0.074144,-0.110134,0.270268,0.074144,-0.115758,0.264268,0.074144,-0.115758,0.21912,0.074144,-0.115609,0.265643,0.074144,-0.111422,0.270109,0.074144,-0.112606,0.269658,0.074144,-0.115186,0.266905,0.074144,-0.11365,0.268949,0.074144,-0.114521,0.268019,0.074144,-0.134883,0.269658,0.074144,-0.136066,0.270109,0.074144,-0.137355,0.270268,0.074144,-0.133839,0.268949,0.074144,-0.132967,0.268019,0.074144,-0.132303,0.266905,0.074144,-0.13188,0.265643,0.074144,-0.131731,0.264268,0.074144,-0.131731,0.21912,0.074144,-0.183784,0.270268,0.074144,-0.13188,0.217745,0.074144,-0.132303,0.216483,0.074144,-0.132967,0.215369,0.074144,-0.133839,0.214439,0.074144,-0.134883,0.21373,0.074144,-0.136066,0.213279,0.074144,-0.137355,0.21312,0.074144,-0.183784,0.21312,0.074144,-0.185072,0.213279,0.074144,-0.186256,0.21373,0.074144,-0.1873,0.214439,0.074144,-0.188171,0.215369,0.074144,-0.188836,0.216483,0.074144,-0.189259,0.217745,0.074144,-0.189408,0.21912,0.074144,-0.189259,0.217745,0.074144,-0.183784,0.270268,0.074144,-0.189408,0.264268,0.074144,-0.189408,0.21912,0.074144,-0.185072,0.270109,0.074144,-0.189259,0.265643,0.074144,-0.186256,0.269658,0.074144,-0.188836,0.266905,0.074144,-0.188171,0.268019,0.074144,-0.1873,0.268949,0.074144,-0.208533,0.269658,0.074144,-0.209716,0.270109,0.074144,-0.211005,0.270268,0.074144,-0.207489,0.268949,0.074144,-0.206617,0.268019,0.074144,-0.205953,0.266905,0.074144,-0.20553,0.265643,0.074144,-0.205381,0.264268,0.074144,-0.205381,0.21912,0.074144,-0.257434,0.270268,0.074144,-0.20553,0.217745,0.074144,-0.205953,0.216483,0.074144,-0.206617,0.215369,0.074144,-0.207489,0.214439,0.074144,-0.208533,0.21373,0.074144,-0.209716,0.213279,0.074144,-0.211005,0.21312,0.074144,-0.257434,0.21312,0.074144,-0.258723,0.213279,0.074144,-0.259906,0.21373,0.074144,-0.26095,0.214439,0.074144,-0.261822,0.215369,0.074144,-0.262486,0.216483,0.074144,-0.262909,0.217745,0.074144,-0.263058,0.21912,0.074144,-0.262909,0.217745,0.074144,-0.257434,0.270268,0.074144,-0.263058,0.264268,0.074144,-0.263058,0.21912,0.074144,-0.258723,0.270109,0.074144,-0.262909,0.265643,0.074144,-0.259906,0.269658,0.074144,-0.262486,0.266905,0.074144,-0.261822,0.268019,0.074144,-0.26095,0.268949,0.074144,-0.336136,0.266905,0.074144,-0.33656,0.265643,0.074144,-0.336708,0.264268,0.074144,-0.335472,0.268019,0.074144,-0.3346,0.268949,0.074144,-0.333556,0.269658,0.074144,-0.332373,0.270109,0.074144,-0.331084,0.270268,0.074144,-0.284655,0.270268,0.074144,-0.336708,0.21912,0.074144,-0.33656,0.217745,0.074144,-0.336136,0.216483,0.074144,-0.335472,0.215369,0.074144,-0.3346,0.214439,0.074144,-0.333556,0.21373,0.074144,-0.332373,0.213279,0.074144,-0.331084,0.21312,0.074144,-0.284655,0.21312,0.074144,-0.283367,0.213279,0.074144,-0.282183,0.21373,0.074144,-0.281139,0.214439,0.074144,-0.280268,0.215369,0.074144,-0.279603,0.216483,0.074144,-0.27918,0.217745,0.074144,-0.284655,0.270268,0.074144,-0.27918,0.217745,0.074144,-0.279031,0.21912,0.074144,-0.279031,0.21912,0.074144,-0.279031,0.264268,0.074144,-0.27918,0.265643,0.074144,-0.283367,0.270109,0.074144,-0.282183,0.269658,0.074144,-0.279603,0.266905,0.074144,-0.281139,0.268949,0.074144,-0.280268,0.268019,0.074144,-0.410358,0.21912,0.074144,-0.41021,0.217745,0.074144,-0.409786,0.216483,0.074144,-0.409122,0.215369,0.074144,-0.408251,0.214439,0.074144,-0.407206,0.21373,0.074144,-0.406023,0.213279,0.074144,-0.404734,0.21312,0.074144,-0.410358,0.264268,0.074144,-0.358305,0.21312,0.074144,-0.41021,0.265643,0.074144,-0.409786,0.266905,0.074144,-0.409122,0.268019,0.074144,-0.408251,0.268949,0.074144,-0.407206,0.269658,0.074144,-0.406023,0.270109,0.074144,-0.404734,0.270268,0.074144,-0.358305,0.270268,0.074144,-0.357017,0.213279,0.074144,-0.355833,0.21373,0.074144,-0.354789,0.214439,0.074144,-0.353918,0.215369,0.074144,-0.353253,0.216483,0.074144,-0.35283,0.217745,0.074144,-0.358305,0.270268,0.074144,-0.35283,0.217745,0.074144,-0.352681,0.21912,0.074144,-0.352681,0.21912,0.074144,-0.352681,0.264268,0.074144,-0.35283,0.265643,0.074144,-0.357017,0.270109,0.074144,-0.355833,0.269658,0.074144,-0.353253,0.266905,0.074144,-0.354789,0.268949,0.074144,-0.353918,0.268019,0.074144,-0.426904,0.216483,0.074144,-0.42648,0.217745,0.074144,-0.426331,0.21912,0.074144,-0.427568,0.215369,0.074144,-0.428439,0.214439,0.074144,-0.429483,0.21373,0.074144,-0.430667,0.213279,0.074144,-0.431956,0.21312,0.074144,-0.478384,0.21312,0.074144,-0.426331,0.264268,0.074144,-0.42648,0.265643,0.074144,-0.426904,0.266905,0.074144,-0.427568,0.268019,0.074144,-0.428439,0.268949,0.074144,-0.429483,0.269658,0.074144,-0.430667,0.270109,0.074144,-0.431956,0.270268,0.074144,-0.478384,0.270268,0.074144,-0.479673,0.213279,0.074144,-0.480856,0.21373,0.074144,-0.481901,0.214439,0.074144,-0.482772,0.215369,0.074144,-0.483436,0.216483,0.074144,-0.48386,0.217745,0.074144,-0.484008,0.21912,0.074144,-0.48386,0.217745,0.074144,-0.478384,0.270268,0.074144,-0.484008,0.264268,0.074144,-0.484008,0.21912,0.074144,-0.479673,0.270109,0.074144,-0.48386,0.265643,0.074144,-0.480856,0.269658,0.074144,-0.483436,0.266905,0.074144,-0.481901,0.268949,0.074144,-0.482772,0.268019,0.074144,-0.613552,0.268768,0.074144,-0.614841,0.268609,0.074144,-0.616024,0.268158,0.074144,-0.617069,0.267449,0.074144,-0.61794,0.266519,0.074144,-0.618604,0.265405,0.074144,-0.619028,0.264143,0.074144,-0.619176,0.262768,0.074144,-0.508379,0.268768,0.074144,-0.619176,0.22062,0.074144,-0.619028,0.219245,0.074144,-0.618604,0.217983,0.074144,-0.61794,0.216869,0.074144,-0.617069,0.215939,0.074144,-0.616024,0.21523,0.074144,-0.614841,0.214779,0.074144,-0.613552,0.21462,0.074144,-0.508379,0.21462,0.074144,-0.507091,0.214779,0.074144,-0.505907,0.21523,0.074144,-0.504863,0.215939,0.074144,-0.503991,0.216869,0.074144,-0.503327,0.217983,0.074144,-0.502904,0.219245,0.074144,-0.508379,0.268768,0.074144,-0.502904,0.219245,0.074144,-0.502755,0.22062,0.074144,-0.502755,0.22062,0.074144,-0.502755,0.262768,0.074144,-0.502904,0.264143,0.074144,-0.507091,0.268609,0.074144,-0.505907,0.268158,0.074144,-0.503327,0.265405,0.074144,-0.503991,0.266519,0.074144,-0.504863,0.267449,0.074144,-0.626729,0.195257,0.074144,-0.627152,0.193994,0.074144,-0.627301,0.192619,0.074144,-0.626064,0.196371,0.074144,-0.625193,0.1973,0.074144,-0.624149,0.198009,0.074144,-0.622965,0.198461,0.074144,-0.621677,0.198619,0.074144,-0.575248,0.198619,0.074144,-0.627301,0.147471,0.074144,-0.627152,0.146096,0.074144,-0.626729,0.144834,0.074144,-0.626064,0.14372,0.074144,-0.625193,0.14279,0.074144,-0.624149,0.142082,0.074144,-0.622965,0.14163,0.074144,-0.621677,0.141471,0.074144,-0.575248,0.141471,0.074144,-0.573959,0.14163,0.074144,-0.572776,0.142082,0.074144,-0.571732,0.14279,0.074144,-0.57086,0.14372,0.074144,-0.570196,0.144834,0.074144,-0.569773,0.146096,0.074144,-0.575248,0.198619,0.074144,-0.569773,0.146096,0.074144,-0.569624,0.147471,0.074144,-0.569624,0.147471,0.074144,-0.569624,0.192619,0.074144,-0.569773,0.193994,0.074144,-0.573959,0.198461,0.074144,-0.570196,0.195257,0.074144,-0.572776,0.198009,0.074144,-0.571732,0.1973,0.074144,-0.57086,0.196371,0.074144,-0.554076,0.195257,0.074144,-0.554499,0.193994,0.074144,-0.554648,0.192619,0.074144,-0.553412,0.196371,0.074144,-0.55254,0.1973,0.074144,-0.551496,0.198009,0.074144,-0.550313,0.198461,0.074144,-0.549024,0.198619,0.074144,-0.502595,0.198619,0.074144,-0.554648,0.147471,0.074144,-0.554499,0.146096,0.074144,-0.554076,0.144834,0.074144,-0.553412,0.14372,0.074144,-0.55254,0.14279,0.074144,-0.551496,0.142082,0.074144,-0.550313,0.14163,0.074144,-0.549024,0.141471,0.074144,-0.502595,0.141471,0.074144,-0.501306,0.14163,0.074144,-0.500123,0.142082,0.074144,-0.499079,0.14279,0.074144,-0.498207,0.14372,0.074144,-0.497543,0.144834,0.074144,-0.49712,0.146096,0.074144,-0.502595,0.198619,0.074144,-0.49712,0.146096,0.074144,-0.496971,0.147471,0.074144,-0.496971,0.147471,0.074144,-0.496971,0.192619,0.074144,-0.49712,0.193994,0.074144,-0.501306,0.198461,0.074144,-0.500123,0.198009,0.074144,-0.497543,0.195257,0.074144,-0.499079,0.1973,0.074144,-0.498207,0.196371,0.074144,-0.480426,0.195257,0.074144,-0.480849,0.193994,0.074144,-0.480998,0.192619,0.074144,-0.479761,0.196371,0.074144,-0.47889,0.1973,0.074144,-0.477846,0.198009,0.074144,-0.476662,0.198461,0.074144,-0.475374,0.198619,0.074144,-0.428945,0.198619,0.074144,-0.480998,0.147471,0.074144,-0.480849,0.146096,0.074144,-0.480426,0.144834,0.074144,-0.479761,0.14372,0.074144,-0.47889,0.14279,0.074144,-0.477846,0.142082,0.074144,-0.476662,0.14163,0.074144,-0.475374,0.141471,0.074144,-0.428945,0.141471,0.074144,-0.427656,0.14163,0.074144,-0.426473,0.142082,0.074144,-0.425429,0.14279,0.074144,-0.424557,0.14372,0.074144,-0.423893,0.144834,0.074144,-0.423469,0.146096,0.074144,-0.428945,0.198619,0.074144,-0.423469,0.146096,0.074144,-0.423321,0.147471,0.074144,-0.423321,0.147471,0.074144,-0.423321,0.192619,0.074144,-0.423469,0.193994,0.074144,-0.427656,0.198461,0.074144,-0.426473,0.198009,0.074144,-0.423893,0.195257,0.074144,-0.424557,0.196371,0.074144,-0.425428,0.1973,0.074144,-0.406776,0.195257,0.074144,-0.407199,0.193994,0.074144,-0.407348,0.192619,0.074144,-0.406111,0.196371,0.074144,-0.40524,0.1973,0.074144,-0.404196,0.198009,0.074144,-0.403012,0.198461,0.074144,-0.401724,0.198619,0.074144,-0.355295,0.198619,0.074144,-0.407348,0.147471,0.074144,-0.407199,0.146096,0.074144,-0.406776,0.144834,0.074144,-0.406111,0.14372,0.074144,-0.40524,0.14279,0.074144,-0.404196,0.142082,0.074144,-0.403012,0.14163,0.074144,-0.401724,0.141471,0.074144,-0.355295,0.141471,0.074144,-0.354006,0.14163,0.074144,-0.352823,0.142082,0.074144,-0.351778,0.14279,0.074144,-0.350907,0.14372,0.074144,-0.350243,0.144834,0.074144,-0.349819,0.146096,0.074144,-0.355295,0.198619,0.074144,-0.349819,0.146096,0.074144,-0.349671,0.147471,0.074144,-0.349671,0.147471,0.074144,-0.349671,0.192619,0.074144,-0.349819,0.193994,0.074144,-0.354006,0.198461,0.074144,-0.352823,0.198009,0.074144,-0.350243,0.195257,0.074144,-0.350907,0.196371,0.074144,-0.351778,0.1973,0.074144,-0.333125,0.195257,0.074144,-0.333549,0.193994,0.074144,-0.333698,0.192619,0.074144,-0.332461,0.196371,0.074144,-0.33159,0.1973,0.074144,-0.330546,0.198009,0.074144,-0.329362,0.198461,0.074144,-0.328073,0.198619,0.074144,-0.281645,0.198619,0.074144,-0.333698,0.147471,0.074144,-0.333549,0.146096,0.074144,-0.333126,0.144834,0.074144,-0.332461,0.14372,0.074144,-0.33159,0.14279,0.074144,-0.330546,0.142082,0.074144,-0.329362,0.14163,0.074144,-0.328073,0.141471,0.074144,-0.281645,0.141471,0.074144,-0.280356,0.14163,0.074144,-0.279173,0.142082,0.074144,-0.278128,0.14279,0.074144,-0.277257,0.14372,0.074144,-0.276593,0.144834,0.074144,-0.276169,0.146096,0.074144,-0.281645,0.198619,0.074144,-0.276169,0.146096,0.074144,-0.276021,0.147471,0.074144,-0.276021,0.147471,0.074144,-0.276021,0.192619,0.074144,-0.276169,0.193994,0.074144,-0.280356,0.198461,0.074144,-0.279173,0.198009,0.074144,-0.276593,0.195257,0.074144,-0.278128,0.1973,0.074144,-0.277257,0.196371,0.074144,-0.205522,0.198009,0.074144,-0.206706,0.198461,0.074144,-0.207995,0.198619,0.074144,-0.204478,0.1973,0.074144,-0.203607,0.196371,0.074144,-0.202943,0.195257,0.074144,-0.202519,0.193994,0.074144,-0.20237,0.192619,0.074144,-0.20237,0.147471,0.074144,-0.254423,0.198619,0.074144,-0.202519,0.146096,0.074144,-0.202943,0.144834,0.074144,-0.203607,0.14372,0.074144,-0.204478,0.14279,0.074144,-0.205522,0.142082,0.074144,-0.206706,0.14163,0.074144,-0.207995,0.141471,0.074144,-0.254423,0.141471,0.074144,-0.255712,0.14163,0.074144,-0.256895,0.142082,0.074144,-0.25794,0.14279,0.074144,-0.258811,0.14372,0.074144,-0.259475,0.144834,0.074144,-0.259899,0.146096,0.074144,-0.260047,0.147471,0.074144,-0.259899,0.146096,0.074144,-0.254423,0.198619,0.074144,-0.260047,0.192619,0.074144,-0.260047,0.147471,0.074144,-0.259899,0.193994,0.074144,-0.255712,0.198461,0.074144,-0.259475,0.195257,0.074144,-0.256895,0.198009,0.074144,-0.25794,0.1973,0.074144,-0.258811,0.196371,0.074144,-0.131872,0.198009,0.074144,-0.133056,0.198461,0.074144,-0.134344,0.198619,0.074144,-0.130828,0.1973,0.074144,-0.129957,0.196371,0.074144,-0.129292,0.195257,0.074144,-0.128869,0.193994,0.074144,-0.12872,0.192619,0.074144,-0.12872,0.147471,0.074144,-0.180773,0.198619,0.074144,-0.128869,0.146096,0.074144,-0.129292,0.144834,0.074144,-0.129957,0.14372,0.074144,-0.130828,0.14279,0.074144,-0.131872,0.142082,0.074144,-0.133056,0.14163,0.074144,-0.134344,0.141471,0.074144,-0.180773,0.141471,0.074144,-0.182062,0.198461,0.074144,-0.183245,0.198009,0.074144,-0.18429,0.1973,0.074144,-0.185161,0.196371,0.074144,-0.185825,0.195257,0.074144,-0.186249,0.193994,0.074144,-0.180773,0.141471,0.074144,-0.186249,0.193994,0.074144,-0.186397,0.192619,0.074144,-0.186397,0.192619,0.074144,-0.186397,0.147471,0.074144,-0.182062,0.14163,0.074144,-0.186249,0.146096,0.074144,-0.185825,0.144834,0.074144,-0.183245,0.142082,0.074144,-0.185161,0.14372,0.074144,-0.18429,0.14279,0.074144,-0.058222,0.198009,0.074144,-0.059406,0.198461,0.074144,-0.060694,0.198619,0.074144,-0.057178,0.1973,0.074144,-0.056307,0.196371,0.074144,-0.055642,0.195257,0.074144,-0.055219,0.193994,0.074144,-0.05507,0.192619,0.074144,-0.05507,0.147471,0.074144,-0.107123,0.198619,0.074144,-0.055219,0.146096,0.074144,-0.055642,0.144834,0.074144,-0.056307,0.14372,0.074144,-0.057178,0.14279,0.074144,-0.058222,0.142082,0.074144,-0.059406,0.14163,0.074144,-0.060694,0.141471,0.074144,-0.107123,0.141471,0.074144,-0.108412,0.14163,0.074144,-0.109595,0.142082,0.074144,-0.110639,0.14279,0.074144,-0.111511,0.14372,0.074144,-0.112175,0.144834,0.074144,-0.112599,0.146096,0.074144,-0.112747,0.147471,0.074144,-0.112599,0.146096,0.074144,-0.107123,0.198619,0.074144,-0.112747,0.192619,0.074144,-0.112747,0.147471,0.074144,-0.108412,0.198461,0.074144,-0.112599,0.193994,0.074144,-0.112175,0.195257,0.074144,-0.109595,0.198009,0.074144,-0.111511,0.196371,0.074144,-0.110639,0.1973,0.074144,0.015428,0.198009,0.074144,0.014245,0.198461,0.074144,0.012956,0.198619,0.074144,0.016472,0.1973,0.074144,0.017344,0.196371,0.074144,0.018008,0.195257,0.074144,0.018431,0.193994,0.074144,0.01858,0.192619,0.074144,0.01858,0.147471,0.074144,-0.033473,0.198619,0.074144,0.018431,0.146096,0.074144,0.018008,0.144834,0.074144,0.017344,0.14372,0.074144,0.016472,0.14279,0.074144,0.015428,0.142082,0.074144,0.014245,0.14163,0.074144,0.012956,0.141471,0.074144,-0.033473,0.141471,0.074144,-0.034762,0.14163,0.074144,-0.035945,0.142082,0.074144,-0.036989,0.14279,0.074144,-0.037861,0.14372,0.074144,-0.038525,0.144834,0.074144,-0.038948,0.146096,0.074144,-0.039097,0.147471,0.074144,-0.038948,0.146096,0.074144,-0.033473,0.198619,0.074144,-0.039097,0.192619,0.074144,-0.039097,0.147471,0.074144,-0.034762,0.198461,0.074144,-0.038948,0.193994,0.074144,-0.038525,0.195257,0.074144,-0.035945,0.198009,0.074144,-0.037861,0.196371,0.074144,-0.036989,0.1973,0.074144,0.089078,0.198009,0.074144,0.087895,0.198461,0.074144,0.086606,0.198619,0.074144,0.090122,0.1973,0.074144,0.090994,0.196371,0.074144,0.091658,0.195257,0.074144,0.092081,0.193994,0.074144,0.09223,0.192619,0.074144,0.09223,0.147471,0.074144,0.040177,0.198619,0.074144,0.092081,0.146096,0.074144,0.091658,0.144834,0.074144,0.090994,0.14372,0.074144,0.090122,0.14279,0.074144,0.089078,0.142082,0.074144,0.087895,0.14163,0.074144,0.086606,0.141471,0.074144,0.040177,0.141471,0.074144,0.038889,0.14163,0.074144,0.037705,0.142082,0.074144,0.036661,0.14279,0.074144,0.03579,0.14372,0.074144,0.035125,0.144834,0.074144,0.034702,0.146096,0.074144,0.034553,0.147471,0.074144,0.034702,0.146096,0.074144,0.040177,0.198619,0.074144,0.034553,0.192619,0.074144,0.034553,0.147471,0.074144,0.038889,0.198461,0.074144,0.034702,0.193994,0.074144,0.035125,0.195257,0.074144,0.037705,0.198009,0.074144,0.03579,0.196371,0.074144,0.036661,0.1973,0.074144,0.162728,0.198009,0.074144,0.161545,0.198461,0.074144,0.160256,0.198619,0.074144,0.163773,0.1973,0.074144,0.164644,0.196371,0.074144,0.165308,0.195257,0.074144,0.165732,0.193994,0.074144,0.16588,0.192619,0.074144,0.16588,0.147471,0.074144,0.113827,0.198619,0.074144,0.165732,0.146096,0.074144,0.165308,0.144834,0.074144,0.164644,0.14372,0.074144,0.163773,0.14279,0.074144,0.162728,0.142082,0.074144,0.161545,0.14163,0.074144,0.160256,0.141471,0.074144,0.113827,0.141471,0.074144,0.112539,0.198461,0.074144,0.111355,0.198009,0.074144,0.110311,0.1973,0.074144,0.10944,0.196371,0.074144,0.108775,0.195257,0.074144,0.108352,0.193994,0.074144,0.113827,0.141471,0.074144,0.108352,0.193994,0.074144,0.108203,0.192619,0.074144,0.108203,0.192619,0.074144,0.108203,0.147471,0.074144,0.108352,0.146096,0.074144,0.112539,0.14163,0.074144,0.108775,0.144834,0.074144,0.111355,0.142082,0.074144,0.110311,0.14279,0.074144,0.10944,0.14372,0.074144,0.236378,0.198009,0.074144,0.235195,0.198461,0.074144,0.233906,0.198619,0.074144,0.237423,0.1973,0.074144,0.238294,0.196371,0.074144,0.238958,0.195257,0.074144,0.239382,0.193994,0.074144,0.23953,0.192619,0.074144,0.23953,0.147471,0.074144,0.187478,0.198619,0.074144,0.239382,0.146096,0.074144,0.238958,0.144834,0.074144,0.238294,0.14372,0.074144,0.237423,0.14279,0.074144,0.236378,0.142082,0.074144,0.235195,0.14163,0.074144,0.233906,0.141471,0.074144,0.187478,0.141471,0.074144,0.186189,0.14163,0.074144,0.185005,0.142082,0.074144,0.183961,0.14279,0.074144,0.18309,0.14372,0.074144,0.182426,0.144834,0.074144,0.182002,0.146097,0.074144,0.181853,0.147471,0.074144,0.182002,0.146097,0.074144,0.187478,0.198619,0.074144,0.181853,0.192619,0.074144,0.181853,0.147471,0.074144,0.182002,0.193994,0.074144,0.186189,0.198461,0.074144,0.185005,0.198009,0.074144,0.182426,0.195257,0.074144,0.18309,0.196371,0.074144,0.183961,0.1973,0.074144,0.310029,0.198009,0.074144,0.308845,0.198461,0.074144,0.307556,0.198619,0.074144,0.311073,0.1973,0.074144,0.311944,0.196371,0.074144,0.312609,0.195257,0.074144,0.313032,0.193994,0.074144,0.313181,0.192619,0.074144,0.313181,0.147471,0.074144,0.261128,0.198619,0.074144,0.313032,0.146096,0.074144,0.312608,0.144834,0.074144,0.311944,0.14372,0.074144,0.311073,0.14279,0.074144,0.310029,0.142082,0.074144,0.308845,0.14163,0.074144,0.307556,0.141471,0.074144,0.261128,0.141471,0.074144,0.259839,0.14163,0.074144,0.258656,0.142082,0.074144,0.257611,0.14279,0.074144,0.25674,0.14372,0.074144,0.256076,0.144834,0.074144,0.255652,0.146097,0.074144,0.255504,0.147471,0.074144,0.255652,0.146097,0.074144,0.261128,0.198619,0.074144,0.255504,0.192619,0.074144,0.255504,0.147471,0.074144,0.255652,0.193994,0.074144,0.259839,0.198461,0.074144,0.258656,0.198009,0.074144,0.256076,0.195257,0.074144,0.25674,0.196371,0.074144,0.257611,0.1973,0.074144,0.446193,0.196509,0.074144,0.44501,0.196961,0.074144,0.443721,0.197119,0.074144,0.447238,0.1958,0.074144,0.448109,0.194871,0.074144,0.448773,0.193757,0.074144,0.449197,0.192494,0.074144,0.449346,0.191119,0.074144,0.449346,0.148971,0.074144,0.338548,0.197119,0.074144,0.449197,0.147597,0.074144,0.448773,0.146334,0.074144,0.448109,0.14522,0.074144,0.447238,0.14429,0.074144,0.446193,0.143582,0.074144,0.44501,0.14313,0.074144,0.443721,0.142971,0.074144,0.338548,0.142971,0.074144,0.33726,0.14313,0.074144,0.336076,0.143582,0.074144,0.335032,0.14429,0.074144,0.334161,0.14522,0.074144,0.333496,0.146334,0.074144,0.333073,0.147596,0.074144,0.332924,0.148971,0.074144,0.333073,0.147596,0.074144,0.338548,0.197119,0.074144,0.332924,0.191119,0.074144,0.332924,0.148971,0.074144,0.333073,0.192494,0.074144,0.33726,0.196961,0.074144,0.336076,0.196509,0.074144,0.333496,0.193757,0.074144,0.335032,0.1958,0.074144,0.334161,0.194871,0.074144,-0.496522,0.122376,0.074144,-0.496945,0.121114,0.074144,-0.497094,0.119739,0.074144,-0.495857,0.12349,0.074144,-0.494986,0.12442,0.074144,-0.493942,0.125129,0.074144,-0.492758,0.12558,0.074144,-0.49147,0.125739,0.074144,-0.445041,0.125739,0.074144,-0.497094,0.074591,0.074144,-0.496945,0.073216,0.074144,-0.496522,0.071954,0.074144,-0.495857,0.07084,0.074144,-0.494986,0.06991,0.074144,-0.493942,0.069201,0.074144,-0.492758,0.06875,0.074144,-0.49147,0.068591,0.074144,-0.445041,0.068591,0.074144,-0.443752,0.06875,0.074144,-0.442569,0.069201,0.074144,-0.441525,0.06991,0.074144,-0.440653,0.07084,0.074144,-0.439989,0.071954,0.074144,-0.439566,0.073216,0.074144,-0.445041,0.125739,0.074144,-0.439566,0.073216,0.074144,-0.439417,0.074591,0.074144,-0.439417,0.074591,0.074144,-0.439417,0.119739,0.074144,-0.439566,0.121114,0.074144,-0.443752,0.12558,0.074144,-0.442569,0.125129,0.074144,-0.439989,0.122376,0.074144,-0.440653,0.12349,0.074144,-0.441525,0.12442,0.074144,-0.422872,0.122376,0.074144,-0.423295,0.121114,0.074144,-0.423444,0.119739,0.074144,-0.422207,0.12349,0.074144,-0.421336,0.12442,0.074144,-0.420292,0.125129,0.074144,-0.419108,0.12558,0.074144,-0.41782,0.125739,0.074144,-0.371391,0.125739,0.074144,-0.423444,0.074591,0.074144,-0.423295,0.073216,0.074144,-0.422872,0.071954,0.074144,-0.422207,0.07084,0.074144,-0.421336,0.06991,0.074144,-0.420292,0.069201,0.074144,-0.419108,0.06875,0.074144,-0.41782,0.068591,0.074144,-0.371391,0.068591,0.074144,-0.370102,0.12558,0.074144,-0.368919,0.125129,0.074144,-0.367874,0.12442,0.074144,-0.367003,0.12349,0.074144,-0.366339,0.122376,0.074144,-0.365915,0.121114,0.074144,-0.365767,0.119739,0.074144,-0.365915,0.121114,0.074144,-0.371391,0.068591,0.074144,-0.365767,0.074591,0.074144,-0.365767,0.119739,0.074144,-0.365915,0.073216,0.074144,-0.370102,0.06875,0.074144,-0.368919,0.069201,0.074144,-0.366339,0.071954,0.074144,-0.367003,0.07084,0.074144,-0.367874,0.06991,0.074144,-0.349221,0.122376,0.074144,-0.349645,0.121114,0.074144,-0.349794,0.119739,0.074144,-0.348557,0.12349,0.074144,-0.347686,0.12442,0.074144,-0.346642,0.125129,0.074144,-0.345458,0.12558,0.074144,-0.344169,0.125739,0.074144,-0.297741,0.125739,0.074144,-0.349794,0.074591,0.074144,-0.349645,0.073216,0.074144,-0.349221,0.071954,0.074144,-0.348557,0.07084,0.074144,-0.347686,0.06991,0.074144,-0.346642,0.069201,0.074144,-0.345458,0.06875,0.074144,-0.344169,0.068591,0.074144,-0.297741,0.068591,0.074144,-0.296452,0.12558,0.074144,-0.295269,0.125129,0.074144,-0.294224,0.12442,0.074144,-0.293353,0.12349,0.074144,-0.292689,0.122376,0.074144,-0.292265,0.121114,0.074144,-0.292117,0.119739,0.074144,-0.292265,0.121114,0.074144,-0.297741,0.068591,0.074144,-0.292117,0.074591,0.074144,-0.292117,0.119739,0.074144,-0.292265,0.073216,0.074144,-0.296452,0.06875,0.074144,-0.295269,0.069201,0.074144,-0.292689,0.071954,0.074144,-0.293353,0.07084,0.074144,-0.294224,0.06991,0.074144,-0.276143,0.074591,0.074144,-0.275995,0.073216,0.074144,-0.275571,0.071954,0.074144,-0.274907,0.07084,0.074144,-0.274036,0.06991,0.074144,-0.272991,0.069201,0.074144,-0.271808,0.06875,0.074144,-0.270519,0.068591,0.074144,-0.276143,0.119739,0.074144,-0.224091,0.068591,0.074144,-0.275995,0.121114,0.074144,-0.275571,0.122376,0.074144,-0.274907,0.12349,0.074144,-0.274036,0.12442,0.074144,-0.272991,0.125129,0.074144,-0.271808,0.12558,0.074144,-0.270519,0.125739,0.074144,-0.224091,0.125739,0.074144,-0.222802,0.06875,0.074144,-0.221618,0.069201,0.074144,-0.220574,0.06991,0.074144,-0.219703,0.07084,0.074144,-0.219039,0.071954,0.074144,-0.218615,0.073216,0.074144,-0.224091,0.125739,0.074144,-0.218615,0.073216,0.074144,-0.218466,0.074591,0.074144,-0.218466,0.074591,0.074144,-0.218466,0.119739,0.074144,-0.218615,0.121114,0.074144,-0.222802,0.12558,0.074144,-0.219039,0.122376,0.074144,-0.221618,0.125129,0.074144,-0.219703,0.12349,0.074144,-0.220574,0.12442,0.074144,-0.15044,0.068591,0.074144,-0.149152,0.06875,0.074144,-0.147968,0.069201,0.074144,-0.146924,0.06991,0.074144,-0.146053,0.07084,0.074144,-0.145388,0.071954,0.074144,-0.144965,0.073216,0.074144,-0.144816,0.074591,0.074144,-0.196869,0.068591,0.074144,-0.144816,0.119739,0.074144,-0.144965,0.121114,0.074144,-0.145388,0.122376,0.074144,-0.146053,0.12349,0.074144,-0.146924,0.12442,0.074144,-0.147968,0.125129,0.074144,-0.149152,0.12558,0.074144,-0.15044,0.125739,0.074144,-0.196869,0.125739,0.074144,-0.198158,0.06875,0.074144,-0.199341,0.069201,0.074144,-0.200386,0.06991,0.074144,-0.201257,0.07084,0.074144,-0.201921,0.071954,0.074144,-0.202345,0.073216,0.074144,-0.202493,0.074591,0.074144,-0.202345,0.073216,0.074144,-0.196869,0.125739,0.074144,-0.202493,0.119739,0.074144,-0.202493,0.074591,0.074144,-0.202345,0.121114,0.074144,-0.198158,0.12558,0.074144,-0.201921,0.122376,0.074144,-0.199341,0.125129,0.074144,-0.200386,0.12442,0.074144,-0.201257,0.12349,0.074144,-0.07679,0.068591,0.074144,-0.075502,0.06875,0.074144,-0.074318,0.069201,0.074144,-0.073274,0.06991,0.074144,-0.072403,0.07084,0.074144,-0.071738,0.071954,0.074144,-0.071315,0.073216,0.074144,-0.071166,0.074591,0.074144,-0.071166,0.119739,0.074144,-0.123219,0.068591,0.074144,-0.071315,0.121114,0.074144,-0.071738,0.122376,0.074144,-0.072403,0.12349,0.074144,-0.073274,0.12442,0.074144,-0.074318,0.125129,0.074144,-0.075502,0.12558,0.074144,-0.07679,0.125739,0.074144,-0.123219,0.125739,0.074144,-0.124508,0.06875,0.074144,-0.125691,0.069201,0.074144,-0.126735,0.06991,0.074144,-0.127607,0.07084,0.074144,-0.128271,0.071954,0.074144,-0.128694,0.073216,0.074144,-0.128843,0.074591,0.074144,-0.128694,0.073216,0.074144,-0.123219,0.125739,0.074144,-0.128843,0.119739,0.074144,-0.128843,0.074591,0.074144,-0.128694,0.121114,0.074144,-0.124508,0.12558,0.074144,-0.128271,0.122376,0.074144,-0.125691,0.125129,0.074144,-0.126735,0.12442,0.074144,-0.127607,0.12349,0.074144,-0.00314,0.068591,0.074144,-0.001851,0.06875,0.074144,-0.000668,0.069201,0.074144,0.000376,0.06991,0.074144,0.001248,0.07084,0.074144,0.001912,0.071954,0.074144,0.002335,0.073216,0.074144,0.002484,0.074591,0.074144,-0.049569,0.068591,0.074144,0.002484,0.119739,0.074144,0.002335,0.121114,0.074144,0.001912,0.122376,0.074144,0.001248,0.12349,0.074144,0.000376,0.12442,0.074144,-0.000668,0.125129,0.074144,-0.001851,0.12558,0.074144,-0.00314,0.125739,0.074144,-0.049569,0.125739,0.074144,-0.050858,0.06875,0.074144,-0.052041,0.069201,0.074144,-0.053085,0.06991,0.074144,-0.053957,0.07084,0.074144,-0.054621,0.071954,0.074144,-0.055044,0.073216,0.074144,-0.055193,0.074591,0.074144,-0.055044,0.073216,0.074144,-0.049569,0.125739,0.074144,-0.055193,0.119739,0.074144,-0.055193,0.074591,0.074144,-0.055044,0.121114,0.074144,-0.050858,0.12558,0.074144,-0.054621,0.122376,0.074144,-0.052041,0.125129,0.074144,-0.053085,0.12442,0.074144,-0.053957,0.12349,0.074144,0.07051,0.068591,0.074144,0.071799,0.06875,0.074144,0.072982,0.069201,0.074144,0.074026,0.06991,0.074144,0.074898,0.07084,0.074144,0.075562,0.071954,0.074144,0.075985,0.073216,0.074144,0.076134,0.074591,0.074144,0.024081,0.068591,0.074144,0.076134,0.119739,0.074144,0.075985,0.121114,0.074144,0.075562,0.122376,0.074144,0.074898,0.12349,0.074144,0.074026,0.12442,0.074144,0.072982,0.125129,0.074144,0.071799,0.12558,0.074144,0.07051,0.125739,0.074144,0.024081,0.125739,0.074144,0.022793,0.06875,0.074144,0.021609,0.069201,0.074144,0.020565,0.06991,0.074144,0.019694,0.07084,0.074144,0.019029,0.071954,0.074144,0.018606,0.073216,0.074144,0.018457,0.074591,0.074144,0.018606,0.073216,0.074144,0.024081,0.125739,0.074144,0.018457,0.119739,0.074144,0.018457,0.074591,0.074144,0.018606,0.121114,0.074144,0.022793,0.12558,0.074144,0.019029,0.122376,0.074144,0.021609,0.125129,0.074144,0.020565,0.12442,0.074144,0.019694,0.12349,0.074144,0.149784,0.119739,0.074144,0.149636,0.121114,0.074144,0.149212,0.122376,0.074144,0.148548,0.12349,0.074144,0.147677,0.12442,0.074144,0.146632,0.125129,0.074144,0.145449,0.12558,0.074144,0.14416,0.125739,0.074144,0.149784,0.074591,0.074144,0.097731,0.125739,0.074144,0.149636,0.073216,0.074144,0.149212,0.071954,0.074144,0.148548,0.07084,0.074144,0.147677,0.06991,0.074144,0.146632,0.069201,0.074144,0.145449,0.06875,0.074144,0.14416,0.068591,0.074144,0.097731,0.068591,0.074144,0.096443,0.06875,0.074144,0.095259,0.069201,0.074144,0.094215,0.06991,0.074144,0.093344,0.07084,0.074144,0.092679,0.071954,0.074144,0.092256,0.073216,0.074144,0.092107,0.074591,0.074144,0.092256,0.073216,0.074144,0.097731,0.125739,0.074144,0.092107,0.119739,0.074144,0.092107,0.074591,0.074144,0.092256,0.121114,0.074144,0.096443,0.12558,0.074144,0.095259,0.125129,0.074144,0.092679,0.122376,0.074144,0.094215,0.12442,0.074144,0.093344,0.12349,0.074144,0.223434,0.119739,0.074144,0.223286,0.121114,0.074144,0.222862,0.122376,0.074144,0.222198,0.12349,0.074144,0.221327,0.12442,0.074144,0.220282,0.125129,0.074144,0.219099,0.12558,0.074144,0.21781,0.125739,0.074144,0.223434,0.074591,0.074144,0.171382,0.125739,0.074144,0.223286,0.073216,0.074144,0.222862,0.071954,0.074144,0.222198,0.07084,0.074144,0.221327,0.06991,0.074144,0.220282,0.069201,0.074144,0.219099,0.06875,0.074144,0.21781,0.068591,0.074144,0.171382,0.068591,0.074144,0.170093,0.06875,0.074144,0.168909,0.069201,0.074144,0.167865,0.06991,0.074144,0.166994,0.07084,0.074144,0.16633,0.071954,0.074144,0.165906,0.073216,0.074144,0.165757,0.074591,0.074144,0.165906,0.073216,0.074144,0.171382,0.125739,0.074144,0.165757,0.119739,0.074144,0.165757,0.074591,0.074144,0.165906,0.121114,0.074144,0.170093,0.12558,0.074144,0.16633,0.122376,0.074144,0.168909,0.125129,0.074144,0.167865,0.12442,0.074144,0.166994,0.12349,0.074144,0.297085,0.119739,0.074144,0.296936,0.121114,0.074144,0.296512,0.122376,0.074144,0.295848,0.12349,0.074144,0.294977,0.12442,0.074144,0.293933,0.125129,0.074144,0.292749,0.12558,0.074144,0.29146,0.125739,0.074144,0.297085,0.074591,0.074144,0.245032,0.125739,0.074144,0.296936,0.073216,0.074144,0.296513,0.071954,0.074144,0.295848,0.07084,0.074144,0.294977,0.06991,0.074144,0.293933,0.069201,0.074144,0.292749,0.06875,0.074144,0.29146,0.068591,0.074144,0.245032,0.068591,0.074144,0.243743,0.06875,0.074144,0.24256,0.069201,0.074144,0.241515,0.06991,0.074144,0.240644,0.07084,0.074144,0.23998,0.071954,0.074144,0.239556,0.073216,0.074144,0.239408,0.074591,0.074144,0.239556,0.073216,0.074144,0.245032,0.125739,0.074144,0.239408,0.119739,0.074144,0.239408,0.074591,0.074144,0.239556,0.121114,0.074144,0.243743,0.12558,0.074144,0.24256,0.125129,0.074144,0.23998,0.122376,0.074144,0.241515,0.12442,0.074144,0.240644,0.12349,0.074144,0.448773,0.073454,0.074144,0.449197,0.074716,0.074144,0.449346,0.076091,0.074144,0.448109,0.07234,0.074144,0.447238,0.07141,0.074144,0.446194,0.070701,0.074144,0.44501,0.07025,0.074144,0.443721,0.070091,0.074144,0.316428,0.070091,0.074144,0.449346,0.118239,0.074144,0.449197,0.119614,0.074144,0.448774,0.120876,0.074144,0.448109,0.12199,0.074144,0.447238,0.12292,0.074144,0.446194,0.123629,0.074144,0.44501,0.12408,0.074144,0.443721,0.124239,0.074144,0.316428,0.124239,0.074144,0.31514,0.07025,0.074144,0.313956,0.070701,0.074144,0.312912,0.07141,0.074144,0.312041,0.07234,0.074144,0.311376,0.073454,0.074144,0.310953,0.074716,0.074144,0.310804,0.076091,0.074144,0.310953,0.074716,0.074144,0.316428,0.124239,0.074144,0.310804,0.118239,0.074144,0.310804,0.076091,0.074144,0.310953,0.119614,0.074144,0.31514,0.12408,0.074144,0.313956,0.123629,0.074144,0.311376,0.120876,0.074144,0.312912,0.12292,0.074144,0.312041,0.12199,0.074144,-0.627301,0.076091,0.074144,-0.627152,0.074716,0.074144,-0.626729,0.073454,0.074144,-0.626064,0.07234,0.074144,-0.625193,0.07141,0.074144,-0.624149,0.070701,0.074144,-0.622965,0.07025,0.074144,-0.621677,0.070091,0.074144,-0.627301,0.118239,0.074144,-0.516504,0.070091,0.074144,-0.627152,0.119614,0.074144,-0.626729,0.120876,0.074144,-0.626064,0.12199,0.074144,-0.625193,0.12292,0.074144,-0.624149,0.123629,0.074144,-0.622965,0.12408,0.074144,-0.621677,0.124239,0.074144,-0.516504,0.124239,0.074144,-0.515215,0.07025,0.074144,-0.514032,0.070701,0.074144,-0.512987,0.07141,0.074144,-0.512116,0.07234,0.074144,-0.511452,0.073454,0.074144,-0.511028,0.074716,0.074144,-0.516504,0.124239,0.074144,-0.511028,0.074716,0.074144,-0.51088,0.076091,0.074144,-0.51088,0.076091,0.074144,-0.51088,0.118239,0.074144,-0.511028,0.119614,0.074144,-0.515215,0.12408,0.074144,-0.514032,0.123629,0.074144,-0.511452,0.120876,0.074144,-0.512116,0.12199,0.074144,-0.512987,0.12292,0.074144,-0.44314,0.049838,0.074144,-0.443564,0.048575,0.074144,-0.443712,0.0472,0.074144,-0.442476,0.050952,0.074144,-0.441605,0.051881,0.074144,-0.44056,0.05259,0.074144,-0.439377,0.053042,0.074144,-0.438088,0.0532,0.074144,-0.391659,0.0532,0.074144,-0.443712,0.002052,0.074144,-0.443564,0.000678,0.074144,-0.391659,0.0532,0.074144,-0.443564,0.000678,0.074144,-0.44314,-0.000585,0.074144,-0.44314,-0.000585,0.074144,-0.442476,-0.001699,0.074144,-0.441605,-0.002629,0.074144,-0.44056,-0.003337,0.074144,-0.439377,-0.003789,0.074144,-0.438088,-0.003948,0.074144,-0.391659,-0.003948,0.074144,-0.390371,-0.003789,0.074144,-0.389187,-0.003337,0.074144,-0.388143,-0.002629,0.074144,-0.387272,-0.001699,0.074144,-0.386607,-0.000585,0.074144,-0.391659,0.0532,0.074144,-0.386607,-0.000585,0.074144,-0.386184,0.000678,0.074144,-0.386184,0.000678,0.074144,-0.386035,0.002052,0.074144,-0.386035,0.0472,0.074144,-0.386184,0.048575,0.074144,-0.390371,0.053042,0.074144,-0.386607,0.049838,0.074144,-0.389187,0.05259,0.074144,-0.388143,0.051881,0.074144,-0.387272,0.050952,0.074144,-0.36949,0.049838,0.074144,-0.369914,0.048575,0.074144,-0.370062,0.0472,0.074144,-0.368826,0.050952,0.074144,-0.367954,0.051881,0.074144,-0.36691,0.05259,0.074144,-0.365727,0.053042,0.074144,-0.364438,0.0532,0.074144,-0.318009,0.0532,0.074144,-0.370062,0.002052,0.074144,-0.369914,0.000678,0.074144,-0.318009,0.0532,0.074144,-0.369914,0.000678,0.074144,-0.36949,-0.000585,0.074144,-0.36949,-0.000585,0.074144,-0.368826,-0.001699,0.074144,-0.367954,-0.002629,0.074144,-0.36691,-0.003337,0.074144,-0.365727,-0.003789,0.074144,-0.364438,-0.003948,0.074144,-0.318009,-0.003948,0.074144,-0.316721,-0.003789,0.074144,-0.315537,-0.003337,0.074144,-0.314493,-0.002629,0.074144,-0.313622,-0.001699,0.074144,-0.312957,-0.000585,0.074144,-0.318009,0.0532,0.074144,-0.312957,-0.000585,0.074144,-0.312534,0.000678,0.074144,-0.312534,0.000678,0.074144,-0.312385,0.002052,0.074144,-0.312385,0.0472,0.074144,-0.312534,0.048575,0.074144,-0.316721,0.053042,0.074144,-0.312957,0.049838,0.074144,-0.315537,0.05259,0.074144,-0.313622,0.050952,0.074144,-0.314493,0.051881,0.074144,-0.29584,0.049838,0.074144,-0.296263,0.048575,0.074144,-0.296412,0.0472,0.074144,-0.295176,0.050952,0.074144,-0.294304,0.051881,0.074144,-0.29326,0.05259,0.074144,-0.292077,0.053042,0.074144,-0.290788,0.0532,0.074144,-0.244359,0.0532,0.074144,-0.296412,0.002052,0.074144,-0.296263,0.000678,0.074144,-0.244359,0.0532,0.074144,-0.296263,0.000678,0.074144,-0.29584,-0.000585,0.074144,-0.29584,-0.000585,0.074144,-0.295176,-0.001699,0.074144,-0.294304,-0.002629,0.074144,-0.29326,-0.003337,0.074144,-0.292077,-0.003789,0.074144,-0.290788,-0.003948,0.074144,-0.244359,-0.003948,0.074144,-0.243071,-0.003789,0.074144,-0.241887,-0.003337,0.074144,-0.240843,-0.002629,0.074144,-0.239971,-0.001699,0.074144,-0.239307,-0.000585,0.074144,-0.244359,0.0532,0.074144,-0.239307,-0.000585,0.074144,-0.238884,0.000678,0.074144,-0.238884,0.000678,0.074144,-0.238735,0.002052,0.074144,-0.238735,0.0472,0.074144,-0.238884,0.048575,0.074144,-0.243071,0.053042,0.074144,-0.239307,0.049838,0.074144,-0.241887,0.05259,0.074144,-0.240843,0.051881,0.074144,-0.239971,0.050952,0.074144,-0.22219,0.049838,0.074144,-0.222613,0.048575,0.074144,-0.222762,0.0472,0.074144,-0.221525,0.050952,0.074144,-0.220654,0.051881,0.074144,-0.21961,0.05259,0.074144,-0.218426,0.053042,0.074144,-0.217138,0.0532,0.074144,-0.170709,0.0532,0.074144,-0.222762,0.002052,0.074144,-0.222613,0.000678,0.074144,-0.170709,0.0532,0.074144,-0.222613,0.000678,0.074144,-0.22219,-0.000585,0.074144,-0.22219,-0.000585,0.074144,-0.221526,-0.001699,0.074144,-0.220654,-0.002629,0.074144,-0.21961,-0.003337,0.074144,-0.218426,-0.003789,0.074144,-0.217138,-0.003948,0.074144,-0.170709,-0.003948,0.074144,-0.16942,-0.003789,0.074144,-0.168237,-0.003337,0.074144,-0.167193,-0.002629,0.074144,-0.166321,-0.001699,0.074144,-0.165657,-0.000585,0.074144,-0.170709,0.0532,0.074144,-0.165657,-0.000585,0.074144,-0.165234,0.000678,0.074144,-0.165234,0.000678,0.074144,-0.165085,0.002052,0.074144,-0.165085,0.0472,0.074144,-0.16942,0.053042,0.074144,-0.165234,0.048575,0.074144,-0.165657,0.049838,0.074144,-0.168237,0.05259,0.074144,-0.167193,0.051881,0.074144,-0.166321,0.050952,0.074144,-0.14854,0.049838,0.074144,-0.148963,0.048575,0.074144,-0.149112,0.0472,0.074144,-0.147875,0.050952,0.074144,-0.147004,0.051881,0.074144,-0.14596,0.05259,0.074144,-0.144776,0.053042,0.074144,-0.143488,0.0532,0.074144,-0.097059,0.0532,0.074144,-0.149112,0.002052,0.074144,-0.148963,0.000678,0.074144,-0.097059,0.0532,0.074144,-0.148963,0.000678,0.074144,-0.14854,-0.000585,0.074144,-0.14854,-0.000585,0.074144,-0.147875,-0.001699,0.074144,-0.147004,-0.002629,0.074144,-0.14596,-0.003337,0.074144,-0.144776,-0.003789,0.074144,-0.143488,-0.003948,0.074144,-0.097059,-0.003948,0.074144,-0.09577,-0.003789,0.074144,-0.094587,-0.003337,0.074144,-0.093542,-0.002629,0.074144,-0.092671,-0.001699,0.074144,-0.092007,-0.000585,0.074144,-0.097059,0.0532,0.074144,-0.092007,-0.000585,0.074144,-0.091583,0.000678,0.074144,-0.091583,0.000678,0.074144,-0.091435,0.002052,0.074144,-0.091435,0.0472,0.074144,-0.091583,0.048575,0.074144,-0.09577,0.053042,0.074144,-0.094587,0.05259,0.074144,-0.092007,0.049838,0.074144,-0.092671,0.050952,0.074144,-0.093542,0.051881,0.074144,-0.020937,0.05259,0.074144,-0.02212,0.053042,0.074144,-0.023409,0.0532,0.074144,-0.019892,0.051881,0.074144,-0.019021,0.050952,0.074144,-0.018357,0.049838,0.074144,-0.017933,0.048575,0.074144,-0.017785,0.0472,0.074144,-0.017785,0.002052,0.074144,-0.069837,0.0532,0.074144,-0.017933,0.000678,0.074144,-0.018357,-0.000585,0.074144,-0.017933,0.000678,0.074144,-0.069837,0.0532,0.074144,-0.019021,-0.001699,0.074144,-0.018357,-0.000585,0.074144,-0.019892,-0.002629,0.074144,-0.020937,-0.003337,0.074144,-0.02212,-0.003789,0.074144,-0.023409,-0.003948,0.074144,-0.069837,-0.003948,0.074144,-0.071126,-0.003789,0.074144,-0.07231,-0.003337,0.074144,-0.073354,-0.002629,0.074144,-0.074225,-0.001699,0.074144,-0.07489,-0.000585,0.074144,-0.075313,0.000678,0.074144,-0.07489,-0.000585,0.074144,-0.069837,0.0532,0.074144,-0.075462,0.002052,0.074144,-0.075313,0.000678,0.074144,-0.075462,0.0472,0.074144,-0.071126,0.053042,0.074144,-0.075313,0.048575,0.074144,-0.07489,0.049838,0.074144,-0.07231,0.05259,0.074144,-0.073354,0.051881,0.074144,-0.074225,0.050952,0.074144,0.055293,-0.000585,0.074144,0.055717,0.000678,0.074144,0.055866,0.002052,0.074144,0.054629,-0.001699,0.074144,0.055293,-0.000585,0.074144,0.055866,0.002052,0.074144,0.053758,-0.002629,0.074144,0.054629,-0.001699,0.074144,0.055866,0.002052,0.074144,0.052714,-0.003337,0.074144,0.053758,-0.002629,0.074144,0.055866,0.002052,0.074144,0.05153,-0.003789,0.074144,0.052714,-0.003337,0.074144,0.055866,0.002052,0.074144,0.050241,-0.003948,0.074144,0.05153,-0.003789,0.074144,0.055866,0.002052,0.074144,0.003813,-0.003948,0.074144,0.003813,-0.003948,0.074144,0.055866,0.002052,0.074144,0.055866,0.0472,0.074144,0.055717,0.048575,0.074144,0.055293,0.049838,0.074144,0.054629,0.050952,0.074144,0.053758,0.051881,0.074144,0.052713,0.05259,0.074144,0.05153,0.053042,0.074144,0.050241,0.0532,0.074144,0.003813,0.0532,0.074144,0.002524,-0.003789,0.074144,0.001341,-0.003337,0.074144,0.000296,-0.002629,0.074144,-0.000575,-0.001699,0.074144,-0.001239,-0.000585,0.074144,-0.001663,0.000678,0.074144,-0.001239,-0.000585,0.074144,0.003813,0.0532,0.074144,-0.001812,0.002052,0.074144,-0.001663,0.000678,0.074144,-0.001812,0.0472,0.074144,0.002524,0.053042,0.074144,-0.001663,0.048575,0.074144,-0.001239,0.049838,0.074144,0.001341,0.05259,0.074144,0.000296,0.051881,0.074144,-0.000575,0.050952,0.074144,0.128944,-0.000585,0.074144,0.129367,0.000678,0.074144,0.129516,0.002052,0.074144,0.128279,-0.001699,0.074144,0.128944,-0.000585,0.074144,0.129516,0.002052,0.074144,0.127408,-0.002629,0.074144,0.128279,-0.001699,0.074144,0.129516,0.002052,0.074144,0.126364,-0.003337,0.074144,0.127408,-0.002629,0.074144,0.129516,0.002052,0.074144,0.12518,-0.003789,0.074144,0.126364,-0.003337,0.074144,0.129516,0.002052,0.074144,0.123892,-0.003948,0.074144,0.12518,-0.003789,0.074144,0.129516,0.002052,0.074144,0.077463,-0.003948,0.074144,0.077463,-0.003948,0.074144,0.129516,0.002052,0.074144,0.129516,0.0472,0.074144,0.129367,0.048575,0.074144,0.128944,0.049838,0.074144,0.128279,0.050952,0.074144,0.127408,0.051881,0.074144,0.126364,0.05259,0.074144,0.12518,0.053042,0.074144,0.123892,0.0532,0.074144,0.077463,0.0532,0.074144,0.076174,-0.003789,0.074144,0.074991,-0.003337,0.074144,0.073946,-0.002629,0.074144,0.073075,-0.001699,0.074144,0.072411,-0.000585,0.074144,0.071987,0.000678,0.074144,0.072411,-0.000585,0.074144,0.077463,0.0532,0.074144,0.071839,0.002052,0.074144,0.071987,0.000678,0.074144,0.071839,0.0472,0.074144,0.071987,0.048575,0.074144,0.076174,0.053042,0.074144,0.074991,0.05259,0.074144,0.072411,0.049838,0.074144,0.073075,0.050952,0.074144,0.073946,0.051881,0.074144,0.145489,0.002052,0.074144,0.145637,0.000678,0.074144,0.146061,-0.000585,0.074144,0.145489,0.002052,0.074144,0.146061,-0.000585,0.074144,0.146725,-0.001699,0.074144,0.145489,0.002052,0.074144,0.146725,-0.001699,0.074144,0.147597,-0.002629,0.074144,0.145489,0.002052,0.074144,0.147597,-0.002629,0.074144,0.148641,-0.003337,0.074144,0.145489,0.002052,0.074144,0.148641,-0.003337,0.074144,0.149824,-0.003789,0.074144,0.145489,0.002052,0.074144,0.149824,-0.003789,0.074144,0.151113,-0.003948,0.074144,0.197542,-0.003948,0.074144,0.145489,0.0472,0.074144,0.145489,0.002052,0.074144,0.197542,-0.003948,0.074144,0.145637,0.048575,0.074144,0.146061,0.049838,0.074144,0.146725,0.050952,0.074144,0.147596,0.051881,0.074144,0.148641,0.05259,0.074144,0.149824,0.053042,0.074144,0.151113,0.0532,0.074144,0.197542,0.0532,0.074144,0.19883,-0.003789,0.074144,0.200014,-0.003337,0.074144,0.201058,-0.002629,0.074144,0.201929,-0.001699,0.074144,0.202594,-0.000585,0.074144,0.197542,0.0532,0.074144,0.202594,-0.000585,0.074144,0.203017,0.000678,0.074144,0.203017,0.000678,0.074144,0.203166,0.002052,0.074144,0.203166,0.0472,0.074144,0.19883,0.053042,0.074144,0.203017,0.048575,0.074144,0.200014,0.05259,0.074144,0.202594,0.049838,0.074144,0.201929,0.050952,0.074144,0.201058,0.051881,0.074144,0.276244,-0.000585,0.074144,0.276667,0.000678,0.074144,0.276816,0.002052,0.074144,0.27558,-0.001699,0.074144,0.276244,-0.000585,0.074144,0.276816,0.002052,0.074144,0.274708,-0.002629,0.074144,0.27558,-0.001699,0.074144,0.276816,0.002052,0.074144,0.273664,-0.003337,0.074144,0.274708,-0.002629,0.074144,0.276816,0.002052,0.074144,0.27248,-0.003789,0.074144,0.273664,-0.003337,0.074144,0.276816,0.002052,0.074144,0.271192,-0.003948,0.074144,0.27248,-0.003789,0.074144,0.276816,0.002052,0.074144,0.224763,-0.003948,0.074144,0.224763,-0.003948,0.074144,0.276816,0.002052,0.074144,0.276816,0.0472,0.074144,0.276667,0.048575,0.074144,0.276244,0.049838,0.074144,0.27558,0.050952,0.074144,0.274708,0.051881,0.074144,0.273664,0.05259,0.074144,0.272481,0.053042,0.074144,0.271192,0.0532,0.074144,0.224763,0.0532,0.074144,0.223474,-0.003789,0.074144,0.222291,-0.003337,0.074144,0.221247,-0.002628,0.074144,0.220375,-0.001699,0.074144,0.219711,-0.000585,0.074144,0.219288,0.000678,0.074144,0.219711,-0.000585,0.074144,0.224763,0.0532,0.074144,0.219139,0.002052,0.074144,0.219288,0.000678,0.074144,0.219139,0.0472,0.074144,0.219288,0.048575,0.074144,0.223474,0.053042,0.074144,0.222291,0.05259,0.074144,0.219711,0.049838,0.074144,0.220375,0.050952,0.074144,0.221247,0.051881,0.074144,-0.627122,0.001978,0.074144,-0.626974,0.000603,0.074144,-0.62655,-0.00066,0.074144,-0.627122,0.001978,0.074144,-0.62655,-0.00066,0.074144,-0.625886,-0.001774,0.074144,-0.627122,0.001978,0.074144,-0.625886,-0.001774,0.074144,-0.625015,-0.002703,0.074144,-0.627122,0.001978,0.074144,-0.625015,-0.002703,0.074144,-0.62397,-0.003412,0.074144,-0.627122,0.001978,0.074144,-0.62397,-0.003412,0.074144,-0.622787,-0.003864,0.074144,-0.627122,0.001978,0.074144,-0.622787,-0.003864,0.074144,-0.621498,-0.004022,0.074144,-0.627122,0.047078,0.074144,-0.627122,0.001978,0.074144,-0.621498,-0.004022,0.074144,-0.627122,0.047078,0.074144,-0.621498,-0.004022,0.074144,-0.464448,-0.004022,0.074144,-0.626974,0.048453,0.074144,-0.62655,0.049715,0.074144,-0.625886,0.050829,0.074144,-0.625014,0.051759,0.074144,-0.62397,0.052467,0.074144,-0.622787,0.052919,0.074144,-0.621498,0.053078,0.074144,-0.464448,0.053078,0.074144,-0.463159,-0.003864,0.074144,-0.461976,-0.003412,0.074144,-0.460931,-0.002703,0.074144,-0.46006,-0.001774,0.074144,-0.459396,-0.00066,0.074144,-0.464448,0.053078,0.074144,-0.459396,-0.00066,0.074144,-0.458972,0.000603,0.074144,-0.458972,0.000603,0.074144,-0.458824,0.001978,0.074144,-0.458824,0.047078,0.074144,-0.458972,0.048453,0.074144,-0.463159,0.052919,0.074144,-0.461976,0.052467,0.074144,-0.459396,0.049715,0.074144,-0.460931,0.051759,0.074144,-0.46006,0.050829,0.074144,0.448949,0.047078,0.074144,0.4488,0.048453,0.074144,0.448377,0.049715,0.074144,0.447712,0.050829,0.074144,0.446841,0.051759,0.074144,0.445797,0.052467,0.074144,0.444613,0.052919,0.074144,0.443325,0.053078,0.074144,0.448949,0.001978,0.074144,0.294555,0.053078,0.074144,0.4488,0.000603,0.074144,0.448377,-0.00066,0.074144,0.4488,0.000603,0.074144,0.294555,0.053078,0.074144,0.447712,-0.001774,0.074144,0.448377,-0.00066,0.074144,0.446841,-0.002703,0.074144,0.445797,-0.003412,0.074144,0.444613,-0.003864,0.074144,0.443325,-0.004022,0.074144,0.294555,-0.004022,0.074144,0.293266,-0.003864,0.074144,0.292083,-0.003412,0.074144,0.291038,-0.002703,0.074144,0.290167,-0.001774,0.074144,0.289503,-0.00066,0.074144,0.289079,0.000603,0.074144,0.289503,-0.00066,0.074144,0.294555,0.053078,0.074144,0.288931,0.001978,0.074144,0.289079,0.000603,0.074144,0.288931,0.047078,0.074144,0.293266,0.052919,0.074144,0.289079,0.048453,0.074144,0.289503,0.049715,0.074144,0.292083,0.052467,0.074144,0.290167,0.050829,0.074144,0.291038,0.051759,0.074144,-0.388556,-0.022919,0.074144,-0.38898,-0.024181,0.074144,-0.389129,-0.025556,0.074144,-0.387892,-0.021804,0.074144,-0.387021,-0.020875,0.074144,-0.385977,-0.020166,0.074144,-0.384793,-0.019715,0.074144,-0.383504,-0.019556,0.074144,-0.337076,-0.019556,0.074144,-0.389129,-0.070704,0.074144,-0.38898,-0.072079,0.074144,-0.388557,-0.073341,0.074144,-0.387892,-0.074455,0.074144,-0.387021,-0.075385,0.074144,-0.385977,-0.076094,0.074144,-0.384793,-0.076545,0.074144,-0.383504,-0.076704,0.074144,-0.337076,-0.076704,0.074144,-0.335787,-0.076545,0.074144,-0.334604,-0.076094,0.074144,-0.333559,-0.075385,0.074144,-0.332688,-0.074455,0.074144,-0.332024,-0.073341,0.074144,-0.3316,-0.072079,0.074144,-0.331452,-0.070704,0.074144,-0.331452,-0.025556,0.074144,-0.335787,-0.019715,0.074144,-0.3316,-0.024181,0.074144,-0.332024,-0.022919,0.074144,-0.334604,-0.020166,0.074144,-0.332688,-0.021804,0.074144,-0.333559,-0.020875,0.074144,0.227273,-0.020166,0.074144,0.22609,-0.019714,0.074144,0.224801,-0.019556,0.074144,0.228318,-0.020875,0.074144,0.229189,-0.021804,0.074144,0.229853,-0.022919,0.074144,0.230277,-0.024181,0.074144,0.230425,-0.025556,0.074144,0.15775,-0.019556,0.074144,0.230425,-0.070704,0.074144,0.230277,-0.072079,0.074144,0.229853,-0.073341,0.074144,0.229189,-0.074455,0.074144,0.228318,-0.075385,0.074144,0.227273,-0.076093,0.074144,0.22609,-0.076545,0.074144,0.224801,-0.076704,0.074144,0.15775,-0.076704,0.074144,0.156462,-0.019714,0.074144,0.155278,-0.020166,0.074144,0.154234,-0.020875,0.074144,0.153363,-0.021804,0.074144,0.152698,-0.022919,0.074144,0.152275,-0.024181,0.074144,0.152126,-0.025556,0.074144,0.152126,-0.070704,0.074144,0.152275,-0.072079,0.074144,0.156462,-0.076545,0.074144,0.155278,-0.076093,0.074144,0.152698,-0.073341,0.074144,0.154234,-0.075385,0.074144,0.153363,-0.074455,0.074144,0.300569,-0.073341,0.074144,0.300993,-0.072079,0.074144,0.301141,-0.070704,0.074144,0.299905,-0.074455,0.074144,0.299034,-0.075385,0.074144,0.297989,-0.076093,0.074144,0.296806,-0.076545,0.074144,0.295517,-0.076704,0.074144,0.249088,-0.076704,0.074144,0.301141,-0.025556,0.074144,0.300993,-0.024181,0.074144,0.300569,-0.022919,0.074144,0.299905,-0.021804,0.074144,0.299034,-0.020875,0.074144,0.297989,-0.020166,0.074144,0.296806,-0.019714,0.074144,0.295517,-0.019556,0.074144,0.249088,-0.019556,0.074144,0.2478,-0.019714,0.074144,0.246616,-0.020166,0.074144,0.245572,-0.020875,0.074144,0.244701,-0.021804,0.074144,0.244036,-0.022919,0.074144,0.243613,-0.024181,0.074144,0.243464,-0.025556,0.074144,0.243464,-0.070704,0.074144,0.243613,-0.072079,0.074144,0.2478,-0.076545,0.074144,0.244036,-0.073341,0.074144,0.246616,-0.076093,0.074144,0.244701,-0.074455,0.074144,0.245572,-0.075385,0.074144,0.374219,-0.073341,0.074144,0.374643,-0.072079,0.074144,0.374791,-0.070704,0.074144,0.373555,-0.074455,0.074144,0.372684,-0.075385,0.074144,0.371639,-0.076093,0.074144,0.370456,-0.076545,0.074144,0.369167,-0.076704,0.074144,0.322739,-0.076704,0.074144,0.374791,-0.025556,0.074144,0.374643,-0.024181,0.074144,0.374219,-0.022919,0.074144,0.373555,-0.021804,0.074144,0.372684,-0.020875,0.074144,0.371639,-0.020166,0.074144,0.370456,-0.019714,0.074144,0.369167,-0.019556,0.074144,0.322739,-0.019556,0.074144,0.32145,-0.019714,0.074144,0.320266,-0.020166,0.074144,0.319222,-0.020875,0.074144,0.318351,-0.021804,0.074144,0.317686,-0.022919,0.074144,0.317263,-0.024181,0.074144,0.317114,-0.025556,0.074144,0.317114,-0.070704,0.074144,0.317263,-0.072079,0.074144,0.32145,-0.076545,0.074144,0.317686,-0.073341,0.074144,0.320266,-0.076093,0.074144,0.319222,-0.075385,0.074144,0.318351,-0.074455,0.074144,0.447869,-0.073341,0.074144,0.448293,-0.072079,0.074144,0.448442,-0.070704,0.074144,0.447205,-0.074455,0.074144,0.446334,-0.075385,0.074144,0.44529,-0.076093,0.074144,0.444106,-0.076545,0.074144,0.442817,-0.076704,0.074144,0.396389,-0.076704,0.074144,0.448442,-0.025556,0.074144,0.448293,-0.024181,0.074144,0.447869,-0.022918,0.074144,0.447205,-0.021804,0.074144,0.446334,-0.020875,0.074144,0.44529,-0.020166,0.074144,0.444106,-0.019714,0.074144,0.442817,-0.019556,0.074144,0.396389,-0.019556,0.074144,0.3951,-0.019714,0.074144,0.393917,-0.020166,0.074144,0.392872,-0.020875,0.074144,0.392001,-0.021804,0.074144,0.391337,-0.022919,0.074144,0.390913,-0.024181,0.074144,0.390765,-0.025556,0.074144,0.390765,-0.070704,0.074144,0.390913,-0.072079,0.074144,0.3951,-0.076545,0.074144,0.391337,-0.073341,0.074144,0.393917,-0.076093,0.074144,0.392872,-0.075385,0.074144,0.392001,-0.074455,0.074144,-0.320047,-0.070704,0.074144,-0.319898,-0.072079,0.074144,-0.319475,-0.073341,0.074144,-0.31881,-0.074455,0.074144,-0.317939,-0.075385,0.074144,-0.316895,-0.076094,0.074144,-0.315711,-0.076545,0.074144,-0.314422,-0.076704,0.074144,-0.247372,-0.076704,0.074144,-0.320047,-0.025556,0.074144,-0.319898,-0.024181,0.074144,-0.319475,-0.022919,0.074144,-0.31881,-0.021804,0.074144,-0.317939,-0.020875,0.074144,-0.316895,-0.020166,0.074144,-0.315711,-0.019715,0.074144,-0.314423,-0.019556,0.074144,-0.247372,-0.019556,0.074144,-0.246083,-0.076545,0.074144,-0.2449,-0.076094,0.074144,-0.243855,-0.075385,0.074144,-0.242984,-0.074455,0.074144,-0.24232,-0.073341,0.074144,-0.241896,-0.072079,0.074144,-0.241748,-0.070704,0.074144,-0.241748,-0.025556,0.074144,-0.246083,-0.019715,0.074144,-0.241896,-0.024181,0.074144,-0.24232,-0.022919,0.074144,-0.2449,-0.020166,0.074144,-0.243855,-0.020875,0.074144,-0.242984,-0.021804,0.074144,-0.465611,-0.075662,0.074144,-0.464427,-0.076114,0.074144,-0.463138,-0.076273,0.074144,-0.466655,-0.074954,0.074144,-0.467526,-0.074024,0.074144,-0.46819,-0.07291,0.074144,-0.468614,-0.071647,0.074144,-0.468763,-0.070273,0.074144,-0.41671,-0.076273,0.074144,-0.468763,-0.053125,0.074144,-0.468614,-0.05175,0.074144,-0.46819,-0.050487,0.074144,-0.467526,-0.049373,0.074144,-0.466655,-0.048444,0.074144,-0.465611,-0.047735,0.074144,-0.464427,-0.047283,0.074144,-0.463138,-0.047125,0.074144,-0.41671,-0.047125,0.074144,-0.415421,-0.047283,0.074144,-0.414237,-0.047735,0.074144,-0.413193,-0.048444,0.074144,-0.412322,-0.049373,0.074144,-0.411658,-0.050487,0.074144,-0.411234,-0.05175,0.074144,-0.411085,-0.053125,0.074144,-0.411085,-0.070273,0.074144,-0.411234,-0.071647,0.074144,-0.415421,-0.076114,0.074144,-0.414238,-0.075662,0.074144,-0.411658,-0.07291,0.074144,-0.412322,-0.074024,0.074144,-0.413193,-0.074954,0.074144,-0.540671,-0.050487,0.074144,-0.541095,-0.05175,0.074144,-0.541243,-0.053125,0.074144,-0.540007,-0.049373,0.074144,-0.539136,-0.048444,0.074144,-0.538091,-0.047735,0.074144,-0.536908,-0.047283,0.074144,-0.535619,-0.047125,0.074144,-0.489191,-0.047125,0.074144,-0.541243,-0.070273,0.074144,-0.541095,-0.071647,0.074144,-0.540671,-0.07291,0.074144,-0.540007,-0.074024,0.074144,-0.539136,-0.074954,0.074144,-0.538091,-0.075662,0.074144,-0.536908,-0.076114,0.074144,-0.535619,-0.076273,0.074144,-0.489191,-0.076273,0.074144,-0.487902,-0.047283,0.074144,-0.486718,-0.047735,0.074144,-0.485674,-0.048444,0.074144,-0.484803,-0.049373,0.074144,-0.484139,-0.050487,0.074144,-0.483715,-0.05175,0.074144,-0.483566,-0.053125,0.074144,-0.483566,-0.070273,0.074144,-0.483715,-0.071647,0.074144,-0.487902,-0.076114,0.074144,-0.486718,-0.075662,0.074144,-0.484139,-0.07291,0.074144,-0.485674,-0.074954,0.074144,-0.484803,-0.074024,0.074144,-0.556047,-0.053125,0.074144,-0.556196,-0.05175,0.074144,-0.55662,-0.050487,0.074144,-0.557284,-0.049373,0.074144,-0.558155,-0.048444,0.074144,-0.559199,-0.047735,0.074144,-0.560383,-0.047283,0.074144,-0.561671,-0.047125,0.074144,-0.6081,-0.047125,0.074144,-0.556047,-0.070273,0.074144,-0.556196,-0.071647,0.074144,-0.556619,-0.07291,0.074144,-0.557284,-0.074024,0.074144,-0.558155,-0.074954,0.074144,-0.559199,-0.075662,0.074144,-0.560383,-0.076114,0.074144,-0.561671,-0.076273,0.074144,-0.6081,-0.076273,0.074144,-0.609389,-0.047283,0.074144,-0.610572,-0.047735,0.074144,-0.611617,-0.048444,0.074144,-0.612488,-0.049373,0.074144,-0.613152,-0.050487,0.074144,-0.613576,-0.05175,0.074144,-0.613724,-0.053125,0.074144,-0.613724,-0.070273,0.074144,-0.609389,-0.076114,0.074144,-0.613576,-0.071647,0.074144,-0.610572,-0.075662,0.074144,-0.613152,-0.07291,0.074144,-0.612488,-0.074024,0.074144,-0.611617,-0.074954,0.074144,-0.540671,-0.020796,0.074144,-0.541095,-0.022058,0.074144,-0.541243,-0.023433,0.074144,-0.540007,-0.019681,0.074144,-0.539136,-0.018752,0.074144,-0.538091,-0.018043,0.074144,-0.536908,-0.017592,0.074144,-0.535619,-0.017433,0.074144,-0.489191,-0.017433,0.074144,-0.541243,-0.040581,0.074144,-0.541095,-0.041956,0.074144,-0.540671,-0.043218,0.074144,-0.540007,-0.044332,0.074144,-0.539136,-0.045262,0.074144,-0.538091,-0.045971,0.074144,-0.536908,-0.046422,0.074144,-0.535619,-0.046581,0.074144,-0.489191,-0.046581,0.074144,-0.487902,-0.046422,0.074144,-0.486718,-0.045971,0.074144,-0.485674,-0.045262,0.074144,-0.484803,-0.044332,0.074144,-0.484139,-0.043218,0.074144,-0.483715,-0.041956,0.074144,-0.483566,-0.040581,0.074144,-0.483566,-0.023433,0.074144,-0.483715,-0.022058,0.074144,-0.487902,-0.017592,0.074144,-0.486718,-0.018043,0.074144,-0.484139,-0.020796,0.074144,-0.485674,-0.018752,0.074144,-0.484803,-0.019681,0.074144,0.397016,0.404358,0.067761,0.397016,0.438994,0.067761,-0.396985,0.438994,0.067761,-0.396985,0.404358,0.067761,0.397016,0.438994,0.067761,0.397016,0.438994,0.02493,-0.396985,0.438994,0.02493,-0.396985,0.438994,0.067761,0.397016,0.438994,0.02493,0.397016,0.438531,0.021002,-0.396984,0.438531,0.021002,-0.396985,0.438994,0.02493,0.397016,0.438531,0.021002,0.397016,0.437216,0.017394,-0.396985,0.437216,0.017394,-0.396984,0.438531,0.021002,0.397016,0.437216,0.017394,0.397016,0.435157,0.014211,-0.396984,0.435157,0.014211,0.397016,0.437216,0.017394,-0.396984,0.435157,0.014211,-0.396985,0.437216,0.017394,0.397016,0.435157,0.014211,0.397016,0.432465,0.011555,-0.396984,0.432464,0.011555,0.397016,0.435157,0.014211,-0.396984,0.432464,0.011555,-0.396984,0.435157,0.014211,0.397016,0.432465,0.011555,0.397016,0.429247,0.00953,-0.396984,0.429247,0.00953,0.397016,0.432465,0.011555,-0.396984,0.429247,0.00953,-0.396984,0.432464,0.011555,0.397016,0.429247,0.00953,0.397016,0.425613,0.008239,-0.396985,0.425613,0.008239,-0.396984,0.429247,0.00953,0.397016,0.425613,0.008239,0.397016,0.421673,0.007786,-0.396985,0.421673,0.007786,-0.396985,0.425613,0.008239,0.397016,0.421673,0.007786,0.397016,0.417734,0.008239,-0.396985,0.417734,0.008239,-0.396985,0.421673,0.007786,0.397016,0.417734,0.008239,0.397016,0.414102,0.00953,-0.396984,0.414102,0.00953,-0.396985,0.417734,0.008239,0.397016,0.414102,0.00953,0.397016,0.410885,0.011555,-0.396984,0.410885,0.011555,-0.396984,0.414102,0.00953,0.397016,0.410885,0.011555,0.397016,0.408193,0.014211,-0.396984,0.408193,0.014211,0.397016,0.410885,0.011555,-0.396984,0.408193,0.014211,-0.396984,0.410885,0.011555,0.397016,0.408193,0.014211,0.397016,0.406135,0.017394,-0.396985,0.406135,0.017394,0.397016,0.408193,0.014211,-0.396985,0.406135,0.017394,-0.396984,0.408193,0.014211,0.397016,0.406135,0.017394,0.397016,0.404821,0.021002,-0.396984,0.404821,0.021002,-0.396985,0.406135,0.017394,0.397016,0.404821,0.021002,0.397016,0.404358,0.02493,-0.396985,0.404358,0.02493,-0.396984,0.404821,0.021002,0.397016,0.404358,0.02493,0.397016,0.404358,0.067761,-0.396985,0.404358,0.067761,-0.396985,0.404358,0.02493,0.397016,0.404358,0.067761,0.397016,0.438994,0.02493,0.397016,0.438994,0.067761,0.397016,0.404358,0.02493,0.397016,0.404358,0.02493,0.397016,0.438531,0.021002,0.397016,0.438994,0.02493,0.397016,0.437216,0.017394,0.397016,0.435157,0.014211,0.397016,0.432465,0.011555,0.397016,0.429247,0.00953,0.397016,0.425613,0.008239,0.397016,0.421673,0.007786,0.397016,0.417734,0.008239,0.397016,0.414102,0.00953,0.397016,0.410885,0.011555,0.397016,0.404821,0.021002,0.397016,0.406135,0.017394,0.397016,0.408193,0.014211,-0.396985,0.404358,0.067761,-0.396985,0.438994,0.067761,-0.396985,0.438994,0.02493,-0.396985,0.404358,0.02493,-0.396985,0.404358,0.02493,-0.396985,0.438994,0.02493,-0.396984,0.438531,0.021002,-0.396985,0.404358,0.02493,-0.396984,0.438531,0.021002,-0.396985,0.437216,0.017394,-0.396985,0.404358,0.02493,-0.396985,0.437216,0.017394,-0.396984,0.435157,0.014211,-0.396985,0.404358,0.02493,-0.396984,0.435157,0.014211,-0.396984,0.432464,0.011555,-0.396985,0.404358,0.02493,-0.396984,0.432464,0.011555,-0.396984,0.429247,0.00953,-0.396985,0.404358,0.02493,-0.396984,0.429247,0.00953,-0.396985,0.425613,0.008239,-0.396985,0.425613,0.008239,-0.396985,0.421673,0.007786,-0.396985,0.417734,0.008239,-0.396985,0.404358,0.02493,-0.396985,0.417734,0.008239,-0.396984,0.414102,0.00953,-0.396985,0.404358,0.02493,-0.396984,0.414102,0.00953,-0.396984,0.410885,0.011555,-0.396984,0.404821,0.021002,-0.396985,0.404358,0.02493,-0.396984,0.410885,0.011555,-0.396985,0.406135,0.017394,-0.396984,0.404821,0.021002,-0.396984,0.410885,0.011555,-0.396984,0.408193,0.014211,-0.396985,0.406135,0.017394,-0.396984,0.410885,0.011555,0.605595,0.693562,0.83922,0.605595,0.478225,0.03557,-0.612405,0.478225,0.03557,-0.612405,0.693562,0.83922,0.605595,0.693562,0.83922,0.605595,0.694544,0.848555,0.60846,0.694426,0.848116,0.605595,0.693562,0.83922,0.60846,0.694426,0.848116,0.611044,0.694085,0.846844,0.605595,0.693562,0.83922,0.611044,0.694085,0.846844,0.613095,0.693554,0.844863,0.605595,0.693562,0.83922,0.613095,0.693554,0.844863,0.614412,0.692886,0.842367,0.605595,0.693562,0.83922,0.614412,0.692886,0.842367,0.614866,0.692144,0.8396,0.605595,0.693562,0.83922,0.614866,0.692144,0.8396,0.614866,0.476806,0.03595,0.614866,0.476806,0.03595,0.605595,0.478225,0.03557,0.605595,0.693562,0.83922,0.605595,0.478225,0.03557,0.614866,0.476806,0.03595,0.614412,0.476065,0.033183,0.605595,0.478225,0.03557,0.614412,0.476065,0.033183,0.613095,0.475396,0.030686,0.605595,0.478225,0.03557,0.613095,0.475396,0.030686,0.611044,0.474865,0.028705,0.605595,0.478225,0.03557,0.611044,0.474865,0.028705,0.60846,0.474525,0.027433,0.605595,0.478225,0.03557,0.60846,0.474525,0.027433,0.605595,0.474407,0.026995,0.605595,0.478225,0.03557,0.605595,0.474407,0.026995,-0.612405,0.474407,0.026995,-0.612405,0.474407,0.026995,-0.612405,0.478225,0.03557,0.605595,0.478225,0.03557,-0.612405,0.478225,0.03557,-0.612405,0.474407,0.026995,-0.615269,0.474524,0.027433,-0.612405,0.478225,0.03557,-0.615269,0.474524,0.027433,-0.617854,0.474865,0.028705,-0.612405,0.478225,0.03557,-0.617854,0.474865,0.028705,-0.619905,0.475396,0.030686,-0.612405,0.478225,0.03557,-0.619905,0.475396,0.030686,-0.621221,0.476065,0.033183,-0.612405,0.478225,0.03557,-0.621221,0.476065,0.033183,-0.621675,0.476806,0.03595,-0.612405,0.478225,0.03557,-0.621675,0.476806,0.03595,-0.621675,0.692144,0.8396,-0.621675,0.692144,0.8396,-0.612405,0.693562,0.83922,-0.612405,0.478225,0.03557,-0.612405,0.693562,0.83922,-0.621675,0.692144,0.8396,-0.621221,0.692885,0.842367,-0.612405,0.693562,0.83922,-0.621221,0.692885,0.842367,-0.619905,0.693554,0.844863,-0.612405,0.693562,0.83922,-0.619905,0.693554,0.844863,-0.617854,0.694085,0.846844,-0.612405,0.693562,0.83922,-0.617854,0.694085,0.846844,-0.615269,0.694426,0.848116,-0.612405,0.693562,0.83922,-0.615269,0.694426,0.848116,-0.612405,0.694543,0.848555,-0.612405,0.693562,0.83922,-0.612405,0.694543,0.848555,0.605595,0.694544,0.848555,0.605595,0.693562,0.83922,-0.612405,0.693562,0.83922,0.605595,0.694544,0.848555,0.611044,0.692369,0.856902,0.60846,0.694426,0.848116,0.605595,0.694544,0.848555,0.605595,0.694544,0.848555,0.605595,0.692592,0.857735,0.611044,0.692369,0.856902,0.61596,0.69172,0.854483,0.611044,0.694085,0.846844,0.60846,0.694426,0.848116,0.60846,0.694426,0.848116,0.611044,0.692369,0.856902,0.61596,0.69172,0.854483,0.613095,0.693554,0.844863,0.611044,0.694085,0.846844,0.61596,0.69172,0.854483,0.61596,0.69172,0.854483,0.619861,0.690711,0.850714,0.613095,0.693554,0.844863,0.622366,0.689438,0.845966,0.614412,0.692886,0.842367,0.613095,0.693554,0.844863,0.613095,0.693554,0.844863,0.619861,0.690711,0.850714,0.622366,0.689438,0.845966,0.623229,0.688028,0.840703,0.614866,0.692144,0.8396,0.614412,0.692886,0.842367,0.614412,0.692886,0.842367,0.622366,0.689438,0.845966,0.623229,0.688028,0.840703,0.614866,0.692144,0.8396,0.623229,0.688028,0.840703,0.623229,0.47269,0.037053,0.623229,0.47269,0.037053,0.614866,0.476806,0.03595,0.614866,0.692144,0.8396,0.622366,0.47128,0.031789,0.614412,0.476065,0.033183,0.614866,0.476806,0.03595,0.614866,0.476806,0.03595,0.623229,0.47269,0.037053,0.622366,0.47128,0.031789,0.619861,0.470008,0.027041,0.613095,0.475396,0.030686,0.614412,0.476065,0.033183,0.614412,0.476065,0.033183,0.622366,0.47128,0.031789,0.619861,0.470008,0.027041,0.611044,0.474865,0.028705,0.613095,0.475396,0.030686,0.619861,0.470008,0.027041,0.619861,0.470008,0.027041,0.61596,0.468998,0.023273,0.611044,0.474865,0.028705,0.611044,0.46835,0.020854,0.60846,0.474525,0.027433,0.611044,0.474865,0.028705,0.611044,0.474865,0.028705,0.61596,0.468998,0.023273,0.611044,0.46835,0.020854,0.605595,0.468127,0.02002,0.605595,0.474407,0.026995,0.60846,0.474525,0.027433,0.60846,0.474525,0.027433,0.611044,0.46835,0.020854,0.605595,0.468127,0.02002,0.605595,0.474407,0.026995,0.605595,0.468127,0.02002,-0.612405,0.468126,0.02002,-0.612405,0.468126,0.02002,-0.612405,0.474407,0.026995,0.605595,0.474407,0.026995,-0.617854,0.46835,0.020854,-0.615269,0.474524,0.027433,-0.612405,0.474407,0.026995,-0.612405,0.474407,0.026995,-0.612405,0.468126,0.02002,-0.617854,0.46835,0.020854,-0.622769,0.468998,0.023273,-0.617854,0.474865,0.028705,-0.615269,0.474524,0.027433,-0.615269,0.474524,0.027433,-0.617854,0.46835,0.020854,-0.622769,0.468998,0.023273,-0.619905,0.475396,0.030686,-0.617854,0.474865,0.028705,-0.622769,0.468998,0.023273,-0.622769,0.468998,0.023273,-0.62667,0.470008,0.027041,-0.619905,0.475396,0.030686,-0.629175,0.47128,0.031789,-0.621221,0.476065,0.033183,-0.619905,0.475396,0.030686,-0.619905,0.475396,0.030686,-0.62667,0.470008,0.027041,-0.629175,0.47128,0.031789,-0.630038,0.47269,0.037053,-0.621675,0.476806,0.03595,-0.621221,0.476065,0.033183,-0.621221,0.476065,0.033183,-0.629175,0.47128,0.031789,-0.630038,0.47269,0.037053,-0.621675,0.476806,0.03595,-0.630038,0.47269,0.037053,-0.630038,0.688028,0.840703,-0.621675,0.692144,0.8396,-0.621675,0.476806,0.03595,-0.629175,0.689438,0.845966,-0.621221,0.692885,0.842367,-0.621675,0.692144,0.8396,-0.621675,0.692144,0.8396,-0.630038,0.688028,0.840703,-0.629175,0.689438,0.845966,-0.626671,0.690711,0.850714,-0.619905,0.693554,0.844863,-0.621221,0.692885,0.842367,-0.621221,0.692885,0.842367,-0.629175,0.689438,0.845966,-0.626671,0.690711,0.850714,-0.617854,0.694085,0.846844,-0.619905,0.693554,0.844863,-0.626671,0.690711,0.850714,-0.626671,0.690711,0.850714,-0.622769,0.69172,0.854483,-0.617854,0.694085,0.846844,-0.617854,0.692368,0.856902,-0.615269,0.694426,0.848116,-0.617854,0.694085,0.846844,-0.617854,0.694085,0.846844,-0.622769,0.69172,0.854483,-0.617854,0.692368,0.856902,-0.612405,0.692592,0.857736,-0.612405,0.694543,0.848555,-0.615269,0.694426,0.848116,-0.615269,0.694426,0.848116,-0.617854,0.692368,0.856902,-0.612405,0.692592,0.857736,-0.612405,0.694543,0.848555,-0.612405,0.692592,0.857736,0.605595,0.692592,0.857735,0.605595,0.692592,0.857735,0.605595,0.694544,0.848555,-0.612405,0.694543,0.848555,0.613095,0.687592,0.864717,0.611044,0.692369,0.856902,0.605595,0.692592,0.857735,0.605595,0.687899,0.865864,0.619861,0.686699,0.861387,0.61596,0.69172,0.854483,0.611044,0.692369,0.856902,0.611044,0.692369,0.856902,0.613095,0.687592,0.864717,0.619861,0.686699,0.861387,0.619861,0.690711,0.850714,0.61596,0.69172,0.854483,0.619861,0.686699,0.861387,0.619861,0.686699,0.861387,0.625231,0.68531,0.8562,0.619861,0.690711,0.850714,0.628678,0.683559,0.849665,0.622366,0.689438,0.845966,0.619861,0.690711,0.850714,0.619861,0.690711,0.850714,0.625231,0.68531,0.8562,0.628678,0.683559,0.849665,0.629866,0.681617,0.842421,0.623229,0.688028,0.840703,0.622366,0.689438,0.845966,0.622366,0.689438,0.845966,0.628678,0.683559,0.849665,0.629866,0.681617,0.842421,0.623229,0.688028,0.840703,0.629866,0.681617,0.842421,0.629866,0.46628,0.03877,0.629866,0.46628,0.03877,0.623229,0.47269,0.037053,0.623229,0.688028,0.840703,0.628678,0.464339,0.031526,0.622366,0.47128,0.031789,0.623229,0.47269,0.037053,0.623229,0.47269,0.037053,0.629866,0.46628,0.03877,0.628678,0.464339,0.031526,0.625231,0.462587,0.024991,0.619861,0.470008,0.027041,0.622366,0.47128,0.031789,0.622366,0.47128,0.031789,0.628678,0.464339,0.031526,0.625231,0.462587,0.024991,0.61596,0.468998,0.023273,0.619861,0.470008,0.027041,0.625231,0.462587,0.024991,0.625231,0.462587,0.024991,0.619861,0.461198,0.019804,0.61596,0.468998,0.023273,0.613095,0.460305,0.016474,0.611044,0.46835,0.020854,0.61596,0.468998,0.023273,0.61596,0.468998,0.023273,0.619861,0.461198,0.019804,0.613095,0.460305,0.016474,0.605595,0.459998,0.015327,0.605595,0.468127,0.02002,0.611044,0.46835,0.020854,0.611044,0.46835,0.020854,0.613095,0.460305,0.016474,0.605595,0.459998,0.015327,0.605595,0.468127,0.02002,0.605595,0.459998,0.015327,-0.612405,0.459998,0.015327,-0.612405,0.459998,0.015327,-0.612405,0.468126,0.02002,0.605595,0.468127,0.02002,-0.619905,0.460305,0.016474,-0.617854,0.46835,0.020854,-0.612405,0.468126,0.02002,-0.612405,0.468126,0.02002,-0.612405,0.459998,0.015327,-0.619905,0.460305,0.016474,-0.62667,0.461198,0.019804,-0.622769,0.468998,0.023273,-0.617854,0.46835,0.020854,-0.617854,0.46835,0.020854,-0.619905,0.460305,0.016474,-0.62667,0.461198,0.019804,-0.62667,0.470008,0.027041,-0.622769,0.468998,0.023273,-0.62667,0.461198,0.019804,-0.62667,0.461198,0.019804,-0.63204,0.462587,0.024991,-0.62667,0.470008,0.027041,-0.635487,0.464338,0.031526,-0.629175,0.47128,0.031789,-0.62667,0.470008,0.027041,-0.62667,0.470008,0.027041,-0.63204,0.462587,0.024991,-0.635487,0.464338,0.031526,-0.636675,0.46628,0.03877,-0.630038,0.47269,0.037053,-0.629175,0.47128,0.031789,-0.629175,0.47128,0.031789,-0.635487,0.464338,0.031526,-0.636675,0.46628,0.03877,-0.630038,0.47269,0.037053,-0.636675,0.46628,0.03877,-0.636675,0.681617,0.842421,-0.636675,0.681617,0.842421,-0.630038,0.688028,0.840703,-0.630038,0.47269,0.037053,-0.635487,0.683558,0.849665,-0.629175,0.689438,0.845966,-0.630038,0.688028,0.840703,-0.630038,0.688028,0.840703,-0.636675,0.681617,0.842421,-0.635487,0.683558,0.849665,-0.63204,0.685309,0.8562,-0.626671,0.690711,0.850714,-0.629175,0.689438,0.845966,-0.629175,0.689438,0.845966,-0.635487,0.683558,0.849665,-0.63204,0.685309,0.8562,-0.622769,0.69172,0.854483,-0.626671,0.690711,0.850714,-0.63204,0.685309,0.8562,-0.63204,0.685309,0.8562,-0.626671,0.686699,0.861387,-0.622769,0.69172,0.854483,-0.619905,0.687591,0.864717,-0.617854,0.692368,0.856902,-0.622769,0.69172,0.854483,-0.622769,0.69172,0.854483,-0.626671,0.686699,0.861387,-0.619905,0.687591,0.864717,-0.612405,0.687899,0.865864,-0.612405,0.692592,0.857736,-0.617854,0.692368,0.856902,-0.617854,0.692368,0.856902,-0.619905,0.687591,0.864717,-0.612405,0.687899,0.865864,-0.612405,0.692592,0.857736,-0.612405,0.687899,0.865864,0.605595,0.687899,0.865864,0.605595,0.692592,0.857735,0.614412,0.680562,0.870796,0.613095,0.687592,0.864717,0.605595,0.687899,0.865864,0.605595,0.687899,0.865864,0.605595,0.680924,0.872145,0.614412,0.680562,0.870796,0.622366,0.679514,0.866881,0.619861,0.686699,0.861387,0.613095,0.687592,0.864717,0.613095,0.687592,0.864717,0.614412,0.680562,0.870796,0.622366,0.679514,0.866881,0.625231,0.68531,0.8562,0.619861,0.686699,0.861387,0.622366,0.679514,0.866881,0.622366,0.679514,0.866881,0.628678,0.67788,0.860784,0.625231,0.68531,0.8562,0.632731,0.675821,0.853101,0.628678,0.683559,0.849665,0.625231,0.68531,0.8562,0.625231,0.68531,0.8562,0.628678,0.67788,0.860784,0.632731,0.675821,0.853101,0.634127,0.673539,0.844585,0.629866,0.681617,0.842421,0.628678,0.683559,0.849665,0.628678,0.683559,0.849665,0.632731,0.675821,0.853101,0.634127,0.673539,0.844585,0.629866,0.681617,0.842421,0.634127,0.673539,0.844585,0.634127,0.458202,0.040935,0.629866,0.46628,0.03877,0.632731,0.45592,0.032419,0.628678,0.464339,0.031526,0.629866,0.46628,0.03877,0.629866,0.46628,0.03877,0.634127,0.458202,0.040935,0.632731,0.45592,0.032419,0.628678,0.453861,0.024736,0.625231,0.462587,0.024991,0.628678,0.464339,0.031526,0.628678,0.464339,0.031526,0.632731,0.45592,0.032419,0.628678,0.453861,0.024736,0.619861,0.461198,0.019804,0.625231,0.462587,0.024991,0.628678,0.453861,0.024736,0.628678,0.453861,0.024736,0.622366,0.452227,0.018639,0.619861,0.461198,0.019804,0.614412,0.451178,0.014724,0.613095,0.460305,0.016474,0.619861,0.461198,0.019804,0.619861,0.461198,0.019804,0.622366,0.452227,0.018639,0.614412,0.451178,0.014724,0.605595,0.450817,0.013375,0.605595,0.459998,0.015327,0.613095,0.460305,0.016474,0.613095,0.460305,0.016474,0.614412,0.451178,0.014724,0.605595,0.450817,0.013375,0.605595,0.459998,0.015327,0.605595,0.450817,0.013375,-0.612405,0.450817,0.013375,-0.612405,0.459998,0.015327,0.605595,0.459998,0.015327,-0.621221,0.451178,0.014724,-0.619905,0.460305,0.016474,-0.612405,0.459998,0.015327,-0.612405,0.459998,0.015327,-0.612405,0.450817,0.013375,-0.621221,0.451178,0.014724,-0.629175,0.452227,0.018639,-0.62667,0.461198,0.019804,-0.619905,0.460305,0.016474,-0.619905,0.460305,0.016474,-0.621221,0.451178,0.014724,-0.629175,0.452227,0.018639,-0.63204,0.462587,0.024991,-0.62667,0.461198,0.019804,-0.629175,0.452227,0.018639,-0.635487,0.453861,0.024736,-0.63954,0.455919,0.032419,-0.635487,0.464338,0.031526,-0.63204,0.462587,0.024991,-0.63204,0.462587,0.024991,-0.635487,0.453861,0.024736,-0.63954,0.455919,0.032419,-0.640936,0.458201,0.040935,-0.636675,0.46628,0.03877,-0.635487,0.464338,0.031526,-0.635487,0.464338,0.031526,-0.63954,0.455919,0.032419,-0.640936,0.458201,0.040935,-0.636675,0.46628,0.03877,-0.640936,0.458201,0.040935,-0.640936,0.673539,0.844585,-0.636675,0.681617,0.842421,-0.636675,0.46628,0.03877,-0.63954,0.675821,0.853101,-0.635487,0.683558,0.849665,-0.636675,0.681617,0.842421,-0.636675,0.681617,0.842421,-0.640936,0.673539,0.844585,-0.63954,0.675821,0.853101,-0.635487,0.67788,0.860784,-0.63204,0.685309,0.8562,-0.635487,0.683558,0.849665,-0.635487,0.683558,0.849665,-0.63954,0.675821,0.853101,-0.635487,0.67788,0.860784,-0.626671,0.686699,0.861387,-0.63204,0.685309,0.8562,-0.635487,0.67788,0.860784,-0.635487,0.67788,0.860784,-0.629175,0.679513,0.866881,-0.626671,0.686699,0.861387,-0.621221,0.680562,0.870796,-0.619905,0.687591,0.864717,-0.626671,0.686699,0.861387,-0.626671,0.686699,0.861387,-0.629175,0.679513,0.866881,-0.621221,0.680562,0.870796,-0.612405,0.680924,0.872145,-0.612405,0.687899,0.865864,-0.619905,0.687591,0.864717,-0.619905,0.687591,0.864717,-0.621221,0.680562,0.870796,-0.612405,0.680924,0.872145,-0.612405,0.687899,0.865864,-0.612405,0.680924,0.872145,0.605595,0.680924,0.872145,0.605595,0.680924,0.872145,0.605595,0.687899,0.865864,-0.612405,0.687899,0.865864,0.605595,0.680924,0.872145,-0.612405,0.680924,0.872145,-0.612405,0.673046,0.875652,-0.612405,0.673046,0.875652,0.605595,0.673047,0.875652,0.605595,0.680924,0.872145,0.635476,0.449975,0.043139,0.634127,0.458202,0.040935,0.634127,0.673539,0.844585,0.634127,0.673539,0.844585,0.635476,0.665313,0.846789,0.635476,0.449975,0.043139,0.622512,0.671655,0.870458,0.623159,0.67157,0.87014,0.622366,0.679514,0.866881,0.622512,0.671655,0.870458,0.622366,0.679514,0.866881,0.614412,0.680562,0.870796,0.622512,0.671655,0.870458,0.614412,0.680562,0.870796,0.614829,0.672668,0.874239,0.614112,0.672698,0.874349,0.614829,0.672668,0.874239,0.614412,0.680562,0.870796,0.614112,0.672698,0.874349,0.614412,0.680562,0.870796,0.605595,0.680924,0.872145,0.605595,0.673047,0.875652,0.633684,0.66787,0.856333,0.634013,0.667703,0.855708,0.632731,0.675821,0.853101,0.633684,0.66787,0.856333,0.632731,0.675821,0.853101,0.628678,0.67788,0.860784,0.633684,0.66787,0.856333,0.628678,0.67788,0.860784,0.629769,0.669859,0.863754,0.629256,0.669992,0.86425,0.629769,0.669859,0.863754,0.628678,0.67788,0.860784,0.629256,0.669992,0.86425,0.628678,0.67788,0.860784,0.622366,0.679514,0.866881,0.629256,0.669992,0.86425,0.622366,0.679514,0.866881,0.623159,0.67157,0.87014,0.635362,0.665499,0.847482,0.635476,0.665313,0.846789,0.634127,0.673539,0.844585,0.635362,0.665499,0.847482,0.634127,0.673539,0.844585,0.632731,0.675821,0.853101,0.635362,0.665499,0.847482,0.632731,0.675821,0.853101,0.634013,0.667703,0.855708,0.634127,0.447771,0.034913,0.634013,0.447585,0.03422,0.632731,0.45592,0.032419,0.634127,0.447771,0.034913,0.632731,0.45592,0.032419,0.634127,0.458202,0.040935,0.634127,0.447771,0.034913,0.634127,0.458202,0.040935,0.635476,0.449975,0.043139,0.615476,0.442705,0.016008,0.614829,0.44262,0.015689,0.614412,0.451178,0.014724,0.615476,0.442705,0.016008,0.614412,0.451178,0.014724,0.622366,0.452227,0.018639,0.615476,0.442705,0.016008,0.622366,0.452227,0.018639,0.623159,0.443719,0.019789,0.606312,0.442271,0.014386,0.605595,0.442242,0.014277,0.605595,0.450817,0.013375,0.606312,0.442271,0.014386,0.605595,0.450817,0.013375,0.614412,0.451178,0.014724,0.606312,0.442271,0.014386,0.614412,0.451178,0.014724,0.614829,0.44262,0.015689,0.623672,0.443851,0.020285,0.623159,0.443719,0.019789,0.622366,0.452227,0.018639,0.623672,0.443851,0.020285,0.622366,0.452227,0.018639,0.628678,0.453861,0.024736,0.623672,0.443851,0.020285,0.628678,0.453861,0.024736,0.629769,0.44543,0.026174,0.630099,0.445597,0.026799,0.629769,0.44543,0.026174,0.628678,0.453861,0.024736,0.630099,0.445597,0.026799,0.628678,0.453861,0.024736,0.632731,0.45592,0.032419,0.630099,0.445597,0.026799,0.632731,0.45592,0.032419,0.634013,0.447585,0.03422,0.605595,0.442242,0.014277,-0.612405,0.442241,0.014277,-0.612405,0.450817,0.013375,-0.612405,0.450817,0.013375,0.605595,0.450817,0.013375,0.605595,0.442242,0.014277,-0.642285,0.665313,0.846789,-0.640936,0.673539,0.844585,-0.640936,0.458201,0.040935,-0.640936,0.458201,0.040935,-0.642285,0.449975,0.043139,-0.642285,0.665313,0.846789,-0.622285,0.672583,0.873921,-0.621638,0.672668,0.874239,-0.621221,0.680562,0.870796,-0.622285,0.672583,0.873921,-0.621221,0.680562,0.870796,-0.629175,0.679513,0.866881,-0.622285,0.672583,0.873921,-0.629175,0.679513,0.866881,-0.629968,0.671569,0.87014,-0.630481,0.671437,0.869644,-0.629968,0.671569,0.87014,-0.629175,0.679513,0.866881,-0.630481,0.671437,0.869644,-0.629175,0.679513,0.866881,-0.635487,0.67788,0.860784,-0.630481,0.671437,0.869644,-0.635487,0.67788,0.860784,-0.636579,0.669859,0.863754,-0.636908,0.669691,0.863129,-0.636579,0.669859,0.863754,-0.635487,0.67788,0.860784,-0.636908,0.669691,0.863129,-0.635487,0.67788,0.860784,-0.63954,0.675821,0.853101,-0.636908,0.669691,0.863129,-0.63954,0.675821,0.853101,-0.640823,0.667703,0.855708,-0.613122,0.673017,0.875542,-0.612405,0.673046,0.875652,-0.612405,0.680924,0.872145,-0.613122,0.673017,0.875542,-0.612405,0.680924,0.872145,-0.621221,0.680562,0.870796,-0.613122,0.673017,0.875542,-0.621221,0.680562,0.870796,-0.621638,0.672668,0.874239,-0.640936,0.667517,0.855016,-0.640823,0.667703,0.855708,-0.63954,0.675821,0.853101,-0.640936,0.667517,0.855016,-0.63954,0.675821,0.853101,-0.640936,0.673539,0.844585,-0.642285,0.665313,0.846789,-0.642172,0.44979,0.042447,-0.642285,0.449975,0.043139,-0.640936,0.458201,0.040935,-0.642172,0.44979,0.042447,-0.640936,0.458201,0.040935,-0.63954,0.455919,0.032419,-0.642172,0.44979,0.042447,-0.63954,0.455919,0.032419,-0.640823,0.447585,0.03422,-0.629321,0.443633,0.019471,-0.629968,0.443718,0.019789,-0.629175,0.452227,0.018639,-0.629321,0.443633,0.019471,-0.629175,0.452227,0.018639,-0.621221,0.451178,0.014724,-0.629321,0.443633,0.019471,-0.621221,0.451178,0.014724,-0.621638,0.44262,0.015689,-0.640493,0.447418,0.033595,-0.640823,0.447585,0.03422,-0.63954,0.455919,0.032419,-0.640493,0.447418,0.033595,-0.63954,0.455919,0.032419,-0.635487,0.453861,0.024736,-0.640493,0.447418,0.033595,-0.635487,0.453861,0.024736,-0.636579,0.445429,0.026174,-0.636065,0.445296,0.025678,-0.636579,0.445429,0.026174,-0.635487,0.453861,0.024736,-0.636065,0.445296,0.025678,-0.635487,0.453861,0.024736,-0.629175,0.452227,0.018639,-0.636065,0.445296,0.025678,-0.629175,0.452227,0.018639,-0.629968,0.443718,0.019789,-0.620921,0.442591,0.01558,-0.621638,0.44262,0.015689,-0.621221,0.451178,0.014724,-0.620921,0.442591,0.01558,-0.621221,0.451178,0.014724,-0.612405,0.450817,0.013375,-0.620921,0.442591,0.01558,-0.612405,0.450817,0.013375,-0.612405,0.442241,0.014277,-0.574913,0.469087,0.114467,-0.574913,0.473917,0.113173,-0.574913,0.661477,0.813158,-0.574913,0.656648,0.814452,0.578297,0.656648,0.814451,0.578297,0.661477,0.813157,0.578297,0.473917,0.113172,0.578297,0.469087,0.114466,0.630099,0.445597,0.026799,0.634013,0.447585,0.03422,0.634127,0.447771,0.034913,0.629769,0.44543,0.026174,0.630099,0.445597,0.026799,0.634127,0.447771,0.034913,0.623672,0.443851,0.020285,0.629769,0.44543,0.026174,0.634127,0.447771,0.034913,0.623159,0.443719,0.019789,0.623672,0.443851,0.020285,0.634127,0.447771,0.034913,0.615476,0.442705,0.016008,0.623159,0.443719,0.019789,0.634127,0.447771,0.034913,0.614829,0.44262,0.015689,0.615476,0.442705,0.016008,0.634127,0.447771,0.034913,0.606312,0.442271,0.014386,0.614829,0.44262,0.015689,0.634127,0.447771,0.034913,0.605595,0.442242,0.014277,0.606312,0.442271,0.014386,0.634127,0.447771,0.034913,0.605595,0.442242,0.014277,0.634127,0.447771,0.034913,0.635476,0.449975,0.043139,0.622512,0.671655,0.870458,0.614829,0.672668,0.874239,0.614112,0.672698,0.874349,0.623159,0.67157,0.87014,0.622512,0.671655,0.870458,0.614112,0.672698,0.874349,0.629256,0.669992,0.86425,0.623159,0.67157,0.87014,0.614112,0.672698,0.874349,0.629769,0.669859,0.863754,0.629256,0.669992,0.86425,0.614112,0.672698,0.874349,0.633684,0.66787,0.856333,0.629769,0.669859,0.863754,0.614112,0.672698,0.874349,0.634013,0.667703,0.855708,0.633684,0.66787,0.856333,0.614112,0.672698,0.874349,0.635362,0.665499,0.847482,0.634013,0.667703,0.855708,0.614112,0.672698,0.874349,0.635476,0.665313,0.846789,0.635362,0.665499,0.847482,0.614112,0.672698,0.874349,0.635476,0.665313,0.846789,0.614112,0.672698,0.874349,0.605595,0.673047,0.875652,0.635476,0.665313,0.846789,0.605595,0.673047,0.875652,-0.612405,0.673046,0.875652,-0.622285,0.672583,0.873921,-0.629968,0.671569,0.87014,-0.630481,0.671437,0.869644,-0.630481,0.671437,0.869644,-0.636579,0.669859,0.863754,-0.636908,0.669691,0.863129,-0.622285,0.672583,0.873921,-0.630481,0.671437,0.869644,-0.636908,0.669691,0.863129,-0.621638,0.672668,0.874239,-0.622285,0.672583,0.873921,-0.636908,0.669691,0.863129,-0.613122,0.673017,0.875542,-0.621638,0.672668,0.874239,-0.636908,0.669691,0.863129,-0.636908,0.669691,0.863129,-0.640823,0.667703,0.855708,-0.640936,0.667517,0.855016,-0.613122,0.673017,0.875542,-0.636908,0.669691,0.863129,-0.640936,0.667517,0.855016,-0.613122,0.673017,0.875542,-0.640936,0.667517,0.855016,-0.642285,0.665313,0.846789,-0.612405,0.673046,0.875652,-0.613122,0.673017,0.875542,-0.642285,0.665313,0.846789,-0.612405,0.673046,0.875652,-0.642285,0.665313,0.846789,-0.642285,0.449975,0.043139,-0.629321,0.443633,0.019471,-0.621638,0.44262,0.015689,-0.620921,0.442591,0.01558,-0.629968,0.443718,0.019789,-0.629321,0.443633,0.019471,-0.620921,0.442591,0.01558,-0.636065,0.445296,0.025678,-0.629968,0.443718,0.019789,-0.620921,0.442591,0.01558,-0.636579,0.445429,0.026174,-0.636065,0.445296,0.025678,-0.620921,0.442591,0.01558,-0.640493,0.447418,0.033595,-0.636579,0.445429,0.026174,-0.620921,0.442591,0.01558,-0.640823,0.447585,0.03422,-0.640493,0.447418,0.033595,-0.620921,0.442591,0.01558,-0.642172,0.44979,0.042447,-0.640823,0.447585,0.03422,-0.620921,0.442591,0.01558,-0.642285,0.449975,0.043139,-0.642172,0.44979,0.042447,-0.620921,0.442591,0.01558,-0.612405,0.673046,0.875652,-0.642285,0.449975,0.043139,-0.620921,0.442591,0.01558,-0.612405,0.673046,0.875652,-0.620921,0.442591,0.01558,-0.612405,0.442241,0.014277,-0.612405,0.673046,0.875652,-0.612405,0.442241,0.014277,-0.574913,0.656648,0.814452,-0.612405,0.673046,0.875652,-0.574913,0.656648,0.814452,-0.525867,0.656648,0.814452,-0.612405,0.673046,0.875652,-0.525867,0.656648,0.814452,-0.52067,0.656648,0.814452,0.635476,0.665313,0.846789,-0.612405,0.673046,0.875652,0.635476,0.665313,0.846789,-0.52067,0.656648,0.814452,0.578297,0.656648,0.814451,0.635476,0.665313,0.846789,0.578297,0.656648,0.814451,0.578297,0.469087,0.114466,0.635476,0.449975,0.043139,0.635476,0.665313,0.846789,0.578297,0.469087,0.114466,0.635476,0.449975,0.043139,0.578297,0.469087,0.114466,0.528561,0.469087,0.114466,0.605595,0.442242,0.014277,0.635476,0.449975,0.043139,0.605595,0.442242,0.014277,0.463925,0.469087,0.114466,-0.574913,0.469087,0.114467,-0.574913,0.656648,0.814452,-0.612405,0.442241,0.014277,-0.574913,0.469087,0.114467,-0.612405,0.442241,0.014277,0.605595,0.442242,0.014277,0.463925,0.469087,0.114466,-0.612405,0.442241,0.014277,-0.525867,0.656648,0.814452,-0.574913,0.656648,0.814452,-0.574913,0.661477,0.813158,-0.52067,0.656648,0.814452,-0.525867,0.656648,0.814452,-0.574913,0.661477,0.813158,0.578297,0.656648,0.814451,-0.52067,0.656648,0.814452,-0.574913,0.661477,0.813158,0.578297,0.656648,0.814451,-0.574913,0.661477,0.813158,0.578297,0.661477,0.813157,-0.574913,0.473917,0.113173,-0.574913,0.469087,0.114467,0.463925,0.469087,0.114466,-0.574913,0.473917,0.113173,0.463925,0.469087,0.114466,0.528561,0.469087,0.114466,-0.574913,0.473917,0.113173,0.528561,0.469087,0.114466,0.578297,0.469087,0.114466,-0.574913,0.473917,0.113173,0.578297,0.469087,0.114466,0.578297,0.473917,0.113172,-0.200812,-0.341623,0.068612,-0.200812,-0.388718,0.068612,-0.200812,-0.388718,0.076612,-0.200812,-0.341623,0.076612,-0.200812,-0.388718,0.068612,-0.200019,-0.395592,0.068612,-0.200019,-0.395592,0.076612,-0.200812,-0.388718,0.076612,-0.200019,-0.395592,0.068612,-0.19776,-0.401905,0.068612,-0.19776,-0.401905,0.076612,-0.200019,-0.395592,0.076612,-0.19776,-0.401905,0.068612,-0.194217,-0.407475,0.068612,-0.194217,-0.407475,0.076612,-0.19776,-0.401905,0.076612,-0.194217,-0.407475,0.068612,-0.189569,-0.412123,0.068612,-0.189569,-0.412123,0.076612,-0.194217,-0.407475,0.076612,-0.189569,-0.412123,0.068612,-0.183999,-0.415666,0.068612,-0.183999,-0.415666,0.076612,-0.189569,-0.412123,0.076612,-0.183999,-0.415666,0.068612,-0.177686,-0.417925,0.068612,-0.177686,-0.417925,0.076612,-0.183999,-0.415666,0.076612,-0.177686,-0.417925,0.068612,-0.170812,-0.418718,0.068612,-0.170812,-0.418718,0.076612,-0.177686,-0.417925,0.076612,-0.170812,-0.418718,0.068612,0.171763,-0.418718,0.068612,0.171763,-0.418718,0.076612,-0.170812,-0.418718,0.076612,0.171763,-0.418718,0.068612,0.178637,-0.417925,0.068612,0.178637,-0.417925,0.076612,0.171763,-0.418718,0.076612,0.178637,-0.417925,0.068612,0.18495,-0.415666,0.068612,0.18495,-0.415666,0.076612,0.178637,-0.417925,0.076612,0.18495,-0.415666,0.068612,0.19052,-0.412123,0.068612,0.19052,-0.412123,0.076612,0.18495,-0.415666,0.076612,0.19052,-0.412123,0.068612,0.195168,-0.407475,0.068612,0.195168,-0.407475,0.076612,0.19052,-0.412123,0.076612,0.195168,-0.407475,0.068612,0.198711,-0.401905,0.068612,0.198711,-0.401905,0.076612,0.195168,-0.407475,0.076612,0.198711,-0.401905,0.068612,0.20097,-0.395592,0.068612,0.20097,-0.395592,0.076612,0.198711,-0.401905,0.076612,0.20097,-0.395592,0.068612,0.201763,-0.388718,0.068612,0.201763,-0.388718,0.076612,0.20097,-0.395592,0.076612,0.201763,-0.388718,0.068612,0.201763,-0.341623,0.068612,0.201763,-0.341623,0.076612,0.201763,-0.388718,0.076612,0.201763,-0.341623,0.068612,-0.200812,-0.341623,0.068612,-0.200812,-0.341623,0.076612,-0.200812,-0.341623,0.076612,0.201763,-0.341623,0.076612,0.201763,-0.341623,0.068612,-0.200812,-0.388718,0.068612,-0.200812,-0.341623,0.068612,0.201763,-0.388718,0.068612,-0.200812,-0.388718,0.068612,0.201763,-0.341623,0.068612,0.201763,-0.388718,0.068612,-0.200019,-0.395592,0.068612,-0.200812,-0.388718,0.068612,0.201763,-0.388718,0.068612,-0.19776,-0.401905,0.068612,-0.200019,-0.395592,0.068612,0.201763,-0.388718,0.068612,-0.194217,-0.407475,0.068612,-0.19776,-0.401905,0.068612,0.201763,-0.388718,0.068612,-0.189569,-0.412123,0.068612,-0.194217,-0.407475,0.068612,0.201763,-0.388718,0.068612,-0.183999,-0.415666,0.068612,-0.189569,-0.412123,0.068612,0.201763,-0.388718,0.068612,-0.177686,-0.417925,0.068612,-0.183999,-0.415666,0.068612,0.201763,-0.388718,0.068612,-0.170812,-0.418718,0.068612,-0.177686,-0.417925,0.068612,0.201763,-0.388718,0.068612,0.171763,-0.418718,0.068612,-0.170812,-0.418718,0.068612,0.201763,-0.388718,0.068612,0.178637,-0.417925,0.068612,0.171763,-0.418718,0.068612,0.20097,-0.395592,0.068612,0.178637,-0.417925,0.068612,0.201763,-0.388718,0.068612,0.20097,-0.395592,0.068612,0.18495,-0.415666,0.068612,0.178637,-0.417925,0.068612,0.198711,-0.401905,0.068612,0.18495,-0.415666,0.068612,0.20097,-0.395592,0.068612,0.195168,-0.407475,0.068612,0.18495,-0.415666,0.068612,0.198711,-0.401905,0.068612,0.195168,-0.407475,0.068612,0.19052,-0.412123,0.068612,0.18495,-0.415666,0.068612,0.201763,-0.341623,0.076612,-0.200812,-0.341623,0.076612,-0.200812,-0.388718,0.076612,0.201763,-0.388718,0.076612,0.201763,-0.341623,0.076612,-0.200812,-0.388718,0.076612,0.201763,-0.388718,0.076612,-0.200812,-0.388718,0.076612,-0.200019,-0.395592,0.076612,0.201763,-0.388718,0.076612,-0.200019,-0.395592,0.076612,-0.19776,-0.401905,0.076612,0.201763,-0.388718,0.076612,-0.19776,-0.401905,0.076612,-0.194217,-0.407475,0.076612,0.201763,-0.388718,0.076612,-0.194217,-0.407475,0.076612,-0.189569,-0.412123,0.076612,0.201763,-0.388718,0.076612,-0.189569,-0.412123,0.076612,-0.183999,-0.415666,0.076612,0.201763,-0.388718,0.076612,-0.183999,-0.415666,0.076612,-0.177686,-0.417925,0.076612,0.201763,-0.388718,0.076612,-0.177686,-0.417925,0.076612,-0.170812,-0.418718,0.076612,0.201763,-0.388718,0.076612,-0.170812,-0.418718,0.076612,0.171763,-0.418718,0.076612,0.201763,-0.388718,0.076612,0.171763,-0.418718,0.076612,0.178637,-0.417925,0.076612,0.20097,-0.395592,0.076612,0.201763,-0.388718,0.076612,0.178637,-0.417925,0.076612,0.20097,-0.395592,0.076612,0.178637,-0.417925,0.076612,0.18495,-0.415666,0.076612,0.198711,-0.401905,0.076612,0.20097,-0.395592,0.076612,0.18495,-0.415666,0.076612,0.195168,-0.407475,0.076612,0.198711,-0.401905,0.076612,0.18495,-0.415666,0.076612,0.195168,-0.407475,0.076612,0.18495,-0.415666,0.076612,0.19052,-0.412123,0.076612,0.6091,-0.444432,0.020829,0.617917,-0.443035,0.020829,0.6091,-0.4459,0.0301,0.617917,-0.443035,0.020829,0.618371,-0.444432,0.0301,0.6091,-0.4459,0.0301,0.6091,-0.444432,0.020829,0.6091,-0.44017,0.012466,0.6166,-0.438983,0.012466,0.6166,-0.438983,0.012466,0.617917,-0.443035,0.020829,0.6091,-0.444432,0.020829,0.6091,-0.44017,0.012466,0.6091,-0.433533,0.005829,0.614549,-0.43267,0.005829,0.614549,-0.43267,0.005829,0.6166,-0.438983,0.012466,0.6091,-0.44017,0.012466,0.6091,-0.433533,0.005829,0.6091,-0.42517,0.001568,0.611965,-0.424717,0.001568,0.611965,-0.424717,0.001568,0.614549,-0.43267,0.005829,0.6091,-0.433533,0.005829,0.6091,-0.42517,0.001568,0.6091,-0.4159,0.0001,0.611965,-0.424717,0.001568,0.611965,-0.424717,0.001568,0.6091,-0.4159,0.0001,0.614549,-0.4234,0.001568,0.614549,-0.4234,0.001568,0.6091,-0.4159,0.0001,0.6166,-0.421349,0.001568,0.614549,-0.4234,0.001568,0.6166,-0.421349,0.001568,0.623366,-0.426265,0.005829,0.623366,-0.426265,0.005829,0.619465,-0.430166,0.005829,0.614549,-0.4234,0.001568,0.619465,-0.430166,0.005829,0.623366,-0.426265,0.005829,0.628735,-0.430166,0.012466,0.628735,-0.430166,0.012466,0.623366,-0.435535,0.012466,0.619465,-0.430166,0.005829,0.623366,-0.435535,0.012466,0.628735,-0.430166,0.012466,0.632183,-0.43267,0.020829,0.625871,-0.438983,0.020829,0.623366,-0.435535,0.012466,0.632183,-0.43267,0.020829,0.633371,-0.433533,0.0301,0.626734,-0.44017,0.0301,0.626734,-0.44017,0.0301,0.625871,-0.438983,0.020829,0.632183,-0.43267,0.020829,0.626734,-0.44017,0.074583,0.626734,-0.44017,0.0301,0.633371,-0.433533,0.0301,0.633371,-0.433533,0.0301,0.633371,-0.433533,0.074583,0.633371,-0.433533,0.074583,0.633371,-0.433533,0.0301,0.637632,-0.42517,0.0301,0.637632,-0.42517,0.074583,0.633371,-0.433533,0.074583,0.637632,-0.42517,0.074583,0.637632,-0.42517,0.0301,0.6391,-0.4159,0.0301,0.6391,-0.4159,0.074583,0.6391,-0.002826,0.074583,0.6391,-0.002826,0.0301,0.6391,0.4161,0.0301,0.6391,0.4161,0.074583,0.6391,0.4161,0.074583,0.6391,0.4161,0.0301,0.637632,0.425371,0.0301,0.637632,0.425371,0.074583,0.6391,0.4161,0.074583,0.637632,0.425371,0.074583,0.637632,0.425371,0.0301,0.63337,0.433734,0.0301,0.63337,0.433734,0.074583,0.637632,0.425371,0.074583,0.63337,0.433734,0.074583,0.63337,0.433734,0.0301,0.626733,0.440371,0.0301,0.626733,0.440371,0.074583,0.626733,0.440371,0.074583,0.626733,0.440371,0.0301,0.61837,0.444632,0.0301,0.61837,0.444632,0.074583,0.626733,0.440371,0.074583,0.61837,0.444632,0.074583,0.61837,0.444632,0.0301,0.6091,0.4461,0.0301,0.6091,0.4461,0.074583,0.61837,0.444632,0.074583,-0.61817,-0.444432,0.074583,-0.61817,-0.444432,0.0301,-0.6089,-0.4459,0.0301,-0.6089,-0.4459,0.074583,-0.61817,-0.444432,0.0301,-0.617717,-0.443035,0.020829,-0.6089,-0.444432,0.020829,-0.6089,-0.444432,0.020829,-0.6089,-0.4459,0.0301,-0.61817,-0.444432,0.0301,-0.617717,-0.443035,0.020829,-0.6164,-0.438983,0.012466,-0.6089,-0.440171,0.012466,-0.6089,-0.440171,0.012466,-0.6089,-0.444432,0.020829,-0.617717,-0.443035,0.020829,-0.6164,-0.438983,0.012466,-0.614349,-0.432671,0.005829,-0.6089,-0.433534,0.005829,-0.6089,-0.433534,0.005829,-0.6089,-0.440171,0.012466,-0.6164,-0.438983,0.012466,-0.614349,-0.432671,0.005829,-0.611765,-0.424717,0.001568,-0.6089,-0.425171,0.001568,-0.6089,-0.433534,0.005829,-0.611765,-0.424717,0.001568,-0.6089,-0.4159,0.0001,-0.6089,-0.425171,0.001568,0.6091,0.4161,0.0001,-0.6089,0.4161,0.0001,-0.6089,0.42537,0.001568,0.6091,0.425371,0.001568,-0.6164,0.439183,0.012466,-0.617717,0.443235,0.020829,-0.6089,0.444632,0.020829,-0.6089,0.444632,0.020829,-0.6089,0.44037,0.012466,-0.6164,0.439183,0.012466,-0.617717,0.443235,0.020829,-0.618171,0.444632,0.0301,-0.6089,0.4461,0.0301,-0.6089,0.4461,0.0301,-0.6089,0.444632,0.020829,-0.617717,0.443235,0.020829,-0.625671,0.439183,0.020829,-0.626534,0.44037,0.0301,-0.618171,0.444632,0.0301,-0.618171,0.444632,0.0301,-0.617717,0.443235,0.020829,-0.625671,0.439183,0.020829,-0.631983,0.43287,0.020829,-0.633171,0.433733,0.0301,-0.626534,0.44037,0.0301,-0.626534,0.44037,0.0301,-0.625671,0.439183,0.020829,-0.631983,0.43287,0.020829,-0.636035,0.424917,0.020829,-0.637432,0.42537,0.0301,-0.633171,0.433733,0.0301,-0.633171,0.433733,0.0301,-0.631983,0.43287,0.020829,-0.636035,0.424917,0.020829,-0.637432,0.4161,0.020829,-0.6389,0.4161,0.0301,-0.637432,0.42537,0.0301,-0.637432,0.42537,0.0301,-0.636035,0.424917,0.020829,-0.637432,0.4161,0.020829,-0.6389,-0.225823,0.0301,-0.637432,-0.225823,0.020829,-0.637432,-0.4159,0.020829,-0.637432,-0.4159,0.020829,-0.6389,-0.4159,0.0301,-0.6389,-0.225823,0.0301,-0.636035,-0.424717,0.020829,-0.637432,-0.425171,0.0301,-0.6389,-0.4159,0.0301,-0.6389,-0.4159,0.0301,-0.637432,-0.4159,0.020829,-0.636035,-0.424717,0.020829,-0.631983,-0.432671,0.020829,-0.63317,-0.433534,0.0301,-0.637432,-0.425171,0.0301,-0.637432,-0.425171,0.0301,-0.636035,-0.424717,0.020829,-0.631983,-0.432671,0.020829,-0.62567,-0.438983,0.020829,-0.626534,-0.440171,0.0301,-0.63317,-0.433534,0.0301,-0.63317,-0.433534,0.0301,-0.631983,-0.432671,0.020829,-0.62567,-0.438983,0.020829,-0.617717,-0.443035,0.020829,-0.61817,-0.444432,0.0301,-0.626534,-0.440171,0.0301,-0.626534,-0.440171,0.0301,-0.62567,-0.438983,0.020829,-0.617717,-0.443035,0.020829,-0.62567,-0.438983,0.020829,-0.631983,-0.432671,0.020829,-0.628535,-0.430166,0.012466,-0.628535,-0.430166,0.012466,-0.623166,-0.435535,0.012466,-0.62567,-0.438983,0.020829,-0.623166,-0.435535,0.012466,-0.628535,-0.430166,0.012466,-0.623166,-0.426265,0.005829,-0.623166,-0.426265,0.005829,-0.619265,-0.430166,0.005829,-0.623166,-0.435535,0.012466,-0.619265,-0.430166,0.005829,-0.623166,-0.426265,0.005829,-0.6164,-0.421349,0.001568,-0.6164,-0.421349,0.001568,-0.614349,-0.4234,0.001568,-0.619265,-0.430166,0.005829,-0.6164,-0.421349,0.001568,-0.6089,-0.4159,0.0001,-0.614349,-0.4234,0.001568,-0.617717,-0.418765,0.001568,-0.6089,-0.4159,0.0001,-0.6164,-0.421349,0.001568,-0.6164,-0.421349,0.001568,-0.623166,-0.426265,0.005829,-0.62567,-0.421349,0.005829,-0.62567,-0.421349,0.005829,-0.617717,-0.418765,0.001568,-0.6164,-0.421349,0.001568,-0.626534,-0.4159,0.005829,-0.61817,-0.4159,0.001568,-0.617717,-0.418765,0.001568,-0.617717,-0.418765,0.001568,-0.62567,-0.421349,0.005829,-0.626534,-0.4159,0.005829,-0.62567,0.421549,0.005829,-0.617717,0.418965,0.001568,-0.618171,0.4161,0.001568,-0.618171,0.4161,0.001568,-0.626534,0.4161,0.005829,-0.62567,0.421549,0.005829,-0.617717,0.418965,0.001568,-0.6089,0.4161,0.0001,-0.618171,0.4161,0.001568,-0.6164,0.421549,0.001568,-0.6089,0.4161,0.0001,-0.617717,0.418965,0.001568,-0.617717,0.418965,0.001568,-0.62567,0.421549,0.005829,-0.623166,0.426465,0.005829,-0.623166,0.426465,0.005829,-0.6164,0.421549,0.001568,-0.617717,0.418965,0.001568,-0.623166,0.426465,0.005829,-0.619265,0.430366,0.005829,-0.614349,0.4236,0.001568,-0.614349,0.4236,0.001568,-0.6164,0.421549,0.001568,-0.623166,0.426465,0.005829,-0.614349,0.43287,0.005829,-0.611765,0.424917,0.001568,-0.614349,0.4236,0.001568,-0.614349,0.4236,0.001568,-0.619265,0.430366,0.005829,-0.614349,0.43287,0.005829,-0.611765,0.424917,0.001568,-0.6089,0.4161,0.0001,-0.614349,0.4236,0.001568,-0.6089,0.433733,0.005829,-0.6089,0.42537,0.001568,-0.611765,0.424917,0.001568,-0.611765,0.424917,0.001568,-0.614349,0.43287,0.005829,-0.6089,0.433733,0.005829,-0.619265,0.430366,0.005829,-0.623166,0.435735,0.012466,-0.6164,0.439183,0.012466,-0.6164,0.439183,0.012466,-0.614349,0.43287,0.005829,-0.619265,0.430366,0.005829,-0.619265,0.430366,0.005829,-0.623166,0.426465,0.005829,-0.628535,0.430366,0.012466,-0.628535,0.430366,0.012466,-0.623166,0.435735,0.012466,-0.619265,0.430366,0.005829,-0.62567,0.421549,0.005829,-0.631983,0.4236,0.012466,-0.628535,0.430366,0.012466,-0.628535,0.430366,0.012466,-0.623166,0.426465,0.005829,-0.62567,0.421549,0.005829,-0.631983,0.4236,0.012466,-0.636035,0.424917,0.020829,-0.631983,0.43287,0.020829,-0.631983,0.43287,0.020829,-0.628535,0.430366,0.012466,-0.631983,0.4236,0.012466,-0.614349,0.4236,0.001568,-0.6089,0.4161,0.0001,-0.6164,0.421549,0.001568,-0.626534,0.4161,0.005829,-0.63317,0.4161,0.012466,-0.631983,0.4236,0.012466,-0.631983,0.4236,0.012466,-0.62567,0.421549,0.005829,-0.626534,0.4161,0.005829,-0.63317,0.4161,0.012466,-0.637432,0.4161,0.020829,-0.636035,0.424917,0.020829,-0.631983,0.4236,0.012466,-0.62567,-0.421349,0.005829,-0.631983,-0.4234,0.012466,-0.63317,-0.4159,0.012466,-0.63317,-0.4159,0.012466,-0.626534,-0.4159,0.005829,-0.62567,-0.421349,0.005829,-0.631983,-0.4234,0.012466,-0.636035,-0.424717,0.020829,-0.637432,-0.4159,0.020829,-0.637432,-0.4159,0.020829,-0.63317,-0.4159,0.012466,-0.631983,-0.4234,0.012466,-0.623166,-0.426265,0.005829,-0.628535,-0.430166,0.012466,-0.631983,-0.4234,0.012466,-0.631983,-0.4234,0.012466,-0.62567,-0.421349,0.005829,-0.623166,-0.426265,0.005829,-0.61817,-0.4159,0.001568,-0.6089,-0.4159,0.0001,-0.617717,-0.418765,0.001568,-0.611765,-0.424717,0.001568,-0.614349,-0.432671,0.005829,-0.619265,-0.430166,0.005829,-0.619265,-0.430166,0.005829,-0.614349,-0.4234,0.001568,-0.611765,-0.424717,0.001568,-0.628535,-0.430166,0.012466,-0.631983,-0.432671,0.020829,-0.636035,-0.424717,0.020829,-0.636035,-0.424717,0.020829,-0.631983,-0.4234,0.012466,-0.628535,-0.430166,0.012466,-0.614349,-0.432671,0.005829,-0.6164,-0.438983,0.012466,-0.623166,-0.435535,0.012466,-0.623166,-0.435535,0.012466,-0.619265,-0.430166,0.005829,-0.614349,-0.432671,0.005829,-0.6164,-0.438983,0.012466,-0.617717,-0.443035,0.020829,-0.62567,-0.438983,0.020829,-0.62567,-0.438983,0.020829,-0.623166,-0.435535,0.012466,-0.6164,-0.438983,0.012466,-0.623166,0.435735,0.012466,-0.628535,0.430366,0.012466,-0.631983,0.43287,0.020829,-0.631983,0.43287,0.020829,-0.625671,0.439183,0.020829,-0.623166,0.435735,0.012466,-0.617717,0.443235,0.020829,-0.6164,0.439183,0.012466,-0.623166,0.435735,0.012466,-0.625671,0.439183,0.020829,-0.6089,0.44037,0.012466,-0.6089,0.433733,0.005829,-0.614349,0.43287,0.005829,-0.614349,0.43287,0.005829,-0.6164,0.439183,0.012466,-0.6089,0.44037,0.012466,0.617917,0.443235,0.020829,0.6166,0.439183,0.012466,0.6091,0.440371,0.012466,0.6091,0.440371,0.012466,0.6091,0.444632,0.020829,0.617917,0.443235,0.020829,0.62587,0.439183,0.020829,0.623366,0.435735,0.012466,0.6166,0.439183,0.012466,0.6166,0.439183,0.012466,0.617917,0.443235,0.020829,0.62587,0.439183,0.020829,0.623366,0.435735,0.012466,0.619465,0.430366,0.005829,0.614549,0.432871,0.005829,0.614549,0.432871,0.005829,0.6166,0.439183,0.012466,0.623366,0.435735,0.012466,0.619465,0.430366,0.005829,0.614549,0.4236,0.001568,0.611965,0.424917,0.001568,0.611965,0.424917,0.001568,0.614549,0.432871,0.005829,0.619465,0.430366,0.005829,0.614549,0.4236,0.001568,0.6091,0.4161,0.0001,0.611965,0.424917,0.001568,0.6166,0.421549,0.001568,0.6091,0.4161,0.0001,0.614549,0.4236,0.001568,0.62587,0.421549,0.005829,0.617917,0.418965,0.001568,0.6166,0.421549,0.001568,0.6166,0.421549,0.001568,0.623366,0.426465,0.005829,0.62587,0.421549,0.005829,0.626734,0.4161,0.005829,0.61837,0.4161,0.001568,0.617917,0.418965,0.001568,0.617917,0.418965,0.001568,0.62587,0.421549,0.005829,0.626734,0.4161,0.005829,0.61837,0.4161,0.001568,0.6091,0.4161,0.0001,0.617917,0.418965,0.001568,0.625871,-0.421349,0.005829,0.617917,-0.418765,0.001568,0.618371,-0.4159,0.001568,0.618371,-0.4159,0.001568,0.626734,-0.4159,0.005829,0.625871,-0.421349,0.005829,0.617917,-0.418765,0.001568,0.6091,-0.4159,0.0001,0.618371,-0.4159,0.001568,0.623366,-0.426265,0.005829,0.6166,-0.421349,0.001568,0.617917,-0.418765,0.001568,0.617917,-0.418765,0.001568,0.625871,-0.421349,0.005829,0.623366,-0.426265,0.005829,0.626734,-0.4159,0.005829,0.633371,-0.4159,0.012466,0.632183,-0.4234,0.012466,0.632183,-0.4234,0.012466,0.625871,-0.421349,0.005829,0.626734,-0.4159,0.005829,0.633371,-0.4159,0.012466,0.637632,-0.4159,0.020829,0.636235,-0.424717,0.020829,0.632183,-0.4234,0.012466,0.637632,-0.4159,0.020829,0.6391,-0.4159,0.0301,0.637632,-0.42517,0.0301,0.637632,-0.42517,0.0301,0.636235,-0.424717,0.020829,0.637632,-0.4159,0.020829,0.632183,0.4236,0.012466,0.636235,0.424917,0.020829,0.637632,0.4161,0.020829,0.637632,0.4161,0.020829,0.63337,0.4161,0.012466,0.632183,0.4236,0.012466,0.636235,0.424917,0.020829,0.637632,0.425371,0.0301,0.6391,0.4161,0.0301,0.6391,0.4161,0.0301,0.637632,0.4161,0.020829,0.636235,0.424917,0.020829,0.628735,0.430366,0.012466,0.632183,0.432871,0.020829,0.636235,0.424917,0.020829,0.636235,0.424917,0.020829,0.632183,0.4236,0.012466,0.628735,0.430366,0.012466,0.632183,0.432871,0.020829,0.63337,0.433734,0.0301,0.637632,0.425371,0.0301,0.637632,0.425371,0.0301,0.636235,0.424917,0.020829,0.632183,0.432871,0.020829,0.632183,0.4236,0.012466,0.62587,0.421549,0.005829,0.623366,0.426465,0.005829,0.623366,0.426465,0.005829,0.628735,0.430366,0.012466,0.632183,0.4236,0.012466,0.63337,0.4161,0.012466,0.626734,0.4161,0.005829,0.62587,0.421549,0.005829,0.62587,0.421549,0.005829,0.632183,0.4236,0.012466,0.63337,0.4161,0.012466,0.632183,-0.43267,0.020829,0.628735,-0.430166,0.012466,0.632183,-0.4234,0.012466,0.632183,-0.4234,0.012466,0.636235,-0.424717,0.020829,0.632183,-0.43267,0.020829,0.628735,-0.430166,0.012466,0.623366,-0.426265,0.005829,0.625871,-0.421349,0.005829,0.625871,-0.421349,0.005829,0.632183,-0.4234,0.012466,0.628735,-0.430166,0.012466,0.618371,-0.4159,0.001568,0.61837,0.4161,0.001568,0.626734,0.4161,0.005829,0.626734,-0.4159,0.005829,0.617917,0.418965,0.001568,0.6091,0.4161,0.0001,0.6166,0.421549,0.001568,0.6166,0.421549,0.001568,0.614549,0.4236,0.001568,0.619465,0.430366,0.005829,0.619465,0.430366,0.005829,0.623366,0.426465,0.005829,0.6166,0.421549,0.001568,0.6091,0.425371,0.001568,0.6091,0.433734,0.005829,0.614549,0.432871,0.005829,0.614549,0.432871,0.005829,0.611965,0.424917,0.001568,0.6091,0.425371,0.001568,0.623366,0.426465,0.005829,0.619465,0.430366,0.005829,0.623366,0.435735,0.012466,0.623366,0.435735,0.012466,0.628735,0.430366,0.012466,0.623366,0.426465,0.005829,0.6091,0.433734,0.005829,0.6091,0.440371,0.012466,0.6166,0.439183,0.012466,0.6166,0.439183,0.012466,0.614549,0.432871,0.005829,0.6091,0.433734,0.005829,0.628735,0.430366,0.012466,0.623366,0.435735,0.012466,0.62587,0.439183,0.020829,0.62587,0.439183,0.020829,0.632183,0.432871,0.020829,0.628735,0.430366,0.012466,0.62587,0.439183,0.020829,0.626733,0.440371,0.0301,0.63337,0.433734,0.0301,0.63337,0.433734,0.0301,0.632183,0.432871,0.020829,0.62587,0.439183,0.020829,0.617917,0.443235,0.020829,0.61837,0.444632,0.0301,0.626733,0.440371,0.0301,0.626733,0.440371,0.0301,0.62587,0.439183,0.020829,0.617917,0.443235,0.020829,0.6091,0.444632,0.020829,0.6091,0.4461,0.0301,0.61837,0.444632,0.0301,0.61837,0.444632,0.0301,0.617917,0.443235,0.020829,0.6091,0.444632,0.020829,-0.6089,0.42537,0.001568,-0.6089,0.4161,0.0001,-0.611765,0.424917,0.001568,0.611965,0.424917,0.001568,0.6091,0.4161,0.0001,0.6091,0.425371,0.001568,-0.61817,-0.002826,0.001568,-0.618171,0.4161,0.001568,-0.6089,0.4161,0.0001,-0.6089,-0.002826,0.0001,-0.614349,-0.4234,0.001568,-0.6089,-0.4159,0.0001,-0.611765,-0.424717,0.001568,-0.626534,-0.440171,0.074583,-0.626534,-0.440171,0.0301,-0.61817,-0.444432,0.0301,-0.61817,-0.444432,0.074583,-0.63317,-0.433534,0.074583,-0.63317,-0.433534,0.0301,-0.626534,-0.440171,0.0301,-0.626534,-0.440171,0.0301,-0.626534,-0.440171,0.074583,-0.637432,-0.425171,0.074583,-0.637432,-0.425171,0.0301,-0.63317,-0.433534,0.0301,-0.63317,-0.433534,0.0301,-0.63317,-0.433534,0.074583,-0.6389,-0.4159,0.074583,-0.6389,-0.4159,0.0301,-0.637432,-0.425171,0.0301,-0.637432,-0.425171,0.0301,-0.637432,-0.425171,0.074583,-0.6389,-0.225823,0.074583,-0.6389,-0.225823,0.0301,-0.6389,-0.4159,0.0301,-0.6389,-0.4159,0.0301,-0.6389,-0.4159,0.074583,-0.637432,0.42537,0.074583,-0.637432,0.42537,0.0301,-0.6389,0.4161,0.0301,-0.6389,0.4161,0.0301,-0.6389,0.4161,0.074583,-0.633171,0.433733,0.074583,-0.633171,0.433733,0.0301,-0.637432,0.42537,0.0301,-0.637432,0.42537,0.0301,-0.637432,0.42537,0.074583,-0.626534,0.44037,0.074583,-0.626534,0.44037,0.0301,-0.633171,0.433733,0.0301,-0.633171,0.433733,0.0301,-0.633171,0.433733,0.074583,-0.618171,0.444632,0.074583,-0.618171,0.444632,0.0301,-0.626534,0.44037,0.0301,-0.626534,0.44037,0.0301,-0.626534,0.44037,0.074583,-0.6089,0.4461,0.074583,-0.6089,0.4461,0.0301,-0.618171,0.444632,0.0301,-0.618171,0.444632,0.0301,-0.618171,0.444632,0.074583,0.637632,-0.002826,0.020829,0.637632,0.4161,0.020829,0.6391,0.4161,0.0301,0.6391,0.4161,0.0301,0.6391,-0.002826,0.0301,0.633371,-0.433533,0.0301,0.632183,-0.43267,0.020829,0.636235,-0.424717,0.020829,0.636235,-0.424717,0.020829,0.637632,-0.42517,0.0301,0.633371,-0.433533,0.0301,0.618371,-0.444432,0.074583,0.618371,-0.444432,0.0301,0.626734,-0.44017,0.0301,0.626734,-0.44017,0.0301,0.626734,-0.44017,0.074583,0.618371,-0.444432,0.0301,0.617917,-0.443035,0.020829,0.625871,-0.438983,0.020829,0.625871,-0.438983,0.020829,0.626734,-0.44017,0.0301,0.618371,-0.444432,0.0301,0.617917,-0.443035,0.020829,0.6166,-0.438983,0.012466,0.623366,-0.435535,0.012466,0.623366,-0.435535,0.012466,0.625871,-0.438983,0.020829,0.617917,-0.443035,0.020829,0.6166,-0.438983,0.012466,0.614549,-0.43267,0.005829,0.619465,-0.430166,0.005829,0.619465,-0.430166,0.005829,0.623366,-0.435535,0.012466,0.6166,-0.438983,0.012466,0.614549,-0.43267,0.005829,0.611965,-0.424717,0.001568,0.614549,-0.4234,0.001568,0.614549,-0.4234,0.001568,0.619465,-0.430166,0.005829,0.614549,-0.43267,0.005829,0.6166,-0.421349,0.001568,0.6091,-0.4159,0.0001,0.617917,-0.418765,0.001568,0.6091,-0.4459,0.074583,0.6091,-0.4459,0.0301,0.618371,-0.444432,0.0301,0.618371,-0.444432,0.0301,0.618371,-0.444432,0.074583,-0.3999,0.444632,0.020829,-0.6089,0.444632,0.020829,-0.6089,0.4461,0.0301,-0.3999,0.4461,0.0301,-0.6089,0.4461,0.074583,-0.3999,0.4461,0.074583,-0.3999,0.4461,0.0301,-0.3999,0.4461,0.0301,-0.6089,0.4461,0.0301,-0.6089,0.4461,0.074583,-0.3999,0.440371,0.012466,-0.6089,0.44037,0.012466,-0.6089,0.444632,0.020829,-0.3999,0.444632,0.020829,-0.3999,0.433734,0.005829,-0.6089,0.433733,0.005829,-0.6089,0.44037,0.012466,-0.3999,0.440371,0.012466,0.4001,0.4461,0.0301,0.6091,0.4461,0.0301,0.6091,0.444632,0.020829,0.4001,0.444632,0.020829,0.6091,0.440371,0.012466,0.4001,0.440371,0.012466,0.4001,0.444632,0.020829,0.4001,0.444632,0.020829,0.6091,0.444632,0.020829,0.6091,0.440371,0.012466,0.6091,0.4461,0.0301,0.4001,0.4461,0.0301,0.4001,0.4461,0.074583,0.6091,0.4461,0.074583,0.6091,0.4461,0.0301,0.4001,0.440371,0.012466,0.6091,0.440371,0.012466,0.6091,0.433734,0.005829,0.4001,0.433734,0.005829,0.4001,0.440371,0.012466,0.0001,0.402661,0.045586,0.0001,0.402661,0.074583,0.4001,0.402661,0.074583,0.4001,0.402661,0.045586,-0.3999,0.403948,0.034434,0.0001,0.403948,0.034434,0.0001,0.407613,0.024192,-0.3999,0.407613,0.024192,0.0001,0.413362,0.015154,0.0001,0.407613,0.024192,0.4001,0.407613,0.024192,0.4001,0.413362,0.015154,0.0001,0.413362,0.015154,0.4001,0.413362,0.015154,0.4001,0.420902,0.007614,0.4001,0.420902,0.007614,0.0001,0.420902,0.007614,0.0001,0.413362,0.015154,0.0001,0.403948,0.034434,-0.3999,0.403948,0.034434,-0.3999,0.402661,0.045586,-0.3999,0.402661,0.045586,0.0001,0.402661,0.045586,0.0001,0.403948,0.034434,0.4001,0.428166,0.002993,0.4001,0.433734,0.005829,0.6091,0.433734,0.005829,0.4001,0.428166,0.002993,0.6091,0.433734,0.005829,0.6091,0.425371,0.001568,0.0001,0.428166,0.002993,0.6091,0.425371,0.001568,0.0001,0.428166,0.002993,0.6091,0.425371,0.001568,-0.6089,0.42537,0.001568,-0.3999,0.428166,0.002993,0.0001,0.428166,0.002993,-0.6089,0.42537,0.001568,-0.3999,0.428166,0.002993,-0.6089,0.42537,0.001568,-0.6089,0.433733,0.005829,-0.3999,0.428166,0.002993,-0.6089,0.433733,0.005829,-0.3999,0.433734,0.005829,0.6391,-0.4159,0.074583,0.6391,-0.4159,0.0301,0.6391,-0.225823,0.0301,0.6391,-0.225823,0.074583,0.6391,-0.4159,0.074583,-0.637432,-0.225823,0.020829,-0.6389,-0.225823,0.0301,-0.6389,-0.002826,0.0301,-0.6389,-0.002826,0.0301,-0.637432,-0.002826,0.020829,-0.637432,-0.225823,0.020829,-0.61817,-0.225823,0.001568,-0.6089,-0.225823,0.0001,-0.6089,-0.4159,0.0001,-0.6089,-0.4159,0.0001,-0.61817,-0.4159,0.001568,-0.61817,-0.225823,0.001568,-0.6389,-0.002826,0.074583,-0.6389,-0.002826,0.0301,-0.6389,-0.225823,0.0301,-0.6389,-0.225823,0.0301,-0.6389,-0.225823,0.074583,0.6391,-0.225823,0.074583,0.6391,-0.225823,0.0301,0.6391,-0.002826,0.0301,0.6391,-0.002826,0.074583,0.6391,-0.225823,0.074583,0.6391,-0.225823,0.0301,0.6391,-0.4159,0.0301,0.637632,-0.4159,0.020829,0.6391,-0.225823,0.0301,0.637632,-0.4159,0.020829,0.637632,-0.002826,0.020829,0.6391,-0.225823,0.0301,0.637632,-0.002826,0.020829,0.6391,-0.002826,0.0301,-0.637432,-0.002826,0.020829,-0.6389,0.4161,0.0301,-0.637432,0.4161,0.020829,-0.637432,-0.002826,0.020829,-0.626534,0.4161,0.005829,-0.626534,-0.4159,0.005829,-0.63317,-0.4159,0.012466,-0.63317,-0.4159,0.012466,-0.63317,0.4161,0.012466,-0.626534,0.4161,0.005829,0.63337,0.4161,0.012466,0.633371,-0.4159,0.012466,0.626734,-0.4159,0.005829,0.626734,-0.4159,0.005829,0.626734,0.4161,0.005829,0.61837,0.4161,0.001568,0.618371,-0.4159,0.001568,0.6091,-0.4159,0.0001,0.6091,-0.4159,0.0001,0.6091,0.4161,0.0001,0.61837,0.4161,0.001568,-0.6389,0.4161,0.074583,-0.6389,0.4161,0.0301,-0.6389,-0.002826,0.0301,-0.6389,-0.002826,0.0301,-0.6389,-0.002826,0.074583,-0.6389,0.4161,0.074583,-0.6089,-0.4159,0.0001,0.6091,-0.4159,0.0001,0.6091,-0.42517,0.001568,0.6091,-0.42517,0.001568,-0.6089,-0.425171,0.001568,-0.6089,-0.4159,0.0001,-0.6089,-0.425171,0.001568,0.6091,-0.42517,0.001568,0.6091,-0.433533,0.005829,0.6091,-0.433533,0.005829,-0.6089,-0.433534,0.005829,-0.6089,-0.425171,0.001568,-0.6089,-0.433534,0.005829,0.6091,-0.433533,0.005829,0.6091,-0.44017,0.012466,0.6091,-0.44017,0.012466,-0.6089,-0.440171,0.012466,-0.6089,-0.433534,0.005829,-0.6089,-0.440171,0.012466,0.6091,-0.44017,0.012466,0.6091,-0.444432,0.020829,0.6091,-0.444432,0.020829,-0.6089,-0.444432,0.020829,-0.6089,-0.440171,0.012466,-0.6089,-0.444432,0.020829,0.6091,-0.444432,0.020829,0.6091,-0.4459,0.0301,0.6091,-0.4459,0.0301,-0.6089,-0.4459,0.0301,-0.3999,0.428166,0.002993,-0.3999,0.420902,0.007614,0.0001,0.420902,0.007614,0.0001,0.420902,0.007614,0.4001,0.420902,0.007614,0.4001,0.428166,0.002993,0.0001,0.420902,0.007614,0.4001,0.428166,0.002993,0.0001,0.428166,0.002993,-0.3999,0.428166,0.002993,0.0001,0.420902,0.007614,0.0001,0.428166,0.002993,-0.3999,0.402661,0.045586,-0.3999,0.402661,0.074583,0.0001,0.402661,0.045586,0.0001,0.403948,0.034434,0.4001,0.403948,0.034434,0.4001,0.403948,0.034434,0.4001,0.407613,0.024192,0.0001,0.407613,0.024192,0.0001,0.407613,0.024192,-0.3999,0.413362,0.015154,-0.3999,0.413362,0.015154,-0.3999,0.407613,0.024192,0.0001,0.407613,0.024192,0.0001,0.413362,0.015154,-0.3999,0.420902,0.007614,-0.3999,0.420902,0.007614,-0.3999,0.413362,0.015154,0.0001,0.413362,0.015154,0.0001,0.403948,0.034434,0.0001,0.402661,0.045586,0.4001,0.402661,0.045586,0.4001,0.402661,0.045586,0.4001,0.403948,0.034434,0.0001,0.403948,0.034434,-0.626534,0.44037,0.074583,-0.633171,0.433733,0.074583,-0.637432,0.42537,0.074583,-0.626534,0.44037,0.074583,-0.637432,0.42537,0.074583,-0.6389,0.4161,0.074583,-0.626534,0.44037,0.074583,-0.6389,0.4161,0.074583,-0.6389,-0.002826,0.074583,-0.626534,0.44037,0.074583,-0.6389,-0.002826,0.074583,-0.573325,-0.002826,0.074583,-0.626534,0.44037,0.074583,-0.573325,0.049917,0.074583,-0.626534,0.44037,0.074583,-0.573325,0.186372,0.074583,-0.626534,0.44037,0.074583,-0.573325,0.322827,0.074583,-0.626534,0.44037,0.074583,-0.572878,0.32793,0.074583,-0.626534,0.44037,0.074583,-0.572279,0.330165,0.074583,-0.626534,0.44037,0.074583,-0.571552,0.332878,0.074583,-0.626534,0.44037,0.074583,-0.570574,0.334975,0.074583,-0.626534,0.44037,0.074583,-0.569387,0.337521,0.074583,-0.626534,0.44037,0.074583,-0.56806,0.339416,0.074583,-0.626534,0.44037,0.074583,-0.566449,0.341717,0.074583,-0.626534,0.44037,0.074583,-0.562827,0.345339,0.074583,-0.626534,0.44037,0.074583,-0.55863,0.348278,0.074583,-0.626534,0.44037,0.074583,-0.556534,0.349256,0.074583,-0.626534,0.44037,0.074583,-0.553988,0.350443,0.074583,-0.626534,0.44037,0.074583,-0.54904,0.351769,0.074583,-0.626534,0.44037,0.074583,-0.543936,0.352215,0.074583,0.567423,0.049917,0.074583,0.567423,-0.002826,0.074583,0.6391,-0.002826,0.074583,0.6391,-0.002826,0.074583,0.6391,0.4161,0.074583,0.567423,0.186372,0.074583,0.6391,0.4161,0.074583,0.567423,0.322827,0.074583,0.6391,0.4161,0.074583,0.566977,0.32793,0.074583,0.6391,0.4161,0.074583,0.566249,0.330643,0.074583,0.6391,0.4161,0.074583,0.565651,0.332878,0.074583,0.6391,0.4161,0.074583,0.564464,0.335424,0.074583,0.6391,0.4161,0.074583,0.563486,0.337521,0.074583,0.6391,0.4161,0.074583,0.561875,0.339822,0.074583,0.6391,0.4161,0.074583,0.560548,0.341717,0.074583,0.6391,0.4161,0.074583,0.556925,0.345339,0.074583,0.6391,0.4161,0.074583,0.63337,0.433734,0.074583,0.626733,0.440371,0.074583,0.61837,0.444632,0.074583,0.637632,0.425371,0.074583,0.63337,0.433734,0.074583,0.61837,0.444632,0.074583,0.6391,0.4161,0.074583,0.637632,0.425371,0.074583,0.61837,0.444632,0.074583,0.6391,0.4161,0.074583,0.61837,0.444632,0.074583,0.6091,0.4461,0.074583,0.6391,0.4161,0.074583,0.6091,0.4461,0.074583,0.552729,0.348278,0.074583,0.556925,0.345339,0.074583,0.6091,0.4461,0.074583,0.550183,0.349465,0.074583,0.552729,0.348278,0.074583,0.6091,0.4461,0.074583,0.548086,0.350443,0.074583,0.6091,0.4461,0.074583,0.545373,0.35117,0.074583,0.6091,0.4461,0.074583,0.543138,0.351769,0.074583,0.6091,0.4461,0.074583,0.538035,0.352215,0.074583,0.6091,0.4461,0.074583,0.6091,0.4461,0.074583,0.4001,0.4461,0.074583,0.4001,0.402661,0.074583,0.6091,0.4461,0.074583,0.4001,0.402661,0.074583,0.350336,0.352215,0.074583,0.4001,0.402661,0.074583,0.4001,0.402661,0.074583,0.0001,0.402661,0.074583,-0.079397,0.352215,0.074583,0.0001,0.402661,0.074583,0.0001,0.402661,0.074583,-0.3999,0.402661,0.074583,-0.3999,0.402661,0.074583,-0.626534,0.44037,0.074583,-0.3999,0.402661,0.074583,-0.3999,0.402661,0.074583,-0.3999,0.4461,0.074583,-0.6089,0.4461,0.074583,-0.3999,0.402661,0.074583,-0.6089,0.4461,0.074583,-0.618171,0.444632,0.074583,-0.626534,0.44037,0.074583,-0.3999,0.402661,0.074583,-0.618171,0.444632,0.074583,-0.548669,0.349665,0.072448,-0.543936,0.350079,0.072448,-0.543936,0.352215,0.074583,-0.543936,0.352215,0.074583,-0.54904,0.351769,0.074583,-0.548669,0.349665,0.072448,-0.553257,0.348436,0.072448,-0.548669,0.349665,0.072448,-0.54904,0.351769,0.074583,-0.54904,0.351769,0.074583,-0.553988,0.350443,0.074583,-0.553257,0.348436,0.072448,-0.556534,0.349256,0.074583,-0.55863,0.348278,0.074583,-0.557563,0.346428,0.072448,-0.556534,0.349256,0.074583,-0.557563,0.346428,0.072448,-0.553257,0.348436,0.072448,-0.556534,0.349256,0.074583,-0.553257,0.348436,0.072448,-0.553988,0.350443,0.074583,-0.561454,0.343703,0.072448,-0.557563,0.346428,0.072448,-0.55863,0.348278,0.074583,-0.55863,0.348278,0.074583,-0.562827,0.345339,0.074583,-0.561454,0.343703,0.072448,-0.564813,0.340344,0.072448,-0.561454,0.343703,0.072448,-0.562827,0.345339,0.074583,-0.562827,0.345339,0.074583,-0.566449,0.341717,0.074583,-0.564813,0.340344,0.072448,-0.56806,0.339416,0.074583,-0.569387,0.337521,0.074583,-0.567538,0.336453,0.072448,-0.56806,0.339416,0.074583,-0.567538,0.336453,0.072448,-0.564813,0.340344,0.072448,-0.56806,0.339416,0.074583,-0.564813,0.340344,0.072448,-0.566449,0.341717,0.074583,-0.570574,0.334975,0.074583,-0.571552,0.332878,0.074583,-0.569545,0.332148,0.072448,-0.570574,0.334975,0.074583,-0.569545,0.332148,0.072448,-0.567538,0.336453,0.072448,-0.570574,0.334975,0.074583,-0.567538,0.336453,0.072448,-0.569387,0.337521,0.074583,-0.572279,0.330165,0.074583,-0.572878,0.32793,0.074583,-0.570775,0.327559,0.072448,-0.572279,0.330165,0.074583,-0.570775,0.327559,0.072448,-0.569545,0.332148,0.072448,-0.572279,0.330165,0.074583,-0.569545,0.332148,0.072448,-0.571552,0.332878,0.074583,-0.571189,0.322827,0.072448,-0.570775,0.327559,0.072448,-0.572878,0.32793,0.074583,-0.572878,0.32793,0.074583,-0.573325,0.322827,0.074583,-0.571189,0.322827,0.072448,-0.573325,0.186372,0.074583,-0.571189,0.186372,0.072448,-0.571189,0.322827,0.072448,-0.573325,0.322827,0.074583,-0.573325,0.186372,0.074583,-0.571189,0.049917,0.072448,-0.573325,0.186372,0.074583,-0.573325,0.186372,0.074583,-0.573325,0.049917,0.074583,-0.571189,0.049917,0.072448,-0.570775,-0.091271,0.072448,-0.571189,-0.086538,0.072448,-0.573325,-0.086538,0.074583,-0.573325,-0.086538,0.074583,-0.572878,-0.091641,0.074583,-0.570775,-0.091271,0.072448,-0.572151,-0.094355,0.074583,-0.571552,-0.09659,0.074583,-0.569545,-0.095859,0.072448,-0.572151,-0.094355,0.074583,-0.569545,-0.095859,0.072448,-0.570775,-0.091271,0.072448,-0.572151,-0.094355,0.074583,-0.570775,-0.091271,0.072448,-0.572878,-0.091641,0.074583,-0.570365,-0.099135,0.074583,-0.569387,-0.101232,0.074583,-0.567538,-0.100164,0.072448,-0.570365,-0.099135,0.074583,-0.567538,-0.100164,0.072448,-0.569545,-0.095859,0.072448,-0.570365,-0.099135,0.074583,-0.569545,-0.095859,0.072448,-0.571552,-0.09659,0.074583,-0.567776,-0.103533,0.074583,-0.566449,-0.105429,0.074583,-0.564813,-0.104056,0.072448,-0.567776,-0.103533,0.074583,-0.564813,-0.104056,0.072448,-0.567538,-0.100164,0.072448,-0.567776,-0.103533,0.074583,-0.567538,-0.100164,0.072448,-0.569387,-0.101232,0.074583,-0.561454,-0.107415,0.072448,-0.564813,-0.104056,0.072448,-0.566449,-0.105429,0.074583,-0.566449,-0.105429,0.074583,-0.562827,-0.109051,0.074583,-0.561454,-0.107415,0.072448,-0.557563,-0.11014,0.072448,-0.561454,-0.107415,0.072448,-0.562827,-0.109051,0.074583,-0.562827,-0.109051,0.074583,-0.558631,-0.111989,0.074583,-0.557563,-0.11014,0.072448,-0.556085,-0.113176,0.074583,-0.553988,-0.114154,0.074583,-0.553257,-0.112147,0.072448,-0.556085,-0.113176,0.074583,-0.553257,-0.112147,0.072448,-0.557563,-0.11014,0.072448,-0.556085,-0.113176,0.074583,-0.557563,-0.11014,0.072448,-0.558631,-0.111989,0.074583,-0.551275,-0.114881,0.074583,-0.54904,-0.11548,0.074583,-0.548669,-0.113377,0.072448,-0.551275,-0.114881,0.074583,-0.548669,-0.113377,0.072448,-0.553257,-0.112147,0.072448,-0.553257,-0.112147,0.072448,-0.553988,-0.114154,0.074583,-0.543936,-0.113791,0.072448,-0.548669,-0.113377,0.072448,-0.54904,-0.11548,0.074583,-0.54904,-0.11548,0.074583,-0.543936,-0.115926,0.074583,-0.543936,-0.113791,0.072448,0.538035,-0.115926,0.074583,0.538035,-0.113791,0.072448,-0.543936,-0.113791,0.072448,-0.543936,-0.115926,0.074583,0.542767,-0.113377,0.072448,0.538035,-0.113791,0.072448,0.538035,-0.115926,0.074583,0.538035,-0.115926,0.074583,0.543138,-0.11548,0.074583,0.545851,-0.114753,0.074583,0.548086,-0.114154,0.074583,0.547356,-0.112147,0.072448,0.545851,-0.114753,0.074583,0.547356,-0.112147,0.072448,0.542767,-0.113377,0.072448,0.543138,-0.11548,0.074583,0.551661,-0.11014,0.072448,0.547356,-0.112147,0.072448,0.548086,-0.114154,0.074583,0.548086,-0.114154,0.074583,0.552729,-0.111989,0.074583,0.551661,-0.11014,0.072448,0.555552,-0.107415,0.072448,0.551661,-0.11014,0.072448,0.552729,-0.111989,0.074583,0.552729,-0.111989,0.074583,0.556925,-0.109051,0.074583,0.555552,-0.107415,0.072448,0.558911,-0.104056,0.072448,0.555552,-0.107415,0.072448,0.556925,-0.109051,0.074583,0.556925,-0.109051,0.074583,0.560547,-0.105429,0.074583,0.558911,-0.104056,0.072448,0.562159,-0.103128,0.074583,0.563486,-0.101232,0.074583,0.561636,-0.100164,0.072448,0.562159,-0.103128,0.074583,0.561636,-0.100164,0.072448,0.558911,-0.104056,0.072448,0.562159,-0.103128,0.074583,0.558911,-0.104056,0.072448,0.560547,-0.105429,0.074583,0.564673,-0.098686,0.074583,0.565651,-0.09659,0.074583,0.563644,-0.095859,0.072448,0.564673,-0.098686,0.074583,0.563644,-0.095859,0.072448,0.561636,-0.100164,0.072448,0.564673,-0.098686,0.074583,0.561636,-0.100164,0.072448,0.563486,-0.101232,0.074583,0.566378,-0.093876,0.074583,0.566976,-0.091641,0.074583,0.564873,-0.091271,0.072448,0.566378,-0.093876,0.074583,0.564873,-0.091271,0.072448,0.563644,-0.095859,0.072448,0.566378,-0.093876,0.074583,0.563644,-0.095859,0.072448,0.565651,-0.09659,0.074583,0.565287,-0.086538,0.072448,0.564873,-0.091271,0.072448,0.566976,-0.091641,0.074583,0.566976,-0.091641,0.074583,0.567423,-0.086538,0.074583,0.565287,-0.086538,0.072448,0.565287,0.186372,0.072448,0.565287,0.049917,0.072448,0.567423,0.049917,0.074583,0.567423,0.049917,0.074583,0.567423,0.186372,0.074583,0.565287,0.186372,0.072448,0.565287,0.322827,0.072448,0.567423,0.186372,0.074583,0.567423,0.186372,0.074583,0.567423,0.322827,0.074583,0.564873,0.327559,0.072448,0.565287,0.322827,0.072448,0.567423,0.322827,0.074583,0.567423,0.322827,0.074583,0.566977,0.32793,0.074583,0.564873,0.327559,0.072448,0.566249,0.330643,0.074583,0.565651,0.332878,0.074583,0.563644,0.332148,0.072448,0.566249,0.330643,0.074583,0.563644,0.332148,0.072448,0.564873,0.327559,0.072448,0.566249,0.330643,0.074583,0.564873,0.327559,0.072448,0.566977,0.32793,0.074583,0.564464,0.335424,0.074583,0.563486,0.337521,0.074583,0.561636,0.336453,0.072448,0.564464,0.335424,0.074583,0.561636,0.336453,0.072448,0.563644,0.332148,0.072448,0.564464,0.335424,0.074583,0.565651,0.332878,0.074583,0.561875,0.339822,0.074583,0.560548,0.341717,0.074583,0.558912,0.340344,0.072448,0.561875,0.339822,0.074583,0.558912,0.340344,0.072448,0.561636,0.336453,0.072448,0.561875,0.339822,0.074583,0.561636,0.336453,0.072448,0.563486,0.337521,0.074583,0.555552,0.343703,0.072448,0.558912,0.340344,0.072448,0.560548,0.341717,0.074583,0.560548,0.341717,0.074583,0.556925,0.345339,0.074583,0.555552,0.343703,0.072448,0.551661,0.346428,0.072448,0.555552,0.343703,0.072448,0.556925,0.345339,0.074583,0.556925,0.345339,0.074583,0.552729,0.348278,0.074583,0.551661,0.346428,0.072448,0.550183,0.349465,0.074583,0.548086,0.350443,0.074583,0.547356,0.348436,0.072448,0.550183,0.349465,0.074583,0.551661,0.346428,0.072448,0.550183,0.349465,0.074583,0.551661,0.346428,0.072448,0.552729,0.348278,0.074583,0.545373,0.35117,0.074583,0.543138,0.351769,0.074583,0.542767,0.349665,0.072448,0.545373,0.35117,0.074583,0.542767,0.349665,0.072448,0.547356,0.348436,0.072448,0.545373,0.35117,0.074583,0.547356,0.348436,0.072448,0.548086,0.350443,0.074583,0.538035,0.350079,0.072448,0.542767,0.349665,0.072448,0.543138,0.351769,0.074583,0.543138,0.351769,0.074583,0.538035,0.352215,0.074583,0.538035,0.350079,0.072448,-0.546454,0.337107,0.067876,-0.543936,0.337328,0.067876,-0.543936,0.344025,0.070436,-0.543936,0.344025,0.070436,-0.547617,0.343703,0.070436,-0.546454,0.337107,0.067876,-0.543936,0.350079,0.072448,-0.548669,0.349665,0.072448,-0.547617,0.343703,0.070436,-0.543936,0.344025,0.070436,-0.548896,0.336453,0.067876,-0.546454,0.337107,0.067876,-0.547617,0.343703,0.070436,-0.547617,0.343703,0.070436,-0.551187,0.342747,0.070436,-0.548896,0.336453,0.067876,-0.548669,0.349665,0.072448,-0.553257,0.348436,0.072448,-0.551187,0.342747,0.070436,-0.551187,0.342747,0.070436,-0.547617,0.343703,0.070436,-0.548669,0.349665,0.072448,-0.551187,0.335385,0.067876,-0.548896,0.336453,0.067876,-0.551187,0.342747,0.070436,-0.551187,0.342747,0.070436,-0.554536,0.341185,0.070436,-0.551187,0.335385,0.067876,-0.553257,0.348436,0.072448,-0.557563,0.346428,0.072448,-0.554536,0.341185,0.070436,-0.554536,0.341185,0.070436,-0.551187,0.342747,0.070436,-0.553257,0.348436,0.072448,-0.554536,0.341185,0.070436,-0.557563,0.339066,0.070436,-0.553257,0.333935,0.067876,-0.553257,0.333935,0.067876,-0.551187,0.335385,0.067876,-0.554536,0.341185,0.070436,-0.557563,0.346428,0.072448,-0.561454,0.343703,0.072448,-0.557563,0.339066,0.070436,-0.554536,0.341185,0.070436,-0.557563,0.339066,0.070436,-0.560175,0.336453,0.070436,-0.555045,0.332148,0.067876,-0.555045,0.332148,0.067876,-0.553257,0.333935,0.067876,-0.557563,0.339066,0.070436,-0.561454,0.343703,0.072448,-0.564813,0.340344,0.072448,-0.560175,0.336453,0.070436,-0.557563,0.339066,0.070436,-0.556494,0.330077,0.067876,-0.555045,0.332148,0.067876,-0.560175,0.336453,0.070436,-0.560175,0.336453,0.070436,-0.562295,0.333426,0.070436,-0.556494,0.330077,0.067876,-0.564813,0.340344,0.072448,-0.567538,0.336453,0.072448,-0.562295,0.333426,0.070436,-0.562295,0.333426,0.070436,-0.560175,0.336453,0.070436,-0.564813,0.340344,0.072448,-0.562295,0.333426,0.070436,-0.563857,0.330077,0.070436,-0.557563,0.327786,0.067876,-0.557563,0.327786,0.067876,-0.556494,0.330077,0.067876,-0.562295,0.333426,0.070436,-0.567538,0.336453,0.072448,-0.569545,0.332148,0.072448,-0.563857,0.330077,0.070436,-0.563857,0.330077,0.070436,-0.562295,0.333426,0.070436,-0.567538,0.336453,0.072448,-0.563857,0.330077,0.070436,-0.564813,0.326508,0.070436,-0.558217,0.325345,0.067876,-0.558217,0.325345,0.067876,-0.557563,0.327786,0.067876,-0.563857,0.330077,0.070436,-0.569545,0.332148,0.072448,-0.570775,0.327559,0.072448,-0.564813,0.326508,0.070436,-0.564813,0.326508,0.070436,-0.563857,0.330077,0.070436,-0.569545,0.332148,0.072448,-0.558437,0.322827,0.067876,-0.558217,0.325345,0.067876,-0.564813,0.326508,0.070436,-0.564813,0.326508,0.070436,-0.565135,0.322827,0.070436,-0.558437,0.322827,0.067876,-0.570775,0.327559,0.072448,-0.571189,0.322827,0.072448,-0.565135,0.322827,0.070436,-0.564813,0.326508,0.070436,-0.558437,0.322827,0.067876,-0.565135,0.322827,0.070436,-0.565135,0.186372,0.070436,-0.565135,0.186372,0.070436,-0.558437,0.186372,0.067876,-0.558437,0.322827,0.067876,-0.565135,0.186372,0.070436,-0.565135,0.049917,0.070436,-0.565135,0.049917,0.070436,-0.558437,0.049917,0.067876,-0.558437,0.186372,0.067876,-0.565135,-0.086538,0.070436,-0.565135,-0.086538,0.070436,-0.558437,-0.086538,0.067876,-0.558437,0.049917,0.067876,-0.558217,-0.089056,0.067876,-0.558437,-0.086538,0.067876,-0.565135,-0.086538,0.070436,-0.565135,-0.086538,0.070436,-0.564813,-0.090219,0.070436,-0.558217,-0.089056,0.067876,-0.571189,-0.086538,0.072448,-0.570775,-0.091271,0.072448,-0.564813,-0.090219,0.070436,-0.564813,-0.090219,0.070436,-0.565135,-0.086538,0.070436,-0.571189,-0.086538,0.072448,-0.564813,-0.090219,0.070436,-0.563857,-0.093789,0.070436,-0.557563,-0.091498,0.067876,-0.557563,-0.091498,0.067876,-0.558217,-0.089056,0.067876,-0.564813,-0.090219,0.070436,-0.570775,-0.091271,0.072448,-0.569545,-0.095859,0.072448,-0.563857,-0.093789,0.070436,-0.563857,-0.093789,0.070436,-0.564813,-0.090219,0.070436,-0.570775,-0.091271,0.072448,-0.563857,-0.093789,0.070436,-0.562295,-0.097138,0.070436,-0.556494,-0.093789,0.067876,-0.556494,-0.093789,0.067876,-0.557563,-0.091498,0.067876,-0.563857,-0.093789,0.070436,-0.569545,-0.095859,0.072448,-0.567538,-0.100164,0.072448,-0.562295,-0.097138,0.070436,-0.562295,-0.097138,0.070436,-0.563857,-0.093789,0.070436,-0.569545,-0.095859,0.072448,-0.562295,-0.097138,0.070436,-0.560176,-0.100164,0.070436,-0.555045,-0.095859,0.067876,-0.555045,-0.095859,0.067876,-0.556494,-0.093789,0.067876,-0.562295,-0.097138,0.070436,-0.567538,-0.100164,0.072448,-0.564813,-0.104056,0.072448,-0.560176,-0.100164,0.070436,-0.560176,-0.100164,0.070436,-0.562295,-0.097138,0.070436,-0.567538,-0.100164,0.072448,-0.560176,-0.100164,0.070436,-0.557563,-0.102777,0.070436,-0.553257,-0.097646,0.067876,-0.553257,-0.097646,0.067876,-0.555045,-0.095859,0.067876,-0.560176,-0.100164,0.070436,-0.564813,-0.104056,0.072448,-0.561454,-0.107415,0.072448,-0.557563,-0.102777,0.070436,-0.557563,-0.102777,0.070436,-0.560176,-0.100164,0.070436,-0.564813,-0.104056,0.072448,-0.551187,-0.099096,0.067876,-0.553257,-0.097646,0.067876,-0.557563,-0.102777,0.070436,-0.557563,-0.102777,0.070436,-0.554536,-0.104897,0.070436,-0.551187,-0.099096,0.067876,-0.561454,-0.107415,0.072448,-0.557563,-0.11014,0.072448,-0.554536,-0.104897,0.070436,-0.557563,-0.102777,0.070436,-0.561454,-0.107415,0.072448,-0.548896,-0.100164,0.067876,-0.551187,-0.099096,0.067876,-0.554536,-0.104897,0.070436,-0.554536,-0.104897,0.070436,-0.551187,-0.106458,0.070436,-0.548896,-0.100164,0.067876,-0.546455,-0.100819,0.067876,-0.548896,-0.100164,0.067876,-0.551187,-0.106458,0.070436,-0.551187,-0.106458,0.070436,-0.547618,-0.107415,0.070436,-0.546455,-0.100819,0.067876,-0.553257,-0.112147,0.072448,-0.548669,-0.113377,0.072448,-0.547618,-0.107415,0.070436,-0.547618,-0.107415,0.070436,-0.551187,-0.106458,0.070436,-0.553257,-0.112147,0.072448,-0.543936,-0.101039,0.067876,-0.546455,-0.100819,0.067876,-0.547618,-0.107415,0.070436,-0.547618,-0.107415,0.070436,-0.543936,-0.107737,0.070436,-0.543936,-0.101039,0.067876,-0.548669,-0.113377,0.072448,-0.543936,-0.113791,0.072448,-0.543936,-0.107737,0.070436,-0.547618,-0.107415,0.070436,-0.548669,-0.113377,0.072448,0.538035,-0.101039,0.067876,-0.543936,-0.101039,0.067876,-0.543936,-0.107737,0.070436,-0.543936,-0.107737,0.070436,0.538035,-0.107737,0.070436,0.538035,-0.101039,0.067876,0.540553,-0.100819,0.067876,0.538035,-0.101039,0.067876,0.538035,-0.107737,0.070436,0.538035,-0.107737,0.070436,0.541716,-0.107415,0.070436,0.540553,-0.100819,0.067876,0.538035,-0.113791,0.072448,0.542767,-0.113377,0.072448,0.541716,-0.107415,0.070436,0.541716,-0.107415,0.070436,0.538035,-0.107737,0.070436,0.538035,-0.113791,0.072448,0.542994,-0.100164,0.067876,0.540553,-0.100819,0.067876,0.541716,-0.107415,0.070436,0.541716,-0.107415,0.070436,0.545285,-0.106458,0.070436,0.542994,-0.100164,0.067876,0.542767,-0.113377,0.072448,0.547356,-0.112147,0.072448,0.545285,-0.106458,0.070436,0.545285,-0.106458,0.070436,0.541716,-0.107415,0.070436,0.542767,-0.113377,0.072448,0.545285,-0.099096,0.067876,0.542994,-0.100164,0.067876,0.545285,-0.106458,0.070436,0.545285,-0.106458,0.070436,0.548634,-0.104897,0.070436,0.545285,-0.099096,0.067876,0.547356,-0.112147,0.072448,0.551661,-0.11014,0.072448,0.548634,-0.104897,0.070436,0.548634,-0.104897,0.070436,0.545285,-0.106458,0.070436,0.547356,-0.112147,0.072448,0.548634,-0.104897,0.070436,0.551661,-0.102777,0.070436,0.547356,-0.097646,0.067876,0.547356,-0.097646,0.067876,0.545285,-0.099096,0.067876,0.548634,-0.104897,0.070436,0.551661,-0.11014,0.072448,0.555552,-0.107415,0.072448,0.551661,-0.102777,0.070436,0.551661,-0.102777,0.070436,0.548634,-0.104897,0.070436,0.551661,-0.11014,0.072448,0.551661,-0.102777,0.070436,0.554274,-0.100164,0.070436,0.549143,-0.095859,0.067876,0.549143,-0.095859,0.067876,0.547356,-0.097646,0.067876,0.551661,-0.102777,0.070436,0.555552,-0.107415,0.072448,0.558911,-0.104056,0.072448,0.554274,-0.100164,0.070436,0.551661,-0.102777,0.070436,0.555552,-0.107415,0.072448,0.550593,-0.093789,0.067876,0.549143,-0.095859,0.067876,0.554274,-0.100164,0.070436,0.554274,-0.100164,0.070436,0.556393,-0.097138,0.070436,0.550593,-0.093789,0.067876,0.558911,-0.104056,0.072448,0.561636,-0.100164,0.072448,0.556393,-0.097138,0.070436,0.556393,-0.097138,0.070436,0.554274,-0.100164,0.070436,0.558911,-0.104056,0.072448,0.556393,-0.097138,0.070436,0.557955,-0.093789,0.070436,0.551661,-0.091498,0.067876,0.551661,-0.091498,0.067876,0.550593,-0.093789,0.067876,0.556393,-0.097138,0.070436,0.561636,-0.100164,0.072448,0.563644,-0.095859,0.072448,0.557955,-0.093789,0.070436,0.557955,-0.093789,0.070436,0.556393,-0.097138,0.070436,0.561636,-0.100164,0.072448,0.557955,-0.093789,0.070436,0.558911,-0.090219,0.070436,0.552315,-0.089056,0.067876,0.552315,-0.089056,0.067876,0.551661,-0.091498,0.067876,0.557955,-0.093789,0.070436,0.563644,-0.095859,0.072448,0.564873,-0.091271,0.072448,0.558911,-0.090219,0.070436,0.558911,-0.090219,0.070436,0.557955,-0.093789,0.070436,0.563644,-0.095859,0.072448,0.552535,-0.086538,0.067876,0.552315,-0.089056,0.067876,0.558911,-0.090219,0.070436,0.558911,-0.090219,0.070436,0.559233,-0.086538,0.070436,0.552535,-0.086538,0.067876,0.564873,-0.091271,0.072448,0.565287,-0.086538,0.072448,0.559233,-0.086538,0.070436,0.558911,-0.090219,0.070436,0.564873,-0.091271,0.072448,0.552535,-0.086538,0.067876,0.559233,-0.086538,0.070436,0.559234,0.049917,0.070436,0.559234,0.049917,0.070436,0.552536,0.049917,0.067876,0.552535,-0.086538,0.067876,0.552536,0.049917,0.067876,0.559233,0.186372,0.070436,0.559233,0.186372,0.070436,0.552535,0.186372,0.067876,0.552536,0.049917,0.067876,0.559234,0.322827,0.070436,0.559234,0.322827,0.070436,0.552536,0.322827,0.067876,0.552535,0.186372,0.067876,0.552315,0.325345,0.067876,0.552536,0.322827,0.067876,0.559234,0.322827,0.070436,0.559234,0.322827,0.070436,0.558912,0.326508,0.070436,0.552315,0.325345,0.067876,0.565287,0.322827,0.072448,0.564873,0.327559,0.072448,0.558912,0.326508,0.070436,0.558912,0.326508,0.070436,0.559234,0.322827,0.070436,0.565287,0.322827,0.072448,0.558912,0.326508,0.070436,0.557955,0.330077,0.070436,0.551661,0.327786,0.067876,0.551661,0.327786,0.067876,0.552315,0.325345,0.067876,0.558912,0.326508,0.070436,0.564873,0.327559,0.072448,0.563644,0.332148,0.072448,0.557955,0.330077,0.070436,0.557955,0.330077,0.070436,0.558912,0.326508,0.070436,0.564873,0.327559,0.072448,0.557955,0.330077,0.070436,0.556394,0.333426,0.070436,0.550593,0.330077,0.067876,0.550593,0.330077,0.067876,0.551661,0.327786,0.067876,0.557955,0.330077,0.070436,0.563644,0.332148,0.072448,0.561636,0.336453,0.072448,0.556394,0.333426,0.070436,0.556394,0.333426,0.070436,0.557955,0.330077,0.070436,0.563644,0.332148,0.072448,0.556394,0.333426,0.070436,0.554274,0.336453,0.070436,0.549143,0.332148,0.067876,0.549143,0.332148,0.067876,0.550593,0.330077,0.067876,0.556394,0.333426,0.070436,0.561636,0.336453,0.072448,0.558912,0.340344,0.072448,0.554274,0.336453,0.070436,0.554274,0.336453,0.070436,0.556394,0.333426,0.070436,0.561636,0.336453,0.072448,0.554274,0.336453,0.070436,0.551661,0.339066,0.070436,0.547356,0.333935,0.067876,0.547356,0.333935,0.067876,0.549143,0.332148,0.067876,0.554274,0.336453,0.070436,0.558912,0.340344,0.072448,0.555552,0.343703,0.072448,0.551661,0.339066,0.070436,0.551661,0.339066,0.070436,0.554274,0.336453,0.070436,0.558912,0.340344,0.072448,0.545285,0.335385,0.067876,0.547356,0.333935,0.067876,0.551661,0.339066,0.070436,0.551661,0.339066,0.070436,0.548634,0.341185,0.070436,0.545285,0.335385,0.067876,0.555552,0.343703,0.072448,0.551661,0.346428,0.072448,0.548634,0.341185,0.070436,0.548634,0.341185,0.070436,0.551661,0.339066,0.070436,0.555552,0.343703,0.072448,0.542994,0.336453,0.067876,0.545285,0.335385,0.067876,0.548634,0.341185,0.070436,0.548634,0.341185,0.070436,0.545285,0.342747,0.070436,0.542994,0.336453,0.067876,0.540553,0.337107,0.067876,0.542994,0.336453,0.067876,0.545285,0.342747,0.070436,0.545285,0.342747,0.070436,0.541716,0.343703,0.070436,0.540553,0.337107,0.067876,0.547356,0.348436,0.072448,0.542767,0.349665,0.072448,0.541716,0.343703,0.070436,0.541716,0.343703,0.070436,0.545285,0.342747,0.070436,0.547356,0.348436,0.072448,0.538035,0.337328,0.067876,0.540553,0.337107,0.067876,0.541716,0.343703,0.070436,0.541716,0.343703,0.070436,0.538035,0.344025,0.070436,0.538035,0.337328,0.067876,0.542767,0.349665,0.072448,0.538035,0.350079,0.072448,0.538035,0.344025,0.070436,0.541716,0.343703,0.070436,-0.543936,0.322827,0.065319,-0.543936,0.330189,0.065963,-0.545215,0.330077,0.065963,-0.543936,0.337328,0.067876,-0.546454,0.337107,0.067876,-0.545215,0.330077,0.065963,-0.545215,0.330077,0.065963,-0.543936,0.330189,0.065963,-0.543936,0.337328,0.067876,-0.543936,0.322827,0.065319,-0.545215,0.330077,0.065963,-0.546454,0.329745,0.065963,-0.543936,0.322827,0.065319,-0.546454,0.329745,0.065963,-0.547617,0.329203,0.065963,-0.543936,0.322827,0.065319,-0.547617,0.329203,0.065963,-0.548669,0.328467,0.065963,-0.551187,0.335385,0.067876,-0.553257,0.333935,0.067876,-0.548669,0.328467,0.065963,-0.548669,0.328467,0.065963,-0.547617,0.329203,0.065963,-0.551187,0.335385,0.067876,-0.543936,0.322827,0.065319,-0.548669,0.328467,0.065963,-0.549576,0.327559,0.065963,-0.543936,0.322827,0.065319,-0.549576,0.327559,0.065963,-0.550312,0.326508,0.065963,-0.555045,0.332148,0.067876,-0.556494,0.330077,0.067876,-0.550312,0.326508,0.065963,-0.550312,0.326508,0.065963,-0.549576,0.327559,0.065963,-0.555045,0.332148,0.067876,-0.543936,0.322827,0.065319,-0.550312,0.326508,0.065963,-0.550855,0.325345,0.065963,-0.556494,0.330077,0.067876,-0.557563,0.327786,0.067876,-0.550855,0.325345,0.065963,-0.550855,0.325345,0.065963,-0.550312,0.326508,0.065963,-0.556494,0.330077,0.067876,-0.543936,0.322827,0.065319,-0.550855,0.325345,0.065963,-0.551187,0.324105,0.065963,-0.557563,0.327786,0.067876,-0.558217,0.325345,0.067876,-0.551187,0.324105,0.065963,-0.551187,0.324105,0.065963,-0.550855,0.325345,0.065963,-0.557563,0.327786,0.067876,-0.543936,0.322827,0.065319,-0.551187,0.324105,0.065963,-0.551299,0.322827,0.065963,-0.558217,0.325345,0.067876,-0.558437,0.322827,0.067876,-0.551299,0.322827,0.065963,-0.551299,0.322827,0.065963,-0.551187,0.324105,0.065963,-0.558217,0.325345,0.067876,-0.543936,-0.086538,0.065319,-0.551299,-0.086538,0.065963,-0.551187,-0.087817,0.065963,-0.558437,-0.086538,0.067876,-0.558217,-0.089056,0.067876,-0.551187,-0.087817,0.065963,-0.551187,-0.087817,0.065963,-0.551299,-0.086538,0.065963,-0.558437,-0.086538,0.067876,-0.543936,-0.086538,0.065319,-0.551187,-0.087817,0.065963,-0.550855,-0.089056,0.065963,-0.558217,-0.089056,0.067876,-0.557563,-0.091498,0.067876,-0.550855,-0.089056,0.065963,-0.550855,-0.089056,0.065963,-0.551187,-0.087817,0.065963,-0.558217,-0.089056,0.067876,-0.543936,-0.086538,0.065319,-0.550855,-0.089056,0.065963,-0.550312,-0.090219,0.065963,-0.557563,-0.091498,0.067876,-0.556494,-0.093789,0.067876,-0.550312,-0.090219,0.065963,-0.550312,-0.090219,0.065963,-0.550855,-0.089056,0.065963,-0.557563,-0.091498,0.067876,-0.543936,-0.086538,0.065319,-0.550312,-0.090219,0.065963,-0.549576,-0.091271,0.065963,-0.556494,-0.093789,0.067876,-0.555045,-0.095859,0.067876,-0.549576,-0.091271,0.065963,-0.549576,-0.091271,0.065963,-0.550312,-0.090219,0.065963,-0.556494,-0.093789,0.067876,-0.543936,-0.086538,0.065319,-0.549576,-0.091271,0.065963,-0.548669,-0.092178,0.065963,-0.543936,-0.086538,0.065319,-0.548669,-0.092178,0.065963,-0.547618,-0.092914,0.065963,-0.553257,-0.097646,0.067876,-0.551187,-0.099096,0.067876,-0.547618,-0.092914,0.065963,-0.547618,-0.092914,0.065963,-0.548669,-0.092178,0.065963,-0.553257,-0.097646,0.067876,-0.543936,-0.086538,0.065319,-0.547618,-0.092914,0.065963,-0.546455,-0.093456,0.065963,-0.543936,-0.086538,0.065319,-0.546455,-0.093456,0.065963,-0.545215,-0.093789,0.065963,-0.543936,-0.086538,0.065319,-0.545215,-0.093789,0.065963,-0.543936,-0.0939,0.065963,-0.546455,-0.100819,0.067876,-0.543936,-0.101039,0.067876,-0.543936,-0.0939,0.065963,-0.543936,-0.0939,0.065963,-0.545215,-0.093789,0.065963,-0.546455,-0.100819,0.067876,0.538035,-0.086538,0.065319,-0.543936,-0.086538,0.065319,-0.543936,-0.0939,0.065963,-0.543936,-0.0939,0.065963,0.538035,-0.0939,0.065963,0.538035,-0.086538,0.065319,0.538035,-0.0939,0.065963,0.539313,-0.093789,0.065963,0.538035,-0.101039,0.067876,0.540553,-0.100819,0.067876,0.539313,-0.093789,0.065963,0.539313,-0.093789,0.065963,0.538035,-0.0939,0.065963,0.538035,-0.101039,0.067876,0.538035,-0.086538,0.065319,0.539313,-0.093789,0.065963,0.540553,-0.093456,0.065963,0.538035,-0.086538,0.065319,0.540553,-0.093456,0.065963,0.541716,-0.092914,0.065963,0.538035,-0.086538,0.065319,0.541716,-0.092914,0.065963,0.542767,-0.092178,0.065963,0.545285,-0.099096,0.067876,0.547356,-0.097646,0.067876,0.542767,-0.092178,0.065963,0.542767,-0.092178,0.065963,0.541716,-0.092914,0.065963,0.545285,-0.099096,0.067876,0.538035,-0.086538,0.065319,0.542767,-0.092178,0.065963,0.543675,-0.091271,0.065963,0.538035,-0.086538,0.065319,0.543675,-0.091271,0.065963,0.544411,-0.090219,0.065963,0.549143,-0.095859,0.067876,0.550593,-0.093789,0.067876,0.544411,-0.090219,0.065963,0.544411,-0.090219,0.065963,0.543675,-0.091271,0.065963,0.549143,-0.095859,0.067876,0.538035,-0.086538,0.065319,0.544411,-0.090219,0.065963,0.544953,-0.089056,0.065963,0.550593,-0.093789,0.067876,0.551661,-0.091498,0.067876,0.544953,-0.089056,0.065963,0.544953,-0.089056,0.065963,0.544411,-0.090219,0.065963,0.550593,-0.093789,0.067876,0.538035,-0.086538,0.065319,0.544953,-0.089056,0.065963,0.545285,-0.087817,0.065963,0.551661,-0.091498,0.067876,0.552315,-0.089056,0.067876,0.545285,-0.087817,0.065963,0.545285,-0.087817,0.065963,0.544953,-0.089056,0.065963,0.551661,-0.091498,0.067876,0.538035,-0.086538,0.065319,0.545285,-0.087817,0.065963,0.545397,-0.086538,0.065963,0.552315,-0.089056,0.067876,0.552535,-0.086538,0.067876,0.545397,-0.086538,0.065963,0.545397,-0.086538,0.065963,0.545285,-0.087817,0.065963,0.552315,-0.089056,0.067876,0.538035,0.322827,0.065319,0.545397,0.322827,0.065963,0.545285,0.324105,0.065963,0.552536,0.322827,0.067876,0.552315,0.325345,0.067876,0.545285,0.324105,0.065963,0.545285,0.324105,0.065963,0.545397,0.322827,0.065963,0.552536,0.322827,0.067876,0.538035,0.322827,0.065319,0.545285,0.324105,0.065963,0.544953,0.325345,0.065963,0.552315,0.325345,0.067876,0.551661,0.327786,0.067876,0.544953,0.325345,0.065963,0.544953,0.325345,0.065963,0.545285,0.324105,0.065963,0.552315,0.325345,0.067876,0.538035,0.322827,0.065319,0.544953,0.325345,0.065963,0.544411,0.326508,0.065963,0.551661,0.327786,0.067876,0.550593,0.330077,0.067876,0.544411,0.326508,0.065963,0.544411,0.326508,0.065963,0.544953,0.325345,0.065963,0.551661,0.327786,0.067876,0.538035,0.322827,0.065319,0.544411,0.326508,0.065963,0.543675,0.327559,0.065963,0.550593,0.330077,0.067876,0.549143,0.332148,0.067876,0.543675,0.327559,0.065963,0.543675,0.327559,0.065963,0.544411,0.326508,0.065963,0.550593,0.330077,0.067876,0.538035,0.322827,0.065319,0.543675,0.327559,0.065963,0.542767,0.328467,0.065963,0.538035,0.322827,0.065319,0.542767,0.328467,0.065963,0.541716,0.329203,0.065963,0.547356,0.333935,0.067876,0.545285,0.335385,0.067876,0.541716,0.329203,0.065963,0.541716,0.329203,0.065963,0.542767,0.328467,0.065963,0.547356,0.333935,0.067876,0.538035,0.322827,0.065319,0.541716,0.329203,0.065963,0.540553,0.329745,0.065963,0.538035,0.322827,0.065319,0.540553,0.329745,0.065963,0.539313,0.330077,0.065963,0.538035,0.322827,0.065319,0.539313,0.330077,0.065963,0.538035,0.330189,0.065963,0.540553,0.337107,0.067876,0.538035,0.337328,0.067876,0.538035,0.330189,0.065963,0.538035,0.330189,0.065963,0.539313,0.330077,0.065963,0.540553,0.337107,0.067876,-0.543936,0.322827,0.065319,0.538035,0.322827,0.065319,0.538035,0.330189,0.065963,-0.543936,0.330189,0.065963,-0.543936,0.322827,0.065319,0.538035,-0.086538,0.065319,0.538035,0.322827,0.065319,-0.543936,0.322827,0.065319,-0.543936,0.322827,0.065319,-0.543936,-0.086538,0.065319,0.538035,-0.086538,0.065319,-0.543936,0.330189,0.065963,0.538035,0.330189,0.065963,0.538035,0.337328,0.067876,-0.543936,0.337328,0.067876,-0.543936,0.330189,0.065963,0.539313,0.330077,0.065963,0.540553,0.329745,0.065963,0.542994,0.336453,0.067876,0.542994,0.336453,0.067876,0.540553,0.337107,0.067876,0.539313,0.330077,0.065963,0.540553,0.329745,0.065963,0.541716,0.329203,0.065963,0.545285,0.335385,0.067876,0.542994,0.336453,0.067876,0.542767,0.328467,0.065963,0.543675,0.327559,0.065963,0.549143,0.332148,0.067876,0.549143,0.332148,0.067876,0.547356,0.333935,0.067876,0.542767,0.328467,0.065963,0.545397,0.322827,0.065963,0.545397,0.186372,0.065963,0.552535,0.186372,0.067876,0.552535,0.186372,0.067876,0.552536,0.322827,0.067876,0.545397,0.322827,0.065963,0.545397,0.049917,0.065963,0.552536,0.049917,0.067876,0.552535,0.186372,0.067876,0.552535,0.186372,0.067876,0.545397,0.186372,0.065963,0.545397,-0.086538,0.065963,0.552535,-0.086538,0.067876,0.552535,-0.086538,0.067876,0.543675,-0.091271,0.065963,0.542767,-0.092178,0.065963,0.547356,-0.097646,0.067876,0.547356,-0.097646,0.067876,0.549143,-0.095859,0.067876,0.543675,-0.091271,0.065963,0.541716,-0.092914,0.065963,0.540553,-0.093456,0.065963,0.542994,-0.100164,0.067876,0.542994,-0.100164,0.067876,0.545285,-0.099096,0.067876,0.541716,-0.092914,0.065963,0.540553,-0.093456,0.065963,0.539313,-0.093789,0.065963,0.540553,-0.100819,0.067876,0.540553,-0.100819,0.067876,0.542994,-0.100164,0.067876,0.540553,-0.093456,0.065963,0.538035,-0.0939,0.065963,-0.543936,-0.0939,0.065963,-0.543936,-0.101039,0.067876,-0.543936,-0.101039,0.067876,0.538035,-0.101039,0.067876,0.538035,-0.0939,0.065963,-0.545215,-0.093789,0.065963,-0.546455,-0.093456,0.065963,-0.548896,-0.100164,0.067876,-0.548896,-0.100164,0.067876,-0.546455,-0.100819,0.067876,-0.545215,-0.093789,0.065963,-0.546455,-0.093456,0.065963,-0.547618,-0.092914,0.065963,-0.551187,-0.099096,0.067876,-0.551187,-0.099096,0.067876,-0.548896,-0.100164,0.067876,-0.546455,-0.093456,0.065963,-0.548669,-0.092178,0.065963,-0.549576,-0.091271,0.065963,-0.555045,-0.095859,0.067876,-0.555045,-0.095859,0.067876,-0.553257,-0.097646,0.067876,-0.548669,-0.092178,0.065963,-0.551299,-0.086538,0.065963,-0.551299,0.049917,0.065963,-0.558437,0.049917,0.067876,-0.558437,-0.086538,0.067876,-0.551299,-0.086538,0.065963,-0.551299,0.186372,0.065963,-0.558437,0.186372,0.067876,-0.551299,0.049917,0.065963,-0.551299,0.186372,0.065963,-0.551299,0.322827,0.065963,-0.558437,0.322827,0.067876,-0.558437,0.322827,0.067876,-0.551299,0.186372,0.065963,-0.549576,0.327559,0.065963,-0.548669,0.328467,0.065963,-0.553257,0.333935,0.067876,-0.553257,0.333935,0.067876,-0.555045,0.332148,0.067876,-0.549576,0.327559,0.065963,-0.547617,0.329203,0.065963,-0.546454,0.329745,0.065963,-0.548896,0.336453,0.067876,-0.548896,0.336453,0.067876,-0.551187,0.335385,0.067876,-0.547617,0.329203,0.065963,-0.546454,0.329745,0.065963,-0.545215,0.330077,0.065963,-0.546454,0.337107,0.067876,-0.546454,0.337107,0.067876,-0.548896,0.336453,0.067876,-0.546454,0.329745,0.065963,0.538035,0.344025,0.070436,-0.543936,0.344025,0.070436,-0.543936,0.337328,0.067876,-0.543936,0.337328,0.067876,0.538035,0.337328,0.067876,0.538035,0.344025,0.070436,-0.543936,0.344025,0.070436,0.538035,0.344025,0.070436,0.538035,0.350079,0.072448,-0.543936,0.350079,0.072448,-0.543936,0.344025,0.070436,0.545285,0.342747,0.070436,0.548634,0.341185,0.070436,0.551661,0.346428,0.072448,0.551661,0.346428,0.072448,0.547356,0.348436,0.072448,0.559233,0.186372,0.070436,0.565287,0.186372,0.072448,0.565287,0.322827,0.072448,0.565287,0.322827,0.072448,0.559234,0.322827,0.070436,0.559233,0.186372,0.070436,0.559234,0.049917,0.070436,0.565287,0.049917,0.072448,0.565287,0.186372,0.072448,0.559233,0.186372,0.070436,0.559234,0.049917,0.070436,0.559233,-0.086538,0.070436,0.565287,-0.086538,0.072448,0.565287,0.049917,0.072448,0.559234,0.049917,0.070436,0.559233,-0.086538,0.070436,0.538035,-0.107737,0.070436,-0.543936,-0.107737,0.070436,-0.543936,-0.113791,0.072448,-0.543936,-0.113791,0.072448,0.538035,-0.113791,0.072448,0.538035,-0.107737,0.070436,-0.551187,-0.106458,0.070436,-0.554536,-0.104897,0.070436,-0.557563,-0.11014,0.072448,-0.557563,-0.11014,0.072448,-0.553257,-0.112147,0.072448,-0.551187,-0.106458,0.070436,-0.565135,0.049917,0.070436,-0.571189,0.049917,0.072448,-0.571189,-0.086538,0.072448,-0.571189,-0.086538,0.072448,-0.565135,-0.086538,0.070436,-0.565135,0.049917,0.070436,-0.565135,0.186372,0.070436,-0.571189,0.186372,0.072448,-0.571189,0.049917,0.072448,-0.571189,0.049917,0.072448,-0.565135,0.049917,0.070436,-0.565135,0.186372,0.070436,-0.565135,0.322827,0.070436,-0.571189,0.322827,0.072448,-0.571189,0.186372,0.072448,-0.571189,0.186372,0.072448,-0.565135,0.186372,0.070436,-0.565135,0.322827,0.070436,-0.059433,-0.434014,0.074583,-0.060446,-0.434059,0.074583,-0.060426,-0.434104,0.07399,-0.059433,-0.434014,0.074583,-0.060426,-0.434104,0.07399,-0.05027,-0.433648,0.07399,-0.059433,-0.434014,0.074583,-0.05027,-0.433648,0.07399,-0.05027,-0.433602,0.074583,-0.069256,-0.435277,0.074583,-0.07023,-0.435412,0.074583,-0.070192,-0.435454,0.07399,-0.069256,-0.435277,0.074583,-0.070192,-0.435454,0.07399,-0.060426,-0.434104,0.07399,-0.069256,-0.435277,0.074583,-0.060426,-0.434104,0.07399,-0.060446,-0.434059,0.074583,-0.079193,-0.437647,0.07399,-0.070192,-0.435454,0.07399,-0.07023,-0.435412,0.074583,-0.07023,-0.435412,0.074583,-0.079248,-0.437609,0.074583,-0.079193,-0.437647,0.07399,-0.086365,-0.440271,0.074583,-0.087152,-0.440565,0.074583,-0.087082,-0.440598,0.07399,-0.086365,-0.440271,0.074583,-0.087082,-0.440598,0.07399,-0.079193,-0.437647,0.07399,-0.086365,-0.440271,0.074583,-0.079193,-0.437647,0.07399,-0.079248,-0.437609,0.074583,-0.092993,-0.443809,0.074583,-0.093639,-0.444168,0.074583,-0.093556,-0.444193,0.07399,-0.092993,-0.443809,0.074583,-0.093556,-0.444193,0.07399,-0.087082,-0.440598,0.07399,-0.092993,-0.443809,0.074583,-0.087082,-0.440598,0.07399,-0.087152,-0.440565,0.074583,-0.093639,-0.444168,0.074583,-0.09567,-0.4459,0.074583,-0.095558,-0.4459,0.07399,-0.095558,-0.4459,0.07399,-0.093556,-0.444193,0.07399,-0.093639,-0.444168,0.074583,-0.094301,-0.4459,0.071839,-0.092149,-0.4459,0.068157,-0.091044,-0.444958,0.068157,-0.094301,-0.4459,0.071839,-0.091044,-0.444958,0.068157,-0.093556,-0.444193,0.07399,-0.095558,-0.4459,0.07399,-0.094301,-0.4459,0.071839,-0.093556,-0.444193,0.07399,-0.091044,-0.4459,0.067084,-0.087951,-0.4459,0.06408,-0.091044,-0.444958,0.068157,-0.091044,-0.444958,0.068157,-0.092149,-0.4459,0.068157,-0.091044,-0.4459,0.067084,-0.086835,-0.4459,0.06313,-0.086426,-0.4459,0.062782,-0.081477,-0.443152,0.062782,-0.086835,-0.4459,0.06313,-0.081477,-0.443152,0.062782,-0.084946,-0.441571,0.068157,-0.086835,-0.4459,0.06313,-0.084946,-0.441571,0.068157,-0.091044,-0.444958,0.068157,-0.086835,-0.4459,0.06313,-0.091044,-0.444958,0.068157,-0.087951,-0.4459,0.06408,-0.081477,-0.4459,0.060038,-0.077927,-0.4459,0.05807,-0.07681,-0.445279,0.05807,-0.081477,-0.4459,0.060038,-0.07681,-0.445279,0.05807,-0.081477,-0.443152,0.062782,-0.086426,-0.4459,0.062782,-0.081477,-0.4459,0.060038,-0.081477,-0.443152,0.062782,-0.07681,-0.445279,0.05807,-0.077927,-0.4459,0.05807,-0.075448,-0.4459,0.057144,-0.071122,-0.4459,0.055819,-0.067093,-0.4459,0.054584,-0.071122,-0.443152,0.05807,-0.071122,-0.443152,0.05807,-0.07681,-0.445279,0.05807,-0.075448,-0.4459,0.057144,-0.071122,-0.4459,0.055819,-0.071122,-0.443152,0.05807,-0.075448,-0.4459,0.057144,-0.066522,-0.4459,0.054454,-0.065422,-0.4459,0.054204,-0.061555,-0.444958,0.054204,-0.066522,-0.4459,0.054454,-0.061555,-0.444958,0.054204,-0.064633,-0.441571,0.05807,-0.064633,-0.441571,0.05807,-0.071122,-0.443152,0.05807,-0.067093,-0.4459,0.054584,-0.066522,-0.4459,0.054454,-0.064633,-0.441571,0.05807,-0.067093,-0.4459,0.054584,-0.061555,-0.4459,0.05363,-0.060699,-0.4459,0.053503,-0.061555,-0.444958,0.054204,-0.061555,-0.444958,0.054204,-0.065422,-0.4459,0.054204,-0.061555,-0.4459,0.05363,-0.056768,-0.4459,0.053144,-0.055278,-0.4459,0.053008,-0.056023,-0.444193,0.054204,-0.056768,-0.4459,0.053144,-0.056023,-0.444193,0.054204,-0.061555,-0.444958,0.054204,-0.056768,-0.4459,0.053144,-0.061555,-0.444958,0.054204,-0.060699,-0.4459,0.053503,-0.052056,-0.4459,0.052909,-0.05027,-0.4459,0.052854,-0.05027,-0.443935,0.054204,-0.052056,-0.4459,0.052909,-0.05027,-0.443935,0.054204,-0.056023,-0.444193,0.054204,-0.052056,-0.4459,0.052909,-0.056023,-0.444193,0.054204,-0.055278,-0.4459,0.053008,0.001112,-0.4459,0.052854,0.01689,-0.4459,0.052854,0.01689,-0.443935,0.054204,0.001112,-0.4459,0.052854,0.01689,-0.443935,0.054204,-0.05027,-0.443935,0.054204,0.001112,-0.4459,0.052854,-0.05027,-0.443935,0.054204,-0.05027,-0.4459,0.052854,0.05047,-0.443935,0.054204,0.01689,-0.443935,0.054204,0.01689,-0.4459,0.052854,0.01689,-0.4459,0.052854,0.05047,-0.4459,0.052854,0.05047,-0.443935,0.054204,0.053721,-0.4459,0.052954,0.055478,-0.4459,0.053008,0.056223,-0.444193,0.054204,0.053721,-0.4459,0.052954,0.056223,-0.444193,0.054204,0.05047,-0.443935,0.054204,0.053721,-0.4459,0.052954,0.05047,-0.443935,0.054204,0.05047,-0.4459,0.052854,0.059688,-0.4459,0.053393,0.060899,-0.4459,0.053503,0.061755,-0.444958,0.054204,0.059688,-0.4459,0.053393,0.061755,-0.444958,0.054204,0.056223,-0.444193,0.054204,0.059688,-0.4459,0.053393,0.056223,-0.444193,0.054204,0.055478,-0.4459,0.053008,0.060899,-0.4459,0.053503,0.065622,-0.4459,0.054204,0.061755,-0.444958,0.054204,0.070162,-0.4459,0.055463,0.075648,-0.4459,0.057144,0.07701,-0.445279,0.05807,0.070162,-0.4459,0.055463,0.07701,-0.445279,0.05807,0.071322,-0.443152,0.05807,0.070162,-0.4459,0.055463,0.071322,-0.443152,0.05807,0.067293,-0.4459,0.054584,0.075648,-0.4459,0.057144,0.078127,-0.4459,0.05807,0.07701,-0.445279,0.05807,0.078127,-0.4459,0.05807,0.086626,-0.4459,0.062782,0.081677,-0.443152,0.062782,0.081677,-0.443152,0.062782,0.07701,-0.445279,0.05807,0.078127,-0.4459,0.05807,0.086626,-0.4459,0.062782,0.088151,-0.4459,0.06408,0.091244,-0.444958,0.068157,0.091244,-0.444958,0.068157,0.085146,-0.441571,0.068157,0.081677,-0.443152,0.062782,0.086626,-0.4459,0.062782,0.081677,-0.443152,0.062782,0.088151,-0.4459,0.06408,0.092349,-0.4459,0.068157,0.091244,-0.444958,0.068157,0.093311,-0.4459,0.069804,0.095758,-0.4459,0.07399,0.093756,-0.444193,0.07399,0.093311,-0.4459,0.069804,0.093756,-0.444193,0.07399,0.091244,-0.444958,0.068157,0.092349,-0.4459,0.068157,0.093311,-0.4459,0.069804,0.091244,-0.444958,0.068157,0.094319,-0.444577,0.074583,0.093839,-0.444168,0.074583,0.093756,-0.444193,0.07399,0.094319,-0.444577,0.074583,0.093756,-0.444193,0.07399,0.095758,-0.4459,0.07399,0.094319,-0.444577,0.074583,0.095758,-0.4459,0.07399,0.09587,-0.4459,0.074583,0.087998,-0.440924,0.074583,0.087352,-0.440565,0.074583,0.087281,-0.440598,0.07399,0.087998,-0.440924,0.074583,0.087281,-0.440598,0.07399,0.093756,-0.444193,0.07399,0.087998,-0.440924,0.074583,0.093756,-0.444193,0.07399,0.093839,-0.444168,0.074583,0.080235,-0.437903,0.074583,0.079448,-0.437609,0.074583,0.079393,-0.437647,0.07399,0.080235,-0.437903,0.074583,0.079393,-0.437647,0.07399,0.087281,-0.440598,0.07399,0.080235,-0.437903,0.074583,0.087281,-0.440598,0.07399,0.087352,-0.440565,0.074583,0.071328,-0.435631,0.074583,0.07043,-0.435412,0.074583,0.070392,-0.435454,0.07399,0.071328,-0.435631,0.074583,0.070392,-0.435454,0.07399,0.079393,-0.437647,0.07399,0.071328,-0.435631,0.074583,0.079393,-0.437647,0.07399,0.079448,-0.437609,0.074583,0.06162,-0.434194,0.074583,0.060646,-0.434059,0.074583,0.060626,-0.434104,0.07399,0.06162,-0.434194,0.074583,0.060626,-0.434104,0.07399,0.070392,-0.435454,0.07399,0.06162,-0.434194,0.074583,0.070392,-0.435454,0.07399,0.07043,-0.435412,0.074583,0.051483,-0.433648,0.074583,0.05047,-0.433603,0.074583,0.05047,-0.433648,0.07399,0.051483,-0.433648,0.074583,0.05047,-0.433648,0.07399,0.060626,-0.434104,0.07399,0.051483,-0.433648,0.074583,0.060626,-0.434104,0.07399,0.060646,-0.434059,0.074583,0.01689,-0.433603,0.074583,0.01689,-0.433648,0.07399,0.05047,-0.433648,0.07399,0.05047,-0.433648,0.07399,0.05047,-0.433603,0.074583,0.01689,-0.433603,0.074583,-0.01669,-0.435025,0.068157,-0.01669,-0.433648,0.07399,-0.05027,-0.433648,0.07399,-0.05027,-0.433648,0.07399,-0.05027,-0.435025,0.068157,-0.05027,-0.433648,0.07399,-0.060426,-0.434104,0.07399,-0.059837,-0.435454,0.068157,-0.059837,-0.435454,0.068157,-0.05027,-0.435025,0.068157,-0.05027,-0.433648,0.07399,-0.05027,-0.435025,0.068157,-0.059837,-0.435454,0.068157,-0.05888,-0.437647,0.062782,-0.05888,-0.437647,0.062782,-0.05027,-0.43726,0.062782,-0.05027,-0.435025,0.068157,-0.067159,-0.438791,0.062782,-0.05888,-0.437647,0.062782,-0.059837,-0.435454,0.068157,-0.059837,-0.435454,0.068157,-0.069036,-0.436726,0.068157,-0.067159,-0.438791,0.062782,-0.069036,-0.436726,0.068157,-0.077514,-0.438791,0.068157,-0.074789,-0.44065,0.062782,-0.074789,-0.44065,0.062782,-0.067159,-0.438791,0.062782,-0.069036,-0.436726,0.068157,-0.077514,-0.438791,0.068157,-0.084946,-0.441571,0.068157,-0.081477,-0.443152,0.062782,-0.081477,-0.443152,0.062782,-0.074789,-0.44065,0.062782,-0.077514,-0.438791,0.068157,-0.071122,-0.443152,0.05807,-0.064633,-0.441571,0.05807,-0.067159,-0.438791,0.062782,-0.067159,-0.438791,0.062782,-0.074789,-0.44065,0.062782,-0.071122,-0.443152,0.05807,-0.064633,-0.441571,0.05807,-0.057592,-0.440598,0.05807,-0.05888,-0.437647,0.062782,-0.05888,-0.437647,0.062782,-0.067159,-0.438791,0.062782,-0.064633,-0.441571,0.05807,-0.057592,-0.440598,0.05807,-0.05027,-0.440269,0.05807,-0.05027,-0.43726,0.062782,-0.05027,-0.43726,0.062782,-0.05888,-0.437647,0.062782,-0.057592,-0.440598,0.05807,-0.056023,-0.444193,0.054204,-0.05027,-0.443935,0.054204,-0.05027,-0.440269,0.05807,-0.05027,-0.440269,0.05807,-0.057592,-0.440598,0.05807,-0.056023,-0.444193,0.054204,0.01689,-0.435025,0.068157,-0.01669,-0.435025,0.068157,-0.01669,-0.43726,0.062782,0.01689,-0.435025,0.068157,-0.01669,-0.43726,0.062782,0.01689,-0.43726,0.062782,0.01689,-0.43726,0.062782,0.05047,-0.43726,0.062782,0.05047,-0.435025,0.068157,0.01689,-0.435025,0.068157,0.01689,-0.43726,0.062782,0.05047,-0.435025,0.068157,0.05047,-0.43726,0.062782,0.05908,-0.437647,0.062782,0.060037,-0.435454,0.068157,0.060037,-0.435454,0.068157,0.05047,-0.435025,0.068157,0.05047,-0.43726,0.062782,0.060626,-0.434104,0.07399,0.05047,-0.433648,0.07399,0.05047,-0.435025,0.068157,0.05047,-0.435025,0.068157,0.060037,-0.435454,0.068157,0.060626,-0.434104,0.07399,0.05047,-0.440269,0.05807,0.057792,-0.440598,0.05807,0.05908,-0.437647,0.062782,0.05908,-0.437647,0.062782,0.05047,-0.43726,0.062782,0.05047,-0.440269,0.05807,0.05047,-0.443935,0.054204,0.056223,-0.444193,0.054204,0.057792,-0.440598,0.05807,0.057792,-0.440598,0.05807,0.05047,-0.440269,0.05807,0.05047,-0.443935,0.054204,0.057792,-0.440598,0.05807,0.064833,-0.441571,0.05807,0.067359,-0.438791,0.062782,0.067359,-0.438791,0.062782,0.05908,-0.437647,0.062782,0.057792,-0.440598,0.05807,0.067359,-0.438791,0.062782,0.074989,-0.44065,0.062782,0.077714,-0.438791,0.068157,0.077714,-0.438791,0.068157,0.069236,-0.436726,0.068157,0.067359,-0.438791,0.062782,0.064833,-0.441571,0.05807,0.071322,-0.443152,0.05807,0.074989,-0.44065,0.062782,0.074989,-0.44065,0.062782,0.067359,-0.438791,0.062782,0.064833,-0.441571,0.05807,0.071322,-0.443152,0.05807,0.07701,-0.445279,0.05807,0.081677,-0.443152,0.062782,0.081677,-0.443152,0.062782,0.074989,-0.44065,0.062782,0.071322,-0.443152,0.05807,0.085146,-0.441571,0.068157,0.077714,-0.438791,0.068157,0.074989,-0.44065,0.062782,0.074989,-0.44065,0.062782,0.081677,-0.443152,0.062782,0.085146,-0.441571,0.068157,0.087281,-0.440598,0.07399,0.079393,-0.437647,0.07399,0.077714,-0.438791,0.068157,0.077714,-0.438791,0.068157,0.085146,-0.441571,0.068157,0.087281,-0.440598,0.07399,0.057792,-0.440598,0.05807,0.056223,-0.444193,0.054204,0.061755,-0.444958,0.054204,0.061755,-0.444958,0.054204,0.064833,-0.441571,0.05807,0.057792,-0.440598,0.05807,0.067359,-0.438791,0.062782,0.069236,-0.436726,0.068157,0.060037,-0.435454,0.068157,0.060037,-0.435454,0.068157,0.05908,-0.437647,0.062782,0.067359,-0.438791,0.062782,0.05047,-0.43726,0.062782,0.01689,-0.43726,0.062782,0.01689,-0.440269,0.05807,0.05047,-0.440269,0.05807,0.05047,-0.43726,0.062782,0.01689,-0.443935,0.054204,0.05047,-0.443935,0.054204,0.05047,-0.440269,0.05807,0.05047,-0.440269,0.05807,0.01689,-0.440269,0.05807,0.01689,-0.443935,0.054204,-0.01669,-0.43726,0.062782,-0.01669,-0.435025,0.068157,-0.05027,-0.435025,0.068157,-0.05027,-0.435025,0.068157,-0.05027,-0.43726,0.062782,-0.01669,-0.433648,0.07399,-0.01669,-0.435025,0.068157,0.01689,-0.435025,0.068157,0.01689,-0.435025,0.068157,0.01689,-0.433648,0.07399,-0.01669,-0.433648,0.07399,0.05047,-0.435025,0.068157,0.05047,-0.433648,0.07399,0.01689,-0.433648,0.07399,0.01689,-0.433648,0.07399,0.01689,-0.435025,0.068157,0.05047,-0.435025,0.068157,0.069236,-0.436726,0.068157,0.070392,-0.435454,0.07399,0.060626,-0.434104,0.07399,0.060626,-0.434104,0.07399,0.060037,-0.435454,0.068157,0.069236,-0.436726,0.068157,0.077714,-0.438791,0.068157,0.079393,-0.437647,0.07399,0.070392,-0.435454,0.07399,0.070392,-0.435454,0.07399,0.069236,-0.436726,0.068157,0.077714,-0.438791,0.068157,0.087281,-0.440598,0.07399,0.085146,-0.441571,0.068157,0.091244,-0.444958,0.068157,0.091244,-0.444958,0.068157,0.093756,-0.444193,0.07399,0.087281,-0.440598,0.07399,0.061755,-0.444958,0.054204,0.065622,-0.4459,0.054204,0.067293,-0.4459,0.054584,0.061755,-0.444958,0.054204,0.067293,-0.4459,0.054584,0.071322,-0.443152,0.05807,0.061755,-0.444958,0.054204,0.071322,-0.443152,0.05807,0.064833,-0.441571,0.05807,-0.05027,-0.443935,0.054204,0.01689,-0.443935,0.054204,0.01689,-0.440269,0.05807,0.01689,-0.440269,0.05807,-0.05027,-0.440269,0.05807,-0.05027,-0.443935,0.054204,-0.061555,-0.444958,0.054204,-0.056023,-0.444193,0.054204,-0.057592,-0.440598,0.05807,-0.057592,-0.440598,0.05807,-0.064633,-0.441571,0.05807,-0.074789,-0.44065,0.062782,-0.081477,-0.443152,0.062782,-0.07681,-0.445279,0.05807,-0.07681,-0.445279,0.05807,-0.071122,-0.443152,0.05807,-0.074789,-0.44065,0.062782,-0.079193,-0.437647,0.07399,-0.087082,-0.440598,0.07399,-0.084946,-0.441571,0.068157,-0.084946,-0.441571,0.068157,-0.077514,-0.438791,0.068157,-0.079193,-0.437647,0.07399,-0.091044,-0.444958,0.068157,-0.084946,-0.441571,0.068157,-0.087082,-0.440598,0.07399,-0.087082,-0.440598,0.07399,-0.093556,-0.444193,0.07399,-0.091044,-0.444958,0.068157,-0.077514,-0.438791,0.068157,-0.069036,-0.436726,0.068157,-0.070192,-0.435454,0.07399,-0.070192,-0.435454,0.07399,-0.079193,-0.437647,0.07399,-0.077514,-0.438791,0.068157,-0.069036,-0.436726,0.068157,-0.059837,-0.435454,0.068157,-0.060426,-0.434104,0.07399,-0.060426,-0.434104,0.07399,-0.070192,-0.435454,0.07399,-0.069036,-0.436726,0.068157,0.201863,-0.388618,0.074583,0.201863,-0.388618,0.071826,0.20107,-0.395492,0.071826,0.20107,-0.395492,0.074583,0.20107,-0.395492,0.074583,0.20107,-0.395492,0.071826,0.198811,-0.401805,0.071826,0.198811,-0.401805,0.074583,0.20107,-0.395492,0.074583,0.198811,-0.401805,0.074583,0.198811,-0.401805,0.071826,0.195268,-0.407375,0.071826,0.195268,-0.407375,0.071826,0.195268,-0.407375,0.074583,0.198811,-0.401805,0.074583,0.195268,-0.407375,0.074583,0.195268,-0.407375,0.071826,0.19062,-0.412023,0.071826,0.19062,-0.412023,0.071826,0.19062,-0.412023,0.074583,0.195268,-0.407375,0.074583,0.19062,-0.412023,0.074583,0.19062,-0.412023,0.071826,0.18505,-0.415566,0.071826,0.18505,-0.415566,0.071826,0.18505,-0.415566,0.074583,0.19062,-0.412023,0.074583,0.18505,-0.415566,0.074583,0.18505,-0.415566,0.071826,0.178737,-0.417825,0.071826,0.178737,-0.417825,0.074583,0.18505,-0.415566,0.074583,0.178737,-0.417825,0.074583,0.178737,-0.417825,0.071826,0.171863,-0.418618,0.071826,0.171863,-0.418618,0.074583,0.178737,-0.417825,0.074583,-0.170712,-0.418618,0.074583,-0.170712,-0.418618,0.071826,-0.177586,-0.417825,0.071826,-0.177586,-0.417825,0.074583,-0.177586,-0.417825,0.074583,-0.177586,-0.417825,0.071826,-0.183899,-0.415566,0.071826,-0.183899,-0.415566,0.074583,-0.177586,-0.417825,0.074583,-0.183899,-0.415566,0.074583,-0.183899,-0.415566,0.071826,-0.189469,-0.412023,0.071826,-0.189469,-0.412023,0.074583,-0.183899,-0.415566,0.074583,-0.189469,-0.412023,0.074583,-0.189469,-0.412023,0.071826,-0.194117,-0.407375,0.071826,-0.194117,-0.407375,0.074583,-0.189469,-0.412023,0.074583,-0.194117,-0.407375,0.074583,-0.194117,-0.407375,0.071826,-0.19766,-0.401805,0.071826,-0.19766,-0.401805,0.074583,-0.194117,-0.407375,0.074583,-0.19766,-0.401805,0.074583,-0.19766,-0.401805,0.071826,-0.199919,-0.395492,0.071826,-0.199919,-0.395492,0.071826,-0.199919,-0.395492,0.074583,-0.19766,-0.401805,0.074583,-0.199919,-0.395492,0.074583,-0.199919,-0.395492,0.071826,-0.200712,-0.388618,0.071826,-0.200712,-0.388618,0.074583,-0.200712,-0.164476,0.074583,-0.200712,-0.164476,0.071826,-0.199919,-0.157602,0.071826,-0.199919,-0.157602,0.074583,-0.199919,-0.157602,0.074583,-0.199919,-0.157602,0.071826,-0.19766,-0.15129,0.071826,-0.19766,-0.15129,0.074583,-0.199919,-0.157602,0.074583,-0.19766,-0.15129,0.074583,-0.19766,-0.15129,0.071826,-0.194117,-0.145719,0.071826,-0.194117,-0.145719,0.074583,-0.19766,-0.15129,0.074583,-0.194117,-0.145719,0.074583,-0.194117,-0.145719,0.071826,-0.189469,-0.141072,0.071826,-0.189469,-0.141072,0.074583,-0.194117,-0.145719,0.074583,-0.189469,-0.141072,0.074583,-0.189469,-0.141072,0.071826,-0.183899,-0.137528,0.071826,-0.183899,-0.137528,0.074583,-0.189469,-0.141072,0.074583,-0.183899,-0.137528,0.074583,-0.183899,-0.137528,0.071826,-0.177586,-0.135269,0.071826,-0.177586,-0.135269,0.074583,-0.177586,-0.135269,0.074583,-0.177586,-0.135269,0.071826,-0.170712,-0.134476,0.071826,-0.170712,-0.134476,0.074583,-0.177586,-0.135269,0.074583,-0.170712,-0.134476,0.071826,0.171863,-0.134476,0.071826,0.171863,-0.134476,0.074583,-0.170712,-0.134476,0.074583,-0.170712,-0.134476,0.071826,0.171863,-0.134476,0.074583,0.171863,-0.134476,0.071826,0.178737,-0.135269,0.071826,0.178737,-0.135269,0.074583,0.171863,-0.134476,0.074583,0.178737,-0.135269,0.074583,0.178737,-0.135269,0.071826,0.18505,-0.137528,0.071826,0.18505,-0.137528,0.074583,0.178737,-0.135269,0.074583,0.18505,-0.137528,0.074583,0.18505,-0.137528,0.071826,0.19062,-0.141072,0.071826,0.19062,-0.141072,0.074583,0.18505,-0.137528,0.074583,0.19062,-0.141072,0.074583,0.19062,-0.141072,0.071826,0.195268,-0.145719,0.071826,0.195268,-0.145719,0.074583,0.19062,-0.141072,0.074583,0.195268,-0.145719,0.074583,0.195268,-0.145719,0.071826,0.198811,-0.15129,0.071826,0.198811,-0.15129,0.074583,0.198811,-0.15129,0.074583,0.198811,-0.15129,0.071826,0.20107,-0.157602,0.071826,0.20107,-0.157602,0.074583,0.20107,-0.157602,0.074583,0.20107,-0.157602,0.071826,0.201863,-0.164476,0.071826,0.201863,-0.164476,0.074583,-0.626534,0.4161,0.005829,-0.618171,0.4161,0.001568,-0.61817,-0.002826,0.001568,-0.626534,0.4161,0.005829,-0.61817,-0.002826,0.001568,-0.61817,-0.225823,0.001568,-0.626534,-0.4159,0.005829,-0.626534,0.4161,0.005829,-0.61817,-0.225823,0.001568,-0.626534,-0.4159,0.005829,-0.61817,-0.225823,0.001568,-0.61817,-0.4159,0.001568,0.63337,0.4161,0.012466,0.637632,0.4161,0.020829,0.637632,-0.002826,0.020829,0.633371,-0.4159,0.012466,0.63337,0.4161,0.012466,0.637632,-0.002826,0.020829,0.633371,-0.4159,0.012466,0.637632,-0.002826,0.020829,0.637632,-0.4159,0.020829,0.4001,0.433734,0.005829,0.4001,0.428166,0.002993,0.4001,0.420902,0.007614,0.4001,0.440371,0.012466,0.4001,0.433734,0.005829,0.4001,0.420902,0.007614,0.4001,0.440371,0.012466,0.4001,0.420902,0.007614,0.4001,0.413362,0.015154,0.4001,0.444632,0.020829,0.4001,0.440371,0.012466,0.4001,0.413362,0.015154,0.4001,0.4461,0.0301,0.4001,0.444632,0.020829,0.4001,0.413362,0.015154,0.4001,0.4461,0.0301,0.4001,0.413362,0.015154,0.4001,0.407613,0.024192,0.4001,0.4461,0.0301,0.4001,0.407613,0.024192,0.4001,0.403948,0.034434,0.4001,0.4461,0.0301,0.4001,0.403948,0.034434,0.4001,0.402661,0.045586,0.4001,0.4461,0.074583,0.4001,0.4461,0.0301,0.4001,0.402661,0.045586,0.4001,0.4461,0.074583,0.4001,0.402661,0.045586,0.4001,0.402661,0.074583,-0.3999,0.420902,0.007614,-0.3999,0.428166,0.002993,-0.3999,0.433734,0.005829,-0.3999,0.420902,0.007614,-0.3999,0.433734,0.005829,-0.3999,0.440371,0.012466,-0.3999,0.413362,0.015154,-0.3999,0.420902,0.007614,-0.3999,0.440371,0.012466,-0.3999,0.413362,0.015154,-0.3999,0.440371,0.012466,-0.3999,0.444632,0.020829,-0.3999,0.413362,0.015154,-0.3999,0.444632,0.020829,-0.3999,0.4461,0.0301,-0.3999,0.407613,0.024192,-0.3999,0.413362,0.015154,-0.3999,0.4461,0.0301,-0.3999,0.403948,0.034434,-0.3999,0.407613,0.024192,-0.3999,0.4461,0.0301,-0.3999,0.402661,0.045586,-0.3999,0.403948,0.034434,-0.3999,0.4461,0.0301,-0.3999,0.402661,0.045586,-0.3999,0.4461,0.0301,-0.3999,0.4461,0.074583,-0.3999,0.402661,0.045586,-0.3999,0.4461,0.074583,-0.3999,0.402661,0.074583,-0.6089,-0.002826,0.0001,-0.6089,0.4161,0.0001,0.6091,0.4161,0.0001,-0.6089,-0.225823,0.0001,0.6091,0.4161,0.0001,-0.6089,-0.225823,0.0001,0.6091,0.4161,0.0001,0.6091,-0.4159,0.0001,-0.6089,-0.225823,0.0001,0.6091,-0.4159,0.0001,-0.6089,-0.4159,0.0001,-0.637432,-0.002826,0.020829,-0.637432,0.4161,0.020829,-0.63317,0.4161,0.012466,-0.637432,-0.225823,0.020829,-0.637432,-0.002826,0.020829,-0.63317,0.4161,0.012466,-0.637432,-0.225823,0.020829,-0.63317,0.4161,0.012466,-0.63317,-0.4159,0.012466,-0.637432,-0.225823,0.020829,-0.63317,-0.4159,0.012466,-0.637432,-0.4159,0.020829,0.538035,0.350079,0.072448,0.538035,0.352215,0.074583,0.350336,0.352215,0.074583,0.538035,0.350079,0.072448,0.350336,0.352215,0.074583,-0.079397,0.352215,0.074583,-0.543936,0.350079,0.072448,0.538035,0.350079,0.072448,-0.079397,0.352215,0.074583,-0.543936,0.350079,0.072448,-0.079397,0.352215,0.074583,-0.543936,0.352215,0.074583,-0.573325,-0.002826,0.074583,-0.573325,-0.086538,0.074583,-0.571189,-0.086538,0.072448,-0.573325,-0.002826,0.074583,-0.571189,-0.086538,0.072448,-0.571189,0.049917,0.072448,-0.573325,-0.002826,0.074583,-0.571189,0.049917,0.072448,-0.573325,0.049917,0.074583,0.565287,-0.086538,0.072448,0.567423,-0.086538,0.074583,0.567423,-0.002826,0.074583,0.565287,-0.086538,0.072448,0.567423,-0.002826,0.074583,0.567423,0.049917,0.074583,0.565287,-0.086538,0.072448,0.567423,0.049917,0.074583,-0.543936,0.322827,0.065319,-0.551299,0.322827,0.065963,-0.551299,0.186372,0.065963,-0.543936,0.322827,0.065319,-0.551299,0.186372,0.065963,-0.551299,0.049917,0.065963,-0.543936,-0.086538,0.065319,-0.543936,0.322827,0.065319,-0.551299,0.049917,0.065963,-0.543936,-0.086538,0.065319,-0.551299,0.049917,0.065963,-0.551299,-0.086538,0.065963,0.538035,-0.086538,0.065319,0.545397,-0.086538,0.065963,0.545397,0.049917,0.065963,0.538035,-0.086538,0.065319,0.545397,0.049917,0.065963,0.545397,0.186372,0.065963,0.538035,0.322827,0.065319,0.538035,-0.086538,0.065319,0.545397,0.186372,0.065963,0.538035,0.322827,0.065319,0.545397,0.186372,0.065963,0.545397,0.322827,0.065963,0.6091,-0.4459,0.0301,0.6091,-0.4459,0.074583,0.09587,-0.4459,0.074583,0.6091,-0.4459,0.0301,0.09587,-0.4459,0.074583,0.095758,-0.4459,0.07399,0.6091,-0.4459,0.0301,0.095758,-0.4459,0.07399,0.093311,-0.4459,0.069804,0.6091,-0.4459,0.0301,0.093311,-0.4459,0.069804,0.092349,-0.4459,0.068157,0.6091,-0.4459,0.0301,0.092349,-0.4459,0.068157,0.088151,-0.4459,0.06408,0.6091,-0.4459,0.0301,0.088151,-0.4459,0.06408,0.086626,-0.4459,0.062782,0.6091,-0.4459,0.0301,0.086626,-0.4459,0.062782,0.078127,-0.4459,0.05807,0.6091,-0.4459,0.0301,0.078127,-0.4459,0.05807,0.075648,-0.4459,0.057144,0.6091,-0.4459,0.0301,0.075648,-0.4459,0.057144,0.070162,-0.4459,0.055463,0.6091,-0.4459,0.0301,0.070162,-0.4459,0.055463,0.067293,-0.4459,0.054584,0.6091,-0.4459,0.0301,0.067293,-0.4459,0.054584,0.065622,-0.4459,0.054204,0.6091,-0.4459,0.0301,0.065622,-0.4459,0.054204,0.060899,-0.4459,0.053503,0.6091,-0.4459,0.0301,0.060899,-0.4459,0.053503,0.059688,-0.4459,0.053393,0.6091,-0.4459,0.0301,0.059688,-0.4459,0.053393,0.055478,-0.4459,0.053008,0.6091,-0.4459,0.0301,0.055478,-0.4459,0.053008,0.053721,-0.4459,0.052954,0.6091,-0.4459,0.0301,0.053721,-0.4459,0.052954,0.05047,-0.4459,0.052854,0.6091,-0.4459,0.0301,0.05047,-0.4459,0.052854,0.01689,-0.4459,0.052854,0.6091,-0.4459,0.0301,0.01689,-0.4459,0.052854,0.001112,-0.4459,0.052854,0.6091,-0.4459,0.0301,0.001112,-0.4459,0.052854,-0.05027,-0.4459,0.052854,0.6091,-0.4459,0.0301,-0.05027,-0.4459,0.052854,-0.052056,-0.4459,0.052909,0.6091,-0.4459,0.0301,-0.052056,-0.4459,0.052909,-0.055278,-0.4459,0.053008,-0.6089,-0.4459,0.0301,0.6091,-0.4459,0.0301,-0.055278,-0.4459,0.053008,-0.6089,-0.4459,0.0301,-0.055278,-0.4459,0.053008,-0.056768,-0.4459,0.053144,-0.6089,-0.4459,0.0301,-0.056768,-0.4459,0.053144,-0.060699,-0.4459,0.053503,-0.6089,-0.4459,0.0301,-0.060699,-0.4459,0.053503,-0.061555,-0.4459,0.05363,-0.6089,-0.4459,0.0301,-0.061555,-0.4459,0.05363,-0.065422,-0.4459,0.054204,-0.6089,-0.4459,0.0301,-0.065422,-0.4459,0.054204,-0.066522,-0.4459,0.054454,-0.6089,-0.4459,0.0301,-0.066522,-0.4459,0.054454,-0.067093,-0.4459,0.054584,-0.6089,-0.4459,0.0301,-0.067093,-0.4459,0.054584,-0.071122,-0.4459,0.055819,-0.6089,-0.4459,0.0301,-0.071122,-0.4459,0.055819,-0.075448,-0.4459,0.057144,-0.6089,-0.4459,0.0301,-0.075448,-0.4459,0.057144,-0.077927,-0.4459,0.05807,-0.6089,-0.4459,0.0301,-0.077927,-0.4459,0.05807,-0.081477,-0.4459,0.060038,-0.6089,-0.4459,0.0301,-0.081477,-0.4459,0.060038,-0.086426,-0.4459,0.062782,-0.6089,-0.4459,0.0301,-0.086426,-0.4459,0.062782,-0.086835,-0.4459,0.06313,-0.6089,-0.4459,0.0301,-0.086835,-0.4459,0.06313,-0.087951,-0.4459,0.06408,-0.6089,-0.4459,0.0301,-0.087951,-0.4459,0.06408,-0.091044,-0.4459,0.067084,-0.6089,-0.4459,0.0301,-0.091044,-0.4459,0.067084,-0.092149,-0.4459,0.068157,-0.6089,-0.4459,0.0301,-0.092149,-0.4459,0.068157,-0.094301,-0.4459,0.071839,-0.6089,-0.4459,0.0301,-0.094301,-0.4459,0.071839,-0.095558,-0.4459,0.07399,-0.6089,-0.4459,0.0301,-0.095558,-0.4459,0.07399,-0.09567,-0.4459,0.074583,-0.6089,-0.4459,0.0301,-0.09567,-0.4459,0.074583,-0.6089,-0.4459,0.074583,0.01689,-0.433648,0.07399,0.01689,-0.433603,0.074583,0.0001,-0.433603,0.074583,0.01689,-0.433648,0.07399,0.0001,-0.433603,0.074583,-0.013405,-0.433602,0.074583,-0.05027,-0.433602,0.074583,-0.05027,-0.433648,0.07399,-0.01669,-0.433648,0.07399,-0.013405,-0.433602,0.074583,-0.05027,-0.433602,0.074583,-0.01669,-0.433648,0.07399,0.01689,-0.433648,0.07399,-0.013405,-0.433602,0.074583,-0.01669,-0.433648,0.07399,-0.01669,-0.43726,0.062782,-0.05027,-0.43726,0.062782,-0.05027,-0.440269,0.05807,-0.01669,-0.43726,0.062782,-0.05027,-0.440269,0.05807,0.01689,-0.440269,0.05807,-0.01669,-0.43726,0.062782,0.01689,-0.440269,0.05807,0.01689,-0.43726,0.062782,0.626734,-0.44017,0.074583,0.633371,-0.433533,0.074583,0.637632,-0.42517,0.074583,0.618371,-0.444432,0.074583,0.626734,-0.44017,0.074583,0.637632,-0.42517,0.074583,0.6091,-0.4459,0.074583,0.618371,-0.444432,0.074583,0.637632,-0.42517,0.074583,0.6091,-0.4459,0.074583,0.637632,-0.42517,0.074583,0.6391,-0.4159,0.074583,0.6091,-0.4459,0.074583,0.6391,-0.4159,0.074583,0.6391,-0.225823,0.074583,0.6391,-0.002826,0.074583,0.567423,-0.002826,0.074583,0.567423,-0.086538,0.074583,0.6391,-0.225823,0.074583,0.6391,-0.002826,0.074583,0.567423,-0.086538,0.074583,0.6391,-0.225823,0.074583,0.567423,-0.086538,0.074583,0.566976,-0.091641,0.074583,0.6391,-0.225823,0.074583,0.566976,-0.091641,0.074583,0.566378,-0.093876,0.074583,0.6391,-0.225823,0.074583,0.566378,-0.093876,0.074583,0.565651,-0.09659,0.074583,0.6391,-0.225823,0.074583,0.565651,-0.09659,0.074583,0.564673,-0.098686,0.074583,0.6391,-0.225823,0.074583,0.564673,-0.098686,0.074583,0.563486,-0.101232,0.074583,0.6391,-0.225823,0.074583,0.563486,-0.101232,0.074583,0.562159,-0.103128,0.074583,0.6391,-0.225823,0.074583,0.562159,-0.103128,0.074583,0.560547,-0.105429,0.074583,0.6391,-0.225823,0.074583,0.560547,-0.105429,0.074583,0.556925,-0.109051,0.074583,0.6391,-0.225823,0.074583,0.556925,-0.109051,0.074583,0.552729,-0.111989,0.074583,0.6391,-0.225823,0.074583,0.552729,-0.111989,0.074583,0.548086,-0.114154,0.074583,0.6391,-0.225823,0.074583,0.548086,-0.114154,0.074583,0.545851,-0.114753,0.074583,0.6391,-0.225823,0.074583,0.545851,-0.114753,0.074583,0.543138,-0.11548,0.074583,-0.573325,-0.086538,0.074583,-0.573325,-0.002826,0.074583,-0.6389,-0.002826,0.074583,-0.573325,-0.086538,0.074583,-0.6389,-0.002826,0.074583,-0.6389,-0.225823,0.074583,-0.572878,-0.091641,0.074583,-0.573325,-0.086538,0.074583,-0.6389,-0.225823,0.074583,-0.572151,-0.094355,0.074583,-0.572878,-0.091641,0.074583,-0.6389,-0.225823,0.074583,-0.571552,-0.09659,0.074583,-0.572151,-0.094355,0.074583,-0.6389,-0.225823,0.074583,-0.570365,-0.099135,0.074583,-0.571552,-0.09659,0.074583,-0.6389,-0.225823,0.074583,-0.569387,-0.101232,0.074583,-0.570365,-0.099135,0.074583,-0.6389,-0.225823,0.074583,-0.567776,-0.103533,0.074583,-0.569387,-0.101232,0.074583,-0.6389,-0.225823,0.074583,-0.566449,-0.105429,0.074583,-0.567776,-0.103533,0.074583,-0.6389,-0.225823,0.074583,-0.562827,-0.109051,0.074583,-0.566449,-0.105429,0.074583,-0.6389,-0.225823,0.074583,-0.558631,-0.111989,0.074583,-0.562827,-0.109051,0.074583,-0.6389,-0.225823,0.074583,-0.556085,-0.113176,0.074583,-0.558631,-0.111989,0.074583,-0.6389,-0.225823,0.074583,-0.553988,-0.114154,0.074583,-0.556085,-0.113176,0.074583,-0.6389,-0.225823,0.074583,-0.551275,-0.114881,0.074583,-0.553988,-0.114154,0.074583,-0.6389,-0.225823,0.074583,-0.54904,-0.11548,0.074583,-0.551275,-0.114881,0.074583,-0.6389,-0.225823,0.074583,-0.013405,-0.433602,0.074583,0.0001,-0.433603,0.074583,0.0001,-0.418618,0.074583,-0.013405,-0.433602,0.074583,-0.170712,-0.418618,0.074583,-0.05027,-0.433602,0.074583,-0.013405,-0.433602,0.074583,-0.170712,-0.418618,0.074583,-0.059433,-0.434014,0.074583,-0.05027,-0.433602,0.074583,-0.170712,-0.418618,0.074583,-0.060446,-0.434059,0.074583,-0.059433,-0.434014,0.074583,-0.170712,-0.418618,0.074583,-0.069256,-0.435277,0.074583,-0.060446,-0.434059,0.074583,-0.170712,-0.418618,0.074583,-0.07023,-0.435412,0.074583,-0.069256,-0.435277,0.074583,-0.170712,-0.418618,0.074583,-0.079248,-0.437609,0.074583,-0.07023,-0.435412,0.074583,-0.170712,-0.418618,0.074583,-0.086365,-0.440271,0.074583,-0.079248,-0.437609,0.074583,-0.170712,-0.418618,0.074583,-0.087152,-0.440565,0.074583,-0.086365,-0.440271,0.074583,-0.170712,-0.418618,0.074583,-0.092993,-0.443809,0.074583,-0.087152,-0.440565,0.074583,-0.170712,-0.418618,0.074583,-0.093639,-0.444168,0.074583,-0.092993,-0.443809,0.074583,-0.170712,-0.418618,0.074583,-0.09567,-0.4459,0.074583,-0.093639,-0.444168,0.074583,-0.170712,-0.418618,0.074583,-0.6089,-0.4459,0.074583,-0.09567,-0.4459,0.074583,-0.170712,-0.418618,0.074583,-0.6089,-0.4459,0.074583,-0.170712,-0.418618,0.074583,-0.177586,-0.417825,0.074583,-0.6089,-0.4459,0.074583,-0.177586,-0.417825,0.074583,-0.183899,-0.415566,0.074583,-0.6089,-0.4459,0.074583,-0.183899,-0.415566,0.074583,-0.189469,-0.412023,0.074583,-0.6089,-0.4459,0.074583,-0.189469,-0.412023,0.074583,-0.194117,-0.407375,0.074583,-0.6089,-0.4459,0.074583,-0.194117,-0.407375,0.074583,-0.19766,-0.401805,0.074583,-0.6089,-0.4459,0.074583,-0.19766,-0.401805,0.074583,-0.199919,-0.395492,0.074583,-0.6089,-0.4459,0.074583,-0.199919,-0.395492,0.074583,-0.200712,-0.388618,0.074583,-0.61817,-0.444432,0.074583,-0.6089,-0.4459,0.074583,-0.200712,-0.388618,0.074583,-0.626534,-0.440171,0.074583,-0.61817,-0.444432,0.074583,-0.200712,-0.388618,0.074583,-0.63317,-0.433534,0.074583,-0.626534,-0.440171,0.074583,-0.200712,-0.388618,0.074583,-0.637432,-0.425171,0.074583,-0.63317,-0.433534,0.074583,-0.200712,-0.388618,0.074583,-0.6389,-0.4159,0.074583,-0.637432,-0.425171,0.074583,-0.200712,-0.388618,0.074583,-0.6389,-0.4159,0.074583,-0.200712,-0.388618,0.074583,-0.200712,-0.285557,0.074583,-0.6389,-0.225823,0.074583,-0.6389,-0.4159,0.074583,-0.6389,-0.225823,0.074583,-0.200712,-0.164476,0.074583,-0.6389,-0.225823,0.074583,-0.200712,-0.164476,0.074583,-0.199919,-0.157602,0.074583,-0.54904,-0.11548,0.074583,-0.6389,-0.225823,0.074583,-0.199919,-0.157602,0.074583,-0.543936,-0.115926,0.074583,-0.54904,-0.11548,0.074583,-0.199919,-0.157602,0.074583,-0.543936,-0.115926,0.074583,-0.199919,-0.157602,0.074583,-0.19766,-0.15129,0.074583,-0.543936,-0.115926,0.074583,-0.19766,-0.15129,0.074583,-0.194117,-0.145719,0.074583,-0.543936,-0.115926,0.074583,-0.194117,-0.145719,0.074583,-0.189469,-0.141072,0.074583,-0.543936,-0.115926,0.074583,-0.189469,-0.141072,0.074583,-0.183899,-0.137528,0.074583,-0.543936,-0.115926,0.074583,-0.183899,-0.137528,0.074583,-0.177586,-0.135269,0.074583,-0.543936,-0.115926,0.074583,-0.177586,-0.135269,0.074583,-0.170712,-0.134476,0.074583,-0.543936,-0.115926,0.074583,-0.170712,-0.134476,0.074583,0.171863,-0.134476,0.074583,0.538035,-0.115926,0.074583,-0.543936,-0.115926,0.074583,0.171863,-0.134476,0.074583,0.538035,-0.115926,0.074583,0.171863,-0.134476,0.074583,0.178737,-0.135269,0.074583,0.538035,-0.115926,0.074583,0.178737,-0.135269,0.074583,0.18505,-0.137528,0.074583,0.538035,-0.115926,0.074583,0.18505,-0.137528,0.074583,0.19062,-0.141072,0.074583,0.538035,-0.115926,0.074583,0.19062,-0.141072,0.074583,0.195268,-0.145719,0.074583,0.538035,-0.115926,0.074583,0.195268,-0.145719,0.074583,0.198811,-0.15129,0.074583,0.538035,-0.115926,0.074583,0.198811,-0.15129,0.074583,0.20107,-0.157602,0.074583,0.543138,-0.11548,0.074583,0.538035,-0.115926,0.074583,0.20107,-0.157602,0.074583,0.6391,-0.225823,0.074583,0.543138,-0.11548,0.074583,0.20107,-0.157602,0.074583,0.6391,-0.225823,0.074583,0.20107,-0.157602,0.074583,0.201863,-0.164476,0.074583,0.6391,-0.225823,0.074583,0.201863,-0.164476,0.074583,0.201863,-0.298735,0.074583,0.6091,-0.4459,0.074583,0.6391,-0.225823,0.074583,0.6091,-0.4459,0.074583,0.201863,-0.388618,0.074583,0.6091,-0.4459,0.074583,0.201863,-0.388618,0.074583,0.20107,-0.395492,0.074583,0.6091,-0.4459,0.074583,0.20107,-0.395492,0.074583,0.198811,-0.401805,0.074583,0.6091,-0.4459,0.074583,0.198811,-0.401805,0.074583,0.195268,-0.407375,0.074583,0.6091,-0.4459,0.074583,0.195268,-0.407375,0.074583,0.19062,-0.412023,0.074583,0.6091,-0.4459,0.074583,0.19062,-0.412023,0.074583,0.18505,-0.415566,0.074583,0.6091,-0.4459,0.074583,0.18505,-0.415566,0.074583,0.178737,-0.417825,0.074583,0.6091,-0.4459,0.074583,0.178737,-0.417825,0.074583,0.171863,-0.418618,0.074583,0.09587,-0.4459,0.074583,0.6091,-0.4459,0.074583,0.171863,-0.418618,0.074583,0.094319,-0.444577,0.074583,0.09587,-0.4459,0.074583,0.171863,-0.418618,0.074583,0.093839,-0.444168,0.074583,0.094319,-0.444577,0.074583,0.171863,-0.418618,0.074583,0.087998,-0.440924,0.074583,0.093839,-0.444168,0.074583,0.171863,-0.418618,0.074583,0.087352,-0.440565,0.074583,0.087998,-0.440924,0.074583,0.171863,-0.418618,0.074583,0.080235,-0.437903,0.074583,0.087352,-0.440565,0.074583,0.171863,-0.418618,0.074583,0.079448,-0.437609,0.074583,0.080235,-0.437903,0.074583,0.171863,-0.418618,0.074583,0.071328,-0.435631,0.074583,0.079448,-0.437609,0.074583,0.171863,-0.418618,0.074583,0.07043,-0.435412,0.074583,0.071328,-0.435631,0.074583,0.171863,-0.418618,0.074583,0.06162,-0.434194,0.074583,0.07043,-0.435412,0.074583,0.171863,-0.418618,0.074583,0.060646,-0.434059,0.074583,0.06162,-0.434194,0.074583,0.171863,-0.418618,0.074583,0.051483,-0.433648,0.074583,0.060646,-0.434059,0.074583,0.171863,-0.418618,0.074583,0.05047,-0.433603,0.074583,0.051483,-0.433648,0.074583,0.171863,-0.418618,0.074583,0.01689,-0.433603,0.074583,0.05047,-0.433603,0.074583,0.171863,-0.418618,0.074583,0.01689,-0.433603,0.074583,0.171863,-0.418618,0.074583,0.01689,-0.433603,0.074583,0.0001,-0.433603,0.074583,0.201863,-0.298735,0.074583,0.201863,-0.164476,0.074583,0.201863,-0.164476,0.071826,0.201863,-0.298735,0.074583,0.201863,-0.164476,0.071826,0.201863,-0.388618,0.071826,0.201863,-0.298735,0.074583,0.201863,-0.388618,0.071826,0.201863,-0.388618,0.074583,0.0001,-0.418618,0.074583,0.171863,-0.418618,0.074583,0.171863,-0.418618,0.071826,0.0001,-0.418618,0.074583,0.171863,-0.418618,0.071826,-0.170712,-0.418618,0.071826,0.0001,-0.418618,0.074583,-0.170712,-0.418618,0.071826,-0.170712,-0.418618,0.074583,-0.200712,-0.285557,0.074583,-0.200712,-0.388618,0.074583,-0.200712,-0.388618,0.071826,-0.200712,-0.164476,0.074583,-0.200712,-0.285557,0.074583,-0.200712,-0.388618,0.071826,-0.200712,-0.164476,0.074583,-0.200712,-0.388618,0.071826,-0.200712,-0.164476,0.071826,-0.189469,-0.141072,0.071826,-0.194117,-0.145719,0.071826,-0.19766,-0.15129,0.071826,-0.183899,-0.137528,0.071826,-0.189469,-0.141072,0.071826,-0.19766,-0.15129,0.071826,-0.183899,-0.137528,0.071826,-0.19766,-0.15129,0.071826,-0.199919,-0.157602,0.071826,-0.177586,-0.135269,0.071826,-0.183899,-0.137528,0.071826,-0.199919,-0.157602,0.071826,-0.177586,-0.135269,0.071826,-0.199919,-0.157602,0.071826,-0.200712,-0.164476,0.071826,-0.170712,-0.134476,0.071826,-0.177586,-0.135269,0.071826,-0.200712,-0.164476,0.071826,-0.170712,-0.134476,0.071826,-0.200712,-0.164476,0.071826,-0.200712,-0.388618,0.071826,-0.170712,-0.134476,0.071826,-0.200712,-0.388618,0.071826,-0.199919,-0.395492,0.071826,-0.170712,-0.134476,0.071826,-0.199919,-0.395492,0.071826,-0.19766,-0.401805,0.071826,-0.170712,-0.134476,0.071826,-0.19766,-0.401805,0.071826,-0.194117,-0.407375,0.071826,-0.170712,-0.134476,0.071826,-0.194117,-0.407375,0.071826,-0.189469,-0.412023,0.071826,-0.170712,-0.134476,0.071826,-0.189469,-0.412023,0.071826,-0.183899,-0.415566,0.071826,-0.170712,-0.134476,0.071826,-0.183899,-0.415566,0.071826,-0.177586,-0.417825,0.071826,-0.170712,-0.134476,0.071826,-0.177586,-0.417825,0.071826,-0.170712,-0.418618,0.071826,-0.170712,-0.134476,0.071826,-0.170712,-0.418618,0.071826,0.171863,-0.418618,0.071826,-0.170712,-0.134476,0.071826,0.171863,-0.418618,0.071826,0.178737,-0.417825,0.071826,-0.170712,-0.134476,0.071826,0.178737,-0.417825,0.071826,0.18505,-0.415566,0.071826,-0.170712,-0.134476,0.071826,0.18505,-0.415566,0.071826,0.19062,-0.412023,0.071826,-0.170712,-0.134476,0.071826,0.19062,-0.412023,0.071826,0.195268,-0.407375,0.071826,-0.170712,-0.134476,0.071826,0.195268,-0.407375,0.071826,0.198811,-0.401805,0.071826,-0.170712,-0.134476,0.071826,0.198811,-0.401805,0.071826,0.20107,-0.395492,0.071826,-0.170712,-0.134476,0.071826,0.20107,-0.395492,0.071826,0.201863,-0.388618,0.071826,0.171863,-0.134476,0.071826,-0.170712,-0.134476,0.071826,0.201863,-0.388618,0.071826,0.171863,-0.134476,0.071826,0.201863,-0.388618,0.071826,0.201863,-0.164476,0.071826,0.171863,-0.134476,0.071826,0.201863,-0.164476,0.071826,0.20107,-0.157602,0.071826,0.171863,-0.134476,0.071826,0.20107,-0.157602,0.071826,0.198811,-0.15129,0.071826,0.171863,-0.134476,0.071826,0.198811,-0.15129,0.071826,0.195268,-0.145719,0.071826,0.171863,-0.134476,0.071826,0.195268,-0.145719,0.071826,0.19062,-0.141072,0.071826,0.171863,-0.134476,0.071826,0.19062,-0.141072,0.071826,0.18505,-0.137528,0.071826,0.171863,-0.134476,0.071826,0.18505,-0.137528,0.071826,0.178737,-0.135269,0.071826],"normals":[0,1,0,0,1,0,0,1,0,0,1,0,-0.12217,0.992509,0,-0.12217,0.992509,0,-0.12217,0.992509,0,-0.122169,0.992509,0,-0.122169,0.992509,0,-0.122169,0.992509,0,-0.3566,0.934257,0,-0.3566,0.934257,0,-0.3566,0.934257,0,-0.3566,0.934257,0,-0.561554,0.82744,0,-0.561554,0.82744,0,-0.561554,0.82744,0,-0.561555,0.82744,0,-0.561555,0.82744,0,-0.561555,0.82744,0,-0.729586,0.683889,0,-0.729586,0.683889,0,-0.729586,0.683889,0,-0.729585,0.68389,0,-0.729585,0.68389,0,-0.729585,0.68389,0,-0.858892,0.512157,0,-0.858892,0.512157,0,-0.858892,0.512157,0,-0.858892,0.512157,0,-0.948102,0.317965,0,-0.948102,0.317965,0,-0.948102,0.317965,0,-0.948102,0.317966,0,-0.948102,0.317966,0,-0.948102,0.317966,0,-0.9942,0.107543,0,-0.9942,0.107543,0,-0.9942,0.107543,0,-0.9942,0.107544,0,-0.9942,0.107544,0,-0.9942,0.107544,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994202,-0.107533,0,-0.994202,-0.107533,0,-0.994202,-0.107533,0,-0.994202,-0.107533,0,-0.948099,-0.317976,0,-0.948099,-0.317976,0,-0.948099,-0.317976,0,-0.9481,-0.317973,0,-0.9481,-0.317973,0,-0.9481,-0.317973,0,-0.858895,-0.512151,0,-0.858895,-0.512151,0,-0.858895,-0.512151,0,-0.858895,-0.512151,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.561531,-0.827456,0,-0.561531,-0.827456,0,-0.561531,-0.827456,0,-0.561531,-0.827456,0,-0.356625,-0.934248,-0.000001,-0.356625,-0.934248,-0.000001,-0.356625,-0.934248,-0.000001,-0.35663,-0.934246,0,-0.35663,-0.934246,0,-0.35663,-0.934246,0,-0.122169,-0.992509,0,-0.122169,-0.992509,0,-0.122169,-0.992509,0,-0.122163,-0.99251,-0.000001,-0.122163,-0.99251,-0.000001,-0.122163,-0.99251,-0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122169,-0.992509,-0.000001,0.122169,-0.992509,-0.000001,0.122169,-0.992509,-0.000001,0.122163,-0.99251,0,0.122163,-0.99251,0,0.122163,-0.99251,0,0.356604,-0.934256,-0.000001,0.356604,-0.934256,-0.000001,0.356604,-0.934256,-0.000001,0.356604,-0.934256,-0.000001,0.561552,-0.827442,0,0.561552,-0.827442,0,0.561552,-0.827442,0,0.561556,-0.827439,0,0.561556,-0.827439,0,0.561556,-0.827439,0,0.729581,-0.683895,0,0.729581,-0.683895,0,0.729581,-0.683895,0,0.729581,-0.683895,0,0.858903,-0.512138,0,0.858903,-0.512138,0,0.858903,-0.512138,0,0.858903,-0.512138,0,0.948095,-0.317986,0,0.948095,-0.317986,0,0.948095,-0.317986,0,0.948095,-0.317986,0,0.994202,-0.107533,0,0.994202,-0.107533,0,0.994202,-0.107533,0,0.994202,-0.107533,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994202,0.107533,0,0.994202,0.107533,0,0.994202,0.107533,0,0.994202,0.107533,0,0.948096,0.317984,0,0.948096,0.317984,0,0.948096,0.317984,0,0.948095,0.317986,0,0.948095,0.317986,0,0.948095,0.317986,0,0.858894,0.512153,0,0.858894,0.512153,0,0.858894,0.512153,0,0.858895,0.512151,0,0.858895,0.512151,0,0.858895,0.512151,0,0.729585,0.68389,0,0.729585,0.68389,0,0.729585,0.68389,0,0.729585,0.68389,0,0.56154,0.82745,0,0.56154,0.82745,0,0.56154,0.82745,0,0.561537,0.827452,0,0.561537,0.827452,0,0.561537,0.827452,0,0.356619,0.93425,0,0.356619,0.93425,0,0.356619,0.93425,0,0.356625,0.934248,0.000001,0.356625,0.934248,0.000001,0.356625,0.934248,0.000001,0.122164,0.99251,0,0.122164,0.99251,0,0.122164,0.99251,0,0.122163,0.99251,0,0.122163,0.99251,0,0.122163,0.99251,0,-0.356645,0.93424,0,-0.356645,0.93424,0,-0.356645,0.93424,0,-0.356624,0.934248,0.000002,-0.356624,0.934248,0.000002,-0.356624,0.934248,0.000002,-0.561559,0.827437,0,-0.561559,0.827437,0,-0.561559,0.827437,0,-0.561559,0.827437,0,-0.72958,0.683895,0,-0.72958,0.683895,0,-0.72958,0.683895,0,-0.72958,0.683895,0,-0.858899,0.512145,0,-0.858899,0.512145,0,-0.858899,0.512145,0,-0.858899,0.512145,0,-0.948102,0.317966,0,-0.948102,0.317966,0,-0.948102,0.317966,0,-0.948102,0.317966,0,-0.994193,0.107607,0,-0.994193,0.107607,0,-0.994193,0.107607,0,-0.994193,0.107607,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994198,-0.107566,0,-0.994198,-0.107566,0,-0.994198,-0.107566,0,-0.994198,-0.107566,0,-0.948102,-0.317966,0,-0.948102,-0.317966,0,-0.948102,-0.317966,0,-0.948102,-0.317966,0,-0.858897,-0.512149,0,-0.858897,-0.512149,0,-0.858897,-0.512149,0,-0.858897,-0.512149,0,-0.729582,-0.683894,0,-0.729582,-0.683894,0,-0.729582,-0.683894,0,-0.729582,-0.683894,0,-0.561493,-0.827482,0,-0.561493,-0.827482,0,-0.561493,-0.827482,0,-0.561493,-0.827482,0,-0.356656,-0.934236,0,-0.356656,-0.934236,0,-0.356656,-0.934236,0,-0.356656,-0.934236,0,-0.122179,-0.992508,0,-0.122179,-0.992508,0,-0.122179,-0.992508,0,-0.122179,-0.992508,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.122179,-0.992508,0,0.122179,-0.992508,0,0.122179,-0.992508,0,0.122179,-0.992508,0,0.356615,-0.934252,0,0.356615,-0.934252,0,0.356615,-0.934252,0,0.356615,-0.934252,0,0.561509,-0.827471,0,0.561509,-0.827471,0,0.561509,-0.827471,0,0.561509,-0.827471,0,0.729617,-0.683856,0,0.729617,-0.683856,0,0.729617,-0.683856,0,0.729617,-0.683856,0,0.858878,-0.51218,0,0.858878,-0.51218,0,0.858878,-0.51218,0,0.858878,-0.51218,0,0.948098,-0.31798,0,0.948098,-0.31798,0,0.948098,-0.31798,0,0.948098,-0.31798,0,0.994203,-0.107524,0,0.994203,-0.107524,0,0.994203,-0.107524,0,0.994203,-0.107524,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.948098,0.31798,0,0.948098,0.31798,0,0.948098,0.31798,0,0.948098,0.31798,0,0.858897,0.512149,0,0.858897,0.512149,0,0.858897,0.512149,0,0.858897,0.512149,0,0.729593,0.683882,0,0.729593,0.683882,0,0.729593,0.683882,0,0.729593,0.683882,0,0.561509,0.827471,0,0.561509,0.827471,0,0.561509,0.827471,0,0.561509,0.827471,0,0.356676,0.934228,0,0.356676,0.934228,0,0.356676,0.934228,0,0.356676,0.934228,0,0.122111,0.992516,0,0.122111,0.992516,0,0.122111,0.992516,0,0.122111,0.992516,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122133,0.992514,0.000002,-0.122133,0.992514,0.000002,-0.122133,0.992514,0.000002,-0.122156,0.992511,0,-0.122156,0.992511,0,-0.122156,0.992511,0,-0.356632,0.934245,0,-0.356632,0.934245,0,-0.356632,0.934245,0,-0.356632,0.934245,0,-0.561548,0.827444,0,-0.561548,0.827444,0,-0.561548,0.827444,0,-0.561548,0.827444,0,-0.729592,0.683883,0,-0.729592,0.683883,0,-0.729592,0.683883,0,-0.729592,0.683883,0,-0.858895,0.512152,0,-0.858895,0.512152,0,-0.858895,0.512152,0,-0.858895,0.512152,0,-0.948086,0.318013,0.000001,-0.948086,0.318013,0.000001,-0.948086,0.318013,0.000001,-0.948089,0.318006,0,-0.948089,0.318006,0,-0.948089,0.318006,0,-0.994203,0.107519,0,-0.994203,0.107519,0,-0.994203,0.107519,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994202,-0.107526,0,-0.994202,-0.107526,0,-0.994202,-0.107526,0,-0.994202,-0.107526,0,-0.948102,-0.317966,0,-0.948102,-0.317966,0,-0.948102,-0.317966,0,-0.948102,-0.317966,0,-0.858887,-0.512166,0,-0.858887,-0.512166,0,-0.858887,-0.512166,0,-0.858887,-0.512166,0,-0.72957,-0.683906,-0.000002,-0.72957,-0.683906,-0.000002,-0.72957,-0.683906,-0.000002,-0.729581,-0.683894,0,-0.729581,-0.683894,0,-0.729581,-0.683894,0,-0.561526,-0.827459,-0.000002,-0.561526,-0.827459,-0.000002,-0.561526,-0.827459,-0.000002,-0.561526,-0.827459,-0.000002,-0.35664,-0.934242,0,-0.35664,-0.934242,0,-0.35664,-0.934242,0,-0.356619,-0.93425,-0.000002,-0.356619,-0.93425,-0.000002,-0.356619,-0.93425,-0.000002,-0.122181,-0.992508,0,-0.122181,-0.992508,0,-0.122181,-0.992508,0,-0.122181,-0.992508,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122176,-0.992508,0,0.122176,-0.992508,0,0.122176,-0.992508,0,0.122176,-0.992508,0,0.356615,-0.934252,0,0.356615,-0.934252,0,0.356615,-0.934252,0,0.356615,-0.934252,0,0.561536,-0.827452,0,0.561536,-0.827452,0,0.561536,-0.827452,0,0.561536,-0.827452,0,0.729593,-0.683881,0,0.729593,-0.683881,0,0.729593,-0.683881,0,0.729593,-0.683881,0,0.858878,-0.51218,0,0.858878,-0.51218,0,0.858878,-0.51218,0,0.858878,-0.51218,0,0.948102,-0.317966,0,0.948102,-0.317966,0,0.948102,-0.317966,0,0.948102,-0.317966,0,0.994203,-0.107522,0,0.994203,-0.107522,0,0.994203,-0.107522,0,0.994203,-0.107522,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.948075,0.318047,0,0.948075,0.318047,0,0.948075,0.318047,0,0.948075,0.318047,0,0.858907,0.512132,0,0.858907,0.512132,0,0.858907,0.512132,0,0.858907,0.512132,0,0.729581,0.683894,0,0.729581,0.683894,0,0.729581,0.683894,0,0.729581,0.683894,0,0.561602,0.827408,0,0.561602,0.827408,0,0.561602,0.827408,0,0.561602,0.827408,0,0.356616,0.934251,0,0.356616,0.934251,0,0.356616,0.934251,0,0.356616,0.934251,0,0.122133,0.992514,0,0.122133,0.992514,0,0.122133,0.992514,0,0.122133,0.992514,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122156,0.992511,0,-0.122156,0.992511,0,-0.122156,0.992511,0,-0.122156,0.992511,0,-0.356645,0.93424,0.000002,-0.356645,0.93424,0.000002,-0.356645,0.93424,0.000002,-0.356645,0.93424,0.000002,-0.561542,0.827448,0.000002,-0.561542,0.827448,0.000002,-0.561542,0.827448,0.000002,-0.561542,0.827448,0.000002,-0.729569,0.683907,0.000002,-0.729569,0.683907,0.000002,-0.729569,0.683907,0.000002,-0.729569,0.683907,0.000002,-0.858905,0.512135,0.000001,-0.858905,0.512135,0.000001,-0.858905,0.512135,0.000001,-0.858905,0.512135,0.000001,-0.948095,0.317986,0.000001,-0.948095,0.317986,0.000001,-0.948095,0.317986,0.000001,-0.948095,0.317986,0.000001,-0.9942,0.107543,0,-0.9942,0.107543,0,-0.9942,0.107543,0,-0.9942,0.107543,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.9942,-0.107545,0,-0.9942,-0.107545,0,-0.9942,-0.107545,0,-0.9942,-0.107545,0,-0.948105,-0.317956,-0.000001,-0.948105,-0.317956,-0.000001,-0.948105,-0.317956,-0.000001,-0.948105,-0.317956,-0.000001,-0.858892,-0.512157,-0.000001,-0.858892,-0.512157,-0.000001,-0.858892,-0.512157,-0.000001,-0.858892,-0.512157,-0.000001,-0.72957,-0.683906,-0.000002,-0.72957,-0.683906,-0.000002,-0.72957,-0.683906,-0.000002,-0.72957,-0.683906,-0.000002,-0.561531,-0.827456,-0.000002,-0.561531,-0.827456,-0.000002,-0.561531,-0.827456,-0.000002,-0.561531,-0.827456,-0.000002,-0.356616,-0.934251,-0.000002,-0.356616,-0.934251,-0.000002,-0.356616,-0.934251,-0.000002,-0.356616,-0.934251,-0.000002,-0.122201,-0.992505,-0.000002,-0.122201,-0.992505,-0.000002,-0.122201,-0.992505,-0.000002,-0.122201,-0.992505,-0.000002,0,-1,0,0,-1,0,0,-1,0,0.000001,-1,-0.000002,0.000001,-1,-0.000002,0.000001,-1,-0.000002,0.122179,-0.992508,0,0.122179,-0.992508,0,0.122179,-0.992508,0,0.122179,-0.992508,0,0.356599,-0.934258,0,0.356599,-0.934258,0,0.356599,-0.934258,0,0.356599,-0.934258,0,0.56152,-0.827463,0,0.56152,-0.827463,0,0.56152,-0.827463,0,0.56152,-0.827463,0,0.729616,-0.683857,0,0.729616,-0.683857,0,0.729616,-0.683857,0,0.729616,-0.683857,0,0.858882,-0.512173,0,0.858882,-0.512173,0,0.858882,-0.512173,0,0.858882,-0.512173,0,0.948091,-0.318,0,0.948091,-0.318,0,0.948091,-0.318,0,0.948091,-0.318,0,0.994205,-0.107503,0,0.994205,-0.107503,0,0.994205,-0.107503,0,0.994205,-0.107503,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.948084,0.31802,0,0.948084,0.31802,0,0.948084,0.31802,0,0.948084,0.31802,0,0.858907,0.512132,0,0.858907,0.512132,0,0.858907,0.512132,0,0.858907,0.512132,0,0.729593,0.683882,0,0.729593,0.683882,0,0.729593,0.683882,0,0.729593,0.683882,0,0.561569,0.82743,0,0.561569,0.82743,0,0.561569,0.82743,0,0.561569,0.82743,0,0.356616,0.934251,0,0.356616,0.934251,0,0.356616,0.934251,0,0.356616,0.934251,0,0.122136,0.992513,0,0.122136,0.992513,0,0.122136,0.992513,0,0.122136,0.992513,0,0,1,0.000002,0,1,0.000002,0,1,0.000002,-0.000001,1,0,-0.000001,1,0,-0.000001,1,0,-0.122135,0.992513,0.000002,-0.122135,0.992513,0.000002,-0.122135,0.992513,0.000002,-0.122135,0.992513,0.000002,-0.35664,0.934242,0,-0.35664,0.934242,0,-0.35664,0.934242,0,-0.35664,0.934242,0,-0.561537,0.827452,0,-0.561537,0.827452,0,-0.561537,0.827452,0,-0.561537,0.827452,0,-0.729592,0.683883,0,-0.729592,0.683883,0,-0.729592,0.683883,0,-0.729592,0.683883,0,-0.85888,0.512178,0,-0.85888,0.512178,0,-0.85888,0.512178,0,-0.85888,0.512178,0,-0.948093,0.317993,0.000001,-0.948093,0.317993,0.000001,-0.948093,0.317993,0.000001,-0.948095,0.317986,0,-0.948095,0.317986,0,-0.948095,0.317986,0,-0.994204,0.107509,0,-0.994204,0.107509,0,-0.994204,0.107509,0,-0.994204,0.107511,0,-0.994204,0.107511,0,-0.994204,0.107511,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994201,-0.107537,0,-0.994201,-0.107537,0,-0.994201,-0.107537,0,-0.994201,-0.107537,0,-0.948102,-0.317966,0,-0.948102,-0.317966,0,-0.948102,-0.317966,0,-0.948102,-0.317966,0,-0.858897,-0.512149,0,-0.858897,-0.512149,0,-0.858897,-0.512149,0,-0.858897,-0.512149,0,-0.72957,-0.683906,-0.000002,-0.72957,-0.683906,-0.000002,-0.72957,-0.683906,-0.000002,-0.729581,-0.683894,0,-0.729581,-0.683894,0,-0.729581,-0.683894,0,-0.561526,-0.827459,-0.000002,-0.561526,-0.827459,-0.000002,-0.561526,-0.827459,-0.000002,-0.561526,-0.827459,-0.000002,-0.356644,-0.93424,0,-0.356644,-0.93424,0,-0.356644,-0.93424,0,-0.356623,-0.934248,-0.000002,-0.356623,-0.934248,-0.000002,-0.356623,-0.934248,-0.000002,-0.122179,-0.992508,0,-0.122179,-0.992508,0,-0.122179,-0.992508,0,-0.122179,-0.992508,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122179,-0.992508,0,0.122179,-0.992508,0,0.122179,-0.992508,0,0.122179,-0.992508,0,0.356599,-0.934258,0,0.356599,-0.934258,0,0.356599,-0.934258,0,0.356599,-0.934258,0,0.561569,-0.82743,0,0.561569,-0.82743,0,0.561569,-0.82743,0,0.561569,-0.82743,0,0.729558,-0.683919,0,0.729558,-0.683919,0,0.729558,-0.683919,0,0.729558,-0.683919,0,0.858904,-0.512137,0,0.858904,-0.512137,0,0.858904,-0.512137,0,0.858904,-0.512137,0,0.948099,-0.317976,0,0.948099,-0.317976,0,0.948099,-0.317976,0,0.948099,-0.317976,0,0.994203,-0.107522,0,0.994203,-0.107522,0,0.994203,-0.107522,0,0.994203,-0.107522,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994204,0.107511,0,0.994204,0.107511,0,0.994204,0.107511,0,0.994204,0.107511,0,0.948089,0.318006,0,0.948089,0.318006,0,0.948089,0.318006,0,0.948089,0.318006,0,0.858902,0.512141,0,0.858902,0.512141,0,0.858902,0.512141,0,0.858902,0.512141,0,0.729569,0.683907,0,0.729569,0.683907,0,0.729569,0.683907,0,0.729569,0.683907,0,0.561574,0.827426,0,0.561574,0.827426,0,0.561574,0.827426,0,0.561574,0.827426,0,0.356636,0.934243,0,0.356636,0.934243,0,0.356636,0.934243,0,0.356636,0.934243,0,0.122133,0.992514,0,0.122133,0.992514,0,0.122133,0.992514,0,0.122133,0.992514,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122156,0.992511,0,-0.122156,0.992511,0,-0.122156,0.992511,0,-0.122156,0.992511,0,-0.356636,0.934243,0,-0.356636,0.934243,0,-0.356636,0.934243,0,-0.356636,0.934243,0,-0.561528,0.827457,0.000002,-0.561528,0.827457,0.000002,-0.561528,0.827457,0.000002,-0.561545,0.827447,0,-0.561545,0.827447,0,-0.561545,0.827447,0,-0.729601,0.683873,0,-0.729601,0.683873,0,-0.729601,0.683873,0,-0.72959,0.683885,0.000002,-0.72959,0.683885,0.000002,-0.72959,0.683885,0.000002,-0.85889,0.512161,0,-0.85889,0.512161,0,-0.85889,0.512161,0,-0.85889,0.512161,0,-0.948094,0.317991,0,-0.948094,0.317991,0,-0.948094,0.317991,0,-0.948094,0.317991,0,-0.994202,0.107527,0,-0.994202,0.107527,0,-0.994202,0.107527,0,-0.994202,0.107527,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994202,-0.107529,0,-0.994202,-0.107529,0,-0.994202,-0.107529,0,-0.994202,-0.107529,0,-0.948098,-0.317978,-0.000001,-0.948098,-0.317978,-0.000001,-0.948098,-0.317978,-0.000001,-0.9481,-0.317971,0,-0.9481,-0.317971,0,-0.9481,-0.317971,0,-0.858905,-0.512135,0,-0.858905,-0.512135,0,-0.858905,-0.512135,0,-0.858899,-0.512145,-0.000001,-0.858899,-0.512145,-0.000001,-0.858899,-0.512145,-0.000001,-0.729564,-0.683912,0,-0.729564,-0.683912,0,-0.729564,-0.683912,0,-0.729564,-0.683912,0,-0.561531,-0.827456,0,-0.561531,-0.827456,0,-0.561531,-0.827456,0,-0.561531,-0.827456,0,-0.356621,-0.934249,0,-0.356621,-0.934249,0,-0.356621,-0.934249,0,-0.356621,-0.934249,0,-0.122179,-0.992508,-0.000002,-0.122179,-0.992508,-0.000002,-0.122179,-0.992508,-0.000002,-0.122201,-0.992505,0,-0.122201,-0.992505,0,-0.122201,-0.992505,0,0,-1,0,0,-1,0,0,-1,0,0.000001,-1,-0.000002,0.000001,-1,-0.000002,0.000001,-1,-0.000002,0.122179,-0.992508,0,0.122179,-0.992508,0,0.122179,-0.992508,0,0.122179,-0.992508,0,0.356599,-0.934258,0,0.356599,-0.934258,0,0.356599,-0.934258,0,0.356599,-0.934258,0,0.561547,-0.827445,0,0.561547,-0.827445,0,0.561547,-0.827445,0,0.561547,-0.827445,0,0.729581,-0.683894,0,0.729581,-0.683894,0,0.729581,-0.683894,0,0.729581,-0.683894,0,0.858903,-0.512139,0,0.858903,-0.512139,0,0.858903,-0.512139,0,0.858903,-0.512139,0,0.948087,-0.31801,0,0.948087,-0.31801,0,0.948087,-0.31801,0,0.948087,-0.31801,0,0.994205,-0.107503,0,0.994205,-0.107503,0,0.994205,-0.107503,0,0.994205,-0.107503,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.948087,0.31801,0,0.948087,0.31801,0,0.948087,0.31801,0,0.948087,0.31801,0,0.858907,0.512132,0,0.858907,0.512132,0,0.858907,0.512132,0,0.858907,0.512132,0,0.729587,0.683888,0,0.729587,0.683888,0,0.729587,0.683888,0,0.729587,0.683888,0,0.561563,0.827434,0,0.561563,0.827434,0,0.561563,0.827434,0,0.561563,0.827434,0,0.356636,0.934243,0,0.356636,0.934243,0,0.356636,0.934243,0,0.356636,0.934243,0,0.122132,0.992514,0,0.122132,0.992514,0,0.122132,0.992514,0,0.122132,0.992514,0,-0.000001,1,0,-0.000001,1,0,-0.000001,1,0,-0.000001,1,0,-0.122133,0.992514,0,-0.122133,0.992514,0,-0.122133,0.992514,0,-0.122133,0.992514,0,-0.356637,0.934243,0,-0.356637,0.934243,0,-0.356637,0.934243,0,-0.356637,0.934243,0,-0.561532,0.827455,0,-0.561532,0.827455,0,-0.561532,0.827455,0,-0.561532,0.827455,0,-0.729595,0.683879,0,-0.729595,0.683879,0,-0.729595,0.683879,0,-0.729595,0.683879,0,-0.85888,0.512177,0.000001,-0.85888,0.512177,0.000001,-0.85888,0.512177,0.000001,-0.858886,0.512167,0,-0.858886,0.512167,0,-0.858886,0.512167,0,-0.948097,0.317981,0,-0.948097,0.317981,0,-0.948097,0.317981,0,-0.948095,0.317988,0.000001,-0.948095,0.317988,0.000001,-0.948095,0.317988,0.000001,-0.994203,0.107523,0,-0.994203,0.107523,0,-0.994203,0.107523,0,-0.994203,0.107521,0,-0.994203,0.107521,0,-0.994203,0.107521,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994202,-0.107528,0,-0.994202,-0.107528,0,-0.994202,-0.107528,0,-0.994202,-0.107531,0,-0.994202,-0.107531,0,-0.994202,-0.107531,0,-0.948098,-0.317977,0,-0.948098,-0.317977,0,-0.948098,-0.317977,0,-0.948098,-0.317977,0,-0.858897,-0.512149,0,-0.858897,-0.512149,0,-0.858897,-0.512149,0,-0.858897,-0.512149,0,-0.729573,-0.683903,0,-0.729573,-0.683903,0,-0.729573,-0.683903,0,-0.729573,-0.683903,0,-0.561527,-0.827458,0,-0.561527,-0.827458,0,-0.561527,-0.827458,0,-0.561527,-0.827458,0,-0.35664,-0.934242,0,-0.35664,-0.934242,0,-0.35664,-0.934242,0,-0.35664,-0.934242,0,-0.122178,-0.992508,0,-0.122178,-0.992508,0,-0.122178,-0.992508,0,-0.122178,-0.992508,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.1222,-0.992506,0,0.1222,-0.992506,0,0.1222,-0.992506,0,0.1222,-0.992506,0,0.356578,-0.934265,0,0.356578,-0.934265,0,0.356578,-0.934265,0,0.356578,-0.934265,0,0.561568,-0.827431,0,0.561568,-0.827431,0,0.561568,-0.827431,0,0.561568,-0.827431,0,0.729569,-0.683908,0,0.729569,-0.683908,0,0.729569,-0.683908,0,0.729569,-0.683908,0,0.858904,-0.512137,0,0.858904,-0.512137,0,0.858904,-0.512137,0,0.858904,-0.512137,0,0.948094,-0.317991,0,0.948094,-0.317991,0,0.948094,-0.317991,0,0.948094,-0.317991,0,0.994203,-0.107522,0,0.994203,-0.107522,0,0.994203,-0.107522,0,0.994203,-0.107522,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994203,0.107516,0,0.994203,0.107516,0,0.994203,0.107516,0,0.994203,0.107516,0,0.948087,0.318012,0,0.948087,0.318012,0,0.948087,0.318012,0,0.948087,0.318012,0,0.858907,0.512133,0,0.858907,0.512133,0,0.858907,0.512133,0,0.858907,0.512133,0,0.729585,0.68389,0,0.729585,0.68389,0,0.729585,0.68389,0,0.729585,0.68389,0,0.561554,0.82744,0,0.561554,0.82744,0,0.561554,0.82744,0,0.561554,0.82744,0,0.356633,0.934244,0,0.356633,0.934244,0,0.356633,0.934244,0,0.356633,0.934244,0,0.122133,0.992514,0,0.122133,0.992514,0,0.122133,0.992514,0,0.122133,0.992514,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122155,0.992511,0,-0.122155,0.992511,0,-0.122155,0.992511,0,-0.122155,0.992511,0,-0.356638,0.934243,0,-0.356638,0.934243,0,-0.356638,0.934243,0,-0.356638,0.934243,0,-0.561534,0.827454,0.000002,-0.561534,0.827454,0.000002,-0.561534,0.827454,0.000002,-0.56155,0.827443,0,-0.56155,0.827443,0,-0.56155,0.827443,0,-0.729589,0.683886,0,-0.729589,0.683886,0,-0.729589,0.683886,0,-0.729578,0.683898,0.000002,-0.729578,0.683898,0.000002,-0.729578,0.683898,0.000002,-0.858887,0.512165,0,-0.858887,0.512165,0,-0.858887,0.512165,0,-0.858887,0.512165,0,-0.948099,0.317976,0,-0.948099,0.317976,0,-0.948099,0.317976,0,-0.948099,0.317976,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994203,-0.107524,0,-0.994203,-0.107524,0,-0.994203,-0.107524,0,-0.994203,-0.107524,0,-0.948093,-0.317993,-0.000001,-0.948093,-0.317993,-0.000001,-0.948093,-0.317993,-0.000001,-0.948095,-0.317986,0,-0.948095,-0.317986,0,-0.948095,-0.317986,0,-0.85891,-0.512126,0,-0.85891,-0.512126,0,-0.85891,-0.512126,0,-0.858904,-0.512136,-0.000001,-0.858904,-0.512136,-0.000001,-0.858904,-0.512136,-0.000001,-0.729567,-0.683909,0,-0.729567,-0.683909,0,-0.729567,-0.683909,0,-0.729567,-0.683909,0,-0.561534,-0.827454,0,-0.561534,-0.827454,0,-0.561534,-0.827454,0,-0.561534,-0.827454,0,-0.356616,-0.934251,0,-0.356616,-0.934251,0,-0.356616,-0.934251,0,-0.356616,-0.934251,0,-0.122178,-0.992508,0,-0.122178,-0.992508,0,-0.122178,-0.992508,0,-0.122178,-0.992508,0,-0.000001,-1,0,-0.000001,-1,0,-0.000001,-1,0,-0.000001,-1,0,0.122178,-0.992508,0,0.122178,-0.992508,0,0.122178,-0.992508,0,0.122178,-0.992508,0,0.356598,-0.934258,0,0.356598,-0.934258,0,0.356598,-0.934258,0,0.356598,-0.934258,0,0.561563,-0.827434,0,0.561563,-0.827434,0,0.561563,-0.827434,0,0.561563,-0.827434,0,0.729569,-0.683907,0,0.729569,-0.683907,0,0.729569,-0.683907,0,0.729569,-0.683907,0,0.858912,-0.512122,0,0.858912,-0.512122,0,0.858912,-0.512122,0,0.858912,-0.512122,0,0.948089,-0.318004,0,0.948089,-0.318004,0,0.948089,-0.318004,0,0.948089,-0.318004,0,0.994203,-0.107521,0,0.994203,-0.107521,0,0.994203,-0.107521,0,0.994203,-0.107521,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994203,0.107518,0,0.994203,0.107518,0,0.994203,0.107518,0,0.994203,0.107518,0,0.948089,0.318004,0,0.948089,0.318004,0,0.948089,0.318004,0,0.948089,0.318004,0,0.858902,0.512141,0,0.858902,0.512141,0,0.858902,0.512141,0,0.858902,0.512141,0,0.729581,0.683894,0,0.729581,0.683894,0,0.729581,0.683894,0,0.729581,0.683894,0,0.561564,0.827433,0,0.561564,0.827433,0,0.561564,0.827433,0,0.561564,0.827433,0,0.356638,0.934243,0,0.356638,0.934243,0,0.356638,0.934243,0,0.356638,0.934243,0,0.122132,0.992514,0,0.122132,0.992514,0,0.122132,0.992514,0,0.122132,0.992514,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122133,0.992514,0,-0.122133,0.992514,0,-0.122133,0.992514,0,-0.122133,0.992514,0,-0.356636,0.934243,0,-0.356636,0.934243,0,-0.356636,0.934243,0,-0.356636,0.934243,0,-0.561531,0.827456,0,-0.561531,0.827456,0,-0.561531,0.827456,0,-0.561531,0.827456,0,-0.729592,0.683883,0,-0.729592,0.683883,0,-0.729592,0.683883,0,-0.729592,0.683883,0,-0.858878,0.512179,0.000001,-0.858878,0.512179,0.000001,-0.858878,0.512179,0.000001,-0.858885,0.512169,0,-0.858885,0.512169,0,-0.858885,0.512169,0,-0.948099,0.317976,0,-0.948099,0.317976,0,-0.948099,0.317976,0,-0.948096,0.317983,0.000001,-0.948096,0.317983,0.000001,-0.948096,0.317983,0.000001,-0.994203,0.107522,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-0.994203,0.107519,0,-0.994203,0.107519,0,-0.994203,0.107519,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994201,-0.107535,0,-0.994201,-0.107535,0,-0.994201,-0.107535,0,-0.994201,-0.107537,0,-0.994201,-0.107537,0,-0.994201,-0.107537,0,-0.948099,-0.317976,0,-0.948099,-0.317976,0,-0.948099,-0.317976,0,-0.948099,-0.317976,0,-0.858897,-0.512149,0,-0.858897,-0.512149,0,-0.858897,-0.512149,0,-0.858897,-0.512149,0,-0.729576,-0.6839,0,-0.729576,-0.6839,0,-0.729576,-0.6839,0,-0.729576,-0.6839,0,-0.561531,-0.827456,0,-0.561531,-0.827456,0,-0.561531,-0.827456,0,-0.561531,-0.827456,0,-0.35664,-0.934242,0,-0.35664,-0.934242,0,-0.35664,-0.934242,0,-0.35664,-0.934242,0,-0.122177,-0.992508,0,-0.122177,-0.992508,0,-0.122177,-0.992508,0,-0.122177,-0.992508,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.1222,-0.992505,0,0.1222,-0.992505,0,0.1222,-0.992505,0,0.1222,-0.992505,0,0.356576,-0.934266,0,0.356576,-0.934266,0,0.356576,-0.934266,0,0.356576,-0.934266,0,0.561563,-0.827434,0,0.561563,-0.827434,0,0.561563,-0.827434,0,0.561563,-0.827434,0,0.729573,-0.683903,0,0.729573,-0.683903,0,0.729573,-0.683903,0,0.729573,-0.683903,0,0.858914,-0.51212,0,0.858914,-0.51212,0,0.858914,-0.51212,0,0.858914,-0.51212,0,0.94809,-0.318001,0,0.94809,-0.318001,0,0.94809,-0.318001,0,0.94809,-0.318001,0,0.994202,-0.107527,0,0.994202,-0.107527,0,0.994202,-0.107527,0,0.994202,-0.107527,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.94809,0.318001,0,0.94809,0.318001,0,0.94809,0.318001,0,0.94809,0.318001,0,0.858905,0.512135,0,0.858905,0.512135,0,0.858905,0.512135,0,0.858905,0.512135,0,0.729581,0.683894,0,0.729581,0.683894,0,0.729581,0.683894,0,0.729581,0.683894,0,0.561545,0.827447,0,0.561545,0.827447,0,0.561545,0.827447,0,0.561545,0.827447,0,0.35664,0.934242,0,0.35664,0.934242,0,0.35664,0.934242,0,0.35664,0.934242,0,0.122133,0.992514,0,0.122133,0.992514,0,0.122133,0.992514,0,0.122133,0.992514,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122156,0.992511,0,-0.122156,0.992511,0,-0.122156,0.992511,0,-0.122156,0.992511,0,-0.356644,0.93424,0,-0.356644,0.93424,0,-0.356644,0.93424,0,-0.356644,0.93424,0,-0.561537,0.827452,0,-0.561537,0.827452,0,-0.561537,0.827452,0,-0.561537,0.827452,0,-0.729592,0.683883,0,-0.729592,0.683883,0,-0.729592,0.683883,0,-0.729592,0.683883,0,-0.85888,0.512178,0,-0.85888,0.512178,0,-0.85888,0.512178,0,-0.85888,0.512178,0,-0.948099,0.317976,0,-0.948099,0.317976,0,-0.948099,0.317976,0,-0.948099,0.317976,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994202,-0.107526,0,-0.994202,-0.107526,0,-0.994202,-0.107526,0,-0.994203,-0.107524,0,-0.994203,-0.107524,0,-0.994203,-0.107524,0,-0.948095,-0.317986,0,-0.948095,-0.317986,0,-0.948095,-0.317986,0,-0.948093,-0.317993,-0.000001,-0.948093,-0.317993,-0.000001,-0.948093,-0.317993,-0.000001,-0.858897,-0.512149,-0.000001,-0.858897,-0.512149,-0.000001,-0.858897,-0.512149,-0.000001,-0.858903,-0.512139,0,-0.858903,-0.512139,0,-0.858903,-0.512139,0,-0.729587,-0.683888,0,-0.729587,-0.683888,0,-0.729587,-0.683888,0,-0.729576,-0.6839,-0.000002,-0.729576,-0.6839,-0.000002,-0.729576,-0.6839,-0.000002,-0.561537,-0.827452,0,-0.561537,-0.827452,0,-0.561537,-0.827452,0,-0.561537,-0.827452,0,-0.356619,-0.93425,0,-0.356619,-0.93425,0,-0.356619,-0.93425,0,-0.356619,-0.93425,0,-0.122176,-0.992508,0,-0.122176,-0.992508,0,-0.122176,-0.992508,0,-0.122176,-0.992508,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122179,-0.992508,0,0.122179,-0.992508,0,0.122179,-0.992508,0,0.122179,-0.992508,0,0.356591,-0.934261,0,0.356591,-0.934261,0,0.356591,-0.934261,0,0.356591,-0.934261,0,0.561574,-0.827426,0,0.561574,-0.827426,0,0.561574,-0.827426,0,0.561574,-0.827426,0,0.72957,-0.683906,0,0.72957,-0.683906,0,0.72957,-0.683906,0,0.72957,-0.683906,0,0.858919,-0.512112,0,0.858919,-0.512112,0,0.858919,-0.512112,0,0.858919,-0.512112,0,0.948085,-0.318017,0,0.948085,-0.318017,0,0.948085,-0.318017,0,0.948085,-0.318017,0,0.994203,-0.107524,0,0.994203,-0.107524,0,0.994203,-0.107524,0,0.994203,-0.107524,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994204,0.107509,0,0.994204,0.107509,0,0.994204,0.107509,0,0.994204,0.107509,0,0.948089,0.318006,0,0.948089,0.318006,0,0.948089,0.318006,0,0.948089,0.318006,0,0.858897,0.512149,0,0.858897,0.512149,0,0.858897,0.512149,0,0.858897,0.512149,0,0.729581,0.683894,0,0.729581,0.683894,0,0.729581,0.683894,0,0.729581,0.683894,0,0.561563,0.827434,0,0.561563,0.827434,0,0.561563,0.827434,0,0.561563,0.827434,0,0.35664,0.934242,0,0.35664,0.934242,0,0.35664,0.934242,0,0.35664,0.934242,0,0.122132,0.992514,0,0.122132,0.992514,0,0.122132,0.992514,0,0.122132,0.992514,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122155,0.992511,0,-0.122155,0.992511,0,-0.122155,0.992511,0,-0.122155,0.992511,0,-0.356648,0.934239,0.000002,-0.356648,0.934239,0.000002,-0.356648,0.934239,0.000002,-0.356668,0.934231,0,-0.356668,0.934231,0,-0.356668,0.934231,0,-0.561537,0.827452,0.000002,-0.561537,0.827452,0.000002,-0.561537,0.827452,0.000002,-0.561537,0.827452,0.000002,-0.72958,0.683895,0,-0.72958,0.683895,0,-0.72958,0.683895,0,-0.729569,0.683907,0.000002,-0.729569,0.683907,0.000002,-0.729569,0.683907,0.000002,-0.858878,0.512179,0.000001,-0.858878,0.512179,0.000001,-0.858878,0.512179,0.000001,-0.858885,0.512169,0,-0.858885,0.512169,0,-0.858885,0.512169,0,-0.948102,0.317966,0,-0.948102,0.317966,0,-0.948102,0.317966,0,-0.9481,0.317973,0.000001,-0.9481,0.317973,0.000001,-0.9481,0.317973,0.000001,-0.9942,0.107543,0,-0.9942,0.107543,0,-0.9942,0.107543,0,-0.994201,0.107541,0,-0.994201,0.107541,0,-0.994201,0.107541,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.9942,-0.107545,0,-0.9942,-0.107545,0,-0.9942,-0.107545,0,-0.9942,-0.107547,0,-0.9942,-0.107547,0,-0.9942,-0.107547,0,-0.948095,-0.317986,-0.000001,-0.948095,-0.317986,-0.000001,-0.948095,-0.317986,-0.000001,-0.948098,-0.317979,0,-0.948098,-0.317979,0,-0.948098,-0.317979,0,-0.858897,-0.512149,-0.000001,-0.858897,-0.512149,-0.000001,-0.858897,-0.512149,-0.000001,-0.858897,-0.512149,-0.000001,-0.729582,-0.683894,-0.000002,-0.729582,-0.683894,-0.000002,-0.729582,-0.683894,-0.000002,-0.729582,-0.683894,-0.000002,-0.561548,-0.827444,-0.000002,-0.561548,-0.827444,-0.000002,-0.561548,-0.827444,-0.000002,-0.561548,-0.827444,-0.000002,-0.356632,-0.934245,0,-0.356632,-0.934245,0,-0.356632,-0.934245,0,-0.356612,-0.934253,-0.000002,-0.356612,-0.934253,-0.000002,-0.356612,-0.934253,-0.000002,-0.122173,-0.992509,-0.000002,-0.122173,-0.992509,-0.000002,-0.122173,-0.992509,-0.000002,-0.122196,-0.992506,0,-0.122196,-0.992506,0,-0.122196,-0.992506,0,0,-1,0,0,-1,0,0,-1,0,0.000001,-1,-0.000002,0.000001,-1,-0.000002,0.000001,-1,-0.000002,0.122179,-0.992508,0,0.122179,-0.992508,0,0.122179,-0.992508,0,0.122179,-0.992508,0,0.356591,-0.934261,0,0.356591,-0.934261,0,0.356591,-0.934261,0,0.356591,-0.934261,0,0.561553,-0.827441,0,0.561553,-0.827441,0,0.561553,-0.827441,0,0.561553,-0.827441,0,0.72957,-0.683906,0,0.72957,-0.683906,0,0.72957,-0.683906,0,0.72957,-0.683906,0,0.858919,-0.512112,0,0.858919,-0.512112,0,0.858919,-0.512112,0,0.858919,-0.512112,0,0.948091,-0.318,0,0.948091,-0.318,0,0.948091,-0.318,0,0.948091,-0.318,0,0.9942,-0.107545,0,0.9942,-0.107545,0,0.9942,-0.107545,0,0.9942,-0.107545,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.948091,0.318,0,0.948091,0.318,0,0.948091,0.318,0,0.948091,0.318,0,0.858907,0.512132,0,0.858907,0.512132,0,0.858907,0.512132,0,0.858907,0.512132,0,0.729581,0.683894,0,0.729581,0.683894,0,0.729581,0.683894,0,0.729581,0.683894,0,0.561542,0.827448,0,0.561542,0.827448,0,0.561542,0.827448,0,0.561542,0.827448,0,0.35666,0.934234,0,0.35666,0.934234,0,0.35666,0.934234,0,0.35666,0.934234,0,0.122111,0.992516,0,0.122111,0.992516,0,0.122111,0.992516,0,0.122111,0.992516,0,0.000001,1,0.000002,0.000001,1,0.000002,0.000001,1,0.000002,0,1,0,0,1,0,0,1,0,-0.122153,0.992511,0,-0.122153,0.992511,0,-0.122153,0.992511,0,-0.12213,0.992514,0.000002,-0.12213,0.992514,0.000002,-0.12213,0.992514,0.000002,-0.35664,0.934242,0,-0.35664,0.934242,0,-0.35664,0.934242,0,-0.35664,0.934242,0,-0.561526,0.827459,0,-0.561526,0.827459,0,-0.561526,0.827459,0,-0.561526,0.827459,0,-0.729592,0.683883,0,-0.729592,0.683883,0,-0.729592,0.683883,0,-0.729592,0.683883,0,-0.858885,0.512169,0,-0.858885,0.512169,0,-0.858885,0.512169,0,-0.858885,0.512169,0,-0.948095,0.317986,0,-0.948095,0.317986,0,-0.948095,0.317986,0,-0.948095,0.317986,0,-0.994205,0.1075,0,-0.994205,0.1075,0,-0.994205,0.1075,0,-0.994205,0.1075,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994202,-0.107526,0,-0.994202,-0.107526,0,-0.994202,-0.107526,0,-0.994203,-0.107524,0,-0.994203,-0.107524,0,-0.994203,-0.107524,0,-0.948095,-0.317986,0,-0.948095,-0.317986,0,-0.948095,-0.317986,0,-0.948093,-0.317993,-0.000001,-0.948093,-0.317993,-0.000001,-0.948093,-0.317993,-0.000001,-0.858897,-0.512149,-0.000001,-0.858897,-0.512149,-0.000001,-0.858897,-0.512149,-0.000001,-0.858903,-0.512139,0,-0.858903,-0.512139,0,-0.858903,-0.512139,0,-0.729593,-0.683882,0,-0.729593,-0.683882,0,-0.729593,-0.683882,0,-0.729582,-0.683894,-0.000002,-0.729582,-0.683894,-0.000002,-0.729582,-0.683894,-0.000002,-0.561537,-0.827452,0,-0.561537,-0.827452,0,-0.561537,-0.827452,0,-0.561537,-0.827452,0,-0.356612,-0.934253,0,-0.356612,-0.934253,0,-0.356612,-0.934253,0,-0.356612,-0.934253,0,-0.122179,-0.992508,0,-0.122179,-0.992508,0,-0.122179,-0.992508,0,-0.122179,-0.992508,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122184,-0.992507,0,0.122184,-0.992507,0,0.122184,-0.992507,0,0.122184,-0.992507,0,0.356591,-0.934261,0,0.356591,-0.934261,0,0.356591,-0.934261,0,0.356591,-0.934261,0,0.561558,-0.827437,0,0.561558,-0.827437,0,0.561558,-0.827437,0,0.561558,-0.827437,0,0.729558,-0.683919,0,0.729558,-0.683919,0,0.729558,-0.683919,0,0.729558,-0.683919,0,0.858939,-0.512078,0,0.858939,-0.512078,0,0.858939,-0.512078,0,0.858939,-0.512078,0,0.948075,-0.318047,0,0.948075,-0.318047,0,0.948075,-0.318047,0,0.948075,-0.318047,0,0.994203,-0.107524,0,0.994203,-0.107524,0,0.994203,-0.107524,0,0.994203,-0.107524,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994201,0.107541,0,0.994201,0.107541,0,0.994201,0.107541,0,0.994201,0.107541,0,0.948102,0.317966,0,0.948102,0.317966,0,0.948102,0.317966,0,0.948102,0.317966,0,0.858887,0.512166,0,0.858887,0.512166,0,0.858887,0.512166,0,0.858887,0.512166,0,0.729569,0.683907,0,0.729569,0.683907,0,0.729569,0.683907,0,0.729569,0.683907,0,0.561558,0.827437,0,0.561558,0.827437,0,0.561558,0.827437,0,0.561558,0.827437,0,0.356648,0.934239,0,0.356648,0.934239,0,0.356648,0.934239,0,0.356648,0.934239,0,0.122133,0.992514,0,0.122133,0.992514,0,0.122133,0.992514,0,0.122133,0.992514,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122156,0.992511,0,-0.122156,0.992511,0,-0.122156,0.992511,0,-0.122156,0.992511,0,-0.356668,0.934231,0,-0.356668,0.934231,0,-0.356668,0.934231,0,-0.356668,0.934231,0,-0.561515,0.827467,0,-0.561515,0.827467,0,-0.561515,0.827467,0,-0.561515,0.827467,0,-0.729616,0.683857,0,-0.729616,0.683857,0,-0.729616,0.683857,0,-0.729616,0.683857,0,-0.858874,0.512186,0,-0.858874,0.512186,0,-0.858874,0.512186,0,-0.858874,0.512186,0,-0.948109,0.317946,0,-0.948109,0.317946,0,-0.948109,0.317946,0,-0.948109,0.317946,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994209,-0.10746,0,-0.994209,-0.10746,0,-0.994209,-0.10746,0,-0.994209,-0.10746,0,-0.948082,-0.318026,0,-0.948082,-0.318026,0,-0.948082,-0.318026,0,-0.948082,-0.318026,0,-0.858897,-0.512149,0,-0.858897,-0.512149,0,-0.858897,-0.512149,0,-0.858897,-0.512149,0,-0.729605,-0.683869,0,-0.729605,-0.683869,0,-0.729605,-0.683869,0,-0.729605,-0.683869,0,-0.561515,-0.827467,0,-0.561515,-0.827467,0,-0.561515,-0.827467,0,-0.561515,-0.827467,0,-0.356627,-0.934247,0,-0.356627,-0.934247,0,-0.356627,-0.934247,0,-0.356627,-0.934247,0,-0.12219,-0.992507,0,-0.12219,-0.992507,0,-0.12219,-0.992507,0,-0.12219,-0.992507,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.122181,-0.992508,0,0.122181,-0.992508,0,0.122181,-0.992508,0,0.122181,-0.992508,0,0.356591,-0.934261,0,0.356591,-0.934261,0,0.356591,-0.934261,0,0.356591,-0.934261,0,0.561553,-0.827441,0,0.561553,-0.827441,0,0.561553,-0.827441,0,0.561553,-0.827441,0,0.72957,-0.683906,0,0.72957,-0.683906,0,0.72957,-0.683906,0,0.72957,-0.683906,0,0.858929,-0.512095,0,0.858929,-0.512095,0,0.858929,-0.512095,0,0.858929,-0.512095,0,0.948084,-0.31802,0,0.948084,-0.31802,0,0.948084,-0.31802,0,0.948084,-0.31802,0,0.994198,-0.107566,0,0.994198,-0.107566,0,0.994198,-0.107566,0,0.994198,-0.107566,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994196,0.107585,0,0.994196,0.107585,0,0.994196,0.107585,0,0.994196,0.107585,0,0.948104,0.317959,0,0.948104,0.317959,0,0.948104,0.317959,0,0.948104,0.317959,0,0.858897,0.512149,0,0.858897,0.512149,0,0.858897,0.512149,0,0.858897,0.512149,0,0.729569,0.683907,0,0.729569,0.683907,0,0.729569,0.683907,0,0.729569,0.683907,0,0.561542,0.827448,0,0.561542,0.827448,0,0.561542,0.827448,0,0.561542,0.827448,0,0.356676,0.934228,0,0.356676,0.934228,0,0.356676,0.934228,0,0.356676,0.934228,0,0.122108,0.992517,0,0.122108,0.992517,0,0.122108,0.992517,0,0.122108,0.992517,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122122,0.992515,0,-0.122122,0.992515,0,-0.122122,0.992515,0,-0.122122,0.992515,0,-0.356656,0.934236,0,-0.356656,0.934236,0,-0.356656,0.934236,0,-0.356656,0.934236,0,-0.561526,0.827459,0,-0.561526,0.827459,0,-0.561526,0.827459,0,-0.561526,0.827459,0,-0.72958,0.683895,0,-0.72958,0.683895,0,-0.72958,0.683895,0,-0.72958,0.683895,0,-0.858874,0.512186,0,-0.858874,0.512186,0,-0.858874,0.512186,0,-0.858874,0.512186,0,-0.9481,0.317973,0.000001,-0.9481,0.317973,0.000001,-0.9481,0.317973,0.000001,-0.948102,0.317966,0,-0.948102,0.317966,0,-0.948102,0.317966,0,-0.994201,0.107541,0,-0.994201,0.107541,0,-0.994201,0.107541,0,-0.9942,0.107543,0,-0.9942,0.107543,0,-0.9942,0.107543,0,-1,-0.000003,0,-1,-0.000003,0,-1,-0.000003,0,-1,-0.000003,0,-0.994205,-0.107505,0,-0.994205,-0.107505,0,-0.994205,-0.107505,0,-0.994205,-0.107505,0,-0.948102,-0.317966,0,-0.948102,-0.317966,0,-0.948102,-0.317966,0,-0.948102,-0.317966,0,-0.858887,-0.512166,0,-0.858887,-0.512166,0,-0.858887,-0.512166,0,-0.858887,-0.512166,0,-0.729558,-0.683919,-0.000002,-0.729558,-0.683919,-0.000002,-0.729558,-0.683919,-0.000002,-0.729569,-0.683907,0,-0.729569,-0.683907,0,-0.729569,-0.683907,0,-0.56157,-0.82743,0,-0.56157,-0.82743,0,-0.56157,-0.82743,0,-0.561553,-0.827441,-0.000002,-0.561553,-0.827441,-0.000002,-0.561553,-0.827441,-0.000002,-0.356624,-0.934248,0,-0.356624,-0.934248,0,-0.356624,-0.934248,0,-0.356624,-0.934248,0,-0.122176,-0.992508,0,-0.122176,-0.992508,0,-0.122176,-0.992508,0,-0.122176,-0.992508,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122179,-0.992508,0,0.122179,-0.992508,0,0.122179,-0.992508,0,0.122179,-0.992508,0,0.356575,-0.934267,0,0.356575,-0.934267,0,0.356575,-0.934267,0,0.356575,-0.934267,0,0.561591,-0.827415,0,0.561591,-0.827415,0,0.561591,-0.827415,0,0.561591,-0.827415,0,0.729558,-0.683919,0,0.729558,-0.683919,0,0.729558,-0.683919,0,0.729558,-0.683919,0,0.858909,-0.512129,0,0.858909,-0.512129,0,0.858909,-0.512129,0,0.858909,-0.512129,0,0.948095,-0.317986,0,0.948095,-0.317986,0,0.948095,-0.317986,0,0.948095,-0.317986,0,0.994205,-0.1075,0,0.994205,-0.1075,0,0.994205,-0.1075,0,0.994205,-0.1075,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994205,0.1075,0,0.994205,0.1075,0,0.994205,0.1075,0,0.994205,0.1075,0,0.948095,0.317986,0,0.948095,0.317986,0,0.948095,0.317986,0,0.948095,0.317986,0,0.858897,0.512149,0,0.858897,0.512149,0,0.858897,0.512149,0,0.858897,0.512149,0,0.729569,0.683907,0,0.729569,0.683907,0,0.729569,0.683907,0,0.729569,0.683907,0,0.561547,0.827445,0,0.561547,0.827445,0,0.561547,0.827445,0,0.561547,0.827445,0,0.356616,0.934251,0,0.356616,0.934251,0,0.356616,0.934251,0,0.356616,0.934251,0,0.122142,0.992513,0,0.122142,0.992513,0,0.122142,0.992513,0,0.122142,0.992513,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122153,0.992511,0,-0.122153,0.992511,0,-0.122153,0.992511,0,-0.122153,0.992511,0,-0.356676,0.934228,0,-0.356676,0.934228,0,-0.356676,0.934228,0,-0.356676,0.934228,0,-0.561548,0.827444,0,-0.561548,0.827444,0,-0.561548,0.827444,0,-0.561548,0.827444,0,-0.729593,0.683882,0,-0.729593,0.683882,0,-0.729593,0.683882,0,-0.729593,0.683882,0,-0.858874,0.512186,0,-0.858874,0.512186,0,-0.858874,0.512186,0,-0.858874,0.512186,0,-0.948075,0.318047,0,-0.948075,0.318047,0,-0.948075,0.318047,0,-0.948075,0.318047,0,-0.994205,0.1075,0,-0.994205,0.1075,0,-0.994205,0.1075,0,-0.994205,0.1075,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994205,-0.107503,0,-0.994205,-0.107503,0,-0.994205,-0.107503,0,-0.994205,-0.107503,0,-0.948075,-0.318047,0,-0.948075,-0.318047,0,-0.948075,-0.318047,0,-0.948075,-0.318047,0,-0.858887,-0.512166,0,-0.858887,-0.512166,0,-0.858887,-0.512166,0,-0.858887,-0.512166,0,-0.729605,-0.683869,0,-0.729605,-0.683869,0,-0.729605,-0.683869,0,-0.729605,-0.683869,0,-0.561548,-0.827444,0,-0.561548,-0.827444,0,-0.561548,-0.827444,0,-0.561548,-0.827444,0,-0.356619,-0.93425,0,-0.356619,-0.93425,0,-0.356619,-0.93425,0,-0.356619,-0.93425,0,-0.122193,-0.992506,0,-0.122193,-0.992506,0,-0.122193,-0.992506,0,-0.122193,-0.992506,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122181,-0.992508,0,0.122181,-0.992508,0,0.122181,-0.992508,0,0.122181,-0.992508,0,0.356568,-0.93427,0,0.356568,-0.93427,0,0.356568,-0.93427,0,0.356568,-0.93427,0,0.561586,-0.827419,0,0.561586,-0.827419,0,0.561586,-0.827419,0,0.561586,-0.827419,0,0.729546,-0.683932,0,0.729546,-0.683932,0,0.729546,-0.683932,0,0.729546,-0.683932,0,0.858953,-0.512054,0,0.858953,-0.512054,0,0.858953,-0.512054,0,0.858953,-0.512054,0,0.948098,-0.31798,0,0.948098,-0.31798,0,0.948098,-0.31798,0,0.948098,-0.31798,0,0.994196,-0.107588,0,0.994196,-0.107588,0,0.994196,-0.107588,0,0.994196,-0.107588,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994205,0.1075,0,0.994205,0.1075,0,0.994205,0.1075,0,0.994205,0.1075,0,0.948111,0.317939,0,0.948111,0.317939,0,0.948111,0.317939,0,0.948111,0.317939,0,0.858866,0.5122,0,0.858866,0.5122,0,0.858866,0.5122,0,0.858866,0.5122,0,0.729569,0.683907,0,0.729569,0.683907,0,0.729569,0.683907,0,0.729569,0.683907,0,0.561602,0.827408,0,0.561602,0.827408,0,0.561602,0.827408,0,0.561602,0.827408,0,0.356609,0.934254,0,0.356609,0.934254,0,0.356609,0.934254,0,0.356609,0.934254,0,0.122136,0.992513,0,0.122136,0.992513,0,0.122136,0.992513,0,0.122136,0.992513,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122125,0.992515,0,-0.122125,0.992515,0,-0.122125,0.992515,0,-0.122125,0.992515,0,-0.356596,0.934259,0,-0.356596,0.934259,0,-0.356596,0.934259,0,-0.356596,0.934259,0,-0.561548,0.827444,0,-0.561548,0.827444,0,-0.561548,0.827444,0,-0.561548,0.827444,0,-0.729593,0.683882,0,-0.729593,0.683882,0,-0.729593,0.683882,0,-0.729593,0.683882,0,-0.858917,0.512115,0,-0.858917,0.512115,0,-0.858917,0.512115,0,-0.858917,0.512115,0,-0.948084,0.31802,0,-0.948084,0.31802,0,-0.948084,0.31802,0,-0.948084,0.31802,0,-0.994203,0.107519,0,-0.994203,0.107519,0,-0.994203,0.107519,0,-0.994203,0.107519,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994205,-0.107501,0,-0.994205,-0.107501,0,-0.994205,-0.107501,0,-0.994205,-0.107501,0,-0.9481,-0.317973,0,-0.9481,-0.317973,0,-0.9481,-0.317973,0,-0.9481,-0.317973,0,-0.858884,-0.512171,0,-0.858884,-0.512171,0,-0.858884,-0.512171,0,-0.858884,-0.512171,0,-0.729581,-0.683894,0,-0.729581,-0.683894,0,-0.729581,-0.683894,0,-0.729581,-0.683894,0,-0.561526,-0.827459,0,-0.561526,-0.827459,0,-0.561526,-0.827459,0,-0.561526,-0.827459,0,-0.35663,-0.934246,0,-0.35663,-0.934246,0,-0.35663,-0.934246,0,-0.35663,-0.934246,0,-0.122179,-0.992508,0,-0.122179,-0.992508,0,-0.122179,-0.992508,0,-0.122179,-0.992508,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122162,-0.99251,-0.000001,0.122162,-0.99251,-0.000001,0.122162,-0.99251,-0.000001,0.12215,-0.992512,0,0.12215,-0.992512,0,0.12215,-0.992512,0,0.356601,-0.934257,0,0.356601,-0.934257,0,0.356601,-0.934257,0,0.356612,-0.934253,-0.000001,0.356612,-0.934253,-0.000001,0.356612,-0.934253,-0.000001,0.56158,-0.827422,-0.000001,0.56158,-0.827422,-0.000001,0.56158,-0.827422,-0.000001,0.561572,-0.827428,0,0.561572,-0.827428,0,0.561572,-0.827428,0,0.729558,-0.683919,-0.000001,0.729558,-0.683919,-0.000001,0.729558,-0.683919,-0.000001,0.729558,-0.683919,-0.000001,0.858882,-0.512173,-0.000001,0.858882,-0.512173,-0.000001,0.858882,-0.512173,-0.000001,0.858882,-0.512173,-0.000001,0.948118,-0.317919,0,0.948118,-0.317919,0,0.948118,-0.317919,0,0.948119,-0.317916,0,0.948119,-0.317916,0,0.948119,-0.317916,0,0.9942,-0.107544,0,0.9942,-0.107544,0,0.9942,-0.107544,0,0.9942,-0.107545,0,0.9942,-0.107545,0,0.9942,-0.107545,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,0.994203,0.107519,0,0.994203,0.107519,0,0.994203,0.107519,0,0.994203,0.107519,0,0.948095,0.317986,0,0.948095,0.317986,0,0.948095,0.317986,0,0.948095,0.317986,0,0.858897,0.512149,0,0.858897,0.512149,0,0.858897,0.512149,0,0.858897,0.512149,0,0.729593,0.683882,0,0.729593,0.683882,0,0.729593,0.683882,0,0.729593,0.683882,0,0.561602,0.827408,0,0.561602,0.827408,0,0.561602,0.827408,0,0.561602,0.827408,0,0.356612,0.934253,0,0.356612,0.934253,0,0.356612,0.934253,0,0.356612,0.934253,0,0.122145,0.992512,0,0.122145,0.992512,0,0.122145,0.992512,0,0.122145,0.992512,0,0,1,0.000002,0,1,0.000002,0,1,0.000002,-0.000001,1,0,-0.000001,1,0,-0.000001,1,0,-0.122179,0.992508,0,-0.122179,0.992508,0,-0.122179,0.992508,0,-0.122156,0.992511,0.000002,-0.122156,0.992511,0.000002,-0.122156,0.992511,0.000002,-0.35664,0.934242,0,-0.35664,0.934242,0,-0.35664,0.934242,0,-0.35664,0.934242,0,-0.561537,0.827452,0,-0.561537,0.827452,0,-0.561537,0.827452,0,-0.561537,0.827452,0,-0.729593,0.683882,0,-0.729593,0.683882,0,-0.729593,0.683882,0,-0.729593,0.683882,0,-0.858891,0.512159,0,-0.858891,0.512159,0,-0.858891,0.512159,0,-0.858891,0.512159,0,-0.948091,0.318,0,-0.948091,0.318,0,-0.948091,0.318,0,-0.948091,0.318,0,-0.994203,0.107519,0,-0.994203,0.107519,0,-0.994203,0.107519,0,-0.994203,0.107519,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-0.994198,-0.107565,0,-0.994198,-0.107565,0,-0.994198,-0.107565,0,-0.994198,-0.107565,0,-0.948093,-0.317993,0,-0.948093,-0.317993,0,-0.948093,-0.317993,0,-0.948093,-0.317993,0,-0.858914,-0.51212,0,-0.858914,-0.51212,0,-0.858914,-0.51212,0,-0.858914,-0.51212,0,-0.729581,-0.683894,0,-0.729581,-0.683894,0,-0.729581,-0.683894,0,-0.729581,-0.683894,0,-0.561515,-0.827467,0,-0.561515,-0.827467,0,-0.561515,-0.827467,0,-0.561515,-0.827467,0,-0.356635,-0.934244,0,-0.356635,-0.934244,0,-0.356635,-0.934244,0,-0.356635,-0.934244,0,-0.122187,-0.992507,0,-0.122187,-0.992507,0,-0.122187,-0.992507,0,-0.122187,-0.992507,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122164,-0.99251,0,0.122164,-0.99251,0,0.122164,-0.99251,0,0.122164,-0.99251,0,0.356617,-0.934251,0,0.356617,-0.934251,0,0.356617,-0.934251,0,0.356617,-0.934251,0,0.561572,-0.827428,0,0.561572,-0.827428,0,0.561572,-0.827428,0,0.561572,-0.827428,0,0.729547,-0.683931,0,0.729547,-0.683931,0,0.729547,-0.683931,0,0.729547,-0.683931,0,0.858903,-0.512139,0,0.858903,-0.512139,0,0.858903,-0.512139,0,0.858903,-0.512139,0,0.948099,-0.317976,0,0.948099,-0.317976,0,0.948099,-0.317976,0,0.948099,-0.317976,0,0.9942,-0.107544,0,0.9942,-0.107544,0,0.9942,-0.107544,0,0.9942,-0.107544,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.948084,0.31802,0,0.948084,0.31802,0,0.948084,0.31802,0,0.948084,0.31802,0,0.858917,0.512115,0,0.858917,0.512115,0,0.858917,0.512115,0,0.858917,0.512115,0,0.729593,0.683882,0,0.729593,0.683882,0,0.729593,0.683882,0,0.729593,0.683882,0,0.561553,0.827441,0,0.561553,0.827441,0,0.561553,0.827441,0,0.561553,0.827441,0,0.356616,0.934251,0,0.356616,0.934251,0,0.356616,0.934251,0,0.356616,0.934251,0,0.122133,0.992514,0,0.122133,0.992514,0,0.122133,0.992514,0,0.122133,0.992514,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122153,0.992511,0,-0.122153,0.992511,0,-0.122153,0.992511,0,-0.122153,0.992511,0,-0.356612,0.934253,0,-0.356612,0.934253,0,-0.356612,0.934253,0,-0.356612,0.934253,0,-0.561537,0.827452,0,-0.561537,0.827452,0,-0.561537,0.827452,0,-0.561537,0.827452,0,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.858901,0.512142,0,-0.858901,0.512142,0,-0.858901,0.512142,0,-0.858901,0.512142,0,-0.948093,0.317993,0,-0.948093,0.317993,0,-0.948093,0.317993,0,-0.948093,0.317993,0,-0.994201,0.107541,0,-0.994201,0.107541,0,-0.994201,0.107541,0,-0.994201,0.107541,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-0.994203,-0.107523,0,-0.994203,-0.107523,0,-0.994203,-0.107523,0,-0.994203,-0.107523,0,-0.948107,-0.317953,0,-0.948107,-0.317953,0,-0.948107,-0.317953,0,-0.948107,-0.317953,0,-0.858881,-0.512176,-0.000001,-0.858881,-0.512176,-0.000001,-0.858881,-0.512176,-0.000001,-0.858884,-0.512171,0,-0.858884,-0.512171,0,-0.858884,-0.512171,0,-0.729581,-0.683894,-0.000001,-0.729581,-0.683894,-0.000001,-0.729581,-0.683894,-0.000001,-0.729581,-0.683894,-0.000001,-0.561515,-0.827467,-0.000001,-0.561515,-0.827467,-0.000001,-0.561515,-0.827467,-0.000001,-0.561515,-0.827467,-0.000001,-0.356638,-0.934243,0,-0.356638,-0.934243,0,-0.356638,-0.934243,0,-0.356627,-0.934247,-0.000001,-0.356627,-0.934247,-0.000001,-0.356627,-0.934247,-0.000001,-0.122193,-0.992506,0,-0.122193,-0.992506,0,-0.122193,-0.992506,0,-0.122193,-0.992506,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0,-1,0,0,-1,0,0.122164,-0.99251,-0.000001,0.122164,-0.99251,-0.000001,0.122164,-0.99251,-0.000001,0.122164,-0.99251,-0.000001,0.356617,-0.934251,-0.000001,0.356617,-0.934251,-0.000001,0.356617,-0.934251,-0.000001,0.356617,-0.934251,-0.000001,0.56155,-0.827443,-0.000001,0.56155,-0.827443,-0.000001,0.56155,-0.827443,-0.000001,0.56155,-0.827443,-0.000001,0.729558,-0.683919,0,0.729558,-0.683919,0,0.729558,-0.683919,0,0.729564,-0.683913,-0.000001,0.729564,-0.683913,-0.000001,0.729564,-0.683913,-0.000001,0.858903,-0.512139,0,0.858903,-0.512139,0,0.858903,-0.512139,0,0.858903,-0.512139,0,0.948092,-0.317996,0,0.948092,-0.317996,0,0.948092,-0.317996,0,0.948091,-0.318,0,0.948091,-0.318,0,0.948091,-0.318,0,0.994205,-0.107501,0,0.994205,-0.107501,0,0.994205,-0.107501,0,0.994205,-0.107501,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.948082,0.318027,0,0.948082,0.318027,0,0.948082,0.318027,0,0.948082,0.318027,0,0.858907,0.512132,0,0.858907,0.512132,0,0.858907,0.512132,0,0.858907,0.512132,0,0.729581,0.683894,0,0.729581,0.683894,0,0.729581,0.683894,0,0.729581,0.683894,0,0.561569,0.82743,0,0.561569,0.82743,0,0.561569,0.82743,0,0.561569,0.82743,0,0.356619,0.93425,0,0.356619,0.93425,0,0.356619,0.93425,0,0.356619,0.93425,0,0.122153,0.992511,0,0.122153,0.992511,0,0.122153,0.992511,0,0.122153,0.992511,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122181,0.992508,0,-0.122181,0.992508,0,-0.122181,0.992508,0,-0.122181,0.992508,0,-0.356636,0.934243,0,-0.356636,0.934243,0,-0.356636,0.934243,0,-0.356636,0.934243,0,-0.561531,0.827456,0,-0.561531,0.827456,0,-0.561531,0.827456,0,-0.561531,0.827456,0,-0.729604,0.68387,0,-0.729604,0.68387,0,-0.729604,0.68387,0,-0.729604,0.68387,0,-0.858886,0.512168,0,-0.858886,0.512168,0,-0.858886,0.512168,0,-0.858886,0.512168,0,-0.948087,0.31801,0,-0.948087,0.31801,0,-0.948087,0.31801,0,-0.948087,0.31801,0,-0.994203,0.107519,0,-0.994203,0.107519,0,-0.994203,0.107519,0,-0.994203,0.107519,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994201,-0.107535,0,-0.994201,-0.107535,0,-0.994201,-0.107535,0,-0.994201,-0.107533,0,-0.994201,-0.107533,0,-0.994201,-0.107533,0,-0.948103,-0.317963,0,-0.948103,-0.317963,0,-0.948103,-0.317963,0,-0.948103,-0.317963,0,-0.858884,-0.512171,0,-0.858884,-0.512171,0,-0.858884,-0.512171,0,-0.858881,-0.512176,-0.000001,-0.858881,-0.512176,-0.000001,-0.858881,-0.512176,-0.000001,-0.729587,-0.683888,0,-0.729587,-0.683888,0,-0.729587,-0.683888,0,-0.729587,-0.683888,0,-0.561515,-0.827467,0,-0.561515,-0.827467,0,-0.561515,-0.827467,0,-0.561515,-0.827467,0,-0.356641,-0.934241,0,-0.356641,-0.934241,0,-0.356641,-0.934241,0,-0.356641,-0.934241,0,-0.122177,-0.992508,0,-0.122177,-0.992508,0,-0.122177,-0.992508,0,-0.122177,-0.992508,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122166,-0.99251,0,0.122166,-0.99251,0,0.122166,-0.99251,0,0.122166,-0.99251,0,0.356609,-0.934254,0,0.356609,-0.934254,0,0.356609,-0.934254,0,0.356609,-0.934254,0,0.561555,-0.827439,0,0.561555,-0.827439,0,0.561555,-0.827439,0,0.561555,-0.827439,0,0.729587,-0.683888,0,0.729587,-0.683888,0,0.729587,-0.683888,0,0.729587,-0.683888,0,0.858888,-0.512164,0,0.858888,-0.512164,0,0.858888,-0.512164,0,0.858888,-0.512164,0,0.948101,-0.31797,0,0.948101,-0.31797,0,0.948101,-0.31797,0,0.948101,-0.31797,0,0.994203,-0.107523,0,0.994203,-0.107523,0,0.994203,-0.107523,0,0.994203,-0.107523,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994204,0.107511,0,0.994204,0.107511,0,0.994204,0.107511,0,0.994204,0.107511,0,0.948084,0.31802,0.000001,0.948084,0.31802,0.000001,0.948084,0.31802,0.000001,0.948084,0.31802,0.000001,0.858917,0.512115,0.000001,0.858917,0.512115,0.000001,0.858917,0.512115,0.000001,0.858917,0.512115,0.000001,0.729581,0.683894,0.000002,0.729581,0.683894,0.000002,0.729581,0.683894,0.000002,0.729581,0.683894,0.000002,0.561553,0.827441,0,0.561553,0.827441,0,0.561553,0.827441,0,0.561569,0.82743,0.000002,0.561569,0.82743,0.000002,0.561569,0.82743,0.000002,0.35662,0.934249,0,0.35662,0.934249,0,0.35662,0.934249,0,0.35662,0.934249,0,0.122136,0.992513,0,0.122136,0.992513,0,0.122136,0.992513,0,0.122136,0.992513,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122156,0.992511,0,-0.122156,0.992511,0,-0.122156,0.992511,0,-0.122156,0.992511,0,-0.356616,0.934251,0,-0.356616,0.934251,0,-0.356616,0.934251,0,-0.356616,0.934251,0,-0.561539,0.82745,0,-0.561539,0.82745,0,-0.561539,0.82745,0,-0.561539,0.82745,0,-0.729578,0.683898,0,-0.729578,0.683898,0,-0.729578,0.683898,0,-0.729578,0.683898,0,-0.858901,0.512142,0,-0.858901,0.512142,0,-0.858901,0.512142,0,-0.858901,0.512142,0,-0.948091,0.317998,0,-0.948091,0.317998,0,-0.948091,0.317998,0,-0.948091,0.317998,0,-0.994202,0.107525,0,-0.994202,0.107525,0,-0.994202,0.107525,0,-0.994202,0.107525,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994204,-0.107513,0,-0.994204,-0.107513,0,-0.994204,-0.107513,0,-0.994204,-0.107513,0,-0.948095,-0.317988,0,-0.948095,-0.317988,0,-0.948095,-0.317988,0,-0.948095,-0.317988,0,-0.858891,-0.512158,0,-0.858891,-0.512158,0,-0.858891,-0.512158,0,-0.858891,-0.512158,0,-0.72959,-0.683885,0,-0.72959,-0.683885,0,-0.72959,-0.683885,0,-0.72959,-0.683885,0,-0.561528,-0.827457,0,-0.561528,-0.827457,0,-0.561528,-0.827457,0,-0.561528,-0.827457,0,-0.356626,-0.934247,0,-0.356626,-0.934247,0,-0.356626,-0.934247,0,-0.356626,-0.934247,0,-0.122178,-0.992508,0,-0.122178,-0.992508,0,-0.122178,-0.992508,0,-0.122178,-0.992508,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122164,-0.99251,0,0.122164,-0.99251,0,0.122164,-0.99251,0,0.122164,-0.99251,0,0.356609,-0.934254,0,0.356609,-0.934254,0,0.356609,-0.934254,0,0.356609,-0.934254,0,0.561561,-0.827435,0,0.561561,-0.827435,0,0.561561,-0.827435,0,0.561561,-0.827435,0,0.729575,-0.6839,0,0.729575,-0.6839,0,0.729575,-0.6839,0,0.729575,-0.6839,0,0.858908,-0.51213,0,0.858908,-0.51213,0,0.858908,-0.51213,0,0.858908,-0.51213,0,0.948087,-0.31801,0,0.948087,-0.31801,0,0.948087,-0.31801,0,0.948087,-0.31801,0,0.994204,-0.107512,0,0.994204,-0.107512,0,0.994204,-0.107512,0,0.994204,-0.107512,0,1,0,0,1,0,0,1,0,0,1,0,0,0.9942,0.107543,0,0.9942,0.107543,0,0.9942,0.107543,0,0.9942,0.107543,0,0.948085,0.318017,0,0.948085,0.318017,0,0.948085,0.318017,0,0.948085,0.318017,0,0.858918,0.512113,0.000001,0.858918,0.512113,0.000001,0.858918,0.512113,0.000001,0.858912,0.512124,0,0.858912,0.512124,0,0.858912,0.512124,0,0.729575,0.683901,0.000002,0.729575,0.683901,0.000002,0.729575,0.683901,0.000002,0.729575,0.683901,0.000002,0.561558,0.827437,0,0.561558,0.827437,0,0.561558,0.827437,0,0.561574,0.827426,0.000002,0.561574,0.827426,0.000002,0.561574,0.827426,0.000002,0.356644,0.93424,0.000002,0.356644,0.93424,0.000002,0.356644,0.93424,0.000002,0.356623,0.934248,0,0.356623,0.934248,0,0.356623,0.934248,0,0.122129,0.992514,0,0.122129,0.992514,0,0.122129,0.992514,0,0.122152,0.992511,0.000002,0.122152,0.992511,0.000002,0.122152,0.992511,0.000002,0,1,0,0,1,0,0,1,0,0,1,0,-0.122177,0.992508,0,-0.122177,0.992508,0,-0.122177,0.992508,0,-0.122177,0.992508,0,-0.356616,0.934251,0,-0.356616,0.934251,0,-0.356616,0.934251,0,-0.356616,0.934251,0,-0.561532,0.827455,0,-0.561532,0.827455,0,-0.561532,0.827455,0,-0.561532,0.827455,0,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.858904,0.512136,0,-0.858904,0.512136,0,-0.858904,0.512136,0,-0.858904,0.512136,0,-0.948091,0.318,0,-0.948091,0.318,0,-0.948091,0.318,0,-0.948091,0.318,0,-0.994202,0.107525,0,-0.994202,0.107525,0,-0.994202,0.107525,0,-0.994202,0.107525,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994203,-0.107521,0,-0.994203,-0.107521,0,-0.994203,-0.107521,0,-0.994203,-0.10752,0,-0.994203,-0.10752,0,-0.994203,-0.10752,0,-0.948093,-0.317993,0,-0.948093,-0.317993,0,-0.948093,-0.317993,0,-0.948093,-0.317993,0,-0.858895,-0.512152,-0.000001,-0.858895,-0.512152,-0.000001,-0.858895,-0.512152,-0.000001,-0.858895,-0.512152,-0.000001,-0.729582,-0.683893,-0.000001,-0.729582,-0.683893,-0.000001,-0.729582,-0.683893,-0.000001,-0.729582,-0.683893,-0.000001,-0.561532,-0.827455,-0.000001,-0.561532,-0.827455,-0.000001,-0.561532,-0.827455,-0.000001,-0.561532,-0.827455,-0.000001,-0.356629,-0.934246,-0.000001,-0.356629,-0.934246,-0.000001,-0.356629,-0.934246,-0.000001,-0.356629,-0.934246,-0.000001,-0.122177,-0.992508,-0.000001,-0.122177,-0.992508,-0.000001,-0.122177,-0.992508,-0.000001,-0.122177,-0.992508,-0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0.122166,-0.99251,0,0.122166,-0.99251,0,0.122166,-0.99251,0,0.122166,-0.99251,0,0.356607,-0.934254,0,0.356607,-0.934254,0,0.356607,-0.934254,0,0.356607,-0.934254,0,0.561569,-0.82743,0,0.561569,-0.82743,0,0.561569,-0.82743,0,0.561569,-0.82743,0,0.729561,-0.683915,0,0.729561,-0.683915,0,0.729561,-0.683915,0,0.729561,-0.683915,0,0.858903,-0.512139,0,0.858903,-0.512139,0,0.858903,-0.512139,0,0.858903,-0.512139,0,0.948096,-0.317985,0,0.948096,-0.317985,0,0.948096,-0.317985,0,0.948096,-0.317985,0,0.994203,-0.107517,0,0.994203,-0.107517,0,0.994203,-0.107517,0,0.994203,-0.107517,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994204,0.107514,0,0.994204,0.107514,0,0.994204,0.107514,0,0.994204,0.107514,0,0.948087,0.318011,0,0.948087,0.318011,0,0.948087,0.318011,0,0.948087,0.318011,0,0.858909,0.512128,0,0.858909,0.512128,0,0.858909,0.512128,0,0.858909,0.512128,0,0.729581,0.683894,0,0.729581,0.683894,0,0.729581,0.683894,0,0.729581,0.683894,0,0.561566,0.827432,0,0.561566,0.827432,0,0.561566,0.827432,0,0.561566,0.827432,0,0.356619,0.93425,0,0.356619,0.93425,0,0.356619,0.93425,0,0.356619,0.93425,0,0.122153,0.992511,0,0.122153,0.992511,0,0.122153,0.992511,0,0.122153,0.992511,0,-0.000001,1,0,-0.000001,1,0,-0.000001,1,0,-0.000001,1,0,-0.122156,0.992511,0,-0.122156,0.992511,0,-0.122156,0.992511,0,-0.122156,0.992511,0,-0.356638,0.934243,0.000002,-0.356638,0.934243,0.000002,-0.356638,0.934243,0.000002,-0.356638,0.934243,0.000002,-0.561531,0.827456,0.000002,-0.561531,0.827456,0.000002,-0.561531,0.827456,0.000002,-0.561531,0.827456,0.000002,-0.729582,0.683893,0,-0.729582,0.683893,0,-0.729582,0.683893,0,-0.729571,0.683905,0.000002,-0.729571,0.683905,0.000002,-0.729571,0.683905,0.000002,-0.858893,0.512155,0,-0.858893,0.512155,0,-0.858893,0.512155,0,-0.858893,0.512155,0,-0.948095,0.317988,0,-0.948095,0.317988,0,-0.948095,0.317988,0,-0.948095,0.317988,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994202,-0.107525,0,-0.994202,-0.107525,0,-0.994202,-0.107525,0,-0.994202,-0.107525,0,-0.948095,-0.317988,0,-0.948095,-0.317988,0,-0.948095,-0.317988,0,-0.948095,-0.317988,0,-0.858896,-0.51215,0,-0.858896,-0.51215,0,-0.858896,-0.51215,0,-0.858896,-0.51215,0,-0.729582,-0.683893,0,-0.729582,-0.683893,0,-0.729582,-0.683893,0,-0.729582,-0.683893,0,-0.561531,-0.827456,0,-0.561531,-0.827456,0,-0.561531,-0.827456,0,-0.561531,-0.827456,0,-0.356628,-0.934247,0,-0.356628,-0.934247,0,-0.356628,-0.934247,0,-0.356628,-0.934247,0,-0.122178,-0.992508,0,-0.122178,-0.992508,0,-0.122178,-0.992508,0,-0.122178,-0.992508,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122166,-0.99251,0,0.122166,-0.99251,0,0.122166,-0.99251,0,0.122166,-0.99251,0,0.356609,-0.934254,0,0.356609,-0.934254,0,0.356609,-0.934254,0,0.356609,-0.934254,0,0.561562,-0.827435,0,0.561562,-0.827435,0,0.561562,-0.827435,0,0.561562,-0.827435,0,0.729571,-0.683905,0,0.729571,-0.683905,0,0.729571,-0.683905,0,0.729571,-0.683905,0,0.858903,-0.512139,0,0.858903,-0.512139,0,0.858903,-0.512139,0,0.858903,-0.512139,0,0.948094,-0.31799,0,0.948094,-0.31799,0,0.948094,-0.31799,0,0.948094,-0.31799,0,0.994202,-0.107525,0,0.994202,-0.107525,0,0.994202,-0.107525,0,0.994202,-0.107525,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994203,0.107519,0,0.994203,0.107519,0,0.994203,0.107519,0,0.994203,0.107519,0,0.948091,0.317999,0,0.948091,0.317999,0,0.948091,0.317999,0,0.948091,0.317999,0,0.858901,0.512142,0,0.858901,0.512142,0,0.858901,0.512142,0,0.858901,0.512142,0,0.729582,0.683894,0,0.729582,0.683894,0,0.729582,0.683894,0,0.729582,0.683894,0,0.561551,0.827442,0,0.561551,0.827442,0,0.561551,0.827442,0,0.561551,0.827442,0,0.356636,0.934243,0,0.356636,0.934243,0,0.356636,0.934243,0,0.356636,0.934243,0,0.122132,0.992514,0,0.122132,0.992514,0,0.122132,0.992514,0,0.122132,0.992514,0,0.000001,1,0.000002,0.000001,1,0.000002,0.000001,1,0.000002,0,1,0,0,1,0,0,1,0,-0.122155,0.992511,0.000002,-0.122155,0.992511,0.000002,-0.122155,0.992511,0.000002,-0.122155,0.992511,0.000002,-0.356621,0.934249,0,-0.356621,0.934249,0,-0.356621,0.934249,0,-0.356621,0.934249,0,-0.561531,0.827456,0,-0.561531,0.827456,0,-0.561531,0.827456,0,-0.561531,0.827456,0,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.858894,0.512153,0,-0.858894,0.512153,0,-0.858894,0.512153,0,-0.858894,0.512153,0,-0.948099,0.317975,0,-0.948099,0.317975,0,-0.948099,0.317975,0,-0.948099,0.317975,0,-0.994201,0.107535,0,-0.994201,0.107535,0,-0.994201,0.107535,0,-0.994201,0.107535,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994203,-0.107523,0,-0.994203,-0.107523,0,-0.994203,-0.107523,0,-0.994203,-0.107523,0,-0.948091,-0.317998,0,-0.948091,-0.317998,0,-0.948091,-0.317998,0,-0.948091,-0.317998,0,-0.858901,-0.512141,0,-0.858901,-0.512141,0,-0.858901,-0.512141,0,-0.858901,-0.512141,0,-0.729581,-0.683894,0,-0.729581,-0.683894,0,-0.729581,-0.683894,0,-0.729581,-0.683894,0,-0.561534,-0.827454,0,-0.561534,-0.827454,0,-0.561534,-0.827454,0,-0.561534,-0.827454,0,-0.356626,-0.934247,0,-0.356626,-0.934247,0,-0.356626,-0.934247,0,-0.356626,-0.934247,0,-0.122177,-0.992508,0,-0.122177,-0.992508,0,-0.122177,-0.992508,0,-0.122177,-0.992508,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122167,-0.99251,-0.000001,0.122167,-0.99251,-0.000001,0.122167,-0.99251,-0.000001,0.122156,-0.992511,0,0.122156,-0.992511,0,0.122156,-0.992511,0,0.356607,-0.934254,0,0.356607,-0.934254,0,0.356607,-0.934254,0,0.356617,-0.93425,-0.000001,0.356617,-0.93425,-0.000001,0.356617,-0.93425,-0.000001,0.561554,-0.82744,0,0.561554,-0.82744,0,0.561554,-0.82744,0,0.561554,-0.82744,0,0.729573,-0.683903,0,0.729573,-0.683903,0,0.729573,-0.683903,0,0.729573,-0.683903,0,0.858904,-0.512137,0,0.858904,-0.512137,0,0.858904,-0.512137,0,0.858904,-0.512137,0,0.948094,-0.317991,0,0.948094,-0.317991,0,0.948094,-0.317991,0,0.948094,-0.317991,0,0.994203,-0.107523,0,0.994203,-0.107523,0,0.994203,-0.107523,0,0.994203,-0.107524,0,0.994203,-0.107524,0,0.994203,-0.107524,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994203,0.107519,0,0.994203,0.107519,0,0.994203,0.107519,0,0.994203,0.107519,0,0.94809,0.318001,0,0.94809,0.318001,0,0.94809,0.318001,0,0.94809,0.318001,0,0.8589,0.512143,0,0.8589,0.512143,0,0.8589,0.512143,0,0.8589,0.512143,0,0.729581,0.683894,0,0.729581,0.683894,0,0.729581,0.683894,0,0.729581,0.683894,0,0.561562,0.827435,0,0.561562,0.827435,0,0.561562,0.827435,0,0.561562,0.827435,0,0.356619,0.93425,0,0.356619,0.93425,0,0.356619,0.93425,0,0.356619,0.93425,0,0.122155,0.992511,0,0.122155,0.992511,0,0.122155,0.992511,0,0.122155,0.992511,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122176,0.992508,0,-0.122176,0.992508,0,-0.122176,0.992508,0,-0.122176,0.992508,0,-0.35664,0.934242,0,-0.35664,0.934242,0,-0.35664,0.934242,0,-0.35664,0.934242,0,-0.561531,0.827456,0,-0.561531,0.827456,0,-0.561531,0.827456,0,-0.561531,0.827456,0,-0.729575,0.683901,0,-0.729575,0.683901,0,-0.729575,0.683901,0,-0.729575,0.683901,0,-0.858891,0.512159,0,-0.858891,0.512159,0,-0.858891,0.512159,0,-0.858891,0.512159,0,-0.948098,0.31798,0,-0.948098,0.31798,0,-0.948098,0.31798,0,-0.948098,0.31798,0,-0.994203,0.107519,0,-0.994203,0.107519,0,-0.994203,0.107519,0,-0.994203,0.107519,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994204,-0.107512,0,-0.994204,-0.107512,0,-0.994204,-0.107512,0,-0.994204,-0.107512,0,-0.948093,-0.317993,0,-0.948093,-0.317993,0,-0.948093,-0.317993,0,-0.948093,-0.317993,0,-0.858894,-0.512154,0,-0.858894,-0.512154,0,-0.858894,-0.512154,0,-0.858894,-0.512154,0,-0.729593,-0.683882,0,-0.729593,-0.683882,0,-0.729593,-0.683882,0,-0.729593,-0.683882,0,-0.561531,-0.827456,0,-0.561531,-0.827456,0,-0.561531,-0.827456,0,-0.561531,-0.827456,0,-0.356612,-0.934253,0,-0.356612,-0.934253,0,-0.356612,-0.934253,0,-0.356612,-0.934253,0,-0.122188,-0.992507,0,-0.122188,-0.992507,0,-0.122188,-0.992507,0,-0.122188,-0.992507,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122169,-0.992509,-0.000001,0.122169,-0.992509,-0.000001,0.122169,-0.992509,-0.000001,0.122157,-0.992511,0,0.122157,-0.992511,0,0.122157,-0.992511,0,0.356605,-0.934255,0,0.356605,-0.934255,0,0.356605,-0.934255,0,0.356616,-0.934251,-0.000001,0.356616,-0.934251,-0.000001,0.356616,-0.934251,-0.000001,0.561555,-0.827439,0,0.561555,-0.827439,0,0.561555,-0.827439,0,0.561555,-0.827439,0,0.72957,-0.683906,0,0.72957,-0.683906,0,0.72957,-0.683906,0,0.72957,-0.683906,0,0.858908,-0.51213,0,0.858908,-0.51213,0,0.858908,-0.51213,0,0.858908,-0.51213,0,0.948095,-0.317986,0,0.948095,-0.317986,0,0.948095,-0.317986,0,0.948095,-0.317986,0,0.994201,-0.107533,0,0.994201,-0.107533,0,0.994201,-0.107533,0,0.994201,-0.107533,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.948091,0.318,0,0.948091,0.318,0,0.948091,0.318,0,0.948091,0.318,0,0.858902,0.51214,0,0.858902,0.51214,0,0.858902,0.51214,0,0.858902,0.51214,0,0.729575,0.683901,0,0.729575,0.683901,0,0.729575,0.683901,0,0.729575,0.683901,0,0.561547,0.827445,0,0.561547,0.827445,0,0.561547,0.827445,0,0.561547,0.827445,0,0.356648,0.934239,0,0.356648,0.934239,0,0.356648,0.934239,0,0.356648,0.934239,0,0.122132,0.992514,0,0.122132,0.992514,0,0.122132,0.992514,0,0.122132,0.992514,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122156,0.992511,0,-0.122156,0.992511,0,-0.122156,0.992511,0,-0.122156,0.992511,0,-0.356627,0.934247,0,-0.356627,0.934247,0,-0.356627,0.934247,0,-0.356627,0.934247,0,-0.561537,0.827452,0,-0.561537,0.827452,0,-0.561537,0.827452,0,-0.561537,0.827452,0,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.85887,0.512193,0,-0.85887,0.512193,0,-0.85887,0.512193,0,-0.85887,0.512193,0,-0.9481,0.317973,0,-0.9481,0.317973,0,-0.9481,0.317973,0,-0.9481,0.317973,0,-0.994205,0.107498,0,-0.994205,0.107498,0,-0.994205,0.107498,0,-0.994205,0.107498,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994203,-0.107523,0,-0.994203,-0.107523,0,-0.994203,-0.107523,0,-0.994203,-0.107523,0,-0.948093,-0.317993,0,-0.948093,-0.317993,0,-0.948093,-0.317993,0,-0.948093,-0.317993,0,-0.858894,-0.512154,0,-0.858894,-0.512154,0,-0.858894,-0.512154,0,-0.858894,-0.512154,0,-0.729581,-0.683894,0,-0.729581,-0.683894,0,-0.729581,-0.683894,0,-0.729581,-0.683894,0,-0.561529,-0.827457,-0.000001,-0.561529,-0.827457,-0.000001,-0.561529,-0.827457,-0.000001,-0.561537,-0.827452,0,-0.561537,-0.827452,0,-0.561537,-0.827452,0,-0.35663,-0.934246,0,-0.35663,-0.934246,0,-0.35663,-0.934246,0,-0.356619,-0.93425,-0.000001,-0.356619,-0.93425,-0.000001,-0.356619,-0.93425,-0.000001,-0.122187,-0.992507,0,-0.122187,-0.992507,0,-0.122187,-0.992507,0,-0.122187,-0.992507,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122166,-0.99251,0,0.122166,-0.99251,0,0.122166,-0.99251,0,0.122166,-0.99251,0,0.356605,-0.934255,0,0.356605,-0.934255,0,0.356605,-0.934255,0,0.356605,-0.934255,0,0.561555,-0.827439,0,0.561555,-0.827439,0,0.561555,-0.827439,0,0.561555,-0.827439,0,0.729575,-0.6839,0,0.729575,-0.6839,0,0.729575,-0.6839,0,0.729575,-0.6839,0,0.858913,-0.512122,0,0.858913,-0.512122,0,0.858913,-0.512122,0,0.858913,-0.512122,0,0.948087,-0.31801,0,0.948087,-0.31801,0,0.948087,-0.31801,0,0.948087,-0.31801,0,0.994203,-0.107523,0,0.994203,-0.107523,0,0.994203,-0.107523,0,0.994203,-0.107523,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.948092,0.317996,0,0.948092,0.317996,0,0.948092,0.317996,0,0.948092,0.317996,0,0.858907,0.512132,0,0.858907,0.512132,0,0.858907,0.512132,0,0.858907,0.512132,0,0.729569,0.683907,0,0.729569,0.683907,0,0.729569,0.683907,0,0.729569,0.683907,0,0.561558,0.827437,0,0.561558,0.827437,0,0.561558,0.827437,0,0.561558,0.827437,0,0.356623,0.934248,0,0.356623,0.934248,0,0.356623,0.934248,0,0.356623,0.934248,0,0.122155,0.992511,0,0.122155,0.992511,0,0.122155,0.992511,0,0.122155,0.992511,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122173,0.992509,0,-0.122173,0.992509,0,-0.122173,0.992509,0,-0.122173,0.992509,0,-0.356648,0.934239,0,-0.356648,0.934239,0,-0.356648,0.934239,0,-0.356648,0.934239,0,-0.561526,0.827459,0,-0.561526,0.827459,0,-0.561526,0.827459,0,-0.561526,0.827459,0,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.858901,0.512142,0,-0.858901,0.512142,0,-0.858901,0.512142,0,-0.858901,0.512142,0,-0.948077,0.31804,0,-0.948077,0.31804,0,-0.948077,0.31804,0,-0.948077,0.31804,0,-0.994208,0.107477,0,-0.994208,0.107477,0,-0.994208,0.107477,0,-0.994208,0.107477,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-0.9942,-0.107545,0,-0.9942,-0.107545,0,-0.9942,-0.107545,0,-0.9942,-0.107544,0,-0.9942,-0.107544,0,-0.9942,-0.107544,0,-0.948093,-0.317993,0,-0.948093,-0.317993,0,-0.948093,-0.317993,0,-0.948093,-0.317993,0,-0.858894,-0.512154,0,-0.858894,-0.512154,0,-0.858894,-0.512154,0,-0.858891,-0.512159,-0.000001,-0.858891,-0.512159,-0.000001,-0.858891,-0.512159,-0.000001,-0.729593,-0.683882,0,-0.729593,-0.683882,0,-0.729593,-0.683882,0,-0.729593,-0.683882,0,-0.561548,-0.827444,0,-0.561548,-0.827444,0,-0.561548,-0.827444,0,-0.561548,-0.827444,0,-0.356614,-0.934252,0,-0.356614,-0.934252,0,-0.356614,-0.934252,0,-0.356614,-0.934252,0,-0.122176,-0.992508,0,-0.122176,-0.992508,0,-0.122176,-0.992508,0,-0.122176,-0.992508,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.12217,-0.992509,0,0.12217,-0.992509,0,0.12217,-0.992509,0,0.12217,-0.992509,0,0.356601,-0.934257,0,0.356601,-0.934257,0,0.356601,-0.934257,0,0.356601,-0.934257,0,0.56155,-0.827443,0,0.56155,-0.827443,0,0.56155,-0.827443,0,0.56155,-0.827443,0,0.729575,-0.6839,0,0.729575,-0.6839,0,0.729575,-0.6839,0,0.729575,-0.6839,0,0.858923,-0.512105,0,0.858923,-0.512105,0,0.858923,-0.512105,0,0.858923,-0.512105,0,0.948091,-0.318,0,0.948091,-0.318,0,0.948091,-0.318,0,0.948091,-0.318,0,0.994198,-0.107565,0,0.994198,-0.107565,0,0.994198,-0.107565,0,0.994198,-0.107565,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,0.9942,0.107543,0,0.9942,0.107543,0,0.9942,0.107543,0,0.9942,0.107543,0,0.948104,0.317959,0,0.948104,0.317959,0,0.948104,0.317959,0,0.948104,0.317959,0,0.858887,0.512166,0,0.858887,0.512166,0,0.858887,0.512166,0,0.858887,0.512166,0,0.729593,0.683882,0,0.729593,0.683882,0,0.729593,0.683882,0,0.729593,0.683882,0,0.561558,0.827437,0,0.561558,0.827437,0,0.561558,0.827437,0,0.561558,0.827437,0,0.356619,0.93425,0,0.356619,0.93425,0,0.356619,0.93425,0,0.356619,0.93425,0,0.122153,0.992511,0,0.122153,0.992511,0,0.122153,0.992511,0,0.122153,0.992511,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122153,0.992511,0,-0.122153,0.992511,0,-0.122153,0.992511,0,-0.122153,0.992511,0,-0.356612,0.934253,0,-0.356612,0.934253,0,-0.356612,0.934253,0,-0.356612,0.934253,0,-0.561537,0.827452,0,-0.561537,0.827452,0,-0.561537,0.827452,0,-0.561537,0.827452,0,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.858891,0.512159,0,-0.858891,0.512159,0,-0.858891,0.512159,0,-0.858891,0.512159,0,-0.948093,0.317993,0,-0.948093,0.317993,0,-0.948093,0.317993,0,-0.948093,0.317993,0,-0.994205,0.107498,0,-0.994205,0.107498,0,-0.994205,0.107498,0,-0.994205,0.107498,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994203,-0.107524,0,-0.994203,-0.107524,0,-0.994203,-0.107524,0,-0.994203,-0.107524,0,-0.948086,-0.318013,0,-0.948086,-0.318013,0,-0.948086,-0.318013,0,-0.948086,-0.318013,0,-0.858914,-0.51212,0,-0.858914,-0.51212,0,-0.858914,-0.51212,0,-0.858914,-0.51212,0,-0.729569,-0.683907,0,-0.729569,-0.683907,0,-0.729569,-0.683907,0,-0.729569,-0.683907,0,-0.561559,-0.827437,0,-0.561559,-0.827437,0,-0.561559,-0.827437,0,-0.561559,-0.827437,0,-0.356622,-0.934249,0,-0.356622,-0.934249,0,-0.356622,-0.934249,0,-0.356622,-0.934249,0,-0.122173,-0.992509,0,-0.122173,-0.992509,0,-0.122173,-0.992509,0,-0.122173,-0.992509,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122167,-0.992509,0,0.122167,-0.992509,0,0.122167,-0.992509,0,0.122167,-0.992509,0,0.356593,-0.93426,0,0.356593,-0.93426,0,0.356593,-0.93426,0,0.356593,-0.93426,0,0.561591,-0.827415,-0.000001,0.561591,-0.827415,-0.000001,0.561591,-0.827415,-0.000001,0.561583,-0.827421,0,0.561583,-0.827421,0,0.561583,-0.827421,0,0.729558,-0.683919,0,0.729558,-0.683919,0,0.729558,-0.683919,0,0.729564,-0.683913,-0.000001,0.729564,-0.683913,-0.000001,0.729564,-0.683913,-0.000001,0.858923,-0.512105,0,0.858923,-0.512105,0,0.858923,-0.512105,0,0.858923,-0.512105,0,0.948091,-0.318,0,0.948091,-0.318,0,0.948091,-0.318,0,0.948091,-0.318,0,0.994198,-0.107565,0,0.994198,-0.107565,0,0.994198,-0.107565,0,0.994198,-0.107565,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,0.9942,0.107543,0,0.9942,0.107543,0,0.9942,0.107543,0,0.9942,0.107543,0,0.948109,0.317946,0,0.948109,0.317946,0,0.948109,0.317946,0,0.948109,0.317946,0,0.858893,0.512156,0.000001,0.858893,0.512156,0.000001,0.858893,0.512156,0.000001,0.858887,0.512166,0,0.858887,0.512166,0,0.858887,0.512166,0,0.729558,0.683919,0,0.729558,0.683919,0,0.729558,0.683919,0,0.729569,0.683907,0.000002,0.729569,0.683907,0.000002,0.729569,0.683907,0.000002,0.561569,0.82743,0,0.561569,0.82743,0,0.561569,0.82743,0,0.561569,0.82743,0,0.356612,0.934253,0,0.356612,0.934253,0,0.356612,0.934253,0,0.356612,0.934253,0,0.122159,0.992511,0,0.122159,0.992511,0,0.122159,0.992511,0,0.122159,0.99251,0,0.122159,0.99251,0,0.122159,0.99251,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122176,0.992509,0,-0.122176,0.992509,0,-0.122176,0.992509,0,-0.122176,0.992509,0,-0.356659,0.934235,0,-0.356659,0.934235,0,-0.356659,0.934235,0,-0.356659,0.934235,0,-0.561515,0.827467,0,-0.561515,0.827467,0,-0.561515,0.827467,0,-0.561515,0.827467,0,-0.729569,0.683907,0,-0.729569,0.683907,0,-0.729569,0.683907,0,-0.729569,0.683907,0,-0.858907,0.512132,0,-0.858907,0.512132,0,-0.858907,0.512132,0,-0.858907,0.512132,0,-0.948071,0.31806,0,-0.948071,0.31806,0,-0.948071,0.31806,0,-0.948071,0.31806,0,-0.99421,0.107455,0,-0.99421,0.107455,0,-0.99421,0.107455,0,-0.99421,0.107455,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.99421,-0.107459,0,-0.99421,-0.107459,0,-0.99421,-0.107459,0,-0.99421,-0.107459,0,-0.948073,-0.318053,0,-0.948073,-0.318053,0,-0.948073,-0.318053,0,-0.948073,-0.318053,0,-0.858894,-0.512154,0,-0.858894,-0.512154,0,-0.858894,-0.512154,0,-0.858894,-0.512154,0,-0.729616,-0.683857,0,-0.729616,-0.683857,0,-0.729616,-0.683857,0,-0.729616,-0.683857,0,-0.561515,-0.827467,0,-0.561515,-0.827467,0,-0.561515,-0.827467,0,-0.561515,-0.827467,0,-0.356645,-0.93424,0,-0.356645,-0.93424,0,-0.356645,-0.93424,0,-0.356645,-0.93424,0,-0.122173,-0.992509,0,-0.122173,-0.992509,0,-0.122173,-0.992509,0,-0.122173,-0.992509,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122167,-0.992509,0,0.122167,-0.992509,0,0.122167,-0.992509,0,0.122167,-0.992509,0,0.356593,-0.93426,0,0.356593,-0.93426,0,0.356593,-0.93426,0,0.356593,-0.93426,0,0.56158,-0.827422,0,0.56158,-0.827422,0,0.56158,-0.827422,0,0.56158,-0.827422,0,0.729582,-0.683894,0,0.729582,-0.683894,0,0.729582,-0.683894,0,0.729582,-0.683894,0,0.858913,-0.512122,0,0.858913,-0.512122,0,0.858913,-0.512122,0,0.858913,-0.512122,0,0.948077,-0.31804,0,0.948077,-0.31804,0,0.948077,-0.31804,0,0.948077,-0.31804,0,0.994205,-0.107501,0,0.994205,-0.107501,0,0.994205,-0.107501,0,0.994205,-0.107501,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994196,0.107583,0,0.994196,0.107583,0,0.994196,0.107583,0,0.994196,0.107585,0,0.994196,0.107585,0,0.994196,0.107585,0,0.948109,0.317946,0,0.948109,0.317946,0,0.948109,0.317946,0,0.948111,0.317939,0.000001,0.948111,0.317939,0.000001,0.948111,0.317939,0.000001,0.858897,0.512149,0,0.858897,0.512149,0,0.858897,0.512149,0,0.858897,0.512149,0,0.729581,0.683894,0,0.729581,0.683894,0,0.729581,0.683894,0,0.729581,0.683894,0,0.561547,0.827445,0,0.561547,0.827445,0,0.561547,0.827445,0,0.561547,0.827445,0,0.356619,0.93425,0,0.356619,0.93425,0,0.356619,0.93425,0,0.356619,0.93425,0,0.122161,0.99251,0,0.122161,0.99251,0,0.122161,0.99251,0,0.122161,0.99251,0,-0.000001,1,0,-0.000001,1,0,-0.000001,1,0,-0.000001,1,0,-0.12215,0.992512,0,-0.12215,0.992512,0,-0.12215,0.992512,0,-0.12215,0.992512,0,-0.356676,0.934228,0,-0.356676,0.934228,0,-0.356676,0.934228,0,-0.356676,0.934228,0,-0.561488,0.827485,0,-0.561488,0.827485,0,-0.561488,0.827485,0,-0.561488,0.827485,0,-0.729593,0.683882,0,-0.729593,0.683882,0,-0.729593,0.683882,0,-0.729593,0.683882,0,-0.858866,0.5122,0,-0.858866,0.5122,0,-0.858866,0.5122,0,-0.858866,0.5122,0,-0.948113,0.317933,0,-0.948113,0.317933,0,-0.948113,0.317933,0,-0.948113,0.317933,0,-0.9942,0.107543,0,-0.9942,0.107543,0,-0.9942,0.107543,0,-0.9942,0.107543,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-0.994205,-0.107504,0,-0.994205,-0.107504,0,-0.994205,-0.107504,0,-0.994205,-0.107504,0,-0.948087,-0.31801,0,-0.948087,-0.31801,0,-0.948087,-0.31801,0,-0.948088,-0.31801,0,-0.948088,-0.31801,0,-0.948088,-0.31801,0,-0.858904,-0.512137,0,-0.858904,-0.512137,0,-0.858904,-0.512137,0,-0.858904,-0.512137,0,-0.729604,-0.68387,0,-0.729604,-0.68387,0,-0.729604,-0.68387,0,-0.729604,-0.68387,0,-0.561548,-0.827444,0,-0.561548,-0.827444,0,-0.561548,-0.827444,0,-0.561548,-0.827444,0,-0.356593,-0.93426,0,-0.356593,-0.93426,0,-0.356593,-0.93426,0,-0.356593,-0.93426,0,-0.122176,-0.992508,0,-0.122176,-0.992508,0,-0.122176,-0.992508,0,-0.122176,-0.992508,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0,-1,0,0,-1,0,0.122176,-0.992508,-0.000001,0.122176,-0.992508,-0.000001,0.122176,-0.992508,-0.000001,0.122176,-0.992508,-0.000001,0.356583,-0.934264,-0.000001,0.356583,-0.934264,-0.000001,0.356583,-0.934264,-0.000001,0.356583,-0.934264,-0.000001,0.561556,-0.827439,0,0.561556,-0.827439,0,0.561556,-0.827439,0,0.561564,-0.827434,-0.000001,0.561564,-0.827434,-0.000001,0.561564,-0.827434,-0.000001,0.729586,-0.683889,0,0.729586,-0.683889,0,0.729586,-0.683889,0,0.729586,-0.683889,0,0.858947,-0.512064,0,0.858947,-0.512064,0,0.858947,-0.512064,0,0.858947,-0.512064,0,0.948072,-0.318057,0,0.948072,-0.318057,0,0.948072,-0.318057,0,0.948072,-0.318057,0,0.994205,-0.107504,0,0.994205,-0.107504,0,0.994205,-0.107504,0,0.994205,-0.107504,0,1,-0.000001,0,1,-0.000001,0,1,-0.000001,0,1,-0.000001,0,0.9942,0.107543,0,0.9942,0.107543,0,0.9942,0.107543,0,0.9942,0.107543,0,0.948095,0.317986,0,0.948095,0.317986,0,0.948095,0.317986,0,0.948095,0.317986,0,0.858913,0.512122,0,0.858913,0.512122,0,0.858913,0.512122,0,0.858913,0.512122,0,0.729569,0.683907,0,0.729569,0.683907,0,0.729569,0.683907,0,0.729569,0.683907,0,0.561536,0.827452,0,0.561536,0.827452,0,0.561536,0.827452,0,0.561536,0.827452,0,0.356615,0.934252,0,0.356615,0.934252,0,0.356615,0.934252,0,0.356615,0.934252,0,0.122153,0.992511,0,0.122153,0.992511,0,0.122153,0.992511,0,0.122153,0.992511,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.12213,0.992514,0,-0.12213,0.992514,0,-0.12213,0.992514,0,-0.12213,0.992514,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122159,0.992511,0,-0.122159,0.992511,0,-0.122159,0.992511,0,-0.122159,0.992511,0,-0.356604,0.934256,0,-0.356604,0.934256,0,-0.356604,0.934256,0,-0.356604,0.934256,0,-0.561534,0.827454,0,-0.561534,0.827454,0,-0.561534,0.827454,0,-0.561534,0.827454,0,-0.72965,0.683821,0,-0.72965,0.683821,0,-0.72965,0.683821,0,-0.72965,0.683821,0,-0.858884,0.512171,0,-0.858884,0.512171,0,-0.858884,0.512171,0,-0.858884,0.512171,0,-0.948084,0.31802,0,-0.948084,0.31802,0,-0.948084,0.31802,0,-0.948084,0.31802,0,-0.9942,0.107543,0,-0.9942,0.107543,0,-0.9942,0.107543,0,-0.994201,0.107542,0,-0.994201,0.107542,0,-0.994201,0.107542,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.9942,-0.107545,0,-0.9942,-0.107545,0,-0.9942,-0.107545,0,-0.9942,-0.107546,0,-0.9942,-0.107546,0,-0.9942,-0.107546,0,-0.948084,-0.31802,0,-0.948084,-0.31802,0,-0.948084,-0.31802,0,-0.948084,-0.31802,0,-0.858893,-0.512156,0,-0.858893,-0.512156,0,-0.858893,-0.512156,0,-0.858893,-0.512156,0,-0.729604,-0.68387,0,-0.729604,-0.68387,0,-0.729604,-0.68387,0,-0.729604,-0.68387,0,-0.561556,-0.827439,0,-0.561556,-0.827439,0,-0.561556,-0.827439,0,-0.561556,-0.827439,0,-0.356609,-0.934254,-0.000001,-0.356609,-0.934254,-0.000001,-0.356609,-0.934254,-0.000001,-0.356619,-0.93425,0,-0.356619,-0.93425,0,-0.356619,-0.93425,0,-0.12217,-0.992509,0,-0.12217,-0.992509,0,-0.12217,-0.992509,0,-0.122159,-0.992511,-0.000001,-0.122159,-0.992511,-0.000001,-0.122159,-0.992511,-0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122176,-0.992509,0,0.122176,-0.992509,0,0.122176,-0.992509,0,0.122176,-0.992509,0,0.356588,-0.934262,0,0.356588,-0.934262,0,0.356588,-0.934262,0,0.356588,-0.934262,0,0.561526,-0.827459,0,0.561526,-0.827459,0,0.561526,-0.827459,0,0.561526,-0.827459,0,0.729569,-0.683907,0,0.729569,-0.683907,0,0.729569,-0.683907,0,0.729569,-0.683907,0,0.85893,-0.512093,0,0.85893,-0.512093,0,0.85893,-0.512093,0,0.85893,-0.512093,0,0.9481,-0.317973,0,0.9481,-0.317973,0,0.9481,-0.317973,0,0.9481,-0.317973,0,0.9942,-0.107544,0,0.9942,-0.107544,0,0.9942,-0.107544,0,0.9942,-0.107544,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994201,0.107542,0,0.994201,0.107542,0,0.994201,0.107542,0,0.9942,0.107543,0,0.9942,0.107543,0,0.9942,0.107543,0,0.948073,0.318053,0,0.948073,0.318053,0,0.948073,0.318053,0,0.948073,0.318053,0,0.858958,0.512046,0,0.858958,0.512046,0,0.858958,0.512046,0,0.858961,0.51204,0.000001,0.858961,0.51204,0.000001,0.858961,0.51204,0.000001,0.729575,0.683901,0,0.729575,0.683901,0,0.729575,0.683901,0,0.729575,0.683901,0,0.56154,0.82745,0,0.56154,0.82745,0,0.56154,0.82745,0,0.56154,0.82745,0,0.356613,0.934252,0,0.356613,0.934252,0,0.356613,0.934252,0,0.356613,0.934252,0,0.122153,0.992511,0,0.122153,0.992511,0,0.122153,0.992511,0,0.122153,0.992511,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122153,0.992511,0,-0.122153,0.992511,0,-0.122153,0.992511,0,-0.122153,0.992511,0,-0.356625,0.934248,0,-0.356625,0.934248,0,-0.356625,0.934248,0,-0.356625,0.934248,0,-0.561578,0.827424,0.000001,-0.561578,0.827424,0.000001,-0.561578,0.827424,0.000001,-0.561586,0.827419,0,-0.561586,0.827419,0,-0.561586,0.827419,0,-0.72958,0.683895,0,-0.72958,0.683895,0,-0.72958,0.683895,0,-0.729575,0.683901,0.000001,-0.729575,0.683901,0.000001,-0.729575,0.683901,0.000001,-0.858924,0.512103,0,-0.858924,0.512103,0,-0.858924,0.512103,0,-0.858924,0.512103,0,-0.948071,0.31806,0,-0.948071,0.31806,0,-0.948071,0.31806,0,-0.948071,0.31806,0,-0.994205,0.107499,0,-0.994205,0.107499,0,-0.994205,0.107499,0,-0.994205,0.107499,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994205,-0.107504,0,-0.994205,-0.107504,0,-0.994205,-0.107504,0,-0.994205,-0.107504,0,-0.948099,-0.317976,0,-0.948099,-0.317976,0,-0.948099,-0.317976,0,-0.948099,-0.317976,0,-0.858872,-0.51219,0,-0.858872,-0.51219,0,-0.858872,-0.51219,0,-0.858872,-0.51219,0,-0.729598,-0.683876,0,-0.729598,-0.683876,0,-0.729598,-0.683876,0,-0.729598,-0.683876,0,-0.561542,-0.827448,0,-0.561542,-0.827448,0,-0.561542,-0.827448,0,-0.561542,-0.827448,0,-0.356625,-0.934248,-0.000001,-0.356625,-0.934248,-0.000001,-0.356625,-0.934248,-0.000001,-0.356635,-0.934244,0,-0.356635,-0.934244,0,-0.356635,-0.934244,0,-0.122164,-0.99251,0,-0.122164,-0.99251,0,-0.122164,-0.99251,0,-0.122153,-0.992511,-0.000001,-0.122153,-0.992511,-0.000001,-0.122153,-0.992511,-0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122164,-0.99251,0,0.122164,-0.99251,0,0.122164,-0.99251,0,0.122164,-0.99251,0,0.356645,-0.93424,0,0.356645,-0.93424,0,0.356645,-0.93424,0,0.356645,-0.93424,0,0.561504,-0.827474,0,0.561504,-0.827474,0,0.561504,-0.827474,0,0.561504,-0.827474,0,0.729534,-0.683944,0,0.729534,-0.683944,0,0.729534,-0.683944,0,0.729534,-0.683944,0,0.858937,-0.512081,0,0.858937,-0.512081,0,0.858937,-0.512081,0,0.858937,-0.512081,0,0.9481,-0.317973,0,0.9481,-0.317973,0,0.9481,-0.317973,0,0.9481,-0.317973,0,0.9942,-0.107544,0,0.9942,-0.107544,0,0.9942,-0.107544,0,0.9942,-0.107544,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.9481,0.317973,0,0.9481,0.317973,0,0.9481,0.317973,0,0.9481,0.317973,0,0.858931,0.512091,0,0.858931,0.512091,0,0.858931,0.512091,0,0.858931,0.512091,0,0.729528,0.683951,0,0.729528,0.683951,0,0.729528,0.683951,0,0.729528,0.683951,0,0.56155,0.827442,0,0.56155,0.827442,0,0.56155,0.827442,0,0.56155,0.827442,0,0.356645,0.93424,0,0.356645,0.93424,0,0.356645,0.93424,0,0.356645,0.93424,0,0.122142,0.992513,0,0.122142,0.992513,0,0.122142,0.992513,0,0.122142,0.992513,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122167,0.992509,0,-0.122167,0.992509,0,-0.122167,0.992509,0,-0.122167,0.992509,0,-0.356586,0.934263,0,-0.356586,0.934263,0,-0.356586,0.934263,0,-0.356586,0.934263,0,-0.561575,0.827426,0,-0.561575,0.827426,0,-0.561575,0.827426,0,-0.561575,0.827426,0,-0.729575,0.683901,0,-0.729575,0.683901,0,-0.729575,0.683901,0,-0.729575,0.683901,0,-0.858924,0.512103,0,-0.858924,0.512103,0,-0.858924,0.512103,0,-0.858924,0.512103,0,-0.948077,0.31804,0,-0.948077,0.31804,0,-0.948077,0.31804,0,-0.948077,0.31804,0,-0.994201,0.107542,0,-0.994201,0.107542,0,-0.994201,0.107542,0,-0.994201,0.107542,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-0.994202,-0.107525,0,-0.994202,-0.107525,0,-0.994202,-0.107525,0,-0.994202,-0.107525,0,-0.948098,-0.31798,0,-0.948098,-0.31798,0,-0.948098,-0.31798,0,-0.948099,-0.317976,0,-0.948099,-0.317976,0,-0.948099,-0.317976,0,-0.858903,-0.512139,-0.000001,-0.858903,-0.512139,-0.000001,-0.858903,-0.512139,-0.000001,-0.858903,-0.512139,-0.000001,-0.72958,-0.683895,0,-0.72958,-0.683895,0,-0.72958,-0.683895,0,-0.729575,-0.683901,-0.000001,-0.729575,-0.683901,-0.000001,-0.729575,-0.683901,-0.000001,-0.561531,-0.827456,0,-0.561531,-0.827456,0,-0.561531,-0.827456,0,-0.561531,-0.827456,0,-0.356617,-0.934251,0,-0.356617,-0.934251,0,-0.356617,-0.934251,0,-0.356617,-0.934251,0,-0.122164,-0.99251,0,-0.122164,-0.99251,0,-0.122164,-0.99251,0,-0.122164,-0.99251,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0,-1,0,0,-1,0,0.122153,-0.992511,0,0.122153,-0.992511,0,0.122153,-0.992511,0,0.122164,-0.99251,-0.000001,0.122164,-0.99251,-0.000001,0.122164,-0.99251,-0.000001,0.356653,-0.934237,0,0.356653,-0.934237,0,0.356653,-0.934237,0,0.356653,-0.934237,0,0.561515,-0.827467,0,0.561515,-0.827467,0,0.561515,-0.827467,0,0.561515,-0.827467,0,0.729581,-0.683894,0,0.729581,-0.683894,0,0.729581,-0.683894,0,0.729581,-0.683894,0,0.8589,-0.512144,-0.000001,0.8589,-0.512144,-0.000001,0.8589,-0.512144,-0.000001,0.858897,-0.512149,0,0.858897,-0.512149,0,0.858897,-0.512149,0,0.948093,-0.317993,0,0.948093,-0.317993,0,0.948093,-0.317993,0,0.948094,-0.31799,0,0.948094,-0.31799,0,0.948094,-0.31799,0,0.994205,-0.107503,0,0.994205,-0.107503,0,0.994205,-0.107503,0,0.994205,-0.107503,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.9481,0.317973,0,0.9481,0.317973,0,0.9481,0.317973,0,0.9481,0.317973,0,0.858888,0.512164,0,0.858888,0.512164,0,0.858888,0.512164,0,0.858888,0.512164,0,0.729604,0.68387,0,0.729604,0.68387,0,0.729604,0.68387,0,0.729604,0.68387,0,0.56152,0.827463,0,0.56152,0.827463,0,0.56152,0.827463,0,0.56152,0.827463,0,0.356645,0.93424,0,0.356645,0.93424,0,0.356645,0.93424,0,0.356645,0.93424,0,0.122156,0.992511,0,0.122156,0.992511,0,0.122156,0.992511,0,0.122156,0.992511,0,0,1,0,0,1,0,0,1,0,0,1,0.000001,0,1,0.000001,0,1,0.000001,-0.122167,0.992509,0,-0.122167,0.992509,0,-0.122167,0.992509,0,-0.122167,0.992509,0,-0.356601,0.934257,0,-0.356601,0.934257,0,-0.356601,0.934257,0,-0.356601,0.934257,0,-0.561564,0.827434,0,-0.561564,0.827434,0,-0.561564,0.827434,0,-0.561564,0.827434,0,-0.729586,0.683889,0,-0.729586,0.683889,0,-0.729586,0.683889,0,-0.729586,0.683889,0,-0.858894,0.512154,0,-0.858894,0.512154,0,-0.858894,0.512154,0,-0.858894,0.512154,0,-0.948085,0.318016,0,-0.948085,0.318016,0,-0.948085,0.318016,0,-0.948085,0.318016,0,-0.994207,0.107479,0,-0.994207,0.107479,0,-0.994207,0.107479,0,-0.994207,0.107479,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994207,-0.107481,0,-0.994207,-0.107481,0,-0.994207,-0.107481,0,-0.994207,-0.107482,0,-0.994207,-0.107482,0,-0.994207,-0.107482,0,-0.948084,-0.31802,0,-0.948084,-0.31802,0,-0.948084,-0.31802,0,-0.948085,-0.318016,0,-0.948085,-0.318016,0,-0.948085,-0.318016,0,-0.858933,-0.512088,-0.000001,-0.858933,-0.512088,-0.000001,-0.858933,-0.512088,-0.000001,-0.858933,-0.512088,-0.000001,-0.729557,-0.68392,0,-0.729557,-0.68392,0,-0.729557,-0.68392,0,-0.729551,-0.683926,-0.000001,-0.729551,-0.683926,-0.000001,-0.729551,-0.683926,-0.000001,-0.561556,-0.827439,-0.000001,-0.561556,-0.827439,-0.000001,-0.561556,-0.827439,-0.000001,-0.561564,-0.827433,0,-0.561564,-0.827433,0,-0.561564,-0.827433,0,-0.356601,-0.934257,-0.000001,-0.356601,-0.934257,-0.000001,-0.356601,-0.934257,-0.000001,-0.356601,-0.934257,-0.000001,-0.122178,-0.992508,0,-0.122178,-0.992508,0,-0.122178,-0.992508,0,-0.122167,-0.992509,-0.000001,-0.122167,-0.992509,-0.000001,-0.122167,-0.992509,-0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.12217,-0.992509,0,0.12217,-0.992509,0,0.12217,-0.992509,0,0.12217,-0.992509,0,0.356619,-0.93425,0,0.356619,-0.93425,0,0.356619,-0.93425,0,0.356619,-0.93425,0,0.561523,-0.827461,-0.000001,0.561523,-0.827461,-0.000001,0.561523,-0.827461,-0.000001,0.561515,-0.827467,0,0.561515,-0.827467,0,0.561515,-0.827467,0,0.729604,-0.68387,-0.000001,0.729604,-0.68387,-0.000001,0.729604,-0.68387,-0.000001,0.729604,-0.68387,-0.000001,0.858876,-0.512183,0,0.858876,-0.512183,0,0.858876,-0.512183,0,0.858879,-0.512178,-0.000001,0.858879,-0.512178,-0.000001,0.858879,-0.512178,-0.000001,0.948107,-0.317953,0,0.948107,-0.317953,0,0.948107,-0.317953,0,0.948107,-0.317953,0,0.9942,-0.107544,0,0.9942,-0.107544,0,0.9942,-0.107544,0,0.9942,-0.107544,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.948086,0.318013,0,0.948086,0.318013,0,0.948086,0.318013,0,0.948086,0.318013,0,0.858888,0.512164,0,0.858888,0.512164,0,0.858888,0.512164,0,0.858888,0.512164,0,0.729604,0.68387,0,0.729604,0.68387,0,0.729604,0.68387,0,0.729604,0.68387,0,0.56152,0.827463,0,0.56152,0.827463,0,0.56152,0.827463,0,0.56152,0.827463,0,0.356653,0.934237,0,0.356653,0.934237,0,0.356653,0.934237,0,0.356653,0.934237,0,0.122159,0.992511,0.000001,0.122159,0.992511,0.000001,0.122159,0.992511,0.000001,0.122147,0.992512,0,0.122147,0.992512,0,0.122147,0.992512,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122164,0.99251,0,-0.122164,0.99251,0,-0.122164,0.99251,0,-0.122164,0.99251,0,-0.356617,0.934251,0,-0.356617,0.934251,0,-0.356617,0.934251,0,-0.356617,0.934251,0,-0.561542,0.827448,0,-0.561542,0.827448,0,-0.561542,0.827448,0,-0.561542,0.827448,0,-0.729586,0.683889,0.000001,-0.729586,0.683889,0.000001,-0.729586,0.683889,0.000001,-0.729592,0.683883,0,-0.729592,0.683883,0,-0.729592,0.683883,0,-0.858914,0.51212,0,-0.858914,0.51212,0,-0.858914,0.51212,0,-0.858911,0.512125,0.000001,-0.858911,0.512125,0.000001,-0.858911,0.512125,0.000001,-0.948085,0.318016,0,-0.948085,0.318016,0,-0.948085,0.318016,0,-0.948085,0.318016,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994202,-0.107525,0,-0.994202,-0.107525,0,-0.994202,-0.107525,0,-0.994202,-0.107525,0,-0.948098,-0.31798,0,-0.948098,-0.31798,0,-0.948098,-0.31798,0,-0.948098,-0.31798,0,-0.858893,-0.512156,0,-0.858893,-0.512156,0,-0.858893,-0.512156,0,-0.858893,-0.512156,0,-0.729592,-0.683883,0,-0.729592,-0.683883,0,-0.729592,-0.683883,0,-0.729592,-0.683883,0,-0.561534,-0.827454,0,-0.561534,-0.827454,0,-0.561534,-0.827454,0,-0.561534,-0.827454,0,-0.356625,-0.934248,-0.000001,-0.356625,-0.934248,-0.000001,-0.356625,-0.934248,-0.000001,-0.356635,-0.934244,0,-0.356635,-0.934244,0,-0.356635,-0.934244,0,-0.122162,-0.99251,0,-0.122162,-0.99251,0,-0.122162,-0.99251,0,-0.12215,-0.992512,-0.000001,-0.12215,-0.992512,-0.000001,-0.12215,-0.992512,-0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.12217,-0.992509,0,0.12217,-0.992509,0,0.12217,-0.992509,0,0.12217,-0.992509,0,0.35663,-0.934246,0,0.35663,-0.934246,0,0.35663,-0.934246,0,0.35663,-0.934246,0,0.561526,-0.827459,-0.000001,0.561526,-0.827459,-0.000001,0.561526,-0.827459,-0.000001,0.561518,-0.827465,0,0.561518,-0.827465,0,0.561518,-0.827465,0,0.729569,-0.683907,-0.000001,0.729569,-0.683907,-0.000001,0.729569,-0.683907,-0.000001,0.729569,-0.683907,-0.000001,0.858907,-0.512132,0,0.858907,-0.512132,0,0.858907,-0.512132,0,0.85891,-0.512127,-0.000001,0.85891,-0.512127,-0.000001,0.85891,-0.512127,-0.000001,0.9481,-0.317973,0,0.9481,-0.317973,0,0.9481,-0.317973,0,0.9481,-0.317973,0,0.9942,-0.107544,0,0.9942,-0.107544,0,0.9942,-0.107544,0,0.9942,-0.107544,0,1,0,0,1,0,0,1,0,0,1,0,0,0.9942,0.107543,0,0.9942,0.107543,0,0.9942,0.107543,0,0.994201,0.107542,0,0.994201,0.107542,0,0.994201,0.107542,0,0.9481,0.317973,0,0.9481,0.317973,0,0.9481,0.317973,0,0.9481,0.317973,0,0.858898,0.512147,0,0.858898,0.512147,0,0.858898,0.512147,0,0.858898,0.512147,0,0.729592,0.683883,0,0.729592,0.683883,0,0.729592,0.683883,0,0.729592,0.683883,0,0.561509,0.82747,0,0.561509,0.82747,0,0.561509,0.82747,0,0.561509,0.82747,0,0.356661,0.934234,0,0.356661,0.934234,0,0.356661,0.934234,0,0.356661,0.934234,0,0.122145,0.992512,0,0.122145,0.992512,0,0.122145,0.992512,0,0.122145,0.992512,0,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0,0,1,0,0,1,0,-0.122164,0.99251,0,-0.122164,0.99251,0,-0.122164,0.99251,0,-0.122153,0.992511,0.000001,-0.122153,0.992511,0.000001,-0.122153,0.992511,0.000001,-0.356609,0.934254,0.000001,-0.356609,0.934254,0.000001,-0.356609,0.934254,0.000001,-0.356619,0.93425,0,-0.356619,0.93425,0,-0.356619,0.93425,0,-0.561553,0.827441,0,-0.561553,0.827441,0,-0.561553,0.827441,0,-0.561545,0.827446,0.000001,-0.561545,0.827446,0.000001,-0.561545,0.827446,0.000001,-0.72958,0.683895,0,-0.72958,0.683895,0,-0.72958,0.683895,0,-0.72958,0.683895,0,-0.858904,0.512137,0,-0.858904,0.512137,0,-0.858904,0.512137,0,-0.858904,0.512137,0,-0.948091,0.318,0,-0.948091,0.318,0,-0.948091,0.318,0,-0.948091,0.318,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-0.994205,-0.107504,0,-0.994205,-0.107504,0,-0.994205,-0.107504,0,-0.994205,-0.107504,0,-0.948099,-0.317976,0,-0.948099,-0.317976,0,-0.948099,-0.317976,0,-0.948099,-0.317976,0,-0.858893,-0.512156,0,-0.858893,-0.512156,0,-0.858893,-0.512156,0,-0.858893,-0.512156,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.561542,-0.827448,0,-0.561542,-0.827448,0,-0.561542,-0.827448,0,-0.561542,-0.827448,0,-0.356617,-0.934251,0,-0.356617,-0.934251,0,-0.356617,-0.934251,0,-0.356617,-0.934251,0,-0.122164,-0.99251,0,-0.122164,-0.99251,0,-0.122164,-0.99251,0,-0.122164,-0.99251,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0,-1,0,0,-1,0,0.122153,-0.992511,0,0.122153,-0.992511,0,0.122153,-0.992511,0,0.122164,-0.99251,-0.000001,0.122164,-0.99251,-0.000001,0.122164,-0.99251,-0.000001,0.356634,-0.934244,0,0.356634,-0.934244,0,0.356634,-0.934244,0,0.356634,-0.934244,0,0.561531,-0.827456,0,0.561531,-0.827456,0,0.561531,-0.827456,0,0.561531,-0.827456,0,0.729581,-0.683894,0,0.729581,-0.683894,0,0.729581,-0.683894,0,0.729581,-0.683894,0,0.8589,-0.512144,-0.000001,0.8589,-0.512144,-0.000001,0.8589,-0.512144,-0.000001,0.858897,-0.512149,0,0.858897,-0.512149,0,0.858897,-0.512149,0,0.9481,-0.317973,0,0.9481,-0.317973,0,0.9481,-0.317973,0,0.9481,-0.317973,0,0.994203,-0.107524,0,0.994203,-0.107524,0,0.994203,-0.107524,0,0.994203,-0.107523,0,0.994203,-0.107523,0,0.994203,-0.107523,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994203,0.10752,0,0.994203,0.10752,0,0.994203,0.10752,0,0.994203,0.10752,0,0.948096,0.317983,0,0.948096,0.317983,0,0.948096,0.317983,0,0.948096,0.317983,0,0.858893,0.512156,0,0.858893,0.512156,0,0.858893,0.512156,0,0.858893,0.512156,0,0.729586,0.683889,0,0.729586,0.683889,0,0.729586,0.683889,0,0.729586,0.683889,0,0.561526,0.827459,0,0.561526,0.827459,0,0.561526,0.827459,0,0.561526,0.827459,0,0.356657,0.934236,0,0.356657,0.934236,0,0.356657,0.934236,0,0.356657,0.934236,0,0.122143,0.992512,0,0.122143,0.992512,0,0.122143,0.992512,0,0.122143,0.992512,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122155,0.992511,0,-0.122155,0.992511,0,-0.122155,0.992511,0,-0.122155,0.992511,0,-0.356616,0.934251,0,-0.356616,0.934251,0,-0.356616,0.934251,0,-0.356616,0.934251,0,-0.561545,0.827446,0,-0.561545,0.827446,0,-0.561545,0.827446,0,-0.561545,0.827446,0,-0.729592,0.683883,0,-0.729592,0.683883,0,-0.729592,0.683883,0,-0.729592,0.683883,0,-0.858894,0.512154,0,-0.858894,0.512154,0,-0.858894,0.512154,0,-0.858894,0.512154,0,-0.948091,0.318,0,-0.948091,0.318,0,-0.948091,0.318,0,-0.948091,0.318,0,-0.994204,0.107511,0,-0.994204,0.107511,0,-0.994204,0.107511,0,-0.994204,0.107511,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994202,-0.107525,0,-0.994202,-0.107525,0,-0.994202,-0.107525,0,-0.994202,-0.107525,0,-0.948094,-0.31799,0,-0.948094,-0.31799,0,-0.948094,-0.31799,0,-0.948094,-0.31799,0,-0.858908,-0.51213,0,-0.858908,-0.51213,0,-0.858908,-0.51213,0,-0.858908,-0.51213,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.561547,-0.827445,0,-0.561547,-0.827445,0,-0.561547,-0.827445,0,-0.561547,-0.827445,0,-0.356613,-0.934252,0,-0.356613,-0.934252,0,-0.356613,-0.934252,0,-0.356613,-0.934252,0,-0.122164,-0.99251,0,-0.122164,-0.99251,0,-0.122164,-0.99251,0,-0.122164,-0.99251,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0,-1,0,0,-1,0,0.122169,-0.992509,-0.000001,0.122169,-0.992509,-0.000001,0.122169,-0.992509,-0.000001,0.122169,-0.992509,-0.000001,0.356626,-0.934247,-0.000001,0.356626,-0.934247,-0.000001,0.356626,-0.934247,-0.000001,0.356626,-0.934247,-0.000001,0.561526,-0.827459,-0.000001,0.561526,-0.827459,-0.000001,0.561526,-0.827459,-0.000001,0.561526,-0.827459,-0.000001,0.729581,-0.683894,-0.000001,0.729581,-0.683894,-0.000001,0.729581,-0.683894,-0.000001,0.729581,-0.683894,-0.000001,0.858902,-0.512141,-0.000001,0.858902,-0.512141,-0.000001,0.858902,-0.512141,-0.000001,0.858902,-0.512141,-0.000001,0.948096,-0.317983,0,0.948096,-0.317983,0,0.948096,-0.317983,0,0.948096,-0.317983,0,0.994201,-0.107535,0,0.994201,-0.107535,0,0.994201,-0.107535,0,0.994201,-0.107533,0,0.994201,-0.107533,0,0.994201,-0.107533,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994202,0.107531,0,0.994202,0.107531,0,0.994202,0.107531,0,0.994202,0.107531,0,0.948093,0.317993,0,0.948093,0.317993,0,0.948093,0.317993,0,0.948093,0.317993,0,0.858898,0.512147,0,0.858898,0.512147,0,0.858898,0.512147,0,0.858898,0.512147,0,0.729586,0.683889,0,0.729586,0.683889,0,0.729586,0.683889,0,0.729586,0.683889,0,0.561523,0.827461,0,0.561523,0.827461,0,0.561523,0.827461,0,0.561523,0.827461,0,0.356653,0.934237,0,0.356653,0.934237,0,0.356653,0.934237,0,0.356653,0.934237,0,0.122146,0.992512,0,0.122146,0.992512,0,0.122146,0.992512,0,0.122146,0.992512,0,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0,0,1,0,0,1,0,-0.122166,0.99251,0,-0.122166,0.99251,0,-0.122166,0.99251,0,-0.122155,0.992511,0.000001,-0.122155,0.992511,0.000001,-0.122155,0.992511,0.000001,-0.356607,0.934254,0,-0.356607,0.934254,0,-0.356607,0.934254,0,-0.356607,0.934254,0,-0.561539,0.82745,0,-0.561539,0.82745,0,-0.561539,0.82745,0,-0.561539,0.82745,0,-0.729595,0.68388,0,-0.729595,0.68388,0,-0.729595,0.68388,0,-0.729595,0.68388,0,-0.858896,0.51215,0,-0.858896,0.51215,0,-0.858896,0.51215,0,-0.858896,0.51215,0,-0.948092,0.317995,0,-0.948092,0.317995,0,-0.948092,0.317995,0,-0.948092,0.317995,0,-0.994203,0.107515,0,-0.994203,0.107515,0,-0.994203,0.107515,0,-0.994203,0.107515,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994203,-0.107519,0,-0.994203,-0.107519,0,-0.994203,-0.107519,0,-0.994203,-0.10752,0,-0.994203,-0.10752,0,-0.994203,-0.10752,0,-0.948093,-0.317995,0,-0.948093,-0.317995,0,-0.948093,-0.317995,0,-0.948093,-0.317995,0,-0.858905,-0.512135,0,-0.858905,-0.512135,0,-0.858905,-0.512135,0,-0.858905,-0.512135,0,-0.729592,-0.683883,0,-0.729592,-0.683883,0,-0.729592,-0.683883,0,-0.729592,-0.683883,0,-0.561539,-0.82745,0,-0.561539,-0.82745,0,-0.561539,-0.82745,0,-0.561539,-0.82745,0,-0.356605,-0.934255,-0.000001,-0.356605,-0.934255,-0.000001,-0.356605,-0.934255,-0.000001,-0.356616,-0.934251,0,-0.356616,-0.934251,0,-0.356616,-0.934251,0,-0.122168,-0.992509,0,-0.122168,-0.992509,0,-0.122168,-0.992509,0,-0.122157,-0.992511,-0.000001,-0.122157,-0.992511,-0.000001,-0.122157,-0.992511,-0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122166,-0.99251,0,0.122166,-0.99251,0,0.122166,-0.99251,0,0.122166,-0.99251,0,0.356617,-0.934251,0,0.356617,-0.934251,0,0.356617,-0.934251,0,0.356617,-0.934251,0,0.561531,-0.827456,0,0.561531,-0.827456,0,0.561531,-0.827456,0,0.561531,-0.827456,0,0.729582,-0.683893,0,0.729582,-0.683893,0,0.729582,-0.683893,0,0.729582,-0.683893,0,0.858902,-0.51214,0,0.858902,-0.51214,0,0.858902,-0.51214,0,0.858902,-0.51214,0,0.948094,-0.31799,0,0.948094,-0.31799,0,0.948094,-0.31799,0,0.948094,-0.31799,0,0.994203,-0.107523,0,0.994203,-0.107523,0,0.994203,-0.107523,0,0.994203,-0.107523,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994203,0.10752,0,0.994203,0.10752,0,0.994203,0.10752,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.948094,0.31799,0,0.948094,0.31799,0,0.948094,0.31799,0,0.948094,0.31799,0,0.85889,0.51216,0,0.85889,0.51216,0,0.85889,0.51216,0,0.858893,0.512155,0.000001,0.858893,0.512155,0.000001,0.858893,0.512155,0.000001,0.729589,0.683886,0,0.729589,0.683886,0,0.729589,0.683886,0,0.729589,0.683886,0,0.561522,0.827462,0,0.561522,0.827462,0,0.561522,0.827462,0,0.561522,0.827462,0,0.356659,0.934235,0,0.356659,0.934235,0,0.356659,0.934235,0,0.356659,0.934235,0,0.122144,0.992512,0,0.122144,0.992512,0,0.122144,0.992512,0,0.122144,0.992512,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122166,0.99251,0,-0.122166,0.99251,0,-0.122166,0.99251,0,-0.122166,0.99251,0,-0.356607,0.934254,0,-0.356607,0.934254,0,-0.356607,0.934254,0,-0.356607,0.934254,0,-0.561539,0.82745,0.000001,-0.561539,0.82745,0.000001,-0.561539,0.82745,0.000001,-0.561547,0.827445,0,-0.561547,0.827445,0,-0.561547,0.827445,0,-0.729592,0.683883,0,-0.729592,0.683883,0,-0.729592,0.683883,0,-0.729586,0.683889,0.000001,-0.729586,0.683889,0.000001,-0.729586,0.683889,0.000001,-0.858897,0.512148,0,-0.858897,0.512148,0,-0.858897,0.512148,0,-0.858897,0.512148,0,-0.948092,0.317997,0,-0.948092,0.317997,0,-0.948092,0.317997,0,-0.948092,0.317997,0,-0.994203,0.10752,0,-0.994203,0.10752,0,-0.994203,0.10752,0,-0.994203,0.10752,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994202,-0.10753,0,-0.994202,-0.10753,0,-0.994202,-0.10753,0,-0.994202,-0.10753,0,-0.948094,-0.317991,0,-0.948094,-0.317991,0,-0.948094,-0.317991,0,-0.948094,-0.317991,0,-0.858907,-0.512133,0,-0.858907,-0.512133,0,-0.858907,-0.512133,0,-0.858907,-0.512133,0,-0.729588,-0.683887,0,-0.729588,-0.683887,0,-0.729588,-0.683887,0,-0.729588,-0.683887,0,-0.561546,-0.827446,0,-0.561546,-0.827446,0,-0.561546,-0.827446,0,-0.561546,-0.827446,0,-0.356607,-0.934254,0,-0.356607,-0.934254,0,-0.356607,-0.934254,0,-0.356607,-0.934254,0,-0.122167,-0.99251,0,-0.122167,-0.99251,0,-0.122167,-0.99251,0,-0.122167,-0.99251,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122167,-0.99251,0,0.122167,-0.99251,0,0.122167,-0.99251,0,0.122167,-0.99251,0,0.356623,-0.934249,0,0.356623,-0.934249,0,0.356623,-0.934249,0,0.356623,-0.934249,0,0.561539,-0.82745,0,0.561539,-0.82745,0,0.561539,-0.82745,0,0.561539,-0.82745,0,0.72958,-0.683896,0,0.72958,-0.683896,0,0.72958,-0.683896,0,0.72958,-0.683896,0,0.858904,-0.512137,0,0.858904,-0.512137,0,0.858904,-0.512137,0,0.858904,-0.512137,0,0.948093,-0.317993,0,0.948093,-0.317993,0,0.948093,-0.317993,0,0.948093,-0.317993,0,0.994202,-0.107524,0,0.994202,-0.107524,0,0.994202,-0.107524,0,0.994202,-0.107524,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994203,0.107519,0,0.994203,0.107519,0,0.994203,0.107519,0,0.994203,0.107519,0,0.948094,0.317989,0,0.948094,0.317989,0,0.948094,0.317989,0,0.948094,0.317989,0,0.85889,0.51216,0,0.85889,0.51216,0,0.85889,0.51216,0,0.85889,0.51216,0,0.729593,0.683882,0,0.729593,0.683882,0,0.729593,0.683882,0,0.729593,0.683882,0,0.561511,0.827469,0,0.561511,0.827469,0,0.561511,0.827469,0,0.561511,0.827469,0,0.35666,0.934234,0,0.35666,0.934234,0,0.35666,0.934234,0,0.35666,0.934234,0,0.122155,0.992511,0,0.122155,0.992511,0,0.122155,0.992511,0,0.122155,0.992511,0,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0,0,1,0,0,1,0,-0.122167,0.992509,0.000001,-0.122167,0.992509,0.000001,-0.122167,0.992509,0.000001,-0.122167,0.992509,0.000001,-0.356607,0.934254,0.000001,-0.356607,0.934254,0.000001,-0.356607,0.934254,0.000001,-0.356607,0.934254,0.000001,-0.561549,0.827444,0.000001,-0.561549,0.827444,0.000001,-0.561549,0.827444,0.000001,-0.561549,0.827444,0.000001,-0.729582,0.683893,0.000001,-0.729582,0.683893,0.000001,-0.729582,0.683893,0.000001,-0.729582,0.683893,0.000001,-0.858896,0.51215,0.000001,-0.858896,0.51215,0.000001,-0.858896,0.51215,0.000001,-0.858896,0.51215,0.000001,-0.948095,0.317986,0,-0.948095,0.317986,0,-0.948095,0.317986,0,-0.948094,0.31799,0,-0.948094,0.31799,0,-0.948094,0.31799,0,-0.994202,0.107524,0,-0.994202,0.107524,0,-0.994202,0.107524,0,-0.994203,0.107523,0,-0.994203,0.107523,0,-0.994203,0.107523,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994202,-0.10753,0,-0.994202,-0.10753,0,-0.994202,-0.10753,0,-0.994202,-0.10753,0,-0.948092,-0.317997,0,-0.948092,-0.317997,0,-0.948092,-0.317997,0,-0.948092,-0.317997,0,-0.858912,-0.512124,0,-0.858912,-0.512124,0,-0.858912,-0.512124,0,-0.858912,-0.512124,0,-0.72959,-0.683884,0,-0.72959,-0.683884,0,-0.72959,-0.683884,0,-0.72959,-0.683884,0,-0.561549,-0.827444,0,-0.561549,-0.827444,0,-0.561549,-0.827444,0,-0.561549,-0.827444,0,-0.356604,-0.934256,0,-0.356604,-0.934256,0,-0.356604,-0.934256,0,-0.356604,-0.934256,0,-0.122167,-0.992509,0,-0.122167,-0.992509,0,-0.122167,-0.992509,0,-0.122167,-0.992509,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0,-1,0,0,-1,0,0.122153,-0.992511,0,0.122153,-0.992511,0,0.122153,-0.992511,0,0.122164,-0.99251,-0.000001,0.122164,-0.99251,-0.000001,0.122164,-0.99251,-0.000001,0.35663,-0.934246,0,0.35663,-0.934246,0,0.35663,-0.934246,0,0.35663,-0.934246,0,0.561545,-0.827446,0,0.561545,-0.827446,0,0.561545,-0.827446,0,0.561545,-0.827446,0,0.729569,-0.683907,0,0.729569,-0.683907,0,0.729569,-0.683907,0,0.729569,-0.683907,0,0.858907,-0.512131,0,0.858907,-0.512131,0,0.858907,-0.512131,0,0.858907,-0.512131,0,0.948095,-0.317988,0,0.948095,-0.317988,0,0.948095,-0.317988,0,0.948095,-0.317988,0,0.994203,-0.107519,0,0.994203,-0.107519,0,0.994203,-0.107519,0,0.994203,-0.107519,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.948098,0.317978,0,0.948098,0.317978,0,0.948098,0.317978,0,0.948098,0.317978,0,0.858888,0.512164,0,0.858888,0.512164,0,0.858888,0.512164,0,0.858888,0.512164,0,0.72958,0.683895,0,0.72958,0.683895,0,0.72958,0.683895,0,0.72958,0.683895,0,0.561523,0.827461,0,0.561523,0.827461,0,0.561523,0.827461,0,0.561523,0.827461,0,0.356664,0.934233,0,0.356664,0.934233,0,0.356664,0.934233,0,0.356664,0.934233,0,0.122152,0.992511,0,0.122152,0.992511,0,0.122152,0.992511,0,0.122152,0.992511,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122168,0.992509,0,-0.122168,0.992509,0,-0.122168,0.992509,0,-0.122168,0.992509,0,-0.356605,0.934255,0,-0.356605,0.934255,0,-0.356605,0.934255,0,-0.356605,0.934255,0,-0.561536,0.827452,0,-0.561536,0.827452,0,-0.561536,0.827452,0,-0.561536,0.827452,0,-0.729589,0.683886,0,-0.729589,0.683886,0,-0.729589,0.683886,0,-0.729589,0.683886,0,-0.858899,0.512146,0,-0.858899,0.512146,0,-0.858899,0.512146,0,-0.858899,0.512146,0,-0.948097,0.317981,0,-0.948097,0.317981,0,-0.948097,0.317981,0,-0.948097,0.317981,0,-0.994202,0.107527,0,-0.994202,0.107527,0,-0.994202,0.107527,0,-0.994202,0.107527,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994201,-0.107535,0,-0.994201,-0.107535,0,-0.994201,-0.107535,0,-0.994201,-0.107536,0,-0.994201,-0.107536,0,-0.994201,-0.107536,0,-0.948091,-0.318,0,-0.948091,-0.318,0,-0.948091,-0.318,0,-0.948091,-0.318,0,-0.858915,-0.512118,0,-0.858915,-0.512118,0,-0.858915,-0.512118,0,-0.858915,-0.512118,0,-0.729589,-0.683886,0,-0.729589,-0.683886,0,-0.729589,-0.683886,0,-0.729589,-0.683886,0,-0.561542,-0.827448,0,-0.561542,-0.827448,0,-0.561542,-0.827448,0,-0.561542,-0.827448,0,-0.356609,-0.934254,0,-0.356609,-0.934254,0,-0.356609,-0.934254,0,-0.356609,-0.934254,0,-0.122166,-0.99251,0,-0.122166,-0.99251,0,-0.122166,-0.99251,0,-0.122166,-0.99251,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122166,-0.99251,0,0.122166,-0.99251,0,0.122166,-0.99251,0,0.122166,-0.99251,0,0.356618,-0.93425,-0.000001,0.356618,-0.93425,-0.000001,0.356618,-0.93425,-0.000001,0.356608,-0.934254,0,0.356608,-0.934254,0,0.356608,-0.934254,0,0.561542,-0.827448,-0.000001,0.561542,-0.827448,-0.000001,0.561542,-0.827448,-0.000001,0.561542,-0.827448,-0.000001,0.729587,-0.683888,-0.000001,0.729587,-0.683888,-0.000001,0.729587,-0.683888,-0.000001,0.729587,-0.683888,-0.000001,0.858917,-0.512115,0,0.858917,-0.512115,0,0.858917,-0.512115,0,0.85892,-0.51211,-0.000001,0.85892,-0.51211,-0.000001,0.85892,-0.51211,-0.000001,0.948073,-0.318053,0,0.948073,-0.318053,0,0.948073,-0.318053,0,0.948073,-0.318053,0,0.994206,-0.107491,0,0.994206,-0.107491,0,0.994206,-0.107491,0,0.994206,-0.107491,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994205,0.1075,0,0.994205,0.1075,0,0.994205,0.1075,0,0.994205,0.1075,0,0.948086,0.318013,0,0.948086,0.318013,0,0.948086,0.318013,0,0.948086,0.318013,0,0.858883,0.512173,0.000001,0.858883,0.512173,0.000001,0.858883,0.512173,0.000001,0.858883,0.512173,0.000001,0.729598,0.683877,0,0.729598,0.683877,0,0.729598,0.683877,0,0.729603,0.683871,0.000001,0.729603,0.683871,0.000001,0.729603,0.683871,0.000001,0.561515,0.827467,0,0.561515,0.827467,0,0.561515,0.827467,0,0.561515,0.827467,0,0.356668,0.934231,0,0.356668,0.934231,0,0.356668,0.934231,0,0.356668,0.934231,0,0.12214,0.992513,0,0.12214,0.992513,0,0.12214,0.992513,0,0.12214,0.992513,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122164,0.99251,0,-0.122164,0.99251,0,-0.122164,0.99251,0,-0.122164,0.99251,0,-0.356613,0.934252,0,-0.356613,0.934252,0,-0.356613,0.934252,0,-0.356613,0.934252,0,-0.561542,0.827448,0,-0.561542,0.827448,0,-0.561542,0.827448,0,-0.561542,0.827448,0,-0.729581,0.683895,0,-0.729581,0.683895,0,-0.729581,0.683895,0,-0.729581,0.683895,0,-0.858899,0.512146,0,-0.858899,0.512146,0,-0.858899,0.512146,0,-0.858899,0.512146,0,-0.948102,0.317966,0,-0.948102,0.317966,0,-0.948102,0.317966,0,-0.948102,0.317966,0,-0.9942,0.107543,0,-0.9942,0.107543,0,-0.9942,0.107543,0,-0.9942,0.107543,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.9942,-0.107546,0,-0.9942,-0.107546,0,-0.9942,-0.107546,0,-0.9942,-0.107546,0,-0.948092,-0.317996,0,-0.948092,-0.317996,0,-0.948092,-0.317996,0,-0.948092,-0.317996,0,-0.858923,-0.512105,0,-0.858923,-0.512105,0,-0.858923,-0.512105,0,-0.858923,-0.512105,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.561547,-0.827445,0,-0.561547,-0.827445,0,-0.561547,-0.827445,0,-0.561547,-0.827445,0,-0.356605,-0.934255,0,-0.356605,-0.934255,0,-0.356605,-0.934255,0,-0.356605,-0.934255,0,-0.122167,-0.992509,0,-0.122167,-0.992509,0,-0.122167,-0.992509,0,-0.122167,-0.992509,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122164,-0.99251,0,0.122164,-0.99251,0,0.122164,-0.99251,0,0.122164,-0.99251,0,0.356618,-0.93425,0,0.356618,-0.93425,0,0.356618,-0.93425,0,0.356618,-0.93425,0,0.561559,-0.827437,0,0.561559,-0.827437,0,0.561559,-0.827437,0,0.561559,-0.827437,0,0.729575,-0.683901,0,0.729575,-0.683901,0,0.729575,-0.683901,0,0.729575,-0.683901,0,0.858912,-0.512124,0,0.858912,-0.512124,0,0.858912,-0.512124,0,0.858912,-0.512124,0,0.94808,-0.318033,0,0.94808,-0.318033,0,0.94808,-0.318033,0,0.94808,-0.318033,0,0.994204,-0.107512,0,0.994204,-0.107512,0,0.994204,-0.107512,0,0.994204,-0.107512,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994206,0.10749,0,0.994206,0.10749,0,0.994206,0.10749,0,0.994206,0.107488,0,0.994206,0.107488,0,0.994206,0.107488,0,0.948093,0.317993,0,0.948093,0.317993,0,0.948093,0.317993,0,0.948093,0.317993,0,0.858872,0.51219,0,0.858872,0.51219,0,0.858872,0.51219,0,0.858872,0.51219,0,0.729604,0.68387,0,0.729604,0.68387,0,0.729604,0.68387,0,0.729604,0.68387,0,0.561515,0.827467,0,0.561515,0.827467,0,0.561515,0.827467,0,0.561515,0.827467,0,0.356664,0.934233,0,0.356664,0.934233,0,0.356664,0.934233,0,0.356664,0.934233,0,0.122139,0.992513,0,0.122139,0.992513,0,0.122139,0.992513,0,0.122139,0.992513,0,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0.000001,-0.122167,0.992509,0,-0.122167,0.992509,0,-0.122167,0.992509,0,-0.122156,0.992511,0.000001,-0.122156,0.992511,0.000001,-0.122156,0.992511,0.000001,-0.356617,0.934251,0.000001,-0.356617,0.934251,0.000001,-0.356617,0.934251,0.000001,-0.356627,0.934247,0,-0.356627,0.934247,0,-0.356627,0.934247,0,-0.561531,0.827456,0,-0.561531,0.827456,0,-0.561531,0.827456,0,-0.561523,0.827461,0.000001,-0.561523,0.827461,0.000001,-0.561523,0.827461,0.000001,-0.729592,0.683883,0,-0.729592,0.683883,0,-0.729592,0.683883,0,-0.729592,0.683883,0,-0.858891,0.512159,0.000001,-0.858891,0.512159,0.000001,-0.858891,0.512159,0.000001,-0.858894,0.512154,0,-0.858894,0.512154,0,-0.858894,0.512154,0,-0.948105,0.317956,0,-0.948105,0.317956,0,-0.948105,0.317956,0,-0.948104,0.317959,0,-0.948104,0.317959,0,-0.948104,0.317959,0,-0.994198,0.107564,0,-0.994198,0.107564,0,-0.994198,0.107564,0,-0.994198,0.107564,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994198,-0.107568,0,-0.994198,-0.107568,0,-0.994198,-0.107568,0,-0.994198,-0.107568,0,-0.948098,-0.31798,0,-0.948098,-0.31798,0,-0.948098,-0.31798,0,-0.948098,-0.31798,0,-0.858913,-0.512122,0,-0.858913,-0.512122,0,-0.858913,-0.512122,0,-0.858913,-0.512122,0,-0.729592,-0.683883,0,-0.729592,-0.683883,0,-0.729592,-0.683883,0,-0.729592,-0.683883,0,-0.561542,-0.827448,0,-0.561542,-0.827448,0,-0.561542,-0.827448,0,-0.561542,-0.827448,0,-0.356609,-0.934254,0,-0.356609,-0.934254,0,-0.356609,-0.934254,0,-0.356609,-0.934254,0,-0.122156,-0.992511,-0.000001,-0.122156,-0.992511,-0.000001,-0.122156,-0.992511,-0.000001,-0.122167,-0.992509,0,-0.122167,-0.992509,0,-0.122167,-0.992509,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0.122153,-0.992511,0,0.122153,-0.992511,0,0.122153,-0.992511,0,0.122153,-0.992511,0,0.35663,-0.934246,0,0.35663,-0.934246,0,0.35663,-0.934246,0,0.35663,-0.934246,0,0.561548,-0.827444,0,0.561548,-0.827444,0,0.561548,-0.827444,0,0.561548,-0.827444,0,0.729581,-0.683894,0,0.729581,-0.683894,0,0.729581,-0.683894,0,0.729581,-0.683894,0,0.85891,-0.512127,0,0.85891,-0.512127,0,0.85891,-0.512127,0,0.85891,-0.512127,0,0.948086,-0.318013,0,0.948086,-0.318013,0,0.948086,-0.318013,0,0.948086,-0.318013,0,0.9942,-0.107545,0,0.9942,-0.107545,0,0.9942,-0.107545,0,0.9942,-0.107545,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,0.994203,0.10752,0,0.994203,0.10752,0,0.994203,0.10752,0,0.994203,0.10752,0,0.948107,0.317953,0,0.948107,0.317953,0,0.948107,0.317953,0,0.948107,0.317953,0,0.858877,0.512181,0.000001,0.858877,0.512181,0.000001,0.858877,0.512181,0.000001,0.858877,0.512181,0.000001,0.729575,0.683901,0,0.729575,0.683901,0,0.729575,0.683901,0,0.72958,0.683895,0.000001,0.72958,0.683895,0.000001,0.72958,0.683895,0.000001,0.561518,0.827465,0.000001,0.561518,0.827465,0.000001,0.561518,0.827465,0.000001,0.561509,0.82747,0,0.561509,0.82747,0,0.561509,0.82747,0,0.356668,0.934231,0.000001,0.356668,0.934231,0.000001,0.356668,0.934231,0.000001,0.356668,0.934231,0.000001,0.122142,0.992513,0.000001,0.122142,0.992513,0.000001,0.122142,0.992513,0.000001,0.122142,0.992513,0.000001,0,1,0,0,1,0,0,1,0,0,1,0.000001,0,1,0.000001,0,1,0.000001,-0.122167,0.992509,0,-0.122167,0.992509,0,-0.122167,0.992509,0,-0.122167,0.992509,0,-0.356596,0.934258,0,-0.356596,0.934258,0,-0.356596,0.934258,0,-0.356596,0.934258,0,-0.561555,0.827439,0,-0.561555,0.827439,0,-0.561555,0.827439,0,-0.561555,0.827439,0,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.8589,0.512144,0,-0.8589,0.512144,0,-0.8589,0.512144,0,-0.8589,0.512144,0,-0.948102,0.317966,0,-0.948102,0.317966,0,-0.948102,0.317966,0,-0.948102,0.317966,0,-0.994201,0.107542,0,-0.994201,0.107542,0,-0.994201,0.107542,0,-0.994201,0.107542,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994203,-0.107522,0,-0.994203,-0.107522,0,-0.994203,-0.107522,0,-0.994203,-0.107522,0,-0.948083,-0.318023,0,-0.948083,-0.318023,0,-0.948083,-0.318023,0,-0.948083,-0.318023,0,-0.858917,-0.512115,0,-0.858917,-0.512115,0,-0.858917,-0.512115,0,-0.858917,-0.512115,0,-0.729592,-0.683883,0,-0.729592,-0.683883,0,-0.729592,-0.683883,0,-0.729592,-0.683883,0,-0.561534,-0.827454,-0.000001,-0.561534,-0.827454,-0.000001,-0.561534,-0.827454,-0.000001,-0.561542,-0.827448,0,-0.561542,-0.827448,0,-0.561542,-0.827448,0,-0.356601,-0.934257,-0.000001,-0.356601,-0.934257,-0.000001,-0.356601,-0.934257,-0.000001,-0.356601,-0.934257,-0.000001,-0.12217,-0.992509,-0.000001,-0.12217,-0.992509,-0.000001,-0.12217,-0.992509,-0.000001,-0.12217,-0.992509,-0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0.122184,-0.992508,0,0.122184,-0.992508,0,0.122184,-0.992508,0,0.122184,-0.992508,0,0.356635,-0.934244,0,0.356635,-0.934244,0,0.356635,-0.934244,0,0.356635,-0.934244,0,0.561507,-0.827472,0,0.561507,-0.827472,0,0.561507,-0.827472,0,0.561507,-0.827472,0,0.729575,-0.683901,0,0.729575,-0.683901,0,0.729575,-0.683901,0,0.729575,-0.683901,0,0.858901,-0.512142,0,0.858901,-0.512142,0,0.858901,-0.512142,0,0.858901,-0.512142,0,0.948094,-0.31799,0,0.948094,-0.31799,0,0.948094,-0.31799,0,0.948094,-0.31799,0,0.994203,-0.107523,0,0.994203,-0.107523,0,0.994203,-0.107523,0,0.994203,-0.107523,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994203,0.107523,0,0.994203,0.107523,0,0.994203,0.107523,0,0.994203,0.107524,0,0.994203,0.107524,0,0.994203,0.107524,0,0.948093,0.317993,0,0.948093,0.317993,0,0.948093,0.317993,0,0.948093,0.317993,0,0.858863,0.512205,0.000001,0.858863,0.512205,0.000001,0.858863,0.512205,0.000001,0.858863,0.512205,0.000001,0.729627,0.683845,0.000001,0.729627,0.683845,0.000001,0.729627,0.683845,0.000001,0.729627,0.683845,0.000001,0.561515,0.827467,0.000001,0.561515,0.827467,0.000001,0.561515,0.827467,0.000001,0.561515,0.827467,0.000001,0.356635,0.934244,0,0.356635,0.934244,0,0.356635,0.934244,0,0.356645,0.93424,0.000001,0.356645,0.93424,0.000001,0.356645,0.93424,0.000001,0.122162,0.99251,0.000001,0.122162,0.99251,0.000001,0.122162,0.99251,0.000001,0.12215,0.992512,0,0.12215,0.992512,0,0.12215,0.992512,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.12215,0.992512,0,-0.12215,0.992512,0,-0.12215,0.992512,0,-0.12215,0.992512,0,-0.356601,0.934257,0,-0.356601,0.934257,0,-0.356601,0.934257,0,-0.356601,0.934257,0,-0.561572,0.827428,0,-0.561572,0.827428,0,-0.561572,0.827428,0,-0.561572,0.827428,0,-0.729569,0.683907,0,-0.729569,0.683907,0,-0.729569,0.683907,0,-0.729569,0.683907,0,-0.858939,0.512079,0,-0.858939,0.512079,0,-0.858939,0.512079,0,-0.858939,0.512079,0,-0.948078,0.318038,0,-0.948078,0.318038,0,-0.948078,0.318038,0,-0.948078,0.318038,0,-0.9942,0.107543,0,-0.9942,0.107543,0,-0.9942,0.107543,0,-0.9942,0.107542,0,-0.9942,0.107542,0,-0.9942,0.107542,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994193,-0.107608,0,-0.994193,-0.107608,0,-0.994193,-0.107608,0,-0.994193,-0.107608,0,-0.948107,-0.317953,0,-0.948107,-0.317953,0,-0.948107,-0.317953,0,-0.948106,-0.317954,0,-0.948106,-0.317954,0,-0.948106,-0.317954,0,-0.858885,-0.512168,0,-0.858885,-0.512168,0,-0.858885,-0.512168,0,-0.858887,-0.512166,0,-0.858887,-0.512166,0,-0.858887,-0.512166,0,-0.72961,-0.683864,0,-0.72961,-0.683864,0,-0.72961,-0.683864,0,-0.729607,-0.683867,0,-0.729607,-0.683867,0,-0.729607,-0.683867,0,-0.561523,-0.827461,0,-0.561523,-0.827461,0,-0.561523,-0.827461,0,-0.561523,-0.827461,0,-0.356643,-0.934241,0,-0.356643,-0.934241,0,-0.356643,-0.934241,0,-0.356643,-0.934241,0,-0.122159,-0.992511,-0.000001,-0.122159,-0.992511,-0.000001,-0.122159,-0.992511,-0.000001,-0.122164,-0.99251,0,-0.122164,-0.99251,0,-0.122164,-0.99251,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0.122173,-0.992509,0,0.122173,-0.992509,0,0.122173,-0.992509,0,0.122173,-0.992509,0,0.356619,-0.93425,0,0.356619,-0.93425,0,0.356619,-0.93425,0,0.356619,-0.93425,0,0.561539,-0.82745,0,0.561539,-0.82745,0,0.561539,-0.82745,0,0.561539,-0.82745,0,0.729575,-0.683901,0,0.729575,-0.683901,0,0.729575,-0.683901,0,0.729575,-0.683901,0,0.858885,-0.512168,0,0.858885,-0.512168,0,0.858885,-0.512168,0,0.858885,-0.512168,0,0.948113,-0.317933,0,0.948113,-0.317933,0,0.948113,-0.317933,0,0.948113,-0.317933,0,0.994198,-0.107565,0,0.994198,-0.107565,0,0.994198,-0.107565,0,0.994198,-0.107565,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994198,0.107564,0,0.994198,0.107564,0,0.994198,0.107564,0,0.994198,0.107564,0,0.948113,0.317933,0,0.948113,0.317933,0,0.948113,0.317933,0,0.948113,0.317933,0,0.858872,0.51219,0,0.858872,0.51219,0,0.858872,0.51219,0,0.858872,0.51219,0,0.729581,0.683894,0,0.729581,0.683894,0,0.729581,0.683894,0,0.729581,0.683894,0,0.56157,0.82743,0,0.56157,0.82743,0,0.56157,0.82743,0,0.56157,0.82743,0,0.356622,0.934249,0,0.356622,0.934249,0,0.356622,0.934249,0,0.356622,0.934249,0,0.122167,0.992509,0,0.122167,0.992509,0,0.122167,0.992509,0,0.122167,0.992509,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122139,0.992513,0,-0.122139,0.992513,0,-0.122139,0.992513,0,-0.122139,0.992513,0,-0.356617,0.934251,0,-0.356617,0.934251,0,-0.356617,0.934251,0,-0.356617,0.934251,0,-0.561565,0.827433,0,-0.561565,0.827433,0,-0.561565,0.827433,0,-0.561565,0.827433,0,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.858888,0.512163,0,-0.858888,0.512163,0,-0.858888,0.512163,0,-0.858888,0.512163,0,-0.948098,0.317978,0,-0.948098,0.317978,0,-0.948098,0.317978,0,-0.948098,0.317978,0,-0.994203,0.107521,0,-0.994203,0.107521,0,-0.994203,0.107521,0,-0.994203,0.107521,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-0.994205,-0.107502,0,-0.994205,-0.107502,0,-0.994205,-0.107502,0,-0.994205,-0.107501,0,-0.994205,-0.107501,0,-0.994205,-0.107501,0,-0.948107,-0.317951,0,-0.948107,-0.317951,0,-0.948107,-0.317951,0,-0.948107,-0.317953,0,-0.948107,-0.317953,0,-0.948107,-0.317953,0,-0.858875,-0.512185,0,-0.858875,-0.512185,0,-0.858875,-0.512185,0,-0.858875,-0.512185,0,-0.729584,-0.683891,0,-0.729584,-0.683891,0,-0.729584,-0.683891,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.561545,-0.827446,0,-0.561545,-0.827446,0,-0.561545,-0.827446,0,-0.561541,-0.827449,0,-0.561541,-0.827449,0,-0.561541,-0.827449,0,-0.356612,-0.934253,0,-0.356612,-0.934253,0,-0.356612,-0.934253,0,-0.356612,-0.934253,0,-0.122162,-0.99251,-0.000001,-0.122162,-0.99251,-0.000001,-0.122162,-0.99251,-0.000001,-0.122167,-0.992509,0,-0.122167,-0.992509,0,-0.122167,-0.992509,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0.122164,-0.99251,0,0.122164,-0.99251,0,0.122164,-0.99251,0,0.122164,-0.99251,0,0.35664,-0.934242,-0.000001,0.35664,-0.934242,-0.000001,0.35664,-0.934242,-0.000001,0.356635,-0.934244,0,0.356635,-0.934244,0,0.356635,-0.934244,0,0.561518,-0.827465,0,0.561518,-0.827465,0,0.561518,-0.827465,0,0.561522,-0.827462,0,0.561522,-0.827462,0,0.561522,-0.827462,0,0.729586,-0.683889,0,0.729586,-0.683889,0,0.729586,-0.683889,0,0.729584,-0.683891,0,0.729584,-0.683891,0,0.729584,-0.683891,0,0.858885,-0.512168,0,0.858885,-0.512168,0,0.858885,-0.512168,0,0.858887,-0.512166,0,0.858887,-0.512166,0,0.858887,-0.512166,0,0.9481,-0.317973,0,0.9481,-0.317973,0,0.9481,-0.317973,0,0.9481,-0.317973,0,0.994203,-0.107523,0,0.994203,-0.107523,0,0.994203,-0.107523,0,0.994203,-0.107523,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.948086,0.318013,0,0.948086,0.318013,0,0.948086,0.318013,0,0.948086,0.318013,0,0.858914,0.51212,0,0.858914,0.51212,0,0.858914,0.51212,0,0.858914,0.51212,0,0.729569,0.683907,0,0.729569,0.683907,0,0.729569,0.683907,0,0.729569,0.683907,0,0.561541,0.827449,0.000001,0.561541,0.827449,0.000001,0.561541,0.827449,0.000001,0.561533,0.827455,0,0.561533,0.827455,0,0.561533,0.827455,0,0.356612,0.934253,0,0.356612,0.934253,0,0.356612,0.934253,0,0.356622,0.934249,0.000001,0.356622,0.934249,0.000001,0.356622,0.934249,0.000001,0.12217,0.992509,0,0.12217,0.992509,0,0.12217,0.992509,0,0.12217,0.992509,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122145,0.992512,0,-0.122145,0.992512,0,-0.122145,0.992512,0,-0.122145,0.992512,0,-0.356601,0.934257,0.000001,-0.356601,0.934257,0.000001,-0.356601,0.934257,0.000001,-0.356612,0.934253,0,-0.356612,0.934253,0,-0.356612,0.934253,0,-0.561565,0.827433,0,-0.561565,0.827433,0,-0.561565,0.827433,0,-0.561557,0.827438,0.000001,-0.561557,0.827438,0.000001,-0.561557,0.827438,0.000001,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.858917,0.512115,0,-0.858917,0.512115,0,-0.858917,0.512115,0,-0.858918,0.512113,0,-0.858918,0.512113,0,-0.858918,0.512113,0,-0.948078,0.318038,0,-0.948078,0.318038,0,-0.948078,0.318038,0,-0.948077,0.31804,0,-0.948077,0.31804,0,-0.948077,0.31804,0,-0.994207,0.107478,0,-0.994207,0.107478,0,-0.994207,0.107478,0,-0.994207,0.107478,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-0.994203,-0.107523,0,-0.994203,-0.107523,0,-0.994203,-0.107523,0,-0.994203,-0.107523,0,-0.9481,-0.317973,0,-0.9481,-0.317973,0,-0.9481,-0.317973,0,-0.9481,-0.317973,0,-0.858895,-0.512152,0,-0.858895,-0.512152,0,-0.858895,-0.512152,0,-0.858895,-0.512152,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.561508,-0.827471,0,-0.561508,-0.827471,0,-0.561508,-0.827471,0,-0.561512,-0.827469,0,-0.561512,-0.827469,0,-0.561512,-0.827469,0,-0.356635,-0.934244,-0.000001,-0.356635,-0.934244,-0.000001,-0.356635,-0.934244,-0.000001,-0.356635,-0.934244,-0.000001,-0.122167,-0.992509,0,-0.122167,-0.992509,0,-0.122167,-0.992509,0,-0.122162,-0.99251,-0.000001,-0.122162,-0.99251,-0.000001,-0.122162,-0.99251,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0,-1,0,0,-1,0,0.122159,-0.992511,0,0.122159,-0.992511,0,0.122159,-0.992511,0,0.122164,-0.99251,-0.000001,0.122164,-0.99251,-0.000001,0.122164,-0.99251,-0.000001,0.356651,-0.934238,0,0.356651,-0.934238,0,0.356651,-0.934238,0,0.356651,-0.934238,0,0.561522,-0.827462,0,0.561522,-0.827462,0,0.561522,-0.827462,0,0.561518,-0.827465,0,0.561518,-0.827465,0,0.561518,-0.827465,0,0.729584,-0.683891,0,0.729584,-0.683891,0,0.729584,-0.683891,0,0.729586,-0.683889,0,0.729586,-0.683889,0,0.729586,-0.683889,0,0.858876,-0.512183,0,0.858876,-0.512183,0,0.858876,-0.512183,0,0.858875,-0.512185,0,0.858875,-0.512185,0,0.858875,-0.512185,0,0.948113,-0.317933,0,0.948113,-0.317933,0,0.948113,-0.317933,0,0.948113,-0.317933,0,0.9942,-0.107545,0,0.9942,-0.107545,0,0.9942,-0.107545,0,0.9942,-0.107544,0,0.9942,-0.107544,0,0.9942,-0.107544,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994203,0.107521,0,0.994203,0.107521,0,0.994203,0.107521,0,0.994203,0.107521,0,0.948093,0.317993,0,0.948093,0.317993,0,0.948093,0.317993,0,0.948093,0.317993,0,0.858894,0.512154,0,0.858894,0.512154,0,0.858894,0.512154,0,0.858894,0.512154,0,0.729581,0.683894,0,0.729581,0.683894,0,0.729581,0.683894,0,0.729581,0.683894,0,0.561548,0.827444,0,0.561548,0.827444,0,0.561548,0.827444,0,0.561548,0.827444,0,0.356622,0.934249,0,0.356622,0.934249,0,0.356622,0.934249,0,0.356622,0.934249,0,0.122156,0.992511,0,0.122156,0.992511,0,0.122156,0.992511,0,0.122156,0.992511,0,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0,0,1,0,0,1,0,-0.122156,0.992511,0,-0.122156,0.992511,0,-0.122156,0.992511,0,-0.122145,0.992512,0.000001,-0.122145,0.992512,0.000001,-0.122145,0.992512,0.000001,-0.356609,0.934254,0,-0.356609,0.934254,0,-0.356609,0.934254,0,-0.356609,0.934254,0,-0.561561,0.827435,0,-0.561561,0.827435,0,-0.561561,0.827435,0,-0.561565,0.827433,0,-0.561565,0.827433,0,-0.561565,0.827433,0,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.858898,0.512146,0,-0.858898,0.512146,0,-0.858898,0.512146,0,-0.858898,0.512146,0,-0.948098,0.317978,0,-0.948098,0.317978,0,-0.948098,0.317978,0,-0.948098,0.31798,0,-0.948098,0.31798,0,-0.948098,0.31798,0,-0.9942,0.107543,0,-0.9942,0.107543,0,-0.9942,0.107543,0,-0.9942,0.107542,0,-0.9942,0.107542,0,-0.9942,0.107542,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-0.994205,-0.107502,0,-0.994205,-0.107502,0,-0.994205,-0.107502,0,-0.994205,-0.107501,0,-0.994205,-0.107501,0,-0.994205,-0.107501,0,-0.9481,-0.317973,0,-0.9481,-0.317973,0,-0.9481,-0.317973,0,-0.9481,-0.317973,0,-0.858895,-0.512152,0,-0.858895,-0.512152,0,-0.858895,-0.512152,0,-0.858895,-0.512152,0,-0.729575,-0.683901,0,-0.729575,-0.683901,0,-0.729575,-0.683901,0,-0.729572,-0.683904,0,-0.729572,-0.683904,0,-0.729572,-0.683904,0,-0.561545,-0.827446,0,-0.561545,-0.827446,0,-0.561545,-0.827446,0,-0.561545,-0.827446,0,-0.356619,-0.93425,0,-0.356619,-0.93425,0,-0.356619,-0.93425,0,-0.356619,-0.93425,0,-0.122159,-0.992511,0,-0.122159,-0.992511,0,-0.122159,-0.992511,0,-0.122159,-0.992511,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122166,-0.99251,0,0.122166,-0.99251,0,0.122166,-0.99251,0,0.122166,-0.99251,0,0.356643,-0.934241,0,0.356643,-0.934241,0,0.356643,-0.934241,0,0.356643,-0.934241,0,0.561507,-0.827472,0,0.561507,-0.827472,0,0.561507,-0.827472,0,0.561507,-0.827472,0,0.729581,-0.683895,0,0.729581,-0.683895,0,0.729581,-0.683895,0,0.729581,-0.683895,0,0.85891,-0.512126,0,0.85891,-0.512126,0,0.85891,-0.512126,0,0.85891,-0.512126,0,0.948096,-0.317983,0,0.948096,-0.317983,0,0.948096,-0.317983,0,0.948096,-0.317983,0,0.9942,-0.107544,0,0.9942,-0.107544,0,0.9942,-0.107544,0,0.9942,-0.107545,0,0.9942,-0.107545,0,0.9942,-0.107545,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994202,0.107532,0,0.994202,0.107532,0,0.994202,0.107532,0,0.994202,0.107532,0,0.948093,0.317993,0,0.948093,0.317993,0,0.948093,0.317993,0,0.948093,0.317993,0,0.858892,0.512157,0,0.858892,0.512157,0,0.858892,0.512157,0,0.858892,0.512157,0,0.729598,0.683876,0,0.729598,0.683876,0,0.729598,0.683876,0,0.729598,0.683876,0,0.561531,0.827456,0,0.561531,0.827456,0,0.561531,0.827456,0,0.561531,0.827456,0,0.356626,0.934247,0,0.356626,0.934247,0,0.356626,0.934247,0,0.356626,0.934247,0,0.122166,0.99251,0,0.122166,0.99251,0,0.122166,0.99251,0,0.122166,0.99251,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122143,0.992512,0.000001,-0.122143,0.992512,0.000001,-0.122143,0.992512,0.000001,-0.122155,0.992511,0,-0.122155,0.992511,0,-0.122155,0.992511,0,-0.356609,0.934254,0.000001,-0.356609,0.934254,0.000001,-0.356609,0.934254,0.000001,-0.356609,0.934254,0.000001,-0.561565,0.827433,0,-0.561565,0.827433,0,-0.561565,0.827433,0,-0.561561,0.827435,0.000001,-0.561561,0.827435,0.000001,-0.561561,0.827435,0.000001,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.858908,0.512129,0,-0.858908,0.512129,0,-0.858908,0.512129,0,-0.858908,0.512129,0,-0.948095,0.317988,0,-0.948095,0.317988,0,-0.948095,0.317988,0,-0.948095,0.317988,0,-0.9942,0.107542,0,-0.9942,0.107542,0,-0.9942,0.107542,0,-0.9942,0.107542,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994203,-0.107523,0,-0.994203,-0.107523,0,-0.994203,-0.107523,0,-0.994203,-0.107523,0,-0.9481,-0.317973,0,-0.9481,-0.317973,0,-0.9481,-0.317973,0,-0.9481,-0.317973,0,-0.85889,-0.51216,0,-0.85889,-0.51216,0,-0.85889,-0.51216,0,-0.85889,-0.51216,0,-0.729584,-0.683891,0,-0.729584,-0.683891,0,-0.729584,-0.683891,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.561539,-0.82745,0,-0.561539,-0.82745,0,-0.561539,-0.82745,0,-0.561535,-0.827453,0,-0.561535,-0.827453,0,-0.561535,-0.827453,0,-0.356619,-0.93425,0,-0.356619,-0.93425,0,-0.356619,-0.93425,0,-0.356619,-0.93425,0,-0.122167,-0.992509,0,-0.122167,-0.992509,0,-0.122167,-0.992509,0,-0.122167,-0.992509,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0,-1,0,0,-1,0,0.122162,-0.99251,0,0.122162,-0.99251,0,0.122162,-0.99251,0,0.122167,-0.992509,-0.000001,0.122167,-0.992509,-0.000001,0.122167,-0.992509,-0.000001,0.35664,-0.934242,-0.000001,0.35664,-0.934242,-0.000001,0.35664,-0.934242,-0.000001,0.356635,-0.934244,0,0.356635,-0.934244,0,0.356635,-0.934244,0,0.561512,-0.827469,0,0.561512,-0.827469,0,0.561512,-0.827469,0,0.561516,-0.827466,0,0.561516,-0.827466,0,0.561516,-0.827466,0,0.729592,-0.683882,0,0.729592,-0.683882,0,0.729592,-0.683882,0,0.72959,-0.683885,0,0.72959,-0.683885,0,0.72959,-0.683885,0,0.858895,-0.512152,0,0.858895,-0.512152,0,0.858895,-0.512152,0,0.858895,-0.512152,0,0.948096,-0.317983,0,0.948096,-0.317983,0,0.948096,-0.317983,0,0.948097,-0.317981,0,0.948097,-0.317981,0,0.948097,-0.317981,0,0.994201,-0.107534,0,0.994201,-0.107534,0,0.994201,-0.107534,0,0.994201,-0.107534,0,1,0,0,1,0,0,1,0,0,1,0,0,0.9942,0.107542,0,0.9942,0.107542,0,0.9942,0.107542,0,0.9942,0.107543,0,0.9942,0.107543,0,0.9942,0.107543,0,0.948096,0.317983,0,0.948096,0.317983,0,0.948096,0.317983,0,0.948097,0.317983,0,0.948097,0.317983,0,0.948097,0.317983,0,0.858897,0.512148,0,0.858897,0.512148,0,0.858897,0.512148,0,0.858899,0.512146,0,0.858899,0.512146,0,0.858899,0.512146,0,0.729581,0.683894,0,0.729581,0.683894,0,0.729581,0.683894,0,0.729581,0.683894,0,0.561541,0.827449,0.000001,0.561541,0.827449,0.000001,0.561541,0.827449,0.000001,0.561533,0.827455,0,0.561533,0.827455,0,0.561533,0.827455,0,0.356616,0.934251,0,0.356616,0.934251,0,0.356616,0.934251,0,0.356626,0.934247,0.000001,0.356626,0.934247,0.000001,0.356626,0.934247,0.000001,0.122166,0.99251,0,0.122166,0.99251,0,0.122166,0.99251,0,0.122166,0.99251,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122145,0.992512,0,-0.122145,0.992512,0,-0.122145,0.992512,0,-0.122145,0.992512,0,-0.356611,0.934253,0,-0.356611,0.934253,0,-0.356611,0.934253,0,-0.356611,0.934253,0,-0.561554,0.82744,0,-0.561554,0.82744,0,-0.561554,0.82744,0,-0.561554,0.82744,0,-0.729587,0.683888,0,-0.729587,0.683888,0,-0.729587,0.683888,0,-0.729587,0.683888,0,-0.858898,0.512146,0,-0.858898,0.512146,0,-0.858898,0.512146,0,-0.858898,0.512146,0,-0.948095,0.317988,0,-0.948095,0.317988,0,-0.948095,0.317988,0,-0.948095,0.317988,0,-0.994203,0.107521,0,-0.994203,0.107521,0,-0.994203,0.107521,0,-0.994203,0.107521,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994203,-0.107523,0,-0.994203,-0.107523,0,-0.994203,-0.107523,0,-0.994203,-0.107523,0,-0.9481,-0.317973,0,-0.9481,-0.317973,0,-0.9481,-0.317973,0,-0.9481,-0.317973,0,-0.858885,-0.512168,0,-0.858885,-0.512168,0,-0.858885,-0.512168,0,-0.858887,-0.512166,0,-0.858887,-0.512166,0,-0.858887,-0.512166,0,-0.729592,-0.683882,0,-0.729592,-0.683882,0,-0.729592,-0.683882,0,-0.72959,-0.683885,0,-0.72959,-0.683885,0,-0.72959,-0.683885,0,-0.561535,-0.827453,0,-0.561535,-0.827453,0,-0.561535,-0.827453,0,-0.561539,-0.82745,0,-0.561539,-0.82745,0,-0.561539,-0.82745,0,-0.356623,-0.934248,-0.000001,-0.356623,-0.934248,-0.000001,-0.356623,-0.934248,-0.000001,-0.356623,-0.934248,-0.000001,-0.122165,-0.99251,0,-0.122165,-0.99251,0,-0.122165,-0.99251,0,-0.122159,-0.99251,-0.000001,-0.122159,-0.99251,-0.000001,-0.122159,-0.99251,-0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122167,-0.99251,0,0.122167,-0.99251,0,0.122167,-0.99251,0,0.122167,-0.99251,0,0.356633,-0.934245,0,0.356633,-0.934245,0,0.356633,-0.934245,0,0.356633,-0.934245,0,0.561527,-0.827458,0,0.561527,-0.827458,0,0.561527,-0.827458,0,0.561523,-0.827461,0,0.561523,-0.827461,0,0.561523,-0.827461,0,0.729584,-0.683891,0,0.729584,-0.683891,0,0.729584,-0.683891,0,0.729586,-0.683889,0,0.729586,-0.683889,0,0.729586,-0.683889,0,0.858899,-0.512145,0,0.858899,-0.512145,0,0.858899,-0.512145,0,0.858898,-0.512147,0,0.858898,-0.512147,0,0.858898,-0.512147,0,0.948094,-0.31799,0,0.948094,-0.31799,0,0.948094,-0.31799,0,0.948095,-0.317988,0,0.948095,-0.317988,0,0.948095,-0.317988,0,0.994202,-0.107528,0,0.994202,-0.107528,0,0.994202,-0.107528,0,0.994202,-0.107528,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994202,0.107526,0,0.994202,0.107526,0,0.994202,0.107526,0,0.994202,0.107526,0,0.948095,0.317988,0,0.948095,0.317988,0,0.948095,0.317988,0,0.948095,0.317988,0,0.858899,0.512146,0,0.858899,0.512146,0,0.858899,0.512146,0,0.858899,0.512146,0,0.729581,0.683894,0,0.729581,0.683894,0,0.729581,0.683894,0,0.729581,0.683894,0,0.561528,0.827457,0,0.561528,0.827457,0,0.561528,0.827457,0,0.561532,0.827455,0,0.561532,0.827455,0,0.561532,0.827455,0,0.356628,0.934247,0,0.356628,0.934247,0,0.356628,0.934247,0,0.356628,0.934247,0,0.122155,0.992511,0,0.122155,0.992511,0,0.122155,0.992511,0,0.122155,0.992511,0,0,1,0,0,1,0,0,1,0,0,1,0.000001,0,1,0.000001,0,1,0.000001,-0.122144,0.992512,0,-0.122144,0.992512,0,-0.122144,0.992512,0,-0.122144,0.992512,0,-0.356606,0.934255,0,-0.356606,0.934255,0,-0.356606,0.934255,0,-0.356606,0.934255,0,-0.561561,0.827435,0,-0.561561,0.827435,0,-0.561561,0.827435,0,-0.561561,0.827435,0,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.729581,0.683894,0,-0.8589,0.512143,0,-0.8589,0.512143,0,-0.8589,0.512143,0,-0.858902,0.51214,0,-0.858902,0.51214,0,-0.858902,0.51214,0,-0.948093,0.317993,0,-0.948093,0.317993,0,-0.948093,0.317993,0,-0.948092,0.317995,0,-0.948092,0.317995,0,-0.948092,0.317995,0,-0.994203,0.107521,0,-0.994203,0.107521,0,-0.994203,0.107521,0,-0.994203,0.107521,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994203,-0.107523,0,-0.994203,-0.107523,0,-0.994203,-0.107523,0,-0.994203,-0.107523,0,-0.948094,-0.31799,0,-0.948094,-0.31799,0,-0.948094,-0.31799,0,-0.948094,-0.31799,0,-0.858899,-0.512145,0,-0.858899,-0.512145,0,-0.858899,-0.512145,0,-0.858898,-0.512147,0,-0.858898,-0.512147,0,-0.858898,-0.512147,0,-0.729585,-0.68389,0,-0.729585,-0.68389,0,-0.729585,-0.68389,0,-0.729585,-0.68389,0,-0.561538,-0.827451,0,-0.561538,-0.827451,0,-0.561538,-0.827451,0,-0.561538,-0.827451,0,-0.356618,-0.93425,0,-0.356618,-0.93425,0,-0.356618,-0.93425,0,-0.356618,-0.93425,0,-0.122161,-0.99251,-0.000001,-0.122161,-0.99251,-0.000001,-0.122161,-0.99251,-0.000001,-0.122166,-0.99251,0,-0.122166,-0.99251,0,-0.122166,-0.99251,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0.122166,-0.99251,-0.000001,0.122166,-0.99251,-0.000001,0.122166,-0.99251,-0.000001,0.122161,-0.99251,0,0.122161,-0.99251,0,0.122161,-0.99251,0,0.356632,-0.934245,0,0.356632,-0.934245,0,0.356632,-0.934245,0,0.356637,-0.934243,-0.000001,0.356637,-0.934243,-0.000001,0.356637,-0.934243,-0.000001,0.561526,-0.827459,0,0.561526,-0.827459,0,0.561526,-0.827459,0,0.561526,-0.827459,0,0.729586,-0.683889,0,0.729586,-0.683889,0,0.729586,-0.683889,0,0.729586,-0.683889,0,0.8589,-0.512144,0,0.8589,-0.512144,0,0.8589,-0.512144,0,0.8589,-0.512144,0,0.948093,-0.317992,0,0.948093,-0.317992,0,0.948093,-0.317992,0,0.948093,-0.317992,0,0.994203,-0.107522,0,0.994203,-0.107522,0,0.994203,-0.107522,0,0.994203,-0.107523,0,0.994203,-0.107523,0,0.994203,-0.107523,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994203,0.107519,0,0.994203,0.107519,0,0.994203,0.107519,0,0.994203,0.107519,0,0.948095,0.317986,0,0.948095,0.317986,0,0.948095,0.317986,0,0.948095,0.317986,0,0.858895,0.512152,0,0.858895,0.512152,0,0.858895,0.512152,0,0.858895,0.512152,0,0.729582,0.683894,0,0.729582,0.683894,0,0.729582,0.683894,0,0.729582,0.683894,0,0.561526,0.827459,0,0.561526,0.827459,0,0.561526,0.827459,0,0.56153,0.827457,0,0.56153,0.827457,0,0.56153,0.827457,0,0.356629,0.934246,0,0.356629,0.934246,0,0.356629,0.934246,0,0.356629,0.934246,0,0.122166,0.99251,0.000001,0.122166,0.99251,0.000001,0.122166,0.99251,0.000001,0.122155,0.992511,0,0.122155,0.992511,0,0.122155,0.992511,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122155,0.992511,0,-0.122155,0.992511,0,-0.122155,0.992511,0,-0.122155,0.992511,0,-0.356609,0.934254,0,-0.356609,0.934254,0,-0.356609,0.934254,0,-0.356609,0.934254,0,-0.561551,0.827442,0,-0.561551,0.827442,0,-0.561551,0.827442,0,-0.561551,0.827442,0,-0.729585,0.683891,0,-0.729585,0.683891,0,-0.729585,0.683891,0,-0.729585,0.683891,0,-0.858898,0.512146,0,-0.858898,0.512146,0,-0.858898,0.512146,0,-0.858898,0.512146,0,-0.948093,0.317993,0,-0.948093,0.317993,0,-0.948093,0.317993,0,-0.948093,0.317993,0,-0.994203,0.107519,0,-0.994203,0.107519,0,-0.994203,0.107519,0,-0.994203,0.107519,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994202,-0.107524,0,-0.994202,-0.107524,0,-0.994202,-0.107524,0,-0.994202,-0.107525,0,-0.994202,-0.107525,0,-0.994202,-0.107525,0,-0.948092,-0.317997,0,-0.948092,-0.317997,0,-0.948092,-0.317997,0,-0.948092,-0.317997,0,-0.858901,-0.512141,0,-0.858901,-0.512141,0,-0.858901,-0.512141,0,-0.858901,-0.512141,0,-0.729587,-0.683888,0,-0.729587,-0.683888,0,-0.729587,-0.683888,0,-0.729587,-0.683888,0,-0.561539,-0.82745,0,-0.561539,-0.82745,0,-0.561539,-0.82745,0,-0.561543,-0.827448,0,-0.561543,-0.827448,0,-0.561543,-0.827448,0,-0.356614,-0.934252,-0.000001,-0.356614,-0.934252,-0.000001,-0.356614,-0.934252,-0.000001,-0.356614,-0.934252,-0.000001,-0.122167,-0.992509,0,-0.122167,-0.992509,0,-0.122167,-0.992509,0,-0.122162,-0.99251,-0.000001,-0.122162,-0.99251,-0.000001,-0.122162,-0.99251,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0,-1,0,0,-1,0,0.122159,-0.992511,0,0.122159,-0.992511,0,0.122159,-0.992511,0,0.122164,-0.99251,-0.000001,0.122164,-0.99251,-0.000001,0.122164,-0.99251,-0.000001,0.356635,-0.934244,0,0.356635,-0.934244,0,0.356635,-0.934244,0,0.356635,-0.934244,0,0.56153,-0.827456,0,0.56153,-0.827456,0,0.56153,-0.827456,0,0.56153,-0.827456,0,0.729586,-0.683889,0,0.729586,-0.683889,0,0.729586,-0.683889,0,0.729584,-0.683891,0,0.729584,-0.683891,0,0.729584,-0.683891,0,0.858903,-0.512139,0,0.858903,-0.512139,0,0.858903,-0.512139,0,0.858903,-0.512139,0,0.948091,-0.317998,0,0.948091,-0.317998,0,0.948091,-0.317998,0,0.948092,-0.317996,0,0.948092,-0.317996,0,0.948092,-0.317996,0,0.994203,-0.107518,0,0.994203,-0.107518,0,0.994203,-0.107518,0,0.994203,-0.107518,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994205,0.1075,0,0.994205,0.1075,0,0.994205,0.1075,0,0.994205,0.1075,0,0.948091,0.317998,0,0.948091,0.317998,0,0.948091,0.317998,0,0.948091,0.317998,0,0.858894,0.512154,0,0.858894,0.512154,0,0.858894,0.512154,0,0.858892,0.512157,0,0.858892,0.512157,0,0.858892,0.512157,0,0.729581,0.683894,0,0.729581,0.683894,0,0.729581,0.683894,0,0.729581,0.683894,0,0.561532,0.827455,0.000001,0.561532,0.827455,0.000001,0.561532,0.827455,0.000001,0.561528,0.827457,0,0.561528,0.827457,0,0.561528,0.827457,0,0.356623,0.934248,0,0.356623,0.934248,0,0.356623,0.934248,0,0.356634,0.934244,0.000001,0.356634,0.934244,0.000001,0.356634,0.934244,0.000001,0.122165,0.99251,0,0.122165,0.99251,0,0.122165,0.99251,0,0.122165,0.99251,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122144,0.992512,0,-0.122144,0.992512,0,-0.122144,0.992512,0,-0.122144,0.992512,0,-0.356613,0.934252,0,-0.356613,0.934252,0,-0.356613,0.934252,0,-0.356613,0.934252,0,-0.561559,0.827436,0,-0.561559,0.827436,0,-0.561559,0.827436,0,-0.561559,0.827436,0,-0.729572,0.683904,0,-0.729572,0.683904,0,-0.729572,0.683904,0,-0.729572,0.683904,0,-0.858903,0.512138,0,-0.858903,0.512138,0,-0.858903,0.512138,0,-0.858903,0.512138,0,-0.948096,0.317983,0,-0.948096,0.317983,0,-0.948096,0.317983,0,-0.948096,0.317983,0,-0.994202,0.107526,0,-0.994202,0.107526,0,-0.994202,0.107526,0,-0.994202,0.107526,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994204,-0.107512,0,-0.994204,-0.107512,0,-0.994204,-0.107512,0,-0.994204,-0.107513,0,-0.994204,-0.107513,0,-0.994204,-0.107513,0,-0.948095,-0.317988,0,-0.948095,-0.317988,0,-0.948095,-0.317988,0,-0.948095,-0.317988,0,-0.85889,-0.51216,0,-0.85889,-0.51216,0,-0.85889,-0.51216,0,-0.858892,-0.512157,0,-0.858892,-0.512157,0,-0.858892,-0.512157,0,-0.729595,-0.683879,0,-0.729595,-0.683879,0,-0.729595,-0.683879,0,-0.729593,-0.683882,0,-0.729593,-0.683882,0,-0.729593,-0.683882,0,-0.561538,-0.827451,0,-0.561538,-0.827451,0,-0.561538,-0.827451,0,-0.561542,-0.827448,0,-0.561542,-0.827448,0,-0.561542,-0.827448,0,-0.356612,-0.934253,-0.000001,-0.356612,-0.934253,-0.000001,-0.356612,-0.934253,-0.000001,-0.356612,-0.934253,-0.000001,-0.122167,-0.992509,0,-0.122167,-0.992509,0,-0.122167,-0.992509,0,-0.122162,-0.99251,-0.000001,-0.122162,-0.99251,-0.000001,-0.122162,-0.99251,-0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122166,-0.99251,0,0.122166,-0.99251,0,0.122166,-0.99251,0,0.122166,-0.99251,0,0.356631,-0.934245,0,0.356631,-0.934245,0,0.356631,-0.934245,0,0.356631,-0.934245,0,0.561538,-0.827451,0,0.561538,-0.827451,0,0.561538,-0.827451,0,0.561534,-0.827454,0,0.561534,-0.827454,0,0.561534,-0.827454,0,0.72959,-0.683885,0,0.72959,-0.683885,0,0.72959,-0.683885,0,0.729592,-0.683882,0,0.729592,-0.683882,0,0.729592,-0.683882,0,0.858895,-0.512152,0,0.858895,-0.512152,0,0.858895,-0.512152,0,0.858895,-0.512152,0,0.948093,-0.317993,0,0.948093,-0.317993,0,0.948093,-0.317993,0,0.948093,-0.317993,0,0.994201,-0.107533,0,0.994201,-0.107533,0,0.994201,-0.107533,0,0.994201,-0.107534,0,0.994201,-0.107534,0,0.994201,-0.107534,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994204,0.10751,0,0.994204,0.10751,0,0.994204,0.10751,0,0.994204,0.107511,0,0.994204,0.107511,0,0.994204,0.107511,0,0.948093,0.317993,0,0.948093,0.317993,0,0.948093,0.317993,0,0.948093,0.317993,0,0.858892,0.512157,0,0.858892,0.512157,0,0.858892,0.512157,0,0.858894,0.512154,0,0.858894,0.512154,0,0.858894,0.512154,0,0.729569,0.683907,0,0.729569,0.683907,0,0.729569,0.683907,0,0.729569,0.683907,0,0.561546,0.827445,0.000001,0.561546,0.827445,0.000001,0.561546,0.827445,0.000001,0.561538,0.827451,0,0.561538,0.827451,0,0.561538,0.827451,0,0.356619,0.93425,0,0.356619,0.93425,0,0.356619,0.93425,0,0.35663,0.934246,0.000001,0.35663,0.934246,0.000001,0.35663,0.934246,0.000001,0.122166,0.99251,0,0.122166,0.99251,0,0.122166,0.99251,0,0.122166,0.99251,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122143,0.992512,0,-0.122143,0.992512,0,-0.122143,0.992512,0,-0.122143,0.992512,0,-0.356613,0.934252,0,-0.356613,0.934252,0,-0.356613,0.934252,0,-0.356613,0.934252,0,-0.561539,0.82745,0,-0.561539,0.82745,0,-0.561539,0.82745,0,-0.561543,0.827448,0,-0.561543,0.827448,0,-0.561543,0.827448,0,-0.729595,0.683879,0,-0.729595,0.683879,0,-0.729595,0.683879,0,-0.729593,0.683882,0,-0.729593,0.683882,0,-0.729593,0.683882,0,-0.858902,0.512141,0,-0.858902,0.512141,0,-0.858902,0.512141,0,-0.858902,0.512141,0,-0.948088,0.318008,0,-0.948088,0.318008,0,-0.948088,0.318008,0,-0.948088,0.318008,0,-0.994203,0.107521,0,-0.994203,0.107521,0,-0.994203,0.107521,0,-0.994203,0.107521,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994201,-0.107533,0,-0.994201,-0.107533,0,-0.994201,-0.107533,0,-0.994201,-0.107533,0,-0.948093,-0.317995,0,-0.948093,-0.317995,0,-0.948093,-0.317995,0,-0.948093,-0.317993,0,-0.948093,-0.317993,0,-0.948093,-0.317993,0,-0.858892,-0.512157,0,-0.858892,-0.512157,0,-0.858892,-0.512157,0,-0.85889,-0.51216,0,-0.85889,-0.51216,0,-0.85889,-0.51216,0,-0.72959,-0.683885,0,-0.72959,-0.683885,0,-0.72959,-0.683885,0,-0.729592,-0.683882,0,-0.729592,-0.683882,0,-0.729592,-0.683882,0,-0.561561,-0.827435,0,-0.561561,-0.827435,0,-0.561561,-0.827435,0,-0.561557,-0.827438,0,-0.561557,-0.827438,0,-0.561557,-0.827438,0,-0.356596,-0.934259,0,-0.356596,-0.934259,0,-0.356596,-0.934259,0,-0.356596,-0.934259,0,-0.12217,-0.992509,0,-0.12217,-0.992509,0,-0.12217,-0.992509,0,-0.12217,-0.992509,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122164,-0.99251,-0.000001,0.122164,-0.99251,-0.000001,0.122164,-0.99251,-0.000001,0.122159,-0.992511,0,0.122159,-0.992511,0,0.122159,-0.992511,0,0.356631,-0.934245,0,0.356631,-0.934245,0,0.356631,-0.934245,0,0.356636,-0.934243,-0.000001,0.356636,-0.934243,-0.000001,0.356636,-0.934243,-0.000001,0.561545,-0.827446,0,0.561545,-0.827446,0,0.561545,-0.827446,0,0.561545,-0.827446,0,0.729575,-0.683901,0,0.729575,-0.683901,0,0.729575,-0.683901,0,0.729575,-0.683901,0,0.8589,-0.512143,0,0.8589,-0.512143,0,0.8589,-0.512143,0,0.8589,-0.512143,0,0.948086,-0.318013,0,0.948086,-0.318013,0,0.948086,-0.318013,0,0.948086,-0.318013,0,0.994206,-0.107491,0,0.994206,-0.107491,0,0.994206,-0.107491,0,0.994206,-0.107491,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994206,0.107489,0,0.994206,0.107489,0,0.994206,0.107489,0,0.994206,0.107489,0,0.948086,0.318013,0,0.948086,0.318013,0,0.948086,0.318013,0,0.948086,0.318013,0,0.858889,0.512163,0,0.858889,0.512163,0,0.858889,0.512163,0,0.858889,0.512163,0,0.729587,0.683888,0,0.729587,0.683888,0,0.729587,0.683888,0,0.729587,0.683888,0,0.561537,0.827452,0,0.561537,0.827452,0,0.561537,0.827452,0,0.561537,0.827452,0,0.356634,0.934244,0,0.356634,0.934244,0,0.356634,0.934244,0,0.356634,0.934244,0,0.122155,0.992511,0,0.122155,0.992511,0,0.122155,0.992511,0,0.122155,0.992511,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122145,0.992512,0.000001,-0.122145,0.992512,0.000001,-0.122145,0.992512,0.000001,-0.122156,0.992511,0,-0.122156,0.992511,0,-0.122156,0.992511,0,-0.356623,0.934248,0,-0.356623,0.934248,0,-0.356623,0.934248,0,-0.356613,0.934252,0.000001,-0.356613,0.934252,0.000001,-0.356613,0.934252,0.000001,-0.56155,0.827443,0,-0.56155,0.827443,0,-0.56155,0.827443,0,-0.56155,0.827443,0,-0.729575,0.683901,0,-0.729575,0.683901,0,-0.729575,0.683901,0,-0.729575,0.683901,0,-0.858903,0.512138,0,-0.858903,0.512138,0,-0.858903,0.512138,0,-0.858903,0.512138,0,-0.948101,0.31797,0,-0.948101,0.31797,0,-0.948101,0.31797,0,-0.948101,0.317968,0,-0.948101,0.317968,0,-0.948101,0.317968,0,-0.9942,0.107542,0,-0.9942,0.107542,0,-0.9942,0.107542,0,-0.9942,0.107543,0,-0.9942,0.107543,0,-0.9942,0.107543,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994201,-0.107533,0,-0.994201,-0.107533,0,-0.994201,-0.107533,0,-0.994201,-0.107534,0,-0.994201,-0.107534,0,-0.994201,-0.107534,0,-0.948096,-0.317983,0,-0.948096,-0.317983,0,-0.948096,-0.317983,0,-0.948096,-0.317983,0,-0.8589,-0.512143,0,-0.8589,-0.512143,0,-0.8589,-0.512143,0,-0.8589,-0.512143,0,-0.729598,-0.683876,0,-0.729598,-0.683876,0,-0.729598,-0.683876,0,-0.729598,-0.683876,0,-0.561524,-0.82746,0,-0.561524,-0.82746,0,-0.561524,-0.82746,0,-0.561528,-0.827458,0,-0.561528,-0.827458,0,-0.561528,-0.827458,0,-0.356619,-0.93425,-0.000001,-0.356619,-0.93425,-0.000001,-0.356619,-0.93425,-0.000001,-0.356619,-0.93425,-0.000001,-0.122166,-0.99251,0,-0.122166,-0.99251,0,-0.122166,-0.99251,0,-0.12216,-0.99251,-0.000001,-0.12216,-0.99251,-0.000001,-0.12216,-0.99251,-0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122164,-0.99251,0,0.122164,-0.99251,0,0.122164,-0.99251,0,0.122164,-0.99251,0,0.356619,-0.93425,0,0.356619,-0.93425,0,0.356619,-0.93425,0,0.356619,-0.93425,0,0.561544,-0.827447,0,0.561544,-0.827447,0,0.561544,-0.827447,0,0.561539,-0.82745,0,0.561539,-0.82745,0,0.561539,-0.82745,0,0.729584,-0.683891,0,0.729584,-0.683891,0,0.729584,-0.683891,0,0.729586,-0.683889,0,0.729586,-0.683889,0,0.729586,-0.683889,0,0.858897,-0.512149,0,0.858897,-0.512149,0,0.858897,-0.512149,0,0.858895,-0.512152,0,0.858895,-0.512152,0,0.858895,-0.512152,0,0.948093,-0.317995,0,0.948093,-0.317995,0,0.948093,-0.317995,0,0.948093,-0.317993,0,0.948093,-0.317993,0,0.948093,-0.317993,0,0.994205,-0.107501,0,0.994205,-0.107501,0,0.994205,-0.107501,0,0.994205,-0.107501,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994207,0.107478,0,0.994207,0.107478,0,0.994207,0.107478,0,0.994207,0.107478,0,0.94808,0.318033,0,0.94808,0.318033,0,0.94808,0.318033,0,0.94808,0.318033,0,0.858892,0.512157,0,0.858892,0.512157,0,0.858892,0.512157,0,0.858892,0.512157,0,0.729581,0.683894,0,0.729581,0.683894,0,0.729581,0.683894,0,0.729581,0.683894,0,0.561537,0.827452,0,0.561537,0.827452,0,0.561537,0.827452,0,0.561537,0.827452,0,0.35663,0.934246,0,0.35663,0.934246,0,0.35663,0.934246,0,0.35663,0.934246,0,0.122164,0.99251,0,0.122164,0.99251,0,0.122164,0.99251,0,0.122164,0.99251,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122187,0.992507,0,-0.122187,0.992507,0,-0.122187,0.992507,0,-0.122187,0.992507,0,-0.356594,0.934259,0,-0.356594,0.934259,0,-0.356594,0.934259,0,-0.356594,0.934259,0,-0.561538,0.827451,0,-0.561538,0.827451,0,-0.561538,0.827451,0,-0.561538,0.827451,0,-0.729578,0.683898,0,-0.729578,0.683898,0,-0.729578,0.683898,0,-0.729578,0.683898,0,-0.858898,0.512146,0,-0.858898,0.512146,0,-0.858898,0.512146,0,-0.858898,0.512146,0,-0.948105,0.317958,0,-0.948105,0.317958,0,-0.948105,0.317958,0,-0.948105,0.317958,0,-0.9942,0.107545,0,-0.9942,0.107545,0,-0.9942,0.107545,0,-0.9942,0.107544,0,-0.9942,0.107544,0,-0.9942,0.107544,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.9942,-0.107545,0,-0.9942,-0.107545,0,-0.9942,-0.107545,0,-0.9942,-0.107545,0,-0.948093,-0.317993,0,-0.948093,-0.317993,0,-0.948093,-0.317993,0,-0.948093,-0.317993,0,-0.858908,-0.512129,0,-0.858908,-0.512129,0,-0.858908,-0.512129,0,-0.858908,-0.512129,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.561541,-0.827449,0,-0.561541,-0.827449,0,-0.561541,-0.827449,0,-0.561545,-0.827446,0,-0.561545,-0.827446,0,-0.561545,-0.827446,0,-0.356606,-0.934255,0,-0.356606,-0.934255,0,-0.356606,-0.934255,0,-0.356601,-0.934257,-0.000001,-0.356601,-0.934257,-0.000001,-0.356601,-0.934257,-0.000001,-0.122176,-0.992508,0,-0.122176,-0.992508,0,-0.122176,-0.992508,0,-0.122176,-0.992508,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122164,-0.99251,0,0.122164,-0.99251,0,0.122164,-0.99251,0,0.122164,-0.99251,0,0.356606,-0.934255,0,0.356606,-0.934255,0,0.356606,-0.934255,0,0.356606,-0.934255,0,0.561583,-0.82742,0,0.561583,-0.82742,0,0.561583,-0.82742,0,0.561583,-0.82742,0,0.729575,-0.683901,0,0.729575,-0.683901,0,0.729575,-0.683901,0,0.729575,-0.683901,0,0.858895,-0.512152,0,0.858895,-0.512152,0,0.858895,-0.512152,0,0.858895,-0.512152,0,0.9481,-0.317973,0,0.9481,-0.317973,0,0.9481,-0.317973,0,0.9481,-0.317973,0,0.994203,-0.107523,0,0.994203,-0.107523,0,0.994203,-0.107523,0,0.994203,-0.107523,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994203,0.107523,0,0.994203,0.107523,0,0.994203,0.107523,0,0.994203,0.107523,0,0.94812,0.317912,0,0.94812,0.317912,0,0.94812,0.317912,0,0.94812,0.317912,0,0.858863,0.512205,0,0.858863,0.512205,0,0.858863,0.512205,0,0.858863,0.512205,0,0.729578,0.683898,0,0.729578,0.683898,0,0.729578,0.683898,0,0.729578,0.683898,0,0.561548,0.827444,0,0.561548,0.827444,0,0.561548,0.827444,0,0.561548,0.827444,0,0.356622,0.934249,0,0.356622,0.934249,0,0.356622,0.934249,0,0.356622,0.934249,0,0.122156,0.992511,0,0.122156,0.992511,0,0.122156,0.992511,0,0.122156,0.992511,0,-0.35663,0.934246,0,-0.35663,0.934246,0,-0.35663,0.934246,0,-0.35663,0.934246,0,-0.561548,0.827444,0,-0.561548,0.827444,0,-0.561548,0.827444,0,-0.561548,0.827444,0,-0.729601,0.683873,0,-0.729601,0.683873,0,-0.729601,0.683873,0,-0.729601,0.683873,0,-0.858884,0.512171,0,-0.858884,0.512171,0,-0.858884,0.512171,0,-0.858884,0.512171,0,-0.948086,0.318013,0,-0.948086,0.318013,0,-0.948086,0.318013,0,-0.948086,0.318013,0,-0.9942,0.107545,0,-0.9942,0.107545,0,-0.9942,0.107545,0,-0.9942,0.107545,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994205,-0.107501,0,-0.994205,-0.107501,0,-0.994205,-0.107501,0,-0.994205,-0.107502,0,-0.994205,-0.107502,0,-0.994205,-0.107502,0,-0.948073,-0.318053,0,-0.948073,-0.318053,0,-0.948073,-0.318053,0,-0.948073,-0.318053,0,-0.858885,-0.512168,0,-0.858885,-0.512168,0,-0.858885,-0.512168,0,-0.858885,-0.512168,0,-0.729621,-0.683851,0,-0.729621,-0.683851,0,-0.729621,-0.683851,0,-0.729621,-0.683851,0,-0.561561,-0.827435,0,-0.561561,-0.827435,0,-0.561561,-0.827435,0,-0.561561,-0.827435,0,-0.356598,-0.934258,0,-0.356598,-0.934258,0,-0.356598,-0.934258,0,-0.356598,-0.934258,0,-0.122176,-0.992508,0,-0.122176,-0.992508,0,-0.122176,-0.992508,0,-0.122176,-0.992508,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122176,-0.992508,0,0.122176,-0.992508,0,0.122176,-0.992508,0,0.122176,-0.992508,0,0.356583,-0.934264,-0.000001,0.356583,-0.934264,-0.000001,0.356583,-0.934264,-0.000001,0.356578,-0.934266,0,0.356578,-0.934266,0,0.356578,-0.934266,0,0.561552,-0.827442,0,0.561552,-0.827442,0,0.561552,-0.827442,0,0.561556,-0.827439,0,0.561556,-0.827439,0,0.561556,-0.827439,0,0.729621,-0.683851,0,0.729621,-0.683851,0,0.729621,-0.683851,0,0.729621,-0.683851,0,0.858908,-0.512129,0,0.858908,-0.512129,0,0.858908,-0.512129,0,0.858907,-0.512132,0,0.858907,-0.512132,0,0.858907,-0.512132,0,0.948073,-0.318053,0,0.948073,-0.318053,0,0.948073,-0.318053,0,0.948073,-0.318053,0,0.994205,-0.107503,0,0.994205,-0.107503,0,0.994205,-0.107503,0,0.994205,-0.107503,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994205,0.107502,0,0.994205,0.107502,0,0.994205,0.107502,0,0.994205,0.107501,0,0.994205,0.107501,0,0.994205,0.107501,0,0.948098,0.317978,0,0.948098,0.317978,0,0.948098,0.317978,0,0.948098,0.317978,0,0.858868,0.512197,0,0.858868,0.512197,0,0.858868,0.512197,0,0.858868,0.512197,0,0.729624,0.683848,0,0.729624,0.683848,0,0.729624,0.683848,0,0.729624,0.683848,0,0.561504,0.827474,0,0.561504,0.827474,0,0.561504,0.827474,0,0.561504,0.827474,0,0.356609,0.934254,0,0.356609,0.934254,0,0.356609,0.934254,0,0.356609,0.934254,0,0.122187,0.992507,0,0.122187,0.992507,0,0.122187,0.992507,0,0.122187,0.992507,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122164,0.99251,0,-0.122164,0.99251,0,-0.122164,0.99251,0,-0.122164,0.99251,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122159,0.992511,0,-0.122159,0.992511,0,-0.122159,0.992511,0,-0.122159,0.992511,0,-0.356588,0.934262,0,-0.356588,0.934262,0,-0.356588,0.934262,0,-0.356588,0.934262,0,-0.561587,0.827418,0,-0.561587,0.827418,0,-0.561587,0.827418,0,-0.561589,0.827417,0,-0.561589,0.827417,0,-0.561589,0.827417,0,-0.729585,0.68389,0,-0.729585,0.68389,0,-0.729585,0.68389,0,-0.729585,0.68389,0,-0.858906,0.512133,0,-0.858906,0.512133,0,-0.858906,0.512133,0,-0.858905,0.512135,0,-0.858905,0.512135,0,-0.858905,0.512135,0,-0.948079,0.318036,0,-0.948079,0.318036,0,-0.948079,0.318036,0,-0.948079,0.318036,0,-0.994207,0.10748,0,-0.994207,0.10748,0,-0.994207,0.10748,0,-0.994207,0.107479,0,-0.994207,0.107479,0,-0.994207,0.107479,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994205,-0.107501,0,-0.994205,-0.107501,0,-0.994205,-0.107501,0,-0.994205,-0.107501,0,-0.948105,-0.317956,0,-0.948105,-0.317956,0,-0.948105,-0.317956,0,-0.948105,-0.317956,0,-0.858877,-0.512182,0,-0.858877,-0.512182,0,-0.858877,-0.512182,0,-0.858877,-0.512182,0,-0.729597,-0.683877,0,-0.729597,-0.683877,0,-0.729597,-0.683877,0,-0.729599,-0.683875,0,-0.729599,-0.683875,0,-0.729599,-0.683875,0,-0.561543,-0.827448,0,-0.561543,-0.827448,0,-0.561543,-0.827448,0,-0.56154,-0.82745,0,-0.56154,-0.82745,0,-0.56154,-0.82745,0,-0.356619,-0.93425,0,-0.356619,-0.93425,0,-0.356619,-0.93425,0,-0.356619,-0.93425,0,-0.122156,-0.992511,-0.000001,-0.122156,-0.992511,-0.000001,-0.122156,-0.992511,-0.000001,-0.122161,-0.99251,0,-0.122161,-0.99251,0,-0.122161,-0.99251,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0.122165,-0.99251,0,0.122165,-0.99251,0,0.122165,-0.99251,0,0.122165,-0.99251,0,0.356628,-0.934247,0,0.356628,-0.934247,0,0.356628,-0.934247,0,0.356628,-0.934247,0,0.561534,-0.827454,0,0.561534,-0.827454,0,0.561534,-0.827454,0,0.561534,-0.827454,0,0.729576,-0.6839,0,0.729576,-0.6839,0,0.729576,-0.6839,0,0.729575,-0.683901,0,0.729575,-0.683901,0,0.729575,-0.683901,0,0.858906,-0.512133,0,0.858906,-0.512133,0,0.858906,-0.512133,0,0.858906,-0.512133,0,0.948093,-0.317994,0,0.948093,-0.317994,0,0.948093,-0.317994,0,0.948093,-0.317994,0,0.9942,-0.107544,0,0.9942,-0.107544,0,0.9942,-0.107544,0,0.9942,-0.107544,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,0.9942,0.107543,0,0.9942,0.107543,0,0.9942,0.107543,0,0.9942,0.107543,0,0.948085,0.318016,0,0.948085,0.318016,0,0.948085,0.318016,0,0.948085,0.318016,0,0.858923,0.512104,0,0.858923,0.512104,0,0.858923,0.512104,0,0.858923,0.512104,0,0.729588,0.683887,0,0.729588,0.683887,0,0.729588,0.683887,0,0.729588,0.683887,0,0.561537,0.827452,0,0.561537,0.827452,0,0.561537,0.827452,0,0.561537,0.827452,0,0.356611,0.934253,0,0.356611,0.934253,0,0.356611,0.934253,0,0.356611,0.934253,0,0.122167,0.99251,0,0.122167,0.99251,0,0.122167,0.99251,0,0.12217,0.992509,0,0.12217,0.992509,0,0.12217,0.992509,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122164,0.99251,0,-0.122164,0.99251,0,-0.122164,0.99251,0,-0.122162,0.99251,0,-0.122162,0.99251,0,-0.122162,0.99251,0,-0.356619,0.93425,0,-0.356619,0.93425,0,-0.356619,0.93425,0,-0.356619,0.93425,0,-0.561543,0.827448,0,-0.561543,0.827448,0,-0.561543,0.827448,0,-0.561543,0.827448,0,-0.729597,0.683878,0,-0.729597,0.683878,0,-0.729597,0.683878,0,-0.729598,0.683876,0,-0.729598,0.683876,0,-0.729598,0.683876,0,-0.858905,0.512135,0,-0.858905,0.512135,0,-0.858905,0.512135,0,-0.858905,0.512135,0,-0.948079,0.318036,0,-0.948079,0.318036,0,-0.948079,0.318036,0,-0.948079,0.318036,0,-0.994205,0.107501,0,-0.994205,0.107501,0,-0.994205,0.107501,0,-0.994205,0.107501,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994205,-0.107501,0,-0.994205,-0.107501,0,-0.994205,-0.107501,0,-0.994205,-0.107501,0,-0.948092,-0.317996,0,-0.948092,-0.317996,0,-0.948092,-0.317996,0,-0.948092,-0.317996,0,-0.858887,-0.512165,0,-0.858887,-0.512165,0,-0.858887,-0.512165,0,-0.858887,-0.512165,0,-0.729585,-0.68389,0,-0.729585,-0.68389,0,-0.729585,-0.68389,0,-0.729587,-0.683888,0,-0.729587,-0.683888,0,-0.729587,-0.683888,0,-0.561521,-0.827462,0,-0.561521,-0.827462,0,-0.561521,-0.827462,0,-0.561518,-0.827465,0,-0.561518,-0.827465,0,-0.561518,-0.827465,0,-0.356635,-0.934244,0,-0.356635,-0.934244,0,-0.356635,-0.934244,0,-0.356635,-0.934244,0,-0.12217,-0.992509,0,-0.12217,-0.992509,0,-0.12217,-0.992509,0,-0.122169,-0.992509,0,-0.122169,-0.992509,0,-0.122169,-0.992509,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122165,-0.99251,0,0.122165,-0.99251,0,0.122165,-0.99251,0,0.122165,-0.99251,0,0.35662,-0.93425,0,0.35662,-0.93425,0,0.35662,-0.93425,0,0.35662,-0.93425,0,0.561534,-0.827454,0,0.561534,-0.827454,0,0.561534,-0.827454,0,0.561534,-0.827454,0,0.729586,-0.683889,0,0.729586,-0.683889,0,0.729586,-0.683889,0,0.729586,-0.683889,0,0.858896,-0.51215,0,0.858896,-0.51215,0,0.858896,-0.51215,0,0.858896,-0.51215,0,0.948099,-0.317974,0,0.948099,-0.317974,0,0.948099,-0.317974,0,0.948099,-0.317974,0,0.9942,-0.107544,0,0.9942,-0.107544,0,0.9942,-0.107544,0,0.9942,-0.107544,0,1,0,0,1,0,0,1,0,0,1,0,0,0.9942,0.107543,0,0.9942,0.107543,0,0.9942,0.107543,0,0.9942,0.107543,0,0.948085,0.318016,0,0.948085,0.318016,0,0.948085,0.318016,0,0.948085,0.318016,0,0.858903,0.512138,0,0.858903,0.512138,0,0.858903,0.512138,0,0.858903,0.512138,0,0.729599,0.683875,0,0.729599,0.683875,0,0.729599,0.683875,0,0.729598,0.683876,0,0.729598,0.683876,0,0.729598,0.683876,0,0.561537,0.827452,0,0.561537,0.827452,0,0.561537,0.827452,0,0.561539,0.827451,0,0.561539,0.827451,0,0.561539,0.827451,0,0.356619,0.93425,0,0.356619,0.93425,0,0.356619,0.93425,0,0.356619,0.93425,0,0.122164,0.99251,0,0.122164,0.99251,0,0.122164,0.99251,0,0.122164,0.99251,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122162,0.99251,0,-0.122162,0.99251,0,-0.122162,0.99251,0,-0.122162,0.99251,0,-0.356612,0.934253,0,-0.356612,0.934253,0,-0.356612,0.934253,0,-0.356612,0.934253,0,-0.561545,0.827446,0,-0.561545,0.827446,0,-0.561545,0.827446,0,-0.561543,0.827448,0,-0.561543,0.827448,0,-0.561543,0.827448,0,-0.729597,0.683878,0,-0.729597,0.683878,0,-0.729597,0.683878,0,-0.729597,0.683878,0,-0.858905,0.512135,0,-0.858905,0.512135,0,-0.858905,0.512135,0,-0.858906,0.512133,0,-0.858906,0.512133,0,-0.858906,0.512133,0,-0.948085,0.318016,0,-0.948085,0.318016,0,-0.948085,0.318016,0,-0.948085,0.318016,0,-0.994205,0.107501,0,-0.994205,0.107501,0,-0.994205,0.107501,0,-0.994205,0.107501,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-0.9942,-0.107544,0,-0.9942,-0.107544,0,-0.9942,-0.107544,0,-0.9942,-0.107544,0,-0.948099,-0.317976,0,-0.948099,-0.317976,0,-0.948099,-0.317976,0,-0.948099,-0.317976,0,-0.858897,-0.512148,0,-0.858897,-0.512148,0,-0.858897,-0.512148,0,-0.858898,-0.512147,0,-0.858898,-0.512147,0,-0.858898,-0.512147,0,-0.729588,-0.683887,0,-0.729588,-0.683887,0,-0.729588,-0.683887,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.561529,-0.827457,0,-0.561529,-0.827457,0,-0.561529,-0.827457,0,-0.561529,-0.827457,0,-0.356619,-0.93425,0,-0.356619,-0.93425,0,-0.356619,-0.93425,0,-0.356619,-0.93425,0,-0.12217,-0.992509,0,-0.12217,-0.992509,0,-0.12217,-0.992509,0,-0.122169,-0.992509,0,-0.122169,-0.992509,0,-0.122169,-0.992509,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0,-1,0,0,-1,0,0.122164,-0.99251,0,0.122164,-0.99251,0,0.122164,-0.99251,0,0.122168,-0.992509,-0.000001,0.122168,-0.992509,-0.000001,0.122168,-0.992509,-0.000001,0.356636,-0.934244,-0.000001,0.356636,-0.934244,-0.000001,0.356636,-0.934244,-0.000001,0.356631,-0.934245,0,0.356631,-0.934245,0,0.356631,-0.934245,0,0.561517,-0.827465,0,0.561517,-0.827465,0,0.561517,-0.827465,0,0.56152,-0.827463,0,0.56152,-0.827463,0,0.56152,-0.827463,0,0.729586,-0.683889,0,0.729586,-0.683889,0,0.729586,-0.683889,0,0.729586,-0.683888,0,0.729586,-0.683888,0,0.729586,-0.683888,0,0.858896,-0.51215,0,0.858896,-0.51215,0,0.858896,-0.51215,0,0.858896,-0.51215,0,0.948103,-0.317964,0,0.948103,-0.317964,0,0.948103,-0.317964,0,0.948103,-0.317964,0,0.9942,-0.107544,0,0.9942,-0.107544,0,0.9942,-0.107544,0,0.9942,-0.107544,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994199,0.107554,0,0.994199,0.107554,0,0.994199,0.107554,0,0.994199,0.107554,0,0.948095,0.317986,0,0.948095,0.317986,0,0.948095,0.317986,0,0.948096,0.317985,0,0.948096,0.317985,0,0.948096,0.317985,0,0.858904,0.512137,0,0.858904,0.512137,0,0.858904,0.512137,0,0.858903,0.512138,0,0.858903,0.512138,0,0.858903,0.512138,0,0.729586,0.683889,0,0.729586,0.683889,0,0.729586,0.683889,0,0.729588,0.683887,0,0.729588,0.683887,0,0.729588,0.683887,0,0.561537,0.827452,0,0.561537,0.827452,0,0.561537,0.827452,0,0.561537,0.827452,0,0.35663,0.934246,0,0.35663,0.934246,0,0.35663,0.934246,0,0.356627,0.934247,0,0.356627,0.934247,0,0.356627,0.934247,0,0.122162,0.99251,0,0.122162,0.99251,0,0.122162,0.99251,0,0.122162,0.99251,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122162,0.99251,0,-0.122162,0.99251,0,-0.122162,0.99251,0,-0.122164,0.99251,0,-0.122164,0.99251,0,-0.122164,0.99251,0,-0.356616,0.934251,0,-0.356616,0.934251,0,-0.356616,0.934251,0,-0.356616,0.934251,0,-0.561559,0.827437,0,-0.561559,0.827437,0,-0.561559,0.827437,0,-0.561559,0.827437,0,-0.729581,0.683895,0,-0.729581,0.683895,0,-0.729581,0.683895,0,-0.729579,0.683896,0,-0.729579,0.683896,0,-0.729579,0.683896,0,-0.85891,0.512126,0,-0.85891,0.512126,0,-0.85891,0.512126,0,-0.858911,0.512125,0,-0.858911,0.512125,0,-0.858911,0.512125,0,-0.948082,0.318026,0,-0.948082,0.318026,0,-0.948082,0.318026,0,-0.948082,0.318027,0,-0.948082,0.318027,0,-0.948082,0.318027,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994201,-0.107533,0,-0.994201,-0.107533,0,-0.994201,-0.107533,0,-0.994202,-0.107533,0,-0.994202,-0.107533,0,-0.994202,-0.107533,0,-0.948099,-0.317976,0,-0.948099,-0.317976,0,-0.948099,-0.317976,0,-0.948099,-0.317976,0,-0.858907,-0.512131,0,-0.858907,-0.512131,0,-0.858907,-0.512131,0,-0.858907,-0.512131,0,-0.729582,-0.683894,0,-0.729582,-0.683894,0,-0.729582,-0.683894,0,-0.729581,-0.683895,0,-0.729581,-0.683895,0,-0.729581,-0.683895,0,-0.561529,-0.827457,0,-0.561529,-0.827457,0,-0.561529,-0.827457,0,-0.561529,-0.827457,0,-0.356619,-0.93425,0,-0.356619,-0.93425,0,-0.356619,-0.93425,0,-0.356619,-0.93425,0,-0.12217,-0.992509,0,-0.12217,-0.992509,0,-0.12217,-0.992509,0,-0.122169,-0.992509,0,-0.122169,-0.992509,0,-0.122169,-0.992509,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0,-1,0,0,-1,0,0.122165,-0.99251,0,0.122165,-0.99251,0,0.122165,-0.99251,0,0.12217,-0.992509,-0.000001,0.12217,-0.992509,-0.000001,0.12217,-0.992509,-0.000001,0.356628,-0.934247,-0.000001,0.356628,-0.934247,-0.000001,0.356628,-0.934247,-0.000001,0.356624,-0.934248,0,0.356624,-0.934248,0,0.356624,-0.934248,0,0.561528,-0.827458,0,0.561528,-0.827458,0,0.561528,-0.827458,0,0.561531,-0.827456,0,0.561531,-0.827456,0,0.561531,-0.827456,0,0.729586,-0.683888,0,0.729586,-0.683888,0,0.729586,-0.683888,0,0.729586,-0.683888,0,0.858896,-0.51215,0,0.858896,-0.51215,0,0.858896,-0.51215,0,0.858896,-0.51215,0,0.948093,-0.317994,0,0.948093,-0.317994,0,0.948093,-0.317994,0,0.948093,-0.317994,0,0.994203,-0.107522,0,0.994203,-0.107522,0,0.994203,-0.107522,0,0.994203,-0.107522,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.948089,0.318006,0,0.948089,0.318006,0,0.948089,0.318006,0,0.948089,0.318006,0,0.858903,0.512138,0,0.858903,0.512138,0,0.858903,0.512138,0,0.858903,0.512138,0,0.729588,0.683887,0,0.729588,0.683887,0,0.729588,0.683887,0,0.729588,0.683887,0,0.561531,0.827456,0,0.561531,0.827456,0,0.561531,0.827456,0,0.561531,0.827456,0,0.356623,0.934248,0,0.356623,0.934248,0,0.356623,0.934248,0,0.356623,0.934248,0,0.122164,0.99251,0,0.122164,0.99251,0,0.122164,0.99251,0,0.122164,0.99251,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122163,0.99251,0,-0.122163,0.99251,0,-0.122163,0.99251,0,-0.122163,0.99251,0,-0.356619,0.93425,0,-0.356619,0.93425,0,-0.356619,0.93425,0,-0.356619,0.93425,0,-0.561543,0.827448,0,-0.561543,0.827448,0,-0.561543,0.827448,0,-0.561545,0.827446,0,-0.561545,0.827446,0,-0.561545,0.827446,0,-0.729579,0.683896,0,-0.729579,0.683896,0,-0.729579,0.683896,0,-0.729579,0.683896,0,-0.858906,0.512133,0,-0.858906,0.512133,0,-0.858906,0.512133,0,-0.858905,0.512135,0,-0.858905,0.512135,0,-0.858905,0.512135,0,-0.948089,0.318006,0,-0.948089,0.318006,0,-0.948089,0.318006,0,-0.948089,0.318006,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994204,-0.107512,0,-0.994204,-0.107512,0,-0.994204,-0.107512,0,-0.994204,-0.107512,0,-0.948095,-0.317986,0,-0.948095,-0.317986,0,-0.948095,-0.317986,0,-0.948095,-0.317986,0,-0.858897,-0.512148,0,-0.858897,-0.512148,0,-0.858897,-0.512148,0,-0.858897,-0.512148,0,-0.729576,-0.6839,0,-0.729576,-0.6839,0,-0.729576,-0.6839,0,-0.729575,-0.683901,0,-0.729575,-0.683901,0,-0.729575,-0.683901,0,-0.56154,-0.82745,0,-0.56154,-0.82745,0,-0.56154,-0.82745,0,-0.56154,-0.82745,0,-0.356619,-0.93425,0,-0.356619,-0.93425,0,-0.356619,-0.93425,0,-0.356619,-0.93425,0,-0.122168,-0.992509,0,-0.122168,-0.992509,0,-0.122168,-0.992509,0,-0.122168,-0.992509,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0,-1,0,0,-1,0,0.122164,-0.99251,0,0.122164,-0.99251,0,0.122164,-0.99251,0,0.122168,-0.992509,-0.000001,0.122168,-0.992509,-0.000001,0.122168,-0.992509,-0.000001,0.356622,-0.934249,0,0.356622,-0.934249,0,0.356622,-0.934249,0,0.356622,-0.934249,0,0.561534,-0.827454,0,0.561534,-0.827454,0,0.561534,-0.827454,0,0.561534,-0.827454,0,0.729586,-0.683888,0,0.729586,-0.683888,0,0.729586,-0.683888,0,0.729586,-0.683889,0,0.729586,-0.683889,0,0.729586,-0.683889,0,0.858896,-0.51215,0,0.858896,-0.51215,0,0.858896,-0.51215,0,0.858896,-0.51215,0,0.948098,-0.317979,0,0.948098,-0.317979,0,0.948098,-0.317979,0,0.948098,-0.317979,0,0.994202,-0.107528,0,0.994202,-0.107528,0,0.994202,-0.107528,0,0.994202,-0.107528,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994202,0.107527,0,0.994202,0.107527,0,0.994202,0.107527,0,0.994202,0.107527,0,0.948092,0.317996,0,0.948092,0.317996,0,0.948092,0.317996,0,0.948092,0.317996,0,0.8589,0.512143,0,0.8589,0.512143,0,0.8589,0.512143,0,0.8589,0.512143,0,0.729588,0.683887,0,0.729588,0.683887,0,0.729588,0.683887,0,0.729588,0.683887,0,0.561531,0.827456,0,0.561531,0.827456,0,0.561531,0.827456,0,0.561531,0.827456,0,0.356625,0.934248,0,0.356625,0.934248,0,0.356625,0.934248,0,0.356625,0.934248,0,0.122164,0.99251,0,0.122164,0.99251,0,0.122164,0.99251,0,0.122167,0.99251,0,0.122167,0.99251,0,0.122167,0.99251,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122166,0.99251,0,-0.122166,0.99251,0,-0.122166,0.99251,0,-0.122163,0.99251,0,-0.122163,0.99251,0,-0.122163,0.99251,0,-0.356617,0.934251,0,-0.356617,0.934251,0,-0.356617,0.934251,0,-0.356617,0.934251,0,-0.56154,0.82745,0,-0.56154,0.82745,0,-0.56154,0.82745,0,-0.56154,0.82745,0,-0.729588,0.683887,0,-0.729588,0.683887,0,-0.729588,0.683887,0,-0.729589,0.683886,0,-0.729589,0.683886,0,-0.729589,0.683886,0,-0.858895,0.512152,0,-0.858895,0.512152,0,-0.858895,0.512152,0,-0.858895,0.512152,0,-0.948094,0.31799,0,-0.948094,0.31799,0,-0.948094,0.31799,0,-0.948094,0.31799,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994203,-0.107522,0,-0.994203,-0.107522,0,-0.994203,-0.107522,0,-0.994203,-0.107522,0,-0.948092,-0.317996,0,-0.948092,-0.317996,0,-0.948092,-0.317996,0,-0.948092,-0.317996,0,-0.8589,-0.512144,0,-0.8589,-0.512144,0,-0.8589,-0.512144,0,-0.8589,-0.512144,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.561534,-0.827453,0,-0.561534,-0.827453,0,-0.561534,-0.827453,0,-0.561538,-0.827451,0,-0.561538,-0.827451,0,-0.561538,-0.827451,0,-0.356617,-0.93425,-0.000001,-0.356617,-0.93425,-0.000001,-0.356617,-0.93425,-0.000001,-0.356617,-0.934251,-0.000001,-0.356617,-0.934251,-0.000001,-0.356617,-0.934251,-0.000001,-0.122168,-0.992509,0,-0.122168,-0.992509,0,-0.122168,-0.992509,0,-0.122164,-0.99251,-0.000001,-0.122164,-0.99251,-0.000001,-0.122164,-0.99251,-0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122168,-0.992509,0,0.122168,-0.992509,0,0.122168,-0.992509,0,0.122169,-0.992509,0,0.122169,-0.992509,0,0.122169,-0.992509,0,0.356623,-0.934248,0,0.356623,-0.934248,0,0.356623,-0.934248,0,0.356623,-0.934249,0,0.356623,-0.934249,0,0.356623,-0.934249,0,0.561531,-0.827456,0,0.561531,-0.827456,0,0.561531,-0.827456,0,0.561531,-0.827456,0,0.729588,-0.683887,0,0.729588,-0.683887,0,0.729588,-0.683887,0,0.729587,-0.683888,0,0.729587,-0.683888,0,0.729587,-0.683888,0,0.858899,-0.512145,0,0.858899,-0.512145,0,0.858899,-0.512145,0,0.858899,-0.512145,0,0.948094,-0.317989,0,0.948094,-0.317989,0,0.948094,-0.317989,0,0.948094,-0.317989,0,0.994202,-0.107528,0,0.994202,-0.107528,0,0.994202,-0.107528,0,0.994202,-0.107528,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.948093,0.317993,0,0.948093,0.317993,0,0.948093,0.317993,0,0.948093,0.317993,0,0.858894,0.512153,0,0.858894,0.512153,0,0.858894,0.512153,0,0.858894,0.512153,0,0.729589,0.683886,0,0.729589,0.683886,0,0.729589,0.683886,0,0.729588,0.683887,0,0.729588,0.683887,0,0.729588,0.683887,0,0.56153,0.827457,0,0.56153,0.827457,0,0.56153,0.827457,0,0.561532,0.827455,0,0.561532,0.827455,0,0.561532,0.827455,0,0.356626,0.934247,0,0.356626,0.934247,0,0.356626,0.934247,0,0.356626,0.934247,0,0.122163,0.99251,0,0.122163,0.99251,0,0.122163,0.99251,0,0.122163,0.99251,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122164,0.99251,0,-0.122164,0.99251,0,-0.122164,0.99251,0,-0.122164,0.99251,0,-0.356617,0.934251,0,-0.356617,0.934251,0,-0.356617,0.934251,0,-0.356617,0.934251,0,-0.561537,0.827452,0,-0.561537,0.827452,0,-0.561537,0.827452,0,-0.561537,0.827452,0,-0.729586,0.683889,0,-0.729586,0.683889,0,-0.729586,0.683889,0,-0.729585,0.68389,0,-0.729585,0.68389,0,-0.729585,0.68389,0,-0.858897,0.512148,0,-0.858897,0.512148,0,-0.858897,0.512148,0,-0.858898,0.512146,0,-0.858898,0.512146,0,-0.858898,0.512146,0,-0.948094,0.317991,0,-0.948094,0.317991,0,-0.948094,0.317991,0,-0.948094,0.317991,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994202,-0.107529,0,-0.994202,-0.107529,0,-0.994202,-0.107529,0,-0.994202,-0.107529,0,-0.948094,-0.317991,0,-0.948094,-0.317991,0,-0.948094,-0.317991,0,-0.948094,-0.317991,0,-0.858902,-0.51214,0,-0.858902,-0.51214,0,-0.858902,-0.51214,0,-0.858902,-0.51214,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.561535,-0.827453,0,-0.561535,-0.827453,0,-0.561535,-0.827453,0,-0.561539,-0.827451,0,-0.561539,-0.827451,0,-0.561539,-0.827451,0,-0.356617,-0.934251,-0.000001,-0.356617,-0.934251,-0.000001,-0.356617,-0.934251,-0.000001,-0.356617,-0.934251,-0.000001,-0.122168,-0.992509,0,-0.122168,-0.992509,0,-0.122168,-0.992509,0,-0.122164,-0.99251,-0.000001,-0.122164,-0.99251,-0.000001,-0.122164,-0.99251,-0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122167,-0.99251,0,0.122167,-0.99251,0,0.122167,-0.99251,0,0.122167,-0.99251,0,0.356622,-0.934249,0,0.356622,-0.934249,0,0.356622,-0.934249,0,0.356622,-0.934249,0,0.561537,-0.827452,0,0.561537,-0.827452,0,0.561537,-0.827452,0,0.561537,-0.827452,0,0.729588,-0.683887,0,0.729588,-0.683887,0,0.729588,-0.683887,0,0.729587,-0.683888,0,0.729587,-0.683888,0,0.729587,-0.683888,0,0.858899,-0.512146,0,0.858899,-0.512146,0,0.858899,-0.512146,0,0.858899,-0.512146,0,0.948094,-0.317989,0,0.948094,-0.317989,0,0.948094,-0.317989,0,0.948094,-0.317989,0,0.994203,-0.10752,0,0.994203,-0.10752,0,0.994203,-0.10752,0,0.994203,-0.10752,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994203,0.107519,0,0.994203,0.107519,0,0.994203,0.107519,0,0.994203,0.107519,0,0.948094,0.317991,0,0.948094,0.317991,0,0.948094,0.317991,0,0.948094,0.31799,0,0.948094,0.31799,0,0.948094,0.31799,0,0.858896,0.51215,0,0.858896,0.51215,0,0.858896,0.51215,0,0.858895,0.512151,0,0.858895,0.512151,0,0.858895,0.512151,0,0.729585,0.68389,0,0.729585,0.68389,0,0.729585,0.68389,0,0.729586,0.683889,0,0.729586,0.683889,0,0.729586,0.683889,0,0.56153,0.827457,0,0.56153,0.827457,0,0.56153,0.827457,0,0.56153,0.827457,0,0.356631,0.934245,0,0.356631,0.934245,0,0.356631,0.934245,0,0.356628,0.934246,0,0.356628,0.934246,0,0.356628,0.934246,0,0.122163,0.99251,0,0.122163,0.99251,0,0.122163,0.99251,0,0.122163,0.99251,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122163,0.99251,0,-0.122163,0.99251,0,-0.122163,0.99251,0,-0.122166,0.99251,0,-0.122166,0.99251,0,-0.122166,0.99251,0,-0.356621,0.934249,0,-0.356621,0.934249,0,-0.356621,0.934249,0,-0.356621,0.934249,0,-0.561532,0.827455,0,-0.561532,0.827455,0,-0.561532,0.827455,0,-0.561532,0.827455,0,-0.729594,0.683881,0,-0.729594,0.683881,0,-0.729594,0.683881,0,-0.729594,0.683881,0,-0.858891,0.512159,0,-0.858891,0.512159,0,-0.858891,0.512159,0,-0.858891,0.512159,0,-0.948094,0.31799,0,-0.948094,0.31799,0,-0.948094,0.31799,0,-0.948094,0.317991,0,-0.948094,0.317991,0,-0.948094,0.317991,0,-0.994203,0.107517,0,-0.994203,0.107517,0,-0.994203,0.107517,0,-0.994203,0.107517,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994202,-0.107528,0,-0.994202,-0.107528,0,-0.994202,-0.107528,0,-0.994202,-0.107528,0,-0.94809,-0.318001,0,-0.94809,-0.318001,0,-0.94809,-0.318001,0,-0.94809,-0.318001,0,-0.85891,-0.512127,0,-0.85891,-0.512127,0,-0.85891,-0.512127,0,-0.85891,-0.512127,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.561532,-0.827455,0,-0.561532,-0.827455,0,-0.561532,-0.827455,0,-0.561535,-0.827453,0,-0.561535,-0.827453,0,-0.561535,-0.827453,0,-0.356623,-0.934248,0,-0.356623,-0.934248,0,-0.356623,-0.934248,0,-0.356619,-0.93425,-0.000001,-0.356619,-0.93425,-0.000001,-0.356619,-0.93425,-0.000001,-0.122163,-0.99251,0,-0.122163,-0.99251,0,-0.122163,-0.99251,0,-0.122164,-0.99251,0,-0.122164,-0.99251,0,-0.122164,-0.99251,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122168,-0.99251,0,0.122168,-0.99251,0,0.122168,-0.99251,0,0.122167,-0.99251,0,0.122167,-0.99251,0,0.122167,-0.99251,0,0.356616,-0.934251,0,0.356616,-0.934251,0,0.356616,-0.934251,0,0.356616,-0.934251,0,0.561548,-0.827444,0,0.561548,-0.827444,0,0.561548,-0.827444,0,0.561548,-0.827444,0,0.729591,-0.683884,0,0.729591,-0.683884,0,0.729591,-0.683884,0,0.729591,-0.683883,0,0.729591,-0.683883,0,0.729591,-0.683883,0,0.858896,-0.51215,0,0.858896,-0.51215,0,0.858896,-0.51215,0,0.858896,-0.51215,0,0.948089,-0.318004,0,0.948089,-0.318004,0,0.948089,-0.318004,0,0.948089,-0.318004,0,0.994204,-0.107512,0,0.994204,-0.107512,0,0.994204,-0.107512,0,0.994204,-0.107512,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994202,0.107532,0,0.994202,0.107532,0,0.994202,0.107532,0,0.994202,0.107532,0,0.948099,0.317975,0,0.948099,0.317975,0,0.948099,0.317975,0,0.948099,0.317975,0,0.858893,0.512155,0,0.858893,0.512155,0,0.858893,0.512155,0,0.858893,0.512155,0,0.729582,0.683893,0,0.729582,0.683893,0,0.729582,0.683893,0,0.729582,0.683893,0,0.561531,0.827456,0,0.561531,0.827456,0,0.561531,0.827456,0,0.561531,0.827456,0,0.356631,0.934245,0,0.356631,0.934245,0,0.356631,0.934245,0,0.356631,0.934245,0,0.122162,0.99251,0,0.122162,0.99251,0,0.122162,0.99251,0,0.122162,0.99251,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122164,0.99251,0,-0.122164,0.99251,0,-0.122164,0.99251,0,-0.122164,0.99251,0,-0.356627,0.934247,0,-0.356627,0.934247,0,-0.356627,0.934247,0,-0.356627,0.934247,0,-0.561521,0.827463,0,-0.561521,0.827463,0,-0.561521,0.827463,0,-0.561523,0.827461,0,-0.561523,0.827461,0,-0.561523,0.827461,0,-0.729585,0.68389,0,-0.729585,0.68389,0,-0.729585,0.68389,0,-0.729585,0.68389,0,-0.858896,0.51215,0,-0.858896,0.51215,0,-0.858896,0.51215,0,-0.858895,0.512152,0,-0.858895,0.512152,0,-0.858895,0.512152,0,-0.948095,0.317986,0,-0.948095,0.317986,0,-0.948095,0.317986,0,-0.948096,0.317985,0,-0.948096,0.317985,0,-0.948096,0.317985,0,-0.994204,0.107511,0,-0.994204,0.107511,0,-0.994204,0.107511,0,-0.994204,0.107512,0,-0.994204,0.107512,0,-0.994204,0.107512,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994203,-0.107522,0,-0.994203,-0.107522,0,-0.994203,-0.107522,0,-0.994203,-0.107522,0,-0.948085,-0.318016,0,-0.948085,-0.318016,0,-0.948085,-0.318016,0,-0.948085,-0.318016,0,-0.858907,-0.512131,0,-0.858907,-0.512131,0,-0.858907,-0.512131,0,-0.858907,-0.512131,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.561543,-0.827447,0,-0.561543,-0.827447,0,-0.561543,-0.827447,0,-0.561543,-0.827448,0,-0.561543,-0.827448,0,-0.561543,-0.827448,0,-0.356615,-0.934251,0,-0.356615,-0.934251,0,-0.356615,-0.934251,0,-0.356615,-0.934251,0,-0.122163,-0.99251,0,-0.122163,-0.99251,0,-0.122163,-0.99251,0,-0.122164,-0.99251,0,-0.122164,-0.99251,0,-0.122164,-0.99251,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122171,-0.992509,-0.000001,0.122171,-0.992509,-0.000001,0.122171,-0.992509,-0.000001,0.122166,-0.99251,0,0.122166,-0.99251,0,0.122166,-0.99251,0,0.356612,-0.934253,0,0.356612,-0.934253,0,0.356612,-0.934253,0,0.356616,-0.934251,-0.000001,0.356616,-0.934251,-0.000001,0.356616,-0.934251,-0.000001,0.561537,-0.827452,0,0.561537,-0.827452,0,0.561537,-0.827452,0,0.561534,-0.827454,0,0.561534,-0.827454,0,0.561534,-0.827454,0,0.729585,-0.68389,0,0.729585,-0.68389,0,0.729585,-0.68389,0,0.729588,-0.683887,0,0.729588,-0.683887,0,0.729588,-0.683887,0,0.858901,-0.512141,0,0.858901,-0.512141,0,0.858901,-0.512141,0,0.858901,-0.512141,0,0.948096,-0.317984,0,0.948096,-0.317984,0,0.948096,-0.317984,0,0.948096,-0.317984,0,0.9942,-0.107544,0,0.9942,-0.107544,0,0.9942,-0.107544,0,0.9942,-0.107544,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994202,0.107532,0,0.994202,0.107532,0,0.994202,0.107532,0,0.994202,0.107532,0,0.948102,0.317965,0,0.948102,0.317965,0,0.948102,0.317965,0,0.948102,0.317966,0,0.948102,0.317966,0,0.948102,0.317966,0,0.858888,0.512164,0,0.858888,0.512164,0,0.858888,0.512164,0,0.858888,0.512164,0,0.729588,0.683887,0,0.729588,0.683887,0,0.729588,0.683887,0,0.729588,0.683887,0,0.561515,0.827467,0,0.561515,0.827467,0,0.561515,0.827467,0,0.561515,0.827467,0,0.356631,0.934245,0,0.356631,0.934245,0,0.356631,0.934245,0,0.356631,0.934245,0,0.122164,0.99251,0,0.122164,0.99251,0,0.122164,0.99251,0,0.122167,0.992509,0,0.122167,0.992509,0,0.122167,0.992509,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122167,0.992509,0,-0.122167,0.992509,0,-0.122167,0.992509,0,-0.122164,0.99251,0,-0.122164,0.99251,0,-0.122164,0.99251,0,-0.356623,0.934248,0,-0.356623,0.934248,0,-0.356623,0.934248,0,-0.356623,0.934248,0,-0.561532,0.827455,0,-0.561532,0.827455,0,-0.561532,0.827455,0,-0.561532,0.827455,0,-0.729579,0.683896,0,-0.729579,0.683896,0,-0.729579,0.683896,0,-0.729581,0.683895,0,-0.729581,0.683895,0,-0.729581,0.683895,0,-0.858895,0.512152,0,-0.858895,0.512152,0,-0.858895,0.512152,0,-0.858895,0.512152,0,-0.948102,0.317965,0,-0.948102,0.317965,0,-0.948102,0.317965,0,-0.948102,0.317965,0,-0.994202,0.107533,0,-0.994202,0.107533,0,-0.994202,0.107533,0,-0.994202,0.107533,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994203,-0.107522,0,-0.994203,-0.107522,0,-0.994203,-0.107522,0,-0.994203,-0.107522,0,-0.948089,-0.318006,0,-0.948089,-0.318006,0,-0.948089,-0.318006,0,-0.948089,-0.318006,0,-0.858923,-0.512106,0,-0.858923,-0.512106,0,-0.858923,-0.512106,0,-0.858923,-0.512106,0,-0.729563,-0.683914,0,-0.729563,-0.683914,0,-0.729563,-0.683914,0,-0.729562,-0.683915,0,-0.729562,-0.683915,0,-0.729562,-0.683915,0,-0.561548,-0.827444,0,-0.561548,-0.827444,0,-0.561548,-0.827444,0,-0.561548,-0.827444,0,-0.356615,-0.934251,0,-0.356615,-0.934251,0,-0.356615,-0.934251,0,-0.356615,-0.934251,0,-0.122165,-0.99251,0,-0.122165,-0.99251,0,-0.122165,-0.99251,0,-0.122165,-0.99251,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.12217,-0.992509,-0.000001,0.12217,-0.992509,-0.000001,0.12217,-0.992509,-0.000001,0.122165,-0.99251,0,0.122165,-0.99251,0,0.122165,-0.99251,0,0.356616,-0.934251,0,0.356616,-0.934251,0,0.356616,-0.934251,0,0.35662,-0.93425,-0.000001,0.35662,-0.93425,-0.000001,0.35662,-0.93425,-0.000001,0.561526,-0.827459,0,0.561526,-0.827459,0,0.561526,-0.827459,0,0.561523,-0.827461,0,0.561523,-0.827461,0,0.561523,-0.827461,0,0.729609,-0.683865,0,0.729609,-0.683865,0,0.729609,-0.683865,0,0.729611,-0.683863,0,0.729611,-0.683863,0,0.729611,-0.683863,0,0.858896,-0.51215,0,0.858896,-0.51215,0,0.858896,-0.51215,0,0.858896,-0.51215,0,0.948086,-0.318014,0,0.948086,-0.318014,0,0.948086,-0.318014,0,0.948086,-0.318014,0,0.994205,-0.107501,0,0.994205,-0.107501,0,0.994205,-0.107501,0,0.994205,-0.107501,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994205,0.1075,0,0.994205,0.1075,0,0.994205,0.1075,0,0.994205,0.1075,0,0.948099,0.317975,0,0.948099,0.317975,0,0.948099,0.317975,0,0.948099,0.317975,0,0.858883,0.512172,0,0.858883,0.512172,0,0.858883,0.512172,0,0.858883,0.512172,0,0.729576,0.6839,0,0.729576,0.6839,0,0.729576,0.6839,0,0.729576,0.6839,0,0.561526,0.827459,0,0.561526,0.827459,0,0.561526,0.827459,0,0.561524,0.827461,0,0.561524,0.827461,0,0.561524,0.827461,0,0.356643,0.934241,0,0.356643,0.934241,0,0.356643,0.934241,0,0.356645,0.93424,0,0.356645,0.93424,0,0.356645,0.93424,0,0.122164,0.99251,0,0.122164,0.99251,0,0.122164,0.99251,0,0.122162,0.99251,0,0.122162,0.99251,0,0.122162,0.99251,0,-0.356643,0.934241,0,-0.356643,0.934241,0,-0.356643,0.934241,0,-0.356643,0.934241,0,-0.561548,0.827444,0,-0.561548,0.827444,0,-0.561548,0.827444,0,-0.561548,0.827444,0,-0.729553,0.683925,0,-0.729553,0.683925,0,-0.729553,0.683925,0,-0.729553,0.683925,0,-0.858883,0.512172,0,-0.858883,0.512172,0,-0.858883,0.512172,0,-0.858883,0.512172,0,-0.9481,0.317973,0,-0.9481,0.317973,0,-0.9481,0.317973,0,-0.9481,0.317973,0,-0.994205,0.107501,0,-0.994205,0.107501,0,-0.994205,0.107501,0,-0.994205,0.107501,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994205,-0.107501,0,-0.994205,-0.107501,0,-0.994205,-0.107501,0,-0.994205,-0.107501,0,-0.948086,-0.318015,0,-0.948086,-0.318015,0,-0.948086,-0.318015,0,-0.948086,-0.318014,0,-0.948086,-0.318014,0,-0.948086,-0.318014,0,-0.858905,-0.512134,0,-0.858905,-0.512134,0,-0.858905,-0.512134,0,-0.858905,-0.512134,0,-0.729597,-0.683877,0,-0.729597,-0.683877,0,-0.729597,-0.683877,0,-0.729596,-0.683879,0,-0.729596,-0.683879,0,-0.729596,-0.683879,0,-0.561526,-0.827459,0,-0.561526,-0.827459,0,-0.561526,-0.827459,0,-0.561526,-0.827459,0,-0.356628,-0.934247,0,-0.356628,-0.934247,0,-0.356628,-0.934247,0,-0.356628,-0.934247,0,-0.122162,-0.99251,0,-0.122162,-0.99251,0,-0.122162,-0.99251,0,-0.122162,-0.99251,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.12217,-0.992509,0,0.12217,-0.992509,0,0.12217,-0.992509,0,0.12217,-0.992509,0,0.356627,-0.934247,0,0.356627,-0.934247,0,0.356627,-0.934247,0,0.356627,-0.934247,0,0.561554,-0.82744,0,0.561554,-0.82744,0,0.561554,-0.82744,0,0.561554,-0.82744,0,0.729584,-0.683891,0,0.729584,-0.683891,0,0.729584,-0.683891,0,0.729583,-0.683892,0,0.729583,-0.683892,0,0.729583,-0.683892,0,0.858888,-0.512164,0,0.858888,-0.512164,0,0.858888,-0.512164,0,0.858888,-0.512164,0,0.948105,-0.317957,0,0.948105,-0.317957,0,0.948105,-0.317957,0,0.948105,-0.317957,0,0.994193,-0.107608,0,0.994193,-0.107608,0,0.994193,-0.107608,0,0.994193,-0.107608,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994196,0.107586,0,0.994196,0.107586,0,0.994196,0.107586,0,0.994196,0.107586,0,0.948092,0.317997,0,0.948092,0.317997,0,0.948092,0.317997,0,0.948092,0.317997,0,0.858927,0.512098,0,0.858927,0.512098,0,0.858927,0.512098,0,0.858927,0.512098,0,0.72955,0.683927,0,0.72955,0.683927,0,0.72955,0.683927,0,0.72955,0.683927,0,0.561554,0.82744,0,0.561554,0.82744,0,0.561554,0.82744,0,0.561556,0.827439,0,0.561556,0.827439,0,0.561556,0.827439,0,0.356611,0.934253,0,0.356611,0.934253,0,0.356611,0.934253,0,0.356611,0.934253,0,0.122164,0.99251,0,0.122164,0.99251,0,0.122164,0.99251,0,0.122164,0.99251,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122164,0.99251,0,-0.122164,0.99251,0,-0.122164,0.99251,0,-0.122162,0.99251,0,-0.122162,0.99251,0,-0.122162,0.99251,0,-0.356619,0.93425,0,-0.356619,0.93425,0,-0.356619,0.93425,0,-0.356619,0.93425,0,-0.561537,0.827452,0,-0.561537,0.827452,0,-0.561537,0.827452,0,-0.561537,0.827452,0,-0.729599,0.683875,0,-0.729599,0.683875,0,-0.729599,0.683875,0,-0.729599,0.683875,0,-0.858903,0.512138,0,-0.858903,0.512138,0,-0.858903,0.512138,0,-0.858903,0.512138,0,-0.948086,0.318013,0,-0.948086,0.318013,0,-0.948086,0.318013,0,-0.948086,0.318013,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994203,-0.107522,0,-0.994203,-0.107522,0,-0.994203,-0.107522,0,-0.994203,-0.107522,0,-0.9481,-0.317973,0,-0.9481,-0.317973,0,-0.9481,-0.317973,0,-0.9481,-0.317973,0,-0.858885,-0.512168,0,-0.858885,-0.512168,0,-0.858885,-0.512168,0,-0.858885,-0.512168,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.729586,-0.683889,0,-0.729585,-0.68389,0,-0.729585,-0.68389,0,-0.729585,-0.68389,0,-0.561537,-0.827452,0,-0.561537,-0.827452,0,-0.561537,-0.827452,0,-0.561536,-0.827452,0,-0.561536,-0.827452,0,-0.561536,-0.827452,0,-0.35662,-0.93425,0,-0.35662,-0.93425,0,-0.35662,-0.93425,0,-0.35662,-0.93425,0,-0.122168,-0.99251,0,-0.122168,-0.99251,0,-0.122168,-0.99251,0,-0.122168,-0.99251,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.12217,-0.992509,-0.000001,0.12217,-0.992509,-0.000001,0.12217,-0.992509,-0.000001,0.122165,-0.99251,0,0.122165,-0.99251,0,0.122165,-0.99251,0,0.356596,-0.934259,0,0.356596,-0.934259,0,0.356596,-0.934259,0,0.3566,-0.934257,-0.000001,0.3566,-0.934257,-0.000001,0.3566,-0.934257,-0.000001,0.561521,-0.827462,0,0.561521,-0.827462,0,0.561521,-0.827462,0,0.561518,-0.827464,0,0.561518,-0.827464,0,0.561518,-0.827464,0,0.729618,-0.683855,0,0.729618,-0.683855,0,0.729618,-0.683855,0,0.72962,-0.683852,0,0.72962,-0.683852,0,0.72962,-0.683852,0,0.858868,-0.512198,0,0.858868,-0.512198,0,0.858868,-0.512198,0,0.858868,-0.512198,0,0.948092,-0.317997,0,0.948092,-0.317997,0,0.948092,-0.317997,0,0.948092,-0.317997,0,0.99421,-0.107459,0,0.99421,-0.107459,0,0.99421,-0.107459,0,0.99421,-0.107459,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.948098,0.317977,0,0.948098,0.317977,0,0.948098,0.317977,0,0.948098,0.317977,0,0.858897,0.512149,0,0.858897,0.512149,0,0.858897,0.512149,0,0.858897,0.512149,0,0.729621,0.683851,0,0.729621,0.683851,0,0.729621,0.683851,0,0.72962,0.683853,0,0.72962,0.683853,0,0.72962,0.683853,0,0.561521,0.827463,0,0.561521,0.827463,0,0.561521,0.827463,0,0.561521,0.827463,0,0.356627,0.934247,0,0.356627,0.934247,0,0.356627,0.934247,0,0.356627,0.934247,0,0.122145,0.992512,0,0.122145,0.992512,0,0.122145,0.992512,0,0.122145,0.992512,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122164,0.99251,0,-0.122164,0.99251,0,-0.122164,0.99251,0,-0.122167,0.992509,0,-0.122167,0.992509,0,-0.122167,0.992509,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122166,0.99251,0,-0.122166,0.99251,0,-0.122166,0.99251,0,-0.122167,0.99251,0,-0.122167,0.99251,0,-0.122167,0.99251,0,-0.356619,0.93425,0,-0.356619,0.93425,0,-0.356619,0.93425,0,-0.356619,0.93425,0,-0.561552,0.827442,0,-0.561552,0.827442,0,-0.561552,0.827442,0,-0.561551,0.827442,0,-0.561551,0.827442,0,-0.561551,0.827442,0,-0.729575,0.6839,0,-0.729575,0.6839,0,-0.729575,0.6839,0,-0.729576,0.6839,0,-0.729576,0.6839,0,-0.729576,0.6839,0,-0.858916,0.512117,0,-0.858916,0.512117,0,-0.858916,0.512117,0,-0.858916,0.512117,0,-0.948085,0.318016,0,-0.948085,0.318016,0,-0.948085,0.318016,0,-0.948085,0.318016,0,-0.9942,0.107543,0,-0.9942,0.107543,0,-0.9942,0.107543,0,-0.9942,0.107543,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-0.994205,-0.107501,0,-0.994205,-0.107501,0,-0.994205,-0.107501,0,-0.994205,-0.107501,0,-0.948093,-0.317993,0,-0.948093,-0.317993,0,-0.948093,-0.317993,0,-0.948093,-0.317993,0,-0.858885,-0.512168,0,-0.858885,-0.512168,0,-0.858885,-0.512168,0,-0.858887,-0.512166,0,-0.858887,-0.512166,0,-0.858887,-0.512166,0,-0.729598,-0.683876,0,-0.729598,-0.683876,0,-0.729598,-0.683876,0,-0.729595,-0.683879,0,-0.729595,-0.683879,0,-0.729595,-0.683879,0,-0.561526,-0.827459,0,-0.561526,-0.827459,0,-0.561526,-0.827459,0,-0.561526,-0.827459,0,-0.35663,-0.934246,0,-0.35663,-0.934246,0,-0.35663,-0.934246,0,-0.35663,-0.934246,0,-0.122162,-0.99251,0,-0.122162,-0.99251,0,-0.122162,-0.99251,0,-0.122162,-0.99251,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122173,-0.992509,0,0.122173,-0.992509,0,0.122173,-0.992509,0,0.122173,-0.992509,0,0.356617,-0.934251,-0.000001,0.356617,-0.934251,-0.000001,0.356617,-0.934251,-0.000001,0.356612,-0.934253,0,0.356612,-0.934253,0,0.356612,-0.934253,0,0.56153,-0.827457,0,0.56153,-0.827457,0,0.56153,-0.827457,0,0.561534,-0.827454,0,0.561534,-0.827454,0,0.561534,-0.827454,0,0.729598,-0.683876,0,0.729598,-0.683876,0,0.729598,-0.683876,0,0.729598,-0.683876,0,0.858885,-0.512168,0,0.858885,-0.512168,0,0.858885,-0.512168,0,0.858885,-0.512168,0,0.948099,-0.317976,0,0.948099,-0.317976,0,0.948099,-0.317976,0,0.948099,-0.317976,0,0.994203,-0.107522,0,0.994203,-0.107522,0,0.994203,-0.107522,0,0.994203,-0.107522,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994205,0.107501,0,0.994205,0.107501,0,0.994205,0.107501,0,0.994205,0.107501,0,0.948079,0.318035,0,0.948079,0.318035,0,0.948079,0.318035,0,0.948079,0.318034,0,0.948079,0.318034,0,0.948079,0.318034,0,0.858906,0.512134,0,0.858906,0.512134,0,0.858906,0.512134,0,0.858905,0.512135,0,0.858905,0.512135,0,0.858905,0.512135,0,0.729585,0.68389,0,0.729585,0.68389,0,0.729585,0.68389,0,0.729586,0.683889,0,0.729586,0.683889,0,0.729586,0.683889,0,0.561552,0.827442,0,0.561552,0.827442,0,0.561552,0.827442,0,0.561548,0.827444,0,0.561548,0.827444,0,0.561548,0.827444,0,0.356608,0.934254,0,0.356608,0.934254,0,0.356608,0.934254,0,0.356611,0.934253,0.000001,0.356611,0.934253,0.000001,0.356611,0.934253,0.000001,0.122164,0.99251,0,0.122164,0.99251,0,0.122164,0.99251,0,0.122164,0.99251,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122171,0.992509,0,-0.122171,0.992509,0,-0.122171,0.992509,0,-0.122171,0.992509,0,-0.356627,0.934247,0,-0.356627,0.934247,0,-0.356627,0.934247,0,-0.356627,0.934247,0,-0.561523,0.827461,0,-0.561523,0.827461,0,-0.561523,0.827461,0,-0.561523,0.827461,0,-0.729594,0.683881,0,-0.729594,0.683881,0,-0.729594,0.683881,0,-0.729594,0.683881,0,-0.85889,0.512159,0,-0.85889,0.512159,0,-0.85889,0.512159,0,-0.85889,0.512159,0,-0.948092,0.317996,0,-0.948092,0.317996,0,-0.948092,0.317996,0,-0.948092,0.317996,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994202,-0.107532,0,-0.994202,-0.107532,0,-0.994202,-0.107532,0,-0.994202,-0.107533,0,-0.994202,-0.107533,0,-0.994202,-0.107533,0,-0.948096,-0.317983,0,-0.948096,-0.317983,0,-0.948096,-0.317983,0,-0.948096,-0.317983,0,-0.858905,-0.512134,0,-0.858905,-0.512134,0,-0.858905,-0.512134,0,-0.858905,-0.512134,0,-0.729578,-0.683898,0,-0.729578,-0.683898,0,-0.729578,-0.683898,0,-0.729581,-0.683895,0,-0.729581,-0.683895,0,-0.729581,-0.683895,0,-0.561537,-0.827452,0,-0.561537,-0.827452,0,-0.561537,-0.827452,0,-0.561537,-0.827452,0,-0.356626,-0.934247,0,-0.356626,-0.934247,0,-0.356626,-0.934247,0,-0.356621,-0.934249,-0.000001,-0.356621,-0.934249,-0.000001,-0.356621,-0.934249,-0.000001,-0.122167,-0.992509,0,-0.122167,-0.992509,0,-0.122167,-0.992509,0,-0.122167,-0.992509,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122176,-0.992508,0,0.122176,-0.992508,0,0.122176,-0.992508,0,0.122176,-0.992508,0,0.356613,-0.934252,-0.000001,0.356613,-0.934252,-0.000001,0.356613,-0.934252,-0.000001,0.356608,-0.934254,0,0.356608,-0.934254,0,0.356608,-0.934254,0,0.561526,-0.827459,0,0.561526,-0.827459,0,0.561526,-0.827459,0,0.561526,-0.827459,0,0.729607,-0.683867,0,0.729607,-0.683867,0,0.729607,-0.683867,0,0.729609,-0.683864,0,0.729609,-0.683864,0,0.729609,-0.683864,0,0.8589,-0.512143,0,0.8589,-0.512143,0,0.8589,-0.512143,0,0.8589,-0.512143,0,0.948092,-0.317996,0,0.948092,-0.317996,0,0.948092,-0.317996,0,0.948092,-0.317996,0,0.994204,-0.107511,0,0.994204,-0.107511,0,0.994204,-0.107511,0,0.994204,-0.107511,0,1,-0.000001,0,1,-0.000001,0,1,-0.000001,0,1,-0.000001,0,0.994204,0.107511,0,0.994204,0.107511,0,0.994204,0.107511,0,0.994204,0.107511,0,0.948103,0.317964,0,0.948103,0.317964,0,0.948103,0.317964,0,0.948103,0.317964,0,0.85888,0.512176,0,0.85888,0.512176,0,0.85888,0.512176,0,0.85888,0.512177,0,0.85888,0.512177,0,0.85888,0.512177,0,0.729585,0.68389,0,0.729585,0.68389,0,0.729585,0.68389,0,0.729586,0.683889,0,0.729586,0.683889,0,0.729586,0.683889,0,0.561526,0.827459,0,0.561526,0.827459,0,0.561526,0.827459,0,0.561526,0.827459,0,0.356625,0.934248,0,0.356625,0.934248,0,0.356625,0.934248,0,0.356623,0.934248,0,0.356623,0.934248,0,0.356623,0.934248,0,0.122166,0.99251,0,0.122166,0.99251,0,0.122166,0.99251,0,0.122166,0.99251,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122163,0.99251,0,-0.122163,0.99251,0,-0.122163,0.99251,0,-0.122162,0.99251,0,-0.122162,0.99251,0,-0.122162,0.99251,0,-0.356631,0.934245,0,-0.356631,0.934245,0,-0.356631,0.934245,0,-0.356632,0.934245,0,-0.356632,0.934245,0,-0.356632,0.934245,0,-0.561526,0.827459,0,-0.561526,0.827459,0,-0.561526,0.827459,0,-0.561526,0.827459,0,-0.729586,0.683889,0,-0.729586,0.683889,0,-0.729586,0.683889,0,-0.729586,0.683889,0,-0.85889,0.512159,0,-0.85889,0.512159,0,-0.85889,0.512159,0,-0.858892,0.512157,0,-0.858892,0.512157,0,-0.858892,0.512157,0,-0.948099,0.317974,0,-0.948099,0.317974,0,-0.948099,0.317974,0,-0.948099,0.317976,0,-0.948099,0.317976,0,-0.948099,0.317976,0,-0.994201,0.107533,0,-0.994201,0.107533,0,-0.994201,0.107533,0,-0.994202,0.107533,0,-0.994202,0.107533,0,-0.994202,0.107533,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994203,-0.107522,0,-0.994203,-0.107522,0,-0.994203,-0.107522,0,-0.994203,-0.107522,0,-0.948086,-0.318013,0,-0.948086,-0.318013,0,-0.948086,-0.318013,0,-0.948086,-0.318013,0,-0.858902,-0.51214,0,-0.858902,-0.51214,0,-0.858902,-0.51214,0,-0.8589,-0.512143,0,-0.8589,-0.512143,0,-0.8589,-0.512143,0,-0.72959,-0.683885,0,-0.72959,-0.683885,0,-0.72959,-0.683885,0,-0.72959,-0.683885,0,-0.561542,-0.827448,0,-0.561542,-0.827448,0,-0.561542,-0.827448,0,-0.561542,-0.827448,0,-0.356622,-0.934249,0,-0.356622,-0.934249,0,-0.356622,-0.934249,0,-0.356622,-0.934249,0,-0.12216,-0.99251,0,-0.12216,-0.99251,0,-0.12216,-0.99251,0,-0.12216,-0.99251,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122156,-0.992511,0,0.122156,-0.992511,0,0.122156,-0.992511,0,0.122156,-0.992511,0,0.356619,-0.93425,0,0.356619,-0.93425,0,0.356619,-0.93425,0,0.356619,-0.93425,0,0.561567,-0.827431,0,0.561567,-0.827431,0,0.561567,-0.827431,0,0.561567,-0.827431,0,0.729586,-0.683889,0,0.729586,-0.683889,0,0.729586,-0.683889,0,0.729584,-0.683891,0,0.729584,-0.683891,0,0.729584,-0.683891,0,0.858897,-0.512149,0,0.858897,-0.512149,0,0.858897,-0.512149,0,0.858898,-0.512146,0,0.858898,-0.512146,0,0.858898,-0.512146,0,0.948086,-0.318015,0,0.948086,-0.318015,0,0.948086,-0.318015,0,0.948085,-0.318018,0,0.948085,-0.318018,0,0.948085,-0.318018,0,0.994203,-0.107522,0,0.994203,-0.107522,0,0.994203,-0.107522,0,0.994203,-0.107522,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,0.994205,0.107501,0,0.994205,0.107501,0,0.994205,0.107501,0,0.994205,0.107501,0,0.948099,0.317974,0,0.948099,0.317974,0,0.948099,0.317974,0,0.948099,0.317974,0,0.858885,0.512168,0,0.858885,0.512168,0,0.858885,0.512168,0,0.858885,0.512168,0,0.729597,0.683878,0,0.729597,0.683878,0,0.729597,0.683878,0,0.729597,0.683878,0,0.561515,0.827467,0,0.561515,0.827467,0,0.561515,0.827467,0,0.561515,0.827467,0,0.356627,0.934247,0,0.356627,0.934247,0,0.356627,0.934247,0,0.356627,0.934247,0,0.122164,0.99251,0,0.122164,0.99251,0,0.122164,0.99251,0,0.122166,0.99251,0,0.122166,0.99251,0,0.122166,0.99251,0,0,1,0,0,1,0,0,1,0,0,1,0.000001,0,1,0.000001,0,1,0.000001,-0.122162,0.99251,0,-0.122162,0.99251,0,-0.122162,0.99251,0,-0.122163,0.99251,0,-0.122163,0.99251,0,-0.122163,0.99251,0,-0.356627,0.934247,0,-0.356627,0.934247,0,-0.356627,0.934247,0,-0.356627,0.934247,0,-0.561544,0.827447,0,-0.561544,0.827447,0,-0.561544,0.827447,0,-0.561543,0.827448,0,-0.561543,0.827448,0,-0.561543,0.827448,0,-0.729573,0.683902,0,-0.729573,0.683902,0,-0.729573,0.683902,0,-0.729574,0.683902,0,-0.729574,0.683902,0,-0.729574,0.683902,0,-0.858897,0.512149,0,-0.858897,0.512149,0,-0.858897,0.512149,0,-0.858897,0.512149,0,-0.948092,0.317996,0,-0.948092,0.317996,0,-0.948092,0.317996,0,-0.948092,0.317996,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-0.994203,0.107522,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-0.994203,-0.107522,0,-0.994203,-0.107522,0,-0.994203,-0.107522,0,-0.994203,-0.107522,0,-0.948093,-0.317993,0,-0.948093,-0.317993,0,-0.948093,-0.317993,0,-0.948093,-0.317993,0,-0.858907,-0.512132,0,-0.858907,-0.512132,0,-0.858907,-0.512132,0,-0.858905,-0.512134,0,-0.858905,-0.512134,0,-0.858905,-0.512134,0,-0.729595,-0.683879,0,-0.729595,-0.683879,0,-0.729595,-0.683879,0,-0.729595,-0.683879,0,-0.561537,-0.827452,0,-0.561537,-0.827452,0,-0.561537,-0.827452,0,-0.561537,-0.827452,0,-0.356614,-0.934252,0,-0.356614,-0.934252,0,-0.356614,-0.934252,0,-0.356614,-0.934252,0,-0.122162,-0.99251,-0.000001,-0.122162,-0.99251,-0.000001,-0.122162,-0.99251,-0.000001,-0.122167,-0.992509,0,-0.122167,-0.992509,0,-0.122167,-0.992509,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0.12217,-0.992509,-0.000001,0.12217,-0.992509,-0.000001,0.12217,-0.992509,-0.000001,0.122164,-0.99251,-0.000001,0.122164,-0.99251,-0.000001,0.122164,-0.99251,-0.000001,0.356612,-0.934253,-0.000001,0.356612,-0.934253,-0.000001,0.356612,-0.934253,-0.000001,0.356612,-0.934253,-0.000001,0.561541,-0.827449,0,0.561541,-0.827449,0,0.561541,-0.827449,0,0.561545,-0.827446,-0.000001,0.561545,-0.827446,-0.000001,0.561545,-0.827446,-0.000001,0.72961,-0.683864,-0.000001,0.72961,-0.683864,-0.000001,0.72961,-0.683864,-0.000001,0.729607,-0.683867,0,0.729607,-0.683867,0,0.729607,-0.683867,0,0.858885,-0.512168,0,0.858885,-0.512168,0,0.858885,-0.512168,0,0.858888,-0.512163,-0.000001,0.858888,-0.512163,-0.000001,0.858888,-0.512163,-0.000001,0.948093,-0.317995,0,0.948093,-0.317995,0,0.948093,-0.317995,0,0.948093,-0.317995,0,0.994203,-0.107522,0,0.994203,-0.107522,0,0.994203,-0.107522,0,0.994203,-0.107522,0,1,0,0,1,0,0,1,0,0,1,0,0,0.9942,0.107543,0,0.9942,0.107543,0,0.9942,0.107543,0,0.9942,0.107543,0,0.948106,0.317954,0,0.948106,0.317954,0,0.948106,0.317954,0,0.948106,0.317955,0,0.948106,0.317955,0,0.948106,0.317955,0,0.858875,0.512185,0,0.858875,0.512185,0,0.858875,0.512185,0,0.858875,0.512185,0,0.729586,0.683889,0,0.729586,0.683889,0,0.729586,0.683889,0,0.729585,0.68389,0,0.729585,0.68389,0,0.729585,0.68389,0,0.561548,0.827444,0,0.561548,0.827444,0,0.561548,0.827444,0,0.561551,0.827442,0,0.561551,0.827442,0,0.561551,0.827442,0,0.356627,0.934247,0.000001,0.356627,0.934247,0.000001,0.356627,0.934247,0.000001,0.356623,0.934248,0,0.356623,0.934248,0,0.356623,0.934248,0,0.122162,0.99251,0.000001,0.122162,0.99251,0.000001,0.122162,0.99251,0.000001,0.122162,0.99251,0.000001,0,1,0,0,1,0,0,1,0,0,1,0.000001,0,1,0.000001,0,1,0.000001,-0.122173,0.992509,0,-0.122173,0.992509,0,-0.122173,0.992509,0,-0.122174,0.992509,0,-0.122174,0.992509,0,-0.122174,0.992509,0,-0.356596,0.934259,0,-0.356596,0.934259,0,-0.356596,0.934259,0,-0.356596,0.934259,0,-0.561544,0.827447,0,-0.561544,0.827447,0,-0.561544,0.827447,0,-0.561544,0.827447,0,-0.729597,0.683878,0,-0.729597,0.683878,0,-0.729597,0.683878,0,-0.729597,0.683878,0,-0.858876,0.512183,0,-0.858876,0.512183,0,-0.858876,0.512183,0,-0.858876,0.512183,0,-0.948099,0.317975,0,-0.948099,0.317975,0,-0.948099,0.317975,0,-0.948099,0.317975,0,-0.994205,0.107501,0,-0.994205,0.107501,0,-0.994205,0.107501,0,-0.994205,0.107501,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-0.994203,-0.107522,0,-0.994203,-0.107522,0,-0.994203,-0.107522,0,-0.994203,-0.107522,0,-0.948086,-0.318013,0,-0.948086,-0.318013,0,-0.948086,-0.318013,0,-0.948086,-0.318013,0,-0.858936,-0.512084,0,-0.858936,-0.512084,0,-0.858936,-0.512084,0,-0.858936,-0.512084,0,-0.729575,-0.683901,0,-0.729575,-0.683901,0,-0.729575,-0.683901,0,-0.729575,-0.683901,0,-0.561548,-0.827444,0,-0.561548,-0.827444,0,-0.561548,-0.827444,0,-0.561548,-0.827444,0,-0.356617,-0.934251,0,-0.356617,-0.934251,0,-0.356617,-0.934251,0,-0.356617,-0.934251,0,-0.122167,-0.992509,0,-0.122167,-0.992509,0,-0.122167,-0.992509,0,-0.122167,-0.992509,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0,-1,0,0,-1,0,0.122162,-0.99251,0,0.122162,-0.99251,0,0.122162,-0.99251,0,0.122173,-0.992509,-0.000001,0.122173,-0.992509,-0.000001,0.122173,-0.992509,-0.000001,0.356612,-0.934253,0,0.356612,-0.934253,0,0.356612,-0.934253,0,0.356612,-0.934253,0,0.561596,-0.827412,0,0.561596,-0.827412,0,0.561596,-0.827412,0,0.561592,-0.827415,0,0.561592,-0.827415,0,0.561592,-0.827415,0,0.729575,-0.683901,0,0.729575,-0.683901,0,0.729575,-0.683901,0,0.729578,-0.683898,0,0.729578,-0.683898,0,0.729578,-0.683898,0,0.858898,-0.512146,-0.000001,0.858898,-0.512146,-0.000001,0.858898,-0.512146,-0.000001,0.858895,-0.512151,0,0.858895,-0.512151,0,0.858895,-0.512151,0,0.948072,-0.318057,0,0.948072,-0.318057,0,0.948072,-0.318057,0,0.948072,-0.318057,0,0.994203,-0.107523,0,0.994203,-0.107523,0,0.994203,-0.107523,0,0.994203,-0.107522,0,0.994203,-0.107522,0,0.994203,-0.107522,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.948072,0.318055,0,0.948072,0.318055,0,0.948072,0.318055,0,0.948072,0.318056,0,0.948072,0.318056,0,0.948072,0.318056,0,0.858895,0.512151,0,0.858895,0.512151,0,0.858895,0.512151,0,0.858895,0.512152,0,0.858895,0.512152,0,0.858895,0.512152,0,0.729573,0.683902,0,0.729573,0.683902,0,0.729573,0.683902,0,0.729574,0.683902,0,0.729574,0.683902,0,0.729574,0.683902,0,0.561559,0.827437,0,0.561559,0.827437,0,0.561559,0.827437,0,0.561562,0.827435,0,0.561562,0.827435,0,0.561562,0.827435,0,0.356644,0.93424,0.000001,0.356644,0.93424,0.000001,0.356644,0.93424,0.000001,0.356639,0.934242,0,0.356639,0.934242,0,0.356639,0.934242,0,0.122159,0.992511,0.000001,0.122159,0.992511,0.000001,0.122159,0.992511,0.000001,0.122159,0.992511,0.000001,0,1,0,0,1,0,0,1,0,0,1,0,-0.122167,0.99251,0,-0.122167,0.99251,0,-0.122167,0.99251,0,-0.122167,0.99251,0,-0.356627,0.934247,0,-0.356627,0.934247,0,-0.356627,0.934247,0,-0.356627,0.934247,0,-0.561544,0.827447,0,-0.561544,0.827447,0,-0.561544,0.827447,0,-0.561543,0.827448,0,-0.561543,0.827448,0,-0.561543,0.827448,0,-0.729573,0.683902,0,-0.729573,0.683902,0,-0.729573,0.683902,0,-0.729574,0.683902,0,-0.729574,0.683902,0,-0.729574,0.683902,0,-0.858906,0.512134,0,-0.858906,0.512134,0,-0.858906,0.512134,0,-0.858905,0.512135,0,-0.858905,0.512135,0,-0.858905,0.512135,0,-0.948093,0.317994,0,-0.948093,0.317994,0,-0.948093,0.317994,0,-0.948093,0.317994,0,-0.9942,0.107544,0,-0.9942,0.107544,0,-0.9942,0.107544,0,-0.9942,0.107544,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-0.994205,-0.107501,0,-0.994205,-0.107501,0,-0.994205,-0.107501,0,-0.994205,-0.1075,0,-0.994205,-0.1075,0,-0.994205,-0.1075,0,-0.948093,-0.317993,0,-0.948093,-0.317993,0,-0.948093,-0.317993,0,-0.948093,-0.317993,0,-0.858887,-0.512166,0,-0.858887,-0.512166,0,-0.858887,-0.512166,0,-0.858885,-0.512168,0,-0.858885,-0.512168,0,-0.858885,-0.512168,0,-0.729595,-0.683879,0,-0.729595,-0.683879,0,-0.729595,-0.683879,0,-0.729595,-0.683879,0,-0.561515,-0.827467,0,-0.561515,-0.827467,0,-0.561515,-0.827467,0,-0.561515,-0.827467,0,-0.356638,-0.934243,0,-0.356638,-0.934243,0,-0.356638,-0.934243,0,-0.356638,-0.934243,0,-0.122159,-0.992511,0,-0.122159,-0.992511,0,-0.122159,-0.992511,0,-0.122159,-0.992511,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122166,-0.99251,0,0.122166,-0.99251,0,0.122166,-0.99251,0,0.122166,-0.99251,0,0.356616,-0.934251,0,0.356616,-0.934251,0,0.356616,-0.934251,0,0.356616,-0.934251,0,0.561535,-0.827453,0,0.561535,-0.827453,0,0.561535,-0.827453,0,0.561531,-0.827456,0,0.561531,-0.827456,0,0.561531,-0.827456,0,0.729598,-0.683876,0,0.729598,-0.683876,0,0.729598,-0.683876,0,0.729601,-0.683873,0,0.729601,-0.683873,0,0.729601,-0.683873,0,0.858903,-0.512138,-0.000001,0.858903,-0.512138,-0.000001,0.858903,-0.512138,-0.000001,0.8589,-0.512143,0,0.8589,-0.512143,0,0.8589,-0.512143,0,0.948089,-0.318006,0,0.948089,-0.318006,0,0.948089,-0.318006,0,0.948089,-0.318006,0,0.994203,-0.107523,0,0.994203,-0.107523,0,0.994203,-0.107523,0,0.994203,-0.107522,0,0.994203,-0.107522,0,0.994203,-0.107522,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.994203,0.107522,0,0.948089,0.318005,0,0.948089,0.318005,0,0.948089,0.318005,0,0.948089,0.318006,0,0.948089,0.318006,0,0.948089,0.318006,0,0.8589,0.512142,0,0.8589,0.512142,0,0.8589,0.512142,0,0.8589,0.512143,0,0.8589,0.512143,0,0.8589,0.512143,0,0.729591,0.683884,0,0.729591,0.683884,0,0.729591,0.683884,0,0.729592,0.683883,0,0.729592,0.683883,0,0.729592,0.683883,0,0.561531,0.827456,0,0.561531,0.827456,0,0.561531,0.827456,0,0.561534,0.827453,0,0.561534,0.827453,0,0.561534,0.827453,0,0.356625,0.934248,0,0.356625,0.934248,0,0.356625,0.934248,0,0.356623,0.934248,0,0.356623,0.934248,0,0.356623,0.934248,0,0.122163,0.99251,0,0.122163,0.99251,0,0.122163,0.99251,0,0.122163,0.99251,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122162,0.99251,0,-0.122162,0.99251,0,-0.122162,0.99251,0,-0.122164,0.99251,0,-0.122164,0.99251,0,-0.122164,0.99251,0,-0.356609,0.934254,0,-0.356609,0.934254,0,-0.356609,0.934254,0,-0.356606,0.934255,0,-0.356606,0.934255,0,-0.356606,0.934255,0,-0.561596,0.827412,0,-0.561596,0.827412,0,-0.561596,0.827412,0,-0.561596,0.827412,0,-0.729585,0.68389,0,-0.729585,0.68389,0,-0.729585,0.68389,0,-0.729585,0.68389,0,-0.858887,0.512166,0,-0.858887,0.512166,0,-0.858887,0.512166,0,-0.858887,0.512166,0,-0.948099,0.317975,0,-0.948099,0.317975,0,-0.948099,0.317975,0,-0.9481,0.317974,0,-0.9481,0.317974,0,-0.9481,0.317974,0,-0.994196,0.107587,0,-0.994196,0.107587,0,-0.994196,0.107587,0,-0.994196,0.107587,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.994205,-0.107501,0,-0.994205,-0.107501,0,-0.994205,-0.107501,0,-0.994205,-0.107501,0,-0.948092,-0.317996,0,-0.948092,-0.317996,0,-0.948092,-0.317996,0,-0.948093,-0.317993,0,-0.948093,-0.317993,0,-0.948093,-0.317993,0,-0.858865,-0.512202,0,-0.858865,-0.512202,0,-0.858865,-0.512202,0,-0.858866,-0.5122,0,-0.858866,-0.5122,0,-0.858866,-0.5122,0,-0.729621,-0.683851,0,-0.729621,-0.683851,0,-0.729621,-0.683851,0,-0.729619,-0.683854,0,-0.729619,-0.683854,0,-0.729619,-0.683854,0,-0.561515,-0.827467,0,-0.561515,-0.827467,0,-0.561515,-0.827467,0,-0.561515,-0.827467,0,-0.356638,-0.934243,0,-0.356638,-0.934243,0,-0.356638,-0.934243,0,-0.356638,-0.934243,0,-0.122159,-0.992511,0,-0.122159,-0.992511,0,-0.122159,-0.992511,0,-0.122159,-0.992511,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122167,-0.99251,0,0.122167,-0.99251,0,0.122167,-0.99251,0,0.122167,-0.99251,0,0.35664,-0.934242,-0.000001,0.35664,-0.934242,-0.000001,0.35664,-0.934242,-0.000001,0.356635,-0.934244,0,0.356635,-0.934244,0,0.356635,-0.934244,0,0.561493,-0.827482,0,0.561493,-0.827482,0,0.561493,-0.827482,0,0.561493,-0.827482,0,0.729613,-0.683861,0,0.729613,-0.683861,0,0.729613,-0.683861,0,0.729615,-0.683858,0,0.729615,-0.683858,0,0.729615,-0.683858,0,0.858885,-0.512168,0,0.858885,-0.512168,0,0.858885,-0.512168,0,0.858885,-0.512168,0,0.948099,-0.317976,0,0.948099,-0.317976,0,0.948099,-0.317976,0,0.948099,-0.317976,0,0.9942,-0.107543,0,0.9942,-0.107543,0,0.9942,-0.107543,0,0.9942,-0.107543,0,1,0,0,1,0,0,1,0,0,1,0,0,0.9942,0.107543,0,0.9942,0.107543,0,0.9942,0.107543,0,0.9942,0.107544,0,0.9942,0.107544,0,0.9942,0.107544,0,0.948099,0.317975,0,0.948099,0.317975,0,0.948099,0.317975,0,0.9481,0.317974,0,0.9481,0.317974,0,0.9481,0.317974,0,0.858896,0.51215,0,0.858896,0.51215,0,0.858896,0.51215,0,0.858896,0.51215,0,0.729597,0.683878,0,0.729597,0.683878,0,0.729597,0.683878,0,0.729598,0.683876,0,0.729598,0.683876,0,0.729598,0.683876,0,0.561541,0.827449,0,0.561541,0.827449,0,0.561541,0.827449,0,0.561539,0.827451,0,0.561539,0.827451,0,0.561539,0.827451,0,0.356599,0.934258,0,0.356599,0.934258,0,0.356599,0.934258,0,0.356601,0.934257,0,0.356601,0.934257,0,0.356601,0.934257,0,0.122173,0.992509,0,0.122173,0.992509,0,0.122173,0.992509,0,0.122173,0.992509,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122159,0.992511,0,-0.122159,0.992511,0,-0.122159,0.992511,0,-0.122156,0.992511,0,-0.122156,0.992511,0,-0.122156,0.992511,0,-0.356622,0.934249,0,-0.356622,0.934249,0,-0.356622,0.934249,0,-0.356625,0.934248,0,-0.356625,0.934248,0,-0.356625,0.934248,0,-0.561552,0.827442,0,-0.561552,0.827442,0,-0.561552,0.827442,0,-0.56155,0.827443,0,-0.56155,0.827443,0,-0.56155,0.827443,0,-0.729573,0.683903,0,-0.729573,0.683903,0,-0.729573,0.683903,0,-0.729573,0.683903,0,-0.858926,0.512099,0,-0.858926,0.512099,0,-0.858926,0.512099,0,-0.858928,0.512097,0,-0.858928,0.512097,0,-0.858928,0.512097,0,-0.948086,0.318015,0,-0.948086,0.318015,0,-0.948086,0.318015,0,-0.948086,0.318015,0,-0.9942,0.107543,0,-0.9942,0.107543,0,-0.9942,0.107543,0,-0.9942,0.107544,0,-0.9942,0.107544,0,-0.9942,0.107544,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.9942,-0.107543,0,-0.9942,-0.107543,0,-0.9942,-0.107543,0,-0.9942,-0.107543,0,-0.948099,-0.317976,0,-0.948099,-0.317976,0,-0.948099,-0.317976,0,-0.948099,-0.317976,0,-0.858905,-0.512134,0,-0.858905,-0.512134,0,-0.858905,-0.512134,0,-0.858905,-0.512134,0,-0.729575,-0.683901,0,-0.729575,-0.683901,0,-0.729575,-0.683901,0,-0.729575,-0.683901,0,-0.561508,-0.827471,0,-0.561508,-0.827471,0,-0.561508,-0.827471,0,-0.561512,-0.827469,0,-0.561512,-0.827469,0,-0.561512,-0.827469,0,-0.356651,-0.934238,-0.000001,-0.356651,-0.934238,-0.000001,-0.356651,-0.934238,-0.000001,-0.356651,-0.934238,-0.000001,-0.122159,-0.992511,0,-0.122159,-0.992511,0,-0.122159,-0.992511,0,-0.122153,-0.992511,-0.000001,-0.122153,-0.992511,-0.000001,-0.122153,-0.992511,-0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.122167,-0.992509,0,0.122167,-0.992509,0,0.122167,-0.992509,0,0.122167,-0.992509,0,0.356604,-0.934256,0,0.356604,-0.934256,0,0.356604,-0.934256,0,0.356604,-0.934256,0,0.561523,-0.827461,0,0.561523,-0.827461,0,0.561523,-0.827461,0,0.561523,-0.827461,0,0.729572,-0.683904,0,0.729572,-0.683904,0,0.729572,-0.683904,0,0.729572,-0.683904,0,0.858939,-0.512079,0,0.858939,-0.512079,0,0.858939,-0.512079,0,0.858939,-0.512079,0,0.948099,-0.317975,0,0.948099,-0.317975,0,0.948099,-0.317975,0,0.948099,-0.317976,0,0.948099,-0.317976,0,0.948099,-0.317976,0,0.994203,-0.107522,0,0.994203,-0.107522,0,0.994203,-0.107522,0,0.994203,-0.107522,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994196,0.107585,0,0.994196,0.107585,0,0.994196,0.107585,0,0.994196,0.107587,0,0.994196,0.107587,0,0.994196,0.107587,0,0.948119,0.317916,0,0.948119,0.317916,0,0.948119,0.317916,0,0.94812,0.317913,0,0.94812,0.317913,0,0.94812,0.317913,0,0.858897,0.512149,0,0.858897,0.512149,0,0.858897,0.512149,0,0.858895,0.512151,0,0.858895,0.512151,0,0.858895,0.512151,0,0.729598,0.683876,0,0.729598,0.683876,0,0.729598,0.683876,0,0.729597,0.683878,0,0.729597,0.683878,0,0.729597,0.683878,0,0.561539,0.827451,0,0.561539,0.827451,0,0.561539,0.827451,0,0.561541,0.827449,0,0.561541,0.827449,0,0.561541,0.827449,0,0.356609,0.934254,0,0.356609,0.934254,0,0.356609,0.934254,0,0.356606,0.934255,0,0.356606,0.934255,0,0.356606,0.934255,0,0.122164,0.99251,0,0.122164,0.99251,0,0.122164,0.99251,0,0.122167,0.992509,0,0.122167,0.992509,0,0.122167,0.992509,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122162,0.99251,0,-0.122162,0.99251,0,-0.122162,0.99251,0,-0.122162,0.99251,0,-0.356625,0.934248,0,-0.356625,0.934248,0,-0.356625,0.934248,0,-0.356625,0.934248,0,-0.56155,0.827443,0,-0.56155,0.827443,0,-0.56155,0.827443,0,-0.561552,0.827442,0,-0.561552,0.827442,0,-0.561552,0.827442,0,-0.729575,0.683901,0,-0.729575,0.683901,0,-0.729575,0.683901,0,-0.729573,0.683903,0,-0.729573,0.683903,0,-0.729573,0.683903,0,-0.858925,0.512101,0,-0.858925,0.512101,0,-0.858925,0.512101,0,-0.858927,0.512098,0,-0.858927,0.512098,0,-0.858927,0.512098,0,-0.948072,0.318055,0,-0.948072,0.318055,0,-0.948072,0.318055,0,-0.948072,0.318055,0,-0.994205,0.107501,0,-0.994205,0.107501,0,-0.994205,0.107501,0,-0.994205,0.107502,0,-0.994205,0.107502,0,-0.994205,0.107502,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.9942,-0.107543,0,-0.9942,-0.107543,0,-0.9942,-0.107543,0,-0.9942,-0.107543,0,-0.948099,-0.317975,0,-0.948099,-0.317975,0,-0.948099,-0.317975,0,-0.9481,-0.317973,0,-0.9481,-0.317973,0,-0.9481,-0.317973,0,-0.858865,-0.512202,0,-0.858865,-0.512202,0,-0.858865,-0.512202,0,-0.858865,-0.512202,0,-0.729642,-0.683829,0,-0.729642,-0.683829,0,-0.729642,-0.683829,0,-0.729642,-0.683829,0,-0.561504,-0.827474,0,-0.561504,-0.827474,0,-0.561504,-0.827474,0,-0.561504,-0.827474,0,-0.356645,-0.93424,0,-0.356645,-0.93424,0,-0.356645,-0.93424,0,-0.356645,-0.93424,0,-0.122159,-0.992511,-0.000001,-0.122159,-0.992511,-0.000001,-0.122159,-0.992511,-0.000001,-0.122164,-0.99251,0,-0.122164,-0.99251,0,-0.122164,-0.99251,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0.122164,-0.99251,0,0.122164,-0.99251,0,0.122164,-0.99251,0,0.12217,-0.992509,-0.000001,0.12217,-0.992509,-0.000001,0.12217,-0.992509,-0.000001,0.356635,-0.934244,0,0.356635,-0.934244,0,0.356635,-0.934244,0,0.356635,-0.934244,0,0.561526,-0.827459,0,0.561526,-0.827459,0,0.561526,-0.827459,0,0.561526,-0.827459,0,0.729531,-0.683948,0,0.729531,-0.683948,0,0.729531,-0.683948,0,0.729531,-0.683948,0,0.858947,-0.512064,0,0.858947,-0.512064,0,0.858947,-0.512064,0,0.858946,-0.512067,0,0.858946,-0.512067,0,0.858946,-0.512067,0,0.948099,-0.317976,0,0.948099,-0.317976,0,0.948099,-0.317976,0,0.9481,-0.317973,0,0.9481,-0.317973,0,0.9481,-0.317973,0,0.994191,-0.107629,0,0.994191,-0.107629,0,0.994191,-0.107629,0,0.994191,-0.107629,0,1,0,0,1,0,0,1,0,0,1,0,0,0.9942,0.107543,0,0.9942,0.107543,0,0.9942,0.107543,0,0.9942,0.107543,0,0.948045,0.318136,0,0.948045,0.318136,0,0.948045,0.318136,0,0.948045,0.318135,0,0.948045,0.318135,0,0.948045,0.318135,0,0.858947,0.512064,0,0.858947,0.512064,0,0.858947,0.512064,0,0.858946,0.512065,0,0.858946,0.512065,0,0.858946,0.512065,0,0.72962,0.683853,0,0.72962,0.683853,0,0.72962,0.683853,0,0.72962,0.683853,0,0.561508,0.827471,0,0.561508,0.827471,0,0.561508,0.827471,0,0.561508,0.827471,0,0.356622,0.934249,0,0.356622,0.934249,0,0.356622,0.934249,0,0.356622,0.934249,0,0.12217,0.992509,0,0.12217,0.992509,0,0.12217,0.992509,0,0.122167,0.99251,0,0.122167,0.99251,0,0.122167,0.99251,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.122163,0.99251,0,-0.122163,0.99251,0,-0.122163,0.99251,0,-0.122162,0.99251,0,-0.122162,0.99251,0,-0.122162,0.99251,0,-0.356608,0.934254,0,-0.356608,0.934254,0,-0.356608,0.934254,0,-0.356609,0.934254,0,-0.356609,0.934254,0,-0.356609,0.934254,0,-0.561551,0.827442,0,-0.561551,0.827442,0,-0.561551,0.827442,0,-0.561551,0.827442,0,-0.729574,0.683902,0,-0.729574,0.683902,0,-0.729574,0.683902,0,-0.729576,0.6839,0,-0.729576,0.6839,0,-0.729576,0.6839,0,-0.858927,0.512098,0,-0.858927,0.512098,0,-0.858927,0.512098,0,-0.858926,0.5121,0,-0.858926,0.5121,0,-0.858926,0.5121,0,-0.948085,0.318016,0,-0.948085,0.318016,0,-0.948085,0.318016,0,-0.948085,0.318016,0,-0.9942,0.107543,0,-0.9942,0.107543,0,-0.9942,0.107543,0,-0.9942,0.107543,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.9942,-0.107543,0,-0.9942,-0.107543,0,-0.9942,-0.107543,0,-0.9942,-0.107544,0,-0.9942,-0.107544,0,-0.9942,-0.107544,0,-0.948099,-0.317975,0,-0.948099,-0.317975,0,-0.948099,-0.317975,0,-0.9481,-0.317974,0,-0.9481,-0.317974,0,-0.9481,-0.317974,0,-0.858906,-0.512133,0,-0.858906,-0.512133,0,-0.858906,-0.512133,0,-0.858907,-0.512132,0,-0.858907,-0.512132,0,-0.858907,-0.512132,0,-0.729576,-0.6839,0,-0.729576,-0.6839,0,-0.729576,-0.6839,0,-0.729573,-0.683903,0,-0.729573,-0.683903,0,-0.729573,-0.683903,0,-0.561528,-0.827458,0,-0.561528,-0.827458,0,-0.561528,-0.827458,0,-0.561528,-0.827458,0,-0.35664,-0.934242,0,-0.35664,-0.934242,0,-0.35664,-0.934242,0,-0.35664,-0.934242,0,-0.122156,-0.992511,0,-0.122156,-0.992511,0,-0.122156,-0.992511,0,-0.122156,-0.992511,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.12217,-0.992509,0,0.12217,-0.992509,0,0.12217,-0.992509,0,0.12217,-0.992509,0,0.356609,-0.934254,0,0.356609,-0.934254,0,0.356609,-0.934254,0,0.356609,-0.934254,0,0.561526,-0.827459,0,0.561526,-0.827459,0,0.561526,-0.827459,0,0.561528,-0.827458,0,0.561528,-0.827458,0,0.561528,-0.827458,0,0.729576,-0.6839,0,0.729576,-0.6839,0,0.729576,-0.6839,0,0.729575,-0.683901,0,0.729575,-0.683901,0,0.729575,-0.683901,0,0.858925,-0.512101,0,0.858925,-0.512101,0,0.858925,-0.512101,0,0.858925,-0.512101,0,0.9481,-0.317974,0,0.9481,-0.317974,0,0.9481,-0.317974,0,0.948099,-0.317975,0,0.948099,-0.317975,0,0.948099,-0.317975,0,0.994203,-0.107522,0,0.994203,-0.107522,0,0.994203,-0.107522,0,0.994203,-0.107522,0,1,0,0,1,0,0,1,0,0,1,0,0,0.994193,0.107607,0,0.994193,0.107607,0,0.994193,0.107607,0,0.994193,0.107607,0,0.948119,0.317915,0,0.948119,0.317915,0,0.948119,0.317915,0,0.948119,0.317915,0,0.858905,0.512135,0,0.858905,0.512135,0,0.858905,0.512135,0,0.858906,0.512134,0,0.858906,0.512134,0,0.858906,0.512134,0,0.729599,0.683875,0,0.729599,0.683875,0,0.729599,0.683875,0,0.729599,0.683875,0,0.561526,0.827459,0,0.561526,0.827459,0,0.561526,0.827459,0,0.561526,0.827459,0,0.356615,0.934251,0,0.356615,0.934251,0,0.356615,0.934251,0,0.356615,0.934251,0,0.122164,0.99251,0,0.122164,0.99251,0,0.122164,0.99251,0,0.122166,0.99251,0,0.122166,0.99251,0,0.122166,0.99251,0,-0.000012,0.000004,-1,-0.000012,0.000004,-1,-0.000012,0.000004,-1,-0.000004,0.000002,-1,-0.000004,0.000002,-1,-0.000004,0.000002,-1,-0.000002,0.000002,-1,-0.000002,0.000002,-1,-0.000002,0.000002,-1,-0.000001,0.000001,-1,-0.000001,0.000001,-1,-0.000001,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000002,0,-1,-0.000002,0,-1,-0.000002,0,-1,0,0,-1,0,0,-1,0,0.000001,-1,0,0.000001,-1,0.000003,0.000003,-1,0.000003,0.000003,-1,0.000003,0.000003,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000003,-0.000002,-1,-0.000003,-0.000002,-1,-0.000003,-0.000002,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000003,0.000002,-1,0.000003,0.000002,-1,0.000003,0.000002,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000013,0.000001,-1,-0.000013,0.000001,-1,-0.000013,0.000001,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000003,-0.000003,-1,0.000003,-0.000003,-1,0.000003,-0.000003,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000003,-0.000002,-1,-0.000003,-0.000002,-1,-0.000003,-0.000002,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000003,0.000002,-1,0.000003,0.000002,-1,0.000003,0.000002,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000013,0.000001,-1,-0.000013,0.000001,-1,-0.000013,0.000001,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000003,-0.000003,-1,0.000003,-0.000003,-1,0.000003,-0.000003,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000003,-0.000002,-1,-0.000003,-0.000002,-1,-0.000003,-0.000002,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000003,0.000002,-1,0.000003,0.000002,-1,0.000003,0.000002,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000013,0.000001,-1,-0.000013,0.000001,-1,-0.000013,0.000001,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000003,-0.000003,-1,0.000003,-0.000003,-1,0.000003,-0.000003,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000003,-0.000002,-1,-0.000003,-0.000002,-1,-0.000003,-0.000002,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000003,0.000002,-1,0.000003,0.000002,-1,0.000003,0.000002,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000013,0.000001,-1,-0.000013,0.000001,-1,-0.000013,0.000001,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000003,-0.000002,-1,0.000003,-0.000002,-1,0.000003,-0.000002,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000012,0.000004,-1,-0.000012,0.000004,-1,-0.000012,0.000004,-1,-0.000004,0.000002,-1,-0.000004,0.000002,-1,-0.000004,0.000002,-1,-0.000002,0.000002,-1,-0.000002,0.000002,-1,-0.000002,0.000002,-1,-0.000001,0.000001,-1,-0.000001,0.000001,-1,-0.000001,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000003,0.000002,-1,-0.000003,0.000002,-1,-0.000003,0.000002,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000013,0.000001,-1,-0.000013,0.000001,-1,-0.000013,0.000001,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000003,-0.000003,-1,0.000003,-0.000003,-1,0.000003,-0.000003,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000004,-0.000011,-1,-0.000004,-0.000011,-1,-0.000004,-0.000011,-1,-0.000002,-0.000003,-1,-0.000002,-0.000003,-1,-0.000002,-0.000003,-1,-0.000002,-0.000002,-1,-0.000002,-0.000002,-1,-0.000002,-0.000002,-1,-0.000001,-0.000001,-1,-0.000001,-0.000001,-1,-0.000001,-0.000001,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000003,0.000002,-1,0.000003,0.000002,-1,0.000003,0.000002,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000013,0.000001,-1,-0.000013,0.000001,-1,-0.000013,0.000001,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000003,-0.000003,-1,0.000003,-0.000003,-1,0.000003,-0.000003,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000004,-0.000011,-1,-0.000004,-0.000011,-1,-0.000004,-0.000011,-1,-0.000002,-0.000003,-1,-0.000002,-0.000003,-1,-0.000002,-0.000003,-1,-0.000002,-0.000002,-1,-0.000002,-0.000002,-1,-0.000002,-0.000002,-1,-0.000001,-0.000001,-1,-0.000001,-0.000001,-1,-0.000001,-0.000001,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000003,0.000002,-1,0.000003,0.000002,-1,0.000003,0.000002,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000013,0.000001,-1,-0.000013,0.000001,-1,-0.000013,0.000001,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000003,-0.000002,-1,0.000003,-0.000002,-1,0.000003,-0.000002,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000004,-0.000011,-1,-0.000004,-0.000011,-1,-0.000004,-0.000011,-1,-0.000002,-0.000003,-1,-0.000002,-0.000003,-1,-0.000002,-0.000003,-1,-0.000002,-0.000002,-1,-0.000002,-0.000002,-1,-0.000002,-0.000002,-1,-0.000001,-0.000001,-1,-0.000001,-0.000001,-1,-0.000001,-0.000001,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000003,0.000002,-1,0.000003,0.000002,-1,0.000003,0.000002,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000013,0.000001,-1,-0.000013,0.000001,-1,-0.000013,0.000001,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000003,-0.000003,-1,0.000003,-0.000003,-1,0.000003,-0.000003,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000004,-0.000011,-1,-0.000004,-0.000011,-1,-0.000004,-0.000011,-1,-0.000002,-0.000003,-1,-0.000002,-0.000003,-1,-0.000002,-0.000003,-1,-0.000002,-0.000002,-1,-0.000002,-0.000002,-1,-0.000002,-0.000002,-1,-0.000001,-0.000001,-1,-0.000001,-0.000001,-1,-0.000001,-0.000001,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000003,0.000002,-1,0.000003,0.000002,-1,0.000003,0.000002,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000013,0.000001,-1,-0.000013,0.000001,-1,-0.000013,0.000001,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000003,-0.000002,-1,0.000003,-0.000002,-1,0.000003,-0.000002,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000004,-0.000011,-1,-0.000004,-0.000011,-1,-0.000004,-0.000011,-1,-0.000002,-0.000003,-1,-0.000002,-0.000003,-1,-0.000002,-0.000003,-1,-0.000002,-0.000002,-1,-0.000002,-0.000002,-1,-0.000002,-0.000002,-1,-0.000001,-0.000001,-1,-0.000001,-0.000001,-1,-0.000001,-0.000001,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000003,0.000002,-1,0.000003,0.000002,-1,0.000003,0.000002,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000013,0.000001,-1,-0.000013,0.000001,-1,-0.000013,0.000001,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000003,-0.000002,-1,0.000003,-0.000002,-1,0.000003,-0.000002,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000003,-0.000002,-1,0.000003,-0.000002,-1,0.000003,-0.000002,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0,-1,0,0,-1,-0.000003,0.000002,-1,-0.000003,0.000002,-1,-0.000003,0.000002,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000013,0.000001,-1,0.000013,0.000001,-1,0.000013,0.000001,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000003,-0.000003,-1,-0.000003,-0.000003,-1,-0.000003,-0.000003,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000012,0.000004,-1,0.000012,0.000004,-1,0.000012,0.000004,-1,0.000004,0.000002,-1,0.000004,0.000002,-1,0.000004,0.000002,-1,0.000002,0.000002,-1,0.000002,0.000002,-1,0.000002,0.000002,-1,0.000001,0.000001,-1,0.000001,0.000001,-1,0.000001,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000003,0.000002,-1,0.000003,0.000002,-1,0.000003,0.000002,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000013,0.000001,-1,0.000013,0.000001,-1,0.000013,0.000001,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000003,-0.000003,-1,-0.000003,-0.000003,-1,-0.000003,-0.000003,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000012,0.000004,-1,-0.000012,0.000004,-1,-0.000012,0.000004,-1,-0.000004,0.000002,-1,-0.000004,0.000002,-1,-0.000004,0.000002,-1,-0.000002,0.000002,-1,-0.000002,0.000002,-1,-0.000002,0.000002,-1,-0.000001,0.000001,-1,-0.000001,0.000001,-1,-0.000001,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000003,0.000002,-1,-0.000003,0.000002,-1,-0.000003,0.000002,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000013,0.000001,-1,-0.000013,0.000001,-1,-0.000013,0.000001,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000003,-0.000002,-1,0.000003,-0.000002,-1,0.000003,-0.000002,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0.000003,-1,-0.000001,0.000003,-1,-0.000001,0.000003,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000007,0.000001,-1,0.000007,0.000001,-1,0.000007,0.000001,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000039,0.000004,-1,-0.000039,0.000004,-1,-0.000039,0.000004,-1,0.000011,-0.000007,-1,0.000011,-0.000007,-1,0.000011,-0.000007,-1,0.000005,-0.000005,-1,0.000005,-0.000005,-1,0.000005,-0.000005,-1,0.000002,-0.000003,-1,0.000002,-0.000003,-1,0.000002,-0.000003,-1,0.000001,-0.000003,-1,0.000001,-0.000003,-1,0.000001,-0.000003,-1,0,-0.000002,-1,0,-0.000002,-1,0,-0.000002,-1,0,-0.000002,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000002,0,-1,0.000002,0,-1,0.000002,0,-1,0.000002,0,-1,0,-0.000003,-1,0,-0.000003,-1,0,-0.000003,-1,-0.000001,-0.000004,-1,-0.000001,-0.000004,-1,-0.000001,-0.000004,-1,-0.000015,-0.000014,-1,-0.000015,-0.000014,-1,-0.000015,-0.000014,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000039,0.000004,-1,-0.000039,0.000004,-1,-0.000039,0.000004,-1,0.000011,-0.000007,-1,0.000011,-0.000007,-1,0.000011,-0.000007,-1,0.000005,-0.000005,-1,0.000005,-0.000005,-1,0.000005,-0.000005,-1,0.000002,-0.000003,-1,0.000002,-0.000003,-1,0.000002,-0.000003,-1,0.000001,-0.000003,-1,0.000001,-0.000003,-1,0.000001,-0.000003,-1,0,-0.000002,-1,0,-0.000002,-1,0,-0.000002,-1,0,-0.000002,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.00002,-0.000002,-1,0.00002,-0.000002,-1,0.00002,-0.000002,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000039,0.000004,-1,-0.000039,0.000004,-1,-0.000039,0.000004,-1,0.000011,-0.000007,-1,0.000011,-0.000007,-1,0.000011,-0.000007,-1,0.000005,-0.000005,-1,0.000005,-0.000005,-1,0.000005,-0.000005,-1,0.000002,-0.000003,-1,0.000002,-0.000003,-1,0.000002,-0.000003,-1,0.000001,-0.000003,-1,0.000001,-0.000003,-1,0.000001,-0.000003,-1,0,-0.000002,-1,0,-0.000002,-1,0,-0.000002,-1,0,-0.000002,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.00002,-0.000002,-1,0.00002,-0.000002,-1,0.00002,-0.000002,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000007,-0.000007,-1,-0.000007,-0.000007,-1,-0.000007,-0.000007,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000002,0,-1,0.000002,0,-1,0.000002,0,-1,0.000002,0,-1,0,-0.000003,-1,0,-0.000003,-1,0,-0.000003,-1,-0.000011,-0.000012,-1,-0.000011,-0.000012,-1,-0.000011,-0.000012,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000007,-0.000007,-1,0.000007,-0.000007,-1,0.000007,-0.000007,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000002,0,-1,-0.000002,0,-1,-0.000002,0,-1,-0.000002,0,-1,0,-0.000003,-1,0,-0.000003,-1,0,-0.000003,-1,0.000011,-0.000012,-1,0.000011,-0.000012,-1,0.000011,-0.000012,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000007,-0.000007,-1,0.000007,-0.000007,-1,0.000007,-0.000007,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000002,0,-1,-0.000002,0,-1,-0.000002,0,-1,-0.000002,0,-1,0,-0.000003,-1,0,-0.000003,-1,0,-0.000003,-1,0.000011,-0.000012,-1,0.000011,-0.000012,-1,0.000011,-0.000012,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000007,-0.000007,-1,0.000007,-0.000007,-1,0.000007,-0.000007,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000002,0,-1,-0.000002,0,-1,-0.000002,0,-1,-0.000002,0,-1,0,-0.000003,-1,0,-0.000003,-1,0,-0.000003,-1,0.000011,-0.000012,-1,0.000011,-0.000012,-1,0.000011,-0.000012,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000007,-0.000007,-1,0.000007,-0.000007,-1,0.000007,-0.000007,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000002,0,-1,-0.000002,0,-1,-0.000002,0,-1,-0.000002,0,-1,0,-0.000003,-1,0,-0.000003,-1,0,-0.000003,-1,0.000011,-0.000012,-1,0.000011,-0.000012,-1,0.000011,-0.000012,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000039,0.000004,-1,0.000039,0.000004,-1,0.000039,0.000004,-1,-0.000011,-0.000007,-1,-0.000011,-0.000007,-1,-0.000011,-0.000007,-1,-0.000005,-0.000005,-1,-0.000005,-0.000005,-1,-0.000005,-0.000005,-1,-0.000002,-0.000003,-1,-0.000002,-0.000003,-1,-0.000002,-0.000003,-1,-0.000001,-0.000003,-1,-0.000001,-0.000003,-1,-0.000001,-0.000003,-1,0,-0.000002,-1,0,-0.000002,-1,0,-0.000002,-1,0.000002,0,-1,0.000002,0,-1,0.000002,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000002,0,-1,-0.000002,0,-1,-0.000002,0,-1,-0.000002,0,-1,0,-0.000003,-1,0,-0.000003,-1,0,-0.000003,-1,0.000001,-0.000004,-1,0.000001,-0.000004,-1,0.000001,-0.000004,-1,0.000015,-0.000014,-1,0.000015,-0.000014,-1,0.000015,-0.000014,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000039,0.000004,-1,0.000039,0.000004,-1,0.000039,0.000004,-1,-0.000011,-0.000007,-1,-0.000011,-0.000007,-1,-0.000011,-0.000007,-1,-0.000005,-0.000005,-1,-0.000005,-0.000005,-1,-0.000005,-0.000005,-1,-0.000002,-0.000003,-1,-0.000002,-0.000003,-1,-0.000002,-0.000003,-1,-0.000001,-0.000003,-1,-0.000001,-0.000003,-1,-0.000001,-0.000003,-1,0,-0.000002,-1,0,-0.000002,-1,0,-0.000002,-1,0.000002,0,-1,0.000002,0,-1,0.000002,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000002,0,-1,-0.000002,0,-1,-0.000002,0,-1,-0.000002,0,-1,0,-0.000003,-1,0,-0.000003,-1,0,-0.000003,-1,0.000011,-0.000012,-1,0.000011,-0.000012,-1,0.000011,-0.000012,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000039,0.000004,-1,0.000039,0.000004,-1,0.000039,0.000004,-1,-0.000011,-0.000007,-1,-0.000011,-0.000007,-1,-0.000011,-0.000007,-1,-0.000005,-0.000005,-1,-0.000005,-0.000005,-1,-0.000005,-0.000005,-1,-0.000002,-0.000003,-1,-0.000002,-0.000003,-1,-0.000002,-0.000003,-1,-0.000001,-0.000003,-1,-0.000001,-0.000003,-1,-0.000001,-0.000003,-1,0,-0.000002,-1,0,-0.000002,-1,0,-0.000002,-1,0.000002,0,-1,0.000002,0,-1,0.000002,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000002,0,-1,-0.000002,0,-1,-0.000002,0,-1,-0.000002,0,-1,0,-0.000003,-1,0,-0.000003,-1,0,-0.000003,-1,0.000001,-0.000004,-1,0.000001,-0.000004,-1,0.000001,-0.000004,-1,0.000015,-0.000014,-1,0.000015,-0.000014,-1,0.000015,-0.000014,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000003,-0.000009,-1,0.000003,-0.000009,-1,0.000003,-0.000009,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000002,0,-1,-0.000002,0,-1,-0.000002,0,-1,-0.000002,0,-1,0,-0.000003,-1,0,-0.000003,-1,0,-0.000003,-1,0.000001,-0.000004,-1,0.000001,-0.000004,-1,0.000001,-0.000004,-1,-0.000007,0.000002,-1,-0.000007,0.000002,-1,-0.000007,0.000002,-1,0.000008,-0.000011,-1,0.000008,-0.000011,-1,0.000008,-0.000011,-1,-0.000035,0.000021,-1,-0.000035,0.000021,-1,-0.000035,0.000021,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000004,-0.000008,-1,-0.000004,-0.000008,-1,-0.000004,-0.000008,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000002,0,-1,0.000002,0,-1,0.000002,0,-1,0.000002,0,-1,0,-0.000003,-1,0,-0.000003,-1,0,-0.000003,-1,-0.000001,-0.000004,-1,-0.000001,-0.000004,-1,-0.000001,-0.000004,-1,0.000007,0.000002,-1,0.000007,0.000002,-1,0.000007,0.000002,-1,0.000012,0.000007,-1,0.000012,0.000007,-1,0.000012,0.000007,-1,-0.000022,-0.000033,-1,-0.000022,-0.000033,-1,-0.000022,-0.000033,-1,0.000013,-0.000001,-1,0.000013,-0.000001,-1,0.000013,-0.000001,-1,-0.000004,0.000002,-1,-0.000004,0.000002,-1,-0.000004,0.000002,-1,-0.000002,0.000002,-1,-0.000002,0.000002,-1,-0.000002,0.000002,-1,-0.000001,0.000001,-1,-0.000001,0.000001,-1,-0.000001,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000007,0.000007,-1,-0.000007,0.000007,-1,-0.000007,0.000007,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0.00002,0.000002,-1,0.00002,0.000002,-1,0.00002,0.000002,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0.000001,-1,0,0.000001,-1,0.000004,0.000004,-1,0.000004,0.000004,-1,0.000004,0.000004,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000013,-0.000001,-1,0.000013,-0.000001,-1,0.000013,-0.000001,-1,-0.000004,0.000002,-1,-0.000004,0.000002,-1,-0.000004,0.000002,-1,-0.000002,0.000002,-1,-0.000002,0.000002,-1,-0.000002,0.000002,-1,-0.000001,0.000001,-1,-0.000001,0.000001,-1,-0.000001,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000007,0.000007,-1,-0.000007,0.000007,-1,-0.000007,0.000007,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0.00002,0.000002,-1,0.00002,0.000002,-1,0.00002,0.000002,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0.000001,-1,0,0.000001,-1,0.000004,0.000004,-1,0.000004,0.000004,-1,0.000004,0.000004,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000013,-0.000001,-1,0.000013,-0.000001,-1,0.000013,-0.000001,-1,-0.000004,0.000002,-1,-0.000004,0.000002,-1,-0.000004,0.000002,-1,-0.000002,0.000002,-1,-0.000002,0.000002,-1,-0.000002,0.000002,-1,-0.000001,0.000001,-1,-0.000001,0.000001,-1,-0.000001,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000007,0.000007,-1,-0.000007,0.000007,-1,-0.000007,0.000007,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0.00002,0.000002,-1,0.00002,0.000002,-1,0.00002,0.000002,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0.000001,-1,0,0.000001,-1,0.000004,0.000004,-1,0.000004,0.000004,-1,0.000004,0.000004,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000013,-0.000001,-1,0.000013,-0.000001,-1,0.000013,-0.000001,-1,-0.000004,0.000002,-1,-0.000004,0.000002,-1,-0.000004,0.000002,-1,-0.000002,0.000002,-1,-0.000002,0.000002,-1,-0.000002,0.000002,-1,-0.000001,0.000001,-1,-0.000001,0.000001,-1,-0.000001,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000007,0.000007,-1,-0.000007,0.000007,-1,-0.000007,0.000007,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0.00002,0.000002,-1,0.00002,0.000002,-1,0.00002,0.000002,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0.000001,-1,0,0.000001,-1,-0.000001,0,-1,-0.000001,0,-1,0.000004,0.000004,-1,0.000004,0.000004,-1,0.000004,0.000004,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000013,-0.000001,-1,0.000013,-0.000001,-1,0.000013,-0.000001,-1,-0.000004,0.000002,-1,-0.000004,0.000002,-1,-0.000004,0.000002,-1,-0.000002,0.000002,-1,-0.000002,0.000002,-1,-0.000002,0.000002,-1,-0.000001,0.000001,-1,-0.000001,0.000001,-1,-0.000001,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000007,0.000007,-1,-0.000007,0.000007,-1,-0.000007,0.000007,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0.00002,0.000002,-1,0.00002,0.000002,-1,0.00002,0.000002,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0.000005,0.000005,-1,0.000005,0.000005,-1,0.000005,0.000005,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000003,0.000004,-1,0.000003,0.000004,-1,0.000003,0.000004,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000007,0.000007,-1,0.000007,0.000007,-1,0.000007,0.000007,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,-0.00002,0.000002,-1,-0.00002,0.000002,-1,-0.00002,0.000002,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0.000001,0,-1,0.000001,0,-1,-0.000004,0.000004,-1,-0.000004,0.000004,-1,-0.000004,0.000004,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000039,-0.000004,-1,0.000039,-0.000004,-1,0.000039,-0.000004,-1,-0.000011,0.000007,-1,-0.000011,0.000007,-1,-0.000011,0.000007,-1,-0.000005,0.000005,-1,-0.000005,0.000005,-1,-0.000005,0.000005,-1,-0.000002,0.000003,-1,-0.000002,0.000003,-1,-0.000002,0.000003,-1,-0.000001,0.000003,-1,-0.000001,0.000003,-1,-0.000001,0.000003,-1,0,0.000002,-1,0,0.000002,-1,0,0.000002,-1,0,0.000002,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000002,0.000002,-1,-0.000002,0.000002,-1,-0.000002,0.000002,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,-0.00002,0.000002,-1,-0.00002,0.000002,-1,-0.00002,0.000002,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0.000001,0,-1,0.000001,0,-1,-0.000004,0.000004,-1,-0.000004,0.000004,-1,-0.000004,0.000004,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000039,-0.000004,-1,0.000039,-0.000004,-1,0.000039,-0.000004,-1,-0.000011,0.000007,-1,-0.000011,0.000007,-1,-0.000011,0.000007,-1,-0.000005,0.000005,-1,-0.000005,0.000005,-1,-0.000005,0.000005,-1,-0.000002,0.000003,-1,-0.000002,0.000003,-1,-0.000002,0.000003,-1,-0.000001,0.000003,-1,-0.000001,0.000003,-1,-0.000001,0.000003,-1,0,0.000002,-1,0,0.000002,-1,0,0.000002,-1,0,0.000002,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000002,0.000002,-1,-0.000002,0.000002,-1,-0.000002,0.000002,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,-0.00002,0.000002,-1,-0.00002,0.000002,-1,-0.00002,0.000002,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,-0.000005,0.000005,-1,-0.000005,0.000005,-1,-0.000005,0.000005,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000039,-0.000004,-1,-0.000039,-0.000004,-1,-0.000039,-0.000004,-1,0.000011,0.000007,-1,0.000011,0.000007,-1,0.000011,0.000007,-1,0.000005,0.000005,-1,0.000005,0.000005,-1,0.000005,0.000005,-1,0.000002,0.000003,-1,0.000002,0.000003,-1,0.000002,0.000003,-1,0.000001,0.000003,-1,0.000001,0.000003,-1,0.000001,0.000003,-1,0,0.000002,-1,0,0.000002,-1,0,0.000002,-1,0,0.000002,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000002,0.000002,-1,0.000002,0.000002,-1,0.000002,0.000002,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0.00002,0.000002,-1,0.00002,0.000002,-1,0.00002,0.000002,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,-0.000001,0,-1,-0.000001,0,-1,0,0.000001,-1,0,0.000001,-1,0.000005,0.000005,-1,0.000005,0.000005,-1,0.000005,0.000005,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000039,-0.000004,-1,0.000039,-0.000004,-1,0.000039,-0.000004,-1,-0.000011,0.000007,-1,-0.000011,0.000007,-1,-0.000011,0.000007,-1,-0.000005,0.000005,-1,-0.000005,0.000005,-1,-0.000005,0.000005,-1,-0.000002,0.000003,-1,-0.000002,0.000003,-1,-0.000002,0.000003,-1,-0.000001,0.000003,-1,-0.000001,0.000003,-1,-0.000001,0.000003,-1,0,0.000002,-1,0,0.000002,-1,0,0.000002,-1,0,0.000002,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000002,0.000002,-1,-0.000002,0.000002,-1,-0.000002,0.000002,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,-0.00002,0.000002,-1,-0.00002,0.000002,-1,-0.00002,0.000002,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,-0.000005,0.000005,-1,-0.000005,0.000005,-1,-0.000005,0.000005,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000039,-0.000004,-1,-0.000039,-0.000004,-1,-0.000039,-0.000004,-1,0.000011,0.000007,-1,0.000011,0.000007,-1,0.000011,0.000007,-1,0.000005,0.000005,-1,0.000005,0.000005,-1,0.000005,0.000005,-1,0.000002,0.000003,-1,0.000002,0.000003,-1,0.000002,0.000003,-1,0.000001,0.000003,-1,0.000001,0.000003,-1,0.000001,0.000003,-1,0,0.000002,-1,0,0.000002,-1,0,0.000002,-1,-0.000002,0,-1,-0.000002,0,-1,-0.000002,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000001,0.000003,-1,0.000001,0.000003,-1,0.000001,0.000003,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0.00002,0.000002,-1,0.00002,0.000002,-1,0.00002,0.000002,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0.000005,0.000005,-1,0.000005,0.000005,-1,0.000005,0.000005,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000013,-0.000001,-1,-0.000013,-0.000001,-1,-0.000013,-0.000001,-1,0.000004,0.000002,-1,0.000004,0.000002,-1,0.000004,0.000002,-1,0.000002,0.000002,-1,0.000002,0.000002,-1,0.000002,0.000002,-1,0.000001,0.000001,-1,0.000001,0.000001,-1,0.000001,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000003,0.000008,-1,0.000003,0.000008,-1,0.000003,0.000008,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,-0.00002,0.000002,-1,-0.00002,0.000002,-1,-0.00002,0.000002,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0.000001,0,-1,0.000001,0,-1,-0.000004,0.000004,-1,-0.000004,0.000004,-1,-0.000004,0.000004,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000002,0.000002,-1,-0.000002,0.000002,-1,-0.000002,0.000002,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0.000011,0.000002,-1,0.000011,0.000002,-1,0.000011,0.000002,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000002,0.000003,-1,0.000002,0.000003,-1,0.000002,0.000003,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000002,0,-1,-0.000002,0,-1,-0.000002,0,-1,0,0,-1,0,0,-1,0.000003,0.000003,-1,0.000003,0.000003,-1,0.000003,0.000003,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000012,0.000004,-1,-0.000012,0.000004,-1,-0.000012,0.000004,-1,-0.000004,0.000002,-1,-0.000004,0.000002,-1,-0.000004,0.000002,-1,-0.000002,0.000002,-1,-0.000002,0.000002,-1,-0.000002,0.000002,-1,-0.000001,0.000001,-1,-0.000001,0.000001,-1,-0.000001,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000002,0,-1,-0.000002,0,-1,-0.000002,0,-1,0,0,-1,0,0,-1,0.000003,0.000003,-1,0.000003,0.000003,-1,0.000003,0.000003,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000012,0.000004,-1,-0.000012,0.000004,-1,-0.000012,0.000004,-1,-0.000004,0.000002,-1,-0.000004,0.000002,-1,-0.000004,0.000002,-1,-0.000002,0.000002,-1,-0.000002,0.000002,-1,-0.000002,0.000002,-1,-0.000001,0.000001,-1,-0.000001,0.000001,-1,-0.000001,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000002,0,-1,-0.000002,0,-1,-0.000002,0,-1,0,0,-1,0,0,-1,0.000003,0.000003,-1,0.000003,0.000003,-1,0.000003,0.000003,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000012,0.000004,-1,-0.000012,0.000004,-1,-0.000012,0.000004,-1,-0.000004,0.000002,-1,-0.000004,0.000002,-1,-0.000004,0.000002,-1,-0.000002,0.000002,-1,-0.000002,0.000002,-1,-0.000002,0.000002,-1,-0.000001,0.000001,-1,-0.000001,0.000001,-1,-0.000001,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000002,0,-1,-0.000002,0,-1,-0.000002,0,-1,0,0,-1,0,0,-1,0.000003,0.000003,-1,0.000003,0.000003,-1,0.000003,0.000003,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000012,0.000004,-1,0.000012,0.000004,-1,0.000012,0.000004,-1,0.000004,0.000002,-1,0.000004,0.000002,-1,0.000004,0.000002,-1,0.000002,0.000002,-1,0.000002,0.000002,-1,0.000002,0.000002,-1,0.000001,0.000001,-1,0.000001,0.000001,-1,0.000001,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,0.000011,0.000002,-1,0.000011,0.000002,-1,0.000011,0.000002,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0.000003,0.000003,-1,0.000003,0.000003,-1,0.000003,0.000003,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0,-1,0,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000002,0,-1,0.000002,0,-1,0.000002,0,-1,0,0.000001,-1,0,0.000001,-1,-0.000003,0.000003,-1,-0.000003,0.000003,-1,-0.000003,0.000003,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,-0.000001,0.000003,-1,-0.000001,0.000003,-1,-0.000001,0.000003,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0,-1,0,0,-1,0,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000002,0,-1,0.000002,0,-1,0.000002,0,-1,0,0.000001,-1,0,0.000001,-1,-0.000003,0.000003,-1,-0.000003,0.000003,-1,-0.000003,0.000003,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0.000001,0.000003,-1,0.000001,0.000003,-1,0.000001,0.000003,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000002,0,-1,-0.000002,0,-1,-0.000002,0,-1,0,0.000001,-1,0,0.000001,-1,0,0.000001,-1,0.000003,0.000003,-1,0.000003,0.000003,-1,0.000003,0.000003,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000001,0,1,-0.000001,0,1,-0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000001,0,1,-0.000001,0,1,-0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000001,0,1,-0.000001,0,1,-0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000001,0,1,-0.000001,0,1,-0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000001,0,1,-0.000001,0,1,-0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000001,0,1,-0.000001,0,1,-0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000001,0,1,-0.000001,0,1,-0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000001,0,1,-0.000001,0,1,-0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000001,0,1,-0.000001,0,1,-0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000001,0,1,-0.000001,0,1,-0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000001,0,1,-0.000001,0,1,-0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000001,0,1,-0.000001,0,1,-0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000001,0,1,-0.000001,0,1,-0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000001,0,1,-0.000001,0,1,-0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000001,0,1,-0.000001,0,1,-0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000001,0,1,-0.000001,0,1,-0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000001,0,1,-0.000001,0,1,-0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000001,0,1,-0.000001,0,1,-0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000001,0,1,-0.000001,0,1,-0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000001,0,1,-0.000001,0,1,-0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000001,0,1,-0.000001,0,1,-0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000001,0,1,-0.000001,0,1,-0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000001,0,1,-0.000001,0,1,-0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000001,0,1,-0.000001,0,1,-0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000001,0,1,-0.000001,0,1,-0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000001,0,1,-0.000001,0,1,-0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000001,0,1,-0.000001,0,1,-0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000001,0,1,-0.000001,0,1,-0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0.000004,-0.000004,1,0.000004,-0.000004,1,0.000004,-0.000004,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000013,-0.000001,1,-0.000013,-0.000001,1,-0.000013,-0.000001,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0.000004,-0.000004,1,0.000004,-0.000004,1,0.000004,-0.000004,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000013,-0.000001,1,-0.000013,-0.000001,1,-0.000013,-0.000001,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0.000004,-0.000004,1,0.000004,-0.000004,1,0.000004,-0.000004,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000013,-0.000001,1,-0.000013,-0.000001,1,-0.000013,-0.000001,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0.000004,-0.000004,1,0.000004,-0.000004,1,0.000004,-0.000004,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000013,-0.000001,1,-0.000013,-0.000001,1,-0.000013,-0.000001,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0.000004,-0.000004,1,0.000004,-0.000004,1,0.000004,-0.000004,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000013,-0.000001,1,-0.000013,-0.000001,1,-0.000013,-0.000001,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000004,-0.000004,1,-0.000004,-0.000004,1,-0.000004,-0.000004,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0.000013,-0.000001,1,0.000013,-0.000001,1,0.000013,-0.000001,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000026,0.000003,1,-0.000026,0.000003,1,-0.000026,0.000003,1,0.000007,-0.000004,1,0.000007,-0.000004,1,0.000007,-0.000004,1,0.000003,-0.000003,1,0.000003,-0.000003,1,0.000003,-0.000003,1,0.000002,-0.000002,1,0.000002,-0.000002,1,0.000002,-0.000002,1,0.000001,-0.000002,1,0.000001,-0.000002,1,0.000001,-0.000002,1,0,-0.000001,1,0,-0.000001,1,0,-0.000001,1,0,-0.000001,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0.000013,-0.000001,1,0.000013,-0.000001,1,0.000013,-0.000001,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000026,0.000003,1,-0.000026,0.000003,1,-0.000026,0.000003,1,0.000007,-0.000004,1,0.000007,-0.000004,1,0.000007,-0.000004,1,0.000003,-0.000003,1,0.000003,-0.000003,1,0.000003,-0.000003,1,0.000002,-0.000002,1,0.000002,-0.000002,1,0.000002,-0.000002,1,0.000001,-0.000002,1,0.000001,-0.000002,1,0.000001,-0.000002,1,0,-0.000001,1,0,-0.000001,1,0,-0.000001,1,0,-0.000001,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0.000013,-0.000001,1,0.000013,-0.000001,1,0.000013,-0.000001,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0.000026,0.000003,1,0.000026,0.000003,1,0.000026,0.000003,1,-0.000007,-0.000004,1,-0.000007,-0.000004,1,-0.000007,-0.000004,1,-0.000003,-0.000003,1,-0.000003,-0.000003,1,-0.000003,-0.000003,1,-0.000002,-0.000002,1,-0.000002,-0.000002,1,-0.000002,-0.000002,1,-0.000001,-0.000002,1,-0.000001,-0.000002,1,-0.000001,-0.000002,1,0,-0.000001,1,0,-0.000001,1,0,-0.000001,1,0,-0.000001,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000013,-0.000001,1,-0.000013,-0.000001,1,-0.000013,-0.000001,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000026,0.000003,1,-0.000026,0.000003,1,-0.000026,0.000003,1,0.000007,-0.000004,1,0.000007,-0.000004,1,0.000007,-0.000004,1,0.000003,-0.000003,1,0.000003,-0.000003,1,0.000003,-0.000003,1,0.000002,-0.000002,1,0.000002,-0.000002,1,0.000002,-0.000002,1,0.000001,-0.000002,1,0.000001,-0.000002,1,0.000001,-0.000002,1,0,-0.000001,1,0,-0.000001,1,0,-0.000001,1,0,-0.000001,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0.000013,-0.000001,1,0.000013,-0.000001,1,0.000013,-0.000001,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0.000026,0.000003,1,0.000026,0.000003,1,0.000026,0.000003,1,-0.000007,-0.000004,1,-0.000007,-0.000004,1,-0.000007,-0.000004,1,-0.000003,-0.000003,1,-0.000003,-0.000003,1,-0.000003,-0.000003,1,-0.000002,-0.000002,1,-0.000002,-0.000002,1,-0.000002,-0.000002,1,-0.000001,-0.000002,1,-0.000001,-0.000002,1,-0.000001,-0.000002,1,0,-0.000001,1,0,-0.000001,1,0,-0.000001,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000013,-0.000001,1,-0.000013,-0.000001,1,-0.000013,-0.000001,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000002,-0.000005,1,-0.000002,-0.000005,1,-0.000002,-0.000005,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0.000013,-0.000001,1,0.000013,-0.000001,1,0.000013,-0.000001,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,1,0,0,1,0,0,1,0,0,1,0,0,0.993136,-0.116969,0,0.993136,-0.116969,0,0.993136,-0.116969,0,0.993136,-0.116969,0,0.939513,-0.342513,0,0.939513,-0.342513,0,0.939513,-0.342513,0,0.939513,-0.342513,0,0.839729,-0.543005,0,0.839729,-0.543005,0,0.839729,-0.543005,0,0.839729,-0.543006,0,0.839729,-0.543006,0,0.839729,-0.543006,0,0.702226,-0.711954,0,0.702226,-0.711954,0,0.702226,-0.711954,0,0.702222,-0.711958,0,0.702222,-0.711958,0,0.702222,-0.711958,0,0.532644,-0.846339,0,0.532644,-0.846339,0,0.532644,-0.846339,0,0.532648,-0.846337,0,0.532648,-0.846337,0,0.532648,-0.846337,0,0.334765,-0.942302,0,0.334765,-0.942302,0,0.334765,-0.942302,0,0.334765,-0.942302,0,0.114278,-0.993449,0,0.114278,-0.993449,0,0.114278,-0.993449,0,0.114278,-0.993449,0,-0.114313,-0.993445,0,-0.114313,-0.993445,0,-0.114313,-0.993445,0,-0.114313,-0.993445,0,-0.334857,-0.942269,0,-0.334857,-0.942269,0,-0.334857,-0.942269,0,-0.334857,-0.942269,0,-0.532764,-0.846264,0,-0.532764,-0.846264,0,-0.532764,-0.846264,0,-0.532764,-0.846264,0,-0.702343,-0.711839,0,-0.702343,-0.711839,0,-0.702343,-0.711839,0,-0.702336,-0.711845,0,-0.702336,-0.711845,0,-0.702336,-0.711845,0,-0.839801,-0.542895,0,-0.839801,-0.542895,0,-0.839801,-0.542895,0,-0.839804,-0.542889,0,-0.839804,-0.542889,0,-0.839804,-0.542889,0,-0.939545,-0.342424,0,-0.939545,-0.342424,0,-0.939545,-0.342424,0,-0.939545,-0.342424,0,-0.99314,-0.116932,0,-0.99314,-0.116932,0,-0.99314,-0.116932,0,-0.99314,-0.116932,0,-1,0,0,-1,0,0,-1,0,0,-1,0,1,0,-0.000001,1,0,-0.000001,1,0,-0.000001,1,0,-0.000001,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,-0.000023,-1,0,-0.000023,-1,0,-0.000023,-1,0.000005,0.000023,-1,0.000005,0.000023,-1,0.000005,0.000023,-1,-0.000006,-0.000024,-1,-0.000006,-0.000024,-1,-0.000006,-0.000024,-1,0.000002,-0.000002,-1,0.000002,-0.000002,-1,0.000002,-0.000002,-1,0.000002,-0.000003,-1,0.000002,-0.000003,-1,0.000002,-0.000003,-1,0.000017,0.000022,-1,0.000017,0.000022,-1,0.000017,0.000022,-1,0,0,-1,0,0,-1,0,0,-1,-0.000034,-0.000028,-1,-0.000034,-0.000028,-1,-0.000034,-0.000028,-1,-0.000006,-0.00001,-1,-0.000006,-0.00001,-1,-0.000006,-0.00001,-1,-0.000043,-0.000028,-1,-0.000043,-0.000028,-1,-0.000043,-0.000028,-1,0.000089,0.000057,-1,0.000089,0.000057,-1,0.000089,0.000057,-1,-0.000077,-0.000078,-1,-0.000077,-0.000078,-1,-0.000077,-0.000078,0,0.965926,-0.258819,0,0.965926,-0.258819,0,0.965926,-0.258819,0,0.965926,-0.258819,0.024785,0.994216,-0.1045,0.024785,0.994216,-0.1045,0.024785,0.994216,-0.1045,0.071885,0.990255,-0.119282,0.071885,0.990255,-0.119282,0.071885,0.990255,-0.119282,0.111987,0.982713,-0.147425,0.111987,0.982713,-0.147425,0.111987,0.982713,-0.147425,0.141063,0.972355,-0.186081,0.141063,0.972355,-0.186081,0.141063,0.972355,-0.186081,0.156389,0.960148,-0.231643,0.156389,0.960148,-0.231643,0.156389,0.960148,-0.231643,0.156437,0.954033,-0.255633,0.156437,0.954033,-0.255633,0.156437,0.954033,-0.255633,0.156431,0.954034,-0.255633,0.156431,0.954034,-0.255633,0.156431,0.954034,-0.255633,0.156383,0.947329,-0.279487,0.156383,0.947329,-0.279487,0.156383,0.947329,-0.279487,0.141077,0.935136,-0.324988,0.141077,0.935136,-0.324988,0.141077,0.935136,-0.324988,0.111959,0.924763,-0.3637,0.111959,0.924763,-0.3637,0.111959,0.924763,-0.3637,0.071884,0.917228,-0.391824,0.071884,0.917228,-0.391824,0.071884,0.917228,-0.391824,0.024767,0.913265,-0.406612,0.024767,0.913265,-0.406612,0.024767,0.913265,-0.406612,0,0.913545,-0.406737,0,0.913545,-0.406737,0,0.913545,-0.406737,0,0.913547,-0.406732,0,0.913547,-0.406732,0,0.913547,-0.406732,-0.02477,0.913267,-0.406607,-0.02477,0.913267,-0.406607,-0.02477,0.913267,-0.406607,-0.071878,0.917229,-0.391823,-0.071878,0.917229,-0.391823,-0.071878,0.917229,-0.391823,-0.111964,0.924766,-0.363691,-0.111964,0.924766,-0.363691,-0.111964,0.924766,-0.363691,-0.141073,0.935136,-0.324991,-0.141073,0.935136,-0.324991,-0.141073,0.935136,-0.324991,-0.156383,0.947331,-0.279478,-0.156383,0.947331,-0.279478,-0.156383,0.947331,-0.279478,-0.156431,0.954034,-0.255633,-0.156431,0.954034,-0.255633,-0.156431,0.954034,-0.255633,-0.156433,0.954034,-0.255633,-0.156433,0.954034,-0.255633,-0.156433,0.954034,-0.255633,-0.156385,0.960149,-0.231641,-0.156385,0.960149,-0.231641,-0.156385,0.960149,-0.231641,-0.141068,0.972349,-0.186109,-0.141068,0.972349,-0.186109,-0.141068,0.972349,-0.186109,-0.111962,0.982718,-0.147413,-0.111962,0.982718,-0.147413,-0.111962,0.982718,-0.147413,-0.071888,0.990254,-0.11929,-0.071888,0.990254,-0.11929,-0.071888,0.990254,-0.11929,-0.024762,0.994217,-0.1045,-0.024762,0.994217,-0.1045,-0.024762,0.994217,-0.1045,0,0.994522,-0.104532,0,0.994522,-0.104532,0,0.994522,-0.104532,0,0.994521,-0.104532,0,0.994521,-0.104532,0,0.994521,-0.104532,0.071735,0.975629,0.207367,0.071735,0.975629,0.207367,0.071735,0.975629,0.207367,0.071712,0.975628,0.207382,0.071712,0.975628,0.207382,0.071712,0.975628,0.207382,0.208142,0.964157,0.164553,0.208142,0.964157,0.164553,0.208142,0.964157,0.164553,0.208138,0.964157,0.164557,0.208138,0.964157,0.164557,0.208138,0.964157,0.164557,0.324199,0.942331,0.083106,0.324199,0.942331,0.083106,0.324199,0.942331,0.083106,0.324181,0.942337,0.083113,0.324181,0.942337,0.083113,0.324181,0.942337,0.083113,0.408489,0.912305,-0.028932,0.408489,0.912305,-0.028932,0.408489,0.912305,-0.028932,0.408493,0.912301,-0.028981,0.408493,0.912301,-0.028981,0.408493,0.912301,-0.028981,0.452822,0.876989,-0.160755,0.452822,0.876989,-0.160755,0.452822,0.876989,-0.160755,0.452826,0.876991,-0.160735,0.452826,0.876991,-0.160735,0.452826,0.876991,-0.160735,0.45399,0.860646,-0.23061,0.45399,0.860646,-0.23061,0.45399,0.860646,-0.23061,0.453993,0.860645,-0.230609,0.453993,0.860645,-0.230609,0.453993,0.860645,-0.230609,0.452818,0.839866,-0.299302,0.452818,0.839866,-0.299302,0.452818,0.839866,-0.299302,0.452824,0.839866,-0.299292,0.452824,0.839866,-0.299292,0.452824,0.839866,-0.299292,0.408493,0.80456,-0.431065,0.408493,0.80456,-0.431065,0.408493,0.80456,-0.431065,0.408497,0.804559,-0.431062,0.408497,0.804559,-0.431062,0.408497,0.804559,-0.431062,0.324185,0.774526,-0.543152,0.324185,0.774526,-0.543152,0.324185,0.774526,-0.543152,0.324184,0.774525,-0.543154,0.324184,0.774525,-0.543154,0.324184,0.774525,-0.543154,0.20814,0.752701,-0.624595,0.20814,0.752701,-0.624595,0.20814,0.752701,-0.624595,0.208135,0.752702,-0.624595,0.208135,0.752702,-0.624595,0.208135,0.752702,-0.624595,0.071721,0.741231,-0.667408,0.071721,0.741231,-0.667408,0.071721,0.741231,-0.667408,0.071724,0.74123,-0.667408,0.071724,0.74123,-0.667408,0.071724,0.74123,-0.667408,0,0.743145,-0.669131,0,0.743145,-0.669131,0,0.743145,-0.669131,0,0.743143,-0.669133,0,0.743143,-0.669133,0,0.743143,-0.669133,-0.071718,0.741235,-0.667403,-0.071718,0.741235,-0.667403,-0.071718,0.741235,-0.667403,-0.071705,0.74123,-0.66741,-0.071705,0.74123,-0.66741,-0.071705,0.74123,-0.66741,-0.208137,0.752702,-0.624595,-0.208137,0.752702,-0.624595,-0.208137,0.752702,-0.624595,-0.208147,0.752708,-0.624585,-0.208147,0.752708,-0.624585,-0.208147,0.752708,-0.624585,-0.324193,0.774525,-0.543148,-0.324193,0.774525,-0.543148,-0.324193,0.774525,-0.543148,-0.324187,0.774525,-0.543151,-0.324187,0.774525,-0.543151,-0.324187,0.774525,-0.543151,-0.40849,0.80456,-0.431066,-0.40849,0.80456,-0.431066,-0.40849,0.80456,-0.431066,-0.408489,0.804557,-0.431074,-0.408489,0.804557,-0.431074,-0.408489,0.804557,-0.431074,-0.452821,0.839868,-0.299289,-0.452821,0.839868,-0.299289,-0.452821,0.839868,-0.299289,-0.45282,0.839872,-0.299282,-0.45282,0.839872,-0.299282,-0.45282,0.839872,-0.299282,-0.45399,0.860646,-0.23061,-0.45399,0.860646,-0.23061,-0.45399,0.860646,-0.23061,-0.45399,0.860646,-0.23061,-0.45399,0.860646,-0.23061,-0.452826,0.876989,-0.160744,-0.452826,0.876989,-0.160744,-0.452826,0.876989,-0.160744,-0.452821,0.876993,-0.160737,-0.452821,0.876993,-0.160737,-0.452821,0.876993,-0.160737,-0.408482,0.912307,-0.028959,-0.408482,0.912307,-0.028959,-0.408482,0.912307,-0.028959,-0.408503,0.912297,-0.028975,-0.408503,0.912297,-0.028975,-0.408503,0.912297,-0.028975,-0.324184,0.942336,0.083113,-0.324184,0.942336,0.083113,-0.324184,0.942336,0.083113,-0.324178,0.942337,0.083127,-0.324178,0.942337,0.083127,-0.324178,0.942337,0.083127,-0.208143,0.964156,0.164562,-0.208143,0.964156,0.164562,-0.208143,0.964156,0.164562,-0.208141,0.964156,0.164562,-0.208141,0.964156,0.164562,-0.208141,0.964156,0.164562,-0.071719,0.975629,0.207374,-0.071719,0.975629,0.207374,-0.071719,0.975629,0.207374,-0.071726,0.975628,0.207376,-0.071726,0.975628,0.207376,-0.071726,0.975628,0.207376,0,0.978148,0.20791,0,0.978148,0.20791,0,0.978148,0.20791,0,0.978146,0.207917,0,0.978146,0.207917,0,0.978146,0.207917,0.111288,0.860645,0.496895,0.111288,0.860645,0.496895,0.111288,0.860645,0.496895,0.111288,0.860645,0.496895,0.323004,0.842838,0.430455,0.323004,0.842838,0.430455,0.323004,0.842838,0.430455,0.32301,0.842841,0.430447,0.32301,0.842841,0.430447,0.32301,0.842841,0.430447,0.503095,0.808973,0.304069,0.503095,0.808973,0.304069,0.503095,0.808973,0.304069,0.503077,0.808983,0.304072,0.503077,0.808983,0.304072,0.503077,0.808983,0.304072,0.633924,0.762373,0.130106,0.633924,0.762373,0.130106,0.633924,0.762373,0.130106,0.633924,0.762371,0.130116,0.633924,0.762371,0.130116,0.633924,0.762371,0.130116,0.702717,0.707573,-0.074363,0.702717,0.707573,-0.074363,0.702717,0.707573,-0.074363,0.702711,0.707577,-0.074384,0.702711,0.707577,-0.074384,0.702711,0.707577,-0.074384,0.707111,0.683009,-0.183012,0.707111,0.683009,-0.183012,0.707111,0.683009,-0.183012,0.707106,0.683013,-0.183013,0.707106,0.683013,-0.183013,0.707106,0.683013,-0.183013,0.702709,0.649966,-0.289385,0.702709,0.649966,-0.289385,0.702709,0.649966,-0.289385,0.702713,0.649965,-0.289379,0.702713,0.649965,-0.289379,0.702713,0.649965,-0.289379,0.633927,0.595172,-0.493869,0.633927,0.595172,-0.493869,0.633927,0.595172,-0.493869,0.633922,0.595174,-0.493873,0.633922,0.595174,-0.493873,0.633922,0.595174,-0.493873,0.503085,0.548563,-0.667821,0.503085,0.548563,-0.667821,0.503085,0.548563,-0.667821,0.503085,0.548564,-0.66782,0.503085,0.548564,-0.66782,0.503085,0.548564,-0.66782,0.322995,0.514701,-0.794203,0.322995,0.514701,-0.794203,0.322995,0.514701,-0.794203,0.322998,0.514699,-0.794202,0.322998,0.514699,-0.794202,0.322998,0.514699,-0.794202,0.111303,0.496899,-0.860641,0.111303,0.496899,-0.860641,0.111303,0.496899,-0.860641,0.111304,0.496898,-0.860641,0.111304,0.496898,-0.860641,0.111304,0.496898,-0.860641,0,0.500006,-0.866022,0,0.500006,-0.866022,0,0.500006,-0.866022,0,0.500007,-0.866021,0,0.500007,-0.866021,0,0.500007,-0.866021,-0.11129,0.496889,-0.860649,-0.11129,0.496889,-0.860649,-0.11129,0.496889,-0.860649,-0.111305,0.4969,-0.86064,-0.111305,0.4969,-0.86064,-0.111305,0.4969,-0.86064,-0.323005,0.514699,-0.794199,-0.323005,0.514699,-0.794199,-0.323005,0.514699,-0.794199,-0.323,0.514693,-0.794205,-0.323,0.514693,-0.794205,-0.323,0.514693,-0.794205,-0.503089,0.548563,-0.667817,-0.503089,0.548563,-0.667817,-0.503089,0.548563,-0.667817,-0.503083,0.548565,-0.66782,-0.503083,0.548565,-0.66782,-0.503083,0.548565,-0.66782,-0.633924,0.595167,-0.493879,-0.633924,0.595167,-0.493879,-0.633924,0.595167,-0.493879,-0.633924,0.595175,-0.493869,-0.633924,0.595175,-0.493869,-0.633924,0.595175,-0.493869,-0.702714,0.649965,-0.289376,-0.702714,0.649965,-0.289376,-0.702714,0.649965,-0.289376,-0.702715,0.649962,-0.289379,-0.702715,0.649962,-0.289379,-0.702715,0.649962,-0.289379,-0.707107,0.683012,-0.183013,-0.707107,0.683012,-0.183013,-0.707107,0.683012,-0.183013,-0.70711,0.68301,-0.183012,-0.70711,0.68301,-0.183012,-0.70711,0.68301,-0.183012,-0.702709,0.70758,-0.074366,-0.702709,0.70758,-0.074366,-0.702709,0.70758,-0.074366,-0.702718,0.707571,-0.074376,-0.702718,0.707571,-0.074376,-0.702718,0.707571,-0.074376,-0.633932,0.762366,0.130112,-0.633932,0.762366,0.130112,-0.633932,0.762366,0.130112,-0.633925,0.762371,0.130116,-0.633925,0.762371,0.130116,-0.633925,0.762371,0.130116,-0.503081,0.808979,0.304076,-0.503081,0.808979,0.304076,-0.503081,0.808979,0.304076,-0.503085,0.808981,0.304066,-0.503085,0.808981,0.304066,-0.503085,0.808981,0.304066,-0.323002,0.842841,0.430451,-0.323002,0.842841,0.430451,-0.323002,0.842841,0.430451,-0.322995,0.842844,0.430451,-0.322995,0.842844,0.430451,-0.322995,0.842844,0.430451,-0.111308,0.860643,0.496894,-0.111308,0.860643,0.496894,-0.111308,0.860643,0.496894,-0.111303,0.860645,0.496892,-0.111303,0.860645,0.496892,-0.111303,0.860645,0.496892,0,0.866025,0.500001,0,0.866025,0.500001,0,0.866025,0.500001,0,0.866025,0.500001,0.139731,0.662561,0.735859,0.139731,0.662561,0.735859,0.139731,0.662561,0.735859,0.139742,0.662569,0.73585,0.139742,0.662569,0.73585,0.139742,0.662569,0.73585,0.405536,0.640216,0.652429,0.405536,0.640216,0.652429,0.405536,0.640216,0.652429,0.405528,0.64021,0.65244,0.405528,0.64021,0.65244,0.405528,0.64021,0.65244,0.631624,0.597702,0.493764,0.631624,0.597702,0.493764,0.631624,0.597702,0.493764,0.631638,0.59769,0.493761,0.631638,0.59769,0.493761,0.631638,0.59769,0.493761,0.795905,0.539175,0.275365,0.795905,0.539175,0.275365,0.795905,0.539175,0.275365,0.795905,0.539174,0.275367,0.795905,0.539174,0.275367,0.795905,0.539174,0.275367,0.882266,0.470383,0.018617,0.882266,0.470383,0.018617,0.882266,0.470383,0.018617,0.882267,0.47038,0.018626,0.882267,0.47038,0.018626,0.882267,0.47038,0.018626,0.891006,0.438522,-0.117502,0.891006,0.438522,-0.117502,0.891006,0.438522,-0.117502,0.891006,0.438522,-0.117502,0.882265,0.398053,-0.251321,0.882265,0.398053,-0.251321,0.882265,0.398053,-0.251321,0.882264,0.398054,-0.251323,0.882264,0.398054,-0.251323,0.882264,0.398054,-0.251323,0.7959,0.329261,-0.508065,0.7959,0.329261,-0.508065,0.7959,0.329261,-0.508065,0.795902,0.329259,-0.508063,0.795902,0.329259,-0.508063,0.795902,0.329259,-0.508063,0.631632,0.270741,-0.726458,0.631632,0.270741,-0.726458,0.631632,0.270741,-0.726458,0.63163,0.270737,-0.726461,0.63163,0.270737,-0.726461,0.63163,0.270737,-0.726461,0.405527,0.228228,-0.885133,0.405527,0.228228,-0.885133,0.405527,0.228228,-0.885133,0.405536,0.228221,-0.88513,0.405536,0.228221,-0.88513,0.405536,0.228221,-0.88513,0.139744,0.205869,-0.96855,0.139744,0.205869,-0.96855,0.139744,0.205869,-0.96855,0.139735,0.205876,-0.96855,0.139735,0.205876,-0.96855,0.139735,0.205876,-0.96855,0,0.207909,-0.978148,0,0.207909,-0.978148,0,0.207909,-0.978148,0,0.207909,-0.978148,0,0.207909,-0.978148,-0.139744,0.205878,-0.968548,-0.139744,0.205878,-0.968548,-0.139744,0.205878,-0.968548,-0.139735,0.205869,-0.968552,-0.139735,0.205869,-0.968552,-0.139735,0.205869,-0.968552,-0.40553,0.228219,-0.885133,-0.40553,0.228219,-0.885133,-0.40553,0.228219,-0.885133,-0.405538,0.228229,-0.885127,-0.405538,0.228229,-0.885127,-0.405538,0.228229,-0.885127,-0.63163,0.270736,-0.726461,-0.63163,0.270736,-0.726461,-0.63163,0.270736,-0.726461,-0.63163,0.270736,-0.726461,-0.795903,0.329261,-0.50806,-0.795903,0.329261,-0.50806,-0.795903,0.329261,-0.50806,-0.795903,0.329256,-0.508064,-0.795903,0.329256,-0.508064,-0.795903,0.329256,-0.508064,-0.882264,0.398054,-0.251321,-0.882264,0.398054,-0.251321,-0.882264,0.398054,-0.251321,-0.882264,0.398054,-0.251322,-0.882264,0.398054,-0.251322,-0.882264,0.398054,-0.251322,-0.891006,0.438522,-0.117502,-0.891006,0.438522,-0.117502,-0.891006,0.438522,-0.117502,-0.891006,0.438522,-0.117502,-0.891006,0.438522,-0.117502,-0.882267,0.470382,0.018622,-0.882267,0.470382,0.018622,-0.882267,0.470382,0.018622,-0.882265,0.470385,0.018624,-0.882265,0.470385,0.018624,-0.882265,0.470385,0.018624,-0.795902,0.539178,0.275367,-0.795902,0.539178,0.275367,-0.795902,0.539178,0.275367,-0.795904,0.539176,0.275366,-0.795904,0.539176,0.275366,-0.795904,0.539176,0.275366,-0.631633,0.597696,0.493761,-0.631633,0.597696,0.493761,-0.631633,0.597696,0.493761,-0.631632,0.597694,0.493764,-0.631632,0.597694,0.493764,-0.631632,0.597694,0.493764,-0.405524,0.64022,0.652433,-0.405524,0.64022,0.652433,-0.405524,0.64022,0.652433,-0.405537,0.64021,0.652434,-0.405537,0.64021,0.652434,-0.405537,0.64021,0.652434,-0.139748,0.662565,0.735852,-0.139748,0.662565,0.735852,-0.139748,0.662565,0.735852,-0.139738,0.662571,0.735848,-0.139738,0.662571,0.735848,-0.139738,0.662571,0.735848,0,0.669131,0.743145,0,0.669131,0.743145,0,0.669131,0.743145,0,0.669134,0.743142,0,0.669134,0.743142,0,0.669134,0.743142,0,0.406734,0.913547,0,0.406734,0.913547,0,0.406734,0.913547,0,0.406742,0.913543,0,0.406742,0.913543,0,0.406742,0.913543,0.987688,0.151107,-0.040489,0.987688,0.151107,-0.040489,0.987688,0.151107,-0.040489,0.987688,0.151109,-0.04049,0.987688,0.151109,-0.04049,0.987688,0.151109,-0.04049,0.448469,0.37714,0.810334,0.448469,0.37714,0.810334,0.448469,0.37714,0.810334,0.448533,0.377128,0.810304,0.448533,0.377128,0.810304,0.448533,0.377128,0.810304,0.448528,0.377123,0.810309,0.448528,0.377123,0.810309,0.448528,0.377123,0.810309,0.154684,0.401842,0.90255,0.154684,0.401842,0.90255,0.154684,0.401842,0.90255,0.154558,0.401854,0.902566,0.154558,0.401854,0.902566,0.154558,0.401854,0.902566,0.154558,0.401854,0.902566,0.880281,0.265386,0.393288,0.880281,0.265386,0.393288,0.880281,0.265386,0.393288,0.880299,0.265375,0.393256,0.880299,0.265375,0.393256,0.880299,0.265375,0.393256,0.880302,0.265381,0.393245,0.880302,0.265381,0.393245,0.880302,0.265381,0.393245,0.69862,0.330104,0.634793,0.69862,0.330104,0.634793,0.69862,0.330104,0.634793,0.698614,0.330106,0.634798,0.698614,0.330106,0.634798,0.698614,0.330106,0.634798,0.698616,0.330108,0.634795,0.698616,0.330108,0.634795,0.698616,0.330108,0.634795,0.975828,0.189283,0.109235,0.975828,0.189283,0.109235,0.975828,0.189283,0.109235,0.97582,0.189299,0.10928,0.97582,0.189299,0.10928,0.97582,0.189299,0.10928,0.975819,0.189293,0.109291,0.975819,0.189293,0.109291,0.975819,0.189293,0.109291,0.975814,0.109271,-0.189331,0.975814,0.109271,-0.189331,0.975814,0.109271,-0.189331,0.975821,0.109286,-0.189288,0.975821,0.109286,-0.189288,0.975821,0.109286,-0.189288,0.97582,0.109289,-0.189293,0.97582,0.109289,-0.189293,0.97582,0.109289,-0.189293,0.448466,-0.078563,-0.89034,0.448466,-0.078563,-0.89034,0.448466,-0.078563,-0.89034,0.448539,-0.078548,-0.890305,0.448539,-0.078548,-0.890305,0.448539,-0.078548,-0.890305,0.448533,-0.078543,-0.890308,0.448533,-0.078543,-0.890308,0.448533,-0.078543,-0.890308,0.154497,-0.103274,-0.982581,0.154497,-0.103274,-0.982581,0.154497,-0.103274,-0.982581,0.154552,-0.103269,-0.982573,0.154552,-0.103269,-0.982573,0.154552,-0.103269,-0.982573,0.154564,-0.10328,-0.98257,0.154564,-0.10328,-0.98257,0.154564,-0.10328,-0.98257,0.698602,-0.031521,-0.714816,0.698602,-0.031521,-0.714816,0.698602,-0.031521,-0.714816,0.698607,-0.031519,-0.714811,0.698607,-0.031519,-0.714811,0.698607,-0.031519,-0.714811,0.698616,-0.031527,-0.714802,0.698616,-0.031527,-0.714802,0.698616,-0.031527,-0.714802,0.88034,0.033213,-0.473179,0.88034,0.033213,-0.473179,0.88034,0.033213,-0.473179,0.880302,0.033188,-0.473252,0.880302,0.033188,-0.473252,0.880302,0.033188,-0.473252,0.880298,0.033193,-0.473259,0.880298,0.033193,-0.473259,0.880298,0.033193,-0.473259,0,-0.104529,-0.994522,0,-0.104529,-0.994522,0,-0.104529,-0.994522,0,-0.10453,-0.994522,0,-0.10453,-0.994522,0,-0.10453,-0.994522,-0.987689,0.151103,-0.040488,-0.987689,0.151103,-0.040488,-0.987689,0.151103,-0.040488,-0.987688,0.151107,-0.040489,-0.987688,0.151107,-0.040489,-0.987688,0.151107,-0.040489,-0.448616,0.377112,0.810266,-0.448616,0.377112,0.810266,-0.448616,0.377112,0.810266,-0.448543,0.377117,0.810304,-0.448543,0.377117,0.810304,-0.448543,0.377117,0.810304,-0.448522,0.377139,0.810305,-0.448522,0.377139,0.810305,-0.448522,0.377139,0.810305,-0.698637,0.330103,0.634774,-0.698637,0.330103,0.634774,-0.698637,0.330103,0.634774,-0.698608,0.330108,0.634803,-0.698608,0.330108,0.634803,-0.698608,0.330108,0.634803,-0.698611,0.330104,0.634802,-0.698611,0.330104,0.634802,-0.698611,0.330104,0.634802,-0.880319,0.265368,0.393216,-0.880319,0.265368,0.393216,-0.880319,0.265368,0.393216,-0.8803,0.265375,0.393252,-0.8803,0.265375,0.393252,-0.8803,0.265375,0.393252,-0.880299,0.265377,0.393253,-0.880299,0.265377,0.393253,-0.880299,0.265377,0.393253,-0.154538,0.401847,0.902572,-0.154538,0.401847,0.902572,-0.154538,0.401847,0.902572,-0.154553,0.401848,0.90257,-0.154553,0.401848,0.90257,-0.154553,0.401848,0.90257,-0.154556,0.401845,0.90257,-0.154556,0.401845,0.90257,-0.154556,0.401845,0.90257,-0.975817,0.189294,0.109314,-0.975817,0.189294,0.109314,-0.975817,0.189294,0.109314,-0.975821,0.189288,0.109284,-0.975821,0.189288,0.109284,-0.975821,0.189288,0.109284,-0.975821,0.189288,0.109284,-0.975826,0.109299,-0.189257,-0.975826,0.109299,-0.189257,-0.975826,0.109299,-0.189257,-0.97582,0.109293,-0.189289,-0.97582,0.109293,-0.189289,-0.97582,0.109293,-0.189289,-0.97582,0.109287,-0.189292,-0.97582,0.109287,-0.189292,-0.97582,0.109287,-0.189292,-0.448516,-0.078548,-0.890316,-0.448516,-0.078548,-0.890316,-0.448516,-0.078548,-0.890316,-0.448541,-0.078546,-0.890304,-0.448541,-0.078546,-0.890304,-0.448541,-0.078546,-0.890304,-0.448532,-0.078559,-0.890308,-0.448532,-0.078559,-0.890308,-0.448532,-0.078559,-0.890308,-0.880293,0.033197,-0.473268,-0.880293,0.033197,-0.473268,-0.880293,0.033197,-0.473268,-0.8803,0.033199,-0.473254,-0.8803,0.033199,-0.473254,-0.8803,0.033199,-0.473254,-0.880298,0.033192,-0.473259,-0.880298,0.033192,-0.473259,-0.880298,0.033192,-0.473259,-0.698635,-0.031525,-0.714783,-0.698635,-0.031525,-0.714783,-0.698635,-0.031525,-0.714783,-0.698608,-0.03153,-0.714809,-0.698608,-0.03153,-0.714809,-0.698608,-0.03153,-0.714809,-0.698615,-0.031517,-0.714803,-0.698615,-0.031517,-0.714803,-0.698615,-0.031517,-0.714803,-0.154636,-0.103276,-0.982559,-0.154636,-0.103276,-0.982559,-0.154636,-0.103276,-0.982559,-0.154552,-0.103274,-0.982572,-0.154552,-0.103274,-0.982572,-0.154552,-0.103274,-0.982572,-0.154553,-0.103273,-0.982572,-0.154553,-0.103273,-0.982572,-0.154553,-0.103273,-0.982572,1,0,0,1,0,0,1,0,0,1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,0.000052,-0.965932,0.258795,0.000052,-0.965932,0.258795,0.000052,-0.965932,0.258795,-0.000348,-0.965882,0.258981,-0.000348,-0.965882,0.258981,-0.000348,-0.965882,0.258981,0.000005,-0.965927,0.258816,0.000005,-0.965927,0.258816,0.000005,-0.965927,0.258816,-0.000061,-0.965915,0.25886,-0.000061,-0.965915,0.25886,-0.000061,-0.965915,0.25886,-0.000002,-0.965925,0.258821,-0.000002,-0.965925,0.258821,-0.000002,-0.965925,0.258821,0.000008,-0.965928,0.258811,0.000008,-0.965928,0.258811,0.000008,-0.965928,0.258811,-0.000001,-0.965926,0.258819,-0.000001,-0.965926,0.258819,-0.000001,-0.965926,0.258819,0,-0.965926,0.258818,0,-0.965926,0.258818,0,-0.965926,0.258818,-0.000002,-0.965925,0.258821,-0.000002,-0.965925,0.258821,-0.000002,-0.965925,0.258821,-0.000051,-0.965951,0.258725,-0.000051,-0.965951,0.258725,-0.000051,-0.965951,0.258725,-0.00023,-0.966048,0.258363,-0.00023,-0.966048,0.258363,-0.00023,-0.966048,0.258363,-0.000001,-0.965925,0.258822,-0.000001,-0.965925,0.258822,-0.000001,-0.965925,0.258822,-0.000162,-0.965985,0.258597,-0.000162,-0.965985,0.258597,-0.000162,-0.965985,0.258597,0.000011,-0.965921,0.258835,0.000011,-0.965921,0.258835,0.000011,-0.965921,0.258835,-0.000249,-0.965992,0.258572,-0.000249,-0.965992,0.258572,-0.000249,-0.965992,0.258572,0.000003,-0.965925,0.258823,0.000003,-0.965925,0.258823,0.000003,-0.965925,0.258823,-0.000017,-0.965929,0.258808,-0.000017,-0.965929,0.258808,-0.000017,-0.965929,0.258808,0.000003,-0.965925,0.258823,0.000003,-0.965925,0.258823,0.000003,-0.965925,0.258823,0,-0.965926,0.25882,0,-0.965926,0.25882,0,-0.965926,0.25882,0.000243,-0.966043,0.258381,0.000243,-0.966043,0.258381,0.000243,-0.966043,0.258381,-0.000154,-0.965887,0.258965,-0.000154,-0.965887,0.258965,-0.000154,-0.965887,0.258965,-0.000009,-0.965922,0.258832,-0.000009,-0.965922,0.258832,-0.000009,-0.965922,0.258832,0.00009,-0.965956,0.258707,0.00009,-0.965956,0.258707,0.00009,-0.965956,0.258707,-0.000012,-0.965921,0.258838,-0.000012,-0.965921,0.258838,-0.000012,-0.965921,0.258838,0.000008,-0.965928,0.25881,0.000008,-0.965928,0.25881,0.000008,-0.965928,0.25881,0.000002,-0.965928,0.258812,0.000002,-0.965928,0.258812,0.000002,-0.965928,0.258812,-0.000004,-0.965926,0.25882,-0.000004,-0.965926,0.25882,-0.000004,-0.965926,0.25882,0.000093,-0.96595,0.258728,0.000093,-0.96595,0.258728,0.000093,-0.96595,0.258728,-0.000001,-0.965926,0.258819,-0.000001,-0.965926,0.258819,-0.000001,-0.965926,0.258819,-0.00001,-0.96593,0.258805,-0.00001,-0.96593,0.258805,-0.00001,-0.96593,0.258805,-0.000284,-0.966078,0.258252,-0.000284,-0.966078,0.258252,-0.000284,-0.966078,0.258252,-0.000003,-0.965927,0.258816,-0.000003,-0.965927,0.258816,-0.000003,-0.965927,0.258816,0.000032,-0.965914,0.258865,0.000032,-0.965914,0.258865,0.000032,-0.965914,0.258865,-0.000004,-0.965927,0.258815,-0.000004,-0.965927,0.258815,-0.000004,-0.965927,0.258815,0.000014,-0.965922,0.258834,0.000014,-0.965922,0.258834,0.000014,-0.965922,0.258834,0.000001,-0.965925,0.25882,0.000001,-0.965925,0.25882,0.000001,-0.965925,0.25882,-0.000026,-0.965931,0.258801,-0.000026,-0.965931,0.258801,-0.000026,-0.965931,0.258801,0,-0.965926,0.258819,0,-0.965926,0.258819,0,-0.965926,0.258819,0.000001,-0.965926,0.258819,0.000001,-0.965926,0.258819,0.000001,-0.965926,0.258819,0,-0.965926,0.258819,0,-0.965926,0.258819,0,-0.965926,0.258819,0.000001,-0.965926,0.25882,0.000001,-0.965926,0.25882,0.000001,-0.965926,0.25882,0,-0.965926,0.258819,0,-0.965926,0.258819,0,-0.965926,0.258819,0,-0.965926,0.258819,0,-0.965926,0.258819,0,-0.965925,0.258822,0,-0.965925,0.258822,0,-0.965925,0.258822,0.000001,-0.965926,0.258819,0.000001,-0.965926,0.258819,0.000001,-0.965926,0.258819,0,-0.965926,0.258819,0,-0.965926,0.258819,0,-0.965926,0.258819,0,-0.965926,0.258819,0,-0.965926,0.258819,0,-0.965926,0.258819,0,-0.965926,0.258819,0,-0.965926,0.258819,0,-0.965926,0.258819,0,-0.965926,0.258819,0,-0.965926,0.258819,0,-0.965926,0.258819,0,-0.965926,0.258819,0,-0.965926,0.258819,0,-0.965926,0.258819,0,-0.965926,0.25882,0,-0.965926,0.25882,0,-0.965926,0.25882,-0.000002,-0.258822,-0.965925,-0.000002,-0.258822,-0.965925,-0.000002,-0.258822,-0.965925,0,-0.258799,-0.965931,0,-0.258799,-0.965931,0,-0.258799,-0.965931,0,-0.258802,-0.96593,0,-0.258802,-0.96593,0,-0.258802,-0.96593,0,-0.258819,-0.965926,0,-0.258819,-0.965926,0,-0.258819,-0.965926,0,0.258828,0.965924,0,0.258828,0.965924,0,0.258828,0.965924,0,0.258722,0.965952,0,0.258722,0.965952,0,0.258722,0.965952,0.000001,0.258957,0.965889,0.000001,0.258957,0.965889,0.000001,0.258957,0.965889,0,0.258829,0.965923,0,0.258829,0.965923,0,0.258829,0.965923,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-0.99341,-0.114614,0,-0.99341,-0.114614,0,-0.99341,-0.114614,0,-0.99341,-0.114614,0,-0.941542,-0.336896,0,-0.941542,-0.336896,0,-0.941542,-0.336896,0,-0.941542,-0.336896,0,-0.843755,-0.536728,0,-0.843755,-0.536728,0,-0.843755,-0.536728,0,-0.843755,-0.536728,0,-0.707109,-0.707104,0,-0.707109,-0.707104,0,-0.707109,-0.707104,0,-0.707109,-0.707104,0,-0.536731,-0.843753,0,-0.536731,-0.843753,0,-0.536731,-0.843753,0,-0.536731,-0.843753,0,-0.336898,-0.941541,0,-0.336898,-0.941541,0,-0.336898,-0.941541,0,-0.336898,-0.941541,0,-0.114612,-0.99341,0,-0.114612,-0.99341,0,-0.114612,-0.99341,0,-0.114612,-0.99341,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0.114612,-0.99341,0,0.114612,-0.99341,0,0.114612,-0.99341,0,0.114612,-0.99341,0,0.336899,-0.941541,0,0.336899,-0.941541,0,0.336899,-0.941541,0,0.336899,-0.941541,0,0.536731,-0.843753,0,0.536731,-0.843753,0,0.536731,-0.843753,0,0.536731,-0.843753,0,0.707109,-0.707104,0,0.707109,-0.707104,0,0.707109,-0.707104,0,0.707109,-0.707104,0,0.843749,-0.536739,0,0.843749,-0.536739,0,0.843749,-0.536739,0,0.843749,-0.536739,0,0.941543,-0.336894,0,0.941543,-0.336894,0,0.941543,-0.336894,0,0.941543,-0.336894,0,0.99341,-0.114616,0,0.99341,-0.114616,0,0.99341,-0.114616,0,0.99341,-0.114616,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0.154549,-0.975821,-0.154558,0.154549,-0.975821,-0.154558,0.154549,-0.975821,-0.154558,0.154554,-0.975821,-0.154553,0.154554,-0.975821,-0.154553,0.154554,-0.975821,-0.154553,0.139742,-0.882266,-0.449532,0.139742,-0.882266,-0.449532,0.139742,-0.882266,-0.449532,0.139732,-0.882264,-0.449539,0.139732,-0.882264,-0.449539,0.139732,-0.882264,-0.449539,0.111302,-0.702712,-0.702714,0.111302,-0.702712,-0.702714,0.111302,-0.702712,-0.702714,0.111302,-0.702712,-0.702715,0.111302,-0.702712,-0.702715,0.111302,-0.702712,-0.702715,0.071725,-0.452821,-0.888712,0.071725,-0.452821,-0.888712,0.071725,-0.452821,-0.888712,0.071722,-0.452821,-0.888712,0.071722,-0.452821,-0.888712,0.071722,-0.452821,-0.888712,0.024771,-0.156387,-0.987385,0.024771,-0.156387,-0.987385,0.024771,-0.156387,-0.987385,0.071885,-0.141078,-0.987385,0.071885,-0.141078,-0.987385,0.071885,-0.141078,-0.987385,0.11196,-0.111962,-0.987385,0.11196,-0.111962,-0.987385,0.11196,-0.111962,-0.987385,0.324181,-0.324186,-0.888712,0.324181,-0.324186,-0.888712,0.324181,-0.324186,-0.888712,0.324184,-0.324181,-0.888713,0.324184,-0.324181,-0.888713,0.324184,-0.324181,-0.888713,0.503089,-0.503085,-0.702714,0.503089,-0.503085,-0.702714,0.503089,-0.503085,-0.702714,0.503088,-0.503088,-0.702713,0.503088,-0.503088,-0.702713,0.503088,-0.503088,-0.702713,0.631631,-0.631631,-0.449538,0.631631,-0.631631,-0.449538,0.631631,-0.631631,-0.449538,0.631631,-0.631631,-0.449538,0.631631,-0.631631,-0.449538,0.698609,-0.698612,-0.154555,0.698609,-0.698612,-0.154555,0.698609,-0.698612,-0.154555,0.698611,-0.698611,-0.154553,0.698611,-0.698611,-0.154553,0.698611,-0.698611,-0.154553,0.707105,-0.707108,0,0.707105,-0.707108,0,0.707105,-0.707108,0,0.707105,-0.707108,0,0.707105,-0.707108,0,0.891007,-0.45399,0,0.891007,-0.45399,0,0.891007,-0.45399,0,0.891007,-0.45399,0,0.891007,-0.45399,0,0.987688,-0.156434,0,0.987688,-0.156434,0,0.987688,-0.156434,0,0.987688,-0.156434,0,1,0,0,1,0,0,1,0,0,1,0,0,0.987688,0.156434,0,0.987688,0.156434,0,0.987688,0.156434,0,0.987688,0.156434,0,0.987688,0.156434,0,0.891003,0.453998,0,0.891003,0.453998,0,0.891003,0.453998,0,0.891003,0.453998,0,0.891003,0.453998,0,0.707112,0.707102,0,0.707112,0.707102,0,0.707112,0.707102,0,0.707112,0.707102,0,0.453988,0.891008,0,0.453988,0.891008,0,0.453988,0.891008,0,0.453988,0.891008,0,0.453988,0.891008,0,0.156438,0.987688,0,0.156438,0.987688,0,0.156438,0.987688,0,0.156438,0.987688,0,0.156438,0.987688,0,-0.156437,-0.987688,0,-0.156437,-0.987688,0,-0.156437,-0.987688,0,-0.156437,-0.987688,0,-0.154552,-0.975821,-0.154553,-0.154552,-0.975821,-0.154553,-0.154552,-0.975821,-0.154553,-0.154557,-0.97582,-0.154558,-0.154557,-0.97582,-0.154558,-0.154557,-0.97582,-0.154558,-0.139738,-0.882264,-0.449537,-0.139738,-0.882264,-0.449537,-0.139738,-0.882264,-0.449537,-0.139735,-0.882266,-0.449535,-0.139735,-0.882266,-0.449535,-0.139735,-0.882266,-0.449535,-0.111302,-0.702712,-0.702715,-0.111302,-0.702712,-0.702715,-0.111302,-0.702712,-0.702715,-0.1113,-0.702714,-0.702713,-0.1113,-0.702714,-0.702713,-0.1113,-0.702714,-0.702713,-0.071722,-0.45282,-0.888712,-0.071722,-0.45282,-0.888712,-0.071722,-0.45282,-0.888712,-0.071722,-0.45282,-0.888712,-0.02477,-0.156387,-0.987385,-0.02477,-0.156387,-0.987385,-0.02477,-0.156387,-0.987385,0,0.156435,-0.987688,0,0.156435,-0.987688,0,0.156435,-0.987688,0,0.156435,-0.987688,-0.139735,0.882265,-0.449537,-0.139735,0.882265,-0.449537,-0.139735,0.882265,-0.449537,-0.139742,0.882266,-0.449532,-0.139742,0.882266,-0.449532,-0.139742,0.882266,-0.449532,-0.154558,0.97582,-0.154552,-0.154558,0.97582,-0.154552,-0.154558,0.97582,-0.154552,-0.154552,0.97582,-0.154558,-0.154552,0.97582,-0.154558,-0.154552,0.97582,-0.154558,-0.44853,0.880302,-0.15456,-0.44853,0.880302,-0.15456,-0.44853,0.880302,-0.15456,-0.448538,0.8803,-0.154552,-0.448538,0.8803,-0.154552,-0.448538,0.8803,-0.154552,-0.698615,0.698606,-0.154553,-0.698615,0.698606,-0.154553,-0.698615,0.698606,-0.154553,-0.69861,0.69861,-0.15456,-0.69861,0.69861,-0.15456,-0.69861,0.69861,-0.15456,-0.880302,0.448533,-0.154555,-0.880302,0.448533,-0.154555,-0.880302,0.448533,-0.154555,-0.880303,0.448531,-0.154553,-0.880303,0.448531,-0.154553,-0.880303,0.448531,-0.154553,-0.975819,0.15456,-0.15456,-0.975819,0.15456,-0.15456,-0.975819,0.15456,-0.15456,-0.975821,0.154553,-0.154553,-0.975821,0.154553,-0.154553,-0.975821,0.154553,-0.154553,-0.987688,0,-0.156434,-0.987688,0,-0.156434,-0.987688,0,-0.156434,-0.987687,0,-0.15644,-0.987687,0,-0.15644,-0.987687,0,-0.15644,-0.97582,-0.15456,-0.154553,-0.97582,-0.15456,-0.154553,-0.97582,-0.15456,-0.154553,-0.97582,-0.154552,-0.154561,-0.97582,-0.154552,-0.154561,-0.97582,-0.154552,-0.154561,-0.8803,-0.448538,-0.154551,-0.8803,-0.448538,-0.154551,-0.8803,-0.448538,-0.154551,-0.8803,-0.448536,-0.154553,-0.8803,-0.448536,-0.154553,-0.8803,-0.448536,-0.154553,-0.698615,-0.698605,-0.154557,-0.698615,-0.698605,-0.154557,-0.698615,-0.698605,-0.154557,-0.698611,-0.698611,-0.154551,-0.698611,-0.698611,-0.154551,-0.698611,-0.698611,-0.154551,-0.448535,-0.8803,-0.154555,-0.448535,-0.8803,-0.154555,-0.448535,-0.8803,-0.154555,-0.448537,-0.880299,-0.154557,-0.448537,-0.880299,-0.154557,-0.448537,-0.880299,-0.154557,-0.631632,-0.631632,-0.449534,-0.631632,-0.631632,-0.449534,-0.631632,-0.631632,-0.449534,-0.631635,-0.631631,-0.449532,-0.631635,-0.631631,-0.449532,-0.631635,-0.631631,-0.449532,-0.503089,-0.503087,-0.702713,-0.503089,-0.503087,-0.702713,-0.503089,-0.503087,-0.702713,-0.503081,-0.503089,-0.702716,-0.503081,-0.503089,-0.702716,-0.503081,-0.503089,-0.702716,-0.324181,-0.324186,-0.888713,-0.324181,-0.324186,-0.888713,-0.324181,-0.324186,-0.888713,-0.324184,-0.324184,-0.888712,-0.324184,-0.324184,-0.888712,-0.324184,-0.324184,-0.888712,-0.111961,-0.111961,-0.987385,-0.111961,-0.111961,-0.987385,-0.111961,-0.111961,-0.987385,-0.141078,-0.071884,-0.987385,-0.141078,-0.071884,-0.987385,-0.141078,-0.071884,-0.987385,-0.408497,-0.208133,-0.888713,-0.408497,-0.208133,-0.888713,-0.408497,-0.208133,-0.888713,-0.408496,-0.208142,-0.888711,-0.408496,-0.208142,-0.888711,-0.408496,-0.208142,-0.888711,-0.45282,-0.071716,-0.888713,-0.45282,-0.071716,-0.888713,-0.45282,-0.071716,-0.888713,-0.452822,-0.071722,-0.888712,-0.452822,-0.071722,-0.888712,-0.452822,-0.071722,-0.888712,-0.45282,0.071727,-0.888712,-0.45282,0.071727,-0.888712,-0.45282,0.071727,-0.888712,-0.452823,0.071723,-0.888711,-0.452823,0.071723,-0.888711,-0.452823,0.071723,-0.888711,-0.156386,0.024771,-0.987385,-0.156386,0.024771,-0.987385,-0.156386,0.024771,-0.987385,-0.141079,0.071883,-0.987385,-0.141079,0.071883,-0.987385,-0.141079,0.071883,-0.987385,-0.408498,0.208135,-0.888712,-0.408498,0.208135,-0.888712,-0.408498,0.208135,-0.888712,-0.408494,0.208138,-0.888713,-0.408494,0.208138,-0.888713,-0.408494,0.208138,-0.888713,-0.324184,0.324181,-0.888713,-0.324184,0.324181,-0.888713,-0.324184,0.324181,-0.888713,-0.324181,0.324186,-0.888712,-0.324181,0.324186,-0.888712,-0.324181,0.324186,-0.888712,-0.208138,0.408495,-0.888713,-0.208138,0.408495,-0.888713,-0.208138,0.408495,-0.888713,-0.208136,0.408495,-0.888713,-0.208136,0.408495,-0.888713,-0.208136,0.408495,-0.888713,-0.071883,0.141079,-0.987385,-0.071883,0.141079,-0.987385,-0.071883,0.141079,-0.987385,-0.071727,0.452821,-0.888712,-0.071727,0.452821,-0.888712,-0.071727,0.452821,-0.888712,-0.071722,0.45282,-0.888713,-0.071722,0.45282,-0.888713,-0.071722,0.45282,-0.888713,-0.323004,0.633928,-0.702712,-0.323004,0.633928,-0.702712,-0.323004,0.633928,-0.702712,-0.322998,0.633928,-0.702715,-0.322998,0.633928,-0.702715,-0.322998,0.633928,-0.702715,-0.503087,0.503083,-0.702716,-0.503087,0.503083,-0.702716,-0.503087,0.503083,-0.702716,-0.503085,0.503091,-0.702713,-0.503085,0.503091,-0.702713,-0.503085,0.503091,-0.702713,-0.63393,0.322994,-0.702714,-0.63393,0.322994,-0.702714,-0.63393,0.322994,-0.702714,-0.633929,0.322995,-0.702715,-0.633929,0.322995,-0.702715,-0.633929,0.322995,-0.702715,-0.795904,0.405528,-0.449537,-0.795904,0.405528,-0.449537,-0.795904,0.405528,-0.449537,-0.795909,0.405524,-0.449532,-0.795909,0.405524,-0.449532,-0.795909,0.405524,-0.449532,-0.11196,0.111962,-0.987385,-0.11196,0.111962,-0.987385,-0.11196,0.111962,-0.987385,-0.702716,0.111298,-0.702712,-0.702716,0.111298,-0.702712,-0.702716,0.111298,-0.702712,-0.702712,0.111302,-0.702714,-0.702712,0.111302,-0.702714,-0.702712,0.111302,-0.702714,-0.882264,0.139735,-0.449537,-0.882264,0.139735,-0.449537,-0.882264,0.139735,-0.449537,-0.882264,0.139735,-0.449537,-0.702713,-0.111297,-0.702714,-0.702713,-0.111297,-0.702714,-0.702713,-0.111297,-0.702714,-0.702715,-0.111303,-0.702711,-0.702715,-0.111303,-0.702711,-0.702715,-0.111303,-0.702711,-0.882265,-0.139735,-0.449537,-0.882265,-0.139735,-0.449537,-0.882265,-0.139735,-0.449537,-0.882264,-0.139734,-0.449537,-0.882264,-0.139734,-0.449537,-0.882264,-0.139734,-0.449537,-0.63393,-0.323001,-0.702712,-0.63393,-0.323001,-0.702712,-0.63393,-0.323001,-0.702712,-0.63393,-0.322993,-0.702715,-0.63393,-0.322993,-0.702715,-0.63393,-0.322993,-0.702715,-0.156387,-0.024768,-0.987385,-0.156387,-0.024768,-0.987385,-0.156387,-0.024768,-0.987385,-0.208139,-0.408496,-0.888712,-0.208139,-0.408496,-0.888712,-0.208139,-0.408496,-0.888712,-0.208139,-0.408495,-0.888712,-0.208139,-0.408495,-0.888712,-0.208139,-0.408495,-0.888712,-0.795903,-0.405534,-0.449534,-0.795903,-0.405534,-0.449534,-0.795903,-0.405534,-0.449534,-0.795903,-0.405529,-0.449537,-0.795903,-0.405529,-0.449537,-0.795903,-0.405529,-0.449537,-0.323,-0.633927,-0.702714,-0.323,-0.633927,-0.702714,-0.323,-0.633927,-0.702714,-0.323001,-0.633926,-0.702715,-0.323001,-0.633926,-0.702715,-0.323001,-0.633926,-0.702715,-0.405534,-0.795901,-0.449537,-0.405534,-0.795901,-0.449537,-0.405534,-0.795901,-0.449537,-0.405532,-0.795904,-0.449534,-0.405532,-0.795904,-0.449534,-0.405532,-0.795904,-0.449534,-0.63163,0.631637,-0.449532,-0.63163,0.631637,-0.449532,-0.63163,0.631637,-0.449532,-0.631632,0.631632,-0.449536,-0.631632,0.631632,-0.449536,-0.631632,0.631632,-0.449536,-0.405534,0.795901,-0.449537,-0.405534,0.795901,-0.449537,-0.405534,0.795901,-0.449537,-0.405534,0.795901,-0.449537,-0.111302,0.702712,-0.702714,-0.111302,0.702712,-0.702714,-0.111302,0.702712,-0.702714,-0.111302,0.702712,-0.702715,-0.111302,0.702712,-0.702715,-0.111302,0.702712,-0.702715,0.139739,0.882264,-0.449537,0.139739,0.882264,-0.449537,0.139739,0.882264,-0.449537,0.139736,0.882266,-0.449535,0.139736,0.882266,-0.449535,0.139736,0.882266,-0.449535,0.405531,0.795903,-0.449536,0.405531,0.795903,-0.449536,0.405531,0.795903,-0.449536,0.405532,0.795902,-0.449537,0.405532,0.795902,-0.449537,0.405532,0.795902,-0.449537,0.323002,0.633927,-0.702713,0.323002,0.633927,-0.702713,0.323002,0.633927,-0.702713,0.323001,0.633928,-0.702713,0.323001,0.633928,-0.702713,0.323001,0.633928,-0.702713,0.208142,0.408493,-0.888713,0.208142,0.408493,-0.888713,0.208142,0.408493,-0.888713,0.208139,0.408497,-0.888712,0.208139,0.408497,-0.888712,0.208139,0.408497,-0.888712,0.071884,0.141078,-0.987385,0.071884,0.141078,-0.987385,0.071884,0.141078,-0.987385,0.111961,0.111961,-0.987385,0.111961,0.111961,-0.987385,0.111961,0.111961,-0.987385,0.408494,0.208141,-0.888712,0.408494,0.208141,-0.888712,0.408494,0.208141,-0.888712,0.408494,0.208143,-0.888712,0.408494,0.208143,-0.888712,0.408494,0.208143,-0.888712,0.45282,0.071726,-0.888712,0.45282,0.071726,-0.888712,0.45282,0.071726,-0.888712,0.452819,0.071722,-0.888713,0.452819,0.071722,-0.888713,0.452819,0.071722,-0.888713,0.156386,0.024771,-0.987385,0.156386,0.024771,-0.987385,0.156386,0.024771,-0.987385,0.452818,-0.071726,-0.888713,0.452818,-0.071726,-0.888713,0.452818,-0.071726,-0.888713,0.45282,-0.071722,-0.888712,0.45282,-0.071722,-0.888712,0.45282,-0.071722,-0.888712,0.156386,-0.024771,-0.987385,0.156386,-0.024771,-0.987385,0.156386,-0.024771,-0.987385,0.408494,-0.208138,-0.888713,0.408494,-0.208138,-0.888713,0.408494,-0.208138,-0.888713,0.408495,-0.208138,-0.888713,0.408495,-0.208138,-0.888713,0.408495,-0.208138,-0.888713,0.702716,-0.111298,-0.702712,0.702716,-0.111298,-0.702712,0.702716,-0.111298,-0.702712,0.702712,-0.111302,-0.702714,0.702712,-0.111302,-0.702714,0.702712,-0.111302,-0.702714,0.882264,-0.139735,-0.449537,0.882264,-0.139735,-0.449537,0.882264,-0.139735,-0.449537,0.882264,-0.139735,-0.449537,0.975821,-0.154554,-0.154555,0.975821,-0.154554,-0.154555,0.975821,-0.154554,-0.154555,0.975821,-0.154553,-0.154553,0.975821,-0.154553,-0.154553,0.975821,-0.154553,-0.154553,0.882265,0.139735,-0.449537,0.882265,0.139735,-0.449537,0.882265,0.139735,-0.449537,0.882264,0.139734,-0.449537,0.882264,0.139734,-0.449537,0.882264,0.139734,-0.449537,0.975821,0.154554,-0.154553,0.975821,0.154554,-0.154553,0.975821,0.154554,-0.154553,0.975821,0.154552,-0.154555,0.975821,0.154552,-0.154555,0.975821,0.154552,-0.154555,0.795898,0.405537,-0.449539,0.795898,0.405537,-0.449539,0.795898,0.405537,-0.449539,0.795898,0.405541,-0.449537,0.795898,0.405541,-0.449537,0.795898,0.405541,-0.449537,0.880297,0.448543,-0.154551,0.880297,0.448543,-0.154551,0.880297,0.448543,-0.154551,0.880298,0.448542,-0.154553,0.880298,0.448542,-0.154553,0.880298,0.448542,-0.154553,0.633924,0.323008,-0.702714,0.633924,0.323008,-0.702714,0.633924,0.323008,-0.702714,0.633924,0.323009,-0.702713,0.633924,0.323009,-0.702713,0.633924,0.323009,-0.702713,0.702715,0.111303,-0.702711,0.702715,0.111303,-0.702711,0.702715,0.111303,-0.702711,0.702713,0.111297,-0.702714,0.702713,0.111297,-0.702714,0.702713,0.111297,-0.702714,0.795901,-0.405533,-0.449539,0.795901,-0.405533,-0.449539,0.795901,-0.405533,-0.449539,0.795902,-0.405532,-0.449537,0.795902,-0.405532,-0.449537,0.795902,-0.405532,-0.449537,0.633928,-0.323002,-0.702713,0.633928,-0.323002,-0.702713,0.633928,-0.323002,-0.702713,0.633927,-0.323003,-0.702713,0.633927,-0.323003,-0.702713,0.633927,-0.323003,-0.702713,0.453989,0,-0.891007,0.453989,0,-0.891007,0.453989,0,-0.891007,0.453989,0,-0.891007,0.141078,0.071884,-0.987385,0.141078,0.071884,-0.987385,0.141078,0.071884,-0.987385,0.324184,0.324184,-0.888712,0.324184,0.324184,-0.888712,0.324184,0.324184,-0.888712,0.324186,0.324183,-0.888712,0.324186,0.324183,-0.888712,0.324186,0.324183,-0.888712,0.071722,0.45282,-0.888712,0.071722,0.45282,-0.888712,0.071722,0.45282,-0.888712,0.07172,0.452821,-0.888712,0.07172,0.452821,-0.888712,0.07172,0.452821,-0.888712,0.503089,0.503085,-0.702714,0.503089,0.503085,-0.702714,0.503089,0.503085,-0.702714,0.503088,0.503086,-0.702714,0.503088,0.503086,-0.702714,0.503088,0.503086,-0.702714,0.111301,0.702714,-0.702713,0.111301,0.702714,-0.702713,0.111301,0.702714,-0.702713,0.111303,0.702712,-0.702714,0.111303,0.702712,-0.702714,0.111303,0.702712,-0.702714,0.631634,0.63163,-0.449536,0.631634,0.63163,-0.449536,0.631634,0.63163,-0.449536,0.631631,0.631631,-0.449538,0.631631,0.631631,-0.449538,0.631631,0.631631,-0.449538,0.698615,0.698605,-0.154557,0.698615,0.698605,-0.154557,0.698615,0.698605,-0.154557,0.698611,0.698611,-0.154551,0.698611,0.698611,-0.154551,0.698611,0.698611,-0.154551,0.448533,0.880302,-0.154555,0.448533,0.880302,-0.154555,0.448533,0.880302,-0.154555,0.448535,0.8803,-0.154557,0.448535,0.8803,-0.154557,0.448535,0.8803,-0.154557,0.154558,0.97582,-0.154557,0.154558,0.97582,-0.154557,0.154558,0.97582,-0.154557,0.154553,0.975821,-0.154553,0.154553,0.975821,-0.154553,0.154553,0.975821,-0.154553,-0.024772,0.156387,-0.987385,-0.024772,0.156387,-0.987385,-0.024772,0.156387,-0.987385,0.024769,0.156387,-0.987385,0.024769,0.156387,-0.987385,0.024769,0.156387,-0.987385,-0.156434,0,-0.987688,-0.156434,0,-0.987688,-0.156434,0,-0.987688,-0.156434,0,-0.987688,-0.071883,-0.141079,-0.987385,-0.071883,-0.141079,-0.987385,-0.071883,-0.141079,-0.987385,-0.45399,-0.891006,0,-0.45399,-0.891006,0,-0.45399,-0.891006,0,-0.45399,-0.891006,0,-0.707112,-0.707102,0,-0.707112,-0.707102,0,-0.707112,-0.707102,0,-0.707112,-0.707102,0,-0.707112,-0.707102,0,-0.891005,-0.453993,0,-0.891005,-0.453993,0,-0.891005,-0.453993,0,-0.891005,-0.453993,0,-0.891005,-0.453993,0,-0.987687,-0.15644,0,-0.987687,-0.15644,0,-0.987687,-0.15644,0,-0.987687,-0.15644,0,-0.987687,-0.15644,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.987687,0.15644,0,-0.987687,0.15644,0,-0.987687,0.15644,0,-0.987687,0.15644,0,-0.987687,0.15644,0,-0.891008,0.453988,0,-0.891008,0.453988,0,-0.891008,0.453988,0,-0.891008,0.453988,0,-0.891008,0.453988,0,-0.707112,0.707102,0,-0.707112,0.707102,0,-0.707112,0.707102,0,-0.707112,0.707102,0,-0.707112,0.707102,0,-0.453985,0.891009,0,-0.453985,0.891009,0,-0.453985,0.891009,0,-0.453985,0.891009,0,-0.453985,0.891009,0,-0.156438,0.987688,0,-0.156438,0.987688,0,-0.156438,0.987688,0,-0.156438,0.987688,0,-0.156438,0.987688,0,0.987688,0,-0.156434,0.987688,0,-0.156434,0.987688,0,-0.156434,0.987688,0,-0.156434,0.987688,0,-0.156434,0.880301,-0.448535,-0.154554,0.880301,-0.448535,-0.154554,0.880301,-0.448535,-0.154554,0.8803,-0.448535,-0.154555,0.8803,-0.448535,-0.154555,0.8803,-0.448535,-0.154555,0.453993,-0.891005,0,0.453993,-0.891005,0,0.453993,-0.891005,0,0.453993,-0.891005,0,0.453993,-0.891005,0,0.448535,-0.880301,-0.154555,0.448535,-0.880301,-0.154555,0.448535,-0.880301,-0.154555,0.448538,-0.8803,-0.154551,0.448538,-0.8803,-0.154551,0.448538,-0.8803,-0.154551,0.40553,-0.795902,-0.44954,0.40553,-0.795902,-0.44954,0.40553,-0.795902,-0.44954,0.405532,-0.795902,-0.449539,0.405532,-0.795902,-0.449539,0.405532,-0.795902,-0.449539,0.322995,-0.633929,-0.702715,0.322995,-0.633929,-0.702715,0.322995,-0.633929,-0.702715,0.323002,-0.633929,-0.702712,0.323002,-0.633929,-0.702712,0.323002,-0.633929,-0.702712,0.208143,-0.408495,-0.888711,0.208143,-0.408495,-0.888711,0.208143,-0.408495,-0.888711,0.208134,-0.408496,-0.888713,0.208134,-0.408496,-0.888713,0.208134,-0.408496,-0.888713,0.141079,-0.071883,-0.987385,0.141079,-0.071883,-0.987385,0.141079,-0.071883,-0.987385,0.156433,-0.987689,0,0.156433,-0.987689,0,0.156433,-0.987689,0,0.156433,-0.987689,0,0.156433,-0.987689,0,0,0.987688,-0.156437,0,0.987688,-0.156437,0,0.987688,-0.156437,0,0.987688,-0.156437,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,0.891009,-0.453986,0,0.891009,-0.453986,0,0.891009,-0.453986,0,0.891009,-0.453986,0,0.707106,-0.707108,0,0.707106,-0.707108,0,0.707106,-0.707108,0,0.707106,-0.707108,0,0.987688,-0.156437,0,0.987688,-0.156437,0,0.987688,-0.156437,0,0.987688,-0.156437,0,0.891007,-0.453989,0,0.891007,-0.453989,0,0.891007,-0.453989,0,0.891007,-0.453989,0,0.891007,-0.453989,0,0.891007,-0.453989,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,0.707107,-0.707106,0,0.707107,-0.707106,0,0.707107,-0.707106,0,0.707107,-0.707106,0,0.707107,-0.707106,0,1,0,0,1,0,0,1,0,0,1,0,0,0.941544,0.336891,0,0.941544,0.336891,0,0.941544,0.336891,0,0.941544,0.336891,0,0.843754,0.53673,0,0.843754,0.53673,0,0.843754,0.53673,0,0.843754,0.53673,0,0.707106,0.707107,0,0.707106,0.707107,0,0.707106,0.707107,0,0.707104,0.70711,0,0.707104,0.70711,0,0.707104,0.70711,0,0.99341,0.114617,0,0.99341,0.114617,0,0.99341,0.114617,0,0.993409,0.11462,0,0.993409,0.11462,0,0.993409,0.11462,0,0.453992,-0.891006,0,0.453992,-0.891006,0,0.453992,-0.891006,0,0.453989,-0.891007,0,0.453989,-0.891007,0,0.453989,-0.891007,0,0.453989,-0.891007,0,0.453989,-0.891007,0,0.453988,-0.891008,0,0.453988,-0.891008,0,0.453988,-0.891008,0,0.453987,-0.891008,0,0.453987,-0.891008,0,0.453987,-0.891008,0,0.453991,-0.891006,0,0.453991,-0.891006,0,0.453991,-0.891006,0,0.45399,-0.891007,0,0.45399,-0.891007,0,0.45399,-0.891007,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,-0.987688,-0.000001,-0.156434,-0.987688,-0.000001,-0.156434,-0.987688,-0.000001,-0.156434,-0.987687,0,-0.15644,-0.987687,0,-0.15644,-0.987687,0,-0.15644,-0.156434,0,-0.987688,-0.156434,0,-0.987688,-0.156434,0,-0.987688,-0.156435,0,-0.987688,-0.156435,0,-0.987688,-0.156435,0,-0.987688,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,0.987688,0,-0.156434,0.987688,0,-0.156434,0.987688,0,-0.156434,0.987687,0,-0.156443,0.987687,0,-0.156443,0.987687,0,-0.156443,0.987688,0.000001,-0.156434,0.987688,0.000001,-0.156434,0.987688,0.000001,-0.156434,-0.987687,0,-0.15644,-0.987687,0,-0.15644,-0.987687,0,-0.15644,-0.987687,0,-0.15644,-0.707109,0,-0.707105,-0.707109,0,-0.707105,-0.707109,0,-0.707105,-0.707109,0,-0.707105,-0.707109,0,-0.707105,-0.707109,0,-0.707105,0.707109,0,-0.707105,0.707109,0,-0.707105,0.707109,0,-0.707105,0.707109,0,-0.707105,0.707109,0,-0.707105,0.156434,0,-0.987688,0.156434,0,-0.987688,0.156434,0,-0.987688,0.156434,0,-0.987688,0.156434,0,-0.987688,0.156434,0,-0.987688,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,0,-0.156435,-0.987688,0,-0.156435,-0.987688,0,-0.156435,-0.987688,0,-0.156435,-0.987688,0,-0.156435,-0.987688,0,-0.156435,-0.987688,0,-0.453991,-0.891006,0,-0.453991,-0.891006,0,-0.453991,-0.891006,0,-0.453989,-0.891007,0,-0.453989,-0.891007,0,-0.453989,-0.891007,0,-0.707106,-0.707108,0,-0.707106,-0.707108,0,-0.707106,-0.707108,0,-0.707107,-0.707106,0,-0.707107,-0.707106,0,-0.707107,-0.707106,0,-0.891009,-0.453986,0,-0.891009,-0.453986,0,-0.891009,-0.453986,0,-0.891007,-0.453989,0,-0.891007,-0.453989,0,-0.891007,-0.453989,0,-0.987688,-0.156437,0,-0.987688,-0.156437,0,-0.987688,-0.156437,0,-0.987688,-0.156437,0,-0.987688,-0.156437,0,0.536732,0.843753,0,0.536732,0.843753,0,0.536732,0.843753,0,0.53673,0.843754,0,0.53673,0.843754,0,0.53673,0.843754,0,0.536733,0.843752,0,0.536733,0.843752,0,0.536733,0.843752,0,0.536733,0.843752,0,0.536733,0.843752,0,0.536733,0.843752,0,1,0,0,1,0,0,1,0,0,0.941544,0.336891,0,0.941544,0.336891,0,0.941542,0.336896,0,0.941542,0.336896,0,0.941542,0.336896,0,0.843754,0.53673,0,0.843754,0.53673,0,0.843753,0.536732,0,0.843753,0.536732,0,0.843753,0.536732,0,0.707104,0.70711,0,0.707104,0.70711,0,0.707106,0.707107,0,0.707106,0.707107,0,0.707106,0.707107,0,0.993409,0.11462,0,0.993409,0.11462,0,0.993409,0.11462,0,0.99341,0.114617,0,0.99341,0.114617,0,0.99341,0.114617,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-0.000001,0.000001,1,-0.000001,0.000001,1,-0.000001,0.000001,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0.061744,-0.705759,0.705756,0.061744,-0.705759,0.705756,0.061744,-0.705759,0.705756,0.061745,-0.70576,0.705755,0.061745,-0.70576,0.705755,0.061745,-0.70576,0.705755,0.183366,-0.684315,0.705755,0.183366,-0.684315,0.705755,0.183366,-0.684315,0.705755,0.183365,-0.684314,0.705756,0.183365,-0.684314,0.705756,0.183365,-0.684314,0.705756,0.299404,-0.642081,0.705754,0.299404,-0.642081,0.705754,0.299404,-0.642081,0.705754,0.299405,-0.642082,0.705754,0.299405,-0.642082,0.705754,0.299405,-0.642082,0.705754,0.299407,-0.642078,0.705756,0.299407,-0.642078,0.705756,0.299407,-0.642078,0.705756,0.406357,-0.580332,0.705754,0.406357,-0.580332,0.705754,0.406357,-0.580332,0.705754,0.406347,-0.58033,0.705762,0.406347,-0.58033,0.705762,0.406347,-0.58033,0.705762,0.500947,-0.500951,0.705762,0.500947,-0.500951,0.705762,0.500947,-0.500951,0.705762,0.500951,-0.500951,0.705759,0.500951,-0.500951,0.705759,0.500951,-0.500951,0.705759,0.580341,-0.406344,0.705754,0.580341,-0.406344,0.705754,0.580341,-0.406344,0.705754,0.580329,-0.40635,0.705761,0.580329,-0.40635,0.705761,0.580329,-0.40635,0.705761,0.580329,-0.406353,0.705759,0.580329,-0.406353,0.705759,0.580329,-0.406353,0.705759,0.642087,-0.299397,0.705752,0.642087,-0.299397,0.705752,0.642087,-0.299397,0.705752,0.642079,-0.299403,0.705756,0.642079,-0.299403,0.705756,0.642079,-0.299403,0.705756,0.64208,-0.299408,0.705754,0.64208,-0.299408,0.705754,0.64208,-0.299408,0.705754,0.684314,-0.183368,0.705755,0.684314,-0.183368,0.705755,0.684314,-0.183368,0.705755,0.684316,-0.183366,0.705753,0.684316,-0.183366,0.705753,0.684316,-0.183366,0.705753,0.684318,-0.183371,0.705751,0.684318,-0.183371,0.705751,0.684318,-0.183371,0.705751,0.70576,-0.061744,0.705755,0.70576,-0.061744,0.705755,0.70576,-0.061744,0.705755,0.705754,-0.061749,0.705761,0.705754,-0.061749,0.705761,0.705754,-0.061749,0.705761,0.707103,0,0.70711,0.707103,0,0.70711,0.707103,0,0.70711,0.707103,0,0.70711,0.707103,0,0.70711,0.707103,0,0.70711,0.707103,0,0.70711,0.707114,0.000001,0.707099,0.707114,0.000001,0.707099,0.707114,0.000001,0.707099,0.705756,0.061744,0.705759,0.705756,0.061744,0.705759,0.705756,0.061744,0.705759,0.705762,0.06175,0.705753,0.705762,0.06175,0.705753,0.705762,0.06175,0.705753,0.684311,0.183367,0.705758,0.684311,0.183367,0.705758,0.684311,0.183367,0.705758,0.684311,0.183365,0.705759,0.684311,0.183365,0.705759,0.684311,0.183365,0.705759,0.684319,0.183358,0.705753,0.684319,0.183358,0.705753,0.684319,0.183358,0.705753,0.642079,0.29939,0.705762,0.642079,0.29939,0.705762,0.642079,0.29939,0.705762,0.64208,0.299404,0.705756,0.64208,0.299404,0.705756,0.64208,0.299404,0.705756,0.642076,0.299406,0.705758,0.642076,0.299406,0.705758,0.642076,0.299406,0.705758,0.580337,0.406345,0.705757,0.580337,0.406345,0.705757,0.580337,0.406345,0.705757,0.580335,0.406354,0.705753,0.580335,0.406354,0.705753,0.580335,0.406354,0.705753,0.580321,0.40636,0.705761,0.580321,0.40636,0.705761,0.580321,0.40636,0.705761,0.500951,0.500954,0.705757,0.500951,0.500954,0.705757,0.500951,0.500954,0.705757,0.500951,0.500951,0.70576,0.500951,0.500951,0.70576,0.500951,0.500951,0.70576,0.406352,0.580329,0.705759,0.406352,0.580329,0.705759,0.406352,0.580329,0.705759,0.406352,0.580335,0.705755,0.406352,0.580335,0.705755,0.406352,0.580335,0.705755,0.29941,0.642076,0.705757,0.29941,0.642076,0.705757,0.29941,0.642076,0.705757,0.299409,0.642077,0.705756,0.299409,0.642077,0.705756,0.299409,0.642077,0.705756,0.29941,0.642077,0.705755,0.29941,0.642077,0.705755,0.29941,0.642077,0.705755,0.183363,0.684313,0.705757,0.183363,0.684313,0.705757,0.183363,0.684313,0.705757,0.183362,0.684314,0.705757,0.183362,0.684314,0.705757,0.183362,0.684314,0.705757,0.183362,0.684314,0.705757,0.183362,0.684314,0.705757,0.061743,0.705758,0.705757,0.061743,0.705758,0.705757,0.061743,0.705758,0.705757,0.061743,0.705759,0.705756,0.061743,0.705759,0.705756,0.061743,0.705759,0.705756,0,0.707108,0.707106,0,0.707108,0.707106,0,0.707108,0.707106,0,0.707108,0.707106,-0.061744,0.705759,0.705756,-0.061744,0.705759,0.705756,-0.061744,0.705759,0.705756,-0.061744,0.705759,0.705756,-0.061744,0.705759,0.705756,-0.183361,0.684314,0.705757,-0.183361,0.684314,0.705757,-0.183361,0.684314,0.705757,-0.183362,0.684315,0.705756,-0.183362,0.684315,0.705756,-0.183362,0.684315,0.705756,-0.183362,0.684315,0.705756,-0.299403,0.642079,0.705757,-0.299403,0.642079,0.705757,-0.299403,0.642079,0.705757,-0.299405,0.64208,0.705755,-0.299405,0.64208,0.705755,-0.299405,0.64208,0.705755,-0.406354,0.580333,0.705754,-0.406354,0.580333,0.705754,-0.406354,0.580333,0.705754,-0.406348,0.580332,0.705759,-0.406348,0.580332,0.705759,-0.406348,0.580332,0.705759,-0.500949,0.500952,0.70576,-0.500949,0.500952,0.70576,-0.500949,0.500952,0.70576,-0.500953,0.500953,0.705757,-0.500953,0.500953,0.705757,-0.500953,0.500953,0.705757,-0.580325,0.406354,0.705761,-0.580325,0.406354,0.705761,-0.580325,0.406354,0.705761,-0.580332,0.40635,0.705758,-0.580332,0.40635,0.705758,-0.580332,0.40635,0.705758,-0.580332,0.406352,0.705757,-0.580332,0.406352,0.705757,-0.580332,0.406352,0.705757,-0.642076,0.299406,0.705758,-0.642076,0.299406,0.705758,-0.642076,0.299406,0.705758,-0.642079,0.299404,0.705756,-0.642079,0.299404,0.705756,-0.642079,0.299404,0.705756,-0.642078,0.299393,0.705762,-0.642078,0.299393,0.705762,-0.642078,0.299393,0.705762,-0.684321,0.183351,0.705753,-0.684321,0.183351,0.705753,-0.684321,0.183351,0.705753,-0.684309,0.183365,0.705761,-0.684309,0.183365,0.705761,-0.684309,0.183365,0.705761,-0.68431,0.18337,0.705758,-0.68431,0.18337,0.705758,-0.68431,0.18337,0.705758,-0.705763,0.061744,0.705752,-0.705763,0.061744,0.705752,-0.705763,0.061744,0.705752,-0.705756,0.061749,0.705759,-0.705756,0.061749,0.705759,-0.705756,0.061749,0.705759,-0.707104,0,0.707109,-0.707104,0,0.707109,-0.707104,0,0.707109,-0.707103,0,0.70711,-0.707103,0,0.70711,-0.707103,0,0.70711,-0.707103,0,0.70711,-0.707103,0,0.70711,-0.707103,0,0.70711,-0.707103,0,0.70711,-0.705754,-0.061744,0.705761,-0.705754,-0.061744,0.705761,-0.705754,-0.061744,0.705761,-0.70576,-0.06175,0.705755,-0.70576,-0.06175,0.705755,-0.70576,-0.06175,0.705755,-0.684315,-0.183353,0.705759,-0.684315,-0.183353,0.705759,-0.684315,-0.183353,0.705759,-0.684318,-0.183366,0.705752,-0.684318,-0.183366,0.705752,-0.684318,-0.183366,0.705752,-0.684314,-0.18337,0.705755,-0.684314,-0.18337,0.705755,-0.684314,-0.18337,0.705755,-0.642078,-0.299411,0.705754,-0.642078,-0.299411,0.705754,-0.642078,-0.299411,0.705754,-0.642077,-0.299403,0.705758,-0.642077,-0.299403,0.705758,-0.642077,-0.299403,0.705758,-0.642077,-0.299403,0.705758,-0.642077,-0.299403,0.705758,-0.580335,-0.406346,0.705759,-0.580335,-0.406346,0.705759,-0.580335,-0.406346,0.705759,-0.580333,-0.406353,0.705755,-0.580333,-0.406353,0.705755,-0.580333,-0.406353,0.705755,-0.580335,-0.406353,0.705754,-0.580335,-0.406353,0.705754,-0.580335,-0.406353,0.705754,-0.500953,-0.500949,0.705759,-0.500953,-0.500949,0.705759,-0.500953,-0.500949,0.705759,-0.500954,-0.500954,0.705755,-0.500954,-0.500954,0.705755,-0.500954,-0.500954,0.705755,-0.406349,-0.580336,0.705756,-0.406349,-0.580336,0.705756,-0.406349,-0.580336,0.705756,-0.406349,-0.580336,0.705755,-0.406349,-0.580336,0.705755,-0.406349,-0.580336,0.705755,-0.29941,-0.642075,0.705757,-0.29941,-0.642075,0.705757,-0.29941,-0.642075,0.705757,-0.29941,-0.642075,0.705757,-0.29941,-0.642075,0.705757,-0.299413,-0.642075,0.705756,-0.299413,-0.642075,0.705756,-0.299413,-0.642075,0.705756,-0.183362,-0.684315,0.705756,-0.183362,-0.684315,0.705756,-0.183362,-0.684315,0.705756,-0.183361,-0.684315,0.705756,-0.183361,-0.684315,0.705756,-0.183361,-0.684315,0.705756,-0.18336,-0.684315,0.705757,-0.18336,-0.684315,0.705757,-0.18336,-0.684315,0.705757,-0.061744,-0.705759,0.705756,-0.061744,-0.705759,0.705756,-0.061744,-0.705759,0.705756,-0.061746,-0.705758,0.705758,-0.061746,-0.705758,0.705758,-0.061746,-0.705758,0.705758,0.031226,-0.356909,0.933617,0.031226,-0.356909,0.933617,0.031226,-0.356909,0.933617,0.031225,-0.356909,0.933617,0.031225,-0.356909,0.933617,0.031225,-0.356909,0.933617,0.027575,-0.315192,0.948627,0.027575,-0.315192,0.948627,0.027575,-0.315192,0.948627,0.027575,-0.315192,0.948627,0.092722,-0.346065,0.933618,0.092722,-0.346065,0.933618,0.092722,-0.346065,0.933618,0.092732,-0.346066,0.933616,0.092732,-0.346066,0.933616,0.092732,-0.346066,0.933616,0.081891,-0.305613,0.948628,0.081891,-0.305613,0.948628,0.081891,-0.305613,0.948628,0.081892,-0.305614,0.948627,0.081892,-0.305614,0.948627,0.081892,-0.305614,0.948627,0.151427,-0.324703,0.933615,0.151427,-0.324703,0.933615,0.151427,-0.324703,0.933615,0.151407,-0.324704,0.933618,0.151407,-0.324704,0.933618,0.151407,-0.324704,0.933618,0.133714,-0.286752,0.948627,0.133714,-0.286752,0.948627,0.133714,-0.286752,0.948627,0.13371,-0.286752,0.948628,0.13371,-0.286752,0.948628,0.13371,-0.286752,0.948628,0.205495,-0.293475,0.933619,0.205495,-0.293475,0.933619,0.205495,-0.293475,0.933619,0.205498,-0.293474,0.933618,0.205498,-0.293474,0.933618,0.205498,-0.293474,0.933618,0.181478,-0.259175,0.948627,0.181478,-0.259175,0.948627,0.181478,-0.259175,0.948627,0.181478,-0.259175,0.948627,0.253334,-0.253336,0.933618,0.253334,-0.253336,0.933618,0.253334,-0.253336,0.933618,0.253327,-0.253339,0.933619,0.253327,-0.253339,0.933619,0.253327,-0.253339,0.933619,0.223724,-0.223726,0.948627,0.223724,-0.223726,0.948627,0.223724,-0.223726,0.948627,0.223724,-0.223726,0.948627,0.293475,-0.205498,0.933618,0.293475,-0.205498,0.933618,0.293475,-0.205498,0.933618,0.293483,-0.205493,0.933617,0.293483,-0.205493,0.933617,0.293483,-0.205493,0.933617,0.259174,-0.181475,0.948628,0.259174,-0.181475,0.948628,0.259174,-0.181475,0.948628,0.259178,-0.181473,0.948627,0.259178,-0.181473,0.948627,0.259178,-0.181473,0.948627,0.324705,-0.151413,0.933617,0.324705,-0.151413,0.933617,0.324705,-0.151413,0.933617,0.324706,-0.151412,0.933617,0.324706,-0.151412,0.933617,0.324706,-0.151412,0.933617,0.28675,-0.133713,0.948628,0.28675,-0.133713,0.948628,0.28675,-0.133713,0.948628,0.286749,-0.133713,0.948628,0.286749,-0.133713,0.948628,0.286749,-0.133713,0.948628,0.34606,-0.092732,0.933618,0.34606,-0.092732,0.933618,0.34606,-0.092732,0.933618,0.346067,-0.092723,0.933617,0.346067,-0.092723,0.933617,0.346067,-0.092723,0.933617,0.305614,-0.081891,0.948628,0.305614,-0.081891,0.948628,0.305614,-0.081891,0.948628,0.305611,-0.081894,0.948628,0.305611,-0.081894,0.948628,0.305611,-0.081894,0.948628,0.356905,-0.031228,0.933618,0.356905,-0.031228,0.933618,0.356905,-0.031228,0.933618,0.356907,-0.031224,0.933618,0.356907,-0.031224,0.933618,0.356907,-0.031224,0.933618,0.315191,-0.027575,0.948628,0.315191,-0.027575,0.948628,0.315191,-0.027575,0.948628,0.315191,-0.027575,0.948628,0.357081,0,0.934073,0.357081,0,0.934073,0.357081,0,0.934073,0.357084,0,0.934072,0.357084,0,0.934072,0.357084,0,0.934072,0.357084,0,0.934072,0.357084,0,0.934072,0.357081,0,0.934073,0.357081,0,0.934073,0.357081,0,0.934073,0.357081,0,0.934073,0.357084,0,0.934072,0.357084,0,0.934072,0.357084,0,0.934072,0.35691,0.031223,0.933617,0.35691,0.031223,0.933617,0.35691,0.031223,0.933617,0.35691,0.031224,0.933617,0.35691,0.031224,0.933617,0.35691,0.031224,0.933617,0.315194,0.027575,0.948627,0.315194,0.027575,0.948627,0.315194,0.027575,0.948627,0.315194,0.027575,0.948627,0.315194,0.027575,0.948627,0.315194,0.027575,0.948627,0.346067,0.092732,0.933616,0.346067,0.092732,0.933616,0.346067,0.092732,0.933616,0.346066,0.092723,0.933617,0.346066,0.092723,0.933617,0.346066,0.092723,0.933617,0.305615,0.081891,0.948627,0.305615,0.081891,0.948627,0.305615,0.081891,0.948627,0.305616,0.081893,0.948627,0.305616,0.081893,0.948627,0.305616,0.081893,0.948627,0.324706,0.151412,0.933617,0.324706,0.151412,0.933617,0.324706,0.151412,0.933617,0.324705,0.151422,0.933615,0.324705,0.151422,0.933615,0.324705,0.151422,0.933615,0.286753,0.133714,0.948627,0.286753,0.133714,0.948627,0.286753,0.133714,0.948627,0.286753,0.133715,0.948627,0.286753,0.133715,0.948627,0.286753,0.133715,0.948627,0.293483,0.205495,0.933617,0.293483,0.205495,0.933617,0.293483,0.205495,0.933617,0.293484,0.20549,0.933617,0.293484,0.20549,0.933617,0.293484,0.20549,0.933617,0.259178,0.181478,0.948627,0.259178,0.181478,0.948627,0.259178,0.181478,0.948627,0.259178,0.181475,0.948627,0.259178,0.181475,0.948627,0.259178,0.181475,0.948627,0.253338,0.253339,0.933616,0.253338,0.253339,0.933616,0.253338,0.253339,0.933616,0.253341,0.253334,0.933617,0.253341,0.253334,0.933617,0.253341,0.253334,0.933617,0.223726,0.223728,0.948627,0.223726,0.223728,0.948627,0.223726,0.223728,0.948627,0.223727,0.223727,0.948627,0.223727,0.223727,0.948627,0.223727,0.223727,0.948627,0.205499,0.293481,0.933616,0.205499,0.293481,0.933616,0.205499,0.293481,0.933616,0.205499,0.293482,0.933616,0.205499,0.293482,0.933616,0.205499,0.293482,0.933616,0.181479,0.259178,0.948627,0.181479,0.259178,0.948627,0.181479,0.259178,0.948627,0.181479,0.259178,0.948627,0.181479,0.259178,0.948627,0.151411,0.32471,0.933616,0.151411,0.32471,0.933616,0.151411,0.32471,0.933616,0.151415,0.324705,0.933617,0.151415,0.324705,0.933617,0.151415,0.324705,0.933617,0.092732,0.346064,0.933617,0.092732,0.346064,0.933617,0.092732,0.346064,0.933617,0.092727,0.346067,0.933616,0.092727,0.346067,0.933616,0.092727,0.346067,0.933616,0.08189,0.305616,0.948627,0.08189,0.305616,0.948627,0.08189,0.305616,0.948627,0.081889,0.305617,0.948626,0.081889,0.305617,0.948626,0.081889,0.305617,0.948626,0.031223,0.356912,0.933616,0.031223,0.356912,0.933616,0.031223,0.356912,0.933616,0.031224,0.356911,0.933616,0.031224,0.356911,0.933616,0.031224,0.356911,0.933616,0.027575,0.315194,0.948627,0.027575,0.315194,0.948627,0.027575,0.315194,0.948627,0.027575,0.315194,0.948627,0.027575,0.315194,0.948627,0,0.357085,0.934072,0,0.357085,0.934072,0,0.357085,0.934072,0,0.357084,0.934072,0,0.357084,0.934072,0,0.357084,0.934072,-0.031226,0.35691,0.933617,-0.031226,0.35691,0.933617,-0.031226,0.35691,0.933617,-0.031225,0.356909,0.933617,-0.031225,0.356909,0.933617,-0.031225,0.356909,0.933617,-0.027575,0.315193,0.948627,-0.027575,0.315193,0.948627,-0.027575,0.315193,0.948627,-0.027575,0.315193,0.948627,-0.027575,0.315193,0.948627,-0.027575,0.315193,0.948627,-0.09273,0.346064,0.933617,-0.09273,0.346064,0.933617,-0.09273,0.346064,0.933617,-0.092727,0.346064,0.933618,-0.092727,0.346064,0.933618,-0.092727,0.346064,0.933618,-0.08189,0.305616,0.948627,-0.08189,0.305616,0.948627,-0.08189,0.305616,0.948627,-0.081889,0.305615,0.948627,-0.081889,0.305615,0.948627,-0.081889,0.305615,0.948627,-0.151412,0.324704,0.933618,-0.151412,0.324704,0.933618,-0.151412,0.324704,0.933618,-0.15141,0.324704,0.933618,-0.15141,0.324704,0.933618,-0.15141,0.324704,0.933618,-0.133714,0.286754,0.948627,-0.133714,0.286754,0.948627,-0.133714,0.286754,0.948627,-0.133713,0.286753,0.948627,-0.133713,0.286753,0.948627,-0.133713,0.286753,0.948627,-0.205491,0.293477,0.933619,-0.205491,0.293477,0.933619,-0.205491,0.293477,0.933619,-0.205496,0.293476,0.933618,-0.205496,0.293476,0.933618,-0.205496,0.293476,0.933618,-0.181479,0.259178,0.948626,-0.181479,0.259178,0.948626,-0.181479,0.259178,0.948626,-0.181476,0.259179,0.948627,-0.181476,0.259179,0.948627,-0.181476,0.259179,0.948627,-0.253334,0.253335,0.933618,-0.253334,0.253335,0.933618,-0.253334,0.253335,0.933618,-0.253329,0.253337,0.933619,-0.253329,0.253337,0.933619,-0.253329,0.253337,0.933619,-0.223727,0.223728,0.948626,-0.223727,0.223728,0.948626,-0.223727,0.223728,0.948626,-0.223727,0.223728,0.948626,-0.223727,0.223728,0.948626,-0.293474,0.205497,0.933619,-0.293474,0.205497,0.933619,-0.293474,0.205497,0.933619,-0.293481,0.205493,0.933618,-0.293481,0.205493,0.933618,-0.293481,0.205493,0.933618,-0.259178,0.181477,0.948627,-0.259178,0.181477,0.948627,-0.259178,0.181477,0.948627,-0.25918,0.181476,0.948626,-0.25918,0.181476,0.948626,-0.25918,0.181476,0.948626,-0.324705,0.151411,0.933617,-0.324705,0.151411,0.933617,-0.324705,0.151411,0.933617,-0.324703,0.151413,0.933618,-0.324703,0.151413,0.933618,-0.324703,0.151413,0.933618,-0.286754,0.133714,0.948627,-0.286754,0.133714,0.948627,-0.286754,0.133714,0.948627,-0.286753,0.133715,0.948627,-0.286753,0.133715,0.948627,-0.286753,0.133715,0.948627,-0.34606,0.09273,0.933619,-0.34606,0.09273,0.933619,-0.34606,0.09273,0.933619,-0.346065,0.092723,0.933617,-0.346065,0.092723,0.933617,-0.346065,0.092723,0.933617,-0.305616,0.081892,0.948627,-0.305616,0.081892,0.948627,-0.305616,0.081892,0.948627,-0.305615,0.081893,0.948627,-0.305615,0.081893,0.948627,-0.305615,0.081893,0.948627,-0.356905,0.031222,0.933619,-0.356905,0.031222,0.933619,-0.356905,0.031222,0.933619,-0.356904,0.031224,0.933619,-0.356904,0.031224,0.933619,-0.356904,0.031224,0.933619,-0.315194,0.027575,0.948627,-0.315194,0.027575,0.948627,-0.315194,0.027575,0.948627,-0.315194,0.027575,0.948627,-0.315194,0.027575,0.948627,-0.357078,0,0.934074,-0.357078,0,0.934074,-0.357078,0,0.934074,-0.357081,0,0.934073,-0.357081,0,0.934073,-0.357081,0,0.934073,-0.357081,0,0.934073,-0.357081,0,0.934073,-0.357078,0,0.934074,-0.357078,0,0.934074,-0.357078,0,0.934074,-0.357078,0,0.934074,-0.357081,0,0.934073,-0.357081,0,0.934073,-0.357081,0,0.934073,-0.356907,-0.031228,0.933618,-0.356907,-0.031228,0.933618,-0.356907,-0.031228,0.933618,-0.356907,-0.03123,0.933618,-0.356907,-0.03123,0.933618,-0.356907,-0.03123,0.933618,-0.315194,-0.027575,0.948627,-0.315194,-0.027575,0.948627,-0.315194,-0.027575,0.948627,-0.315196,-0.02758,0.948626,-0.315196,-0.02758,0.948626,-0.315196,-0.02758,0.948626,-0.346065,-0.092728,0.933617,-0.346065,-0.092728,0.933617,-0.346065,-0.092728,0.933617,-0.346064,-0.092721,0.933618,-0.346064,-0.092721,0.933618,-0.346064,-0.092721,0.933618,-0.305617,-0.081892,0.948626,-0.305617,-0.081892,0.948626,-0.305617,-0.081892,0.948626,-0.305617,-0.08189,0.948627,-0.305617,-0.08189,0.948627,-0.305617,-0.08189,0.948627,-0.324702,-0.151411,0.933618,-0.324702,-0.151411,0.933618,-0.324702,-0.151411,0.933618,-0.324701,-0.151424,0.933617,-0.324701,-0.151424,0.933617,-0.324701,-0.151424,0.933617,-0.286754,-0.133714,0.948627,-0.286754,-0.133714,0.948627,-0.286754,-0.133714,0.948627,-0.286755,-0.133716,0.948626,-0.286755,-0.133716,0.948626,-0.286755,-0.133716,0.948626,-0.29348,-0.205491,0.933618,-0.29348,-0.205491,0.933618,-0.29348,-0.205491,0.933618,-0.29348,-0.205487,0.933619,-0.29348,-0.205487,0.933619,-0.29348,-0.205487,0.933619,-0.259179,-0.181479,0.948626,-0.259179,-0.181479,0.948626,-0.259179,-0.181479,0.948626,-0.25918,-0.181474,0.948627,-0.25918,-0.181474,0.948627,-0.25918,-0.181474,0.948627,-0.253335,-0.253338,0.933617,-0.253335,-0.253338,0.933617,-0.253335,-0.253338,0.933617,-0.253338,-0.25333,0.933619,-0.253338,-0.25333,0.933619,-0.253338,-0.25333,0.933619,-0.223728,-0.223726,0.948627,-0.223728,-0.223726,0.948627,-0.223728,-0.223726,0.948627,-0.223727,-0.223729,0.948626,-0.223727,-0.223729,0.948626,-0.223727,-0.223729,0.948626,-0.205495,-0.293481,0.933617,-0.205495,-0.293481,0.933617,-0.205495,-0.293481,0.933617,-0.205495,-0.29348,0.933617,-0.205495,-0.29348,0.933617,-0.205495,-0.29348,0.933617,-0.181477,-0.25918,0.948626,-0.181477,-0.25918,0.948626,-0.181477,-0.25918,0.948626,-0.181477,-0.259178,0.948627,-0.181477,-0.259178,0.948627,-0.181477,-0.259178,0.948627,-0.151418,-0.324702,0.933617,-0.151418,-0.324702,0.933617,-0.151418,-0.324702,0.933617,-0.151416,-0.324705,0.933617,-0.151416,-0.324705,0.933617,-0.151416,-0.324705,0.933617,-0.092722,-0.346067,0.933617,-0.092722,-0.346067,0.933617,-0.092722,-0.346067,0.933617,-0.092726,-0.346064,0.933617,-0.092726,-0.346064,0.933617,-0.092726,-0.346064,0.933617,-0.081889,-0.305616,0.948627,-0.081889,-0.305616,0.948627,-0.081889,-0.305616,0.948627,-0.081888,-0.305617,0.948627,-0.081888,-0.305617,0.948627,-0.081888,-0.305617,0.948627,-0.031225,-0.356908,0.933617,-0.031225,-0.356908,0.933617,-0.031225,-0.356908,0.933617,-0.031224,-0.356909,0.933617,-0.031224,-0.356909,0.933617,-0.031224,-0.356909,0.933617,-0.027575,-0.315192,0.948627,-0.027575,-0.315192,0.948627,-0.027575,-0.315192,0.948627,-0.027575,-0.315192,0.948627,0.007627,-0.087154,0.996166,0.007627,-0.087154,0.996166,0.007627,-0.087154,0.996166,0.022638,-0.258753,0.965678,0.022638,-0.258753,0.965678,0.022638,-0.258753,0.965678,0.022645,-0.258754,0.965678,0.022645,-0.258754,0.965678,0.022645,-0.258754,0.965678,0.022643,-0.084506,0.996166,0.022643,-0.084506,0.996166,0.022643,-0.084506,0.996166,0.036975,-0.07929,0.996166,0.036975,-0.07929,0.996166,0.036975,-0.07929,0.996166,0.050178,-0.071668,0.996166,0.050178,-0.071668,0.996166,0.050178,-0.071668,0.996166,0.148987,-0.212769,0.965677,0.148987,-0.212769,0.965677,0.148987,-0.212769,0.965677,0.148973,-0.212774,0.965678,0.148973,-0.212774,0.965678,0.148973,-0.212774,0.965678,0.061863,-0.061863,0.996166,0.061863,-0.061863,0.996166,0.061863,-0.061863,0.996166,0.071666,-0.05018,0.996166,0.071666,-0.05018,0.996166,0.071666,-0.05018,0.996166,0.212767,-0.148984,0.965678,0.212767,-0.148984,0.965678,0.212767,-0.148984,0.965678,0.212771,-0.148981,0.965678,0.212771,-0.148981,0.965678,0.212771,-0.148981,0.965678,0.079291,-0.036974,0.996166,0.079291,-0.036974,0.996166,0.079291,-0.036974,0.996166,0.235406,-0.109771,0.965678,0.235406,-0.109771,0.965678,0.235406,-0.109771,0.965678,0.235407,-0.109771,0.965678,0.235407,-0.109771,0.965678,0.235407,-0.109771,0.965678,0.084508,-0.02264,0.996166,0.084508,-0.02264,0.996166,0.084508,-0.02264,0.996166,0.250891,-0.067222,0.965678,0.250891,-0.067222,0.965678,0.250891,-0.067222,0.965678,0.250895,-0.067216,0.965678,0.250895,-0.067216,0.965678,0.250895,-0.067216,0.965678,0.087155,-0.007627,0.996166,0.087155,-0.007627,0.996166,0.087155,-0.007627,0.996166,0.258753,-0.022641,0.965678,0.258753,-0.022641,0.965678,0.258753,-0.022641,0.965678,0.258752,-0.022644,0.965678,0.258752,-0.022644,0.965678,0.258752,-0.022644,0.965678,0.087153,0.007627,0.996166,0.087153,0.007627,0.996166,0.087153,0.007627,0.996166,0.258753,0.022635,0.965678,0.258753,0.022635,0.965678,0.258753,0.022635,0.965678,0.258754,0.022644,0.965678,0.258754,0.022644,0.965678,0.258754,0.022644,0.965678,0.084505,0.022641,0.996166,0.084505,0.022641,0.996166,0.084505,0.022641,0.996166,0.250892,0.067222,0.965678,0.250892,0.067222,0.965678,0.250892,0.067222,0.965678,0.250892,0.067221,0.965678,0.250892,0.067221,0.965678,0.250892,0.067221,0.965678,0.079289,0.036972,0.996166,0.079289,0.036972,0.996166,0.079289,0.036972,0.996166,0.235405,0.109778,0.965677,0.235405,0.109778,0.965677,0.235405,0.109778,0.965677,0.235407,0.109768,0.965678,0.235407,0.109768,0.965678,0.235407,0.109768,0.965678,0.071663,0.050181,0.996166,0.071663,0.050181,0.996166,0.071663,0.050181,0.996166,0.212772,0.148977,0.965678,0.212772,0.148977,0.965678,0.212772,0.148977,0.965678,0.212768,0.148988,0.965677,0.212768,0.148988,0.965677,0.212768,0.148988,0.965677,0.06186,0.061864,0.996166,0.06186,0.061864,0.996166,0.06186,0.061864,0.996166,0.050182,0.071663,0.996166,0.050182,0.071663,0.996166,0.050182,0.071663,0.996166,0.148982,0.212767,0.965678,0.148982,0.212767,0.965678,0.148982,0.212767,0.965678,0.148987,0.212762,0.965679,0.148987,0.212762,0.965679,0.148987,0.212762,0.965679,0.036973,0.079289,0.996166,0.036973,0.079289,0.996166,0.036973,0.079289,0.996166,0.022641,0.084506,0.996166,0.022641,0.084506,0.996166,0.022641,0.084506,0.996166,0.007626,0.087153,0.996166,0.007626,0.087153,0.996166,0.007626,0.087153,0.996166,0.022636,0.258752,0.965678,0.022636,0.258752,0.965678,0.022636,0.258752,0.965678,0.022642,0.25875,0.965679,0.022642,0.25875,0.965679,0.022642,0.25875,0.965679,0,0.087156,0.996195,0,0.087156,0.996195,0,0.087156,0.996195,0,0.087156,0.996195,0,0.087156,0.996195,-0.007626,0.087153,0.996166,-0.007626,0.087153,0.996166,-0.007626,0.087153,0.996166,-0.022638,0.258751,0.965679,-0.022638,0.258751,0.965679,-0.022638,0.258751,0.965679,-0.022641,0.258752,0.965678,-0.022641,0.258752,0.965678,-0.022641,0.258752,0.965678,-0.022641,0.084506,0.996166,-0.022641,0.084506,0.996166,-0.022641,0.084506,0.996166,-0.036974,0.079289,0.996166,-0.036974,0.079289,0.996166,-0.036974,0.079289,0.996166,-0.05018,0.071664,0.996166,-0.05018,0.071664,0.996166,-0.05018,0.071664,0.996166,-0.148982,0.212767,0.965678,-0.148982,0.212767,0.965678,-0.148982,0.212767,0.965678,-0.148982,0.212767,0.965678,-0.148982,0.212767,0.965678,-0.148982,0.212767,0.965678,-0.06186,0.061864,0.996166,-0.06186,0.061864,0.996166,-0.06186,0.061864,0.996166,-0.071665,0.050179,0.996166,-0.071665,0.050179,0.996166,-0.071665,0.050179,0.996166,-0.212766,0.148983,0.965678,-0.212766,0.148983,0.965678,-0.212766,0.148983,0.965678,-0.212771,0.148978,0.965678,-0.212771,0.148978,0.965678,-0.212771,0.148978,0.965678,-0.07929,0.036972,0.996166,-0.07929,0.036972,0.996166,-0.07929,0.036972,0.996166,-0.235404,0.109771,0.965679,-0.235404,0.109771,0.965679,-0.235404,0.109771,0.965679,-0.235406,0.109768,0.965678,-0.235406,0.109768,0.965678,-0.235406,0.109768,0.965678,-0.084506,0.022641,0.996166,-0.084506,0.022641,0.996166,-0.084506,0.022641,0.996166,-0.25089,0.067222,0.965679,-0.25089,0.067222,0.965679,-0.25089,0.067222,0.965679,-0.250891,0.06722,0.965678,-0.250891,0.06722,0.965678,-0.250891,0.06722,0.965678,-0.087154,0.007627,0.996166,-0.087154,0.007627,0.996166,-0.087154,0.007627,0.996166,-0.258754,0.022635,0.965678,-0.258754,0.022635,0.965678,-0.258754,0.022635,0.965678,-0.258751,0.022644,0.965679,-0.258751,0.022644,0.965679,-0.258751,0.022644,0.965679,-0.087154,-0.007627,0.996166,-0.087154,-0.007627,0.996166,-0.087154,-0.007627,0.996166,-0.258753,-0.022641,0.965678,-0.258753,-0.022641,0.965678,-0.258753,-0.022641,0.965678,-0.258753,-0.022645,0.965678,-0.258753,-0.022645,0.965678,-0.258753,-0.022645,0.965678,-0.084507,-0.022641,0.996166,-0.084507,-0.022641,0.996166,-0.084507,-0.022641,0.996166,-0.250893,-0.067222,0.965678,-0.250893,-0.067222,0.965678,-0.250893,-0.067222,0.965678,-0.250893,-0.067218,0.965678,-0.250893,-0.067218,0.965678,-0.250893,-0.067218,0.965678,-0.07929,-0.036973,0.996166,-0.07929,-0.036973,0.996166,-0.07929,-0.036973,0.996166,-0.235405,-0.109781,0.965677,-0.235405,-0.109781,0.965677,-0.235405,-0.109781,0.965677,-0.235407,-0.109771,0.965678,-0.235407,-0.109771,0.965678,-0.235407,-0.109771,0.965678,-0.071664,-0.050183,0.996166,-0.071664,-0.050183,0.996166,-0.071664,-0.050183,0.996166,-0.212772,-0.148978,0.965678,-0.212772,-0.148978,0.965678,-0.212772,-0.148978,0.965678,-0.212767,-0.148991,0.965677,-0.212767,-0.148991,0.965677,-0.212767,-0.148991,0.965677,-0.061863,-0.061863,0.996166,-0.061863,-0.061863,0.996166,-0.061863,-0.061863,0.996166,-0.05018,-0.071666,0.996166,-0.05018,-0.071666,0.996166,-0.05018,-0.071666,0.996166,-0.14898,-0.212768,0.965678,-0.14898,-0.212768,0.965678,-0.14898,-0.212768,0.965678,-0.148979,-0.21277,0.965678,-0.148979,-0.21277,0.965678,-0.148979,-0.21277,0.965678,-0.036975,-0.07929,0.996166,-0.036975,-0.07929,0.996166,-0.036975,-0.07929,0.996166,-0.022643,-0.084506,0.996166,-0.022643,-0.084506,0.996166,-0.022643,-0.084506,0.996166,-0.007627,-0.087154,0.996166,-0.007627,-0.087154,0.996166,-0.007627,-0.087154,0.996166,-0.022638,-0.258754,0.965678,-0.022638,-0.258754,0.965678,-0.022638,-0.258754,0.965678,-0.022643,-0.258752,0.965678,-0.022643,-0.258752,0.965678,-0.022643,-0.258752,0.965678,0,-0.087157,0.996195,0,-0.087157,0.996195,0,-0.087157,0.996195,0,-0.087157,0.996195,0,-0.087157,0.996195,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,-0.258821,0.965925,0,-0.258821,0.965925,0,-0.258821,0.965925,0,-0.258821,0.965925,0,-0.258821,0.965925,-0.067225,-0.25089,0.965679,-0.067225,-0.25089,0.965679,-0.067225,-0.25089,0.965679,-0.067222,-0.250892,0.965678,-0.067222,-0.250892,0.965678,-0.067222,-0.250892,0.965678,-0.109776,-0.235403,0.965678,-0.109776,-0.235403,0.965678,-0.109776,-0.235403,0.965678,-0.109776,-0.235403,0.965678,-0.183666,-0.183666,0.965678,-0.183666,-0.183666,0.965678,-0.183666,-0.183666,0.965678,-0.183668,-0.183662,0.965678,-0.183668,-0.183662,0.965678,-0.183668,-0.183662,0.965678,-0.258821,0,0.965925,-0.258821,0,0.965925,-0.258821,0,0.965925,-0.25882,0,0.965926,-0.25882,0,0.965926,-0.25882,0,0.965926,-0.258821,0,0.965925,-0.258821,0,0.965925,-0.258821,0,0.965925,-0.258821,0,0.965925,-0.258821,0,0.965925,-0.258821,0,0.965925,-0.258821,0,0.965925,-0.258821,0,0.965925,-0.183658,0.18367,0.965678,-0.183658,0.18367,0.965678,-0.183658,0.18367,0.965678,-0.183662,0.183668,0.965678,-0.183662,0.183668,0.965678,-0.183662,0.183668,0.965678,-0.109773,0.235405,0.965678,-0.109773,0.235405,0.965678,-0.109773,0.235405,0.965678,-0.109771,0.235405,0.965678,-0.109771,0.235405,0.965678,-0.109771,0.235405,0.965678,-0.067219,0.25089,0.965679,-0.067219,0.25089,0.965679,-0.067219,0.25089,0.965679,-0.067227,0.25089,0.965678,-0.067227,0.25089,0.965678,-0.067227,0.25089,0.965678,0,0.258819,0.965926,0,0.258819,0.965926,0,0.258819,0.965926,0,0.258818,0.965926,0,0.258818,0.965926,0,0.258818,0.965926,0.06722,0.250893,0.965678,0.06722,0.250893,0.965678,0.06722,0.250893,0.965678,0.067229,0.250888,0.965679,0.067229,0.250888,0.965679,0.067229,0.250888,0.965679,0.109772,0.235405,0.965678,0.109772,0.235405,0.965678,0.109772,0.235405,0.965678,0.109769,0.235407,0.965678,0.109769,0.235407,0.965678,0.109769,0.235407,0.965678,0.18366,0.183672,0.965678,0.18366,0.183672,0.965678,0.18366,0.183672,0.965678,0.183666,0.183662,0.965679,0.183666,0.183662,0.965679,0.183666,0.183662,0.965679,0.258821,0,0.965925,0.258821,0,0.965925,0.258821,0,0.965925,0.258821,0,0.965925,0.258821,0,0.965925,0.258821,0,0.965925,0.258821,0,0.965925,0.258821,0,0.965925,0.25882,0,0.965926,0.25882,0,0.965926,0.25882,0,0.965926,0.258821,0,0.965925,0.258821,0,0.965925,0.183668,-0.183668,0.965677,0.183668,-0.183668,0.965677,0.183668,-0.183668,0.965677,0.183662,-0.183671,0.965678,0.183662,-0.183671,0.965678,0.183662,-0.183671,0.965678,0.109776,-0.235403,0.965678,0.109776,-0.235403,0.965678,0.109776,-0.235403,0.965678,0.109781,-0.235402,0.965678,0.109781,-0.235402,0.965678,0.109781,-0.235402,0.965678,0.067226,-0.250891,0.965678,0.067226,-0.250891,0.965678,0.067226,-0.250891,0.965678,0.067222,-0.250891,0.965678,0.067222,-0.250891,0.965678,0.067222,-0.250891,0.965678,0,-0.357083,0.934073,0,-0.357083,0.934073,0,-0.357083,0.934073,0,-0.357083,0.934073,0,-0.357083,0.934073,0,-0.357083,0.934073,0,-0.315312,0.948988,0,-0.315312,0.948988,0,-0.315312,0.948988,0,-0.315312,0.948988,0,-0.315312,0.948988,-0.133718,-0.286753,0.948627,-0.133718,-0.286753,0.948627,-0.133718,-0.286753,0.948627,-0.133718,-0.286753,0.948627,-0.133718,-0.286753,0.948627,-0.315313,0,0.948988,-0.315313,0,0.948988,-0.315313,0,0.948988,-0.315316,0,0.948987,-0.315316,0,0.948987,-0.315316,0,0.948987,-0.315316,0,0.948987,-0.315316,0,0.948987,-0.315316,0,0.948987,-0.315313,0,0.948988,-0.315313,0,0.948988,-0.315313,0,0.948988,-0.315313,0,0.948988,-0.315313,0,0.948988,-0.315316,0,0.948987,-0.315316,0,0.948987,0,0.315314,0.948987,0,0.315314,0.948987,0,0.315314,0.948987,0,0.315313,0.948988,0,0.315313,0.948988,0,0.315313,0.948988,0.133717,0.286753,0.948627,0.133717,0.286753,0.948627,0.133717,0.286753,0.948627,0.133717,0.286753,0.948627,0.133717,0.286753,0.948627,0.133717,0.286753,0.948627,0.315311,0,0.948988,0.315311,0,0.948988,0.315311,0,0.948988,0.315313,0,0.948988,0.315313,0,0.948988,0.315313,0,0.948988,0.315313,0,0.948988,0.315313,0,0.948988,0.315313,0,0.948988,0.315311,0,0.948988,0.315311,0,0.948988,0.315311,0,0.948988,0.315311,0,0.948989,0.315311,0,0.948989,0.315311,0,0.948989,0.315313,0,0.948988,0.315313,0,0.948988,0.315313,0,0.948988,0.044718,-0.996081,0.076309,0.044718,-0.996081,0.076309,0.044718,-0.996081,0.076309,0.044717,-0.996081,0.076311,0.044717,-0.996081,0.076311,0.044717,-0.996081,0.076311,0.044719,-0.996078,0.076342,0.044719,-0.996078,0.076342,0.044719,-0.996078,0.076342,0.136504,-0.987507,0.078716,0.136504,-0.987507,0.078716,0.136504,-0.987507,0.078716,0.13653,-0.987507,0.078674,0.13653,-0.987507,0.078674,0.13653,-0.987507,0.078674,0.13653,-0.987507,0.078677,0.13653,-0.987507,0.078677,0.13653,-0.987507,0.078677,0.23586,-0.968172,0.083741,0.23586,-0.968172,0.083741,0.23586,-0.968172,0.083741,0.235864,-0.968176,0.083692,0.235864,-0.968176,0.083692,0.235864,-0.968176,0.083692,0.348898,-0.932632,0.092019,0.348898,-0.932632,0.092019,0.348898,-0.932632,0.092019,0.348848,-0.932644,0.092086,0.348848,-0.932644,0.092086,0.348848,-0.932644,0.092086,0.348844,-0.932656,0.091984,0.348844,-0.932656,0.091984,0.348844,-0.932656,0.091984,0.48287,-0.869429,0.104541,0.48287,-0.869429,0.104541,0.48287,-0.869429,0.104541,0.482856,-0.869435,0.104559,0.482856,-0.869435,0.104559,0.482856,-0.869435,0.104559,0.482855,-0.86944,0.10452,0.482855,-0.86944,0.10452,0.482855,-0.86944,0.10452,0.643973,-0.755228,0.122185,0.643973,-0.755228,0.122185,0.643973,-0.755228,0.122185,0.643969,-0.755229,0.122201,0.643969,-0.755229,0.122201,0.643969,-0.755229,0.122201,0.606679,-0.711512,0.354529,0.606679,-0.711512,0.354529,0.606679,-0.711512,0.354529,0.606683,-0.711507,0.354533,0.606683,-0.711507,0.354533,0.606683,-0.711507,0.354533,0.606686,-0.711505,0.354531,0.606686,-0.711505,0.354531,0.606686,-0.711505,0.354531,0.539502,-0.632719,0.555522,0.539502,-0.632719,0.555522,0.539502,-0.632719,0.555522,0.539497,-0.632721,0.555524,0.539497,-0.632721,0.555524,0.539497,-0.632721,0.555524,0.421735,-0.759388,0.495449,0.421735,-0.759388,0.495449,0.421735,-0.759388,0.495449,0.421736,-0.759391,0.495444,0.421736,-0.759391,0.495444,0.421736,-0.759391,0.495444,0.42174,-0.75939,0.495442,0.42174,-0.75939,0.495442,0.42174,-0.75939,0.495442,0.421735,-0.759394,0.495439,0.421735,-0.759394,0.495439,0.421735,-0.759394,0.495439,0.365252,-0.65769,0.658813,0.365252,-0.65769,0.658813,0.365252,-0.65769,0.658813,0.365253,-0.657686,0.658817,0.365253,-0.657686,0.658817,0.365253,-0.657686,0.658817,0.365254,-0.657686,0.658816,0.365254,-0.657686,0.658816,0.365254,-0.657686,0.658816,0.295987,-0.532969,0.792676,0.295987,-0.532969,0.792676,0.295987,-0.532969,0.792676,0.230658,-0.616653,0.752686,0.230658,-0.616653,0.752686,0.230658,-0.616653,0.752686,0.230656,-0.616656,0.752684,0.230656,-0.616656,0.752684,0.230656,-0.616656,0.752684,0.230654,-0.616653,0.752687,0.230654,-0.616653,0.752687,0.230654,-0.616653,0.752687,0.164094,-0.673599,0.720651,0.164094,-0.673599,0.720651,0.164094,-0.673599,0.720651,0.164094,-0.673595,0.720655,0.164094,-0.673595,0.720655,0.164094,-0.673595,0.720655,0.164099,-0.673595,0.720653,0.164099,-0.673595,0.720653,0.164099,-0.673595,0.720653,0.164096,-0.673595,0.720654,0.164096,-0.673595,0.720654,0.164096,-0.673595,0.720654,0.125674,-0.515883,0.84739,0.125674,-0.515883,0.84739,0.125674,-0.515883,0.84739,0.125674,-0.515883,0.847391,0.125674,-0.515883,0.847391,0.125674,-0.515883,0.847391,0.075979,-0.549579,0.83198,0.075979,-0.549579,0.83198,0.075979,-0.549579,0.83198,0.075984,-0.549581,0.831978,0.075984,-0.549581,0.831978,0.075984,-0.549581,0.831978,0.075984,-0.549583,0.831977,0.075984,-0.549583,0.831977,0.075984,-0.549583,0.831977,0.025413,-0.566045,0.823982,0.025413,-0.566045,0.823982,0.025413,-0.566045,0.823982,0.025411,-0.566044,0.823984,0.025411,-0.566044,0.823984,0.025411,-0.566044,0.823984,0.025409,-0.566047,0.823981,0.025409,-0.566047,0.823981,0.025409,-0.566047,0.823981,-0.000001,-0.566219,0.824255,-0.000001,-0.566219,0.824255,-0.000001,-0.566219,0.824255,0,-0.566222,0.824253,0,-0.566222,0.824253,0,-0.566222,0.824253,0,-0.566228,0.824249,0,-0.566228,0.824249,0,-0.566228,0.824249,-0.000001,-0.566219,0.824255,-0.000001,-0.566219,0.824255,-0.000001,-0.566219,0.824255,0,-0.566225,0.824251,0,-0.566225,0.824251,0,-0.566225,0.824251,-0.025403,-0.566042,0.823985,-0.025403,-0.566042,0.823985,-0.025403,-0.566042,0.823985,-0.025408,-0.566038,0.823988,-0.025408,-0.566038,0.823988,-0.025408,-0.566038,0.823988,-0.025411,-0.566042,0.823985,-0.025411,-0.566042,0.823985,-0.025411,-0.566042,0.823985,-0.075989,-0.549561,0.83199,-0.075989,-0.549561,0.83199,-0.075989,-0.549561,0.83199,-0.075983,-0.54957,0.831985,-0.075983,-0.54957,0.831985,-0.075983,-0.54957,0.831985,-0.075983,-0.549571,0.831985,-0.075983,-0.549571,0.831985,-0.075983,-0.549571,0.831985,-0.125674,-0.515866,0.847401,-0.125674,-0.515866,0.847401,-0.125674,-0.515866,0.847401,-0.230659,-0.616649,0.752689,-0.230659,-0.616649,0.752689,-0.230659,-0.616649,0.752689,-0.230656,-0.616656,0.752684,-0.230656,-0.616656,0.752684,-0.230656,-0.616656,0.752684,-0.230658,-0.616655,0.752684,-0.230658,-0.616655,0.752684,-0.230658,-0.616655,0.752684,-0.295989,-0.532962,0.792681,-0.295989,-0.532962,0.792681,-0.295989,-0.532962,0.792681,-0.365251,-0.657687,0.658816,-0.365251,-0.657687,0.658816,-0.365251,-0.657687,0.658816,-0.365255,-0.657684,0.658818,-0.365255,-0.657684,0.658818,-0.365255,-0.657684,0.658818,-0.421736,-0.75939,0.495444,-0.421736,-0.75939,0.495444,-0.421736,-0.75939,0.495444,-0.421734,-0.759392,0.495443,-0.421734,-0.759392,0.495443,-0.421734,-0.759392,0.495443,-0.421734,-0.759392,0.495443,-0.421734,-0.759392,0.495443,-0.53951,-0.632704,0.55553,-0.53951,-0.632704,0.55553,-0.53951,-0.632704,0.55553,-0.606691,-0.711498,0.354537,-0.606691,-0.711498,0.354537,-0.606691,-0.711498,0.354537,-0.606692,-0.711498,0.354537,-0.606692,-0.711498,0.354537,-0.606692,-0.711498,0.354537,-0.606694,-0.711493,0.354542,-0.606694,-0.711493,0.354542,-0.606694,-0.711493,0.354542,-0.644002,-0.755202,0.122196,-0.644002,-0.755202,0.122196,-0.644002,-0.755202,0.122196,-0.643979,-0.755228,0.122157,-0.643979,-0.755228,0.122157,-0.643979,-0.755228,0.122157,-0.643972,-0.75523,0.122177,-0.643972,-0.75523,0.122177,-0.643972,-0.75523,0.122177,-0.482843,-0.869452,0.104481,-0.482843,-0.869452,0.104481,-0.482843,-0.869452,0.104481,-0.482852,-0.869445,0.104497,-0.482852,-0.869445,0.104497,-0.482852,-0.869445,0.104497,-0.482847,-0.869443,0.104532,-0.482847,-0.869443,0.104532,-0.482847,-0.869443,0.104532,-0.348864,-0.932644,0.092032,-0.348864,-0.932644,0.092032,-0.348864,-0.932644,0.092032,-0.348853,-0.932649,0.092015,-0.348853,-0.932649,0.092015,-0.348853,-0.932649,0.092015,-0.348858,-0.932652,0.091973,-0.348858,-0.932652,0.091973,-0.348858,-0.932652,0.091973,-0.235827,-0.968185,0.083691,-0.235827,-0.968185,0.083691,-0.235827,-0.968185,0.083691,-0.235862,-0.968171,0.083751,-0.235862,-0.968171,0.083751,-0.235862,-0.968171,0.083751,-0.235863,-0.968171,0.083741,-0.235863,-0.968171,0.083741,-0.235863,-0.968171,0.083741,-0.136505,-0.98751,0.078676,-0.136505,-0.98751,0.078676,-0.136505,-0.98751,0.078676,-0.136527,-0.987504,0.078715,-0.136527,-0.987504,0.078715,-0.136527,-0.987504,0.078715,-0.136531,-0.987507,0.078668,-0.136531,-0.987507,0.078668,-0.136531,-0.987507,0.078668,-0.044719,-0.996078,0.076342,-0.044719,-0.996078,0.076342,-0.044719,-0.996078,0.076342,-0.044714,-0.996079,0.076334,-0.044714,-0.996079,0.076334,-0.044714,-0.996079,0.076334,-0.044716,-0.996081,0.076309,-0.044716,-0.996081,0.076309,-0.044716,-0.996081,0.076309,0,-0.997072,0.076469,0,-0.997072,0.076469,0,-0.997072,0.076469,-0.000001,-0.997076,0.076419,-0.000001,-0.997076,0.076419,-0.000001,-0.997076,0.076419,0,-0.973257,0.22972,0,-0.973257,0.22972,0,-0.973257,0.22972,0,-0.973257,0.22972,0,-0.973257,0.22972,0.043651,-0.972329,0.229499,0.043651,-0.972329,0.229499,0.043651,-0.972329,0.229499,0.04365,-0.972329,0.229501,0.04365,-0.972329,0.229501,0.04365,-0.972329,0.229501,0.041414,-0.922539,0.383676,0.041414,-0.922539,0.383676,0.041414,-0.922539,0.383676,0.041413,-0.922538,0.383679,0.041413,-0.922538,0.383679,0.041413,-0.922538,0.383679,0.125886,-0.910529,0.393815,0.125886,-0.910529,0.393815,0.125886,-0.910529,0.393815,0.125884,-0.910528,0.393817,0.125884,-0.910528,0.393817,0.125884,-0.910528,0.393817,0.215361,-0.884022,0.414879,0.215361,-0.884022,0.414879,0.215361,-0.884022,0.414879,0.215362,-0.884022,0.414879,0.215362,-0.884022,0.414879,0.215362,-0.884022,0.414879,0.313166,-0.837239,0.448283,0.313166,-0.837239,0.448283,0.313166,-0.837239,0.448283,0.313165,-0.837239,0.448284,0.313165,-0.837239,0.448284,0.313165,-0.837239,0.448284,0.193898,-0.795918,0.573514,0.193898,-0.795918,0.573514,0.193898,-0.795918,0.573514,0.193898,-0.795918,0.573514,0.193898,-0.795918,0.573514,0.193898,-0.795918,0.573514,0.114419,-0.827574,0.549572,0.114419,-0.827574,0.549572,0.114419,-0.827574,0.549572,0.114417,-0.827573,0.549575,0.114417,-0.827573,0.549575,0.114417,-0.827573,0.549575,0.037806,-0.84222,0.537806,0.037806,-0.84222,0.537806,0.037806,-0.84222,0.537806,0.037807,-0.842221,0.537805,0.037807,-0.842221,0.537805,0.037807,-0.842221,0.537805,0.03256,-0.725302,0.687661,0.03256,-0.725302,0.687661,0.03256,-0.725302,0.687661,0.032558,-0.7253,0.687662,0.032558,-0.7253,0.687662,0.032558,-0.7253,0.687662,-0.000001,-0.92333,0.384008,-0.000001,-0.92333,0.384008,-0.000001,-0.92333,0.384008,0,-0.923332,0.384004,0,-0.923332,0.384004,0,-0.923332,0.384004,-0.000002,-0.92333,0.384008,-0.000002,-0.92333,0.384008,-0.000002,-0.92333,0.384008,-0.000001,-0.923332,0.384004,-0.000001,-0.923332,0.384004,-0.000001,-0.923332,0.384004,-0.041409,-0.922537,0.38368,-0.041409,-0.922537,0.38368,-0.041409,-0.922537,0.38368,-0.041409,-0.922538,0.383679,-0.041409,-0.922538,0.383679,-0.041409,-0.922538,0.383679,-0.043648,-0.972329,0.229501,-0.043648,-0.972329,0.229501,-0.043648,-0.972329,0.229501,-0.043644,-0.972331,0.229494,-0.043644,-0.972331,0.229494,-0.043644,-0.972331,0.229494,-0.037806,-0.842219,0.537809,-0.037806,-0.842219,0.537809,-0.037806,-0.842219,0.537809,-0.037804,-0.84222,0.537806,-0.037804,-0.84222,0.537806,-0.037804,-0.84222,0.537806,-0.032557,-0.725306,0.687656,-0.032557,-0.725306,0.687656,-0.032557,-0.725306,0.687656,-0.032558,-0.725305,0.687658,-0.032558,-0.725305,0.687658,-0.032558,-0.725305,0.687658,-0.114418,-0.827569,0.549579,-0.114418,-0.827569,0.549579,-0.114418,-0.827569,0.549579,-0.114416,-0.827572,0.549576,-0.114416,-0.827572,0.549576,-0.114416,-0.827572,0.549576,-0.215364,-0.884019,0.414884,-0.215364,-0.884019,0.414884,-0.215364,-0.884019,0.414884,-0.215362,-0.884022,0.414879,-0.215362,-0.884022,0.414879,-0.215362,-0.884022,0.414879,-0.193898,-0.795918,0.573514,-0.193898,-0.795918,0.573514,-0.193898,-0.795918,0.573514,-0.1939,-0.795914,0.573518,-0.1939,-0.795914,0.573518,-0.1939,-0.795914,0.573518,-0.277585,-0.742118,0.610088,-0.277585,-0.742118,0.610088,-0.277585,-0.742118,0.610088,-0.277585,-0.742117,0.610089,-0.277585,-0.742117,0.610089,-0.277585,-0.742117,0.610089,-0.313167,-0.837236,0.448288,-0.313167,-0.837236,0.448288,-0.313167,-0.837236,0.448288,-0.313165,-0.837239,0.448284,-0.313165,-0.837239,0.448284,-0.313165,-0.837239,0.448284,-0.336958,-0.900848,0.273737,-0.336958,-0.900848,0.273737,-0.336958,-0.900848,0.273737,-0.336961,-0.900846,0.273742,-0.336961,-0.900846,0.273742,-0.336961,-0.900846,0.273742,-0.097978,-0.708653,0.698721,-0.097978,-0.708653,0.698721,-0.097978,-0.708653,0.698721,-0.097977,-0.708653,0.698721,-0.097977,-0.708653,0.698721,-0.097977,-0.708653,0.698721,-0.125886,-0.910527,0.393818,-0.125886,-0.910527,0.393818,-0.125886,-0.910527,0.393818,-0.125885,-0.910527,0.393819,-0.125885,-0.910527,0.393819,-0.125885,-0.910527,0.393819,-0.000001,-0.842823,0.538191,-0.000001,-0.842823,0.538191,-0.000001,-0.842823,0.538191,-0.000001,-0.842823,0.538191,-0.000001,-0.842823,0.538191,-0.000001,-0.725689,0.688023,-0.000001,-0.725689,0.688023,-0.000001,-0.725689,0.688023,-0.000001,-0.725687,0.688025,-0.000001,-0.725687,0.688025,-0.000001,-0.725687,0.688025,0,-0.92333,0.384008,0,-0.92333,0.384008,0,-0.92333,0.384008,0,-0.92333,0.384008,0,-0.92333,0.384008,-0.000001,-0.973257,0.22972,-0.000001,-0.973257,0.22972,-0.000001,-0.973257,0.22972,-0.000002,-0.973258,0.229715,-0.000002,-0.973258,0.229715,-0.000002,-0.973258,0.229715,0,-0.973257,0.22972,0,-0.973257,0.22972,0,-0.973257,0.22972,-0.000001,-0.973258,0.229715,-0.000001,-0.973258,0.229715,-0.000001,-0.973258,0.229715,-0.133075,-0.962533,0.236264,-0.133075,-0.962533,0.236264,-0.133075,-0.962533,0.236264,-0.133077,-0.962534,0.236262,-0.133077,-0.962534,0.236262,-0.133077,-0.962534,0.236262,-0.229146,-0.940602,0.25052,-0.229146,-0.940602,0.25052,-0.229146,-0.940602,0.25052,-0.229145,-0.940602,0.250521,-0.229145,-0.940602,0.250521,-0.229145,-0.940602,0.250521,-0.461913,-0.831742,0.307964,-0.461913,-0.831742,0.307964,-0.461913,-0.831742,0.307964,-0.461913,-0.831742,0.307964,-0.461913,-0.831742,0.307964,-0.461913,-0.831742,0.307964,-0.164098,-0.673593,0.720655,-0.164098,-0.673593,0.720655,-0.164098,-0.673593,0.720655,-0.164099,-0.673598,0.720651,-0.164099,-0.673598,0.720651,-0.164099,-0.673598,0.720651,-0.164099,-0.673597,0.720651,-0.164099,-0.673597,0.720651,-0.164099,-0.673597,0.720651,0,-0.725687,0.688025,0,-0.725687,0.688025,0,-0.725687,0.688025,0,-0.725687,0.688025,0,-0.725687,0.688025,0,-0.725687,0.688025,0.097977,-0.708648,0.698726,0.097977,-0.708648,0.698726,0.097977,-0.708648,0.698726,0.097977,-0.708648,0.698726,0.097977,-0.708648,0.698726,0.277585,-0.742118,0.610089,0.277585,-0.742118,0.610089,0.277585,-0.742118,0.610089,0.277584,-0.742118,0.610089,0.277584,-0.742118,0.610089,0.277584,-0.742118,0.610089,0.336955,-0.900848,0.27374,0.336955,-0.900848,0.27374,0.336955,-0.900848,0.27374,0.336958,-0.900848,0.273737,0.336958,-0.900848,0.273737,0.336958,-0.900848,0.273737,0.461919,-0.831738,0.307966,0.461919,-0.831738,0.307966,0.461919,-0.831738,0.307966,0.46192,-0.831737,0.307966,0.46192,-0.831737,0.307966,0.46192,-0.831737,0.307966,0.229145,-0.940603,0.250517,0.229145,-0.940603,0.250517,0.229145,-0.940603,0.250517,0.229143,-0.940603,0.250519,0.229143,-0.940603,0.250519,0.229143,-0.940603,0.250519,0.133073,-0.962533,0.236266,0.133073,-0.962533,0.236266,0.133073,-0.962533,0.236266,0.133078,-0.962534,0.23626,0.133078,-0.962534,0.23626,0.133078,-0.962534,0.23626,-0.99341,0.114614,0,-0.99341,0.114614,0,-0.99341,0.114614,0,-0.99341,0.114614,0,-0.941542,0.336895,0,-0.941542,0.336895,0,-0.941542,0.336895,0,-0.941542,0.336895,0,-0.941542,0.336895,0,-0.843755,0.536728,0,-0.843755,0.536728,0,-0.843755,0.536728,0,-0.843754,0.53673,-0.000005,-0.843754,0.53673,-0.000005,-0.843754,0.53673,-0.000005,-0.707107,0.707107,-0.000004,-0.707107,0.707107,-0.000004,-0.707107,0.707107,-0.000004,-0.707108,0.707106,0,-0.707108,0.707106,0,-0.707108,0.707106,0,-0.536731,0.843753,0,-0.536731,0.843753,0,-0.536731,0.843753,0,-0.53673,0.843754,-0.000003,-0.53673,0.843754,-0.000003,-0.53673,0.843754,-0.000003,-0.33689,0.941544,-0.000002,-0.33689,0.941544,-0.000002,-0.33689,0.941544,-0.000002,-0.33689,0.941544,-0.000002,-0.33689,0.941544,-0.000002,-0.114616,0.99341,-0.000001,-0.114616,0.99341,-0.000001,-0.114616,0.99341,-0.000001,-0.114616,0.99341,-0.000001,-0.114616,0.99341,-0.000001,0.11462,0.993409,0.000001,0.11462,0.993409,0.000001,0.11462,0.993409,0.000001,0.11462,0.993409,0.000001,0.336894,0.941543,0.000002,0.336894,0.941543,0.000002,0.336894,0.941543,0.000002,0.336894,0.941543,0.000002,0.336894,0.941543,0.000002,0.536734,0.843751,0.000003,0.536734,0.843751,0.000003,0.536734,0.843751,0.000003,0.536734,0.843751,0.000003,0.536734,0.843751,0.000003,0.707106,0.707108,0.000004,0.707106,0.707108,0.000004,0.707106,0.707108,0.000004,0.707106,0.707108,0.000004,0.707106,0.707108,0.000004,0.843749,0.536738,0.000005,0.843749,0.536738,0.000005,0.843749,0.536738,0.000005,0.843749,0.536738,0.000005,0.843749,0.536738,0.000005,0.941545,0.336887,0.000005,0.941545,0.336887,0.000005,0.941545,0.336887,0.000005,0.941546,0.336885,0,0.941546,0.336885,0,0.941546,0.336885,0,0.993409,0.114622,0,0.993409,0.114622,0,0.993409,0.114622,0,0.993409,0.114622,0,0.99341,-0.114616,0,0.99341,-0.114616,0,0.99341,-0.114616,0,0.99341,-0.114616,0,0.941542,-0.336895,0,0.941542,-0.336895,0,0.941542,-0.336895,0,0.941542,-0.336895,0,0.941542,-0.336895,0,0.843755,-0.536728,0,0.843755,-0.536728,0,0.843755,-0.536728,0,0.843755,-0.536728,0,0.843755,-0.536728,0,0.707107,-0.707107,0,0.707107,-0.707107,0,0.707107,-0.707107,0,0.707107,-0.707107,0,0.707107,-0.707107,0,0.536732,-0.843753,0,0.536732,-0.843753,0,0.536732,-0.843753,0,0.536732,-0.843753,0,0.536732,-0.843753,0,0.336891,-0.941544,0,0.336891,-0.941544,0,0.336891,-0.941544,0,0.336891,-0.941544,0,0.114616,-0.99341,0,0.114616,-0.99341,0,0.114616,-0.99341,0,0.114616,-0.99341,0,0.114616,-0.99341,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,-0.114616,-0.99341,0,-0.114616,-0.99341,0,-0.114616,-0.99341,0,-0.114616,-0.99341,0,-0.114616,-0.99341,0,-0.336896,-0.941542,0,-0.336896,-0.941542,0,-0.336896,-0.941542,0,-0.336896,-0.941542,0,-0.336896,-0.941542,0,-0.536731,-0.843753,0,-0.536731,-0.843753,0,-0.536731,-0.843753,0,-0.536731,-0.843753,0,-0.536731,-0.843753,0,-0.707106,-0.707108,0,-0.707106,-0.707108,0,-0.707106,-0.707108,0,-0.707106,-0.707108,0,-0.707106,-0.707108,0,-0.843751,-0.536735,0,-0.843751,-0.536735,0,-0.843751,-0.536735,0,-0.843751,-0.536735,0,-0.941543,-0.336892,0,-0.941543,-0.336892,0,-0.941543,-0.336892,0,-0.941543,-0.336892,0,-0.99341,-0.114616,0,-0.99341,-0.114616,0,-0.99341,-0.114616,0,-0.99341,-0.114616,0,-0.453992,0,-0.891006,-0.453992,0,-0.891006,-0.453992,0,-0.891006,-0.453994,0,-0.891005,-0.453994,0,-0.891005,-0.453994,0,-0.891005,-0.453989,0,-0.891007,-0.453989,0,-0.891007,-0.453989,0,-0.891007,-0.453989,0,-0.891007,-0.453989,0,-0.891007,-0.453989,0,-0.891007,0.891006,0,-0.453991,0.891006,0,-0.453991,0.891006,0,-0.453991,0.891007,0,-0.453989,0.891007,0,-0.453989,0.891007,0,-0.453989,0.891006,0,-0.453991,0.891006,0,-0.453991,0.891006,0,-0.453991,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,-0.000003,-1,0,-0.000003,-1,0,-0.000003,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,1,0.000002,-0.000004,1,0.000002,-0.000004,1,0.000002,-0.000004,1,0.000002,-0.000002,1,0.000002,-0.000002,1,0.000002,-0.000002,1,0.000001,0.000001,1,0.000001,0.000001,1,0.000001,0.000001,1,0.000001,-0.000001,1,0.000001,-0.000001,1,0.000001,-0.000001,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,1,0.000001,0,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.891006,0,-0.453991,-0.891006,0,-0.453991,-0.891006,0,-0.453991,-0.891001,0,-0.454001,-0.891001,0,-0.454001,-0.891001,0,-0.454001,-0.891007,0,-0.45399,-0.891007,0,-0.45399,-0.891007,0,-0.45399,-0.891006,0,-0.453991,-0.891006,0,-0.453991,-0.891006,0,-0.453991,0,-0.707107,0.707107,0,-0.707107,0.707107,0,-0.707107,0.707107,0,-0.707105,0.707108,0,-0.707105,0.707108,0,-0.707105,0.707108,0,-0.70711,0.707103,0,-0.70711,0.707103,0,-0.70711,0.707103,0,-0.707108,0.707106,0,-0.707108,0.707106,0,-0.707108,0.707106,0.707106,0,0.707108,0.707106,0,0.707108,0.707106,0,0.707108,0.707108,0,0.707105,0.707108,0,0.707105,0.707108,0,0.707105,0.707114,-0.000001,0.707099,0.707114,-0.000001,0.707099,0.707114,-0.000001,0.707099,-0.707106,0.000001,0.707108,-0.707106,0.000001,0.707108,-0.707106,0.000001,0.707108,-0.707094,0,0.707119,-0.707094,0,0.707119,-0.707094,0,0.707119,-0.707104,0,0.707109,-0.707104,0,0.707109,0.087157,0,0.996195,0.087157,0,0.996195,0.087157,0,0.996195,0.087152,0,0.996195,0.087152,0,0.996195,0.087152,0,0.996195,0.087157,0,0.996195,0.087157,0,0.996195,0.087157,0,0.996195,0.087155,0,0.996195,0.087155,0,0.996195,0.087155,0,0.996195,-0.087156,0,0.996195,-0.087156,0,0.996195,-0.087156,0,0.996195,-0.087152,0,0.996195,-0.087152,0,0.996195,-0.087152,0,0.996195,-0.087157,0,0.996195,-0.087157,0,0.996195,-0.087157,0,0.996195,-0.087156,0,0.996195,-0.087156,0,0.996195,-0.087156,0,0.996195,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000001,0,-1,-0.000002,0,-1,-0.000002,0,-1,-0.000002,0,-1,-0.000002,0,-1,-0.000002,0,-1,-0.000002,0,-1,-0.000003,0,-1,-0.000003,0,-1,-0.000003,0,-1,-0.000003,0,-1,-0.000003,0,-1,-0.000003,0,-1,-0.000005,0,-1,-0.000005,0,-1,-0.000005,0,-1,-0.000005,0,-1,-0.000005,0,-1,-0.000005,-0.000001,-1,-0.000021,-0.000001,-1,-0.000021,-0.000001,-1,-0.000021,-0.000001,-1,-0.000037,-0.000001,-1,-0.000037,-0.000001,-1,-0.000037,-0.000001,-1,-0.000037,-0.000001,-1,-0.000037,-0.000001,-1,-0.000037,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000002,0,-1,0.000002,0,-1,0.000002,0,-1,0.000002,0,-1,0.000002,0,-1,0.000002,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0.000001,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-1,0,0,-0.997072,0.076469,0,-0.997072,0.076469,0,-0.997072,0.076469,-0.000002,-0.997077,0.076407,-0.000002,-0.997077,0.076407,-0.000002,-0.997077,0.076407,0,-0.997076,0.076419,0,-0.997076,0.076419,0,-0.997076,0.076419,0,-0.997076,0.076419,0,-0.997076,0.076419,0,-0.997076,0.076419,-0.000002,-0.997075,0.076429,-0.000002,-0.997075,0.076429,-0.000002,-0.997075,0.076429,0,-0.842823,0.538191,0,-0.842823,0.538191,0,-0.842823,0.538191,0,-0.842823,0.538191,0,-0.842823,0.538191,0,-0.842823,0.538191,0,-0.842823,0.538191,0,-0.842823,0.538191,0,-0.842823,0.538191,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0.000001,1,0,0.000001,1,0,0.000001,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0.000001,1,0,0.000001,1,0,0.000001,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,-1,0,0,-1,0,0,-1,0,0,-1,0,0.000006,-1,0,0.000006,-1,0,0.000006,-1,0,0,-1,0,0,-1,0,0,0,1,0,0,1,0,0,1,0,0,1,-0.000016,0,1,-0.000016,0,1,-0.000016,-0.000001,1,0,-0.000001,1,0,-0.000001,1,0,1,0,0,1,0,0,1,0,0,1,0,-0.000011,1,0,-0.000011,1,0,-0.000011,1,0,0,1,0,0,1,0,0,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1,0,0,1],"texCoords":[0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0,0],"indices":[0,1,2,0,2,3,4,5,6,7,8,9,10,11,12,10,12,13,14,15,16,17,18,19,20,21,22,23,24,25,26,27,28,26,28,29,30,31,32,33,34,35,36,37,38,39,40,41,42,43,44,42,44,45,46,47,48,46,48,49,50,51,52,53,54,55,56,57,58,56,58,59,60,61,62,60,62,63,64,65,66,64,66,67,68,69,70,71,72,73,74,75,76,77,78,79,80,81,82,80,82,83,84,85,86,87,88,89,90,91,92,90,92,93,94,95,96,97,98,99,100,101,102,100,102,103,104,105,106,104,106,107,108,109,110,108,110,111,112,113,114,112,114,115,116,117,118,116,118,119,120,121,122,120,122,123,124,125,126,127,128,129,130,131,132,133,134,135,136,137,138,136,138,139,140,141,142,143,144,145,146,147,148,149,150,151,152,153,154,155,156,157,158,159,160,161,162,163,164,165,166,164,166,167,168,169,170,168,170,171,172,173,174,172,174,175,176,177,178,176,178,179,180,181,182,180,182,183,184,185,186,184,186,187,188,189,190,188,190,191,192,193,194,192,194,195,196,197,198,196,198,199,200,201,202,200,202,203,204,205,206,204,206,207,208,209,210,208,210,211,212,213,214,212,214,215,216,217,218,216,218,219,220,221,222,220,222,223,224,225,226,224,226,227,228,229,230,228,230,231,232,233,234,232,234,235,236,237,238,236,238,239,240,241,242,240,242,243,244,245,246,244,246,247,248,249,250,248,250,251,252,253,254,252,254,255,256,257,258,256,258,259,260,261,262,260,262,263,264,265,266,264,266,267,268,269,270,268,270,271,272,273,274,272,274,275,276,277,278,276,278,279,280,281,282,280,282,283,284,285,286,287,288,289,290,291,292,290,292,293,294,295,296,294,296,297,298,299,300,298,300,301,302,303,304,302,304,305,306,307,308,309,310,311,312,313,314,315,316,317,318,319,320,318,320,321,322,323,324,322,324,325,326,327,328,326,328,329,330,331,332,330,332,333,334,335,336,337,338,339,340,341,342,340,342,343,344,345,346,347,348,349,350,351,352,350,352,353,354,355,356,354,356,357,358,359,360,358,360,361,362,363,364,362,364,365,366,367,368,366,368,369,370,371,372,370,372,373,374,375,376,374,376,377,378,379,380,378,380,381,382,383,384,382,384,385,386,387,388,386,388,389,390,391,392,390,392,393,394,395,396,394,396,397,398,399,400,398,400,401,402,403,404,402,404,405,406,407,408,406,408,409,410,411,412,410,412,413,414,415,416,414,416,417,418,419,420,418,420,421,422,423,424,422,424,425,426,427,428,426,428,429,430,431,432,430,432,433,434,435,436,434,436,437,438,439,440,438,440,441,442,443,444,442,444,445,446,447,448,446,448,449,450,451,452,450,452,453,454,455,456,454,456,457,458,459,460,458,460,461,462,463,464,462,464,465,466,467,468,466,468,469,470,471,472,470,472,473,474,475,476,474,476,477,478,479,480,478,480,481,482,483,484,485,486,487,488,489,490,488,490,491,492,493,494,492,494,495,496,497,498,496,498,499,500,501,502,500,502,503,504,505,506,504,506,507,508,509,510,508,510,511,512,513,514,512,514,515,516,517,518,516,518,519,520,521,522,520,522,523,524,525,526,524,526,527,528,529,530,528,530,531,532,533,534,532,534,535,536,537,538,536,538,539,540,541,542,540,542,543,544,545,546,544,546,547,548,549,550,551,552,553,554,555,556,554,556,557,558,559,560,558,560,561,562,563,564,562,564,565,566,567,568,566,568,569,570,571,572,570,572,573,574,575,576,577,578,579,580,581,582,583,584,585,586,587,588,586,588,589,590,591,592,590,592,593,594,595,596,594,596,597,598,599,600,598,600,601,602,603,604,605,606,607,608,609,610,608,610,611,612,613,614,615,616,617,618,619,620,618,620,621,622,623,624,622,624,625,626,627,628,626,628,629,630,631,632,630,632,633,634,635,636,634,636,637,638,639,640,638,640,641,642,643,644,642,644,645,646,647,648,646,648,649,650,651,652,650,652,653,654,655,656,654,656,657,658,659,660,658,660,661,662,663,664,662,664,665,666,667,668,666,668,669,670,671,672,670,672,673,674,675,676,674,676,677,678,679,680,678,680,681,682,683,684,682,684,685,686,687,688,686,688,689,690,691,692,690,692,693,694,695,696,694,696,697,698,699,700,701,702,703,704,705,706,707,708,709,710,711,712,710,712,713,714,715,716,714,716,717,718,719,720,718,720,721,722,723,724,722,724,725,726,727,728,726,728,729,730,731,732,733,734,735,736,737,738,739,740,741,742,743,744,742,744,745,746,747,748,746,748,749,750,751,752,750,752,753,754,755,756,757,758,759,760,761,762,763,764,765,766,767,768,766,768,769,770,771,772,770,772,773,774,775,776,774,776,777,778,779,780,778,780,781,782,783,784,782,784,785,786,787,788,786,788,789,790,791,792,790,792,793,794,795,796,794,796,797,798,799,800,798,800,801,802,803,804,802,804,805,806,807,808,806,808,809,810,811,812,810,812,813,814,815,816,814,816,817,818,819,820,818,820,821,822,823,824,822,824,825,826,827,828,826,828,829,830,831,832,830,832,833,834,835,836,834,836,837,838,839,840,838,840,841,842,843,844,842,844,845,846,847,848,849,850,851,852,853,854,855,856,857,858,859,860,861,862,863,864,865,866,864,866,867,868,869,870,871,872,873,874,875,876,874,876,877,878,879,880,878,880,881,882,883,884,882,884,885,886,887,888,886,888,889,890,891,892,890,892,893,894,895,896,894,896,897,898,899,900,898,900,901,902,903,904,902,904,905,906,907,908,906,908,909,910,911,912,910,912,913,914,915,916,914,916,917,918,919,920,918,920,921,922,923,924,922,924,925,926,927,928,926,928,929,930,931,932,930,932,933,934,935,936,934,936,937,938,939,940,938,940,941,942,943,944,942,944,945,946,947,948,946,948,949,950,951,952,950,952,953,954,955,956,954,956,957,958,959,960,958,960,961,962,963,964,962,964,965,966,967,968,966,968,969,970,971,972,970,972,973,974,975,976,977,978,979,980,981,982,983,984,985,986,987,988,986,988,989,990,991,992,990,992,993,994,995,996,994,996,997,998,999,1000,998,1000,1001,1002,1003,1004,1002,1004,1005,1006,1007,1008,1009,1010,1011,1012,1013,1014,1015,1016,1017,1018,1019,1020,1018,1020,1021,1022,1023,1024,1022,1024,1025,1026,1027,1028,1026,1028,1029,1030,1031,1032,1030,1032,1033,1034,1035,1036,1034,1036,1037,1038,1039,1040,1038,1040,1041,1042,1043,1044,1042,1044,1045,1046,1047,1048,1046,1048,1049,1050,1051,1052,1050,1052,1053,1054,1055,1056,1054,1056,1057,1058,1059,1060,1058,1060,1061,1062,1063,1064,1062,1064,1065,1066,1067,1068,1066,1068,1069,1070,1071,1072,1070,1072,1073,1074,1075,1076,1074,1076,1077,1078,1079,1080,1078,1080,1081,1082,1083,1084,1082,1084,1085,1086,1087,1088,1086,1088,1089,1090,1091,1092,1090,1092,1093,1094,1095,1096,1094,1096,1097,1098,1099,1100,1098,1100,1101,1102,1103,1104,1102,1104,1105,1106,1107,1108,1106,1108,1109,1110,1111,1112,1110,1112,1113,1114,1115,1116,1114,1116,1117,1118,1119,1120,1121,1122,1123,1124,1125,1126,1127,1128,1129,1130,1131,1132,1133,1134,1135,1136,1137,1138,1136,1138,1139,1140,1141,1142,1143,1144,1145,1146,1147,1148,1146,1148,1149,1150,1151,1152,1150,1152,1153,1154,1155,1156,1154,1156,1157,1158,1159,1160,1158,1160,1161,1162,1163,1164,1162,1164,1165,1166,1167,1168,1166,1168,1169,1170,1171,1172,1170,1172,1173,1174,1175,1176,1174,1176,1177,1178,1179,1180,1178,1180,1181,1182,1183,1184,1182,1184,1185,1186,1187,1188,1186,1188,1189,1190,1191,1192,1190,1192,1193,1194,1195,1196,1194,1196,1197,1198,1199,1200,1198,1200,1201,1202,1203,1204,1202,1204,1205,1206,1207,1208,1206,1208,1209,1210,1211,1212,1210,1212,1213,1214,1215,1216,1214,1216,1217,1218,1219,1220,1218,1220,1221,1222,1223,1224,1222,1224,1225,1226,1227,1228,1226,1228,1229,1230,1231,1232,1230,1232,1233,1234,1235,1236,1234,1236,1237,1238,1239,1240,1238,1240,1241,1242,1243,1244,1242,1244,1245,1246,1247,1248,1246,1248,1249,1250,1251,1252,1250,1252,1253,1254,1255,1256,1254,1256,1257,1258,1259,1260,1258,1260,1261,1262,1263,1264,1262,1264,1265,1266,1267,1268,1266,1268,1269,1270,1271,1272,1273,1274,1275,1276,1277,1278,1279,1280,1281,1282,1283,1284,1285,1286,1287,1288,1289,1290,1291,1292,1293,1294,1295,1296,1294,1296,1297,1298,1299,1300,1298,1300,1301,1302,1303,1304,1302,1304,1305,1306,1307,1308,1306,1308,1309,1310,1311,1312,1310,1312,1313,1314,1315,1316,1314,1316,1317,1318,1319,1320,1318,1320,1321,1322,1323,1324,1322,1324,1325,1326,1327,1328,1326,1328,1329,1330,1331,1332,1330,1332,1333,1334,1335,1336,1334,1336,1337,1338,1339,1340,1338,1340,1341,1342,1343,1344,1342,1344,1345,1346,1347,1348,1346,1348,1349,1350,1351,1352,1350,1352,1353,1354,1355,1356,1354,1356,1357,1358,1359,1360,1358,1360,1361,1362,1363,1364,1362,1364,1365,1366,1367,1368,1366,1368,1369,1370,1371,1372,1370,1372,1373,1374,1375,1376,1374,1376,1377,1378,1379,1380,1381,1382,1383,1384,1385,1386,1384,1386,1387,1388,1389,1390,1391,1392,1393,1394,1395,1396,1397,1398,1399,1400,1401,1402,1403,1404,1405,1406,1407,1408,1409,1410,1411,1412,1413,1414,1412,1414,1415,1416,1417,1418,1419,1420,1421,1422,1423,1424,1425,1426,1427,1428,1429,1430,1428,1430,1431,1432,1433,1434,1432,1434,1435,1436,1437,1438,1436,1438,1439,1440,1441,1442,1443,1444,1445,1446,1447,1448,1449,1450,1451,1452,1453,1454,1455,1456,1457,1458,1459,1460,1458,1460,1461,1462,1463,1464,1462,1464,1465,1466,1467,1468,1466,1468,1469,1470,1471,1472,1470,1472,1473,1474,1475,1476,1474,1476,1477,1478,1479,1480,1478,1480,1481,1482,1483,1484,1482,1484,1485,1486,1487,1488,1486,1488,1489,1490,1491,1492,1490,1492,1493,1494,1495,1496,1494,1496,1497,1498,1499,1500,1498,1500,1501,1502,1503,1504,1502,1504,1505,1506,1507,1508,1506,1508,1509,1510,1511,1512,1510,1512,1513,1514,1515,1516,1514,1516,1517,1518,1519,1520,1521,1522,1523,1524,1525,1526,1527,1528,1529,1530,1531,1532,1530,1532,1533,1534,1535,1536,1534,1536,1537,1538,1539,1540,1538,1540,1541,1542,1543,1544,1542,1544,1545,1546,1547,1548,1546,1548,1549,1550,1551,1552,1550,1552,1553,1554,1555,1556,1554,1556,1557,1558,1559,1560,1561,1562,1563,1564,1565,1566,1567,1568,1569,1570,1571,1572,1573,1574,1575,1576,1577,1578,1579,1580,1581,1582,1583,1584,1582,1584,1585,1586,1587,1588,1586,1588,1589,1590,1591,1592,1590,1592,1593,1594,1595,1596,1594,1596,1597,1598,1599,1600,1598,1600,1601,1602,1603,1604,1602,1604,1605,1606,1607,1608,1606,1608,1609,1610,1611,1612,1610,1612,1613,1614,1615,1616,1614,1616,1617,1618,1619,1620,1618,1620,1621,1622,1623,1624,1622,1624,1625,1626,1627,1628,1626,1628,1629,1630,1631,1632,1630,1632,1633,1634,1635,1636,1634,1636,1637,1638,1639,1640,1638,1640,1641,1642,1643,1644,1642,1644,1645,1646,1647,1648,1646,1648,1649,1650,1651,1652,1650,1652,1653,1654,1655,1656,1654,1656,1657,1658,1659,1660,1658,1660,1661,1662,1663,1664,1662,1664,1665,1666,1667,1668,1666,1668,1669,1670,1671,1672,1670,1672,1673,1674,1675,1676,1674,1676,1677,1678,1679,1680,1678,1680,1681,1682,1683,1684,1682,1684,1685,1686,1687,1688,1686,1688,1689,1690,1691,1692,1690,1692,1693,1694,1695,1696,1694,1696,1697,1698,1699,1700,1698,1700,1701,1702,1703,1704,1702,1704,1705,1706,1707,1708,1706,1708,1709,1710,1711,1712,1710,1712,1713,1714,1715,1716,1714,1716,1717,1718,1719,1720,1718,1720,1721,1722,1723,1724,1722,1724,1725,1726,1727,1728,1726,1728,1729,1730,1731,1732,1730,1732,1733,1734,1735,1736,1734,1736,1737,1738,1739,1740,1738,1740,1741,1742,1743,1744,1742,1744,1745,1746,1747,1748,1746,1748,1749,1750,1751,1752,1750,1752,1753,1754,1755,1756,1754,1756,1757,1758,1759,1760,1758,1760,1761,1762,1763,1764,1762,1764,1765,1766,1767,1768,1766,1768,1769,1770,1771,1772,1770,1772,1773,1774,1775,1776,1774,1776,1777,1778,1779,1780,1778,1780,1781,1782,1783,1784,1782,1784,1785,1786,1787,1788,1786,1788,1789,1790,1791,1792,1790,1792,1793,1794,1795,1796,1794,1796,1797,1798,1799,1800,1798,1800,1801,1802,1803,1804,1802,1804,1805,1806,1807,1808,1806,1808,1809,1810,1811,1812,1813,1814,1815,1816,1817,1818,1819,1820,1821,1822,1823,1824,1822,1824,1825,1826,1827,1828,1826,1828,1829,1830,1831,1832,1830,1832,1833,1834,1835,1836,1834,1836,1837,1838,1839,1840,1841,1842,1843,1844,1845,1846,1847,1848,1849,1850,1851,1852,1850,1852,1853,1854,1855,1856,1854,1856,1857,1858,1859,1860,1858,1860,1861,1862,1863,1864,1862,1864,1865,1866,1867,1868,1866,1868,1869,1870,1871,1872,1870,1872,1873,1874,1875,1876,1874,1876,1877,1878,1879,1880,1878,1880,1881,1882,1883,1884,1882,1884,1885,1886,1887,1888,1886,1888,1889,1890,1891,1892,1890,1892,1893,1894,1895,1896,1894,1896,1897,1898,1899,1900,1898,1900,1901,1902,1903,1904,1902,1904,1905,1906,1907,1908,1906,1908,1909,1910,1911,1912,1910,1912,1913,1914,1915,1916,1914,1916,1917,1918,1919,1920,1918,1920,1921,1922,1923,1924,1922,1924,1925,1926,1927,1928,1926,1928,1929,1930,1931,1932,1930,1932,1933,1934,1935,1936,1934,1936,1937,1938,1939,1940,1938,1940,1941,1942,1943,1944,1942,1944,1945,1946,1947,1948,1946,1948,1949,1950,1951,1952,1950,1952,1953,1954,1955,1956,1954,1956,1957,1958,1959,1960,1958,1960,1961,1962,1963,1964,1962,1964,1965,1966,1967,1968,1966,1968,1969,1970,1971,1972,1970,1972,1973,1974,1975,1976,1974,1976,1977,1978,1979,1980,1978,1980,1981,1982,1983,1984,1982,1984,1985,1986,1987,1988,1986,1988,1989,1990,1991,1992,1990,1992,1993,1994,1995,1996,1994,1996,1997,1998,1999,2000,1998,2000,2001,2002,2003,2004,2002,2004,2005,2006,2007,2008,2006,2008,2009,2010,2011,2012,2010,2012,2013,2014,2015,2016,2014,2016,2017,2018,2019,2020,2018,2020,2021,2022,2023,2024,2022,2024,2025,2026,2027,2028,2026,2028,2029,2030,2031,2032,2030,2032,2033,2034,2035,2036,2034,2036,2037,2038,2039,2040,2038,2040,2041,2042,2043,2044,2042,2044,2045,2046,2047,2048,2046,2048,2049,2050,2051,2052,2050,2052,2053,2054,2055,2056,2054,2056,2057,2058,2059,2060,2058,2060,2061,2062,2063,2064,2062,2064,2065,2066,2067,2068,2066,2068,2069,2070,2071,2072,2070,2072,2073,2074,2075,2076,2074,2076,2077,2078,2079,2080,2078,2080,2081,2082,2083,2084,2082,2084,2085,2086,2087,2088,2086,2088,2089,2090,2091,2092,2090,2092,2093,2094,2095,2096,2094,2096,2097,2098,2099,2100,2098,2100,2101,2102,2103,2104,2102,2104,2105,2106,2107,2108,2106,2108,2109,2110,2111,2112,2110,2112,2113,2114,2115,2116,2114,2116,2117,2118,2119,2120,2121,2122,2123,2124,2125,2126,2127,2128,2129,2130,2131,2132,2133,2134,2135,2136,2137,2138,2136,2138,2139,2140,2141,2142,2140,2142,2143,2144,2145,2146,2147,2148,2149,2150,2151,2152,2153,2154,2155,2156,2157,2158,2156,2158,2159,2160,2161,2162,2160,2162,2163,2164,2165,2166,2164,2166,2167,2168,2169,2170,2168,2170,2171,2172,2173,2174,2172,2174,2175,2176,2177,2178,2176,2178,2179,2180,2181,2182,2180,2182,2183,2184,2185,2186,2184,2186,2187,2188,2189,2190,2191,2192,2193,2194,2195,2196,2197,2198,2199,2200,2201,2202,2200,2202,2203,2204,2205,2206,2204,2206,2207,2208,2209,2210,2208,2210,2211,2212,2213,2214,2212,2214,2215,2216,2217,2218,2216,2218,2219,2220,2221,2222,2220,2222,2223,2224,2225,2226,2224,2226,2227,2228,2229,2230,2228,2230,2231,2232,2233,2234,2232,2234,2235,2236,2237,2238,2236,2238,2239,2240,2241,2242,2240,2242,2243,2244,2245,2246,2244,2246,2247,2248,2249,2250,2248,2250,2251,2252,2253,2254,2252,2254,2255,2256,2257,2258,2256,2258,2259,2260,2261,2262,2260,2262,2263,2264,2265,2266,2264,2266,2267,2268,2269,2270,2268,2270,2271,2272,2273,2274,2272,2274,2275,2276,2277,2278,2276,2278,2279,2280,2281,2282,2280,2282,2283,2284,2285,2286,2284,2286,2287,2288,2289,2290,2288,2290,2291,2292,2293,2294,2292,2294,2295,2296,2297,2298,2296,2298,2299,2300,2301,2302,2300,2302,2303,2304,2305,2306,2304,2306,2307,2308,2309,2310,2308,2310,2311,2312,2313,2314,2312,2314,2315,2316,2317,2318,2316,2318,2319,2320,2321,2322,2320,2322,2323,2324,2325,2326,2324,2326,2327,2328,2329,2330,2328,2330,2331,2332,2333,2334,2332,2334,2335,2336,2337,2338,2336,2338,2339,2340,2341,2342,2340,2342,2343,2344,2345,2346,2344,2346,2347,2348,2349,2350,2348,2350,2351,2352,2353,2354,2352,2354,2355,2356,2357,2358,2356,2358,2359,2360,2361,2362,2360,2362,2363,2364,2365,2366,2367,2368,2369,2370,2371,2372,2370,2372,2373,2374,2375,2376,2374,2376,2377,2378,2379,2380,2381,2382,2383,2384,2385,2386,2384,2386,2387,2388,2389,2390,2391,2392,2393,2394,2395,2396,2394,2396,2397,2398,2399,2400,2398,2400,2401,2402,2403,2404,2402,2404,2405,2406,2407,2408,2409,2410,2411,2412,2413,2414,2412,2414,2415,2416,2417,2418,2419,2420,2421,2422,2423,2424,2422,2424,2425,2426,2427,2428,2426,2428,2429,2430,2431,2432,2430,2432,2433,2434,2435,2436,2434,2436,2437,2438,2439,2440,2438,2440,2441,2442,2443,2444,2442,2444,2445,2446,2447,2448,2446,2448,2449,2450,2451,2452,2450,2452,2453,2454,2455,2456,2454,2456,2457,2458,2459,2460,2458,2460,2461,2462,2463,2464,2462,2464,2465,2466,2467,2468,2466,2468,2469,2470,2471,2472,2470,2472,2473,2474,2475,2476,2474,2476,2477,2478,2479,2480,2478,2480,2481,2482,2483,2484,2482,2484,2485,2486,2487,2488,2486,2488,2489,2490,2491,2492,2490,2492,2493,2494,2495,2496,2497,2498,2499,2500,2501,2502,2500,2502,2503,2504,2505,2506,2507,2508,2509,2510,2511,2512,2510,2512,2513,2514,2515,2516,2514,2516,2517,2518,2519,2520,2518,2520,2521,2522,2523,2524,2522,2524,2525,2526,2527,2528,2526,2528,2529,2530,2531,2532,2530,2532,2533,2534,2535,2536,2534,2536,2537,2538,2539,2540,2538,2540,2541,2542,2543,2544,2542,2544,2545,2546,2547,2548,2546,2548,2549,2550,2551,2552,2550,2552,2553,2554,2555,2556,2554,2556,2557,2558,2559,2560,2558,2560,2561,2562,2563,2564,2562,2564,2565,2566,2567,2568,2566,2568,2569,2570,2571,2572,2570,2572,2573,2574,2575,2576,2574,2576,2577,2578,2579,2580,2581,2582,2583,2584,2585,2586,2584,2586,2587,2588,2589,2590,2588,2590,2591,2592,2593,2594,2592,2594,2595,2596,2597,2598,2596,2598,2599,2600,2601,2602,2600,2602,2603,2604,2605,2606,2604,2606,2607,2608,2609,2610,2608,2610,2611,2612,2613,2614,2612,2614,2615,2616,2617,2618,2616,2618,2619,2620,2621,2622,2620,2622,2623,2624,2625,2626,2624,2626,2627,2628,2629,2630,2628,2630,2631,2632,2633,2634,2632,2634,2635,2636,2637,2638,2636,2638,2639,2640,2641,2642,2640,2642,2643,2644,2645,2646,2644,2646,2647,2648,2649,2650,2648,2650,2651,2652,2653,2654,2652,2654,2655,2656,2657,2658,2656,2658,2659,2660,2661,2662,2660,2662,2663,2664,2665,2666,2664,2666,2667,2668,2669,2670,2668,2670,2671,2672,2673,2674,2672,2674,2675,2676,2677,2678,2676,2678,2679,2680,2681,2682,2680,2682,2683,2684,2685,2686,2684,2686,2687,2688,2689,2690,2688,2690,2691,2692,2693,2694,2692,2694,2695,2696,2697,2698,2696,2698,2699,2700,2701,2702,2703,2704,2705,2706,2707,2708,2706,2708,2709,2710,2711,2712,2713,2714,2715,2716,2717,2718,2719,2720,2721,2722,2723,2724,2725,2726,2727,2728,2729,2730,2728,2730,2731,2732,2733,2734,2732,2734,2735,2736,2737,2738,2736,2738,2739,2740,2741,2742,2740,2742,2743,2744,2745,2746,2744,2746,2747,2748,2749,2750,2748,2750,2751,2752,2753,2754,2752,2754,2755,2756,2757,2758,2756,2758,2759,2760,2761,2762,2760,2762,2763,2764,2765,2766,2767,2768,2769,2770,2771,2772,2770,2772,2773,2774,2775,2776,2774,2776,2777,2778,2779,2780,2778,2780,2781,2782,2783,2784,2782,2784,2785,2786,2787,2788,2786,2788,2789,2790,2791,2792,2790,2792,2793,2794,2795,2796,2797,2798,2799,2800,2801,2802,2800,2802,2803,2804,2805,2806,2804,2806,2807,2808,2809,2810,2808,2810,2811,2812,2813,2814,2812,2814,2815,2816,2817,2818,2816,2818,2819,2820,2821,2822,2820,2822,2823,2824,2825,2826,2824,2826,2827,2828,2829,2830,2828,2830,2831,2832,2833,2834,2832,2834,2835,2836,2837,2838,2836,2838,2839,2840,2841,2842,2840,2842,2843,2844,2845,2846,2844,2846,2847,2848,2849,2850,2848,2850,2851,2852,2853,2854,2852,2854,2855,2856,2857,2858,2856,2858,2859,2860,2861,2862,2860,2862,2863,2864,2865,2866,2864,2866,2867,2868,2869,2870,2868,2870,2871,2872,2873,2874,2872,2874,2875,2876,2877,2878,2879,2880,2881,2882,2883,2884,2882,2884,2885,2886,2887,2888,2886,2888,2889,2890,2891,2892,2890,2892,2893,2894,2895,2896,2894,2896,2897,2898,2899,2900,2898,2900,2901,2902,2903,2904,2902,2904,2905,2906,2907,2908,2906,2908,2909,2910,2911,2912,2910,2912,2913,2914,2915,2916,2914,2916,2917,2918,2919,2920,2918,2920,2921,2922,2923,2924,2922,2924,2925,2926,2927,2928,2926,2928,2929,2930,2931,2932,2930,2932,2933,2934,2935,2936,2934,2936,2937,2938,2939,2940,2938,2940,2941,2942,2943,2944,2942,2944,2945,2946,2947,2948,2946,2948,2949,2950,2951,2952,2950,2952,2953,2954,2955,2956,2954,2956,2957,2958,2959,2960,2958,2960,2961,2962,2963,2964,2962,2964,2965,2966,2967,2968,2966,2968,2969,2970,2971,2972,2970,2972,2973,2974,2975,2976,2974,2976,2977,2978,2979,2980,2978,2980,2981,2982,2983,2984,2982,2984,2985,2986,2987,2988,2986,2988,2989,2990,2991,2992,2993,2994,2995,2996,2997,2998,2996,2998,2999,3000,3001,3002,3000,3002,3003,3004,3005,3006,3004,3006,3007,3008,3009,3010,3008,3010,3011,3012,3013,3014,3012,3014,3015,3016,3017,3018,3016,3018,3019,3020,3021,3022,3020,3022,3023,3024,3025,3026,3024,3026,3027,3028,3029,3030,3028,3030,3031,3032,3033,3034,3032,3034,3035,3036,3037,3038,3036,3038,3039,3040,3041,3042,3040,3042,3043,3044,3045,3046,3044,3046,3047,3048,3049,3050,3048,3050,3051,3052,3053,3054,3052,3054,3055,3056,3057,3058,3056,3058,3059,3060,3061,3062,3063,3064,3065,3066,3067,3068,3069,3070,3071,3072,3073,3074,3072,3074,3075,3076,3077,3078,3076,3078,3079,3080,3081,3082,3080,3082,3083,3084,3085,3086,3084,3086,3087,3088,3089,3090,3091,3092,3093,3094,3095,3096,3094,3096,3097,3098,3099,3100,3098,3100,3101,3102,3103,3104,3102,3104,3105,3106,3107,3108,3106,3108,3109,3110,3111,3112,3110,3112,3113,3114,3115,3116,3114,3116,3117,3118,3119,3120,3118,3120,3121,3122,3123,3124,3122,3124,3125,3126,3127,3128,3126,3128,3129,3130,3131,3132,3130,3132,3133,3134,3135,3136,3134,3136,3137,3138,3139,3140,3138,3140,3141,3142,3143,3144,3142,3144,3145,3146,3147,3148,3146,3148,3149,3150,3151,3152,3150,3152,3153,3154,3155,3156,3154,3156,3157,3158,3159,3160,3158,3160,3161,3162,3163,3164,3162,3164,3165,3166,3167,3168,3166,3168,3169,3170,3171,3172,3170,3172,3173,3174,3175,3176,3174,3176,3177,3178,3179,3180,3178,3180,3181,3182,3183,3184,3182,3184,3185,3186,3187,3188,3186,3188,3189,3190,3191,3192,3190,3192,3193,3194,3195,3196,3197,3198,3199,3200,3201,3202,3203,3204,3205,3206,3207,3208,3206,3208,3209,3210,3211,3212,3210,3212,3213,3214,3215,3216,3214,3216,3217,3218,3219,3220,3218,3220,3221,3222,3223,3224,3222,3224,3225,3226,3227,3228,3226,3228,3229,3230,3231,3232,3230,3232,3233,3234,3235,3236,3234,3236,3237,3238,3239,3240,3238,3240,3241,3242,3243,3244,3242,3244,3245,3246,3247,3248,3246,3248,3249,3250,3251,3252,3250,3252,3253,3254,3255,3256,3254,3256,3257,3258,3259,3260,3258,3260,3261,3262,3263,3264,3262,3264,3265,3266,3267,3268,3266,3268,3269,3270,3271,3272,3270,3272,3273,3274,3275,3276,3274,3276,3277,3278,3279,3280,3278,3280,3281,3282,3283,3284,3282,3284,3285,3286,3287,3288,3286,3288,3289,3290,3291,3292,3290,3292,3293,3294,3295,3296,3294,3296,3297,3298,3299,3300,3298,3300,3301,3302,3303,3304,3302,3304,3305,3306,3307,3308,3306,3308,3309,3310,3311,3312,3313,3314,3315,3316,3317,3318,3319,3320,3321,3322,3323,3324,3322,3324,3325,3326,3327,3328,3326,3328,3329,3330,3331,3332,3330,3332,3333,3334,3335,3336,3334,3336,3337,3338,3339,3340,3338,3340,3341,3342,3343,3344,3342,3344,3345,3346,3347,3348,3346,3348,3349,3350,3351,3352,3350,3352,3353,3354,3355,3356,3354,3356,3357,3358,3359,3360,3358,3360,3361,3362,3363,3364,3362,3364,3365,3366,3367,3368,3366,3368,3369,3370,3371,3372,3370,3372,3373,3374,3375,3376,3374,3376,3377,3378,3379,3380,3378,3380,3381,3382,3383,3384,3382,3384,3385,3386,3387,3388,3386,3388,3389,3390,3391,3392,3390,3392,3393,3394,3395,3396,3394,3396,3397,3398,3399,3400,3398,3400,3401,3402,3403,3404,3402,3404,3405,3406,3407,3408,3406,3408,3409,3410,3411,3412,3410,3412,3413,3414,3415,3416,3414,3416,3417,3418,3419,3420,3418,3420,3421,3422,3423,3424,3422,3424,3425,3426,3427,3428,3429,3430,3431,3432,3433,3434,3432,3434,3435,3436,3437,3438,3439,3440,3441,3442,3443,3444,3442,3444,3445,3446,3447,3448,3446,3448,3449,3450,3451,3452,3450,3452,3453,3454,3455,3456,3454,3456,3457,3458,3459,3460,3458,3460,3461,3462,3463,3464,3462,3464,3465,3466,3467,3468,3466,3468,3469,3470,3471,3472,3470,3472,3473,3474,3475,3476,3474,3476,3477,3478,3479,3480,3478,3480,3481,3482,3483,3484,3482,3484,3485,3486,3487,3488,3486,3488,3489,3490,3491,3492,3490,3492,3493,3494,3495,3496,3494,3496,3497,3498,3499,3500,3498,3500,3501,3502,3503,3504,3502,3504,3505,3506,3507,3508,3506,3508,3509,3510,3511,3512,3510,3512,3513,3514,3515,3516,3514,3516,3517,3518,3519,3520,3518,3520,3521,3522,3523,3524,3522,3524,3525,3526,3527,3528,3526,3528,3529,3530,3531,3532,3530,3532,3533,3534,3535,3536,3534,3536,3537,3538,3539,3540,3538,3540,3541,3542,3543,3544,3542,3544,3545,3546,3547,3548,3546,3548,3549,3550,3551,3552,3550,3552,3553,3554,3555,3556,3554,3556,3557,3558,3559,3560,3558,3560,3561,3562,3563,3564,3562,3564,3565,3566,3567,3568,3566,3568,3569,3570,3571,3572,3570,3572,3573,3574,3575,3576,3574,3576,3577,3578,3579,3580,3578,3580,3581,3582,3583,3584,3582,3584,3585,3586,3587,3588,3586,3588,3589,3590,3591,3592,3590,3592,3593,3594,3595,3596,3594,3596,3597,3598,3599,3600,3601,3602,3603,3604,3605,3606,3607,3608,3609,3610,3611,3612,3610,3612,3613,3614,3615,3616,3614,3616,3617,3618,3619,3620,3618,3620,3621,3622,3623,3624,3622,3624,3625,3626,3627,3628,3626,3628,3629,3630,3631,3632,3630,3632,3633,3634,3635,3636,3637,3638,3639,3640,3641,3642,3643,3644,3645,3646,3647,3648,3646,3648,3649,3650,3651,3652,3650,3652,3653,3654,3655,3656,3657,3658,3659,3660,3661,3662,3660,3662,3663,3664,3665,3666,3664,3666,3667,3668,3669,3670,3668,3670,3671,3672,3673,3674,3672,3674,3675,3676,3677,3678,3676,3678,3679,3680,3681,3682,3680,3682,3683,3684,3685,3686,3684,3686,3687,3688,3689,3690,3688,3690,3691,3692,3693,3694,3692,3694,3695,3696,3697,3698,3696,3698,3699,3700,3701,3702,3700,3702,3703,3704,3705,3706,3704,3706,3707,3708,3709,3710,3708,3710,3711,3712,3713,3714,3712,3714,3715,3716,3717,3718,3716,3718,3719,3720,3721,3722,3720,3722,3723,3724,3725,3726,3724,3726,3727,3728,3729,3730,3728,3730,3731,3732,3733,3734,3732,3734,3735,3736,3737,3738,3736,3738,3739,3740,3741,3742,3740,3742,3743,3744,3745,3746,3744,3746,3747,3748,3749,3750,3748,3750,3751,3752,3753,3754,3752,3754,3755,3756,3757,3758,3756,3758,3759,3760,3761,3762,3763,3764,3765,3766,3767,3768,3769,3770,3771,3772,3773,3774,3772,3774,3775,3776,3777,3778,3776,3778,3779,3780,3781,3782,3780,3782,3783,3784,3785,3786,3784,3786,3787,3788,3789,3790,3788,3790,3791,3792,3793,3794,3792,3794,3795,3796,3797,3798,3796,3798,3799,3800,3801,3802,3800,3802,3803,3804,3805,3806,3804,3806,3807,3808,3809,3810,3808,3810,3811,3812,3813,3814,3812,3814,3815,3816,3817,3818,3816,3818,3819,3820,3821,3822,3820,3822,3823,3824,3825,3826,3824,3826,3827,3828,3829,3830,3828,3830,3831,3832,3833,3834,3835,3836,3837,3838,3839,3840,3838,3840,3841,3842,3843,3844,3842,3844,3845,3846,3847,3848,3846,3848,3849,3850,3851,3852,3850,3852,3853,3854,3855,3856,3854,3856,3857,3858,3859,3860,3861,3862,3863,3864,3865,3866,3864,3866,3867,3868,3869,3870,3868,3870,3871,3872,3873,3874,3875,3876,3877,3878,3879,3880,3878,3880,3881,3882,3883,3884,3882,3884,3885,3886,3887,3888,3886,3888,3889,3890,3891,3892,3890,3892,3893,3894,3895,3896,3894,3896,3897,3898,3899,3900,3898,3900,3901,3902,3903,3904,3902,3904,3905,3906,3907,3908,3906,3908,3909,3910,3911,3912,3910,3912,3913,3914,3915,3916,3914,3916,3917,3918,3919,3920,3918,3920,3921,3922,3923,3924,3922,3924,3925,3926,3927,3928,3926,3928,3929,3930,3931,3932,3930,3932,3933,3934,3935,3936,3934,3936,3937,3938,3939,3940,3938,3940,3941,3942,3943,3944,3942,3944,3945,3946,3947,3948,3946,3948,3949,3950,3951,3952,3950,3952,3953,3954,3955,3956,3954,3956,3957,3958,3959,3960,3958,3960,3961,3962,3963,3964,3965,3966,3967,3968,3969,3970,3968,3970,3971,3972,3973,3974,3975,3976,3977,3978,3979,3980,3978,3980,3981,3982,3983,3984,3982,3984,3985,3986,3987,3988,3986,3988,3989,3990,3991,3992,3990,3992,3993,3994,3995,3996,3997,3998,3999,4000,4001,4002,4003,4004,4005,4006,4007,4008,4006,4008,4009,4010,4011,4012,4010,4012,4013,4014,4015,4016,4014,4016,4017,4018,4019,4020,4018,4020,4021,4022,4023,4024,4022,4024,4025,4026,4027,4028,4026,4028,4029,4030,4031,4032,4030,4032,4033,4034,4035,4036,4034,4036,4037,4038,4039,4040,4038,4040,4041,4042,4043,4044,4045,4046,4047,4048,4049,4050,4048,4050,4051,4052,4053,4054,4055,4056,4057,4058,4059,4060,4058,4060,4061,4062,4063,4064,4062,4064,4065,4066,4067,4068,4066,4068,4069,4070,4071,4072,4070,4072,4073,4074,4075,4076,4074,4076,4077,4078,4079,4080,4078,4080,4081,4082,4083,4084,4082,4084,4085,4086,4087,4088,4089,4090,4091,4092,4093,4094,4095,4096,4097,4098,4099,4100,4098,4100,4101,4102,4103,4104,4102,4104,4105,4106,4107,4108,4106,4108,4109,4110,4111,4112,4110,4112,4113,4114,4115,4116,4114,4116,4117,4118,4119,4120,4118,4120,4121,4122,4123,4124,4122,4124,4125,4126,4127,4128,4126,4128,4129,4130,4131,4132,4130,4132,4133,4134,4135,4136,4137,4138,4139,4140,4141,4142,4143,4144,4145,4146,4147,4148,4146,4148,4149,4150,4151,4152,4150,4152,4153,4154,4155,4156,4154,4156,4157,4158,4159,4160,4158,4160,4161,4162,4163,4164,4162,4164,4165,4166,4167,4168,4166,4168,4169,4170,4171,4172,4170,4172,4173,4174,4175,4176,4174,4176,4177,4178,4179,4180,4178,4180,4181,4182,4183,4184,4182,4184,4185,4186,4187,4188,4186,4188,4189,4190,4191,4192,4190,4192,4193,4194,4195,4196,4194,4196,4197,4198,4199,4200,4198,4200,4201,4202,4203,4204,4202,4204,4205,4206,4207,4208,4206,4208,4209,4210,4211,4212,4210,4212,4213,4214,4215,4216,4214,4216,4217,4218,4219,4220,4218,4220,4221,4222,4223,4224,4222,4224,4225,4226,4227,4228,4226,4228,4229,4230,4231,4232,4230,4232,4233,4234,4235,4236,4234,4236,4237,4238,4239,4240,4238,4240,4241,4242,4243,4244,4242,4244,4245,4246,4247,4248,4246,4248,4249,4250,4251,4252,4253,4254,4255,4256,4257,4258,4256,4258,4259,4260,4261,4262,4263,4264,4265,4266,4267,4268,4266,4268,4269,4270,4271,4272,4270,4272,4273,4274,4275,4276,4274,4276,4277,4278,4279,4280,4281,4282,4283,4284,4285,4286,4287,4288,4289,4290,4291,4292,4290,4292,4293,4294,4295,4296,4294,4296,4297,4298,4299,4300,4298,4300,4301,4302,4303,4304,4305,4306,4307,4308,4309,4310,4311,4312,4313,4314,4315,4316,4314,4316,4317,4318,4319,4320,4318,4320,4321,4322,4323,4324,4322,4324,4325,4326,4327,4328,4326,4328,4329,4330,4331,4332,4330,4332,4333,4334,4335,4336,4334,4336,4337,4338,4339,4340,4338,4340,4341,4342,4343,4344,4342,4344,4345,4346,4347,4348,4346,4348,4349,4350,4351,4352,4353,4354,4355,4356,4357,4358,4356,4358,4359,4360,4361,4362,4360,4362,4363,4364,4365,4366,4364,4366,4367,4368,4369,4370,4368,4370,4371,4372,4373,4374,4372,4374,4375,4376,4377,4378,4376,4378,4379,4380,4381,4382,4380,4382,4383,4384,4385,4386,4384,4386,4387,4388,4389,4390,4391,4392,4393,4394,4395,4396,4397,4398,4399,4400,4401,4402,4400,4402,4403,4404,4405,4406,4407,4408,4409,4410,4411,4412,4413,4414,4415,4416,4417,4418,4416,4418,4419,4420,4421,4422,4423,4424,4425,4426,4427,4428,4426,4428,4429,4430,4431,4432,4430,4432,4433,4434,4435,4436,4434,4436,4437,4438,4439,4440,4441,4442,4443,4444,4445,4446,4444,4446,4447,4448,4449,4450,4451,4452,4453,4454,4455,4456,4454,4456,4457,4458,4459,4460,4458,4460,4461,4462,4463,4464,4462,4464,4465,4466,4467,4468,4466,4468,4469,4470,4471,4472,4470,4472,4473,4474,4475,4476,4474,4476,4477,4478,4479,4480,4478,4480,4481,4482,4483,4484,4482,4484,4485,4486,4487,4488,4486,4488,4489,4490,4491,4492,4493,4494,4495,4496,4497,4498,4496,4498,4499,4500,4501,4502,4500,4502,4503,4504,4505,4506,4504,4506,4507,4508,4509,4510,4508,4510,4511,4512,4513,4514,4515,4516,4517,4518,4519,4520,4521,4522,4523,4524,4525,4526,4524,4526,4527,4528,4529,4530,4528,4530,4531,4532,4533,4534,4532,4534,4535,4536,4537,4538,4536,4538,4539,4540,4541,4542,4540,4542,4543,4544,4545,4546,4544,4546,4547,4548,4549,4550,4548,4550,4551,4552,4553,4554,4552,4554,4555,4556,4557,4558,4559,4560,4561,4562,4563,4564,4565,4566,4567,4568,4569,4570,4568,4570,4571,4572,4573,4574,4572,4574,4575,4576,4577,4578,4576,4578,4579,4580,4581,4582,4583,4584,4585,4586,4587,4588,4586,4588,4589,4590,4591,4592,4593,4594,4595,4596,4597,4598,4596,4598,4599,4600,4601,4602,4600,4602,4603,4604,4605,4606,4604,4606,4607,4608,4609,4610,4611,4612,4613,4614,4615,4616,4614,4616,4617,4618,4619,4620,4618,4620,4621,4622,4623,4624,4622,4624,4625,4626,4627,4628,4626,4628,4629,4630,4631,4632,4630,4632,4633,4634,4635,4636,4634,4636,4637,4638,4639,4640,4641,4642,4643,4644,4645,4646,4647,4648,4649,4650,4651,4652,4653,4654,4655,4656,4657,4658,4659,4660,4661,4662,4663,4664,4662,4664,4665,4666,4667,4668,4666,4668,4669,4670,4671,4672,4670,4672,4673,4674,4675,4676,4674,4676,4677,4678,4679,4680,4678,4680,4681,4682,4683,4684,4682,4684,4685,4686,4687,4688,4686,4688,4689,4690,4691,4692,4690,4692,4693,4694,4695,4696,4694,4696,4697,4698,4699,4700,4698,4700,4701,4702,4703,4704,4702,4704,4705,4706,4707,4708,4706,4708,4709,4710,4711,4712,4713,4714,4715,4716,4717,4718,4719,4720,4721,4722,4723,4724,4722,4724,4725,4726,4727,4728,4726,4728,4729,4730,4731,4732,4730,4732,4733,4734,4735,4736,4737,4738,4739,4740,4741,4742,4740,4742,4743,4744,4745,4746,4747,4748,4749,4750,4751,4752,4750,4752,4753,4754,4755,4756,4754,4756,4757,4758,4759,4760,4758,4760,4761,4762,4763,4764,4762,4764,4765,4766,4767,4768,4766,4768,4769,4770,4771,4772,4770,4772,4773,4774,4775,4776,4774,4776,4777,4778,4779,4780,4778,4780,4781,4782,4783,4784,4782,4784,4785,4786,4787,4788,4786,4788,4789,4790,4791,4792,4790,4792,4793,4794,4795,4796,4794,4796,4797,4798,4799,4800,4798,4800,4801,4802,4803,4804,4802,4804,4805,4806,4807,4808,4806,4808,4809,4810,4811,4812,4810,4812,4813,4814,4815,4816,4814,4816,4817,4818,4819,4820,4818,4820,4821,4822,4823,4824,4822,4824,4825,4826,4827,4828,4826,4828,4829,4830,4831,4832,4830,4832,4833,4834,4835,4836,4834,4836,4837,4838,4839,4840,4838,4840,4841,4842,4843,4844,4842,4844,4845,4846,4847,4848,4849,4850,4851,4852,4853,4854,4852,4854,4855,4856,4857,4858,4856,4858,4859,4860,4861,4862,4860,4862,4863,4864,4865,4866,4864,4866,4867,4868,4869,4870,4868,4870,4871,4872,4873,4874,4872,4874,4875,4876,4877,4878,4879,4880,4881,4882,4883,4884,4882,4884,4885,4886,4887,4888,4886,4888,4889,4890,4891,4892,4890,4892,4893,4894,4895,4896,4894,4896,4897,4898,4899,4900,4898,4900,4901,4902,4903,4904,4902,4904,4905,4906,4907,4908,4906,4908,4909,4910,4911,4912,4910,4912,4913,4914,4915,4916,4917,4918,4919,4920,4921,4922,4923,4924,4925,4926,4927,4928,4926,4928,4929,4930,4931,4932,4930,4932,4933,4934,4935,4936,4934,4936,4937,4938,4939,4940,4938,4940,4941,4942,4943,4944,4942,4944,4945,4946,4947,4948,4946,4948,4949,4950,4951,4952,4950,4952,4953,4954,4955,4956,4957,4958,4959,4960,4961,4962,4960,4962,4963,4964,4965,4966,4964,4966,4967,4968,4969,4970,4968,4970,4971,4972,4973,4974,4972,4974,4975,4976,4977,4978,4979,4980,4981,4982,4983,4984,4985,4986,4987,4988,4989,4990,4988,4990,4991,4992,4993,4994,4992,4994,4995,4996,4997,4998,4996,4998,4999,5000,5001,5002,5000,5002,5003,5004,5005,5006,5004,5006,5007,5008,5009,5010,5008,5010,5011,5012,5013,5014,5012,5014,5015,5016,5017,5018,5016,5018,5019,5020,5021,5022,5020,5022,5023,5024,5025,5026,5027,5028,5029,5030,5031,5032,5030,5032,5033,5034,5035,5036,5037,5038,5039,5040,5041,5042,5040,5042,5043,5044,5045,5046,5044,5046,5047,5048,5049,5050,5048,5050,5051,5052,5053,5054,5052,5054,5055,5056,5057,5058,5056,5058,5059,5060,5061,5062,5060,5062,5063,5064,5065,5066,5064,5066,5067,5068,5069,5070,5071,5072,5073,5074,5075,5076,5077,5078,5079,5080,5081,5082,5080,5082,5083,5084,5085,5086,5084,5086,5087,5088,5089,5090,5088,5090,5091,5092,5093,5094,5092,5094,5095,5096,5097,5098,5096,5098,5099,5100,5101,5102,5100,5102,5103,5104,5105,5106,5104,5106,5107,5108,5109,5110,5108,5110,5111,5112,5113,5114,5112,5114,5115,5116,5117,5118,5116,5118,5119,5120,5121,5122,5120,5122,5123,5124,5125,5126,5124,5126,5127,5128,5129,5130,5128,5130,5131,5132,5133,5134,5132,5134,5135,5136,5137,5138,5136,5138,5139,5140,5141,5142,5140,5142,5143,5144,5145,5146,5144,5146,5147,5148,5149,5150,5148,5150,5151,5152,5153,5154,5152,5154,5155,5156,5157,5158,5156,5158,5159,5160,5161,5162,5160,5162,5163,5164,5165,5166,5164,5166,5167,5168,5169,5170,5168,5170,5171,5172,5173,5174,5172,5174,5175,5176,5177,5178,5176,5178,5179,5180,5181,5182,5180,5182,5183,5184,5185,5186,5184,5186,5187,5188,5189,5190,5191,5192,5193,5194,5195,5196,5194,5196,5197,5198,5199,5200,5198,5200,5201,5202,5203,5204,5202,5204,5205,5206,5207,5208,5206,5208,5209,5210,5211,5212,5210,5212,5213,5214,5215,5216,5217,5218,5219,5220,5221,5222,5223,5224,5225,5226,5227,5228,5226,5228,5229,5230,5231,5232,5230,5232,5233,5234,5235,5236,5234,5236,5237,5238,5239,5240,5238,5240,5241,5242,5243,5244,5242,5244,5245,5246,5247,5248,5246,5248,5249,5250,5251,5252,5250,5252,5253,5254,5255,5256,5254,5256,5257,5258,5259,5260,5261,5262,5263,5264,5265,5266,5267,5268,5269,5270,5271,5272,5270,5272,5273,5274,5275,5276,5274,5276,5277,5278,5279,5280,5278,5280,5281,5282,5283,5284,5282,5284,5285,5286,5287,5288,5286,5288,5289,5290,5291,5292,5290,5292,5293,5294,5295,5296,5294,5296,5297,5298,5299,5300,5298,5300,5301,5302,5303,5304,5302,5304,5305,5306,5307,5308,5306,5308,5309,5310,5311,5312,5310,5312,5313,5314,5315,5316,5314,5316,5317,5318,5319,5320,5318,5320,5321,5322,5323,5324,5322,5324,5325,5326,5327,5328,5326,5328,5329,5330,5331,5332,5330,5332,5333,5334,5335,5336,5334,5336,5337,5338,5339,5340,5338,5340,5341,5342,5343,5344,5342,5344,5345,5346,5347,5348,5346,5348,5349,5350,5351,5352,5350,5352,5353,5354,5355,5356,5354,5356,5357,5358,5359,5360,5358,5360,5361,5362,5363,5364,5365,5366,5367,5368,5369,5370,5368,5370,5371,5372,5373,5374,5372,5374,5375,5376,5377,5378,5376,5378,5379,5380,5381,5382,5380,5382,5383,5384,5385,5386,5384,5386,5387,5388,5389,5390,5388,5390,5391,5392,5393,5394,5392,5394,5395,5396,5397,5398,5396,5398,5399,5400,5401,5402,5403,5404,5405,5406,5407,5408,5406,5408,5409,5410,5411,5412,5410,5412,5413,5414,5415,5416,5417,5418,5419,5420,5421,5422,5420,5422,5423,5424,5425,5426,5424,5426,5427,5428,5429,5430,5428,5430,5431,5432,5433,5434,5432,5434,5435,5436,5437,5438,5436,5438,5439,5440,5441,5442,5440,5442,5443,5444,5445,5446,5447,5448,5449,5450,5451,5452,5450,5452,5453,5454,5455,5456,5454,5456,5457,5458,5459,5460,5458,5460,5461,5462,5463,5464,5462,5464,5465,5466,5467,5468,5466,5468,5469,5470,5471,5472,5470,5472,5473,5474,5475,5476,5474,5476,5477,5478,5479,5480,5478,5480,5481,5482,5483,5484,5482,5484,5485,5486,5487,5488,5486,5488,5489,5490,5491,5492,5490,5492,5493,5494,5495,5496,5494,5496,5497,5498,5499,5500,5498,5500,5501,5502,5503,5504,5502,5504,5505,5506,5507,5508,5506,5508,5509,5510,5511,5512,5510,5512,5513,5514,5515,5516,5514,5516,5517,5518,5519,5520,5518,5520,5521,5522,5523,5524,5522,5524,5525,5526,5527,5528,5526,5528,5529,5530,5531,5532,5530,5532,5533,5534,5535,5536,5534,5536,5537,5538,5539,5540,5538,5540,5541,5542,5543,5544,5542,5544,5545,5546,5547,5548,5546,5548,5549,5550,5551,5552,5550,5552,5553,5554,5555,5556,5554,5556,5557,5558,5559,5560,5558,5560,5561,5562,5563,5564,5565,5566,5567,5568,5569,5570,5568,5570,5571,5572,5573,5574,5572,5574,5575,5576,5577,5578,5576,5578,5579,5580,5581,5582,5580,5582,5583,5584,5585,5586,5584,5586,5587,5588,5589,5590,5588,5590,5591,5592,5593,5594,5592,5594,5595,5596,5597,5598,5599,5600,5601,5602,5603,5604,5605,5606,5607,5608,5609,5610,5611,5612,5613,5614,5615,5616,5614,5616,5617,5618,5619,5620,5621,5622,5623,5624,5625,5626,5627,5628,5629,5630,5631,5632,5630,5632,5633,5634,5635,5636,5634,5636,5637,5638,5639,5640,5638,5640,5641,5642,5643,5644,5642,5644,5645,5646,5647,5648,5646,5648,5649,5650,5651,5652,5650,5652,5653,5654,5655,5656,5654,5656,5657,5658,5659,5660,5658,5660,5661,5662,5663,5664,5665,5666,5667,5668,5669,5670,5671,5672,5673,5674,5675,5676,5674,5676,5677,5678,5679,5680,5678,5680,5681,5682,5683,5684,5682,5684,5685,5686,5687,5688,5686,5688,5689,5690,5691,5692,5690,5692,5693,5694,5695,5696,5694,5696,5697,5698,5699,5700,5698,5700,5701,5702,5703,5704,5702,5704,5705,5706,5707,5708,5706,5708,5709,5710,5711,5712,5710,5712,5713,5714,5715,5716,5714,5716,5717,5718,5719,5720,5721,5722,5723,5724,5725,5726,5727,5728,5729,5730,5731,5732,5730,5732,5733,5734,5735,5736,5734,5736,5737,5738,5739,5740,5741,5742,5743,5744,5745,5746,5744,5746,5747,5748,5749,5750,5748,5750,5751,5752,5753,5754,5752,5754,5755,5756,5757,5758,5756,5758,5759,5760,5761,5762,5760,5762,5763,5764,5765,5766,5764,5766,5767,5768,5769,5770,5768,5770,5771,5772,5773,5774,5772,5774,5775,5776,5777,5778,5776,5778,5779,5780,5781,5782,5780,5782,5783,5784,5785,5786,5784,5786,5787,5788,5789,5790,5788,5790,5791,5792,5793,5794,5795,5796,5797,5798,5799,5800,5798,5800,5801,5802,5803,5804,5802,5804,5805,5806,5807,5808,5809,5810,5811,5812,5813,5814,5812,5814,5815,5816,5817,5818,5816,5818,5819,5820,5821,5822,5820,5822,5823,5824,5825,5826,5824,5826,5827,5828,5829,5830,5828,5830,5831,5832,5833,5834,5832,5834,5835,5836,5837,5838,5836,5838,5839,5840,5841,5842,5840,5842,5843,5844,5845,5846,5847,5848,5849,5850,5851,5852,5850,5852,5853,5854,5855,5856,5854,5856,5857,5858,5859,5860,5858,5860,5861,5862,5863,5864,5862,5864,5865,5866,5867,5868,5869,5870,5871,5872,5873,5874,5875,5876,5877,5878,5879,5880,5878,5880,5881,5882,5883,5884,5882,5884,5885,5886,5887,5888,5886,5888,5889,5890,5891,5892,5890,5892,5893,5894,5895,5896,5894,5896,5897,5898,5899,5900,5898,5900,5901,5902,5903,5904,5902,5904,5905,5906,5907,5908,5909,5910,5911,5912,5913,5914,5912,5914,5915,5916,5917,5918,5916,5918,5919,5920,5921,5922,5923,5924,5925,5926,5927,5928,5929,5930,5931,5932,5933,5934,5935,5936,5937,5938,5939,5940,5938,5940,5941,5942,5943,5944,5942,5944,5945,5946,5947,5948,5949,5950,5951,5952,5953,5954,5955,5956,5957,5958,5959,5960,5958,5960,5961,5962,5963,5964,5962,5964,5965,5966,5967,5968,5966,5968,5969,5970,5971,5972,5970,5972,5973,5974,5975,5976,5974,5976,5977,5978,5979,5980,5978,5980,5981,5982,5983,5984,5982,5984,5985,5986,5987,5988,5986,5988,5989,5990,5991,5992,5990,5992,5993,5994,5995,5996,5994,5996,5997,5998,5999,6000,5998,6000,6001,6002,6003,6004,6002,6004,6005,6006,6007,6008,6006,6008,6009,6010,6011,6012,6010,6012,6013,6014,6015,6016,6014,6016,6017,6018,6019,6020,6018,6020,6021,6022,6023,6024,6022,6024,6025,6026,6027,6028,6026,6028,6029,6030,6031,6032,6030,6032,6033,6034,6035,6036,6034,6036,6037,6038,6039,6040,6038,6040,6041,6042,6043,6044,6042,6044,6045,6046,6047,6048,6046,6048,6049,6050,6051,6052,6050,6052,6053,6054,6055,6056,6057,6058,6059,6060,6061,6062,6063,6064,6065,6066,6067,6068,6066,6068,6069,6070,6071,6072,6073,6074,6075,6076,6077,6078,6079,6080,6081,6082,6083,6084,6082,6084,6085,6086,6087,6088,6089,6090,6091,6092,6093,6094,6095,6096,6097,6098,6099,6100,6098,6100,6101,6102,6103,6104,6105,6106,6107,6108,6109,6110,6111,6112,6113,6114,6115,6116,6117,6118,6119,6120,6121,6122,6123,6124,6125,6126,6127,6128,6126,6128,6129,6130,6131,6132,6130,6132,6133,6134,6135,6136,6134,6136,6137,6138,6139,6140,6138,6140,6141,6142,6143,6144,6142,6144,6145,6146,6147,6148,6146,6148,6149,6150,6151,6152,6150,6152,6153,6154,6155,6156,6157,6158,6159,6160,6161,6162,6163,6164,6165,6166,6167,6168,6166,6168,6169,6170,6171,6172,6170,6172,6173,6174,6175,6176,6174,6176,6177,6178,6179,6180,6181,6182,6183,6184,6185,6186,6187,6188,6189,6190,6191,6192,6190,6192,6193,6194,6195,6196,6197,6198,6199,6200,6201,6202,6203,6204,6205,6206,6207,6208,6206,6208,6209,6210,6211,6212,6210,6212,6213,6214,6215,6216,6214,6216,6217,6218,6219,6220,6218,6220,6221,6222,6223,6224,6222,6224,6225,6226,6227,6228,6226,6228,6229,6230,6231,6232,6233,6234,6235,6236,6237,6238,6236,6238,6239,6240,6241,6242,6243,6244,6245,6246,6247,6248,6249,6250,6251,6252,6253,6254,6255,6256,6257,6258,6259,6260,6258,6260,6261,6262,6263,6264,6265,6266,6267,6268,6269,6270,6271,6272,6273,6274,6275,6276,6277,6278,6279,6280,6281,6282,6280,6282,6283,6284,6285,6286,6287,6288,6289,6290,6291,6292,6290,6292,6293,6294,6295,6296,6294,6296,6297,6298,6299,6300,6298,6300,6301,6302,6303,6304,6302,6304,6305,6306,6307,6308,6306,6308,6309,6310,6311,6312,6310,6312,6313,6314,6315,6316,6314,6316,6317,6318,6319,6320,6318,6320,6321,6322,6323,6324,6325,6326,6327,6328,6329,6330,6331,6332,6333,6334,6335,6336,6334,6336,6337,6338,6339,6340,6341,6342,6343,6344,6345,6346,6344,6346,6347,6348,6349,6350,6348,6350,6351,6352,6353,6354,6355,6356,6357,6358,6359,6360,6361,6362,6363,6364,6365,6366,6364,6366,6367,6368,6369,6370,6371,6372,6373,6374,6375,6376,6374,6376,6377,6378,6379,6380,6378,6380,6381,6382,6383,6384,6385,6386,6387,6388,6389,6390,6388,6390,6391,6392,6393,6394,6392,6394,6395,6396,6397,6398,6396,6398,6399,6400,6401,6402,6400,6402,6403,6404,6405,6406,6404,6406,6407,6408,6409,6410,6408,6410,6411,6412,6413,6414,6412,6414,6415,6416,6417,6418,6416,6418,6419,6420,6421,6422,6420,6422,6423,6424,6425,6426,6424,6426,6427,6428,6429,6430,6431,6432,6433,6434,6435,6436,6434,6436,6437,6438,6439,6440,6438,6440,6441,6442,6443,6444,6442,6444,6445,6446,6447,6448,6446,6448,6449,6450,6451,6452,6450,6452,6453,6454,6455,6456,6454,6456,6457,6458,6459,6460,6458,6460,6461,6462,6463,6464,6462,6464,6465,6466,6467,6468,6466,6468,6469,6470,6471,6472,6473,6474,6475,6476,6477,6478,6476,6478,6479,6480,6481,6482,6483,6484,6485,6486,6487,6488,6486,6488,6489,6490,6491,6492,6490,6492,6493,6494,6495,6496,6494,6496,6497,6498,6499,6500,6498,6500,6501,6502,6503,6504,6502,6504,6505,6506,6507,6508,6506,6508,6509,6510,6511,6512,6510,6512,6513,6514,6515,6516,6514,6516,6517,6518,6519,6520,6521,6522,6523,6524,6525,6526,6527,6528,6529,6530,6531,6532,6530,6532,6533,6534,6535,6536,6534,6536,6537,6538,6539,6540,6541,6542,6543,6544,6545,6546,6547,6548,6549,6550,6551,6552,6553,6554,6555,6556,6557,6558,6559,6560,6561,6562,6563,6564,6565,6566,6567,6568,6569,6570,6568,6570,6571,6572,6573,6574,6575,6576,6577,6578,6579,6580,6578,6580,6581,6582,6583,6584,6582,6584,6585,6586,6587,6588,6589,6590,6591,6592,6593,6594,6595,6596,6597,6598,6599,6600,6601,6602,6603,6604,6605,6606,6604,6606,6607,6608,6609,6610,6611,6612,6613,6614,6615,6616,6617,6618,6619,6620,6621,6622,6620,6622,6623,6624,6625,6626,6624,6626,6627,6628,6629,6630,6628,6630,6631,6632,6633,6634,6632,6634,6635,6636,6637,6638,6636,6638,6639,6640,6641,6642,6640,6642,6643,6644,6645,6646,6644,6646,6647,6648,6649,6650,6648,6650,6651,6652,6653,6654,6652,6654,6655,6656,6657,6658,6656,6658,6659,6660,6661,6662,6660,6662,6663,6664,6665,6666,6664,6666,6667,6668,6669,6670,6671,6672,6673,6674,6675,6676,6677,6678,6679,6680,6681,6682,6683,6684,6685,6686,6687,6688,6686,6688,6689,6690,6691,6692,6693,6694,6695,6696,6697,6698,6696,6698,6699,6700,6701,6702,6700,6702,6703,6704,6705,6706,6704,6706,6707,6708,6709,6710,6711,6712,6713,6714,6715,6716,6717,6718,6719,6720,6721,6722,6723,6724,6725,6726,6727,6728,6729,6730,6731,6732,6733,6734,6732,6734,6735,6736,6737,6738,6736,6738,6739,6740,6741,6742,6740,6742,6743,6744,6745,6746,6744,6746,6747,6748,6749,6750,6748,6750,6751,6752,6753,6754,6752,6754,6755,6756,6757,6758,6759,6760,6761,6762,6763,6764,6762,6764,6765,6766,6767,6768,6766,6768,6769,6770,6771,6772,6773,6774,6775,6776,6777,6778,6776,6778,6779,6780,6781,6782,6780,6782,6783,6784,6785,6786,6784,6786,6787,6788,6789,6790,6788,6790,6791,6792,6793,6794,6795,6796,6797,6798,6799,6800,6801,6802,6803,6804,6805,6806,6804,6806,6807,6808,6809,6810,6808,6810,6811,6812,6813,6814,6812,6814,6815,6816,6817,6818,6816,6818,6819,6820,6821,6822,6823,6824,6825,6826,6827,6828,6826,6828,6829,6830,6831,6832,6830,6832,6833,6834,6835,6836,6834,6836,6837,6838,6839,6840,6841,6842,6843,6844,6845,6846,6847,6848,6849,6850,6851,6852,6853,6854,6855,6856,6857,6858,6859,6860,6861,6862,6863,6864,6862,6864,6865,6866,6867,6868,6866,6868,6869,6870,6871,6872,6870,6872,6873,6874,6875,6876,6874,6876,6877,6878,6879,6880,6881,6882,6883,6884,6885,6886,6884,6886,6887,6888,6889,6890,6888,6890,6891,6892,6893,6894,6892,6894,6895,6896,6897,6898,6896,6898,6899,6900,6901,6902,6900,6902,6903,6904,6905,6906,6907,6908,6909,6910,6911,6912,6910,6912,6913,6914,6915,6916,6917,6918,6919,6920,6921,6922,6920,6922,6923,6924,6925,6926,6924,6926,6927,6928,6929,6930,6928,6930,6931,6932,6933,6934,6932,6934,6935,6936,6937,6938,6936,6938,6939,6940,6941,6942,6940,6942,6943,6944,6945,6946,6944,6946,6947,6948,6949,6950,6948,6950,6951,6952,6953,6954,6952,6954,6955,6956,6957,6958,6959,6960,6961,6962,6963,6964,6962,6964,6965,6966,6967,6968,6966,6968,6969,6970,6971,6972,6970,6972,6973,6974,6975,6976,6977,6978,6979,6980,6981,6982,6980,6982,6983,6984,6985,6986,6987,6988,6989,6990,6991,6992,6993,6994,6995,6996,6997,6998,6999,7000,7001,7002,7003,7004,7002,7004,7005,7006,7007,7008,7006,7008,7009,7010,7011,7012,7013,7014,7015,7016,7017,7018,7016,7018,7019,7020,7021,7022,7023,7024,7025,7026,7027,7028,7026,7028,7029,7030,7031,7032,7030,7032,7033,7034,7035,7036,7034,7036,7037,7038,7039,7040,7038,7040,7041,7042,7043,7044,7045,7046,7047,7048,7049,7050,7048,7050,7051,7052,7053,7054,7055,7056,7057,7058,7059,7060,7061,7062,7063,7064,7065,7066,7064,7066,7067,7068,7069,7070,7068,7070,7071,7072,7073,7074,7072,7074,7075,7076,7077,7078,7076,7078,7079,7080,7081,7082,7080,7082,7083,7084,7085,7086,7084,7086,7087,7088,7089,7090,7088,7090,7091,7092,7093,7094,7092,7094,7095,7096,7097,7098,7096,7098,7099,7100,7101,7102,7100,7102,7103,7104,7105,7106,7107,7108,7109,7110,7111,7112,7110,7112,7113,7114,7115,7116,7117,7118,7119,7120,7121,7122,7123,7124,7125,7126,7127,7128,7129,7130,7131,7132,7133,7134,7132,7134,7135,7136,7137,7138,7139,7140,7141,7142,7143,7144,7142,7144,7145,7146,7147,7148,7146,7148,7149,7150,7151,7152,7150,7152,7153,7154,7155,7156,7157,7158,7159,7160,7161,7162,7163,7164,7165,7166,7167,7168,7166,7168,7169,7170,7171,7172,7170,7172,7173,7174,7175,7176,7177,7178,7179,7180,7181,7182,7180,7182,7183,7184,7185,7186,7187,7188,7189,7190,7191,7192,7190,7192,7193,7194,7195,7196,7197,7198,7199,7200,7201,7202,7200,7202,7203,7204,7205,7206,7207,7208,7209,7210,7211,7212,7213,7214,7215,7216,7217,7218,7216,7218,7219,7220,7221,7222,7220,7222,7223,7224,7225,7226,7224,7226,7227,7228,7229,7230,7228,7230,7231,7232,7233,7234,7235,7236,7237,7238,7239,7240,7241,7242,7243,7244,7245,7246,7244,7246,7247,7248,7249,7250,7248,7250,7251,7252,7253,7254,7252,7254,7255,7256,7257,7258,7256,7258,7259,7260,7261,7262,7260,7262,7263,7264,7265,7266,7267,7268,7269,7270,7271,7272,7273,7274,7275,7276,7277,7278,7279,7280,7281,7282,7283,7284,7285,7286,7287,7288,7289,7290,7288,7290,7291,7292,7293,7294,7292,7294,7295,7296,7297,7298,7296,7298,7299,7300,7301,7302,7303,7304,7305,7306,7307,7308,7309,7310,7311,7312,7313,7314,7312,7314,7315,7316,7317,7318,7316,7318,7319,7320,7321,7322,7320,7322,7323,7324,7325,7326,7324,7326,7327,7328,7329,7330,7328,7330,7331,7332,7333,7334,7332,7334,7335,7336,7337,7338,7336,7338,7339,7340,7341,7342,7340,7342,7343,7344,7345,7346,7344,7346,7347,7348,7349,7350,7348,7350,7351,7352,7353,7354,7352,7354,7355,7356,7357,7358,7356,7358,7359,7360,7361,7362,7360,7362,7363,7364,7365,7366,7364,7366,7367,7368,7369,7370,7371,7372,7373,7374,7375,7376,7377,7378,7379,7380,7381,7382,7380,7382,7383,7384,7385,7386,7384,7386,7387,7388,7389,7390,7388,7390,7391,7392,7393,7394,7395,7396,7397,7398,7399,7400,7401,7402,7403,7404,7405,7406,7404,7406,7407,7408,7409,7410,7411,7412,7413,7414,7415,7416,7414,7416,7417,7418,7419,7420,7418,7420,7421,7422,7423,7424,7422,7424,7425,7426,7427,7428,7429,7430,7431,7432,7433,7434,7432,7434,7435,7436,7437,7438,7439,7440,7441,7442,7443,7444,7442,7444,7445,7446,7447,7448,7446,7448,7449,7450,7451,7452,7450,7452,7453,7454,7455,7456,7457,7458,7459,7460,7461,7462,7463,7464,7465,7466,7467,7468,7469,7470,7471,7472,7473,7474,7475,7476,7477,7478,7479,7480,7478,7480,7481,7482,7483,7484,7482,7484,7485,7486,7487,7488,7486,7488,7489,7490,7491,7492,7490,7492,7493,7494,7495,7496,7494,7496,7497,7498,7499,7500,7498,7500,7501,7502,7503,7504,7502,7504,7505,7506,7507,7508,7506,7508,7509,7510,7511,7512,7510,7512,7513,7514,7515,7516,7514,7516,7517,7518,7519,7520,7518,7520,7521,7522,7523,7524,7522,7524,7525,7526,7527,7528,7526,7528,7529,7530,7531,7532,7530,7532,7533,7534,7535,7536,7534,7536,7537,7538,7539,7540,7538,7540,7541,7542,7543,7544,7545,7546,7547,7548,7549,7550,7548,7550,7551,7552,7553,7554,7552,7554,7555,7556,7557,7558,7556,7558,7559,7560,7561,7562,7560,7562,7563,7564,7565,7566,7564,7566,7567,7568,7569,7570,7571,7572,7573,7574,7575,7576,7577,7578,7579,7580,7581,7582,7580,7582,7583,7584,7585,7586,7584,7586,7587,7588,7589,7590,7588,7590,7591,7592,7593,7594,7592,7594,7595,7596,7597,7598,7596,7598,7599,7600,7601,7602,7600,7602,7603,7604,7605,7606,7604,7606,7607,7608,7609,7610,7608,7610,7611,7612,7613,7614,7612,7614,7615,7616,7617,7618,7616,7618,7619,7620,7621,7622,7620,7622,7623,7624,7625,7626,7624,7626,7627,7628,7629,7630,7628,7630,7631,7632,7633,7634,7632,7634,7635,7636,7637,7638,7636,7638,7639,7640,7641,7642,7640,7642,7643,7644,7645,7646,7644,7646,7647,7648,7649,7650,7648,7650,7651,7652,7653,7654,7652,7654,7655,7656,7657,7658,7656,7658,7659,7660,7661,7662,7660,7662,7663,7664,7665,7666,7664,7666,7667,7668,7669,7670,7668,7670,7671,7672,7673,7674,7672,7674,7675,7676,7677,7678,7679,7680,7681,7682,7683,7684,7682,7684,7685,7686,7687,7688,7686,7688,7689,7690,7691,7692,7690,7692,7693,7694,7695,7696,7694,7696,7697,7698,7699,7700,7698,7700,7701,7702,7703,7704,7702,7704,7705,7706,7707,7708,7706,7708,7709,7710,7711,7712,7710,7712,7713,7714,7715,7716,7717,7718,7719,7720,7721,7722,7723,7724,7725,7726,7727,7728,7726,7728,7729,7730,7731,7732,7733,7734,7735,7736,7737,7738,7736,7738,7739,7740,7741,7742,7740,7742,7743,7744,7745,7746,7744,7746,7747,7748,7749,7750,7751,7752,7753,7754,7755,7756,7754,7756,7757,7758,7759,7760,7758,7760,7761,7762,7763,7764,7762,7764,7765,7766,7767,7768,7766,7768,7769,7770,7771,7772,7770,7772,7773,7774,7775,7776,7774,7776,7777,7778,7779,7780,7778,7780,7781,7782,7783,7784,7782,7784,7785,7786,7787,7788,7786,7788,7789,7790,7791,7792,7790,7792,7793,7794,7795,7796,7794,7796,7797,7798,7799,7800,7801,7802,7803,7804,7805,7806,7804,7806,7807,7808,7809,7810,7811,7812,7813,7814,7815,7816,7814,7816,7817,7818,7819,7820,7821,7822,7823,7824,7825,7826,7824,7826,7827,7828,7829,7830,7828,7830,7831,7832,7833,7834,7832,7834,7835,7836,7837,7838,7836,7838,7839,7840,7841,7842,7843,7844,7845,7846,7847,7848,7849,7850,7851,7852,7853,7854,7852,7854,7855,7856,7857,7858,7859,7860,7861,7862,7863,7864,7865,7866,7867,7868,7869,7870,7868,7870,7871,7872,7873,7874,7872,7874,7875,7876,7877,7878,7876,7878,7879,7880,7881,7882,7883,7884,7885,7886,7887,7888,7886,7888,7889,7890,7891,7892,7890,7892,7893,7894,7895,7896,7894,7896,7897,7898,7899,7900,7898,7900,7901,7902,7903,7904,7902,7904,7905,7906,7907,7908,7906,7908,7909,7910,7911,7912,7910,7912,7913,7914,7915,7916,7914,7916,7917,7918,7919,7920,7918,7920,7921,7922,7923,7924,7922,7924,7925,7926,7927,7928,7929,7930,7931,7932,7933,7934,7932,7934,7935,7936,7937,7938,7939,7940,7941,7942,7943,7944,7942,7944,7945,7946,7947,7948,7946,7948,7949,7950,7951,7952,7953,7954,7955,7956,7957,7958,7956,7958,7959,7960,7961,7962,7960,7962,7963,7964,7965,7966,7964,7966,7967,7968,7969,7970,7968,7970,7971,7972,7973,7974,7972,7974,7975,7976,7977,7978,7976,7978,7979,7980,7981,7982,7980,7982,7983,7984,7985,7986,7987,7988,7989,7990,7991,7992,7993,7994,7995,7996,7997,7998,7996,7998,7999,8000,8001,8002,8003,8004,8005,8006,8007,8008,8006,8008,8009,8010,8011,8012,8010,8012,8013,8014,8015,8016,8014,8016,8017,8018,8019,8020,8018,8020,8021,8022,8023,8024,8022,8024,8025,8026,8027,8028,8026,8028,8029,8030,8031,8032,8030,8032,8033,8034,8035,8036,8034,8036,8037,8038,8039,8040,8038,8040,8041,8042,8043,8044,8042,8044,8045,8046,8047,8048,8046,8048,8049,8050,8051,8052,8050,8052,8053,8054,8055,8056,8057,8058,8059,8060,8061,8062,8063,8064,8065,8066,8067,8068,8066,8068,8069,8070,8071,8072,8070,8072,8073,8074,8075,8076,8074,8076,8077,8078,8079,8080,8078,8080,8081,8082,8083,8084,8082,8084,8085,8086,8087,8088,8089,8090,8091,8092,8093,8094,8092,8094,8095,8096,8097,8098,8099,8100,8101,8102,8103,8104,8102,8104,8105,8106,8107,8108,8106,8108,8109,8110,8111,8112,8110,8112,8113,8114,8115,8116,8114,8116,8117,8118,8119,8120,8118,8120,8121,8122,8123,8124,8125,8126,8127,8128,8129,8130,8131,8132,8133,8134,8135,8136,8134,8136,8137,8138,8139,8140,8138,8140,8141,8142,8143,8144,8145,8146,8147,8148,8149,8150,8151,8152,8153,8154,8155,8156,8157,8158,8159,8160,8161,8162,8163,8164,8165,8166,8167,8168,8169,8170,8171,8172,8173,8174,8175,8176,8177,8178,8179,8180,8178,8180,8181,8182,8183,8184,8182,8184,8185,8186,8187,8188,8186,8188,8189,8190,8191,8192,8190,8192,8193,8194,8195,8196,8194,8196,8197,8198,8199,8200,8201,8202,8203,8204,8205,8206,8207,8208,8209,8210,8211,8212,8213,8214,8215,8216,8217,8218,8216,8218,8219,8220,8221,8222,8223,8224,8225,8226,8227,8228,8226,8228,8229,8230,8231,8232,8230,8232,8233,8234,8235,8236,8237,8238,8239,8240,8241,8242,8240,8242,8243,8244,8245,8246,8244,8246,8247,8248,8249,8250,8251,8252,8253,8254,8255,8256,8257,8258,8259,8260,8261,8262,8263,8264,8265,8266,8267,8268,8266,8268,8269,8270,8271,8272,8270,8272,8273,8274,8275,8276,8277,8278,8279,8280,8281,8282,8280,8282,8283,8284,8285,8286,8284,8286,8287,8288,8289,8290,8291,8292,8293,8294,8295,8296,8294,8296,8297,8298,8299,8300,8298,8300,8301,8302,8303,8304,8305,8306,8307,8308,8309,8310,8311,8312,8313,8314,8315,8316,8317,8318,8319,8320,8321,8322,8323,8324,8325,8326,8327,8328,8329,8330,8331,8332,8333,8334,8332,8334,8335,8336,8337,8338,8336,8338,8339,8340,8341,8342,8340,8342,8343,8344,8345,8346,8344,8346,8347,8348,8349,8350,8348,8350,8351,8352,8353,8354,8352,8354,8355,8356,8357,8358,8356,8358,8359,8360,8361,8362,8360,8362,8363,8364,8365,8366,8364,8366,8367,8368,8369,8370,8368,8370,8371,8372,8373,8374,8372,8374,8375,8376,8377,8378,8376,8378,8379,8380,8381,8382,8380,8382,8383,8384,8385,8386,8384,8386,8387,8388,8389,8390,8388,8390,8391,8392,8393,8394,8395,8396,8397,8398,8399,8400,8398,8400,8401,8402,8403,8404,8405,8406,8407,8408,8409,8410,8408,8410,8411,8412,8413,8414,8412,8414,8415,8416,8417,8418,8416,8418,8419,8420,8421,8422,8420,8422,8423,8424,8425,8426,8424,8426,8427,8428,8429,8430,8428,8430,8431,8432,8433,8434,8435,8436,8437,8438,8439,8440,8438,8440,8441,8442,8443,8444,8442,8444,8445,8446,8447,8448,8446,8448,8449,8450,8451,8452,8453,8454,8455,8456,8457,8458,8459,8460,8461,8462,8463,8464,8462,8464,8465,8466,8467,8468,8466,8468,8469,8470,8471,8472,8473,8474,8475,8476,8477,8478,8476,8478,8479,8480,8481,8482,8480,8482,8483,8484,8485,8486,8484,8486,8487,8488,8489,8490,8488,8490,8491,8492,8493,8494,8492,8494,8495,8496,8497,8498,8496,8498,8499,8500,8501,8502,8500,8502,8503,8504,8505,8506,8504,8506,8507,8508,8509,8510,8508,8510,8511,8512,8513,8514,8512,8514,8515,8516,8517,8518,8519,8520,8521,8522,8523,8524,8522,8524,8525,8526,8527,8528,8529,8530,8531,8532,8533,8534,8532,8534,8535,8536,8537,8538,8536,8538,8539,8540,8541,8542,8543,8544,8545,8546,8547,8548,8546,8548,8549,8550,8551,8552,8550,8552,8553,8554,8555,8556,8554,8556,8557,8558,8559,8560,8558,8560,8561,8562,8563,8564,8562,8564,8565,8566,8567,8568,8566,8568,8569,8570,8571,8572,8570,8572,8573,8574,8575,8576,8574,8576,8577,8578,8579,8580,8581,8582,8583,8584,8585,8586,8587,8588,8589,8590,8591,8592,8593,8594,8595,8596,8597,8598,8596,8598,8599,8600,8601,8602,8603,8604,8605,8606,8607,8608,8609,8610,8611,8612,8613,8614,8612,8614,8615,8616,8617,8618,8619,8620,8621,8622,8623,8624,8622,8624,8625,8626,8627,8628,8626,8628,8629,8630,8631,8632,8630,8632,8633,8634,8635,8636,8634,8636,8637,8638,8639,8640,8638,8640,8641,8642,8643,8644,8642,8644,8645,8646,8647,8648,8646,8648,8649,8650,8651,8652,8653,8654,8655,8656,8657,8658,8659,8660,8661,8662,8663,8664,8662,8664,8665,8666,8667,8668,8666,8668,8669,8670,8671,8672,8670,8672,8673,8674,8675,8676,8674,8676,8677,8678,8679,8680,8678,8680,8681,8682,8683,8684,8682,8684,8685,8686,8687,8688,8689,8690,8691,8692,8693,8694,8695,8696,8697,8698,8699,8700,8698,8700,8701,8702,8703,8704,8702,8704,8705,8706,8707,8708,8706,8708,8709,8710,8711,8712,8710,8712,8713,8714,8715,8716,8714,8716,8717,8718,8719,8720,8718,8720,8721,8722,8723,8724,8722,8724,8725,8726,8727,8728,8729,8730,8731,8732,8733,8734,8732,8734,8735,8736,8737,8738,8739,8740,8741,8742,8743,8744,8742,8744,8745,8746,8747,8748,8746,8748,8749,8750,8751,8752,8750,8752,8753,8754,8755,8756,8754,8756,8757,8758,8759,8760,8761,8762,8763,8764,8765,8766,8764,8766,8767,8768,8769,8770,8768,8770,8771,8772,8773,8774,8772,8774,8775,8776,8777,8778,8776,8778,8779,8780,8781,8782,8780,8782,8783,8784,8785,8786,8787,8788,8789,8790,8791,8792,8793,8794,8795,8796,8797,8798,8799,8800,8801,8802,8803,8804,8802,8804,8805,8806,8807,8808,8809,8810,8811,8812,8813,8814,8812,8814,8815,8816,8817,8818,8816,8818,8819,8820,8821,8822,8823,8824,8825,8826,8827,8828,8826,8828,8829,8830,8831,8832,8830,8832,8833,8834,8835,8836,8834,8836,8837,8838,8839,8840,8838,8840,8841,8842,8843,8844,8845,8846,8847,8848,8849,8850,8848,8850,8851,8852,8853,8854,8852,8854,8855,8856,8857,8858,8856,8858,8859,8860,8861,8862,8860,8862,8863,8864,8865,8866,8864,8866,8867,8868,8869,8870,8868,8870,8871,8872,8873,8874,8875,8876,8877,8878,8879,8880,8881,8882,8883,8884,8885,8886,8887,8888,8889,8890,8891,8892,8890,8892,8893,8894,8895,8896,8897,8898,8899,8900,8901,8902,8900,8902,8903,8904,8905,8906,8904,8906,8907,8908,8909,8910,8911,8912,8913,8914,8915,8916,8914,8916,8917,8918,8919,8920,8918,8920,8921,8922,8923,8924,8922,8924,8925,8926,8927,8928,8926,8928,8929,8930,8931,8932,8930,8932,8933,8934,8935,8936,8934,8936,8937,8938,8939,8940,8938,8940,8941,8942,8943,8944,8942,8944,8945,8946,8947,8948,8946,8948,8949,8950,8951,8952,8950,8952,8953,8954,8955,8956,8954,8956,8957,8958,8959,8960,8958,8960,8961,8962,8963,8964,8962,8964,8965,8966,8967,8968,8966,8968,8969,8970,8971,8972,8973,8974,8975,8976,8977,8978,8976,8978,8979,8980,8981,8982,8983,8984,8985,8986,8987,8988,8989,8990,8991,8992,8993,8994,8995,8996,8997,8998,8999,9000,8998,9000,9001,9002,9003,9004,9002,9004,9005,9006,9007,9008,9006,9008,9009,9010,9011,9012,9010,9012,9013,9014,9015,9016,9014,9016,9017,9018,9019,9020,9021,9022,9023,9024,9025,9026,9024,9026,9027,9028,9029,9030,9031,9032,9033,9034,9035,9036,9034,9036,9037,9038,9039,9040,9041,9042,9043,9044,9045,9046,9047,9048,9049,9050,9051,9052,9053,9054,9055,9056,9057,9058,9059,9060,9061,9062,9063,9064,9062,9064,9065,9066,9067,9068,9066,9068,9069,9070,9071,9072,9070,9072,9073,9074,9075,9076,9074,9076,9077,9078,9079,9080,9078,9080,9081,9082,9083,9084,9085,9086,9087,9088,9089,9090,9088,9090,9091,9092,9093,9094,9092,9094,9095,9096,9097,9098,9096,9098,9099,9100,9101,9102,9100,9102,9103,9104,9105,9106,9107,9108,9109,9110,9111,9112,9110,9112,9113,9114,9115,9116,9117,9118,9119,9120,9121,9122,9120,9122,9123,9124,9125,9126,9124,9126,9127,9128,9129,9130,9131,9132,9133,9134,9135,9136,9134,9136,9137,9138,9139,9140,9138,9140,9141,9142,9143,9144,9142,9144,9145,9146,9147,9148,9146,9148,9149,9150,9151,9152,9150,9152,9153,9154,9155,9156,9154,9156,9157,9158,9159,9160,9158,9160,9161,9162,9163,9164,9165,9166,9167,9168,9169,9170,9168,9170,9171,9172,9173,9174,9172,9174,9175,9176,9177,9178,9176,9178,9179,9180,9181,9182,9180,9182,9183,9184,9185,9186,9187,9188,9189,9190,9191,9192,9193,9194,9195,9196,9197,9198,9199,9200,9201,9202,9203,9204,9205,9206,9207,9208,9209,9210,9208,9210,9211,9212,9213,9214,9212,9214,9215,9216,9217,9218,9216,9218,9219,9220,9221,9222,9220,9222,9223,9224,9225,9226,9224,9226,9227,9228,9229,9230,9228,9230,9231,9232,9233,9234,9232,9234,9235,9236,9237,9238,9236,9238,9239,9240,9241,9242,9243,9244,9245,9246,9247,9248,9249,9250,9251,9252,9253,9254,9255,9256,9257,9258,9259,9260,9258,9260,9261,9262,9263,9264,9262,9264,9265,9266,9267,9268,9266,9268,9269,9270,9271,9272,9270,9272,9273,9274,9275,9276,9274,9276,9277,9278,9279,9280,9278,9280,9281,9282,9283,9284,9282,9284,9285,9286,9287,9288,9286,9288,9289,9290,9291,9292,9293,9294,9295,9296,9297,9298,9296,9298,9299,9300,9301,9302,9303,9304,9305,9306,9307,9308,9306,9308,9309,9310,9311,9312,9310,9312,9313,9314,9315,9316,9314,9316,9317,9318,9319,9320,9318,9320,9321,9322,9323,9324,9322,9324,9325,9326,9327,9328,9326,9328,9329,9330,9331,9332,9330,9332,9333,9334,9335,9336,9337,9338,9339,9340,9341,9342,9340,9342,9343,9344,9345,9346,9344,9346,9347,9348,9349,9350,9348,9350,9351,9352,9353,9354,9352,9354,9355,9356,9357,9358,9356,9358,9359,9360,9361,9362,9360,9362,9363,9364,9365,9366,9364,9366,9367,9368,9369,9370,9368,9370,9371,9372,9373,9374,9375,9376,9377,9378,9379,9380,9378,9380,9381,9382,9383,9384,9382,9384,9385,9386,9387,9388,9386,9388,9389,9390,9391,9392,9393,9394,9395,9396,9397,9398,9396,9398,9399,9400,9401,9402,9400,9402,9403,9404,9405,9406,9404,9406,9407,9408,9409,9410,9408,9410,9411,9412,9413,9414,9412,9414,9415,9416,9417,9418,9416,9418,9419,9420,9421,9422,9420,9422,9423,9424,9425,9426,9424,9426,9427,9428,9429,9430,9428,9430,9431,9432,9433,9434,9432,9434,9435,9436,9437,9438,9439,9440,9441,9442,9443,9444,9445,9446,9447,9448,9449,9450,9448,9450,9451,9452,9453,9454,9452,9454,9455,9456,9457,9458,9456,9458,9459,9460,9461,9462,9463,9464,9465,9466,9467,9468,9469,9470,9471,9472,9473,9474,9475,9476,9477,9478,9479,9480,9481,9482,9483,9484,9485,9486,9484,9486,9487,9488,9489,9490,9488,9490,9491,9492,9493,9494,9492,9494,9495,9496,9497,9498,9496,9498,9499,9500,9501,9502,9500,9502,9503,9504,9505,9506,9504,9506,9507,9508,9509,9510,9508,9510,9511,9512,9513,9514,9515,9516,9517,9518,9519,9520,9518,9520,9521,9522,9523,9524,9522,9524,9525,9526,9527,9528,9526,9528,9529,9530,9531,9532,9530,9532,9533,9534,9535,9536,9537,9538,9539,9540,9541,9542,9540,9542,9543,9544,9545,9546,9547,9548,9549,9550,9551,9552,9550,9552,9553,9554,9555,9556,9557,9558,9559,9560,9561,9562,9563,9564,9565,9566,9567,9568,9566,9568,9569,9570,9571,9572,9570,9572,9573,9574,9575,9576,9574,9576,9577,9578,9579,9580,9578,9580,9581,9582,9583,9584,9582,9584,9585,9586,9587,9588,9586,9588,9589,9590,9591,9592,9593,9594,9595,9596,9597,9598,9599,9600,9601,9602,9603,9604,9602,9604,9605,9606,9607,9608,9606,9608,9609,9610,9611,9612,9610,9612,9613,9614,9615,9616,9614,9616,9617,9618,9619,9620,9618,9620,9621,9622,9623,9624,9625,9626,9627,9628,9629,9630,9631,9632,9633,9634,9635,9636,9634,9636,9637,9638,9639,9640,9638,9640,9641,9642,9643,9644,9642,9644,9645,9646,9647,9648,9646,9648,9649,9650,9651,9652,9650,9652,9653,9654,9655,9656,9654,9656,9657,9658,9659,9660,9661,9662,9663,9664,9665,9666,9667,9668,9669,9670,9671,9672,9673,9674,9675,9676,9677,9678,9679,9680,9681,9682,9683,9684,9685,9686,9687,9688,9689,9690,9688,9690,9691,9692,9693,9694,9692,9694,9695,9696,9697,9698,9696,9698,9699,9700,9701,9702,9700,9702,9703,9704,9705,9706,9704,9706,9707,9708,9709,9710,9708,9710,9711,9712,9713,9714,9712,9714,9715,9716,9717,9718,9716,9718,9719,9720,9721,9722,9720,9722,9723,9724,9725,9726,9724,9726,9727,9728,9729,9730,9731,9732,9733,9734,9735,9736,9734,9736,9737,9738,9739,9740,9738,9740,9741,9742,9743,9744,9745,9746,9747,9748,9749,9750,9748,9750,9751,9752,9753,9754,9755,9756,9757,9758,9759,9760,9758,9760,9761,9762,9763,9764,9762,9764,9765,9766,9767,9768,9766,9768,9769,9770,9771,9772,9773,9774,9775,9776,9777,9778,9776,9778,9779,9780,9781,9782,9783,9784,9785,9786,9787,9788,9786,9788,9789,9790,9791,9792,9790,9792,9793,9794,9795,9796,9794,9796,9797,9798,9799,9800,9798,9800,9801,9802,9803,9804,9802,9804,9805,9806,9807,9808,9806,9808,9809,9810,9811,9812,9813,9814,9815,9816,9817,9818,9819,9820,9821,9822,9823,9824,9822,9824,9825,9826,9827,9828,9829,9830,9831,9832,9833,9834,9832,9834,9835,9836,9837,9838,9836,9838,9839,9840,9841,9842,9843,9844,9845,9846,9847,9848,9849,9850,9851,9852,9853,9854,9852,9854,9855,9856,9857,9858,9856,9858,9859,9860,9861,9862,9863,9864,9865,9866,9867,9868,9869,9870,9871,9872,9873,9874,9875,9876,9877,9878,9879,9880,9878,9880,9881,9882,9883,9884,9882,9884,9885,9886,9887,9888,9886,9888,9889,9890,9891,9892,9893,9894,9895,9896,9897,9898,9896,9898,9899,9900,9901,9902,9900,9902,9903,9904,9905,9906,9904,9906,9907,9908,9909,9910,9908,9910,9911,9912,9913,9914,9912,9914,9915,9916,9917,9918,9916,9918,9919,9920,9921,9922,9920,9922,9923,9924,9925,9926,9924,9926,9927,9928,9929,9930,9931,9932,9933,9934,9935,9936,9937,9938,9939,9940,9941,9942,9943,9944,9945,9946,9947,9948,9946,9948,9949,9950,9951,9952,9950,9952,9953,9954,9955,9956,9954,9956,9957,9958,9959,9960,9958,9960,9961,9962,9963,9964,9962,9964,9965,9966,9967,9968,9966,9968,9969,9970,9971,9972,9970,9972,9973,9974,9975,9976,9974,9976,9977,9978,9979,9980,9981,9982,9983,9984,9985,9986,9987,9988,9989,9990,9991,9992,9993,9994,9995,9996,9997,9998,9996,9998,9999,10000,10001,10002,10003,10004,10005,10006,10007,10008,10009,10010,10011,10012,10013,10014,10012,10014,10015,10016,10017,10018,10016,10018,10019,10020,10021,10022,10020,10022,10023,10024,10025,10026,10024,10026,10027,10028,10029,10030,10028,10030,10031,10032,10033,10034,10032,10034,10035,10036,10037,10038,10039,10040,10041,10042,10043,10044,10042,10044,10045,10046,10047,10048,10046,10048,10049,10050,10051,10052,10050,10052,10053,10054,10055,10056,10057,10058,10059,10060,10061,10062,10060,10062,10063,10064,10065,10066,10067,10068,10069,10070,10071,10072,10070,10072,10073,10074,10075,10076,10077,10078,10079,10080,10081,10082,10083,10084,10085,10086,10087,10088,10089,10090,10091,10092,10093,10094,10092,10094,10095,10096,10097,10098,10096,10098,10099,10100,10101,10102,10100,10102,10103,10104,10105,10106,10104,10106,10107,10108,10109,10110,10111,10112,10113,10114,10115,10116,10114,10116,10117,10118,10119,10120,10121,10122,10123,10124,10125,10126,10127,10128,10129,10130,10131,10132,10133,10134,10135,10136,10137,10138,10136,10138,10139,10140,10141,10142,10143,10144,10145,10146,10147,10148,10149,10150,10151,10152,10153,10154,10152,10154,10155,10156,10157,10158,10156,10158,10159,10160,10161,10162,10160,10162,10163,10164,10165,10166,10164,10166,10167,10168,10169,10170,10168,10170,10171,10172,10173,10174,10172,10174,10175,10176,10177,10178,10176,10178,10179,10180,10181,10182,10180,10182,10183,10184,10185,10186,10184,10186,10187,10188,10189,10190,10188,10190,10191,10192,10193,10194,10192,10194,10195,10196,10197,10198,10196,10198,10199,10200,10201,10202,10200,10202,10203,10204,10205,10206,10204,10206,10207,10208,10209,10210,10211,10212,10213,10214,10215,10216,10217,10218,10219,10220,10221,10222,10220,10222,10223,10224,10225,10226,10227,10228,10229,10230,10231,10232,10233,10234,10235,10236,10237,10238,10239,10240,10241,10242,10243,10244,10242,10244,10245,10246,10247,10248,10249,10250,10251,10252,10253,10254,10252,10254,10255,10256,10257,10258,10256,10258,10259,10260,10261,10262,10263,10264,10265,10266,10267,10268,10269,10270,10271,10272,10273,10274,10275,10276,10277,10278,10279,10280,10281,10282,10283,10284,10285,10286,10287,10288,10289,10290,10291,10292,10290,10292,10293,10294,10295,10296,10294,10296,10297,10298,10299,10300,10298,10300,10301,10302,10303,10304,10302,10304,10305,10306,10307,10308,10309,10310,10311,10312,10313,10314,10315,10316,10317,10318,10319,10320,10321,10322,10323,10324,10325,10326,10324,10326,10327,10328,10329,10330,10328,10330,10331,10332,10333,10334,10332,10334,10335,10336,10337,10338,10339,10340,10341,10342,10343,10344,10342,10344,10345,10346,10347,10348,10349,10350,10351,10352,10353,10354,10352,10354,10355,10356,10357,10358,10356,10358,10359,10360,10361,10362,10360,10362,10363,10364,10365,10366,10364,10366,10367,10368,10369,10370,10368,10370,10371,10372,10373,10374,10372,10374,10375,10376,10377,10378,10376,10378,10379,10380,10381,10382,10383,10384,10385,10386,10387,10388,10389,10390,10391,10392,10393,10394,10395,10396,10397,10398,10399,10400,10398,10400,10401,10402,10403,10404,10405,10406,10407,10408,10409,10410,10408,10410,10411,10412,10413,10414,10412,10414,10415,10416,10417,10418,10419,10420,10421,10422,10423,10424,10425,10426,10427,10428,10429,10430,10431,10432,10433,10434,10435,10436,10437,10438,10439,10440,10441,10442,10443,10444,10445,10446,10447,10448,10446,10448,10449,10450,10451,10452,10450,10452,10453,10454,10455,10456,10457,10458,10459,10460,10461,10462,10463,10464,10465,10466,10467,10468,10466,10468,10469,10470,10471,10472,10470,10472,10473,10474,10475,10476,10474,10476,10477,10478,10479,10480,10481,10482,10483,10484,10485,10486,10484,10486,10487,10488,10489,10490,10488,10490,10491,10492,10493,10494,10492,10494,10495,10496,10497,10498,10499,10500,10501,10502,10503,10504,10505,10506,10507,10508,10509,10510,10511,10512,10513,10514,10515,10516,10514,10516,10517,10518,10519,10520,10518,10520,10521,10522,10523,10524,10522,10524,10525,10526,10527,10528,10526,10528,10529,10530,10531,10532,10530,10532,10533,10534,10535,10536,10537,10538,10539,10540,10541,10542,10540,10542,10543,10544,10545,10546,10547,10548,10549,10550,10551,10552,10550,10552,10553,10554,10555,10556,10554,10556,10557,10558,10559,10560,10558,10560,10561,10562,10563,10564,10562,10564,10565,10566,10567,10568,10569,10570,10571,10572,10573,10574,10575,10576,10577,10578,10579,10580,10578,10580,10581,10582,10583,10584,10585,10586,10587,10588,10589,10590,10591,10592,10593,10594,10595,10596,10597,10598,10599,10600,10601,10602,10600,10602,10603,10604,10605,10606,10604,10606,10607,10608,10609,10610,10611,10612,10613,10614,10615,10616,10617,10618,10619,10620,10621,10622,10623,10624,10625,10626,10627,10628,10626,10628,10629,10630,10631,10632,10633,10634,10635,10636,10637,10638,10636,10638,10639,10640,10641,10642,10643,10644,10645,10646,10647,10648,10646,10648,10649,10650,10651,10652,10650,10652,10653,10654,10655,10656,10654,10656,10657,10658,10659,10660,10658,10660,10661,10662,10663,10664,10662,10664,10665,10666,10667,10668,10669,10670,10671,10672,10673,10674,10672,10674,10675,10676,10677,10678,10679,10680,10681,10682,10683,10684,10682,10684,10685,10686,10687,10688,10686,10688,10689,10690,10691,10692,10690,10692,10693,10694,10695,10696,10694,10696,10697,10698,10699,10700,10698,10700,10701,10702,10703,10704,10702,10704,10705,10706,10707,10708,10709,10710,10711,10712,10713,10714,10712,10714,10715,10716,10717,10718,10716,10718,10719,10720,10721,10722,10723,10724,10725,10726,10727,10728,10729,10730,10731,10732,10733,10734,10735,10736,10737,10738,10739,10740,10741,10742,10743,10744,10745,10746,10747,10748,10749,10750,10751,10752,10753,10754,10755,10756,10757,10758,10759,10760,10761,10762,10763,10764,10762,10764,10765,10766,10767,10768,10766,10768,10769,10770,10771,10772,10770,10772,10773,10774,10775,10776,10777,10778,10779,10780,10781,10782,10783,10784,10785,10786,10787,10788,10789,10790,10791,10792,10793,10794,10792,10794,10795,10796,10797,10798,10799,10800,10801,10802,10803,10804,10802,10804,10805,10806,10807,10808,10806,10808,10809,10810,10811,10812,10813,10814,10815,10816,10817,10818,10816,10818,10819,10820,10821,10822,10820,10822,10823,10824,10825,10826,10824,10826,10827,10828,10829,10830,10828,10830,10831,10832,10833,10834,10835,10836,10837,10838,10839,10840,10838,10840,10841,10842,10843,10844,10845,10846,10847,10848,10849,10850,10848,10850,10851,10852,10853,10854,10852,10854,10855,10856,10857,10858,10856,10858,10859,10860,10861,10862,10863,10864,10865,10866,10867,10868,10869,10870,10871,10872,10873,10874,10872,10874,10875,10876,10877,10878,10876,10878,10879,10880,10881,10882,10880,10882,10883,10884,10885,10886,10887,10888,10889,10890,10891,10892,10893,10894,10895,10896,10897,10898,10896,10898,10899,10900,10901,10902,10900,10902,10903,10904,10905,10906,10904,10906,10907,10908,10909,10910,10911,10912,10913,10914,10915,10916,10914,10916,10917,10918,10919,10920,10921,10922,10923,10924,10925,10926,10927,10928,10929,10930,10931,10932,10930,10932,10933,10934,10935,10936,10937,10938,10939,10940,10941,10942,10943,10944,10945,10946,10947,10948,10946,10948,10949,10950,10951,10952,10950,10952,10953,10954,10955,10956,10954,10956,10957,10958,10959,10960,10961,10962,10963,10964,10965,10966,10967,10968,10969,10970,10971,10972,10973,10974,10975,10976,10977,10978,10979,10980,10981,10982,10983,10984,10982,10984,10985,10986,10987,10988,10986,10988,10989,10990,10991,10992,10990,10992,10993,10994,10995,10996,10994,10996,10997,10998,10999,11000,10998,11000,11001,11002,11003,11004,11002,11004,11005,11006,11007,11008,11009,11010,11011,11012,11013,11014,11015,11016,11017,11018,11019,11020,11018,11020,11021,11022,11023,11024,11025,11026,11027,11028,11029,11030,11028,11030,11031,11032,11033,11034,11032,11034,11035,11036,11037,11038,11036,11038,11039,11040,11041,11042,11040,11042,11043,11044,11045,11046,11047,11048,11049,11050,11051,11052,11050,11052,11053,11054,11055,11056,11054,11056,11057,11058,11059,11060,11058,11060,11061,11062,11063,11064,11065,11066,11067,11068,11069,11070,11071,11072,11073,11074,11075,11076,11077,11078,11079,11080,11081,11082,11083,11081,11080,11084,11081,11083,11085,11086,11087,11085,11088,11086,11085,11089,11088,11085,11090,11089,11085,11091,11090,11085,11092,11091,11085,11093,11092,11085,11094,11093,11095,11094,11085,11085,11096,11095,11085,11097,11096,11085,11098,11097,11085,11099,11098,11100,11101,11102,11100,11103,11101,11104,11105,11106,11085,11107,11108,11109,11110,11084,11111,11112,11113,11114,11115,11116,11114,11117,11115,11118,11117,11114,11118,11119,11117,11120,11121,11122,11123,11121,11120,11124,11121,11123,11125,11121,11124,11126,11121,11125,11127,11121,11126,11128,11121,11127,11128,11129,11121,11130,11129,11128,11131,11129,11130,11132,11129,11131,11133,11129,11132,11134,11129,11133,11135,11129,11134,11136,11129,11135,11137,11129,11136,11138,11129,11137,11139,11129,11138,11140,11129,11139,11141,11129,11140,11142,11129,11141,11143,11129,11142,11144,11129,11143,11145,11129,11144,11146,11129,11145,11146,11147,11129,11146,11148,11147,11149,11148,11146,11149,11150,11148,11151,11150,11149,11152,11153,11154,11152,11155,11153,11152,11156,11155,11152,11157,11156,11152,11158,11157,11152,11159,11158,11160,11159,11152,11160,11161,11159,11162,11161,11160,11163,11161,11162,11164,11161,11163,11165,11161,11164,11166,11161,11165,11167,11161,11166,11168,11161,11167,11169,11161,11168,11170,11161,11169,11171,11161,11170,11172,11161,11171,11173,11161,11172,11174,11161,11173,11175,11161,11174,11176,11161,11175,11177,11161,11176,11178,11161,11177,11178,11179,11161,11180,11179,11178,11180,11181,11179,11180,11182,11181,11183,11182,11180,11184,11185,11186,11184,11187,11185,11184,11188,11187,11184,11189,11188,11184,11190,11189,11184,11191,11190,11192,11191,11184,11192,11193,11191,11194,11193,11192,11195,11193,11194,11196,11193,11195,11197,11193,11196,11198,11193,11197,11199,11193,11198,11200,11193,11199,11201,11193,11200,11202,11193,11201,11203,11193,11202,11204,11193,11203,11205,11193,11204,11206,11193,11205,11207,11193,11206,11208,11193,11207,11209,11193,11208,11210,11193,11209,11210,11211,11193,11210,11212,11211,11213,11212,11210,11213,11214,11212,11215,11214,11213,11216,11217,11218,11219,11217,11216,11220,11217,11219,11221,11217,11220,11222,11217,11221,11223,11217,11222,11224,11217,11223,11224,11225,11217,11226,11225,11224,11227,11225,11226,11228,11225,11227,11229,11225,11228,11230,11225,11229,11231,11225,11230,11232,11225,11231,11233,11225,11232,11234,11225,11233,11235,11225,11234,11236,11225,11235,11237,11225,11236,11238,11225,11237,11239,11225,11238,11240,11225,11239,11241,11225,11240,11242,11225,11241,11242,11243,11225,11242,11244,11243,11245,11244,11242,11246,11244,11245,11246,11247,11244,11248,11249,11250,11251,11249,11248,11252,11249,11251,11253,11249,11252,11254,11249,11253,11255,11249,11254,11256,11249,11255,11256,11257,11249,11258,11257,11256,11259,11257,11258,11260,11257,11259,11261,11257,11260,11262,11257,11261,11263,11257,11262,11264,11257,11263,11265,11257,11264,11266,11257,11265,11267,11257,11266,11268,11257,11267,11269,11257,11268,11270,11257,11269,11271,11257,11270,11272,11257,11271,11273,11257,11272,11274,11257,11273,11274,11275,11257,11274,11276,11275,11277,11276,11274,11278,11276,11277,11278,11279,11276,11280,11281,11282,11283,11281,11280,11284,11281,11283,11285,11281,11284,11286,11281,11285,11287,11281,11286,11288,11281,11287,11288,11289,11281,11290,11289,11288,11291,11289,11290,11292,11289,11291,11293,11289,11292,11294,11289,11293,11295,11289,11294,11296,11289,11295,11297,11289,11296,11298,11289,11297,11299,11289,11298,11300,11289,11299,11301,11289,11300,11302,11289,11301,11303,11289,11302,11304,11289,11303,11305,11289,11304,11306,11289,11305,11306,11307,11289,11306,11308,11307,11309,11308,11306,11310,11308,11309,11310,11311,11308,11312,11313,11314,11315,11313,11312,11316,11313,11315,11317,11313,11316,11318,11313,11317,11319,11313,11318,11320,11313,11319,11320,11321,11313,11322,11321,11320,11323,11321,11322,11324,11321,11323,11325,11321,11324,11326,11321,11325,11327,11321,11326,11328,11321,11327,11329,11321,11328,11330,11321,11329,11331,11321,11330,11332,11321,11331,11333,11321,11332,11334,11321,11333,11335,11321,11334,11336,11321,11335,11337,11321,11336,11338,11321,11337,11338,11339,11321,11338,11340,11339,11341,11340,11338,11342,11340,11341,11342,11343,11340,11344,11345,11346,11347,11345,11344,11348,11345,11347,11349,11345,11348,11350,11345,11349,11351,11345,11350,11352,11345,11351,11352,11353,11345,11354,11353,11352,11355,11353,11354,11356,11353,11355,11357,11353,11356,11358,11353,11357,11359,11353,11358,11360,11353,11359,11361,11353,11360,11362,11353,11361,11363,11353,11362,11364,11353,11363,11365,11353,11364,11366,11353,11365,11367,11353,11366,11368,11353,11367,11369,11353,11368,11370,11353,11369,11370,11371,11353,11370,11372,11371,11373,11372,11370,11374,11372,11373,11374,11375,11372,11376,11377,11378,11379,11377,11376,11380,11377,11379,11381,11377,11380,11382,11377,11381,11383,11377,11382,11384,11377,11383,11384,11385,11377,11386,11385,11384,11387,11385,11386,11388,11385,11387,11389,11385,11388,11390,11385,11389,11391,11385,11390,11392,11385,11391,11393,11385,11392,11394,11385,11393,11395,11385,11394,11396,11385,11395,11397,11385,11396,11398,11385,11397,11399,11385,11398,11400,11385,11399,11401,11385,11400,11402,11385,11401,11402,11403,11385,11402,11404,11403,11405,11404,11402,11406,11404,11405,11406,11407,11404,11408,11409,11410,11411,11409,11408,11412,11409,11411,11413,11409,11412,11414,11409,11413,11415,11409,11414,11416,11409,11415,11416,11417,11409,11418,11417,11416,11419,11417,11418,11420,11417,11419,11421,11417,11420,11422,11417,11421,11423,11417,11422,11424,11417,11423,11425,11417,11424,11426,11417,11425,11427,11417,11426,11428,11417,11427,11429,11417,11428,11430,11417,11429,11431,11417,11430,11432,11417,11431,11433,11417,11432,11434,11417,11433,11434,11435,11417,11434,11436,11435,11437,11436,11434,11438,11436,11437,11438,11439,11436,11440,11441,11442,11443,11441,11440,11444,11441,11443,11445,11441,11444,11446,11441,11445,11447,11441,11446,11448,11441,11447,11448,11449,11441,11450,11449,11448,11451,11449,11450,11452,11449,11451,11453,11449,11452,11454,11449,11453,11455,11449,11454,11456,11449,11455,11457,11449,11456,11458,11449,11457,11459,11449,11458,11460,11449,11459,11461,11449,11460,11462,11449,11461,11463,11449,11462,11464,11449,11463,11465,11449,11464,11465,11466,11449,11467,11466,11465,11467,11468,11466,11469,11468,11467,11470,11468,11469,11470,11471,11468,11472,11473,11474,11475,11473,11472,11476,11473,11475,11477,11473,11476,11478,11473,11477,11479,11473,11478,11480,11473,11479,11480,11481,11473,11482,11481,11480,11483,11481,11482,11484,11481,11483,11485,11481,11484,11486,11481,11485,11487,11481,11486,11488,11481,11487,11489,11481,11488,11490,11481,11489,11491,11481,11490,11492,11481,11491,11493,11481,11492,11494,11481,11493,11495,11481,11494,11496,11481,11495,11497,11481,11496,11498,11481,11497,11498,11499,11481,11498,11500,11499,11501,11500,11498,11502,11500,11501,11502,11503,11500,11504,11505,11506,11504,11507,11505,11504,11508,11507,11504,11509,11508,11504,11510,11509,11504,11511,11510,11512,11511,11504,11512,11513,11511,11512,11514,11513,11512,11515,11514,11512,11516,11515,11512,11517,11516,11512,11518,11517,11512,11519,11518,11512,11520,11519,11512,11521,11520,11512,11522,11521,11512,11523,11522,11512,11524,11523,11512,11525,11524,11512,11526,11525,11512,11527,11526,11512,11528,11527,11512,11529,11528,11512,11530,11529,11531,11530,11512,11532,11530,11531,11532,11533,11530,11532,11534,11533,11535,11534,11532,11536,11537,11538,11536,11539,11537,11536,11540,11539,11536,11541,11540,11536,11542,11541,11536,11543,11542,11544,11543,11536,11544,11545,11543,11546,11545,11544,11547,11545,11546,11548,11545,11547,11549,11545,11548,11550,11545,11549,11551,11545,11550,11552,11545,11551,11553,11545,11552,11553,11554,11545,11553,11555,11554,11553,11556,11555,11553,11557,11556,11553,11558,11557,11553,11559,11558,11553,11560,11559,11553,11561,11560,11553,11562,11561,11563,11562,11553,11564,11562,11563,11564,11565,11562,11566,11565,11564,11566,11567,11565,11568,11569,11570,11568,11571,11569,11568,11572,11571,11568,11573,11572,11568,11574,11573,11575,11576,11577,11578,11579,11580,11581,11582,11583,11584,11585,11586,11587,11582,11588,11589,11582,11587,11590,11582,11589,11591,11582,11590,11592,11582,11591,11593,11582,11592,11594,11582,11593,11595,11582,11594,11596,11582,11595,11597,11582,11596,11598,11582,11597,11599,11582,11598,11600,11582,11599,11601,11602,11603,11604,11605,11606,11607,11605,11604,11608,11609,11610,11611,11612,11613,11611,11614,11612,11611,11615,11614,11616,11615,11611,11617,11618,11619,11617,11620,11618,11617,11621,11620,11617,11622,11621,11617,11623,11622,11624,11625,11626,11627,11628,11629,11630,11631,11632,11633,11634,11635,11636,11631,11637,11638,11631,11636,11639,11631,11638,11640,11631,11639,11641,11631,11640,11642,11631,11641,11643,11631,11642,11644,11631,11643,11645,11631,11644,11646,11631,11645,11647,11631,11646,11648,11631,11647,11649,11631,11648,11650,11651,11652,11653,11654,11655,11656,11654,11653,11657,11658,11659,11660,11661,11662,11660,11663,11661,11664,11663,11660,11664,11665,11663,11666,11667,11668,11666,11669,11667,11666,11670,11669,11666,11671,11670,11666,11672,11671,11673,11674,11675,11676,11677,11678,11679,11680,11681,11682,11683,11684,11685,11680,11686,11687,11680,11685,11688,11680,11687,11689,11680,11688,11690,11680,11689,11691,11680,11690,11692,11680,11691,11693,11680,11692,11694,11680,11693,11695,11680,11694,11696,11680,11695,11697,11680,11696,11698,11680,11697,11699,11700,11701,11702,11703,11704,11705,11703,11702,11706,11707,11708,11709,11710,11711,11709,11712,11710,11713,11712,11709,11713,11714,11712,11715,11716,11717,11715,11718,11716,11715,11719,11718,11715,11720,11719,11715,11721,11720,11722,11723,11724,11725,11726,11727,11728,11729,11730,11731,11732,11733,11734,11729,11735,11736,11729,11734,11737,11729,11736,11738,11729,11737,11739,11729,11738,11740,11729,11739,11741,11729,11740,11742,11729,11741,11743,11729,11742,11744,11729,11743,11745,11729,11744,11746,11729,11745,11747,11729,11746,11748,11749,11750,11751,11752,11753,11754,11755,11756,11757,11758,11759,11760,11758,11757,11760,11761,11758,11762,11761,11760,11762,11763,11761,11764,11765,11766,11767,11768,11769,11770,11771,11772,11773,11774,11775,11776,11777,11778,11779,11777,11776,11780,11777,11779,11781,11782,11783,11781,11784,11782,11781,11785,11784,11781,11786,11785,11781,11787,11786,11781,11788,11787,11781,11789,11788,11790,11791,11792,11781,11793,11794,11795,11793,11781,11796,11793,11795,11797,11793,11796,11798,11793,11797,11799,11793,11798,11800,11793,11799,11801,11802,11803,11804,11805,11806,11807,11805,11804,11808,11809,11810,11811,11812,11813,11811,11814,11812,11811,11815,11814,11816,11815,11811,11817,11818,11819,11820,11821,11822,11823,11824,11825,11826,11827,11828,11829,11830,11831,11832,11830,11829,11833,11830,11832,11834,11835,11836,11837,11838,11839,11840,11835,11841,11842,11835,11840,11843,11835,11842,11844,11835,11843,11845,11835,11844,11846,11835,11845,11847,11835,11846,11848,11835,11847,11849,11835,11848,11850,11835,11849,11851,11835,11850,11852,11835,11851,11853,11835,11852,11854,11855,11856,11857,11858,11859,11860,11858,11857,11861,11862,11863,11864,11865,11866,11867,11865,11864,11867,11868,11865,11869,11868,11867,11870,11871,11872,11873,11874,11875,11876,11877,11878,11879,11880,11881,11882,11883,11884,11885,11883,11882,11886,11883,11885,11887,11888,11889,11890,11891,11892,11893,11888,11894,11895,11888,11893,11896,11888,11895,11897,11888,11896,11898,11888,11897,11899,11888,11898,11900,11888,11899,11901,11888,11900,11902,11888,11901,11903,11888,11902,11904,11888,11903,11905,11888,11904,11906,11888,11905,11907,11908,11909,11910,11911,11912,11913,11914,11915,11916,11917,11918,11916,11919,11917,11920,11919,11916,11920,11921,11919,11922,11921,11920,11923,11924,11925,11926,11927,11928,11929,11930,11931,11932,11933,11934,11935,11936,11937,11938,11936,11935,11939,11936,11938,11940,11941,11942,11943,11944,11945,11946,11941,11947,11948,11941,11946,11949,11941,11948,11950,11941,11949,11951,11941,11950,11952,11941,11951,11953,11941,11952,11954,11941,11953,11955,11941,11954,11956,11941,11955,11957,11941,11956,11958,11941,11957,11959,11941,11958,11960,11961,11962,11963,11964,11965,11966,11964,11963,11967,11968,11969,11970,11971,11972,11973,11971,11970,11973,11974,11971,11975,11974,11973,11976,11977,11978,11979,11980,11981,11982,11983,11984,11985,11986,11987,11988,11989,11990,11991,11989,11988,11992,11989,11991,11993,11994,11995,11996,11997,11998,11999,11994,12000,12001,11994,11999,12002,11994,12001,12003,11994,12002,12004,11994,12003,12005,11994,12004,12006,11994,12005,12007,11994,12006,12008,11994,12007,12009,11994,12008,12010,11994,12009,12011,11994,12010,12012,11994,12011,12013,12014,12015,12016,12017,12018,12019,12020,12021,12022,12023,12024,12022,12025,12023,12026,12025,12022,12027,12025,12026,12027,12028,12025,12029,12030,12031,12032,12033,12034,12035,12036,12037,12038,12039,12040,12041,12042,12043,12044,12042,12041,12045,12042,12044,12046,12047,12048,12049,12050,12051,12052,12047,12053,12054,12047,12052,12055,12047,12054,12056,12047,12055,12057,12047,12056,12058,12047,12057,12059,12047,12058,12060,12047,12059,12061,12047,12060,12062,12047,12061,12063,12047,12062,12064,12047,12063,12065,12047,12064,12066,12067,12068,12069,12070,12071,12072,12073,12074,12075,12076,12077,12075,12078,12076,12079,12078,12075,12080,12078,12079,12080,12081,12078,12082,12083,12084,12085,12083,12082,12086,12083,12085,12087,12083,12086,12088,12083,12087,12089,12090,12091,12092,12093,12094,12095,12096,12083,12097,12098,12099,12095,12100,12101,12095,12102,12100,12095,12103,12102,12095,12104,12103,12095,12105,12104,12095,12106,12105,12095,12107,12106,12095,12108,12107,12095,12109,12108,12095,12110,12109,12095,12111,12110,12095,12112,12111,12095,12113,12112,12114,12115,12116,12117,12118,12119,12117,12120,12118,12121,12122,12123,12124,12125,12126,12124,12127,12125,12128,12127,12124,12128,12129,12127,12130,12131,12132,12133,12134,12135,12136,12137,12138,12139,12140,12141,12142,12143,12144,12142,12145,12143,12146,12147,12148,12149,12150,12151,12152,12150,12149,12153,12150,12152,12154,12150,12153,12155,12150,12154,12156,12150,12155,12157,12150,12156,12158,12159,12160,12161,12150,12162,12161,12163,12150,12161,12164,12163,12161,12165,12164,12161,12166,12165,12161,12167,12166,12161,12168,12167,12169,12170,12171,12172,12173,12174,12172,12175,12173,12176,12177,12178,12179,12180,12181,12179,12182,12180,12183,12182,12179,12183,12184,12182,12185,12186,12187,12188,12189,12190,12191,12192,12193,12194,12195,12196,12197,12198,12199,12200,12198,12197,12201,12198,12200,12202,12203,12204,12202,12205,12203,12202,12206,12205,12202,12207,12206,12202,12208,12207,12202,12209,12208,12202,12210,12209,12211,12212,12213,12202,12214,12215,12216,12214,12202,12217,12214,12216,12218,12214,12217,12219,12214,12218,12220,12214,12219,12221,12214,12220,12222,12223,12224,12225,12226,12227,12228,12229,12230,12231,12232,12233,12231,12234,12232,12235,12234,12231,12235,12236,12234,12237,12236,12235,12238,12239,12240,12238,12241,12239,12238,12242,12241,12238,12243,12242,12238,12244,12243,12238,12245,12244,12246,12245,12238,12246,12247,12245,12246,12248,12247,12249,12250,12251,12246,12252,12253,12246,12254,12252,12246,12255,12254,12246,12256,12255,12246,12257,12256,12246,12258,12257,12246,12259,12258,12246,12260,12259,12246,12261,12260,12246,12262,12261,12246,12263,12262,12264,12265,12266,12267,12268,12269,12246,12270,12271,12246,12272,12270,12273,12272,12246,12274,12272,12273,12274,12275,12272,12274,12276,12275,12277,12276,12274,12278,12279,12280,12281,12279,12278,12282,12279,12281,12283,12279,12282,12284,12279,12283,12285,12279,12284,12286,12279,12285,12286,12287,12279,12286,12288,12287,12286,12289,12288,12286,12290,12289,12286,12291,12290,12286,12292,12291,12286,12293,12292,12286,12294,12293,12286,12295,12294,12286,12296,12295,12286,12297,12296,12286,12298,12297,12286,12299,12298,12286,12300,12299,12286,12301,12300,12302,12303,12304,12286,12305,12306,12286,12307,12305,12308,12307,12286,12308,12309,12307,12310,12309,12308,12311,12309,12310,12311,12312,12309,12313,12314,12315,12316,12314,12313,12317,12314,12316,12318,12314,12317,12319,12314,12318,12320,12314,12319,12321,12314,12320,12321,12322,12314,12321,12323,12322,12321,12324,12323,12321,12325,12324,12321,12326,12325,12321,12327,12326,12321,12328,12327,12321,12329,12328,12321,12330,12329,12321,12331,12330,12321,12332,12331,12321,12333,12332,12321,12334,12333,12321,12335,12334,12321,12336,12335,12337,12338,12339,12321,12340,12341,12321,12342,12340,12343,12342,12321,12344,12342,12343,12344,12345,12342,12346,12345,12344,12346,12347,12345,12348,12349,12350,12351,12349,12348,12352,12349,12351,12353,12349,12352,12354,12349,12353,12355,12349,12354,12356,12349,12355,12356,12357,12349,12356,12358,12357,12356,12359,12358,12356,12360,12359,12356,12361,12360,12356,12362,12361,12356,12363,12362,12356,12364,12363,12356,12365,12364,12356,12366,12365,12356,12367,12366,12356,12368,12367,12356,12369,12368,12356,12370,12369,12356,12371,12370,12372,12373,12374,12356,12375,12376,12356,12377,12375,12378,12377,12356,12379,12377,12378,12379,12380,12377,12379,12381,12380,12382,12381,12379,12383,12384,12385,12386,12384,12383,12387,12384,12386,12388,12384,12387,12389,12384,12388,12390,12384,12389,12391,12384,12390,12391,12392,12384,12391,12393,12392,12391,12394,12393,12391,12395,12394,12391,12396,12395,12391,12397,12396,12391,12398,12397,12391,12399,12398,12391,12400,12399,12391,12401,12400,12391,12402,12401,12391,12403,12402,12391,12404,12403,12391,12405,12404,12391,12406,12405,12407,12408,12409,12391,12410,12411,12391,12412,12410,12413,12412,12391,12414,12412,12413,12414,12415,12412,12414,12416,12415,12417,12416,12414,12418,12419,12420,12421,12419,12418,12422,12419,12421,12423,12419,12422,12424,12419,12423,12425,12419,12424,12426,12419,12425,12426,12427,12419,12426,12428,12427,12426,12429,12428,12426,12430,12429,12426,12431,12430,12426,12432,12431,12426,12433,12432,12426,12434,12433,12426,12435,12434,12426,12436,12435,12426,12437,12436,12426,12438,12437,12426,12439,12438,12426,12440,12439,12426,12441,12440,12442,12443,12444,12426,12445,12446,12426,12447,12445,12448,12447,12426,12449,12447,12448,12449,12450,12447,12451,12450,12449,12451,12452,12450,12453,12454,12455,12456,12454,12453,12457,12454,12456,12458,12454,12457,12459,12454,12458,12460,12454,12459,12461,12454,12460,12461,12462,12454,12463,12462,12461,12464,12462,12463,12465,12462,12464,12466,12462,12465,12467,12462,12466,12468,12462,12467,12469,12462,12468,12470,12462,12469,12471,12462,12470,12472,12462,12471,12473,12462,12472,12474,12462,12473,12475,12462,12474,12476,12462,12475,12477,12478,12479,12480,12462,12481,12482,12462,12480,12482,12483,12462,12484,12483,12482,12484,12485,12483,12484,12486,12485,12487,12486,12484,12488,12489,12490,12491,12489,12488,12492,12489,12491,12493,12489,12492,12494,12489,12493,12495,12489,12494,12496,12489,12495,12496,12497,12489,12498,12497,12496,12499,12497,12498,12500,12497,12499,12501,12497,12500,12502,12497,12501,12503,12497,12502,12504,12497,12503,12505,12497,12504,12505,12506,12497,12505,12507,12506,12505,12508,12507,12505,12509,12508,12505,12510,12509,12505,12511,12510,12512,12513,12514,12505,12515,12516,12517,12515,12505,12517,12518,12515,12517,12519,12518,12520,12519,12517,12520,12521,12519,12522,12521,12520,12523,12524,12525,12526,12524,12523,12527,12524,12526,12528,12524,12527,12529,12524,12528,12530,12524,12529,12531,12524,12530,12531,12532,12524,12533,12532,12531,12534,12532,12533,12535,12532,12534,12536,12532,12535,12537,12532,12536,12538,12532,12537,12539,12532,12538,12540,12532,12539,12541,12532,12540,12542,12532,12541,12543,12532,12542,12544,12532,12543,12545,12532,12544,12546,12532,12545,12547,12548,12549,12550,12532,12551,12550,12552,12532,12553,12552,12550,12554,12552,12553,12554,12555,12552,12556,12555,12554,12556,12557,12555,12558,12559,12560,12561,12559,12558,12562,12559,12561,12563,12559,12562,12564,12559,12563,12565,12559,12564,12566,12559,12565,12566,12567,12559,12568,12567,12566,12569,12567,12568,12570,12567,12569,12571,12567,12570,12572,12567,12571,12573,12567,12572,12574,12567,12573,12575,12567,12574,12576,12567,12575,12577,12567,12576,12578,12567,12577,12579,12567,12578,12580,12567,12579,12581,12567,12580,12582,12583,12584,12585,12567,12586,12585,12587,12567,12588,12587,12585,12589,12587,12588,12589,12590,12587,12591,12590,12589,12591,12592,12590,12593,12594,12595,12596,12594,12593,12597,12594,12596,12598,12594,12597,12599,12594,12598,12600,12594,12599,12601,12594,12600,12601,12602,12594,12603,12602,12601,12604,12602,12603,12605,12602,12604,12606,12602,12605,12607,12602,12606,12608,12602,12607,12609,12602,12608,12610,12602,12609,12611,12602,12610,12612,12602,12611,12613,12602,12612,12614,12602,12613,12615,12602,12614,12616,12602,12615,12617,12618,12619,12620,12602,12621,12620,12622,12602,12623,12622,12620,12624,12622,12623,12624,12625,12622,12626,12625,12624,12626,12627,12625,12628,12629,12630,12631,12629,12628,12632,12629,12631,12633,12629,12632,12634,12629,12633,12635,12629,12634,12636,12629,12635,12636,12637,12629,12638,12637,12636,12639,12637,12638,12640,12637,12639,12641,12637,12640,12642,12637,12641,12643,12637,12642,12644,12637,12643,12645,12637,12644,12645,12646,12637,12645,12647,12646,12645,12648,12647,12645,12649,12648,12645,12650,12649,12645,12651,12650,12652,12653,12654,12645,12655,12656,12645,12657,12655,12658,12657,12645,12658,12659,12657,12660,12659,12658,12661,12659,12660,12661,12662,12659,12663,12664,12665,12666,12664,12663,12667,12664,12666,12668,12664,12667,12669,12664,12668,12670,12664,12669,12671,12664,12670,12671,12672,12664,12673,12672,12671,12674,12672,12673,12675,12672,12674,12676,12672,12675,12677,12672,12676,12678,12672,12677,12679,12672,12678,12680,12672,12679,12681,12672,12680,12682,12672,12681,12683,12672,12682,12684,12672,12683,12685,12672,12684,12686,12672,12685,12687,12688,12689,12690,12672,12691,12692,12672,12690,12692,12693,12672,12692,12694,12693,12695,12694,12692,12696,12694,12695,12696,12697,12694,12698,12699,12700,12701,12699,12698,12702,12699,12701,12703,12699,12702,12704,12699,12703,12705,12699,12704,12706,12699,12705,12706,12707,12699,12708,12707,12706,12709,12707,12708,12710,12707,12709,12711,12707,12710,12712,12707,12711,12713,12707,12712,12714,12707,12713,12715,12707,12714,12716,12707,12715,12717,12707,12716,12718,12707,12717,12719,12707,12718,12720,12707,12719,12721,12707,12720,12722,12723,12724,12725,12707,12726,12727,12707,12725,12727,12728,12707,12727,12729,12728,12730,12729,12727,12731,12729,12730,12731,12732,12729,12733,12734,12735,12736,12734,12733,12737,12734,12736,12738,12734,12737,12739,12734,12738,12740,12734,12739,12741,12734,12740,12741,12742,12734,12743,12742,12741,12744,12742,12743,12745,12742,12744,12746,12742,12745,12747,12742,12746,12748,12742,12747,12749,12742,12748,12750,12742,12749,12751,12742,12750,12752,12742,12751,12753,12742,12752,12754,12742,12753,12755,12742,12754,12756,12742,12755,12757,12758,12759,12760,12742,12761,12762,12742,12760,12762,12763,12742,12762,12764,12763,12765,12764,12762,12765,12766,12764,12767,12766,12765,12768,12769,12770,12771,12772,12773,12774,12775,12776,12777,12778,12779,12780,12781,12782,12783,12784,12785,12786,12784,12783,12787,12788,12789,12787,12790,12788,12787,12791,12790,12787,12792,12791,12787,12793,12792,12787,12794,12793,12787,12795,12794,12787,12796,12795,12787,12797,12796,12787,12798,12797,12787,12799,12798,12787,12800,12799,12787,12801,12800,12787,12802,12801,12787,12803,12802,12804,12805,12806,12807,12808,12809,12807,12810,12808,12811,12812,12813,12814,12815,12816,12817,12818,12819,12820,12821,12822,12823,12821,12820,12824,12825,12826,12827,12828,12829,12830,12831,12832,12833,12834,12835,12836,12837,12838,12839,12840,12841,12842,12840,12839,12843,12844,12845,12843,12846,12844,12843,12847,12846,12843,12848,12847,12843,12849,12848,12843,12850,12849,12843,12851,12850,12843,12852,12851,12843,12853,12852,12854,12853,12843,12855,12853,12854,12856,12853,12855,12857,12853,12856,12858,12853,12857,12859,12860,12861,12862,12853,12863,12864,12853,12862,12865,12853,12864,12865,12866,12853,12865,12867,12866,12868,12867,12865,12869,12867,12868,12869,12870,12867,12871,12872,12873,12874,12875,12876,12877,12878,12879,12880,12881,12882,12883,12884,12885,12886,12887,12888,12889,12887,12886,12890,12891,12892,12890,12893,12891,12890,12894,12893,12890,12895,12894,12890,12896,12895,12890,12897,12896,12890,12898,12897,12890,12899,12898,12890,12900,12899,12901,12900,12890,12902,12900,12901,12903,12900,12902,12904,12900,12903,12905,12900,12904,12906,12907,12908,12909,12900,12910,12911,12900,12909,12912,12900,12911,12912,12913,12900,12912,12914,12913,12915,12914,12912,12916,12914,12915,12916,12917,12914,12918,12919,12920,12918,12921,12919,12918,12922,12921,12918,12923,12922,12918,12924,12923,12918,12925,12924,12926,12925,12918,12926,12927,12925,12928,12927,12926,12929,12930,12931,12932,12927,12933,12934,12927,12932,12935,12927,12934,12936,12927,12935,12937,12927,12936,12938,12927,12937,12938,12939,12927,12938,12940,12939,12938,12941,12940,12938,12942,12941,12938,12943,12942,12938,12944,12943,12945,12946,12947,12948,12949,12950,12948,12951,12949,12952,12953,12954,12955,12956,12957,12958,12959,12960,12958,12961,12959,12962,12961,12958,12963,12964,12965,12963,12966,12964,12963,12967,12966,12963,12968,12967,12963,12969,12968,12963,12970,12969,12971,12970,12963,12971,12972,12970,12971,12973,12972,12974,12975,12976,12971,12977,12978,12971,12979,12977,12971,12980,12979,12971,12981,12980,12971,12982,12981,12971,12983,12982,12984,12983,12971,12985,12983,12984,12986,12983,12985,12987,12983,12986,12988,12983,12987,12989,12983,12988,12990,12991,12992,12993,12994,12995,12996,12994,12993,12997,12998,12999,13000,13001,13002,13003,13004,13005,13003,13006,13004,13007,13006,13003,13008,13009,13010,13008,13011,13009,13008,13012,13011,13008,13013,13012,13008,13014,13013,13008,13015,13014,13008,13016,13015,13017,13016,13008,13017,13018,13016,13019,13020,13021,13017,13022,13023,13017,13024,13022,13017,13025,13024,13017,13026,13025,13017,13027,13026,13017,13028,13027,13029,13028,13017,13030,13028,13029,13031,13028,13030,13032,13028,13031,13033,13028,13032,13034,13028,13033,13035,13036,13037,13038,13039,13040,13041,13039,13038,13042,13043,13044,13045,13046,13047,13048,13049,13050,13048,13051,13049,13052,13051,13048,13053,13054,13055,13053,13056,13054,13053,13057,13056,13053,13058,13057,13053,13059,13058,13053,13060,13059,13061,13060,13053,13061,13062,13060,13061,13063,13062,13064,13065,13066,13061,13067,13068,13061,13069,13067,13061,13070,13069,13061,13071,13070,13061,13072,13071,13061,13073,13072,13074,13073,13061,13075,13073,13074,13076,13073,13075,13077,13073,13076,13078,13073,13077,13079,13073,13078,13080,13081,13082,13083,13084,13085,13086,13084,13083,13087,13088,13089,13090,13091,13092,13093,13094,13095,13093,13096,13094,13097,13096,13093,13098,13099,13100,13098,13101,13099,13098,13102,13101,13098,13103,13102,13098,13104,13103,13098,13105,13104,13106,13105,13098,13106,13107,13105,13106,13108,13107,13109,13110,13111,13106,13112,13113,13106,13114,13112,13106,13115,13114,13106,13116,13115,13106,13117,13116,13106,13118,13117,13119,13118,13106,13120,13118,13119,13121,13118,13120,13122,13118,13121,13123,13118,13122,13124,13118,13123,13125,13126,13127,13128,13129,13130,13131,13129,13128,13132,13133,13134,13135,13136,13137,13138,13139,13140,13138,13141,13139,13142,13141,13138,13143,13144,13145,13146,13147,13148,13149,13150,13151,13152,13153,13154,13155,13156,13157,13158,13159,13160,13161,13162,13163,13164,13165,13166,13167,13165,13164,13168,13165,13167,13169,13165,13168,13170,13165,13169,13171,13165,13170,13172,13165,13171,13173,13165,13172,13174,13165,13173,13175,13165,13174,13176,13165,13175,13177,13165,13176,13178,13165,13177,13179,13165,13178,13180,13165,13179,13181,13182,13183,13184,13185,13186,13187,13185,13184,13188,13189,13190,13191,13192,13193,13194,13195,13196,13197,13198,13199,13200,13198,13197,13201,13202,13203,13204,13205,13206,13207,13208,13209,13210,13211,13212,13213,13214,13215,13216,13217,13218,13219,13220,13221,13222,13223,13224,13225,13223,13222,13226,13223,13225,13227,13223,13226,13228,13223,13227,13229,13223,13228,13230,13223,13229,13231,13223,13230,13232,13223,13231,13233,13223,13232,13234,13223,13233,13235,13223,13234,13236,13223,13235,13237,13223,13236,13238,13223,13237,13239,13240,13241,13242,13243,13244,13245,13243,13242,13246,13247,13248,13249,13250,13251,13252,13253,13254,13252,13255,13253,13256,13255,13252,13257,13258,13259,13260,13261,13262,13263,13264,13265,13266,13267,13268,13269,13270,13271,13272,13273,13274,13275,13276,13277,13278,13279,13280,13281,13279,13278,13282,13279,13281,13283,13279,13282,13284,13279,13283,13285,13279,13284,13286,13279,13285,13287,13279,13286,13288,13279,13287,13289,13279,13288,13290,13279,13289,13291,13279,13290,13292,13279,13291,13293,13279,13292,13294,13279,13293,13295,13296,13297,13298,13299,13300,13301,13299,13298,13302,13303,13304,13305,13306,13307,13308,13309,13310,13311,13312,13313,13314,13312,13311,13315,13316,13317,13318,13316,13315,13319,13316,13318,13320,13316,13319,13321,13316,13320,13322,13316,13321,13323,13316,13322,13323,13324,13316,13323,13325,13324,13323,13326,13325,13323,13327,13326,13328,13329,13330,13323,13331,13332,13323,13333,13331,13323,13334,13333,13323,13335,13334,13336,13335,13323,13337,13335,13336,13338,13335,13337,13339,13335,13338,13340,13335,13339,13341,13335,13340,13342,13343,13344,13345,13346,13347,13348,13346,13345,13349,13350,13351,13352,13353,13354,13355,13356,13357,13358,13359,13360,13361,13362,13363,13364,13365,13366,13364,13367,13365,13364,13368,13367,13364,13369,13368,13364,13370,13369,13364,13371,13370,13372,13371,13364,13372,13373,13371,13374,13373,13372,13375,13373,13374,13376,13373,13375,13377,13378,13379,13380,13373,13381,13382,13373,13380,13383,13373,13382,13384,13373,13383,13384,13385,13373,13384,13386,13385,13384,13387,13386,13384,13388,13387,13384,13389,13388,13384,13390,13389,13391,13392,13393,13394,13395,13396,13394,13397,13395,13398,13399,13400,13401,13402,13403,13404,13405,13406,13407,13408,13409,13410,13411,13412,13413,13414,13415,13416,13417,13418,13419,13420,13421,13422,13423,13424,13425,13426,13427,13428,13426,13425,13429,13426,13428,13430,13431,13432,13430,13433,13431,13434,13435,13436,13430,13437,13438,13430,13439,13437,13430,13440,13439,13430,13441,13440,13430,13442,13441,13430,13443,13442,13430,13444,13443,13430,13445,13444,13430,13446,13445,13430,13447,13446,13448,13449,13450,13451,13452,13453,13448,13454,13455,13448,13456,13454,13448,13457,13456,13458,13459,13429,13460,13461,13462,13463,13464,13465,13466,13464,13463,13466,13467,13464,13468,13469,13470,13471,13472,13473,13474,13475,13476,13477,13478,13479,13480,13481,13482,13483,13481,13480,13484,13481,13483,13485,13486,13487,13485,13488,13486,13489,13490,13491,13485,13492,13493,13485,13494,13492,13485,13495,13494,13485,13496,13495,13485,13497,13496,13485,13498,13497,13485,13499,13498,13485,13500,13499,13485,13501,13500,13485,13502,13501,13503,13504,13505,13506,13507,13508,13503,13509,13510,13503,13511,13509,13503,13512,13511,13513,13514,13484,13515,13516,13517,13518,13519,13520,13518,13521,13519,13522,13521,13518,13523,13524,13525,13526,13527,13528,13529,13530,13531,13532,13533,13534,13535,13536,13537,13538,13536,13535,13539,13536,13538,13540,13541,13542,13540,13543,13541,13544,13545,13546,13540,13547,13548,13540,13549,13547,13540,13550,13549,13540,13551,13550,13540,13552,13551,13540,13553,13552,13540,13554,13553,13540,13555,13554,13540,13556,13555,13540,13557,13556,13558,13559,13560,13561,13562,13563,13558,13564,13565,13558,13566,13564,13558,13567,13566,13568,13569,13539,13570,13571,13572,13573,13574,13575,13576,13574,13573,13576,13577,13574,13578,13579,13580,13581,13582,13583,13584,13585,13586,13587,13588,13589,13590,13591,13592,13593,13591,13590,13594,13591,13593,13595,13596,13597,13595,13598,13596,13599,13600,13601,13595,13602,13603,13595,13604,13602,13595,13605,13604,13595,13606,13605,13595,13607,13606,13595,13608,13607,13595,13609,13608,13595,13610,13609,13595,13611,13610,13595,13612,13611,13613,13614,13615,13616,13617,13618,13613,13619,13620,13613,13621,13619,13622,13623,13594,13624,13625,13621,13626,13627,13628,13629,13630,13631,13632,13630,13629,13632,13633,13630,13634,13635,13636,13637,13638,13639,13640,13641,13642,13643,13644,13645,13646,13647,13648,13649,13647,13646,13650,13647,13649,13651,13652,13653,13651,13654,13652,13655,13656,13657,13651,13658,13659,13651,13660,13658,13651,13661,13660,13651,13662,13661,13651,13663,13662,13651,13664,13663,13651,13665,13664,13651,13666,13665,13651,13667,13666,13651,13668,13667,13669,13670,13671,13672,13673,13674,13669,13675,13676,13669,13677,13675,13669,13678,13677,13679,13680,13650,13681,13680,13679,13682,13683,13684,13685,13686,13687,13688,13686,13685,13689,13690,13691,13692,13690,13689,13693,13690,13692,13694,13690,13693,13695,13696,13697,13698,13699,13700,13701,13699,13698,13702,13703,13690,13704,13703,13702,13705,13706,13707,13708,13703,13709,13710,13703,13708,13711,13703,13710,13712,13703,13711,13713,13703,13712,13714,13703,13713,13715,13703,13714,13716,13703,13715,13717,13703,13716,13718,13703,13717,13719,13720,13721,13722,13723,13724,13725,13720,13726,13727,13720,13725,13728,13729,13730,13731,13732,13727,13733,13734,13735,13736,13737,13738,13736,13739,13737,13740,13739,13736,13741,13742,13743,13744,13745,13746,13747,13748,13749,13750,13751,13752,13753,13754,13755,13756,13757,13758,13759,13757,13756,13760,13761,13762,13760,13763,13761,13764,13765,13766,13760,13767,13768,13760,13769,13767,13760,13770,13769,13760,13771,13770,13760,13772,13771,13760,13773,13772,13774,13773,13760,13775,13773,13774,13776,13773,13775,13777,13773,13776,13778,13779,13780,13781,13782,13783,13784,13779,13785,13786,13779,13784,13787,13788,13789,13790,13791,13786,13792,13793,13794,13795,13796,13797,13795,13798,13796,13799,13798,13795,13800,13801,13802,13803,13804,13805,13806,13807,13808,13809,13810,13811,13812,13813,13814,13815,13816,13817,13818,13816,13815,13819,13820,13821,13819,13822,13820,13823,13824,13825,13819,13826,13827,13819,13828,13826,13819,13829,13828,13819,13830,13829,13819,13831,13830,13819,13832,13831,13833,13832,13819,13834,13832,13833,13835,13832,13834,13836,13832,13835,13837,13838,13839,13840,13841,13842,13843,13838,13844,13845,13838,13843,13846,13838,13845,13847,13848,13849,13847,13850,13848,13851,13852,13853,13854,13855,13856,13854,13857,13855,13858,13859,13860,13861,13862,13863,13864,13865,13866,13867,13868,13869,13870,13871,13872,13873,13874,13875,13873,13876,13874,13877,13878,13879,13880,13878,13877,13881,13882,13883,13884,13878,13885,13886,13878,13884,13887,13878,13886,13888,13878,13887,13889,13878,13888,13890,13878,13889,13890,13891,13878,13890,13892,13891,13890,13893,13892,13890,13894,13893,13895,13896,13897,13898,13899,13900,13895,13901,13902,13895,13903,13901,13904,13905,13906,13907,13908,13903,13909,13910,13904,13911,13912,13913,13914,13915,13916,13917,13915,13914,13918,13919,13920,13921,13922,13923,13924,13925,13926,13927,13928,13929,13930,13931,13932,13933,13934,13935,13936,13934,13933,13937,13938,13939,13937,13940,13938,13941,13942,13943,13937,13944,13945,13937,13946,13944,13937,13947,13946,13937,13948,13947,13937,13949,13948,13937,13950,13949,13951,13950,13937,13952,13950,13951,13953,13950,13952,13954,13950,13953,13955,13956,13957,13958,13959,13960,13961,13956,13962,13963,13956,13961,13964,13956,13963,13965,13966,13967,13965,13968,13966,13969,13970,13971,13972,13973,13974,13972,13975,13973,13976,13977,13978,13979,13980,13981,13982,13983,13984,13985,13986,13987,13988,13989,13990,13991,13992,13993,13994,13995,13996,13997,13998,13999,14000,13998,13997,14001,14002,14003,14004,13998,14005,14006,13998,14004,14007,13998,14006,14008,13998,14007,14009,13998,14008,14010,13998,14009,14010,14011,13998,14010,14012,14011,14010,14013,14012,14010,14014,14013,14015,14016,14017,14018,14019,14020,14015,14021,14022,14015,14023,14021,14015,14024,14023,14025,14026,14027,14028,14026,14025,14029,14030,14031,14032,14033,14034,14032,14035,14033,14036,14037,14038,14039,14040,14041,14042,14043,14044,14045,14046,14047,14048,14049,14050,14048,14051,14049,14052,14053,14054,14055,14056,14057,14058,14056,14055,14059,14060,14061,14062,14056,14063,14064,14056,14062,14065,14056,14064,14066,14056,14065,14067,14056,14066,14068,14056,14067,14069,14056,14068,14070,14056,14069,14071,14056,14070,14072,14056,14071,14073,14074,14075,14076,14077,14078,14079,14074,14080,14081,14074,14079,14082,14083,14084,14085,14086,14081,14087,14088,14089,14090,14091,14092,14093,14091,14090,14093,14094,14091,14095,14096,14097,14098,14096,14095,14099,14096,14098,14100,14096,14099,14101,14096,14100,14102,14096,14101,14103,14096,14102,14103,14104,14096,14105,14106,14107,14103,14108,14109,14103,14110,14108,14103,14111,14110,14103,14112,14111,14103,14113,14112,14103,14114,14113,14103,14115,14114,14103,14116,14115,14103,14117,14116,14103,14118,14117,14103,14119,14118,14120,14121,14122,14120,14123,14121,14124,14125,14126,14103,14127,14128,14129,14127,14103,14129,14130,14127,14129,14131,14130,14132,14131,14129,14132,14133,14131,14134,14133,14132,14135,14136,14137,14138,14136,14135,14139,14136,14138,14140,14136,14139,14141,14136,14140,14142,14136,14141,14142,14143,14136,14144,14143,14142,14145,14146,14147,14148,14143,14149,14150,14143,14148,14151,14143,14150,14152,14143,14151,14153,14143,14152,14154,14143,14153,14155,14143,14154,14155,14156,14143,14155,14157,14156,14155,14158,14157,14155,14159,14158,14160,14161,14162,14160,14163,14161,14164,14165,14166,14155,14167,14168,14169,14170,14171,14172,14173,14155,14174,14173,14172,14174,14175,14173,14176,14175,14174,14176,14177,14175,14178,14179,14180,14181,14182,14183,14184,14185,14186,14187,14188,14189,14190,14191,14192,14193,14191,14190,14194,14191,14193,14195,14196,14197,14195,14198,14196,14195,14199,14198,14195,14200,14199,14195,14201,14200,14195,14202,14201,14195,14203,14202,14195,14204,14203,14195,14205,14204,14195,14206,14205,14195,14207,14206,14195,14208,14207,14195,14209,14208,14210,14211,14212,14210,14213,14211,14214,14215,14216,14195,14217,14218,14219,14220,14221,14222,14223,14195,14222,14224,14223,14225,14224,14222,14225,14226,14224,14227,14226,14225,14228,14229,14230,14231,14232,14233,14234,14235,14236,14237,14238,14239,14240,14241,14242,14243,14241,14240,14244,14241,14243,14245,14246,14247,14245,14248,14246,14245,14249,14248,14245,14250,14249,14245,14251,14250,14245,14252,14251,14245,14253,14252,14245,14254,14253,14245,14255,14254,14245,14256,14255,14245,14257,14256,14245,14258,14257,14245,14259,14258,14260,14261,14262,14260,14263,14261,14264,14265,14266,14245,14267,14268,14269,14270,14271,14272,14273,14245,14272,14274,14273,14275,14274,14272,14276,14274,14275,14276,14277,14274,14278,14279,14280,14281,14282,14283,14284,14285,14286,14287,14288,14289,14290,14291,14292,14293,14291,14290,14294,14291,14293,14295,14296,14297,14295,14298,14296,14295,14299,14298,14295,14300,14299,14295,14301,14300,14295,14302,14301,14295,14303,14302,14295,14304,14303,14295,14305,14304,14295,14306,14305,14295,14307,14306,14295,14308,14307,14295,14309,14308,14310,14311,14312,14310,14313,14311,14314,14315,14316,14295,14317,14318,14319,14320,14321,14322,14323,14295,14322,14324,14323,14325,14324,14322,14326,14324,14325,14326,14327,14324,14328,14329,14330,14331,14332,14333,14334,14335,14336,14337,14338,14339,14340,14341,14342,14340,14343,14341,14340,14344,14343,14345,14346,14347,14348,14346,14345,14349,14346,14348,14350,14346,14349,14351,14346,14350,14352,14346,14351,14353,14346,14352,14354,14346,14353,14355,14346,14354,14355,14356,14346,14355,14357,14356,14355,14358,14357,14355,14359,14358,14360,14361,14362,14360,14363,14361,14364,14365,14366,14355,14367,14368,14369,14367,14355,14369,14370,14367,14369,14371,14370,14372,14371,14369,14373,14371,14372,14373,14374,14371,14375,14376,14377,14378,14376,14375,14379,14376,14378,14380,14376,14379,14381,14376,14380,14382,14383,14384,14385,14386,14387,14388,14386,14385,14389,14390,14391,14392,14390,14389,14393,14390,14392,14394,14390,14393,14395,14390,14394,14396,14390,14395,14397,14390,14396,14398,14386,14399,14400,14386,14398,14401,14386,14400,14402,14390,14403,14404,14405,14406,14407,14405,14404,14408,14405,14407,14409,14410,14411,14412,14386,14413,14414,14415,14416,14417,14418,14390,14417,14419,14418,14420,14419,14417,14421,14419,14420,14421,14422,14419,14423,14424,14425,14426,14424,14423,14427,14424,14426,14428,14424,14427,14429,14424,14428,14430,14424,14429,14431,14424,14430,14432,14433,14434,14435,14436,14437,14431,14438,14439,14431,14440,14438,14431,14441,14440,14431,14442,14441,14431,14443,14442,14431,14444,14443,14432,14445,14446,14447,14445,14432,14448,14445,14447,14449,14450,14451,14452,14453,14454,14455,14453,14452,14456,14453,14455,14457,14458,14459,14460,14445,14461,14462,14463,14464,14465,14466,14450,14465,14467,14466,14468,14467,14465,14468,14469,14467,14470,14469,14468,14471,14472,14473,14471,14474,14472,14471,14475,14474,14471,14476,14475,14471,14477,14476,14471,14478,14477,14471,14479,14478,14480,14481,14482,14483,14484,14485,14486,14479,14487,14488,14479,14486,14489,14479,14488,14490,14479,14489,14491,14479,14490,14492,14479,14491,14493,14481,14494,14493,14495,14481,14493,14496,14495,14497,14498,14499,14500,14501,14502,14500,14503,14501,14500,14504,14503,14505,14506,14507,14493,14508,14509,14510,14508,14493,14511,14512,14513,14514,14515,14516,14514,14517,14515,14514,14518,14517,14519,14518,14514,14520,14521,14522,14523,14521,14520,14524,14521,14523,14525,14521,14524,14526,14521,14525,14527,14521,14526,14528,14521,14527,14528,14529,14521,14528,14530,14529,14528,14531,14530,14528,14532,14531,14528,14533,14532,14528,14534,14533,14528,14535,14534,14528,14536,14535,14528,14537,14536,14528,14538,14537,14528,14539,14538,14528,14540,14539,14528,14541,14540,14528,14542,14541,14528,14543,14542,14528,14544,14543,14528,14545,14544,14528,14546,14545,14547,14546,14528,14548,14546,14547,14548,14549,14546,14550,14549,14548,14550,14551,14549,14552,14553,14554,14555,14552,14554,14556,14555,14554,14557,14556,14554,14558,14557,14554,14559,14558,14554,14560,14559,14554,14560,14554,14561,14560,14561,14562,14560,14562,14563,14560,14563,14564,14560,14564,14565,14560,14565,14566,14560,14566,14567,14560,14567,14568,14560,14568,14569,14560,14569,14570,14560,14570,14571,14560,14571,14572,14560,14572,14573,14560,14573,14574,14560,14574,14575,14560,14575,14576,14560,14576,14577,14578,14560,14577,14578,14577,14579,14580,14578,14579,14580,14579,14581,14582,14580,14581,14582,14581,14583,14584,14585,14586,14587,14584,14586,14588,14587,14586,14589,14588,14586,14590,14589,14586,14591,14590,14586,14592,14591,14586,14592,14586,14593,14594,14592,14593,14595,14594,14593,14596,14595,14593,14597,14596,14593,14598,14597,14593,14599,14598,14593,14600,14599,14593,14601,14600,14593,14602,14601,14593,14603,14602,14593,14604,14603,14593,14605,14604,14593,14606,14605,14593,14607,14606,14593,14608,14607,14593,14609,14608,14593,14610,14609,14593,14610,14593,14611,14610,14611,14612,14613,14610,14612,14613,14612,14614,14615,14613,14614,14616,14617,14618,14616,14618,14619,14616,14619,14620,14616,14620,14621,14616,14621,14622,14616,14622,14623,14624,14616,14623,14624,14623,14625,14626,14624,14625,14627,14626,14625,14628,14627,14625,14629,14628,14625,14630,14629,14625,14631,14630,14625,14632,14631,14625,14633,14632,14625,14634,14633,14625,14635,14634,14625,14636,14635,14625,14637,14636,14625,14638,14637,14625,14639,14638,14625,14640,14639,14625,14641,14640,14625,14642,14641,14625,14642,14625,14643,14644,14642,14643,14644,14643,14645,14644,14645,14646,14647,14644,14646,14648,14649,14650,14648,14650,14651,14648,14651,14652,14648,14652,14653,14648,14653,14654,14648,14654,14655,14656,14648,14655,14656,14655,14657,14658,14656,14657,14659,14658,14657,14660,14659,14657,14661,14660,14657,14662,14661,14657,14663,14662,14657,14664,14663,14657,14665,14664,14657,14666,14665,14657,14667,14666,14657,14668,14667,14657,14669,14668,14657,14670,14669,14657,14671,14670,14657,14672,14671,14657,14673,14672,14657,14674,14673,14657,14674,14657,14675,14674,14675,14676,14677,14674,14676,14677,14676,14678,14679,14677,14678,14680,14681,14682,14683,14680,14682,14684,14683,14682,14685,14684,14682,14686,14685,14682,14687,14686,14682,14688,14687,14682,14688,14682,14689,14690,14688,14689,14691,14690,14689,14692,14691,14689,14693,14692,14689,14694,14693,14689,14695,14694,14689,14696,14695,14689,14697,14696,14689,14698,14697,14689,14699,14698,14689,14700,14699,14689,14701,14700,14689,14702,14701,14689,14703,14702,14689,14704,14703,14689,14705,14704,14689,14706,14705,14689,14706,14689,14707,14706,14707,14708,14709,14706,14708,14710,14709,14708,14710,14708,14711,14712,14713,14714,14715,14712,14714,14716,14715,14714,14717,14716,14714,14718,14717,14714,14719,14718,14714,14720,14719,14714,14720,14714,14721,14722,14720,14721,14723,14722,14721,14724,14723,14721,14725,14724,14721,14726,14725,14721,14727,14726,14721,14728,14727,14721,14729,14728,14721,14730,14729,14721,14731,14730,14721,14732,14731,14721,14733,14732,14721,14734,14733,14721,14735,14734,14721,14736,14735,14721,14737,14736,14721,14738,14737,14721,14738,14721,14739,14738,14739,14740,14741,14738,14740,14742,14741,14740,14742,14740,14743,14744,14745,14746,14747,14744,14746,14748,14747,14746,14749,14748,14746,14750,14749,14746,14751,14750,14746,14752,14751,14746,14752,14746,14753,14754,14752,14753,14755,14754,14753,14756,14755,14753,14757,14756,14753,14758,14757,14753,14759,14758,14753,14760,14759,14753,14761,14760,14753,14762,14761,14753,14763,14762,14753,14764,14763,14753,14765,14764,14753,14766,14765,14753,14767,14766,14753,14768,14767,14753,14769,14768,14753,14770,14769,14753,14770,14753,14771,14770,14771,14772,14773,14770,14772,14774,14773,14772,14774,14772,14775,14776,14777,14778,14779,14776,14778,14780,14779,14778,14781,14780,14778,14782,14781,14778,14783,14782,14778,14784,14783,14778,14784,14778,14785,14786,14784,14785,14787,14786,14785,14788,14787,14785,14789,14788,14785,14790,14789,14785,14791,14790,14785,14792,14791,14785,14793,14792,14785,14794,14793,14785,14795,14794,14785,14796,14795,14785,14797,14796,14785,14798,14797,14785,14799,14798,14785,14800,14799,14785,14801,14800,14785,14802,14801,14785,14802,14785,14803,14802,14803,14804,14805,14802,14804,14806,14805,14804,14806,14804,14807,14808,14809,14810,14811,14808,14810,14812,14811,14810,14813,14812,14810,14814,14813,14810,14815,14814,14810,14816,14815,14810,14816,14810,14817,14818,14816,14817,14819,14818,14817,14820,14819,14817,14821,14820,14817,14822,14821,14817,14823,14822,14817,14824,14823,14817,14825,14824,14817,14826,14825,14817,14827,14826,14817,14828,14827,14817,14829,14828,14817,14830,14829,14817,14831,14830,14817,14832,14831,14817,14833,14832,14817,14834,14833,14817,14834,14817,14835,14834,14835,14836,14837,14834,14836,14838,14837,14836,14838,14836,14839,14840,14841,14842,14843,14840,14842,14844,14843,14842,14845,14844,14842,14846,14845,14842,14847,14846,14842,14848,14847,14842,14848,14842,14849,14850,14848,14849,14851,14850,14849,14852,14851,14849,14853,14852,14849,14854,14853,14849,14855,14854,14849,14856,14855,14849,14857,14856,14849,14858,14857,14849,14859,14858,14849,14860,14859,14849,14861,14860,14849,14862,14861,14849,14863,14862,14849,14864,14863,14849,14865,14864,14849,14866,14865,14849,14866,14849,14867,14866,14867,14868,14869,14866,14868,14870,14869,14868,14870,14868,14871,14872,14873,14874,14875,14872,14874,14876,14875,14874,14877,14876,14874,14878,14877,14874,14879,14878,14874,14880,14879,14874,14880,14874,14881,14882,14880,14881,14883,14882,14881,14884,14883,14881,14885,14884,14881,14886,14885,14881,14887,14886,14881,14888,14887,14881,14889,14888,14881,14890,14889,14881,14891,14890,14881,14892,14891,14881,14893,14892,14881,14894,14893,14881,14895,14894,14881,14896,14895,14881,14897,14896,14881,14898,14897,14881,14898,14881,14899,14898,14899,14900,14901,14898,14900,14902,14901,14900,14902,14900,14903,14904,14905,14906,14907,14904,14906,14908,14907,14906,14909,14908,14906,14910,14909,14906,14911,14910,14906,14912,14911,14906,14912,14906,14913,14914,14912,14913,14915,14914,14913,14916,14915,14913,14917,14916,14913,14918,14917,14913,14919,14918,14913,14920,14919,14913,14921,14920,14913,14922,14921,14913,14923,14922,14913,14924,14923,14913,14925,14924,14913,14926,14925,14913,14927,14926,14913,14928,14927,14913,14929,14928,14913,14929,14913,14930,14931,14929,14930,14931,14930,14932,14933,14931,14932,14934,14933,14932,14934,14932,14935,14936,14937,14938,14939,14936,14938,14940,14939,14938,14941,14940,14938,14942,14941,14938,14943,14942,14938,14944,14943,14938,14944,14938,14945,14946,14944,14945,14947,14946,14945,14948,14947,14945,14949,14948,14945,14950,14949,14945,14951,14950,14945,14952,14951,14945,14953,14952,14945,14954,14953,14945,14955,14954,14945,14956,14955,14945,14957,14956,14945,14958,14957,14945,14959,14958,14945,14960,14959,14945,14961,14960,14945,14962,14961,14945,14962,14945,14963,14962,14963,14964,14965,14962,14964,14966,14965,14964,14966,14964,14967,14968,14969,14970,14968,14970,14971,14968,14971,14972,14968,14972,14973,14968,14973,14974,14968,14974,14975,14976,14968,14975,14976,14975,14977,14976,14977,14978,14976,14978,14979,14976,14979,14980,14976,14980,14981,14976,14981,14982,14976,14982,14983,14976,14983,14984,14976,14984,14985,14976,14985,14986,14976,14986,14987,14976,14987,14988,14976,14988,14989,14976,14989,14990,14976,14990,14991,14976,14991,14992,14976,14992,14993,14976,14993,14994,14995,14976,14994,14996,14995,14994,14996,14994,14997,14996,14997,14998,14999,14996,14998,15000,15001,15002,15000,15002,15003,15000,15003,15004,15000,15004,15005,15000,15005,15006,15000,15006,15007,15008,15000,15007,15008,15007,15009,15010,15008,15009,15011,15010,15009,15012,15011,15009,15013,15012,15009,15014,15013,15009,15015,15014,15009,15016,15015,15009,15017,15016,15009,15017,15009,15018,15017,15018,15019,15017,15019,15020,15017,15020,15021,15017,15021,15022,15017,15022,15023,15017,15023,15024,15017,15024,15025,15017,15025,15026,15027,15017,15026,15028,15027,15026,15028,15026,15029,15030,15028,15029,15030,15029,15031,15032,15033,15034,15032,15034,15035,15032,15035,15036,15032,15036,15037,15032,15037,15038,15032,15038,15039,15040,15032,15039,15040,15039,15041,15042,15040,15041,15043,15042,15041,15044,15043,15041,15045,15044,15041,15046,15045,15041,15047,15046,15041,15048,15047,15041,15049,15048,15041,15050,15049,15041,15051,15050,15041,15052,15051,15041,15053,15052,15041,15054,15053,15041,15055,15054,15041,15056,15057,15058,15059,15060,15041,15061,15059,15041,15061,15041,15062,15063,15061,15062,15063,15062,15064,15063,15064,15065,15066,15063,15065,15067,15068,15069,15067,15069,15070,15067,15070,15071,15067,15071,15072,15067,15072,15073,15067,15073,15074,15075,15067,15074,15075,15074,15076,15077,15075,15076,15078,15077,15076,15079,15078,15076,15080,15079,15076,15081,15080,15076,15082,15081,15076,15083,15082,15076,15084,15083,15076,15085,15084,15076,15086,15085,15076,15087,15086,15076,15088,15087,15076,15089,15088,15076,15090,15089,15076,15091,15092,15093,15094,15095,15076,15096,15094,15076,15096,15076,15097,15098,15096,15097,15098,15097,15099,15100,15098,15099,15100,15099,15101,15102,15103,15104,15102,15104,15105,15102,15105,15106,15102,15106,15107,15102,15107,15108,15102,15108,15109,15110,15102,15109,15110,15109,15111,15112,15110,15111,15113,15112,15111,15114,15113,15111,15115,15114,15111,15116,15115,15111,15117,15116,15111,15118,15117,15111,15119,15118,15111,15120,15119,15111,15121,15120,15111,15122,15121,15111,15123,15122,15111,15124,15123,15111,15125,15124,15111,15126,15127,15128,15129,15130,15111,15131,15129,15111,15131,15111,15132,15133,15131,15132,15133,15132,15134,15135,15133,15134,15135,15134,15136,15137,15138,15139,15137,15139,15140,15137,15140,15141,15137,15141,15142,15137,15142,15143,15137,15143,15144,15145,15137,15144,15145,15144,15146,15147,15145,15146,15148,15147,15146,15149,15148,15146,15150,15149,15146,15151,15150,15146,15152,15151,15146,15153,15152,15146,15154,15153,15146,15155,15154,15146,15156,15155,15146,15157,15156,15146,15158,15157,15146,15159,15158,15146,15160,15159,15146,15161,15162,15163,15164,15165,15146,15164,15146,15166,15167,15164,15166,15168,15167,15166,15168,15166,15169,15170,15168,15169,15170,15169,15171,15172,15173,15174,15175,15172,15174,15176,15175,15174,15177,15176,15174,15178,15177,15174,15179,15178,15174,15180,15179,15174,15180,15174,15181,15180,15181,15182,15180,15182,15183,15180,15183,15184,15180,15184,15185,15180,15185,15186,15180,15186,15187,15180,15187,15188,15180,15188,15189,15190,15180,15189,15191,15190,15189,15192,15191,15189,15193,15192,15189,15194,15193,15189,15195,15194,15189,15196,15197,15198,15199,15200,15189,15201,15199,15189,15201,15189,15202,15203,15201,15202,15203,15202,15204,15203,15204,15205,15206,15203,15205,15207,15208,15209,15210,15207,15209,15211,15210,15209,15212,15211,15209,15213,15212,15209,15214,15213,15209,15215,15214,15209,15215,15209,15216,15217,15215,15216,15218,15217,15216,15219,15218,15216,15220,15219,15216,15221,15220,15216,15222,15221,15216,15223,15222,15216,15224,15223,15216,15225,15224,15216,15226,15225,15216,15227,15226,15216,15228,15227,15216,15229,15228,15216,15230,15229,15216,15231,15232,15233,15234,15235,15216,15236,15234,15216,15236,15216,15237,15236,15237,15238,15239,15236,15238,15239,15238,15240,15241,15239,15240,15242,15243,15244,15245,15242,15244,15246,15245,15244,15247,15246,15244,15248,15247,15244,15249,15248,15244,15250,15249,15244,15250,15244,15251,15252,15250,15251,15253,15252,15251,15254,15253,15251,15255,15254,15251,15256,15255,15251,15257,15256,15251,15258,15257,15251,15259,15258,15251,15260,15259,15251,15261,15260,15251,15262,15261,15251,15263,15262,15251,15264,15263,15251,15265,15264,15251,15266,15267,15268,15269,15270,15251,15269,15251,15271,15272,15269,15271,15272,15271,15273,15274,15272,15273,15274,15273,15275,15276,15274,15275,15277,15278,15279,15280,15277,15279,15281,15280,15279,15282,15281,15279,15283,15282,15279,15284,15283,15279,15285,15284,15279,15285,15279,15286,15287,15285,15286,15288,15287,15286,15289,15288,15286,15290,15289,15286,15291,15290,15286,15292,15291,15286,15293,15292,15286,15294,15293,15286,15295,15294,15286,15296,15295,15286,15297,15296,15286,15298,15297,15286,15299,15298,15286,15300,15299,15286,15301,15302,15303,15304,15305,15286,15306,15304,15286,15306,15286,15307,15306,15307,15308,15309,15306,15308,15309,15308,15310,15311,15309,15310,15312,15313,15314,15315,15312,15314,15316,15315,15314,15317,15316,15314,15318,15317,15314,15319,15318,15314,15320,15319,15314,15320,15314,15321,15322,15320,15321,15323,15322,15321,15324,15323,15321,15325,15324,15321,15326,15325,15321,15327,15326,15321,15328,15327,15321,15329,15328,15321,15330,15329,15321,15331,15330,15321,15332,15331,15321,15333,15332,15321,15334,15333,15321,15335,15334,15321,15336,15337,15338,15339,15340,15321,15339,15321,15341,15342,15339,15341,15342,15341,15343,15344,15342,15343,15345,15344,15343,15345,15343,15346,15347,15348,15349,15350,15347,15349,15351,15350,15349,15352,15351,15349,15353,15352,15349,15354,15353,15349,15355,15354,15349,15355,15349,15356,15357,15355,15356,15358,15357,15356,15359,15358,15356,15360,15359,15356,15361,15360,15356,15362,15361,15356,15363,15362,15356,15364,15363,15356,15365,15364,15356,15366,15365,15356,15367,15366,15356,15368,15367,15356,15369,15368,15356,15370,15369,15356,15371,15372,15373,15374,15375,15356,15374,15356,15376,15377,15374,15376,15377,15376,15378,15379,15377,15378,15380,15379,15378,15380,15378,15381,15382,15383,15384,15385,15382,15384,15386,15385,15384,15387,15386,15384,15388,15387,15384,15389,15388,15384,15390,15389,15384,15390,15384,15391,15390,15391,15392,15390,15392,15393,15390,15393,15394,15390,15394,15395,15390,15395,15396,15390,15396,15397,15390,15397,15398,15390,15398,15399,15390,15399,15400,15390,15400,15401,15390,15401,15402,15390,15402,15403,15390,15403,15404,15390,15404,15405,15406,15407,15408,15390,15409,15410,15390,15410,15411,15412,15390,15411,15413,15412,15411,15413,15411,15414,15415,15413,15414,15415,15414,15416,15417,15418,15419,15417,15419,15420,15417,15420,15421,15417,15421,15422,15417,15422,15423,15417,15423,15424,15425,15417,15424,15425,15424,15426,15427,15425,15426,15428,15427,15426,15429,15428,15426,15430,15429,15426,15431,15430,15426,15432,15431,15426,15433,15432,15426,15434,15433,15426,15434,15426,15435,15434,15435,15436,15434,15436,15437,15434,15437,15438,15434,15438,15439,15434,15439,15440,15441,15442,15443,15434,15444,15445,15434,15445,15446,15447,15434,15446,15448,15447,15446,15448,15446,15449,15450,15448,15449,15450,15449,15451,15452,15453,15454,15455,15452,15454,15456,15455,15454,15457,15456,15454,15458,15457,15454,15459,15458,15454,15460,15459,15454,15460,15454,15461,15460,15461,15462,15460,15462,15463,15460,15463,15464,15460,15464,15465,15460,15465,15466,15460,15466,15467,15460,15467,15468,15460,15468,15469,15470,15460,15469,15471,15470,15469,15472,15471,15469,15473,15472,15469,15474,15473,15469,15475,15474,15469,15476,15477,15478,15479,15480,15469,15479,15469,15481,15482,15479,15481,15482,15481,15483,15484,15482,15483,15484,15483,15485,15486,15484,15485,15487,15488,15489,15487,15489,15490,15487,15490,15491,15487,15491,15492,15487,15492,15493,15487,15493,15494,15495,15487,15494,15495,15494,15496,15495,15496,15497,15495,15497,15498,15495,15498,15499,15495,15499,15500,15495,15500,15501,15495,15501,15502,15495,15502,15503,15495,15503,15504,15495,15504,15505,15495,15505,15506,15495,15506,15507,15495,15507,15508,15495,15508,15509,15495,15509,15510,15511,15512,15513,15495,15514,15515,15495,15515,15516,15517,15495,15516,15518,15517,15516,15518,15516,15519,15518,15519,15520,15521,15518,15520,15522,15523,15524,15525,15522,15524,15526,15525,15524,15527,15526,15524,15528,15527,15524,15529,15528,15524,15530,15529,15524,15530,15524,15531,15530,15531,15532,15530,15532,15533,15530,15533,15534,15530,15534,15535,15530,15535,15536,15530,15536,15537,15530,15537,15538,15530,15538,15539,15530,15539,15540,15530,15540,15541,15530,15541,15542,15530,15542,15543,15530,15543,15544,15530,15544,15545,15546,15547,15548,15530,15549,15550,15530,15550,15551,15552,15530,15551,15552,15551,15553,15554,15552,15553,15555,15554,15553,15555,15553,15556,15557,15558,15559,15560,15557,15559,15561,15560,15559,15562,15561,15559,15563,15562,15559,15564,15563,15559,15565,15564,15559,15565,15559,15566,15565,15566,15567,15565,15567,15568,15565,15568,15569,15565,15569,15570,15565,15570,15571,15565,15571,15572,15565,15572,15573,15565,15573,15574,15565,15574,15575,15565,15575,15576,15565,15576,15577,15565,15577,15578,15565,15578,15579,15565,15579,15580,15581,15582,15583,15565,15584,15585,15565,15585,15586,15587,15565,15586,15588,15587,15586,15588,15586,15589,15590,15588,15589,15590,15589,15591,15592,15593,15594,15595,15592,15594,15596,15595,15594,15597,15596,15594,15598,15597,15594,15599,15598,15594,15600,15599,15594,15600,15594,15601,15600,15601,15602,15600,15602,15603,15600,15603,15604,15600,15604,15605,15600,15605,15606,15600,15606,15607,15600,15607,15608,15600,15608,15609,15600,15609,15610,15600,15610,15611,15600,15611,15612,15600,15612,15613,15600,15613,15614,15600,15614,15615,15616,15617,15618,15600,15619,15620,15600,15620,15621,15622,15600,15621,15623,15622,15621,15623,15621,15624,15623,15624,15625,15626,15623,15625,15627,15628,15629,15630,15627,15629,15631,15630,15629,15632,15631,15629,15633,15632,15629,15634,15633,15629,15635,15634,15629,15635,15629,15636,15635,15636,15637,15635,15637,15638,15635,15638,15639,15635,15639,15640,15635,15640,15641,15635,15641,15642,15635,15642,15643,15635,15643,15644,15635,15644,15645,15635,15645,15646,15635,15646,15647,15635,15647,15648,15635,15648,15649,15635,15649,15650,15651,15652,15653,15635,15654,15655,15635,15655,15656,15657,15635,15656,15658,15657,15656,15658,15656,15659,15658,15659,15660,15661,15658,15660,15662,15663,15664,15665,15662,15664,15666,15665,15664,15667,15666,15664,15668,15667,15664,15669,15668,15664,15670,15669,15664,15670,15664,15671,15670,15671,15672,15670,15672,15673,15670,15673,15674,15670,15674,15675,15670,15675,15676,15670,15676,15677,15670,15677,15678,15670,15678,15679,15670,15679,15680,15670,15680,15681,15670,15681,15682,15670,15682,15683,15670,15683,15684,15670,15684,15685,15686,15687,15688,15670,15689,15690,15670,15690,15691,15692,15670,15691,15693,15692,15691,15693,15691,15694,15695,15693,15694,15695,15694,15696,15697,15698,15699,15700,15697,15699,15701,15700,15699,15702,15701,15699,15703,15702,15699,15704,15703,15699,15705,15704,15699,15705,15699,15706,15707,15705,15706,15708,15707,15706,15709,15708,15706,15710,15709,15706,15711,15710,15706,15712,15711,15706,15713,15712,15706,15714,15713,15706,15715,15714,15706,15716,15715,15706,15717,15716,15706,15718,15717,15706,15719,15718,15706,15720,15719,15706,15721,15722,15723,15724,15725,15706,15726,15724,15706,15726,15706,15727,15728,15726,15727,15728,15727,15729,15728,15729,15730,15731,15728,15730,15732,15733,15734,15735,15732,15734,15736,15735,15734,15737,15736,15734,15738,15737,15734,15739,15738,15734,15740,15739,15734,15740,15734,15741,15742,15740,15741,15743,15742,15741,15744,15743,15741,15745,15744,15741,15746,15745,15741,15747,15746,15741,15748,15747,15741,15749,15748,15741,15749,15741,15750,15749,15750,15751,15749,15751,15752,15749,15752,15753,15749,15753,15754,15749,15754,15755,15756,15757,15758,15749,15759,15760,15761,15749,15760,15761,15760,15762,15761,15762,15763,15764,15761,15763,15764,15763,15765,15766,15764,15765,15767,15768,15769,15770,15767,15769,15771,15770,15769,15772,15771,15769,15773,15772,15769,15774,15773,15769,15775,15774,15769,15775,15769,15776,15777,15775,15776,15778,15777,15776,15779,15778,15776,15780,15779,15776,15781,15780,15776,15782,15781,15776,15783,15782,15776,15784,15783,15776,15785,15784,15776,15786,15785,15776,15787,15786,15776,15788,15787,15776,15789,15788,15776,15790,15789,15776,15791,15792,15793,15794,15795,15776,15794,15776,15796,15797,15794,15796,15798,15797,15796,15798,15796,15799,15800,15798,15799,15800,15799,15801,15802,15803,15804,15805,15802,15804,15806,15805,15804,15807,15806,15804,15808,15807,15804,15809,15808,15804,15810,15809,15804,15810,15804,15811,15812,15810,15811,15813,15812,15811,15814,15813,15811,15815,15814,15811,15816,15815,15811,15817,15816,15811,15818,15817,15811,15819,15818,15811,15820,15819,15811,15821,15820,15811,15822,15821,15811,15823,15822,15811,15824,15823,15811,15825,15824,15811,15826,15827,15828,15829,15830,15811,15829,15811,15831,15832,15829,15831,15833,15832,15831,15833,15831,15834,15835,15833,15834,15835,15834,15836,15837,15838,15839,15840,15837,15839,15841,15840,15839,15842,15841,15839,15843,15842,15839,15844,15843,15839,15845,15844,15839,15845,15839,15846,15847,15845,15846,15848,15847,15846,15849,15848,15846,15850,15849,15846,15851,15850,15846,15852,15851,15846,15853,15852,15846,15854,15853,15846,15855,15854,15846,15856,15855,15846,15857,15856,15846,15858,15857,15846,15859,15858,15846,15860,15859,15846,15861,15862,15863,15864,15865,15846,15864,15846,15866,15867,15864,15866,15868,15867,15866,15868,15866,15869,15870,15868,15869,15870,15869,15871,15872,15873,15874,15875,15872,15874,15876,15875,15874,15877,15876,15874,15878,15877,15874,15879,15878,15874,15880,15879,15874,15880,15874,15881,15882,15880,15881,15883,15882,15881,15884,15883,15881,15885,15884,15881,15886,15885,15881,15887,15886,15881,15888,15887,15881,15889,15888,15881,15889,15881,15890,15889,15890,15891,15889,15891,15892,15889,15892,15893,15889,15893,15894,15889,15894,15895,15896,15897,15898,15889,15899,15900,15889,15900,15901,15902,15889,15901,15902,15901,15903,15904,15902,15903,15905,15904,15903,15905,15903,15906,15907,15908,15909,15910,15907,15909,15911,15910,15909,15912,15911,15909,15913,15912,15909,15914,15913,15909,15915,15914,15909,15915,15909,15916,15917,15915,15916,15918,15917,15916,15919,15918,15916,15920,15919,15916,15921,15920,15916,15922,15921,15916,15923,15922,15916,15924,15923,15916,15925,15924,15916,15926,15925,15916,15927,15926,15916,15928,15927,15916,15929,15928,15916,15930,15929,15916,15931,15932,15933,15934,15935,15916,15936,15934,15916,15936,15916,15937,15936,15937,15938,15939,15936,15938,15940,15939,15938,15940,15938,15941,15942,15943,15944,15945,15942,15944,15946,15945,15944,15947,15946,15944,15948,15947,15944,15949,15948,15944,15950,15949,15944,15950,15944,15951,15952,15950,15951,15953,15952,15951,15954,15953,15951,15955,15954,15951,15956,15955,15951,15957,15956,15951,15958,15957,15951,15959,15958,15951,15960,15959,15951,15961,15960,15951,15962,15961,15951,15963,15962,15951,15964,15963,15951,15965,15964,15951,15966,15967,15968,15969,15970,15951,15971,15969,15951,15971,15951,15972,15971,15972,15973,15974,15971,15973,15975,15974,15973,15975,15973,15976,15977,15978,15979,15980,15977,15979,15981,15980,15979,15982,15981,15979,15983,15982,15979,15984,15983,15979,15985,15984,15979,15985,15979,15986,15987,15985,15986,15988,15987,15986,15989,15988,15986,15990,15989,15986,15991,15990,15986,15992,15991,15986,15993,15992,15986,15994,15993,15986,15995,15994,15986,15996,15995,15986,15997,15996,15986,15998,15997,15986,15999,15998,15986,16000,15999,15986,16001,16002,16003,16004,16005,15986,16006,16004,15986,16006,15986,16007,16006,16007,16008,16009,16006,16008,16009,16008,16010,16011,16009,16010,16012,16013,16014,16015,16012,16014,16016,16015,16014,16017,16016,16014,16018,16017,16014,16019,16018,16014,16020,16019,16014,16020,16014,16021,16020,16021,16022,16020,16022,16023,16020,16023,16024,16020,16024,16025,16020,16025,16026,16020,16026,16027,16020,16027,16028,16020,16028,16029,16020,16029,16030,16020,16030,16031,16020,16031,16032,16020,16032,16033,16020,16033,16034,16020,16034,16035,16036,16037,16038,16020,16039,16040,16020,16040,16041,16042,16020,16041,16043,16042,16041,16043,16041,16044,16043,16044,16045,16046,16043,16045,16047,16048,16049,16050,16047,16049,16051,16050,16049,16052,16051,16049,16053,16052,16049,16054,16053,16049,16055,16054,16049,16055,16049,16056,16055,16056,16057,16055,16057,16058,16055,16058,16059,16055,16059,16060,16055,16060,16061,16055,16061,16062,16055,16062,16063,16055,16063,16064,16065,16055,16064,16066,16065,16064,16067,16066,16064,16068,16067,16064,16069,16068,16064,16070,16069,16064,16071,16072,16073,16074,16075,16064,16076,16074,16064,16076,16064,16077,16076,16077,16078,16079,16076,16078,16080,16079,16078,16080,16078,16081,16082,16083,16084,16085,16082,16084,16086,16085,16084,16087,16086,16084,16088,16087,16084,16089,16088,16084,16090,16089,16084,16090,16084,16091,16090,16091,16092,16090,16092,16093,16090,16093,16094,16090,16094,16095,16090,16095,16096,16090,16096,16097,16090,16097,16098,16090,16098,16099,16100,16090,16099,16101,16100,16099,16102,16101,16099,16103,16102,16099,16104,16103,16099,16105,16104,16099,16106,16107,16108,16109,16110,16099,16111,16109,16099,16111,16099,16112,16111,16112,16113,16114,16111,16113,16115,16114,16113,16115,16113,16116,16117,16118,16119,16117,16119,16120,16117,16120,16121,16117,16121,16122,16117,16122,16123,16117,16123,16124,16125,16117,16124,16125,16124,16126,16127,16125,16126,16128,16127,16126,16129,16128,16126,16130,16129,16126,16131,16130,16126,16132,16131,16126,16133,16132,16126,16134,16133,16126,16134,16126,16135,16134,16135,16136,16134,16136,16137,16134,16137,16138,16134,16138,16139,16134,16139,16140,16141,16142,16143,16134,16144,16145,16134,16145,16146,16147,16134,16146,16147,16146,16148,16149,16147,16148,16149,16148,16150,16151,16149,16150,16152,16153,16154,16152,16154,16155,16152,16155,16156,16152,16156,16157,16152,16157,16158,16152,16158,16159,16160,16152,16159,16160,16159,16161,16160,16161,16162,16160,16162,16163,16160,16163,16164,16160,16164,16165,16160,16165,16166,16160,16166,16167,16160,16167,16168,16160,16168,16169,16170,16160,16169,16171,16170,16169,16172,16171,16169,16173,16172,16169,16174,16173,16169,16175,16174,16169,16176,16177,16178,16179,16180,16169,16181,16179,16169,16181,16169,16182,16183,16181,16182,16183,16182,16184,16183,16184,16185,16186,16183,16185,16187,16188,16189,16187,16189,16190,16187,16190,16191,16187,16191,16192,16187,16192,16193,16187,16193,16194,16187,16194,16195,16196,16187,16195,16196,16195,16197,16196,16197,16198,16196,16198,16199,16196,16199,16200,16196,16200,16201,16196,16201,16202,16196,16202,16203,16196,16203,16204,16205,16196,16204,16206,16205,16204,16207,16206,16204,16208,16207,16204,16209,16208,16204,16210,16209,16204,16211,16212,16213,16214,16215,16204,16216,16214,16204,16216,16204,16217,16218,16216,16217,16218,16217,16219,16218,16219,16220,16221,16218,16220,16222,16223,16224,16222,16224,16225,16222,16225,16226,16222,16226,16227,16222,16227,16228,16222,16228,16229,16230,16222,16229,16230,16229,16231,16230,16231,16232,16230,16232,16233,16230,16233,16234,16230,16234,16235,16230,16235,16236,16230,16236,16237,16230,16237,16238,16230,16238,16239,16240,16230,16239,16241,16240,16239,16242,16241,16239,16243,16242,16239,16244,16243,16239,16245,16244,16239,16246,16247,16248,16249,16250,16239,16251,16249,16239,16251,16239,16252,16253,16251,16252,16253,16252,16254,16253,16254,16255,16256,16253,16255,16257,16258,16259,16257,16259,16260,16257,16260,16261,16257,16261,16262,16257,16262,16263,16257,16263,16264,16265,16257,16264,16265,16264,16266,16265,16266,16267,16265,16267,16268,16265,16268,16269,16265,16269,16270,16265,16270,16271,16265,16271,16272,16265,16272,16273,16265,16273,16274,16275,16265,16274,16276,16275,16274,16277,16276,16274,16278,16277,16274,16279,16278,16274,16280,16279,16274,16281,16282,16283,16284,16285,16274,16286,16284,16274,16286,16274,16287,16288,16286,16287,16288,16287,16289,16288,16289,16290,16291,16288,16290,16292,16293,16294,16292,16294,16295,16292,16295,16296,16292,16296,16297,16292,16297,16298,16292,16298,16299,16300,16292,16299,16300,16299,16301,16302,16300,16301,16303,16302,16301,16304,16303,16301,16305,16304,16301,16306,16305,16301,16307,16306,16301,16308,16307,16301,16309,16308,16301,16310,16309,16301,16311,16310,16301,16312,16311,16301,16313,16312,16301,16314,16313,16301,16315,16314,16301,16316,16317,16318,16319,16320,16301,16321,16319,16301,16321,16301,16322,16321,16322,16323,16324,16321,16323,16324,16323,16325,16326,16324,16325,16327,16328,16329,16327,16329,16330,16327,16330,16331,16327,16331,16332,16327,16332,16333,16327,16333,16334,16335,16327,16334,16335,16334,16336,16337,16335,16336,16338,16337,16336,16339,16338,16336,16340,16339,16336,16341,16340,16336,16342,16341,16336,16343,16342,16336,16344,16343,16336,16345,16344,16336,16346,16345,16336,16347,16346,16336,16348,16347,16336,16349,16348,16336,16350,16349,16336,16351,16352,16353,16354,16355,16336,16356,16354,16336,16356,16336,16357,16358,16356,16357,16358,16357,16359,16358,16359,16360,16361,16358,16360,16362,16363,16364,16362,16364,16365,16362,16365,16366,16362,16366,16367,16362,16367,16368,16362,16368,16369,16370,16362,16369,16370,16369,16371,16372,16370,16371,16373,16372,16371,16374,16373,16371,16375,16374,16371,16376,16375,16371,16377,16376,16371,16378,16377,16371,16379,16378,16371,16380,16379,16371,16381,16380,16371,16382,16381,16371,16383,16382,16371,16384,16383,16371,16385,16384,16371,16386,16387,16388,16389,16390,16371,16391,16389,16371,16391,16371,16392,16391,16392,16393,16394,16391,16393,16394,16393,16395,16396,16394,16395,16397,16398,16399,16400,16397,16399,16401,16400,16399,16402,16401,16399,16403,16402,16399,16404,16403,16399,16405,16404,16399,16405,16399,16406,16405,16406,16407,16405,16407,16408,16405,16408,16409,16405,16409,16410,16405,16410,16411,16405,16411,16412,16405,16412,16413,16405,16413,16414,16415,16405,16414,16416,16415,16414,16417,16416,16414,16418,16417,16414,16419,16418,16414,16420,16419,16414,16421,16422,16423,16424,16425,16414,16426,16424,16414,16426,16414,16427,16426,16427,16428,16429,16426,16428,16429,16428,16430,16431,16429,16430,16432,16433,16434,16432,16434,16435,16432,16435,16436,16432,16436,16437,16432,16437,16438,16432,16438,16439,16440,16432,16439,16440,16439,16441,16442,16440,16441,16443,16442,16441,16444,16443,16441,16445,16444,16441,16446,16445,16441,16447,16446,16441,16448,16447,16441,16449,16448,16441,16449,16441,16450,16449,16450,16451,16449,16451,16452,16449,16452,16453,16449,16453,16454,16449,16454,16455,16456,16457,16458,16449,16459,16460,16449,16460,16461,16462,16449,16461,16463,16462,16461,16463,16461,16464,16463,16464,16465,16466,16463,16465,16467,16468,16469,16470,16467,16469,16471,16470,16469,16472,16471,16469,16473,16472,16469,16474,16473,16469,16475,16474,16469,16475,16469,16476,16475,16476,16477,16478,16479,16480,16475,16481,16482,16475,16482,16483,16475,16483,16484,16475,16484,16485,16475,16485,16486,16475,16486,16487,16475,16487,16488,16475,16488,16489,16475,16489,16490,16475,16490,16491,16475,16491,16492,16493,16494,16495,16475,16496,16497,16475,16497,16498,16475,16498,16499,16500,16475,16499,16500,16499,16501,16502,16500,16501,16503,16502,16501,16503,16501,16504,16505,16506,16507,16508,16505,16507,16509,16508,16507,16510,16509,16507,16511,16510,16507,16512,16511,16507,16513,16512,16507,16513,16507,16514,16513,16514,16515,16516,16517,16518,16513,16519,16520,16513,16520,16521,16513,16521,16522,16513,16522,16523,16513,16523,16524,16513,16524,16525,16513,16525,16526,16513,16526,16527,16513,16527,16528,16513,16528,16529,16513,16529,16530,16531,16532,16533,16513,16534,16535,16513,16535,16536,16513,16536,16537,16538,16513,16537,16538,16537,16539,16540,16538,16539,16540,16539,16541,16542,16540,16541,16543,16544,16545,16546,16543,16545,16547,16546,16545,16548,16547,16545,16549,16548,16545,16550,16549,16545,16551,16550,16545,16551,16545,16552,16551,16552,16553,16554,16555,16556,16551,16557,16558,16551,16558,16559,16551,16559,16560,16551,16560,16561,16551,16561,16562,16551,16562,16563,16551,16563,16564,16551,16564,16565,16551,16565,16566,16551,16566,16567,16551,16567,16568,16569,16570,16571,16551,16572,16573,16551,16573,16574,16551,16574,16575,16576,16551,16575,16576,16575,16577,16578,16576,16577,16579,16578,16577,16579,16577,16580,16581,16582,16583,16584,16581,16583,16585,16584,16583,16586,16585,16583,16587,16586,16583,16588,16587,16583,16589,16588,16583,16589,16583,16590,16589,16590,16591,16592,16593,16594,16589,16595,16596,16589,16596,16597,16589,16597,16598,16589,16598,16599,16589,16599,16600,16589,16600,16601,16589,16601,16602,16589,16602,16603,16589,16603,16604,16589,16604,16605,16589,16605,16606,16607,16608,16609,16589,16610,16611,16589,16611,16612,16613,16589,16612,16613,16612,16614,16613,16614,16615,16616,16613,16615,16617,16616,16615,16617,16615,16618,16619,16620,16621,16622,16619,16621,16623,16622,16621,16624,16623,16621,16625,16624,16621,16626,16625,16621,16627,16626,16621,16627,16621,16628,16627,16628,16629,16630,16631,16632,16627,16633,16634,16627,16634,16635,16627,16635,16636,16627,16636,16637,16627,16637,16638,16627,16638,16639,16627,16639,16640,16627,16640,16641,16627,16641,16642,16627,16642,16643,16627,16643,16644,16645,16646,16647,16627,16648,16649,16627,16649,16650,16627,16650,16651,16652,16627,16651,16653,16652,16651,16653,16651,16654,16653,16654,16655,16656,16653,16655,16657,16658,16659,16660,16657,16659,16661,16660,16659,16662,16661,16659,16663,16662,16659,16664,16663,16659,16665,16664,16659,16665,16659,16666,16667,16665,16666,16668,16669,16670,16671,16672,16666,16673,16671,16666,16674,16673,16666,16675,16674,16666,16676,16675,16666,16677,16676,16666,16678,16677,16666,16679,16678,16666,16680,16679,16666,16681,16680,16666,16682,16681,16666,16683,16684,16685,16686,16687,16666,16688,16686,16666,16688,16666,16689,16690,16688,16689,16691,16690,16689,16691,16689,16692,16691,16692,16693,16694,16691,16693,16695,16696,16697,16698,16699,16700,16701,16702,16703,16704,16705,16706,16707,16708,16709,16710,16711,16712,16713,16710,16712,16714,16715,16716,16714,16716,16717,16714,16717,16718,16714,16718,16719,16714,16719,16720,16714,16720,16721,16714,16721,16722,16714,16722,16723,16714,16723,16724,16725,16714,16724,16726,16725,16724,16727,16726,16724,16728,16727,16724,16729,16728,16724,16730,16731,16732,16733,16734,16724,16735,16733,16724,16735,16724,16736,16737,16735,16736,16738,16737,16736,16738,16736,16739,16738,16739,16740,16741,16738,16740,16742,16743,16744,16745,16746,16747,16748,16749,16750,16751,16752,16753,16754,16755,16756,16757,16758,16759,16760,16757,16759,16761,16762,16763,16761,16763,16764,16761,16764,16765,16761,16765,16766,16761,16766,16767,16761,16767,16768,16761,16768,16769,16761,16769,16770,16761,16770,16771,16772,16761,16771,16773,16772,16771,16774,16773,16771,16775,16774,16771,16776,16775,16771,16777,16778,16779,16780,16781,16771,16782,16780,16771,16783,16782,16771,16783,16771,16784,16783,16784,16785,16786,16783,16785,16787,16786,16785,16787,16785,16788,16789,16790,16791,16792,16793,16794,16795,16796,16797,16798,16799,16800,16801,16802,16803,16804,16805,16806,16804,16806,16807,16808,16809,16810,16811,16808,16810,16812,16811,16810,16813,16812,16810,16814,16813,16810,16815,16814,16810,16816,16815,16810,16817,16816,16810,16818,16817,16810,16818,16810,16819,16818,16819,16820,16818,16820,16821,16818,16821,16822,16818,16822,16823,16824,16825,16826,16818,16827,16828,16818,16828,16829,16830,16818,16829,16830,16829,16831,16832,16830,16831,16832,16831,16833,16832,16833,16834,16835,16832,16834,16836,16837,16838,16839,16840,16841,16842,16843,16844,16845,16846,16847,16848,16849,16850,16851,16852,16853,16854,16851,16853,16855,16856,16857,16855,16857,16858,16855,16858,16859,16855,16859,16860,16855,16860,16861,16855,16861,16862,16855,16862,16863,16855,16863,16864,16855,16864,16865,16866,16855,16865,16867,16866,16865,16868,16867,16865,16869,16868,16865,16870,16869,16865,16871,16872,16873,16874,16875,16865,16876,16874,16865,16877,16876,16865,16877,16865,16878,16877,16878,16879,16880,16877,16879,16881,16880,16879,16881,16879,16882,16883,16884,16885,16886,16887,16888,16889,16890,16891,16892,16893,16894,16895,16896,16897,16898,16899,16900,16901,16902,16903,16904,16905,16906,16907,16904,16906,16908,16907,16906,16909,16908,16906,16910,16909,16906,16911,16910,16906,16912,16911,16906,16913,16912,16906,16914,16913,16906,16914,16906,16915,16914,16915,16916,16914,16916,16917,16914,16917,16918,16914,16918,16919,16920,16921,16922,16914,16923,16924,16914,16924,16925,16914,16925,16926,16927,16914,16926,16928,16927,16926,16928,16926,16929,16930,16928,16929,16930,16929,16931,16932,16933,16934,16932,16934,16935,16932,16935,16936,16932,16936,16937,16932,16937,16938,16932,16938,16939,16940,16932,16939,16940,16939,16941,16942,16940,16941,16943,16944,16945,16946,16947,16941,16948,16946,16941,16949,16948,16941,16950,16949,16941,16951,16950,16941,16952,16951,16941,16953,16952,16941,16954,16953,16941,16955,16954,16941,16956,16955,16941,16957,16956,16941,16958,16959,16960,16961,16962,16941,16963,16961,16941,16963,16941,16964,16965,16963,16964,16966,16965,16964,16966,16964,16967,16968,16966,16967,16968,16967,16969,16970,16971,16972,16973,16970,16972,16974,16973,16972,16975,16974,16972,16976,16975,16972,16977,16976,16972,16978,16977,16972,16978,16972,16979,16978,16979,16980,16978,16980,16981,16978,16981,16982,16978,16982,16983,16978,16983,16984,16978,16984,16985,16978,16985,16986,16978,16986,16987,16978,16987,16988,16978,16988,16989,16978,16989,16990,16978,16990,16991,16978,16991,16992,16978,16992,16993,16978,16993,16994,16978,16994,16995,16996,16978,16995,16996,16995,16997,16996,16997,16998,16999,16996,16998,16999,16998,17000,17001,16999,17000,17002,17003,17004,17005,17002,17004,17006,17005,17004,17007,17006,17004,17008,17007,17004,17009,17008,17004,17009,17004,17010,17011,17009,17010,17012,17011,17010,17013,17012,17010,17014,17013,17010,17015,17014,17010,17016,17015,17010,17017,17016,17010,17018,17017,17010,17019,17018,17010,17019,17010,17020,17019,17020,17021,17019,17021,17022,17019,17022,17023,17019,17023,17024,17019,17024,17025,17019,17025,17026,17019,17026,17027,17019,17027,17028,17029,17019,17028,17030,17029,17028,17030,17028,17031,17032,17030,17031,17032,17031,17033,17034,17035,17036,17037,17034,17036,17038,17037,17036,17039,17038,17036,17040,17039,17036,17041,17040,17036,17042,17041,17036,17042,17036,17043,17042,17043,17044,17042,17044,17045,17042,17045,17046,17042,17046,17047,17042,17047,17048,17042,17048,17049,17042,17049,17050,17042,17050,17051,17042,17051,17052,17042,17052,17053,17042,17053,17054,17042,17054,17055,17042,17055,17056,17042,17056,17057,17042,17057,17058,17042,17058,17059,17042,17059,17060,17061,17042,17060,17061,17060,17062,17063,17061,17062,17063,17062,17064,17065,17063,17064,17066,17067,17068,17069,17066,17068,17070,17069,17068,17071,17070,17068,17072,17071,17068,17073,17072,17068,17074,17073,17068,17074,17068,17075,17074,17075,17076,17074,17076,17077,17074,17077,17078,17074,17078,17079,17074,17079,17080,17074,17080,17081,17074,17081,17082,17074,17082,17083,17074,17083,17084,17074,17084,17085,17074,17085,17086,17074,17086,17087,17074,17087,17088,17074,17088,17089,17074,17089,17090,17074,17090,17091,17074,17091,17092,17093,17074,17092,17093,17092,17094,17095,17093,17094,17096,17095,17094,17096,17094,17097,17098,17099,17100,17101,17098,17100,17102,17101,17100,17103,17102,17100,17104,17103,17100,17105,17104,17100,17106,17105,17100,17106,17100,17107,17106,17107,17108,17106,17108,17109,17106,17109,17110,17106,17110,17111,17106,17111,17112,17106,17112,17113,17106,17113,17114,17106,17114,17115,17106,17115,17116,17106,17116,17117,17106,17117,17118,17106,17118,17119,17106,17119,17120,17106,17120,17121,17106,17121,17122,17106,17122,17123,17106,17123,17124,17125,17106,17124,17125,17124,17126,17127,17125,17126,17128,17127,17126,17128,17126,17129,17130,17131,17132,17130,17132,17133,17130,17133,17134,17130,17134,17135,17130,17135,17136,17130,17136,17137,17130,17137,17138,17139,17130,17138,17140,17139,17138,17141,17140,17138,17142,17141,17138,17143,17142,17138,17144,17143,17138,17145,17144,17138,17146,17145,17138,17147,17146,17138,17147,17138,17148,17147,17148,17149,17147,17149,17150,17147,17150,17151,17147,17151,17152,17147,17152,17153,17147,17153,17154,17147,17154,17155,17156,17147,17155,17156,17155,17157,17156,17157,17158,17159,17156,17158,17160,17159,17158,17160,17158,17161,17162,17163,17164,17165,17162,17164,17166,17165,17164,17167,17166,17164,17168,17167,17164,17169,17168,17164,17169,17164,17170,17171,17169,17170,17172,17171,17170,17173,17172,17170,17174,17173,17170,17175,17174,17170,17176,17175,17170,17177,17176,17170,17178,17177,17170,17179,17178,17170,17180,17179,17170,17181,17180,17170,17182,17181,17170,17183,17182,17170,17184,17183,17170,17185,17184,17170,17186,17185,17170,17187,17186,17170,17188,17187,17170,17188,17170,17189,17188,17189,17190,17191,17188,17190,17192,17191,17190,17192,17190,17193,17194,17195,17196,17197,17194,17196,17198,17197,17196,17199,17198,17196,17200,17199,17196,17201,17200,17196,17202,17201,17196,17202,17196,17203,17202,17203,17204,17202,17204,17205,17202,17205,17206,17202,17206,17207,17202,17207,17208,17202,17208,17209,17202,17209,17210,17202,17210,17211,17212,17202,17211,17213,17212,17211,17214,17213,17211,17215,17214,17211,17216,17215,17211,17217,17216,17211,17218,17217,17211,17219,17218,17211,17220,17219,17211,17220,17211,17221,17220,17221,17222,17223,17220,17222,17223,17222,17224,17225,17223,17224,17226,17227,17228,17226,17228,17229,17226,17229,17230,17226,17230,17231,17226,17231,17232,17226,17232,17233,17226,17233,17234,17235,17226,17234,17236,17235,17234,17237,17236,17234,17238,17237,17234,17239,17238,17234,17240,17239,17234,17241,17240,17234,17242,17241,17234,17243,17242,17234,17243,17234,17244,17243,17244,17245,17243,17245,17246,17243,17246,17247,17243,17247,17248,17243,17248,17249,17243,17249,17250,17243,17250,17251,17252,17243,17251,17252,17251,17253,17254,17252,17253,17254,17253,17255,17254,17255,17256,17257,17254,17256,17258,17259,17260,17261,17258,17260,17262,17261,17260,17263,17262,17260,17264,17263,17260,17265,17264,17260,17266,17265,17260,17266,17260,17267,17266,17267,17268,17266,17268,17269,17266,17269,17270,17266,17270,17271,17266,17271,17272,17266,17272,17273,17266,17273,17274,17266,17274,17275,17266,17275,17276,17266,17276,17277,17266,17277,17278,17266,17278,17279,17266,17279,17280,17266,17280,17281,17266,17281,17282,17266,17282,17283,17266,17283,17284,17285,17266,17284,17286,17285,17284,17286,17284,17287,17288,17286,17287,17288,17287,17289,17290,17291,17292,17290,17292,17293,17294,17295,17296,17294,17296,17297,17298,17299,17300,17298,17300,17301,17302,17303,17304,17302,17304,17305,17306,17307,17308,17309,17310,17311,17312,17313,17314,17315,17316,17317,17318,17319,17320,17321,17322,17323,17324,17325,17326,17324,17326,17327,17328,17329,17330,17328,17330,17331,17332,17333,17334,17332,17334,17335,17336,17337,17338,17336,17338,17339,17340,17341,17342,17340,17342,17343,17344,17345,17346,17347,17348,17349,17350,17351,17352,17353,17354,17355,17356,17357,17358,17356,17358,17359,17360,17361,17362,17360,17362,17363,17364,17365,17366,17364,17366,17367,17368,17369,17370,17369,17368,17371,17372,17373,17374,17372,17375,17373,17372,17376,17375,17372,17377,17376,17372,17378,17377,17372,17379,17378,17372,17380,17379,17372,17381,17380,17372,17382,17381,17372,17383,17382,17384,17383,17372,17385,17383,17384,17386,17383,17385,17387,17388,17389,17390,17387,17389,17391,17392,17393,17394,17395,17396,17397,17398,17399,17400,17401,17402,17403,17404,17405,17406,17407,17408,17390,17409,17410,17390,17410,17411,17412,17413,17414,17415,17416,17417,17418,17419,17420,17421,17422,17423,17424,17425,17426,17427,17428,17429,17429,17430,17427,17431,17432,17433,17434,17435,17436,17437,17438,17439,17440,17441,17442,17443,17444,17445,17446,17447,17448,17449,17450,17451,17452,17453,17454,17455,17456,17457,17458,17459,17460,17461,17462,17463,17464,17465,17466,17467,17468,17469,17470,17471,17472,17473,17474,17475,17476,17477,17478,17479,17480,17481,17482,17483,17484,17485,17486,17487,17488,17489,17490,17491,17492,17493,17494,17495,17496,17497,17498,17499,17500,17501,17502,17503,17504,17505,17506,17507,17508,17509,17510,17511,17512,17513,17514,17515,17516,17517,17518,17519,17520,17521,17522,17523,17524,17525,17526,17527,17528,17529,17530,17531,17532,17533,17534,17535,17536,17537,17538,17539,17540,17541,17542,17543,17544,17545,17546,17547,17548,17549,17550,17551,17552,17553,17554,17555,17556,17557,17558,17559,17560,17561,17562,17563,17564,17565,17566,17567,17568,17569,17570,17571,17572,17573,17574,17575,17576,17577,17578,17579,17580,17581,17582,17583,17584,17585,17586,17587,17588,17589,17590,17591,17592,17593,17594,17595,17596,17597,17598,17599,17600,17601,17602,17603,17604,17605,17606,17607,17608,17609,17610,17611,17612,17613,17614,17615,17616,17617,17618,17619,17619,17620,17621,17622,17623,17624,17625,17626,17627,17628,17629,17630,17631,17632,17633,17634,17635,17636,17637,17638,17639,17640,17641,17642,17643,17644,17645,17646,17647,17648,17649,17650,17651,17652,17653,17654,17655,17656,17657,17658,17659,17660,17660,17661,17658,17662,17663,17664,17665,17666,17667,17668,17669,17670,17671,17672,17673,17674,17675,17676,17677,17678,17679,17680,17681,17682,17683,17684,17685,17686,17687,17688,17689,17690,17691,17692,17693,17694,17695,17696,17697,17698,17699,17700,17701,17702,17703,17704,17705,17706,17707,17708,17709,17710,17711,17712,17713,17714,17715,17716,17717,17718,17719,17720,17721,17722,17723,17724,17725,17726,17727,17728,17729,17730,17731,17732,17733,17734,17735,17736,17737,17738,17739,17740,17741,17742,17743,17744,17745,17746,17747,17748,17749,17750,17751,17752,17753,17754,17755,17756,17757,17758,17759,17760,17761,17762,17763,17764,17765,17766,17767,17768,17769,17770,17771,17772,17773,17774,17775,17776,17777,17778,17779,17780,17781,17782,17783,17784,17785,17786,17787,17788,17789,17790,17791,17792,17793,17794,17795,17796,17796,17797,17794,17798,17799,17800,17801,17802,17803,17804,17805,17806,17807,17808,17809,17810,17811,17812,17813,17814,17815,17816,17817,17818,17819,17820,17821,17822,17823,17824,17825,17826,17827,17828,17829,17830,17830,17831,17828,17832,17833,17834,17835,17836,17837,17838,17839,17840,17841,17842,17843,17844,17845,17846,17847,17848,17849,17850,17851,17852,17853,17854,17855,17856,17857,17858,17859,17860,17861,17862,17863,17864,17864,17865,17866,17867,17868,17869,17870,17871,17872,17873,17874,17875,17876,17877,17878,17879,17880,17881,17881,17882,17879,17883,17884,17885,17886,17887,17888,17889,17890,17891,17892,17893,17894,17895,17896,17897,17897,17898,17899,17900,17901,17902,17903,17904,17905,17906,17907,17908,17909,17910,17911,17912,17913,17914,17915,17916,17917,17918,17919,17920,17921,17922,17923,17924,17925,17926,17927,17928,17929,17930,17931,17932,17933,17934,17935,17936,17937,17938,17939,17940,17941,17942,17943,17944,17945,17946,17947,17948,17949,17950,17951,17952,17953,17954,17955,17956,17957,17958,17959,17960,17961,17962,17960,17962,17963,17964,17965,17966,17967,17968,17969,17970,17971,17972,17973,17974,17975,17976,17977,17978,17979,17980,17981,17982,17983,17984,17985,17986,17987,17988,17989,17990,17991,17992,17993,17994,17995,17996,17997,17998,17999,18000,18001,18002,18003,18004,18005,18006,18007,18008,18009,18010,18011,18012,18013,18014,18015,18016,18017,18018,18019,18020,18021,18022,18023,18024,18025,18026,18027,18028,18029,18030,18031,18032,18033,18034,18035,18036,18037,18038,18039,18040,18041,18042,18043,18044,18045,18046,18047,18048,18049,18050,18051,18052,18053,18054,18055,18056,18057,18058,18059,18060,18061,18062,18063,18064,18065,18066,18067,18068,18069,18070,18071,18072,18073,18074,18075,18076,18077,18078,18079,18080,18081,18082,18083,18084,18085,18086,18087,18088,18089,18087,18089,18090,18091,18092,18093,18094,18095,18096,18097,18098,18099,18100,18101,18102,18103,18104,18105,18106,18107,18108,18109,18110,18111,18112,18113,18114,18115,18116,18117,18118,18119,18120,18121,18122,18123,18124,18125,18126,18127,18128,18129,18130,18131,18132,18133,18134,18135,18136,18137,18138,18138,18139,18136,18140,18141,18142,18142,18143,18140,18144,18145,18146,18147,18148,18149,18150,18151,18152,18153,18154,18155,18156,18157,18158,18159,18160,18161,18162,18163,18164,18165,18166,18167,18168,18169,18170,18171,18172,18173,18174,18175,18176,18177,18178,18179,18180,18181,18182,18183,18184,18185,18186,18187,18188,18189,18190,18191,18192,18193,18194,18195,18196,18197,18198,18199,18200,18201,18202,18203,18204,18205,18206,18207,18208,18209,18210,18211,18212,18213,18214,18215,18216,18217,18218,18219,18220,18221,18222,18223,18224,18225,18226,18227,18228,18229,18230,18231,18232,18233,18234,18235,18236,18237,18238,18239,18240,18241,18242,18243,18244,18245,18246,18247,18248,18249,18250,18251,18252,18253,18254,18255,18256,18257,18258,18259,18260,18261,18262,18263,18264,18265,18266,18267,18268,18269,18270,18271,18269,18272,18273,18274,18275,18276,18277,18278,18279,18280,18281,18282,18283,18284,18285,18283,18286,18283,18287,18288,18289,18290,18287,18291,18292,18293,18294,18295,18296,18297,18298,18299,18300,18301,18302,18303,18304,18305,18306,18307,18308,18309,18310,18311,18312,18313,18314,18315,18316,18317,18318,18319,18320,18321,18322,18320,18322,18323,18324,18325,18326,18324,18326,18327,18328,18329,18330,18328,18330,18331,18332,18333,18334,18332,18334,18335,18336,18337,18338,18336,18338,18339,18340,18341,18342,18340,18342,18343,18344,18345,18346,18344,18346,18347,18348,18349,18350,18348,18350,18351,18352,18353,18354,18352,18354,18355,18356,18357,18358,18356,18358,18359,18360,18361,18362,18360,18362,18363,18364,18365,18366,18364,18366,18367,18368,18369,18370,18368,18370,18371,18372,18373,18374,18372,18374,18375,18376,18377,18378,18376,18378,18379,18380,18381,18382,18380,18382,18383,18384,18385,18386,18384,18386,18387,18388,18389,18390,18388,18391,18392,18393,18394,18395,18396,18397,18398,18399,18400,18401,18402,18403,18404,18405,18406,18407,18408,18409,18410,18411,18412,18413,18414,18415,18416,18417,18418,18419,18420,18421,18422,18423,18424,18425,18426,18427,18428,18429,18430,18431,18432,18433,18434,18435,18436,18437,18438,18439,18440,18441,18442,18443,18444,18445,18446,18447,18448,18449,18450,18451,18452,18453,18454,18455,18456,18457,18458,18459,18460,18461,18462,18463,18464,18465,18466,18467,18468,18469,18470,18471,18472,18473,18474,18475,18476,18477,18478,18479,18480,18481,18482,18483,18484,18485,18486,18487,18488,18489,18490,18491,18492,18493,18494,18495,18496,18497,18498,18499,18500,18501,18502,18503,18504,18505,18506,18507,18508,18509,18510,18511,18512,18513,18514,18515,18516,18517,18518,18519,18520,18521,18522,18523,18524,18525,18526,18527,18528,18529,18530,18531,18532,18533,18534,18535,18536,18536,18537,18538,18539,18540,18541,18542,18543,18544,18545,18546,18547,18548,18549,18545,18550,18551,18552,18552,18553,18554,18555,18556,18557,18557,18558,18555,18559,18560,18561,18561,18562,18559,18563,18564,18565,18565,18566,18567,18568,18569,18570,18570,18571,18572,18573,18574,18575,18575,18576,18573,18577,18578,18579,18579,18580,18581,18582,18583,18584,18584,18585,18586,18587,18588,18589,18589,18590,18587,18591,18592,18593,18594,18595,18596,18597,18598,18599,18600,18601,18602,18603,18604,18605,18606,18607,18608,18609,18610,18611,18611,18612,18609,18613,18614,18615,18616,18617,18618,18618,18619,18616,18620,18621,18622,18623,18624,18625,18626,18627,18628,18629,18630,18631,18632,18633,18634,18635,18636,18637,18638,18639,18640,18641,18642,18643,18644,18645,18646,18647,18648,18649,18650,18651,18652,18653,18654,18655,18656,18657,18658,18659,18660,18661,18662,18663,18664,18665,18666,18667,18668,18669,18670,18671,18672,18673,18674,18675,18676,18677,18678,18679,18680,18681,18682,18683,18684,18685,18686,18687,18688,18689,18690,18691,18692,18693,18694,18695,18696,18697,18698,18699,18700,18701,18702,18703,18704,18705,18706,18707,18708,18709,18710,18711,18712,18713,18714,18715,18716,18717,18718,18719,18720,18721,18722,18723,18724,18725,18726,18727,18728,18729,18730,18731,18732,18733,18734,18735,18736,18737,18738,18739,18740,18741,18742,18743,18744,18745,18746,18747,18748,18749,18750,18751,18752,18753,18754,18755,18756,18757,18758,18759,18760,18761,18762,18763,18764,18765,18766,18767,18768,18769,18770,18771,18772,18773,18774,18775,18776,18777,18778,18779,18780,18781,18782,18783,18784,18785,18786,18787,18788,18789,18790,18791,18792,18793,18794,18795,18796,18796,18797,18794,18798,18799,18800,18801,18802,18803,18804,18805,18806,18807,18808,18809,18810,18811,18812,18813,18814,18815,18816,18817,18818,18819,18820,18821,18822,18823,18824,18825,18826,18827,18828,18829,18830,18831,18832,18833,18834,18835,18836,18837,18838,18839,18840,18841,18842,18843,18844,18845,18846,18847,18848,18849,18850,18851,18851,18852,18849,18853,18854,18855,18856,18857,18858,18859,18860,18861,18862,18863,18864,18865,18866,18867,18868,18869,18870,18871,18872,18873,18874,18875,18876,18877,18878,18879,18880,18881,18882,18883,18884,18885,18886,18887,18888,18889,18890,18891,18892,18893,18894,18895,18896,18897,18898,18899,18900,18901,18902,18903,18904,18905,18906,18907,18908,18909,18910,18911,18912,18913,18914,18915,18916,18917,18918,18919,18920,18921,18922,18923,18924,18925,18926,18927,18927,18928,18925,18929,18930,18931,18932,18933,18934,18935,18936,18937,18938,18939,18940,18941,18942,18943,18944,18945,18946,18947,18948,18949,18950,18951,18952,18953,18954,18955,18956,18957,18958,18959,18960,18961,18962,18963,18964,18965,18966,18967,18968,18969,18970,18971,18972,18973,18974,18975,18976,18977,18978,18979,18980,18981,18982,18983,18984,18985,18985,18986,18983,18987,18988,18989,18990,18991,18992,18993,18994,18995,18996,18997,18998,18999,19000,19001,19002,19003,19004,19005,19006,19007,19008,19009,19010,19011,19012,19013,19014,19015,19016,19017,19018,19019,19020,19021,19022,19023,19024,19025,19026,19027,19028,19029,19030,19031,19032,19033,19034,19035,19036,19037,19038,19039,19040,19041,19042,19043,19044,19045,19046,19046,19047,19044,19048,19049,19050,19051,19052,19053,19053,19054,19051,19055,19056,19057,19058,19059,19055,19060,19061,19062,19063,19064,19060,19065,19066,19067,19068,19069,19065,19070,19071,19072,19073,19074,19070,19075,19076,19077,19078,19079,19075,19080,19081,19082,19083,19084,19080,19085,19086,19087,19088,19089,19085,19090,19091,19092,19093,19094,19090,19095,19096,19097,19098,19099,19095,19100,19101,19102,19103,19104,19100,19105,19106,19107,19108,19109,19110,19111,19112,19113,19114,19115,19111,19116,19117,19118,19119,19120,19121,19122,19123,19124,19125,19126,19127,19128,19129,19130,19131,19132,19133,19134,19135,19136,19137,19138,19139,19140,19141,19142,19143,19144,19145,19146,19147,19143,19148,19149,19150,19150,19151,19148,19152,19153,19154,19155,19156,19157,19158,19159,19160,19160,19161,19158,19162,19163,19164,19164,19165,19162,19166,19167,19168,19168,19169,19166,19170,19171,19172,19173,19174,19175,19176,19177,19178,19178,19179,19180,19181,19182,19183,19183,19184,19185,19186,19187,19188,19188,19189,19186,19190,19191,19192,19192,19193,19190,19194,19195,19196,19196,19197,19194,19198,19199,19200,19201,19202,19203,19204,19205,19206,19207,19208,19209,19210,19211,19212,19213,19214,19215,19216,19213,19217,19218,19219,19220,19221,19222,19223,19224,19225,19226,19227,19228,19229,19230,19231,19232,19232,19233,19234,19235,19236,19237,19238,19239,19240,19241,19242,19243,19244,19245,19246,19247,19248,19249,19250,19251,19247,19252,19253,19254,19254,19255,19256,19241,19044,19047,19047,19242,19241,19257,19258,19259,19260,19261,19262,19263,19264,19265,19266,19238,19267,19267,19268,19269,19270,19271,19272,19273,19274,19275,19276,19277,19278,19279,19280,19276,19281,19282,19283,19284,19285,19286,19287,19288,19289,19290,19291,19292,19293,19294,19295,19296,19297,19298,19299,19300,19301,19302,19303,19304,19305,19306,19307,19308,19309,19310,19311,19312,19313,19314,19315,19316,19317,19318,19319,19320,19321,19317,19322,19323,19324,19325,19326,19327,19328,19329,19330,19331,19332,19333,19334,19335,19187,19187,19336,19334,19192,19337,19338,19339,19340,19341,19342,19194,19343,19344,19345,19346,19347,19202,19348,19349,19350,19351,19352,19353,19354,19355,19356,19357,19358,19359,19360,19361,19362,19363,19364,19365,19366,19367,19368,19369,19370,19369,19371,19372,19371,19373,19374,19373,19375,19376,19375,19377,19378,19377,19379,19380,19379,19381,19382,19381,19383,19384,19383,19385,19386,19385,19387,19388,19387,19389,19390,19389,19391,19392,19391,19393,19394,19393,19395,19396,19395,19397,19398,19397,19399,19400,19399,19401,19402,19403,19404,19402,19405,19406,19407,19402,19408,19409,19407,19410,19411,19409,19412,19413,19411,19414,19415,19413,19416,19417,19415,19418,19419,19417,19420,19421,19419,19422,19423,19421,19424,19425,19423,19426,19427,19428,19429,19430,19431,19432,19433,19434,19435,19436,19437,19438,19425,19439,19440,19441,19442,19443,19444,19445,19446,19447,19444,19448,19449,19447,19450,19451,19449,19452,19453,19451,19454,19455,19456,19457,19453,19458,19459,19460,19453,19461,19460,19462,19463,19464,19460,19465,19464,19466,19467,19401,19464,19468,19469,19401,19470,19471,19472,19473,19474,19475,19476,19477,19478,19479,19480,19481,19482,19483,19484,19485,19486,19487,19488,19489,19490,19491,19492,19493,19494,19495,19496,19497,19498,19499,19500,19501,19502,19503,19504,19505,19506,19507,19508,19509,19510,19511,19512,19513,19514,19515,19516,19517,19518,19519,19520,19521,19522,19523,19524,19525,19526,19527,19528,19529,19530,19531,19532,19533,19534,19535,19536,19537,19538,19539,19540,19541,19542,19543,19544,19545,19546,19547,19548,19548,19549,19550,19551,19547,19552,19553,19554,19555,19556,19557,19558,19559,19560,19561,19562,19563,19564,19565,19566,19567,19568,19569,19570,19571,19572,19573,19574,19575,19576,19577,19578,19579,19580,19581,19582,19583,19584,19585,19586,19587,19588,19589,19590,19591,19592,19593,19594,19595,19596,19597,19598,19599,19600,19601,19602,19603,19604,19605,19606,19607,19608,19609,19610,19611,19612,19613,19614,19615,19613,19616,19617,19618,19619,19620,19621,19622,19623,19624,19625,19626,19626,19627,19624,19628,19629,19630,19631,19632,19628,19633,19634,19635,19636,19637,19638,19636,19638,19639,19640,19641,19642,19643,19644,19645,19646,19647,19648,19649,19650,19651,19652,19653,19654,19655,19656,19657,19658,19659,19660,19661,19662,19663,19664,19665,19666,19667,19668,19669,19670,19671,19672,19673,19674,19675,19676,19677,19678,19679,19680,19681,19682,19683,19684,19685,19686,19687,19688,19689,19690,19691,19692,19693,19694,19695,19696,19697,19696,19698,19699,19700,19697,19701,19702,19703,19704,19705,19706,19707,19708,19709,19710,19711,19712,19713,19714,19715,19716,19717,19718,19719,19720,19721,19722,19721,19723,19724,19725,19726,19727,19728,19729,19730,19731,19732,19733,19734,19735,19736,19737,19738,19739,19740,19741,19742,19743,19744,19745,19746,19747,19748,19747,19749,19750,19751,19752,19753,19754,19755,19756,19757,19758,19759,19760,19761,19762,19763,19764,19765,19766,19767,19768,19769,19770,19771,19772,19773,19774,19775,19776,19776,19777,19774,19778,19779,19780,19781,19782,19783,19784,19785,19786,19787,19788,19789,19790,19791,19792,19793,19794,19795,19796,19797,19798,19799,19800,19801,19802,19803,19804,19805,19806,19807,19808,19809,19810,19810,19811,19808,19812,19813,19814,19815,19816,19817,19818,19819,19820,19820,19821,19818,19822,19823,19824,19825,19826,19827,19828,19829,19830,19831,19832,19833,19834,19835,19836,19837,19838,19839,19840,19841,19842,19843,19844,19845,19846,19847,19848,19849,19850,19851,19852,19853,19854,19855,19856,19857,19858,19859,19860,19861,19862,19863,19864,19865,19866,19866,19867,19864,19868,19869,19870,19871,19872,19873,19872,19874,19875,19876,19877,19878,19877,19876,19879,19880,19881,19882,19883,19884,19885,19886,19887,19888,19889,19890,19891,19892,19893,19894,19895,19896,19897,19898,19899,19900,19901,19902,19903,19904,19905,19906,19907,19908,19909,19910,19911,19912,19913,19914,19915,19916,19917,19918,19919,19920,19921,19922,19923,19924,19925,19926,19927,19928,19929,19930,19931,19932,19933,19934,19935,19936,19937,19938,19939,19940,19941,19942,19943,19944,19945,19946,19947,19948,19949,19950,19951,19951,19952,19953,19954,19955,19956,19957,19958,19959,19960,19961,19962,19963,19964,19965,19966,19967,19968,19969,19970,19971,19972,19973,19974,19975,19976,19977,19978,19979,19980,19980,19981,19982,19983,19984,19985,19986,19987,19988,19989,19990,19991,19992,19993,19994,19995,19996,19997,19998,19999,20000,20001,20002,20003,20004,20005,20006,20007,20008,20009,20010,20011,20012,20013,20014,20015,20016,20017,20018,20019,20020,20021,20022,20023,20024,20025,20026,20027,20028,20029,20030,20031,20032,20033,20034,20035,20036,20037,20038,20039,20040,20041,20042,20043,20044,20045,20045,20046,20047,20048,20049,20050,20051,20052,20053,20054,20055,20056,20057,20058,20059,20060,20061,20062,20063,20064,20065,20066,20067,20068,20069,20070,20071,20072,20073,20074,20075,20076,20077,20078,20079,20080,20081,20082,20083,20084,20085,20086,20087,20088,20089,20090,20091,20092,20092,20093,20094,20095,20096,20097,20098,20099,20100,20101,20098,20102,20103,20104,20105,20104,20103,20106,20107,20108,20109,20110,20111,20112,20113,20114,20115,20116,20117,20118,20119,20120,20121,20122,20123,20124,20125,20126,20127,20128,20129,20130,20131,20132,20133,20134,20135,20136,20137,20138,20139,20140,20141,20142,20143,20144,20145,20146,20147,20148,20149,20150,20151,20152,20153,20154,20155,20156,20157,20158,20159,20160,20161,20162,20163,20164,20165,20166,20167,20168,20169,20170,20171,20172,20173,20174,20175,20176,20177,20178,20179,20180,20181,20182,20183,20184,20185,20186,20187,20188,20189,20190,20191,20192,20193,20194,20195,20196,20197,20198,20199,20200,20201,20202,20203,20204,20205,20206,20207,20208,20208,20209,20206,20210,20211,20212,20213,20214,20215,20216,20217,20218,20219,20220,20221,20222,20223,20224,20225,20226,20227,20228,20229,20230,20231,20232,20233,20234,20235,20236,20237,20238,20239,20240,20241,20242,20243,20244,20245,20246,20247,20248,20249,20250,20251,20252,20253,20254,20255,20256,20257,20258,20259,20260,20261,20262,20263,20264,20265,20266,20267,20268,20269,20270,20271,20272,20273,20274,20275,20276,20277,20278,20279,20280,20281,20282,20283,20284,20285,20286,20287,20288,20289,20290,20291,20292,20293,20294,20295,20296,20297,20298,20299,20300,20301,20302,20303,20304,20305,20306,20307,20308,20309,20310,20311,20312,20313,20314,20315,20316,20317,20318,20319,20320,20321,20322,20323,20324,20325,20326,20327,20328,20329,20330,20331,20332,20333,20334,20335,20336,20337,20338,20339,20340,20336,20341,20342,20343,20344,20345,20346,20347,20348,20349,20350,20351,20352,20353,20354,20355,20356,20357,20358,20359,20360,20361,20362,20363,20364,20365,20366,20367,20368,20369,20370,20371,20372,20373,20374,20375,20376,20377,20378,20379,20380,20381,20382,20383,20384,20385,20386,20387,20388,20389,20390,20391,20392,20393,20394,20395,20396,20397,20398,20399,20400,20401,20402,20403,20404,20405,20406,20407,20408,20409,20410,20411,20412,20413,20414,20415,20416,20417,20418,20419,20420,20421,20422,20423,20424,20425,20426,20427,20428,20429,20430,20431,20432,20433,20434,20435,20436,20437,20438,20439,20440,20441,20442,20443,20444,20445,20446,20447,20448,20449,20450,20451,20452,20453,20454,20455,20456,20457,20458,20459,20460,20461,20462,20463,20464,20465,20466,20467,20468,20469,20469,20470,20471,20472,20473,20474,20475,20476,20477,20478,20479,20480,20480,20481,20482,20483,20484,20485,20486,20487,20488,20489,20490,20491,20491,20492,20489,20493,20494,20495,20496,20497,20498,20499,20500,20501,20502,20503,20504,20505,20506,20507,20508,20509,20505,20505,20510,20511,20512,20506,20505,20513,20514,20515,20516,20517,20518,20519,20520,20521,20522,20523,20524,20525,20526,20527,20528,20529,20530,20531,20532,20533,20534,20535,20536,20537,20538,20539,20540,20541,20542,20543,20544,20545,20546,20547,20548,20549,20550,20551,20552,20553,20554,20555,20556,20557,20557,20558,20559,20560,20561,20557,20557,20562,20560,20563,20564,20565,20566,20561,20567,20568,20569,20570,20571,20572,20573,20574,20575,20576,20577,20578,20579,20580,20581,20582,20583,20584,20585,20586,20587,20588,20589,20590,20591,20592,20593,20594,20594,20595,20596,20597,20598,20599,20600,20601,20597,20602,20603,20604,20605,20606,20607,20608,20609,20610,20603,20611,20612,20613,20614,20615,20609,20616,20617,20618,20619,20620,20621,20622,20623,20624,20625,20626,20627,20628,20629,20630,20631,20632,20633,20634,20635,20636,20637,20638,20639,20640,20641,20642,20643,20644,20645,20646,20647,20648,20649,20650,20651,20652,20653,20654,20655,20656,20657,20658,20659,20660,20661,20662,20663,20664,20665,20666,20667,20668,20669,20670,20671,20672,20673,20674,20675,20676,20677,20678,20679,20680,20681,20682,20683,20684,20685,20686,20687,20688,20689,20690,20691,20692,20693,20694,20695,20696,20697,20698,20699,20700,20701,20702,20703,20704,20705,20706,20707,20708,20709,20710,20711,20712,20713,20714,20715,20716,20717,20718,20719,20720,20721,20722,20723,20724,20725,20726,20727,20728,20729,20730,20731,20732,20733,20734,20735,20736,20737,20738,20739,20740,20741,20742,20743,20744,20745,20746,20747,20748,20749,20750,20751,20752,20753,20754,20755,20756,20757,20758,20759,20760,20761,20762,20763,20764,20765,20766,20767,20768,20769,20770,20771,20772,20773,20774,20775,20776,20777,20778,20779,20780,20781,20782,20783,20784,20785,20786,20787,20788,20789,20790,20791,20792,20793,20794,20795,20796,20797,20798,20799,20800,20801,20802,20803,20804,20805,20806,20807,20808,20809,20810,20811,20812,20813,20814,20815,20816,20817,20818,20819,20820,20821,20822,20823,20824,20825,20826,20827,20828,20829,20830,20831,20832,20833,20834,20835,20836,20837,20838,20839,20840,20837,20841,20842,20843,20844,20845,20846,20847,20848,20849,20850,20851,20852,20853,20854,20855,20856,20857,20858,20859,20860,20861,20862,20863,20864,20865,20866,20867,20868,20869,20870,20871,20872,20873,20874,20875,20876,20877,20878,20879,20880,20881,20882,20883,20884,20885,20886,20887,20888,20889,20890,20891,20892,20893,20894,20895,20896,20897,20898,20899,20900,20901,20902,20903,20904,20905,20906,20907,20908,20909,20910,20911,20912,20913,20914,20915,20916,20917,20918,20914,20919,20920,20921,20922,20923,20924,20925,20926,20927,20928,20929,20930,20931,20932,20933,20934,20935,20936,20937,20938,20939,20940,20941,20942,20943,20944,20945,20946,20947,20948,20949,20950,20951,20952,20953,20954,20955,20956,20957,20958,20959,20960,20961,20962,20963,20964,20965,20966,20967,20968,20969,20970,20971,20972,20973,20974,20975,20976,20977,20978,20979,20980,20981,20982,20983,20984,20985,20986,20987,20988,20989,20990,20991,20992,20993,20994,20995,20996,20997,20998,20999,21000,21001,21002,21003,21004,21005,21006,21007,21008,21009,21010,21011,21012,21013,21014,21015,21016,21017,21018,21019,21020,21021,21022,21023,21024,21025,21026,21027,21028,21029,21030,21031,21032,21033,21034,21035,21036,21037,21038,21039,21040,21041,21042,21043,21044,21045,21046,21047,21048,21049,21050,21051,21052,21053,21054,21055,21056,21057,21058,21059,21059,21060,21061,21062,21063,21064,21065,21066,21067,21068,21069,21070,21071,21072,21068,21073,21074,21075,21076,21077,21078,21079,21080,21081,21082,21083,21084,21085,21086,21087,21088,21089,21090,21091,21092,21093,21094,21095,21096,21097,21098,21099,21100,21101,21102,21103,21104,21105,21106,21107,21108,21109,21110,21111,21112,21113,21114,21115,21116,21117,21118,21119,21120,21121,21122,21118,21123,21124,21125,21126,21127,21128,21129,21130,21131,21132,21133,21134,21135,21136,21137,21138,21139,21140,21141,21142,21143,21144,21145,21146,21147,21148,21149,21150,21151,21152,21153,21154,21155,21155,21156,21153,21157,21158,21159,21159,21160,21161,21162,21163,21164,21165,21166,21167,21168,21169,21170,21171,21172,21173,21174,21175,21176,21177,21178,21179,21180,21181,21182,21182,21183,21184,21185,21186,21187,21187,21188,21189,21190,21191,21192,21192,21193,21190,21194,21195,21196,21196,21197,21198,21199,21200,21201,21201,21202,21203,21204,21205,21206,21206,21207,21208,21209,21210,21211,21211,21212,21213,21214,21215,21216,21217,21218,21219,21220,21221,21222,21222,21223,21220,21224,21225,21226,21226,21227,21224,21228,21229,21230,21230,21231,21232,21233,21234,21235,21235,21236,21237,21238,21239,21240,21240,21241,21242,21243,21244,21245,21245,21246,21247,21248,21249,21250,21250,21251,21248,21252,21253,21254,21254,21255,21256,21257,21258,21259,21259,21260,21261,21262,21263,21264,21264,21265,21266,21267,21268,21269,21269,21270,21271,21272,21273,21274,21274,21275,21276,21277,21278,21279,21279,21280,21281,21282,21283,21284,21284,21285,21282,21286,21287,21288,21288,21289,21286,21290,21291,21292,21292,21293,21290,21294,21295,21296,21297,21298,21299,21300,21301,21302,21303,21304,21305,21306,21307,21308,21309,21310,21311,21312,21313,21314,21315,21316,21317,21318,21319,21320,21321,21322,21323,21324,21325,21326,21327,21328,21329,21330,21331,21332,21333,21334,21335,21336,21337,21338,21339,21340,21341,21342,21343,21344,21345,21346,21347,21348,21349,21350,21351,21352,21353,21354,21355,21356,21357,21358,21359,21360,21361,21362,21363,21364,21365,21366,21367,21368,21369,21370,21371,21372,21373,21374,21375,21376,21377,21378,21375,21379,21380,21381,21382,21383,21384,21385,21386,21387,21388,21389,21390,21391,21392,21393,21394,21395,21396,21397,21398,21399,21400,21401,21402,21403,21404,21405,21406,21407,21408,21409,21410,21411,21412,21413,21414,21415,21416,21417,21418,21419,21420,21421,21422,21423,21424,21425,21426,19692,21427,21428,21429,21430,21431,21432,21433,21434,21435,21436,21437,21438,21439,21440,21441,21442,21443,21444,21445,21446,21447,21448,21449,21450,21451,21452,21453,21454,21455,21456,21457,21458,21459,21460,21461,21462,21463,21464,21465,21466,21467,21468,21469,21470,21471,21472,21473,21474,21475,21476,21477,21478,21479,21480,21481,21482,21483,21484,21485,21486,21487,21488,21489,21490,21491,21492,21493,21494,21495,21496,21497,21498,21499,21500,21501,21502,21503,21504,21505,21506,21507,21508,21509,21510,21511,21512,21513,21514,21515,21516,21517,21518,21519,21520,21521,21522,21523,21524,21525,21526,21527,21528,21529,21530,21531,21532,21533,21534,21535,21536,21537,21538,21539,21540,21541,21542,21543,21544,21545,21546,21547,21548,21549,21550,21551,21552,21553,21554,21555,21556,21557,21558,21559,21560,21561,21562,21563,21564,21565,21566,21567,21568,21569,21570,21571,21572,21573,21574,21575,21576,21577,21578,21579,21580,21581,21582,21583,21584,21585,21586,21587,21588,21589,21590,21591,21592,21593,21594,21595,21596,21597,21598,21599,21600,21601,21602,21603,21604,21605,21606,21607,21608,21609,21610,21611,21612,21613,21614,21615,21616,21617,21618,21619,21620,21621,21622,21623,21624,21625,21626,21627,21628,21629,21630,21631,21632,21633,21634,21635,21636,21637,21638,21639,21640,21641,21642,21643,21644,21645,21646,21647,21648,21649,21650,21651,21652,21653,21654,21655,21656,21657,21658,21659,21660,21661,21662,21663,21664,21665,21666,21667,21668,21669,21670,21671,21672,21673,21674,21675,21676,21677,21678,21679,21680,21681,21682,21683,21684,21685,21686,21687,21688,21689,21690,21691,21692,21693,21694,21695,21696,21697,21698,21699,21700,21701,21702,21703,21702,21704,21705,21706,21707,21708,21709,21710,21711,21712,21713,21714,21715,21716,21717,21718,21719,21720,21721,21722,21723,21724,21725,21726,21727,21728,21729,21730,21731,21732,21733,21734,21735,21736,21737,21738,21739,21740,21741,21742,21743,21744,21745,21746,21747,21748,21749,21750,21751,21752,21753,21754,21755,21756,21757,21758,21759,21760,21761,21762,21763,21764,21765,21766,21767,21768,21769,21770,21771,21772,21773,21774,21775,21776,21777,21778,21779,21780,21781,21779,21782,21779,21783,21784,21785,21786,21787,21788,21789,21790,21791,21792,21793,21794,21795,21796,21797,21798,21799,21800,21801,21802,21803,21804,21805,21806,21807,21808,21809,21810,21811,21812,21813,21814,21815,21816,21817,21818,21819,21820,21821,21822,21823,21824,21825,21826,21827,21828,21829,21830,21831,21832,21833,21834,21835,21836,21837,21838,21839,21840,21841,21842,21843,21844,21845,21846,21847,21848,21846,21849,21846,21850,21851,21852,21853,21854,21855,21856,21857,21858,21859,21860,21861,21862,21863,21864,21865,21866,21867,21868,21869,21870,21871,21872,21873,21874,21875,21876,21877,21878,21879,21880,21881,21882,21883,21884,21885,21886,21887,21888,21889,21890,21891,21892,21893,21894,21895,21896,21897,21898,21899,21900,21901,21902,21903,21904,21905,21906,21907,21908,21909,21910,21911,21912,21913,21914,21915,21702,21916,21702,21917,21918,21919,21920,21921,21922,21923,21924,21925,21926,21927,21928,21929,21930,21931,21932,21933,21934,21935,21936,21937,21938,21939,21940,21941,21942,21943,21944,21945,21946,21947,21948,21949,21950,21951,21952,21953,21954,21955,21956,21957,21958,21959,21960,21961,21962,21963,21964,21965,21966,21967,21968,21969,21970,21971,21972,21973,21974,21975,21976,21977,21978,21979,21980,21981,21982,21983,21984,21985,21986,21987,21988,21989,21990,21991,21992,21993,21994,21995,21996,21997,21998,21999,22000,22001,22002,22003,22004,22005,22006,22007,22008,22009,22010,22011,22012,22013,22014,22015,22016,22017,22018,22019,22020,22021,22022,22023,22024,22025,22026,22027,22028,22029,22030,22031,22032,22033,22034]}
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/16/app.js
|
// TODO: Remaining issues
// 1. Specular highlights don not match with example:
// verify light position relative to moon/cube
// 2. Fix positioning (translations) of moon and cube.
// 3. Match laptopScreen uniforms with the example.
// 4. Match zNear/zFar values with example on all cases.
// 5. Verify lookAt matrix used. (do we need it?)
/* eslint-disable max-statements, indent, no-multi-spaces */
import GL from '@luma.gl/constants';
import {
AnimationLoop,
Model,
Geometry,
Texture2D,
Program,
Renderbuffer,
Framebuffer,
setParameters,
CubeGeometry,
SphereGeometry
} from '@luma.gl/core';
import {Matrix4} from 'math.gl';
import { loadFile } from '@luma.gl/webgl';
import { ModelNode } from '@luma.gl/experimental';
const INFO_HTML = `
<p>
<a href="http://learningwebgl.com/blog/?p=1786" target="_blank">
Rendering to textures
</a>
<br/>
<br/>
Laptop model adapted from
<a href="http://www.turbosquid.com/3d-models/apple-macbook-max-free/391534">
this 3DS Max model by Xedium
</a><br/>
Moon texture courtesy of
<a href="http://maps.jpl.nasa.gov/">
the Jet Propulsion Laboratory
</a>.
<p>
The classic WebGL Lessons in luma.gl
`;
// TODO: For Debugging only, remove once rendering issues fixed.
const FRAGMENT_SHADER_SQ = `\
precision highp float;
varying vec4 vColor;
void main(void) {
gl_FragColor = vColor;
}
`;
const VERTEX_SHADER_SQ = `\
attribute vec3 positions;
attribute vec4 colors;
uniform mat4 uMVMatrix;
uniform mat4 uPMatrix;
varying vec4 vColor;
void main(void) {
gl_Position = uPMatrix * uMVMatrix * vec4(positions, 1.0);
vColor = colors;
}
`;
const squareGeometry = new Geometry({
drawMode: GL.TRIANGLE_STRIP,
attributes: {
positions: new Float32Array([1, 1, 0, -1, 1, 0, 1, -1, 0, -1, -1, 0]),
colors: {
size: 4,
value: new Float32Array([1, 0, 0, 1, 0, 1, 0, 1, 0, 0, 1, 1, 1, 1, 0, 1])
}
}
});
const RENDER_SQUARE = false;
const VERTEX_SHADER = `\
attribute vec3 positions;
attribute vec3 normals;
attribute vec2 texCoords;
uniform mat4 uMVMatrix;
uniform mat4 uPMatrix;
varying vec2 vTextureCoord;
varying vec3 vTransformedNormal;
varying vec4 vPosition;
void main(void) {
// Perform lighting in world space
// we should use 'transpose(inverse(mat3(uMVMatrix)))', but
// 'inverse' matrix operation not supported in GLSL 1.0, for now use
// upper-left 3X3 matrix of model view matrix, it works since we are not
// doing any non-uniform scaling transormations in this example.
mat3 normalMatrix = mat3(uMVMatrix);
vPosition = uMVMatrix * vec4(positions, 1.0);
gl_Position = uPMatrix * vPosition;
vTextureCoord = texCoords;
vTransformedNormal = normalMatrix * normals;
}
`;
const FRAGMENT_SHADER = `\
precision highp float;
varying vec2 vTextureCoord;
varying vec3 vTransformedNormal;
varying vec4 vPosition;
uniform vec3 uMaterialAmbientColor;
uniform vec3 uMaterialDiffuseColor;
uniform vec3 uMaterialSpecularColor;
uniform float uMaterialShininess;
uniform vec3 uMaterialEmissiveColor;
uniform bool uShowSpecularHighlights;
uniform bool uUseTextures;
uniform vec3 uAmbientLightingColor;
uniform vec3 uPointLightingLocation;
uniform vec3 uPointLightingDiffuseColor;
uniform vec3 uPointLightingSpecularColor;
uniform sampler2D uSampler;
void main(void) {
vec3 ambientLightWeighting = uAmbientLightingColor;
vec3 lightDirection = normalize(uPointLightingLocation - vPosition.xyz);
vec3 normal = normalize(vTransformedNormal);
vec3 specularLightWeighting = vec3(0.0, 0.0, 0.0);
if (uShowSpecularHighlights) {
vec3 eyeDirection = normalize(-vPosition.xyz);
vec3 reflectionDirection = reflect(-lightDirection, normal);
float specularLightBrightness =
pow(max(dot(reflectionDirection, eyeDirection), 0.0), uMaterialShininess);
specularLightWeighting = uPointLightingSpecularColor * specularLightBrightness;
}
float diffuseLightBrightness = max(dot(normal, lightDirection), 0.0);
vec3 diffuseLightWeighting = uPointLightingDiffuseColor * diffuseLightBrightness;
vec3 materialAmbientColor = uMaterialAmbientColor;
vec3 materialDiffuseColor = uMaterialDiffuseColor;
vec3 materialSpecularColor = uMaterialSpecularColor;
vec3 materialEmissiveColor = uMaterialEmissiveColor;
float alpha = 1.0;
if (uUseTextures) {
vec4 textureColor = texture2D(uSampler, vec2(vTextureCoord.s, vTextureCoord.t));
materialAmbientColor = materialAmbientColor * textureColor.rgb;
materialDiffuseColor = materialDiffuseColor * textureColor.rgb;
materialEmissiveColor = materialEmissiveColor * textureColor.rgb;
alpha = textureColor.a;
}
gl_FragColor = vec4(
materialAmbientColor * ambientLightWeighting
+ materialDiffuseColor * diffuseLightWeighting
+ materialSpecularColor * specularLightWeighting
+ materialEmissiveColor,
alpha
);
}
`;
let rttFramebuffer;
let rttTexture;
const DISABLE_FB = false;
const FB_WIDTH = 512;
const FB_HEIGHT = 512;
let moonAngle = 0.0;
let cubeAngle = Math.PI;
let laptopAngle = 0.0;
const moonAngleDelta = 0.01; // * Math.PI / 180.0;
const cubeAngleDelta = 0.01; // * Math.PI / 180.0;
const laptopAngleDelta = -0.002; // * Math.PI / 180.0;
export default class AppAnimationLoop extends AnimationLoop {
static getInfo() {
return INFO_HTML;
}
onInitialize({canvas, gl}) {
setParameters(gl, {
clearColor: [0, 0, 0, 1],
clearDepth: 1,
depthTest: true,
depthFunc: GL.LEQUAL
});
const tMoon = new Texture2D(gl, {
data: 'moon.gif',
parameters: {
[gl.TEXTURE_MAG_FILTER]: gl.LINEAR,
[gl.TEXTURE_MIN_FILTER]: gl.LINEAR_MIPMAP_NEAREST
},
mipmap: true
});
const tCrate = new Texture2D(gl, {
data: 'crate.gif',
parameters: {
[gl.TEXTURE_MAG_FILTER]: gl.LINEAR,
[gl.TEXTURE_MIN_FILTER]: gl.LINEAR_MIPMAP_NEAREST
},
mipmap: true
});
return loadFile('macbook.json').then(macbookJSON => {
// Fix attribute name to match with Shaders
macbookJSON = macbookJSON.replace('vertices', 'positions');
const program = new Program(gl, {vs: VERTEX_SHADER, fs: FRAGMENT_SHADER});
const macbook = parseModel(gl, {
id: 'macbook',
file: macbookJSON,
program,
uniforms: Object.assign({}, getLaptopUniforms(), getLightUniforms())
});
const moon = new ModelNode(gl, {
geometry: new SphereGeometry({
nlat: 30,
nlong: 30,
radius: 2
}),
vs: VERTEX_SHADER,
fs: FRAGMENT_SHADER,
uniforms: Object.assign(
{uUseTextures: true, uSampler: tMoon},
getMoonCubeUniforms(),
getLightUniforms()
)
});
const cube = new ModelNode(gl, {
id: 'cube-model',
geometry: new CubeGeometry(),
vs: VERTEX_SHADER,
fs: FRAGMENT_SHADER,
uniforms: Object.assign(
{uUseTextures: true, uSampler: tCrate},
getMoonCubeUniforms(),
getLightUniforms()
)
});
setupFramebuffer(gl);
const laptopScreenModel = generateLaptopScreenModel(gl);
// TODO: Square program/model for debugging only, remove once all rendering issues resolved
const programSQ = new Program(gl, {vs: VERTEX_SHADER_SQ, fs: FRAGMENT_SHADER_SQ});
const tSquare = new Model(gl, {geometry: squareGeometry, program: programSQ});
return {moon, macbook, cube, laptopScreenModel, tCrate, tSquare};
});
}
onRender({gl, tick, aspect, moon, macbook, cube, laptopScreenModel, canvas, tCrate, tSquare}) {
generateTextureForLaptopScreen(gl, tick, aspect, moon, cube, tSquare);
if (!DISABLE_FB) {
drawOuterScene(gl, tick, aspect, macbook, laptopScreenModel, canvas, tCrate);
}
}
}
function getLaptopUniforms() {
return {
uMaterialAmbientColor: [1.0, 1.0, 1.0],
uMaterialDiffuseColor: [1.0, 1.0, 1.0],
uMaterialSpecularColor: [1.5, 1.5, 1.5],
uMaterialShininess: 5.0,
uMaterialEmissiveColor: [0, 0, 0],
uShowSpecularHighlights: true,
uPointLightingLocation: [-1, 2, -1]
};
}
function getMoonCubeUniforms() {
return {
uMaterialAmbientColor: [1.0, 1.0, 1.0],
uMaterialDiffuseColor: [1.0, 1.0, 1.0],
uMaterialSpecularColor: [0.0, 0.0, 0.0],
uMaterialShininess: 0.0,
uMaterialEmissiveColor: [0.0, 0.0, 0.0],
uShowSpecularHighlights: false,
uPointLightingLocation: [0, 0, -5]
};
}
function getLaptopScreenUniforms() {
return {
uMaterialAmbientColor: [1.0, 1.0, 1.0], // [0, 0, 0],
uMaterialDiffuseColor: [1.0, 1.0, 1.0], // [0, 0, 0],
uMaterialSpecularColor: [0.5, 0.5, 0.5],
uMaterialShininess: 20.0,
uMaterialEmissiveColor: [0.0, 0.0, 0.0],
uShowSpecularHighlights: true,
uPointLightingLocation: [1.5, 1.5, 1.5]
};
}
function getLightUniforms() {
return {
uAmbientLightingColor: [0.2, 0.2, 0.2],
uPointLightingDiffuseColor: [0.8, 0.8, 0.8],
uPointLightingSpecularColor: [0.8, 0.8, 0.8]
};
}
function generateLaptopScreenModel(gl) {
const POSITIONS = new Float32Array([
0.580687,
0.659,
0.813106,
-0.580687,
0.659,
0.813107,
0.580687,
0.472,
0.113121,
-0.580687,
0.472,
0.113121
]);
const NORMALS = new Float32Array([
0.0,
-0.965926,
0.258819,
0.0,
-0.965926,
0.258819,
0.0,
-0.965926,
0.258819,
0.0,
-0.965926,
0.258819
]);
const TEXCOORDS = new Float32Array([1.0, 1.0, 0.0, 1.0, 1.0, 0.0, 0.0, 0.0]);
const geometry = new Geometry({
id: 'laptopscreen-geometry',
attributes: {
positions: POSITIONS,
normals: NORMALS,
texCoords: TEXCOORDS
},
drawMode: GL.TRIANGLE_STRIP
});
const model = new Model(gl, {
gl,
id: 'laptopscreen-model',
geometry,
vs: VERTEX_SHADER,
fs: FRAGMENT_SHADER,
uniforms: Object.assign({uUseTextures: true}, getLaptopScreenUniforms(), getLightUniforms())
});
return model;
}
function setupFramebuffer(gl) {
rttTexture = new Texture2D(gl, {
data: null,
format: GL.RGBA,
type: GL.UNSIGNED_BYTE,
border: 0,
mipmaps: true,
parameters: {
[GL.TEXTURE_MAG_FILTER]: GL.NEAREST, // GL.LINEAR,
[GL.TEXTURE_MIN_FILTER]: GL.NEAREST // GL.LINEAR_MIPMAP_NEAREST
},
width: FB_WIDTH,
height: FB_HEIGHT,
dataFormat: GL.RGBA
});
const renderbuffer = new Renderbuffer(gl, {
format: GL.DEPTH_COMPONENT16,
width: FB_WIDTH,
height: FB_HEIGHT
});
rttFramebuffer = new Framebuffer(gl, {
width: FB_WIDTH,
height: FB_HEIGHT,
attachments: {
[GL.COLOR_ATTACHMENT0]: rttTexture,
[GL.DEPTH_ATTACHMENT]: renderbuffer
}
});
if (DISABLE_FB === true) {
rttFramebuffer = null;
}
}
// eslint-disable-next-line max-params
function generateTextureForLaptopScreen(gl, tick, aspect, moon, cube, tSquare) {
moonAngle += moonAngleDelta;
cubeAngle += cubeAngleDelta;
gl.viewport(0, 0, FB_WIDTH, FB_HEIGHT);
if (!DISABLE_FB) {
rttFramebuffer.bind();
}
gl.clear(GL.COLOR_BUFFER_BIT | GL.DEPTH_BUFFER_BIT);
// Rendering square for dubgging only, remove once all issues are resolved.
if (RENDER_SQUARE) {
// Draw Square
tSquare
.setPosition([0, 0, -1])
.updateMatrix()
.setUniforms({
uMVMatrix: tSquare.matrix,
uPMatrix: new Matrix4().perspective({aspect})
})
.draw();
} else {
let uMVMatrix = new Matrix4()
.lookAt({eye: [0, 0, 20]})
.translate([2, 0, 0])
.rotateY(moonAngle)
.rotateX((30 * Math.PI) / 180.0)
.translate([0, 0, -5])
.multiplyRight(moon.matrix);
moon
.setUniforms({
uMVMatrix,
uPMatrix: new Matrix4().perspective({aspect: FB_WIDTH / FB_HEIGHT, near: 0.1, far: 500})
})
.draw();
uMVMatrix = new Matrix4()
.lookAt({eye: [0, 0, 20]})
.translate([1, 0, 0])
.rotateY(cubeAngle)
.translate([0, 0, -5])
.multiplyRight(cube.matrix);
cube
.setUniforms({
uMVMatrix,
uPMatrix: new Matrix4().perspective({aspect: FB_WIDTH / FB_HEIGHT})
})
.draw();
}
if (!DISABLE_FB) {
rttFramebuffer.unbind();
}
}
// eslint-disable-next-line max-params
function drawOuterScene(gl, tick, aspect, macbook, laptopScreenModel, canvas, tCrate) {
laptopAngle += laptopAngleDelta;
gl.viewport(0, 0, canvas.width, canvas.height);
gl.clear(GL.COLOR_BUFFER_BIT | GL.DEPTH_BUFFER_BIT);
const uMVMatrix = new Matrix4()
.lookAt({eye: [0, 0, 0]})
.translate([0, -0.5, -3])
.rotateY(laptopAngle)
.rotateX((-80.0 * Math.PI) / 180.0);
macbook
.setUniforms({
uMVMatrix,
uPMatrix: new Matrix4().perspective({aspect}),
uUseTextures: false
})
.draw();
laptopScreenModel
.setUniforms({
uMVMatrix,
uPMatrix: new Matrix4().perspective({aspect}),
uUseTextures: true,
uSampler: rttFramebuffer.texture
})
.draw();
}
function parseModel(gl, opts = {}) {
const {file, program = new Program(gl)} = opts;
const json = typeof file === 'string' ? parseJSON(file) : file;
// Remove any attributes so that we can create a geometry
// TODO - change format to put these in geometry sub object?
const attributes = {};
const modelOptions = {};
for (const key in json) {
const value = json[key];
if (Array.isArray(value)) {
attributes[key] = key === 'indices' ? new Uint16Array(value) : new Float32Array(value);
} else {
modelOptions[key] = value;
}
}
return new Model(
gl,
Object.assign({program, geometry: new Geometry({attributes})}, modelOptions, opts)
);
}
function parseJSON(file) {
try {
return JSON.parse(file);
} catch (error) {
throw new Error(`Failed to parse JSON: ${error}`);
}
}
/* global window */
if (typeof window !== 'undefined' && !window.website) {
const animationLoop = new AppAnimationLoop();
animationLoop.start();
}
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/09/package.json
|
{
"version": "0.0.1",
"private": true,
"name": "@rapidsai/demo-luma.gl-lessons-09",
"scripts": {
"start": "webpack-dev-server --progress --hot --open -d",
"start-local": "webpack-dev-server --env.local --progress --hot --open -d"
},
"dependencies": {
"@loaders.gl/images": "3.2.9",
"@luma.gl/constants": "8.5.16",
"@luma.gl/core": "8.5.16",
"@luma.gl/experimental": "8.5.16",
"@luma.gl/shadertools": "8.5.16",
"math.gl": "3.6.3"
}
}
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/09/star.js
|
import { Program, Geometry } from '@luma.gl/core';
import { ModelNode } from '@luma.gl/experimental';
const VERTEX_SHADER = `\
attribute vec3 positions;
attribute vec2 texCoords;
uniform mat4 uMVMatrix;
uniform mat4 uPMatrix;
varying vec2 vTextureCoord;
void main(void) {
gl_Position = uPMatrix * uMVMatrix * vec4(positions, 1.0);
vTextureCoord = texCoords;
}
`;
const FRAGMENT_SHADER = `\
precision highp float;
varying vec2 vTextureCoord;
uniform sampler2D uSampler;
uniform vec3 uColor;
void main(void) {
vec4 textureColor = vec4(texture2D(uSampler, vec2(vTextureCoord.s, vTextureCoord.t)).rgb, 1.0);
gl_FragColor = textureColor * vec4(uColor, 1.0);
}
`;
export class Star extends ModelNode {
constructor(gl, opts = {}) {
const program = new Program(gl, {
fs: FRAGMENT_SHADER,
vs: VERTEX_SHADER
});
super(gl, {
program,
geometry: new Geometry({
attributes: {
// prettier-ignore
positions: new Float32Array([
-1.0, -1.0, 0.0,
1.0, -1.0, 0.0,
-1.0, 1.0, 0.0,
1.0, 1.0, 0.0
]),
// prettier-ignore
texCoords: new Float32Array([
0.0, 0.0,
1.0, 0.0,
0.0, 1.0,
1.0, 1.0
]),
indices: new Uint16Array([0, 1, 3, 3, 2, 0])
}
}),
uniforms: {
uSampler: opts.texture
},
onBeforeRender: () => {
// TODO: Fix this so user can control this with a check-box
const isTwinkle = false; // twinkle.checked;
const r = isTwinkle ? Math.min(1, this.r + this.twinklerR) : this.r;
const g = isTwinkle ? Math.min(1, this.g + this.twinklerG) : this.g;
const b = isTwinkle ? Math.min(1, this.b + this.twinklerB) : this.b;
this.setUniforms({uColor: [r, g, b]});
}
});
this.angle = 0;
this.dist = opts.startingDistance;
this.rotationSpeed = opts.rotationSpeed;
this.spin = 0;
this.randomiseColors();
}
randomiseColors() {
const rd = Math.random;
this.r = rd();
this.g = rd();
this.b = rd();
this.twinklerR = rd();
this.twinklerG = rd();
this.twinklerB = rd();
}
animate(elapsedTime, twinkle) {
this.angle += this.rotationSpeed / 10;
this.dist -= 0.001;
if (this.dist < 0) {
this.dist += 5;
this.randomiseColors();
}
this.position.set(Math.cos(this.angle) * this.dist, Math.sin(this.angle) * this.dist, 0);
this.setRotation([0, 0, this.spin]);
this.spin += 0.1;
this.updateMatrix();
}
}
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/09/app.js
|
import GL from '@luma.gl/constants';
import {AnimationLoop, Texture2D, setParameters} from '@luma.gl/core';
import {Matrix4} from 'math.gl';
import {Star} from './star';
const INFO_HTML = `
<p>
<a href="http://learningwebgl.com/blog/?p=1008" target="_blank">
Improving the code structure with lots of moving objects
</a>
Up/Down/PageUp/PageDown to tilt and zoom.
<p>
The classic WebGL Lessons in luma.gl
`;
let zoom = -15;
let tilt = 90;
export default class AppAnimationLoop extends AnimationLoop {
static getInfo() {
return INFO_HTML;
}
onInitialize({canvas, gl}) {
/* global document */
document.addEventListener('keydown', keyboardEventHandler);
setParameters(gl, {
clearColor: [0, 0, 0, 1],
clearDepth: 1,
blendFunc: [gl.SRC_ALPHA, gl.ONE],
blend: true
});
const texture = new Texture2D(gl, 'star.gif');
const stars = [];
const numStars = 50;
for (let i = 0; i < numStars; i++) {
stars.push(
new Star(gl, {
startingDistance: (i / numStars) * 5.0,
rotationSpeed: i / numStars,
texture
})
);
}
return {stars};
}
onRender({gl, tick, aspect, stars}) {
// Update Camera Position
const radTilt = (tilt / 180) * Math.PI;
const cameraY = Math.cos(radTilt) * zoom;
const cameraZ = Math.sin(radTilt) * zoom;
gl.clear(GL.COLOR_BUFFER_BIT | GL.DEPTH_BUFFER_BIT);
for (const i in stars) {
const uMVMatrix = new Matrix4()
.lookAt({eye: [0, cameraY, cameraZ]})
.multiplyRight(stars[i].matrix);
stars[i]
.setUniforms({
uMVMatrix,
uPMatrix: new Matrix4().perspective({aspect})
})
.draw();
stars[i].animate();
}
}
onFinalize() {
document.removeEventListener('keydown', keyboardEventHandler);
}
}
function keyboardEventHandler(e) {
switch (e.code) {
case 'ArrowUp':
tilt -= 1.5;
break;
case 'ArrowDown':
tilt += 1.5;
break;
case 'PageUp':
zoom -= 0.1;
break;
case 'PageDown':
zoom += 0.1;
break;
default:
}
}
/* global window */
if (typeof window !== 'undefined' && !window.website) {
const animationLoop = new AppAnimationLoop();
animationLoop.start();
}
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/03/package.json
|
{
"version": "0.0.1",
"private": true,
"name": "@rapidsai/demo-luma.gl-lessons-03",
"scripts": {
"start": "webpack-dev-server --progress --hot --open -d",
"start-local": "webpack-dev-server --env.local --progress --hot --open -d"
},
"dependencies": {
"@loaders.gl/images": "3.2.9",
"@luma.gl/constants": "8.5.16",
"@luma.gl/core": "8.5.16",
"@luma.gl/experimental": "8.5.16",
"@luma.gl/shadertools": "8.5.16",
"math.gl": "3.6.3"
}
}
| 0 |
rapidsai_public_repos/node/modules/demo/luma/lessons
|
rapidsai_public_repos/node/modules/demo/luma/lessons/03/app.js
|
/* eslint-disable array-bracket-spacing, no-multi-spaces */
import GL from '@luma.gl/constants';
import {ModelNode} from '@luma.gl/experimental';
import {AnimationLoop, setParameters, Geometry} from '@luma.gl/core';
import {Matrix4} from 'math.gl';
const INFO_HTML = `
<p>
<a href="http://learningwebgl.com/blog/?p=239" target="_blank">
A Bit of Movement
</a>
<p>
The classic WebGL Lessons in luma.gl
`;
const FRAGMENT_SHADER = `\
precision highp float;
varying vec4 vColor;
void main(void) {
gl_FragColor = vColor;
}
`;
const VERTEX_SHADER = `\
attribute vec3 positions;
attribute vec4 colors;
uniform mat4 uMVMatrix;
uniform mat4 uPMatrix;
varying vec4 vColor;
void main(void) {
gl_Position = uPMatrix * uMVMatrix * vec4(positions, 1.0);
vColor = colors;
}
`;
const triangleGeometry = new Geometry({
attributes: {
positions: {size: 3, value: new Float32Array([0, 1, 0, -1, -1, 0, 1, -1, 0])},
colors: {size: 4, value: new Float32Array([1, 0, 0, 1, 0, 1, 0, 1, 0, 0, 1, 1])}
}
});
const squareGeometry = new Geometry({
drawMode: GL.TRIANGLE_STRIP,
attributes: {
positions: new Float32Array([1, 1, 0, -1, 1, 0, 1, -1, 0, -1, -1, 0]),
colors: {
size: 4,
value: new Float32Array([0.5, 0.5, 1, 1, 0.5, 0.5, 1, 1, 0.5, 0.5, 1, 1, 0.5, 0.5, 1, 1])
}
}
});
export default class AppAnimationLoop extends AnimationLoop {
static getInfo() {
return INFO_HTML;
}
onInitialize({gl}) {
setParameters(gl, {
clearColor: [0, 0, 0, 1],
clearDepth: [1],
depthTest: true,
depthFunc: gl.LEQUAL
});
return {
triangle: new ModelNode(gl, {
geometry: triangleGeometry,
vs: VERTEX_SHADER,
fs: FRAGMENT_SHADER
}),
square: new ModelNode(gl, {geometry: squareGeometry, vs: VERTEX_SHADER, fs: FRAGMENT_SHADER})
};
}
onRender(context) {
const {gl, tick, aspect, triangle, square} = context;
gl.clear(gl.COLOR_BUFFER_BIT | gl.DEPTH_BUFFER_BIT);
const projection = new Matrix4().perspective({aspect});
// Draw triangle
triangle
.setPosition([-1.5, 0, -7])
.setRotation([0, tick * 0.01, 0])
.updateMatrix()
.setUniforms({
uMVMatrix: triangle.matrix,
uPMatrix: projection
})
.draw();
// Draw Square
square
.setPosition([1.5, 0, -7])
.setRotation([tick * 0.1, 0, 0])
.updateMatrix()
.setUniforms({
uMVMatrix: square.matrix,
uPMatrix: projection
})
.draw();
}
}
/* global window */
if (typeof window !== 'undefined' && !window.website) {
const animationLoop = new AppAnimationLoop();
animationLoop.start();
}
| 0 |
rapidsai_public_repos/node/modules/demo
|
rapidsai_public_repos/node/modules/demo/.vscode/launch.json
|
{
// Use IntelliSense to learn about possible attributes.
// Hover to view descriptions of existing attributes.
// For more information, visit: https://go.microsoft.com/fwlink/?linkid=830387
"version": "0.2.0",
"compounds": [
{
"name": "Debug Demo (TS and C++)",
"configurations": [
"Debug Demo (launch gdb)",
"Debug Demo (attach node)",
]
}
],
"configurations": [
{
"name": "Attach Test",
"port": 9229,
"request": "attach",
"skipFiles": [
"<node_internals>/**"
],
"type": "node"
},
{
"type": "node",
"request": "launch",
"name": "Debug Demo (TS only)",
"program": "${workspaceFolder}/${input:DEMO_NAME}",
"stopOnEntry": false,
"args": [
"${input:DEMO_ARGS}"
],
"runtimeArgs": [
"--experimental-vm-modules"
],
"cwd": "${workspaceFolder}/${input:DEMO_NAME}",
"console": "integratedTerminal",
"internalConsoleOptions": "neverOpen",
"skipFiles": [
"**/.vscode/server/**",
// "**/node_modules/**",
"<node_internals>/**",
// "**/node_modules/esm/**",
"**/node_modules/debug/**",
"**/node_modules/core-js/**",
"**/node_modules/mjolnir.js/**",
"<node_internals>/internal/buffer",
"<node_internals>/internal/fs/utils",
// "<node_internals>/internal/validators",
],
"env": {
"NODE_NO_WARNINGS": "1",
// "NODE_ENV": "development",
"NODE_ENV": "production",
// "READABLE_STREAM": "disable",
}
},
{
"name": "Debug Demo (launch gdb)",
// hide the individual configurations from the debug dropdown list
"presentation": {
"hidden": true
},
"type": "cppdbg",
"request": "launch",
"stopAtEntry": false,
"externalConsole": false,
// "envFile": "${workspaceFolder}/.env",
"cwd": "${workspaceFolder}/${input:DEMO_NAME}",
"MIMode": "gdb",
"miDebuggerPath": "/usr/bin/gdb",
"setupCommands": [
{
"description": "Enable pretty-printing for gdb",
"text": "-enable-pretty-printing",
"ignoreFailures": true
}
],
"program": "${input:NODE_BINARY}",
"environment": [
{
"name": "NODE_DEBUG",
"value": "1"
},
{
"name": "NODE_NO_WARNINGS",
"value": "1"
},
{
"name": "NODE_ENV",
"value": "production"
},
// { "name": "READABLE_STREAM", "value": "disable" },
],
"args": [
"--inspect=9229",
"--expose-internals",
"--experimental-vm-modules",
"${workspaceFolder}/${input:DEMO_NAME}",
// "${input:DEMO_ARGS}"
],
},
{
"name": "Debug Demo (attach node)",
"type": "node",
"request": "attach",
// hide the individual configurations from the debug dropdown list
"presentation": {
"hidden": true
},
"port": 9229,
"timeout": 60000,
"cwd": "${workspaceFolder}",
"skipFiles": [
"<node_internals>/**",
"${workspaceFolder}/node_modules/**"
],
},
],
"inputs": [
{
"type": "command",
"id": "NODE_BINARY",
"command": "shellCommand.execute",
"args": {
"description": "path to node",
"command": "which node",
"useFirstResult": true,
}
},
{
"id": "DEMO_ARGS",
"type": "promptString",
"description": "Supply additional arguments to the demo (optional)",
"default": "",
},
{
"type": "command",
"id": "DEMO_NAME",
"command": "shellCommand.execute",
"args": {
"description": "Select a demo to debug",
"command": "echo client-server viz-app api-server luma graph spatial xterm $(find modules/demo/deck modules/demo/tfjs modules/demo/ipc modules/demo/ssr modules/demo/sql -maxdepth 2 -type f -name 'package.json' -print0 | grep -z -v node_modules | tr -d '\\0' | sed -r 's@modules/demo/@@g' | sed -r 's@/package.json@ @g') | sort -Vr | sed -r 's@\\s@\\n@g'",
}
},
]
}
| 0 |
rapidsai_public_repos/node/modules/demo
|
rapidsai_public_repos/node/modules/demo/ipc/README.md
|
# Inter Process Communication (IPC) - Depricated
Early demo showing how to use IPC handles from Python with Node.js.
| 0 |
rapidsai_public_repos/node/modules/demo/ipc
|
rapidsai_public_repos/node/modules/demo/ipc/graph/package.json
|
{
"private": true,
"name": "@rapidsai/demo-ipc-graph",
"main": "index.js",
"version": "22.12.2",
"license": "Apache-2.0",
"author": "NVIDIA, Inc. (https://nvidia.com/)",
"maintainers": [
"Paul Taylor <[email protected]>"
],
"bin": "index.js",
"scripts": {
"start": "node --experimental-vm-modules --enable-source-maps --trace-uncaught index.js",
"watch": "find -type f | entr -c -d -r node --experimental-vm-modules --enable-source-maps --trace-uncaught index.js"
},
"dependencies": {
"@deck.gl/core": "8.8.10",
"@deck.gl/react": "8.8.10",
"@luma.gl/core": "8.5.16",
"@luma.gl/gltools": "8.5.16",
"@rapidsai/cuda": "~22.12.2",
"@rapidsai/cudf": "~22.12.2",
"@rapidsai/cugraph": "~22.12.2",
"@rapidsai/deck.gl": "~22.12.2",
"@rapidsai/glfw": "~22.12.2",
"ix": "4.4.1",
"mjolnir.js": "2.7.1",
"react": "17.0.2",
"react-dom": "17.0.2",
"zeromq": "6.0.0-beta.6"
},
"files": [
"src",
"python",
"index.js",
"package.json",
"fa2.py"
]
}
| 0 |
rapidsai_public_repos/node/modules/demo/ipc
|
rapidsai_public_repos/node/modules/demo/ipc/graph/index.js
|
#!/usr/bin/env node
// Copyright (c) 2020-2021, NVIDIA CORPORATION.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
module.exports = ({url, ...glfwOptions} = {
title: 'Graph Demo',
visible: true,
transparent: false,
}) => {
return require('@rapidsai/jsdom')
.RapidsJSDOM.fromReactComponent(
'./src/app.jsx',
{
glfwOptions,
// Change cwd to the example dir so relative file paths are resolved
module: {path: __dirname},
},
{url});
};
if (require.main === module) {
const args = process.argv.length === 3 && process.argv[2].includes(' ')
? process.argv[2].split(' ')
: process.argv.slice(2);
const parseArg = (prefix, fallback = '') =>
(args.find((arg) => arg.includes(prefix)) || `${prefix}${fallback}`).slice(prefix.length);
const url = args.find((arg) => arg.includes('tcp://')) || 'tcp://0.0.0.0:6000';
module
.exports({
title: '',
visible: true,
transparent: false,
url: url && require('url').parse(url),
width: parseInt(parseArg('--width=', 800)) | 0,
height: parseInt(parseArg('--height=', 600)) | 0,
})
.window.addEventListener('close', () => process.exit(0), {once: true});
}
| 0 |
rapidsai_public_repos/node/modules/demo/ipc
|
rapidsai_public_repos/node/modules/demo/ipc/graph/fa2.py
|
# Copyright (c) 2020-2021, NVIDIA CORPORATION.
#
# Licensed under the Apache License, Version 2.0 (the "License");
# you may not use this file except in compliance with the License.
# You may obtain a copy of the License at
#
# http://www.apache.org/licenses/LICENSE-2.0
#
# Unless required by applicable law or agreed to in writing, software
# distributed under the License is distributed on an "AS IS" BASIS,
# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
# See the License for the specific language governing permissions and
# limitations under the License.
import warnings
warnings.filterwarnings("ignore", category=UserWarning)
warnings.filterwarnings("ignore", category=DeprecationWarning)
import python.test_data as datasets
from python.callback import GraphZmqCallback
import zmq
import cudf
import cugraph
import asyncio
import zmq.asyncio
graph, nodes, edges = datasets.make_synthetic_dataset()
print("num_nodes:", graph.number_of_nodes())
print("num_edges:", graph.number_of_edges())
async def main(zmq_ctx):
def map_positions(pos):
return cudf.DataFrame(pos, columns=["x", "y"]).astype("float32")
callback = GraphZmqCallback(
zmq_ctx=zmq_ctx,
map_positions=map_positions,
nodes=nodes[["id", "color", "size"]],
edges=edges[["edge", "bundle", "color"]],
edge_col_names=["edge", "color", "bundle"],
node_col_names=["id", "color", "size", "x", "y"],
)
cugraph.force_atlas2(
graph,
max_iter=500,
callback=callback,
)
callback.update(msg=b"close")
callback.close()
asyncio.run(main(zmq.Context.instance()))
| 0 |
rapidsai_public_repos/node/modules/demo/ipc/graph
|
rapidsai_public_repos/node/modules/demo/ipc/graph/python/test_data.py
|
# Copyright (c) 2021, NVIDIA CORPORATION.
#
# Licensed under the Apache License, Version 2.0 (the "License");
# you may not use this file except in compliance with the License.
# You may obtain a copy of the License at
#
# http://www.apache.org/licenses/LICENSE-2.0
#
# Unless required by applicable law or agreed to in writing, software
# distributed under the License is distributed on an "AS IS" BASIS,
# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
# See the License for the specific language governing permissions and
# limitations under the License.
import cudf
import cugraph
import numpy as np
import pandas as pd
import datetime as dt
from .convert_matrix import from_cudf_edgelist
from .graph_components import (
annotate_nodes,
annotate_edges
)
def make_synthetic_dataset(**kwargs):
kwargs.update(direct=True)
df = cudf.DataFrame.from_pandas(pd.DataFrame({
"src": [0, 1, 2, 3],
"dst": [1, 2, 3, 0],
"colors": [1, 1, 2, 2],
"bool": [True, False, True, True],
"char": ["a", "b", "c", "d"],
"str": ["a", "b", "c", "d"],
"ustr": [u"a", u"b", u"c", u"d"],
"emoji": ["😋", "😋😋", "😋", "😋"],
"int": [0, 1, 2, 3],
"num": [0.5, 1.5, 2.5, 3.5],
"date_str": [
"2018-01-01 00:00:00",
"2018-01-02 00:00:00",
"2018-01-03 00:00:00",
"2018-01-05 00:00:00",
],
"date": [
dt.datetime(2018, 1, 1),
dt.datetime(2018, 1, 1),
dt.datetime(2018, 1, 1),
dt.datetime(2018, 1, 1),
],
"time": [
pd.Timestamp("2018-01-05"),
pd.Timestamp("2018-01-05"),
pd.Timestamp("2018-01-05"),
pd.Timestamp("2018-01-05"),
],
}))
return make_and_shape_hypergraph(df, **kwargs)
def make_and_shape_hypergraph(df, **kwargs):
hyper = cugraph.hypergraph(df, **kwargs)
del hyper["events"]
del hyper["entities"]
SOURCE = kwargs.get("SOURCE", "src")
TARGET = kwargs.get("TARGET", "dst")
NODEID = kwargs.get("NODEID", "node_id")
EVENTID = kwargs.get("EVENTID", "event_id")
CATEGORY = kwargs.get("CATEGORY", "category")
nodes = hyper["nodes"][[NODEID, CATEGORY]]
edges = hyper["edges"][[SOURCE, TARGET]]
# Create graph
graph, nodes, edges = from_cudf_edgelist(edges, SOURCE, TARGET)
nodes["name"] = nodes["node"]
# Add vis components
nodes = annotate_nodes(graph, nodes, edges)
edges = annotate_edges(graph, nodes, edges)
return graph, nodes, edges
| 0 |
rapidsai_public_repos/node/modules/demo/ipc/graph
|
rapidsai_public_repos/node/modules/demo/ipc/graph/python/convert_matrix.py
|
# Copyright (c) 2021, NVIDIA CORPORATION.
#
# Licensed under the Apache License, Version 2.0 (the "License");
# you may not use this file except in compliance with the License.
# You may obtain a copy of the License at
#
# http://www.apache.org/licenses/LICENSE-2.0
#
# Unless required by applicable law or agreed to in writing, software
# distributed under the License is distributed on an "AS IS" BASIS,
# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
# See the License for the specific language governing permissions and
# limitations under the License.
import cudf
import cugraph
import numpy as np
from cugraph.structure.graph_implementation import simpleGraphImpl
EdgeList = simpleGraphImpl.EdgeList
def from_cudf_edgelist(df, source="src", target="dst"):
"""
Construct an enhanced graph from a cuDF edgelist that doesn't collapse
duplicate edges and includes columns for node degree and edge bundle.
"""
def drop_index(df):
return df.reset_index(drop=True)
def arange(size, dtype="uint32"):
return cudf.core.index.RangeIndex(0, size).to_series().astype(dtype)
def smoosh(df):
size = sum([df[x].dtype.itemsize for x in df])
data = drop_index(drop_index(df).stack()).data
dtype = cudf.utils.dtypes.min_unsigned_type(0, size*8)
return cudf.core.column.NumericalColumn(data, dtype=dtype)
def compute_edge_bundles(edges, id_, src, dst):
edges = cudf.DataFrame({
"eid": drop_index(edges[id_]),
"src": drop_index(edges[src]),
"dst": drop_index(edges[dst]),
})
# Create a duplicate table with:
# * all the [src, dst] in the upper half
# * all the [dst, src] pairs as the lower half, but flipped so dst->src, src->dst
bundles = drop_index(cudf.DataFrame({
"eid": cudf.concat([edges["eid"], edges["eid"]], ignore_index=True),
# concat [src, dst] into the "src" column
"src": cudf.concat([edges["src"], edges["dst"]], ignore_index=True),
# concat [dst, src] into the "dst" column
"dst": cudf.concat([edges["dst"], edges["src"]], ignore_index=True),
}))
# Group the duplicated edgelist by [src, dst] and get the min edge id.
# Since all the [dst, src] pairs have been flipped to [src, dst], each
# edge with the same [src, dst] or [dst, src] vertices will be assigned
# the same bundle id
bundles = bundles \
.groupby(["src", "dst"]).agg({"eid": "min"}) \
.reset_index().rename({"eid": "bid"}, axis=1, copy=False)
# Join the bundle ids into the edgelist
edges = edges.merge(bundles, on=["src", "dst"], how="inner")
# Determine each bundle"s size and relative offset
lengths = edges["bid"].value_counts(sort=False).sort_index()
bundles = lengths.index.to_series().unique()
offsets = lengths.cumsum() - lengths
# Join the bundle segment lengths + offsets into the edgelist
edges = edges.merge(cudf.DataFrame({
"bid": drop_index(bundles.astype(np.uint32)),
"start": drop_index(offsets.astype(np.uint32)),
"count": drop_index(lengths.astype(np.uint32)),
}), on="bid", how="left")
# Determine each edge's index relative to its bundle
edges = drop_index(edges.sort_values(by="bid"))
edges["index"] = edges.index.to_series() - edges["start"]
edges["index"] = edges["index"].astype(np.uint32)
# Re-sort the edgelist by edge id and cleanup
edges = drop_index(edges.sort_values(by="eid"))
edges = edges.rename({"eid": "id"}, axis=1, copy=False)
edges = edges[["id", "src", "dst", "index", "count"]]
return {
"edge": smoosh(edges[["src", "dst"]]).astype(np.uint64),
"bundle": smoosh(edges[["index", "count"]]).astype(np.uint64),
}
def make_nodes(df, src, dst):
nodes = drop_index(df[src].append(df[dst], ignore_index=True).unique())
ids = drop_index(cudf.Series(nodes.factorize()[0])).astype(np.uint32)
return drop_index(cudf.DataFrame({"id": ids, "node": nodes}).sort_values(by="id"))
def make_edges(df, src, dst, nodes):
def join(edges, nodes, col):
edges = edges.set_index(col, drop=True)
nodes = nodes.set_index("node", drop=True)
edges = edges.join(nodes).sort_values(by="eid")
edges = edges.rename({"id": col}, axis=1, copy=False)
return drop_index(edges)
edges = df.reset_index().rename({"index": "eid"}, axis=1, copy=False)
edges = join(join(edges.assign(src=df[src], dst=df[dst]), nodes, "src"), nodes, "dst")
edges = edges.assign(**compute_edge_bundles(edges, "eid", "src", "dst"))
return drop_index(edges.rename({"eid": "id"}, axis=1, copy=False))
df = drop_index(df)
nodes = make_nodes(df, source, target)
edges = make_edges(df, source, target, nodes)
graph = cugraph.MultiGraph(directed=True)
graph._Impl = simpleGraphImpl(graph.graph_properties)
graph._Impl.edgelist = EdgeList(edges["src"], edges["dst"])
degree = graph._Impl.degree().set_index("vertex")
nodes = nodes.set_index("id", drop=False).join(degree)
return graph, drop_index(nodes.sort_index()), edges
| 0 |
rapidsai_public_repos/node/modules/demo/ipc/graph
|
rapidsai_public_repos/node/modules/demo/ipc/graph/python/callback.py
|
# Copyright (c) 2020-2021, NVIDIA CORPORATION.
#
# Licensed under the Apache License, Version 2.0 (the "License");
# you may not use this file except in compliance with the License.
# You may obtain a copy of the License at
#
# http://www.apache.org/licenses/LICENSE-2.0
#
# Unless required by applicable law or agreed to in writing, software
# distributed under the License is distributed on an "AS IS" BASIS,
# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
# See the License for the specific language governing permissions and
# limitations under the License.
import ctypes
import rmm
import zmq
import cudf
import cupy
import asyncio
import cugraph
import traceback
import numpy as np
from numba import cuda
from numba.cuda import MemoryPointer
from cugraph.internals import GraphBasedDimRedCallback
class GraphZmqCallback(GraphBasedDimRedCallback):
def __init__(
self,
zmq_ctx=None,
zmq_port=6000,
zmq_host='0.0.0.0',
zmq_protocol='tcp://',
edges=None, edge_col_names=['bundle', 'color', 'edge'],
nodes=None, node_col_names=['x', 'y', 'color', 'size'],
map_positions=lambda p: cudf.DataFrame.from_gpu_matrix(p, columns=['x', 'y'])
):
super(GraphZmqCallback, self).__init__()
self._ctx = zmq_ctx
self._edge_cols = dict()
self._node_cols = dict()
self._edge_ipch = dict()
self._node_ipch = dict()
self._noop_df = cudf.DataFrame()
self._map_positions = map_positions
self._edge_col_names = list(edge_col_names)
self._node_col_names = list(node_col_names)
self._edges = self._noop_df if edges is None else edges
self._nodes = self._noop_df if nodes is None else nodes
self._num_nodes = len(self._nodes)
self._num_edges = len(self._edges)
self._pub_url = '{0}{1}:{2}'.format(zmq_protocol, zmq_host, zmq_port)
self._cmd_url = '{0}{1}:{2}'.format(zmq_protocol, zmq_host, zmq_port + 1)
self._connected = False
def on_preprocess_end(self, positions):
try:
self.connect()
edges = self._edges
nodes = self._nodes.assign(**dict(
self._map_positions(positions)[:self._num_nodes].iteritems()
))
self._nodes, self._edges = (self._noop_df, self._noop_df)
self.update(edges=edges, nodes=nodes, **self._get_bbox(nodes))
except Exception:
print('on_preprocess_end err:', traceback.format_exc())
def on_epoch_end(self, positions):
try:
self.connect()
nodes = self._map_positions(positions)[:self._num_nodes]
self.update(nodes=nodes, **self._get_bbox(nodes))
except Exception:
print('on_epoch_end err:', traceback.format_exc())
def on_train_end(self, positions):
try:
self.connect()
nodes = self._map_positions(positions)[:self._num_nodes]
self.update(nodes=nodes, **self._get_bbox(nodes))
except Exception:
print('on_train_end err:', traceback.format_exc())
def connect(self):
if not self._connected:
self._pub = self._ctx.socket(zmq.PUSH)
self._cmd = self._ctx.socket(zmq.REP)
self._pub.set_hwm(0)
self._cmd.set_hwm(0)
self._pub.bind(self._pub_url)
self._cmd.bind(self._cmd_url)
print('Waiting for subscriber to connect at {0}...'.format(self._pub_url))
while self._cmd.recv() != b'ready': pass
self._connected = True
self._cmd.send_json({
'num_edges': self._num_edges,
'num_nodes': self._num_nodes,
})
return self
def update(self, edges=None, nodes=None, msg=b'', **kwargs):
if not self._connected:
return self
edges = self._noop_df if edges is None else edges
nodes = self._noop_df if nodes is None else nodes
edges = self._filter(edges, self._edge_col_names)
nodes = self._filter(nodes, self._node_col_names)
edges = self._filter(self._copy(self._edge_cols, edges), edges.keys())
nodes = self._filter(self._copy(self._node_cols, nodes), nodes.keys())
edge_ipchs = self._store_ipchs(self._edge_ipch, edges)
node_ipchs = self._store_ipchs(self._node_ipch, nodes)
kwargs.update(edge=list(map(self._ipch_to_msg(), edge_ipchs.values())))
kwargs.update(node=list(map(self._ipch_to_msg(), node_ipchs.values())))
self._pub.send_json(kwargs)
while self._cmd.recv() != b'ready': pass
self._cmd.send(msg)
self._edge_ipch.clear()
self._node_ipch.clear()
return self
def close(self):
if self._connected:
self._pub.close()
self._cmd.close()
self._connected = False
self._pub, self._cmd = (None, None)
def _ipch_to_msg(self):
def tok_to_msg(tok):
return {'name': tok['name'], 'data': tok['ary']}
return tok_to_msg
def _sr_data_to_device_ary(self, sr):
size = sr.data.size // sr.dtype.itemsize
return device_array_from_ptr(sr.data.ptr, size, dtype=sr.dtype)
def _sr_data_to_ipc_handle(self, sr):
return self._sr_data_to_device_ary(sr).get_ipc_handle()
def _filter(self, src, names):
dst = dict()
for col in names:
if col in src:
dst[col] = src[col]
return dst
def _copy(self, dst, src):
for col in src.keys():
if col in dst:
dst_col = self._sr_data_to_device_ary(dst[col])
src_col = self._sr_data_to_device_ary(src[col])
cupy.copyto(cupy.asarray(dst_col), cupy.asarray(src_col))
else:
dst[col] = src[col].copy(True)
return dst
def _store_ipchs(self, dst, src):
for col in src.keys():
if col not in dst:
dst[col] = self._make_ipch(src, col)
return dst
def _make_ipch(self, df, name):
col = None if name not in df else df[name]
if col is not None and len(col) > 0:
hnd = self._sr_data_to_ipc_handle(col)
ary = np.array(hnd._ipc_handle.handle)
return {'name': name, 'handle': hnd, 'ary': ary.tolist()}
return None
def _get_bbox(self, positions):
bbox = dict(x_min=0, x_max=0, y_min=0, y_max=0)
bbox.update(num_edges=self._num_edges)
bbox.update(num_nodes=self._num_nodes)
if 'x' in positions:
bbox.update(x_min=(0 + positions['x'].min()))
bbox.update(x_max=(0 + positions['x'].max()))
if 'y' in positions:
bbox.update(y_min=(0 + positions['y'].min()))
bbox.update(y_max=(0 + positions['y'].max()))
return bbox
def _blocking_wait(self, *tasks):
tasks = asyncio.gather(*tasks)
try:
loop = asyncio.get_running_loop()
loop.run_until_complete(tasks)
except RuntimeError:
loop = asyncio.get_event_loop()
loop.run_until_complete(tasks)
loop.close()
def device_array_from_ptr(ptr, nelem, dtype=np.float, finalizer=None):
"""
device_array_from_ptr(ptr, size, dtype=np.float, stream=0)
Create a Numba device array from a ptr, size, and dtype.
"""
# Handle Datetime Column
if dtype == np.datetime64:
dtype = np.dtype("datetime64[ms]")
else:
dtype = np.dtype(dtype)
elemsize = dtype.itemsize
datasize = elemsize * nelem
shape = (nelem,)
strides = (elemsize,)
# note no finalizer -- freed externally!
ctx = cuda.current_context()
ptr = ctypes.c_uint64(int(ptr))
mem = MemoryPointer(ctx, ptr, datasize, finalizer=finalizer)
return cuda.cudadrv.devicearray.DeviceNDArray(
shape, strides, dtype, gpu_data=mem
)
| 0 |
rapidsai_public_repos/node/modules/demo/ipc/graph
|
rapidsai_public_repos/node/modules/demo/ipc/graph/python/graph_components.py
|
# Copyright (c) 2021, NVIDIA CORPORATION.
#
# Licensed under the Apache License, Version 2.0 (the "License");
# you may not use this file except in compliance with the License.
# You may obtain a copy of the License at
#
# http://www.apache.org/licenses/LICENSE-2.0
#
# Unless required by applicable law or agreed to in writing, software
# distributed under the License is distributed on an "AS IS" BASIS,
# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
# See the License for the specific language governing permissions and
# limitations under the License.
import cudf
import cugraph
import numpy as np
from math import ceil
def annotate_nodes(graph, nodes, edges):
return nodes.assign(
# add node names
name=nodes["name"] if "name" in nodes else nodes["id"],
# add node sizes
size=(nodes["degree"].scale() * 254 + 1).astype(np.uint8),
# add node colors
color=category_to_color(
cugraph.spectralBalancedCutClustering(graph, 9)
.sort_values(by="vertex").reset_index(drop=True)["cluster"],
color_palette=[
# https://colorbrewer2.org/#type=diverging&scheme=Spectral&n=9
4292165199, 4294208835,
4294815329, 4294893707,
4294967231, 4293326232,
4289453476, 4284924581,
4281501885
])
)
def annotate_edges(graph, nodes, edges):
def drop_index(df):
return df.reset_index(drop=True)
def smoosh(df):
size = sum([df[x].dtype.itemsize for x in df])
data = drop_index(drop_index(df).stack()).data
dtype = cudf.utils.dtypes.min_unsigned_type(0, size*8)
return cudf.core.column.NumericalColumn(data, dtype=dtype)
def edge_colors(nodes, edges, col):
edges = edges[["id", col]].set_index(col, drop=True)
nodes = nodes[["id", "color"]].set_index("id", drop=True)
return drop_index(edges.join(nodes).sort_values(by="id")["color"])
return edges.assign(
# add edge names
name=edges["name"] if "name" in edges else edges["id"],
# add edge colors
color=smoosh(cudf.DataFrame({
"src": edge_colors(nodes, edges, "src"),
"dst": edge_colors(nodes, edges, "dst"),
})))
# from random import shuffle
default_palette = [
# https://colorbrewer2.org/#type=diverging&scheme=Spectral&n=11
4288545090, 4292165199,
4294208835, 4294815329,
4294893707, 4294967231,
4293326232, 4289453476,
4284924581, 4281501885,
4284370850
# -12451426,-11583787,-12358156,-10375427,
# -7610114,-4194305,-6752794,-5972565,
# -5914010,-4356046,-6140066
]
# shuffle(color_palette)
def category_to_color(categories, color_palette=None):
if color_palette is None:
color_palette = default_palette
color_indices = cudf.Series(categories)
color_palette = cudf.Series(color_palette)
if color_indices.dtype.type != np.uint32:
color_indices = cudf.Series(categories.factorize()[0]).astype(np.uint32)
color_palettes = []
num_color_ids = color_indices.max() + 1
for i in range(ceil(num_color_ids / len(color_palette))):
color_palettes.append(color_palette)
return cudf.Series(cudf.core.column.build_categorical_column(
ordered=True,
codes=color_indices._column,
categories=cudf.concat(color_palettes)[:num_color_ids],
).as_numerical_column(dtype=np.uint32))
| 0 |
rapidsai_public_repos/node/modules/demo/ipc/graph
|
rapidsai_public_repos/node/modules/demo/ipc/graph/src/index.js
|
#!/usr/bin/env node
// Copyright (c) 2020, NVIDIA CORPORATION.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
import * as React from 'react';
import {render} from 'react-dom';
import App from './app';
export default App;
if (process.env.REACT_APP_ENVIRONMENT === 'browser') {
render(
<React.StrictMode>
<App />
</React.StrictMode>,
document.getElementById('root')
);
}
| 0 |
rapidsai_public_repos/node/modules/demo/ipc/graph
|
rapidsai_public_repos/node/modules/demo/ipc/graph/src/loader.js
|
// Copyright (c) 2020, NVIDIA CORPORATION.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
import {IpcMemory, Uint8Buffer} from '@rapidsai/cuda';
import {flatMap} from 'ix/asynciterable/operators/flatmap';
import {takeWhile} from 'ix/asynciterable/operators/takewhile';
import {pipe} from 'ix/asynciterable/pipe';
import * as zmq from 'zeromq';
const edgeBufferNames = new Set(['edge', 'color', 'bundle']);
const nodeBufferNames = new Set(['id', 'color', 'size', 'x', 'y']);
export default async function* loadGraphData(props = {}) {
const ipcHandles = new zmq.Pull();
const ipcRequests = new zmq.Request();
const {protocol, hostname, port} = props.url;
ipcHandles.connect(`${protocol}//${hostname}:${+ port + 0}`);
ipcRequests.connect(`${protocol}//${hostname}:${+ port + 1}`);
const next = () => request(ipcRequests, 'ready');
let {numEdges = 0, numNodes = 0} = await next();
yield* pipe(ipcHandles,
flatMap(async function*(buf) {
const msg = tryJSONParse(buf);
numEdges = Math.max(numEdges, msg.num_edges || 0);
numNodes = Math.max(numNodes, msg.num_nodes || 0);
const edges = openMemHandles(msg.edge, edgeBufferNames);
const nodes = openMemHandles(msg.node, nodeBufferNames);
const bbox = [msg.x_min, msg.x_max, msg.y_min, msg.y_max];
const graph = createGraph(edges, nodes, numEdges, numNodes);
const {promise, resolve: onAfterRender} = promiseSubject();
yield {graph, bbox, onAfterRender};
await promise.then(() => closeMemHandles([edges, nodes]));
yield {graph, bbox};
}),
takeWhile(async (_, i) => i % 2 === 0 || ((await next()) !== 'close')));
[ipcHandles, ipcRequests].forEach(sock => sock.close());
}
async function request(sock, req = 'ready') {
const resp = await sock.send(req).then(() => sock.receive()).then((resp) => `${resp}`);
switch (resp) {
case '':
case 'close': return resp;
default: return tryJSONParse(resp);
}
}
const createGraph = (edges, nodes, numEdges, numNodes) => ({
numNodes,
numEdges,
nodeRadiusScale: 1 / 75,
// nodeRadiusScale: 1/255,
nodeRadiusMinPixels: 5,
nodeRadiusMaxPixels: 150,
data: (edges.size + nodes.size <= 0) ? {} : {
edges: {
offset: 0,
length: numEdges,
attributes: {
edgeList: getBuffer(edges, 'edge', numEdges * 8),
edgeColors: getBuffer(edges, 'color', numEdges * 8),
edgeBundles: getBuffer(edges, 'bundle', numEdges * 8),
}
},
nodes: {
offset: 0,
length: numNodes,
attributes: {
nodeRadius: getBuffer(nodes, 'size', numNodes * 1),
nodeXPositions: getBuffer(nodes, 'x', numNodes * 4),
nodeYPositions: getBuffer(nodes, 'y', numNodes * 4),
nodeFillColors: getBuffer(nodes, 'color', numNodes * 4),
nodeElementIndices: getBuffer(nodes, 'id', numNodes * 4),
}
},
},
});
function getBuffer(map, key, size) {
return map.has(key) ? map.get(key).subarray(0, size) : undefined;
}
function tryJSONParse(message = '') {
try {
return JSON.parse(message || '{}');
} catch (e) { return {}; }
}
function promiseSubject() {
let resolve, reject;
let promise = new Promise((r1, r2) => {
resolve = r1;
reject = r2;
});
return {promise, resolve, reject};
}
function openMemHandle(handle) { return new Uint8Buffer(new IpcMemory(handle)); }
function openMemHandles(handles, names) {
return (Array.isArray(handles) ? handles : [])
.filter(Boolean)
.filter(({name, data = []}) => data.length > 0 && names.has(name))
.reduce((xs, {name, data}) => xs.set(name, openMemHandle(data)), new Map());
}
function closeMemHandle({buffer}) {
try {
buffer.close();
} catch (e) {}
}
function closeMemHandles(maps) {
return maps.forEach((handles) => handles.forEach(closeMemHandle));
}
| 0 |
rapidsai_public_repos/node/modules/demo/ipc/graph
|
rapidsai_public_repos/node/modules/demo/ipc/graph/src/app.jsx
|
// Copyright (c) 2020-2021, NVIDIA CORPORATION.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
import { log as deckLog } from '@deck.gl/core';
import { log as lumaLog } from '@luma.gl/gltools';
deckLog.level = 0;
lumaLog.level = 0;
deckLog.enable(false);
lumaLog.enable(false);
import { OrthographicView } from '@deck.gl/core';
import { TextLayer } from '@deck.gl/layers';
import DeckGL from '@deck.gl/react';
import { createDeckGLReactRef } from '@rapidsai/deck.gl';
import { as as asAsyncIterable } from 'ix/asynciterable/as';
import { takeWhile } from 'ix/asynciterable/operators/takewhile';
import * as React from 'react';
import { GraphLayer } from '@rapidsai/deck.gl';
const composeFns = (fns) => function (...args) { fns.forEach((fn) => fn && fn.apply(this, args)); }
import loadGraphData from './loader';
export class App extends React.Component {
constructor(props, context) {
if (props.serverRendered) { Object.assign(props, createDeckGLReactRef()); }
super(props, context);
this._isMounted = false;
this._deck = React.createRef();
this.state = { graph: {}, autoCenter: true };
}
componentWillUnmount() { this._isMounted = false; }
componentDidMount() {
this._isMounted = true;
asAsyncIterable(loadGraphData(this.props))
.pipe(takeWhile(() => this._isMounted))
.forEach((state) => this.setState(state));
}
render() {
const { onAfterRender, ...props } = this.props;
const { params = {}, selectedParameter } = this.state;
if (this.state.autoCenter && this.state.bbox) {
const viewState = centerOnBbox(this.state.bbox);
viewState && (props.initialViewState = viewState);
}
return (
<DeckGL {...props}
ref={this._deck}
onViewStateChange={() => this.setState({
autoCenter: params.autoCenter ? (params.autoCenter.val = false) : false
})}
_framebuffer={props.getRenderTarget ? props.getRenderTarget() : null}
onAfterRender={composeFns([onAfterRender, this.state.onAfterRender])}>
<GraphLayer
edgeStrokeWidth={2} edgeOpacity={.5} nodesStroked={true} nodeFillOpacity={
.5} nodeStrokeOpacity={.9} {
...this.state.graph
} />
{selectedParameter !== undefined ?
<TextLayer
sizeScale={1}
opacity={0.9}
maxWidth={2000}
pickable={false}
backgroundColor={[46, 46, 46]}
getTextAnchor='start'
getAlignmentBaseline='top'
getSize={(d) => d.size}
getColor={(d) => d.color}
getPixelOffset={(d) => [0, 0]}
getPosition={(d) => this._deck.current.viewports[0].unproject(d.position)}
data={Object.keys(params).map((key, i) => ({
size: 15,
text: i === selectedParameter
? `(${i}) ${params[key].name}: ${params[key].val}`
: ` ${i} ${params[key].name}: ${params[key].val}`,
color: [255, 255, 255],
position: [0, i * 15],
}))}
/> : null
}
</DeckGL>
);
}
}
export default App;
App.defaultProps = {
controller: { keyboard: false },
onHover: onDragEnd,
onDrag: onDragStart,
onDragEnd: onDragEnd,
onDragStart: onDragStart,
initialViewState: {
zoom: 1,
target: [0, 0, 0],
minZoom: Number.NEGATIVE_INFINITY,
maxZoom: Number.POSITIVE_INFINITY,
},
views: [
new OrthographicView({
clear: {
color: [...[46, 46, 46].map((x) => x / 255), 1]
}
})
]
};
function onDragStart({ index }, { target }) {
if (target) { [window, target].forEach((element) => (element.style || {}).cursor = 'grabbing'); }
}
function onDragEnd({ index }, { target }) {
if (target) {
[window, target].forEach((element) => (element.style || {}).cursor =
~index ? 'pointer' : 'default');
}
}
function centerOnBbox([minX, maxX, minY, maxY]) {
const width = maxX - minX, height = maxY - minY;
if ((width === width) && (height === height)) {
const { outerWidth, outerHeight, devicePixelRatio } = window;
const world = (outerWidth > outerHeight ? width : height);
const screen = (outerWidth > outerHeight ? outerWidth : outerHeight) / devicePixelRatio;
const zoom = world > screen ? -(world / screen) : (screen / world);
return {
minZoom: Number.NEGATIVE_INFINITY,
maxZoom: Number.POSITIVE_INFINITY,
zoom: Math.log2(Math.abs(zoom)) * Math.sign(zoom),
target: [minX + (width * .5), minY + (height * .5), 0],
};
}
}
| 0 |
rapidsai_public_repos/node/modules/demo/ipc
|
rapidsai_public_repos/node/modules/demo/ipc/umap/package.json
|
{
"private": true,
"name": "@rapidsai/demo-ipc-umap",
"main": "index.js",
"version": "22.12.2",
"license": "Apache-2.0",
"author": "NVIDIA, Inc. (https://nvidia.com/)",
"maintainers": [
"Paul Taylor <[email protected]>"
],
"bin": "index.js",
"scripts": {
"start": "node --experimental-vm-modules --enable-source-maps --trace-uncaught index.js",
"watch": "find -type f | entr -c -d -r node --experimental-vm-modules --enable-source-maps --trace-uncaught index.js"
},
"dependencies": {
"@deck.gl/core": "8.8.10",
"@deck.gl/layers": "8.8.10",
"@luma.gl/constants": "8.5.16",
"@luma.gl/core": "8.5.16",
"@rapidsai/cuda": "~22.12.2",
"@rapidsai/jsdom": "~22.12.2",
"mjolnir.js": "2.7.1",
"zeromq": "6.0.0-beta.6"
},
"files": [
"layers",
"app.js",
"index.js",
"README.md",
"package.json",
"umap.py"
]
}
| 0 |
rapidsai_public_repos/node/modules/demo/ipc
|
rapidsai_public_repos/node/modules/demo/ipc/umap/index.js
|
#!/usr/bin/env node
// Copyright (c) 2020-2021, NVIDIA CORPORATION.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
module.exports = (glfwOptions = {
title: 'UMAP Demo',
visible: true,
transparent: false,
}) => {
const {RapidsJSDOM} = require('@rapidsai/jsdom');
const jsdom = new RapidsJSDOM({
glfwOptions,
// Change cwd to the example dir so relative file paths are resolved
module: {path: __dirname}
});
jsdom.window.evalFn(() => require(`./app.js`));
return jsdom;
};
if (require.main === module) {
module.exports().window.addEventListener('close', () => process.exit(0), {once: true});
}
| 0 |
rapidsai_public_repos/node/modules/demo/ipc
|
rapidsai_public_repos/node/modules/demo/ipc/umap/umap.py
|
import os
import cupy
import ctypes
import numba
import numpy as np
import zmq
import traceback
from cudf.core.buffer import Buffer
from cudf.core.index import RangeIndex
from cudf.core.column import CategoricalColumn
from cuml.internals import GraphBasedDimRedCallback
# GPU UMAP
import cudf
from cuml.manifold.umap import UMAP as cumlUMAP
import warnings
warnings.filterwarnings("ignore", category=FutureWarning)
warnings.filterwarnings("ignore", category=DeprecationWarning)
if not os.path.exists('data/fashion'):
print("error, data is missing!")
# https://github.com/zalandoresearch/fashion-mnist/blob/master/utils/mnist_reader.py
def load_mnist(path, kind='train'):
import os
import gzip
import numpy as np
"""Load MNIST data from `path`"""
labels_path = os.path.join(path,
'%s-labels-idx1-ubyte.gz'
% kind)
images_path = os.path.join(path,
'%s-images-idx3-ubyte.gz'
% kind)
with gzip.open(labels_path, 'rb') as lbpath:
labels = np.frombuffer(lbpath.read(), dtype=np.uint8,
offset=8)
with gzip.open(images_path, 'rb') as imgpath:
images = np.frombuffer(imgpath.read(), dtype=np.uint8,
offset=16).reshape(len(labels), 784)
return images, labels
train, train_labels = load_mnist('data/fashion', kind='train')
test, test_labels = load_mnist('data/fashion', kind='t10k')
data = np.array(np.vstack([train, test]), dtype=np.float64) / 255.0
target = np.array(np.hstack([train_labels, test_labels]))
record_data = (('fea%d'%i, data[:,i]) for i in range(data.shape[1]))
gdf = cudf.DataFrame(dict(record_data))
classes = [
'T-shirt/top',
'Trouser',
'Pullover',
'Dress',
'Coat',
'Sandal',
'Shirt',
'Sneaker',
'Bag',
'Ankle boot']
edge_col_names = ['color', 'edge', 'id']
node_col_names = ['position', 'size', 'color', 'edge_offset']
def filled_series(size, dtype, fill_value=0):
sr = RangeIndex(0, size).to_series()
sr[0:size] = fill_value
return sr.astype(dtype)
def to_series_view(mem, dtype):
ptr = numba.cuda.cudadrv.driver.device_pointer(mem)
buf = Buffer(ptr, mem.gpu_data.size)
return cudf.Series(buf, dtype=dtype)
def create_initial_nodes_df(labels):
color_indices = cudf.Series(labels.astype(np.int8))
color_palette = cudf.Series([
-12451426,-11583787,-12358156,-10375427,
-7610114,-4194305,-6752794,-5972565,
-5914010,-4356046,-6140066
])[:color_indices.max() + 1]
dtype = cudf.core.dtypes.CategoricalDtype(ordered=True, categories=color_palette)
color = CategoricalColumn(children=(color_indices._column,), dtype=dtype)
color = cudf.Series(color.as_numerical_column(dtype=np.int32))
return cudf.DataFrame({
'color': color,
'size': filled_series(len(color), 'int8', 20),
'edge_offset': filled_series(len(color), 'int64', 0),
})
def create_node_positions_df(embedding):
return cudf.DataFrame({
'position': to_series_view(embedding, np.float32) * 1000
})
def get_df(src, colnames):
dst = cudf.DataFrame()
for col in colnames:
if col in src:
dst[col] = src[col]
return dst
def make_ipch(cols, name):
if name in cols and len(cols[name]) > 0:
hnd = sr_data_to_ipc_handle(cols[name])
ary = np.array(hnd._ipc_handle.handle)
return {'name': name, 'handle': hnd, 'ary': ary.tolist()}
return None
def ipch_to_msg(tok):
return {'name': tok['name'], 'data': tok['ary']}
def sr_data_to_device_ary(sr):
size = sr.data.size // sr.dtype.itemsize
return device_array_from_ptr(sr.data.ptr, size, dtype=sr.dtype)
def sr_data_to_ipc_handle(sr):
return sr_data_to_device_ary(sr).get_ipc_handle()
def copy_cols(dst, src):
for col in src.columns:
if col in dst:
cupy.copyto(
cupy.asarray(sr_data_to_device_ary(dst[col])),
cupy.asarray(sr_data_to_device_ary(src[col])))
else:
dst[col] = src[col].copy(True)
return dst
def store_ipchs(dst, src):
for col in src.keys():
if col not in dst:
dst[col] = make_ipch(src, col)
return dst
def device_array_from_ptr(ptr, nelem, dtype=np.float, finalizer=None):
"""
device_array_from_ptr(ptr, size, dtype=np.float, stream=0)
Create a Numba device array from a ptr, size, and dtype.
"""
# Handle Datetime Column
if dtype == np.datetime64:
dtype = np.dtype("datetime64[ms]")
else:
dtype = np.dtype(dtype)
elemsize = dtype.itemsize
datasize = elemsize * nelem
shape = (nelem,)
strides = (elemsize,)
# note no finalizer -- freed externally!
ctx = numba.cuda.current_context()
ptr = ctypes.c_uint64(int(ptr))
mem = numba.cuda.MemoryPointer(ctx, ptr, datasize, finalizer=finalizer)
return numba.cuda.cudadrv.devicearray.DeviceNDArray(
shape, strides, dtype, gpu_data=mem
)
class UmapZmqCallback(GraphBasedDimRedCallback):
def __init__(self, zmq_context):
super(UmapZmqCallback, self).__init__()
self._ctx = zmq_context
self._edge_cols = dict()
self._node_cols = dict()
self._edge_ipch = dict()
self._node_ipch = dict()
self._pub_port = 6000
self._cmd_port = self._pub_port + 1
self._pub = self._ctx.socket(zmq.PUSH)
self._cmd = self._ctx.socket(zmq.REP)
self._pub.set_hwm(0)
self._cmd.set_hwm(0)
pub_url = 'tcp://{0}:{1}'.format('0.0.0.0', self._pub_port)
cmd_url = 'tcp://{0}:{1}'.format('0.0.0.0', self._cmd_port)
self._pub.bind(pub_url)
self._cmd.bind(cmd_url)
def on_preprocess_end(self, embedding):
try:
self.connect()
self.update(nodes=create_initial_nodes_df(target))
except Exception:
print('on_preprocess_end err:', traceback.format_exc())
def on_epoch_end(self, embedding):
try:
self.update(nodes=create_node_positions_df(embedding))
except Exception:
print('on_epoch_end err:', traceback.format_exc())
def on_train_end(self, embedding):
try:
self.update(nodes=create_node_positions_df(embedding))
self.close()
except Exception:
print('on_train_end err:', traceback.format_exc())
def connect(self):
print('Waiting for subscriber to connect at tcp://{0}:{1}...'
.format('0.0.0.0', self._pub_port))
while self._cmd.recv() != b'ready':
pass
self._cmd.send(b'')
return self
def update(self, edges=None, nodes=None):
if self._pub.closed:
return self
edges = get_df(cudf.DataFrame() if edges is None else edges, edge_col_names)
nodes = get_df(cudf.DataFrame() if nodes is None else nodes, node_col_names)
edge_ipchs = store_ipchs(self._edge_ipch, copy_cols(self._edge_cols, edges))
node_ipchs = store_ipchs(self._node_ipch, copy_cols(self._node_cols, nodes))
self._pub.send_json({
'edge': list(map(ipch_to_msg, edge_ipchs.values())),
'node': list(map(ipch_to_msg, node_ipchs.values())),
})
while self._cmd.recv() != b'ready':
pass
self._cmd.send(b'')
# self._edge_ipch.clear()
# self._node_ipch.clear()
return self
def close(self):
self._pub.close()
self._cmd.close()
self._ctx.term()
def do_umap():
cumlUMAP(
n_neighbors=5,
init="spectral",
callback=UmapZmqCallback(zmq.Context.instance())
).fit_transform(gdf)
do_umap()
| 0 |
rapidsai_public_repos/node/modules/demo/ipc
|
rapidsai_public_repos/node/modules/demo/ipc/umap/README.md
|
```shell
$ docker run --rm -it \
--network=host -w /rapids/notebooks \
-v "$PWD/umap.py:/rapids/notebooks/umap.py" \
rapidsai/rapidsai-dev-nightly:21.08-cuda11.2-devel-ubuntu20.04-py3.8
\# python umap.py
```
| 0 |
rapidsai_public_repos/node/modules/demo/ipc
|
rapidsai_public_repos/node/modules/demo/ipc/umap/app.js
|
// Copyright (c) 2020-2021, NVIDIA CORPORATION.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
import {COORDINATE_SYSTEM, Deck, log as deckLog, OrthographicView} from '@deck.gl/core';
import {IpcMemory, Uint8Buffer} from '@rapidsai/cuda';
import Url from 'url';
import * as zmq from 'zeromq';
import ArrowGraphLayer from './layers/arrow-graph-layer';
let numNodes = 0;
let numEdges = 0;
let drawEdges = null;
let graphVersion = 0;
let redrawTimeout = null;
let onAfterRenderPromise = null;
const deck = new Deck({
width: '100%',
height: '100%',
controller: true,
initialViewState: {target: [0, 0, 0], zoom: -5.2},
views: new OrthographicView({controller: true}),
onViewStateChange: ({viewState}) => redraw({viewState, drawEdges})
});
window._inputEventTarget = deck.canvas;
// const useTestData = true;
const useTestData = false;
(useTestData ? localRenderLoop() : remoteRenderLoop())
.catch((e) => console.error('Main loop error:', e) || process.exit(1));
async function localRenderLoop() {
await Promise.resolve().then(() => {
const r = 5;
const d = r * 2;
const xOff = 100;
const yOff = 100;
const c = [0xFFFFFFFF, 0xFFFF0000, 0xFF00FF00, 0xFF0000FF];
const edgeUpdates = [(() => {
const edges = [
[0, 1],
[0, 2],
[0, 3],
[1, 0],
[1, 2],
[1, 3],
[1, 3],
[2, 0],
[2, 1],
[2, 3],
[3, 1],
[3, 1],
[3, 2],
[3, 0],
[3, 0],
];
const bundles = (() => {
const {keys, offsets, lengths} = edges.reduce(({keys, offsets, lengths}, e, i) => {
const k = `${e.sort((a, b) => a - b)}`;
lengths[k] = (lengths[k] || 0) + 1;
offsets[i] = (lengths[k] - 1);
keys[i] = k;
return {keys, offsets, lengths};
}, {keys: [], offsets: [], lengths: {}});
return keys.map((k, i) => [offsets[i], lengths[k]]);
})();
return {
offset: 0,
edge: Uint32Array.from(edges.flatMap((e) => e)),
bundle: Uint32Array.from(bundles.flatMap((b) => b)),
color: Uint32Array.from(edges.flatMap((e) => e).map((n) => c[n]))
};
})()];
const nodeUpdates = [(() => {
return {
offset: 0, position: Float32Array.from([
// x, y
(xOff * +0),
(yOff * +0) + d, // center (white)
(xOff * +1) + d,
(yOff * +1) - d, // bottom right (blue)
(xOff * -1) - d,
(yOff * +1) - d, // bottom left (green)
(xOff * +0),
(yOff * -1) - d, // top middle (red)
]),
size: Uint8Array.from([r, r, r, r]), color: Uint32Array.from(c),
}
})()];
numEdges = edgeUpdates[0].length = edgeUpdates[0].edge.length / 2;
numNodes = nodeUpdates[0].length = nodeUpdates[0].position.length;
// console.log({
// edges: edgeUpdates[0],
// nodes: nodeUpdates[0],
// });
return redraw(
{nodeUpdates, edgeUpdates, drawEdges: drawEdges = true, graphVersion: ++graphVersion});
});
}
async function remoteRenderLoop() {
const mapToObject = (m) => [...m.entries()].reduce((xs, [k, v]) => ({...xs, [k]: v}), {});
const loadIpcHandle = (handle) => new Uint8Buffer(new IpcMemory(handle));
const loadIpcHandles = (handles, names) =>
handles
.filter(Boolean)
// .filter(({name, data}) => (data || []).length > 0 && ~names.indexOf(name))
.filter(({name, data}) => (data || []).length > 0)
.reduce((xs, {name, data}) => xs.set(name, loadIpcHandle(data)), new Map());
const closeMemHandle = ({buffer}) => {
try {
buffer.close();
} catch (e) {}
};
const ipchs = new zmq.Pull();
const ready = new zmq.Request();
const {protocol, hostname, port} = Url.parse(process.argv[2]);
const ipchsUrl = `${protocol}//${hostname}:${port}`;
const readyUrl = `${protocol}//${hostname}:${+ port + 1}`;
ipchs.connect(ipchsUrl);
ready.connect(readyUrl);
await ready.send('ready');
await ready.receive();
for await (const msg of ipchs) {
// console.log(msg);
let {node: nodeTokens, edge: edgeTokens} = JSON.parse(msg);
// console.log(nodeTokens);
nodeTokens = (nodeTokens || []).filter(Boolean);
edgeTokens = (edgeTokens || []).filter(Boolean);
// console.log(nodeTokens);
// let nodeIPCBuffers = loadIpcHandles(nodeTokens, ['size', 'color', 'position']);
let nodeIPCBuffers = loadIpcHandles(nodeTokens);
let edgeIPCBuffers = loadIpcHandles(edgeTokens, ['edge', 'color', 'bundle']);
if (nodeIPCBuffers.size + edgeIPCBuffers.size > 0) {
// console.log(nodeIPCBuffers);
numNodes =
nodeIPCBuffers.has('color') ? nodeIPCBuffers.get('color').byteLength / 4 : numNodes;
numEdges =
edgeIPCBuffers.has('color') ? edgeIPCBuffers.get('color').byteLength / 8 : numEdges;
const nodeUpdates = nodeIPCBuffers.size === 0
? []
: [{length: numNodes, offset: 0, ...mapToObject(nodeIPCBuffers)}];
// console.log(nodeUpdates);
// console.log(nodeUpdates[0]);
const edgeUpdates = edgeIPCBuffers.size === 0
? []
: [{length: numEdges, offset: 0, ...mapToObject(edgeIPCBuffers)}];
// console.log(nodeUpdates[0].position);
await redraw(
{nodeUpdates, edgeUpdates, drawEdges: drawEdges = null, graphVersion: ++graphVersion});
nodeIPCBuffers.forEach(closeMemHandle);
edgeIPCBuffers.forEach(closeMemHandle);
await ready.send('ready');
if (`${await ready.receive()}` === 'close') { break; }
}
}
// console.log('done');
ipchs.close();
ready.close();
await redraw({drawEdges: drawEdges = true});
}
function redraw({nodeUpdates = [], edgeUpdates = [], ...rest}) {
const nextProps = {
width: window.clientWidth,
height: window.clientHeight,
layers: [new ArrowGraphLayer({
id: 'graph',
nodeUpdates,
edgeUpdates,
numNodes: numNodes,
numEdges: numEdges,
version: graphVersion,
edgeWidth: useTestData ? 5 : 1,
edgeOpacity: useTestData ? 0.5 : 0.01,
coordinateSystem: COORDINATE_SYSTEM.CARTESIAN,
},
{drawEdges})]
};
rest.viewState !== undefined && (nextProps.viewState = rest.viewState);
if (!onAfterRenderPromise) {
onAfterRenderPromise = new Promise((resolve) => {
nextProps.onAfterRender =
() => {
onAfterRenderPromise = null;
resolve();
}
});
}
deck.setProps(nextProps);
if (drawEdges === false) {
redrawTimeout !== null && clearTimeout(redrawTimeout);
redrawTimeout = setTimeout(() => {
redrawTimeout = null;
redraw({drawEdges: drawEdges = true});
}, 350);
}
return onAfterRenderPromise;
}
| 0 |
rapidsai_public_repos/node/modules/demo/ipc/umap
|
rapidsai_public_repos/node/modules/demo/ipc/umap/layers/arrow-graph-layer.js
|
// Copyright (c) 2020-2021, NVIDIA CORPORATION.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
import {CompositeLayer} from '@deck.gl/core';
import GL from '@luma.gl/constants';
import {Buffer, Texture2D, Transform} from '@luma.gl/core';
import {CUDA, Uint8Buffer} from '@rapidsai/cuda';
import EdgeLayer from './edge/bezier-curve-layer';
import edgePositionsVS from './edge/edge-positions-vertex.glsl';
import NodeLayer from './node/node-layer';
import {getLayerAttributes} from './utils';
const defaultProps = {
numNodes: 0,
numEdges: 0,
nodeUpdates: [],
edgeUpdates: [],
drawEdges: true,
edgeWidth: 1,
edgeOpacity: 0.1,
};
const TEXTURE_WIDTH = 256;
const nodeLayerAttributes = getLayerAttributes(NodeLayer);
const edgeLayerAttributes = getLayerAttributes(EdgeLayer);
/*
LayerAttribute.allocate(numInstances) also creates a typed array as `value`, which we don't want.
Maybe extend it into
LayerAttribute.allocate(numInstances, {valueArray = true})
*/
function resizeBuffer(buffer, numInstances) {
if (buffer.byteLength !== (numInstances * buffer.accessor.BYTES_PER_VERTEX)) {
buffer.reallocate(numInstances * buffer.accessor.BYTES_PER_VERTEX);
}
}
function registerCUDAGraphicsResources(
webGLToCUDABufferMap, cudaResourceToBuffersMap, webGLBuffers) {
webGLBuffers.forEach((glBuffer) => {
if (!webGLToCUDABufferMap.has(glBuffer) || !webGLToCUDABufferMap.get(glBuffer)[1]) {
try {
const cuGraphicsResource =
CUDA.runtime.cudaGraphicsGLRegisterBuffer(glBuffer.handle.ptr, 0);
webGLToCUDABufferMap.set(glBuffer, [cuGraphicsResource, null]);
cudaResourceToBuffersMap.set(cuGraphicsResource, [glBuffer, null]);
} catch (e) {}
}
});
}
function getCUDAGraphicsResourcesBuffers(
webGLToCUDABufferMap, cudaResourceToBuffersMap, webGLBuffers) {
webGLBuffers.forEach((glBuffer) => {
if (!webGLToCUDABufferMap.has(glBuffer) || !webGLToCUDABufferMap.get(glBuffer)[1]) {
const [cuGraphicsResource] = webGLToCUDABufferMap.get(glBuffer);
try {
const cuBuffer =
new Uint8Buffer(CUDA.runtime.cudaGraphicsResourceGetMappedPointer(cuGraphicsResource));
webGLToCUDABufferMap.set(glBuffer, [cuGraphicsResource, cuBuffer]);
cudaResourceToBuffersMap.set(cuGraphicsResource, [glBuffer, cuBuffer]);
} catch (e) {}
}
});
}
function mapCUDAGraphicsResources(webGLToCUDABufferMap, cudaResourceToBuffersMap, webGLBuffers) {
registerCUDAGraphicsResources(webGLToCUDABufferMap, cudaResourceToBuffersMap, webGLBuffers);
CUDA.runtime.cudaGraphicsMapResources([...cudaResourceToBuffersMap.keys()]);
getCUDAGraphicsResourcesBuffers(webGLToCUDABufferMap, cudaResourceToBuffersMap, webGLBuffers);
return [webGLToCUDABufferMap, cudaResourceToBuffersMap];
}
function unmapCUDAGraphicsResources(webGLToCUDABufferMap, cudaResourceToBuffersMap, webGLBuffers) {
CUDA.runtime.cudaGraphicsUnmapResources([...cudaResourceToBuffersMap.keys()]);
webGLBuffers.forEach((glBuffer) => {
if (webGLToCUDABufferMap.has(glBuffer) && webGLToCUDABufferMap.get(glBuffer)[1]) {
const [cuGraphicsResource] = webGLToCUDABufferMap.get(glBuffer);
webGLToCUDABufferMap.delete(glBuffer);
cudaResourceToBuffersMap.delete(cuGraphicsResource);
}
});
}
/*
Always use bufferSubData in
LayerAttribute.updateBuffer ?
*/
function updatePartialBuffer(buffer, data, instanceOffset, webGLToCUDABufferMap) {
const [, cuBuffer] = webGLToCUDABufferMap.get(buffer);
try {
cuBuffer.copyFrom(data, instanceOffset * buffer.accessor.BYTES_PER_VERTEX);
} catch (e) {}
}
export default class ArrowGraphLayer extends CompositeLayer {
static get layerName() { return 'ArrowGraphLayer'; }
initializeState() {
const {gl} = this.context;
this.setState({
loadedNodeCount: 0,
loadedEdgeCount: 0,
hasRenderedEdges: false,
webGLToCUDABufferMap: new Map(),
cudaResourceToBuffersMap: new Map(),
edgePositionsToUpdate: Object.create(null),
// Node layer buffers
nodeColorsBuffer:
new Buffer(gl, {accessor: nodeLayerAttributes.instanceFillColors, byteLength: 1}),
nodeRadiusBuffer:
new Buffer(gl, {accessor: nodeLayerAttributes.instanceRadius, byteLength: 1}),
nodePositionsBuffer:
new Buffer(gl, {accessor: nodeLayerAttributes.instancePositions, byteLength: 1}),
// Line layer buffers
edgeSourcePositionsBuffer:
new Buffer(gl, {accessor: edgeLayerAttributes.instanceSourcePositions, byteLength: 1}),
edgeTargetPositionsBuffer:
new Buffer(gl, {accessor: edgeLayerAttributes.instanceTargetPositions, byteLength: 1}),
edgeControlPointsBuffer:
new Buffer(gl, {accessor: edgeLayerAttributes.instanceTargetPositions, byteLength: 1}),
edgeColorsBuffer: new Buffer(
gl, {accessor: {...edgeLayerAttributes.instanceSourceColors, size: 8}, byteLength: 1}),
// Transform feedback buffers
nodePositionsTexture: new Texture2D(gl, {
format: GL.RG32F,
type: GL.FLOAT,
width: 1,
height: 1,
parameters: {[GL.TEXTURE_MIN_FILTER]: [GL.NEAREST], [GL.TEXTURE_MAG_FILTER]: [GL.NEAREST]},
mipmap: false
}),
edgesBuffer: new Buffer(gl, {accessor: {type: GL.UNSIGNED_INT, size: 2}, byteLength: 1}),
edgeBundlesBuffer:
new Buffer(gl, {accessor: {type: GL.UNSIGNED_INT, size: 2}, byteLength: 1}),
edgeSourcePositionsBufferTemp:
new Buffer(gl, {accessor: edgeLayerAttributes.instanceSourcePositions, byteLength: 1}),
edgeTargetPositionsBufferTemp:
new Buffer(gl, {accessor: edgeLayerAttributes.instanceTargetPositions, byteLength: 1}),
edgeControlPointsBufferTemp:
new Buffer(gl, {accessor: edgeLayerAttributes.instanceTargetPositions, byteLength: 1}),
});
this.setState({
// Transform feedback that looks up node positions from ids
edgePositionsTransform: new Transform(gl, {
sourceBuffers: {
edge: this.state.edgesBuffer,
bundle: this.state.edgeBundlesBuffer,
// instanceIds: this.state.edgesBuffer,
},
feedbackBuffers: {
controlPoints: this.state.edgeControlPointsBufferTemp,
sourcePositions: this.state.edgeSourcePositionsBufferTemp,
targetPositions: this.state.edgeTargetPositionsBufferTemp
},
vs: edgePositionsVS,
varyings: ['sourcePositions', 'targetPositions', 'controlPoints'],
elementCount: 1,
isInstanced: false,
})
});
}
/* eslint-disable max-statements */
updateState({props, oldProps}) {
const {nodeUpdates, edgeUpdates, numNodes, numEdges, drawEdges} = props;
const {
nodeColorsBuffer,
nodeRadiusBuffer,
edgeBundlesBuffer,
nodePositionsBuffer,
nodePositionsTexture,
edgePositionsTransform,
edgeControlPointsBuffer,
edgeSourcePositionsBuffer,
edgeTargetPositionsBuffer,
edgeControlPointsBufferTemp,
edgeSourcePositionsBufferTemp,
edgeTargetPositionsBufferTemp,
edgeColorsBuffer,
edgesBuffer,
webGLToCUDABufferMap,
cudaResourceToBuffersMap
} = this.state;
let {hasRenderedEdges, loadedNodeCount, loadedEdgeCount} = this.state;
// Resize node layer buffers
if (numNodes && numNodes !== oldProps.numNodes) {
resizeBuffer(nodeColorsBuffer, numNodes);
resizeBuffer(nodeRadiusBuffer, numNodes);
nodePositionsTexture.resize(
{width: TEXTURE_WIDTH, height: Math.ceil(numNodes / TEXTURE_WIDTH)});
resizeBuffer(nodePositionsBuffer, nodePositionsTexture.width * nodePositionsTexture.height);
loadedNodeCount = 0;
}
// Resize edge layer buffers
if (numEdges && numEdges !== oldProps.numEdges) {
resizeBuffer(edgeBundlesBuffer, numEdges);
resizeBuffer(edgeControlPointsBuffer, numEdges);
resizeBuffer(edgeSourcePositionsBuffer, numEdges);
resizeBuffer(edgeTargetPositionsBuffer, numEdges);
resizeBuffer(edgeColorsBuffer, numEdges);
resizeBuffer(edgesBuffer, numEdges);
loadedEdgeCount = 0;
}
const nodesUpdated = nodeUpdates.length > 0;
const edgesUpdated = edgeUpdates.length > 0;
const webglBuffers = [
edgesBuffer,
edgeColorsBuffer,
nodeColorsBuffer,
edgeBundlesBuffer,
nodeRadiusBuffer,
nodePositionsBuffer
];
(nodesUpdated || edgesUpdated) &&
mapCUDAGraphicsResources(webGLToCUDABufferMap, cudaResourceToBuffersMap, webglBuffers);
// Apply node data updates
while (nodeUpdates.length) {
const {length, offset, color, size, position} = nodeUpdates.shift();
color && updatePartialBuffer(nodeColorsBuffer, color, offset, webGLToCUDABufferMap);
size && updatePartialBuffer(nodeRadiusBuffer, size, offset, webGLToCUDABufferMap);
position && updatePartialBuffer(nodePositionsBuffer, position, offset, webGLToCUDABufferMap);
loadedNodeCount = Math.max(loadedNodeCount, offset + length);
}
// Apply edge data updates
let edgePositionsToUpdate = this.state.edgePositionsToUpdate;
while (edgeUpdates.length) {
const {length, offset, edge, color, bundle} = edgeUpdates.shift();
edge && updatePartialBuffer(edgesBuffer, edge, offset, webGLToCUDABufferMap);
color && updatePartialBuffer(edgeColorsBuffer, color, offset, webGLToCUDABufferMap);
bundle && updatePartialBuffer(edgeBundlesBuffer, bundle, offset, webGLToCUDABufferMap);
loadedEdgeCount = Math.max(loadedEdgeCount, offset + length);
edgePositionsToUpdate[`[${offset},${length}]`] = {offset, length};
}
(nodesUpdated || edgesUpdated) &&
unmapCUDAGraphicsResources(webGLToCUDABufferMap, cudaResourceToBuffersMap, webglBuffers);
// Update edge position buffers
if (drawEdges && numEdges > 0) {
const allNodesLoaded =
(numNodes > 0 && loadedNodeCount === numNodes &&
(nodeColorsBuffer.byteLength / nodeColorsBuffer.accessor.BYTES_PER_VERTEX) === numNodes &&
(nodeRadiusBuffer.byteLength / nodeRadiusBuffer.accessor.BYTES_PER_VERTEX) === numNodes);
if (!hasRenderedEdges || (nodesUpdated && allNodesLoaded)) {
nodePositionsTexture.setImageData({data: nodePositionsBuffer});
}
const allEdgesLoaded =
(numEdges > 0 && loadedEdgeCount === numEdges &&
(edgesBuffer.byteLength / edgesBuffer.accessor.BYTES_PER_VERTEX) === numEdges &&
(edgeColorsBuffer.byteLength / edgeColorsBuffer.accessor.BYTES_PER_VERTEX) === numEdges &&
(edgeBundlesBuffer.byteLength / edgeBundlesBuffer.accessor.BYTES_PER_VERTEX) === numEdges);
const edgePositionUpdateInfo = {
loadedNodeCount,
loadedEdgeCount,
nodePositionsTexture,
edgePositionsTransform,
edgeControlPointsBuffer,
edgeSourcePositionsBuffer,
edgeTargetPositionsBuffer,
edgeControlPointsBufferTemp,
edgeSourcePositionsBufferTemp,
edgeTargetPositionsBufferTemp,
edgeWidth: this.props.edgeWidth,
};
if (allEdgesLoaded && (nodesUpdated || !hasRenderedEdges)) {
hasRenderedEdges = true;
edgePositionUpdateInfo.offset = 0;
edgePositionUpdateInfo.length = numEdges;
copyEdgePositions(edgePositionUpdateInfo);
} else if (allNodesLoaded && (edgesUpdated || !hasRenderedEdges)) {
hasRenderedEdges = true;
for (const k in edgePositionsToUpdate) {
edgePositionUpdateInfo.offset = edgePositionsToUpdate[k].offset;
edgePositionUpdateInfo.length = edgePositionsToUpdate[k].length;
copyEdgePositions(edgePositionUpdateInfo);
}
edgePositionsToUpdate = Object.create(null);
}
}
this.setState({loadedNodeCount, loadedEdgeCount, hasRenderedEdges, edgePositionsToUpdate});
}
/* eslint-enable max-statements */
renderLayers() {
const {
loadedNodeCount,
loadedEdgeCount,
nodeColorsBuffer,
nodeRadiusBuffer,
nodePositionsBuffer,
edgeControlPointsBuffer,
edgeSourcePositionsBuffer,
edgeTargetPositionsBuffer,
edgeColorsBuffer
} = this.state;
return [
loadedEdgeCount && new EdgeLayer(this.getSubLayerProps({
id: 'edges',
numInstances: loadedEdgeCount,
visible: this.props.drawEdges,
opacity: this.props.edgeOpacity,
strokeWidth: this.props.edgeWidth,
data: {
attributes: {
instanceSourcePositions: edgeSourcePositionsBuffer,
instanceTargetPositions: edgeTargetPositionsBuffer,
instanceControlPoints: edgeControlPointsBuffer,
instanceSourceColors: edgeColorsBuffer,
instanceTargetColors: edgeColorsBuffer,
}
},
pickable: true,
autoHighlight: true,
highlightColor: [255, 255, 255, 255],
})),
loadedNodeCount && new NodeLayer(this.getSubLayerProps({
id: 'nodes',
numInstances: loadedNodeCount,
data: {
attributes: {
instanceRadius: nodeRadiusBuffer,
instanceFillColors: nodeColorsBuffer,
instanceLineColors: nodeColorsBuffer,
instancePositions: nodePositionsBuffer,
}
},
opacity: 0.5,
radiusScale: 1,
radiusMinPixels: 0,
radiusMaxPixels: 25,
// interaction
pickable: true,
autoHighlight: true,
highlightColor: [255, 255, 255, 255],
}))
];
}
}
ArrowGraphLayer.defaultProps = defaultProps;
function copyEdgePositions({
offset,
length,
edgeWidth,
loadedNodeCount,
loadedEdgeCount,
// nodeXTexture,
// nodeYTexture,
nodePositionsTexture,
edgePositionsTransform,
edgeControlPointsBuffer,
edgeSourcePositionsBuffer,
edgeTargetPositionsBuffer,
edgeControlPointsBufferTemp,
edgeSourcePositionsBufferTemp,
edgeTargetPositionsBufferTemp
}) {
if (length <= 0) return;
// Update edge position buffers
resizeBuffer(edgeControlPointsBufferTemp, length);
resizeBuffer(edgeSourcePositionsBufferTemp, length);
resizeBuffer(edgeTargetPositionsBufferTemp, length);
edgePositionsTransform.update({
elementCount: length,
});
edgePositionsTransform.run({
offset,
uniforms: {
loadedNodeCount,
loadedEdgeCount,
width: TEXTURE_WIDTH,
strokeWidth: edgeWidth,
nodePositions: nodePositionsTexture
}
});
edgeControlPointsBuffer.copyData({
sourceBuffer: edgeControlPointsBufferTemp,
size: length * edgeControlPointsBuffer.accessor.BYTES_PER_VERTEX,
writeOffset: offset * edgeControlPointsBuffer.accessor.BYTES_PER_VERTEX,
});
edgeSourcePositionsBuffer.copyData({
sourceBuffer: edgeSourcePositionsBufferTemp,
size: length * edgeSourcePositionsBuffer.accessor.BYTES_PER_VERTEX,
writeOffset: offset * edgeSourcePositionsBuffer.accessor.BYTES_PER_VERTEX,
});
edgeTargetPositionsBuffer.copyData({
sourceBuffer: edgeTargetPositionsBufferTemp,
size: length * edgeTargetPositionsBuffer.accessor.BYTES_PER_VERTEX,
writeOffset: offset * edgeTargetPositionsBuffer.accessor.BYTES_PER_VERTEX,
});
resizeBuffer(edgeControlPointsBufferTemp, 0);
resizeBuffer(edgeSourcePositionsBufferTemp, 0);
resizeBuffer(edgeTargetPositionsBufferTemp, 0);
}
| 0 |
rapidsai_public_repos/node/modules/demo/ipc/umap
|
rapidsai_public_repos/node/modules/demo/ipc/umap/layers/utils.js
|
// Copyright (c) 2015 - 2017 Uber Technologies, Inc.
//
// Permission is hereby granted, free of charge, to any person obtaining a copy
// of this software and associated documentation files (the "Software"), to deal
// in the Software without restriction, including without limitation the rights
// to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
// copies of the Software, and to permit persons to whom the Software is
// furnished to do so, subject to the following conditions:
//
// The above copyright notice and this permission notice shall be included in
// all copies or substantial portions of the Software.
//
// THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
// IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
// FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
// AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
// LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
// OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN
// THE SOFTWARE.
// Copyright (c) 2020-2021, NVIDIA CORPORATION.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
import GL from '@luma.gl/constants';
/* deck.gl could potentially make this as a Layer utility? */
export function getLayerAttributes(LayerClass) {
const layer = new LayerClass({});
try {
layer.context = {};
layer._initState();
layer.initializeState();
} catch (error) {
// ignore
}
const attributes = { ...layer.getAttributeManager().getAttributes() };
for (const attributeName in attributes) {
attributes[attributeName] = Object.assign({}, {
offset: attributes[attributeName].settings.offset,
stride: attributes[attributeName].settings.stride,
type: attributes[attributeName].settings.type || GL.FLOAT,
size: attributes[attributeName].settings.size,
divisor: attributes[attributeName].settings.divisor,
normalize: attributes[attributeName].settings.normalized,
integer: attributes[attributeName].settings.integer,
});
}
return attributes;
}
| 0 |
rapidsai_public_repos/node/modules/demo/ipc/umap/layers
|
rapidsai_public_repos/node/modules/demo/ipc/umap/layers/edge/bezier-curve-layer.js
|
// Copyright (c) 2015 - 2017 Uber Technologies, Inc.
//
// Permission is hereby granted, free of charge, to any person obtaining a copy
// of this software and associated documentation files (the "Software"), to deal
// in the Software without restriction, including without limitation the rights
// to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
// copies of the Software, and to permit persons to whom the Software is
// furnished to do so, subject to the following conditions:
//
// The above copyright notice and this permission notice shall be included in
// all copies or substantial portions of the Software.
//
// THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
// IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
// FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
// AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
// LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
// OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN
// THE SOFTWARE.
// Copyright (c) 2020-2021, NVIDIA CORPORATION.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
import { Layer, fp64LowPart, picking } from '@deck.gl/core';
import GL from '@luma.gl/constants';
import { Model, Geometry } from '@luma.gl/core';
import vs from './bezier-curve-layer-vertex.glsl';
import fs from './bezier-curve-layer-fragment.glsl';
const NUM_SEGMENTS = 40;
const DEFAULT_COLOR = [0, 0, 0, 255];
const defaultProps = {
strokeWidth: { type: 'number', min: 0, value: 1 },
getSourcePosition: { type: 'accessor', value: x => x.sourcePosition },
getTargetPosition: { type: 'accessor', value: x => x.targetPosition },
getControlPoint: { type: 'accessor', value: x => x.controlPoint },
getSourceColor: { type: 'accessor', value: DEFAULT_COLOR },
getTargetColor: { type: 'accessor', value: DEFAULT_COLOR },
};
export default class BezierCurveLayer extends Layer {
getShaders() {
return { vs, fs, modules: [picking] };
}
initializeState() {
const attributeManager = this.getAttributeManager();
/* eslint-disable max-len */
attributeManager.addInstanced({
instanceSourcePositions: {
size: 3,
transition: true,
accessor: 'getSourcePosition'
},
instanceTargetPositions: {
size: 3,
transition: true,
accessor: 'getTargetPosition'
},
instanceControlPoints: {
size: 3,
transition: false,
accessor: 'getControlPoint'
},
instanceSourceColors: {
size: 4,
stride: 8,
// transition: true,
type: GL.UNSIGNED_BYTE,
accessor: 'getSourceColor',
defaultValue: [255, 255, 255, 255]
},
instanceTargetColors: {
size: 4,
stride: 8,
offset: 4,
// transition: true,
type: GL.UNSIGNED_BYTE,
accessor: 'getTargetColor',
defaultValue: [255, 255, 255, 255]
}
});
/* eslint-enable max-len */
}
updateState({ props, oldProps, changeFlags }) {
super.updateState({ props, oldProps, changeFlags });
if (changeFlags.extensionsChanged) {
const { gl } = this.context;
if (this.state.model) {
this.state.model.delete();
}
this.setState({ model: this._getModel(gl) });
}
}
draw({ uniforms }) {
const { strokeWidth } = this.props;
this.state.model.render(
Object.assign({}, uniforms, {
strokeWidth
})
);
}
_getModel(gl) {
/*
* (0, -1)-------------_(1, -1)
* | _,-" |
* o _,-" o
* | _,-" |
* (0, 1)"-------------(1, 1)
*/
let positions = [];
for (let i = 0; i <= NUM_SEGMENTS; i++) {
positions = positions.concat([i, -1, 0, i, 1, 0]);
}
const model = new Model(
gl,
Object.assign({}, this.getShaders(), {
id: this.props.id,
geometry: new Geometry({
drawMode: GL.TRIANGLE_STRIP,
attributes: {
positions: new Float32Array(positions)
}
}),
isInstanced: true,
shaderCache: this.context.shaderCache
})
);
model.setUniforms({ numSegments: NUM_SEGMENTS });
return model;
}
calculateInstanceSourceTargetPositions64xyLow(attribute) {
const { data, getSourcePosition, getTargetPosition } = this.props;
const { value, size } = attribute;
let i = 0;
data.forEach(object => {
const sourcePosition = getSourcePosition(object);
const targetPosition = getTargetPosition(object);
value[i + 0] = fp64LowPart(sourcePosition[0]);
value[i + 1] = fp64LowPart(sourcePosition[1]);
value[i + 2] = fp64LowPart(targetPosition[0]);
value[i + 3] = fp64LowPart(targetPosition[1]);
i += size;
});
}
}
BezierCurveLayer.layerName = 'BezierCurveLayer';
BezierCurveLayer.defaultProps = defaultProps;
| 0 |
rapidsai_public_repos/node/modules/demo/ipc/umap/layers
|
rapidsai_public_repos/node/modules/demo/ipc/umap/layers/edge/edge-positions-vertex.glsl.js
|
// Copyright (c) 2015 - 2017 Uber Technologies, Inc.
//
// Permission is hereby granted, free of charge, to any person obtaining a copy
// of this software and associated documentation files (the "Software"), to deal
// in the Software without restriction, including without limitation the rights
// to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
// copies of the Software, and to permit persons to whom the Software is
// furnished to do so, subject to the following conditions:
//
// The above copyright notice and this permission notice shall be included in
// all copies or substantial portions of the Software.
//
// THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
// IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
// FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
// AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
// LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
// OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN
// THE SOFTWARE.
// Copyright (c) 2020-2021, NVIDIA CORPORATION.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
export default `\
#version 410
#define MAX_BUNDLE_SIZE 100.0
in uvec2 edge;
in uvec2 bundle;
uniform sampler2D nodePositions;
uniform uint loadedNodeCount;
uniform float strokeWidth;
uniform uint width;
out vec3 controlPoints;
out vec3 sourcePositions;
out vec3 targetPositions;
ivec2 getTexCoord(uint id) {
uint y = id / width;
uint x = id - width * y;
return ivec2(x, y);
}
void main(void) {
controlPoints = vec3(0., 0., 1.);
sourcePositions = vec3(0., 0., 1.);
targetPositions = vec3(0., 0., 1.);
if (edge.x < loadedNodeCount) {
sourcePositions = vec3(texelFetch(nodePositions, getTexCoord(edge.x), 0).xy, 0.);
}
if (edge.y < loadedNodeCount) {
targetPositions = vec3(texelFetch(nodePositions, getTexCoord(edge.y), 0).xy, 0.);
}
// Compute the quadratic bezier control point for this edge
if ((sourcePositions.z + targetPositions.z) < 1.0) {
uint uindex = bundle.x;
float bundleSize = bundle.y;
float stroke = max(strokeWidth, 1.);
float eindex = uindex + mod(uindex, 2);
int direction = int(mix(1, -1, mod(uindex, 2)));
// If all the edges in the bundle fit into MAX_BUNDLE_SIZE,
// separate the edges without overlap via 'stroke * eindex'.
// Otherwise allow edges to overlap.
float size = mix(
stroke * eindex,
(MAX_BUNDLE_SIZE * .5 / stroke)
* (eindex / bundleSize),
step(MAX_BUNDLE_SIZE, bundleSize * strokeWidth)
);
vec3 midp = (sourcePositions + targetPositions) * 0.5;
vec3 dist = (targetPositions - sourcePositions);
vec3 unit = normalize(dist) * vec3(-1., 1., 1.);
// handle horizontal and vertical edges
if (unit.x == 0. || unit.y == 0.) {
unit = mix(
vec3(1., 0., unit.z), // if x is 0, x=1, y=0
vec3(0., 1., unit.z), // if y is 0, x=0, y=1
step(0.5, unit.x)
);
}
controlPoints = vec3((midp + (unit * size * direction)).xy, 0.);
}
}
`;
| 0 |
rapidsai_public_repos/node/modules/demo/ipc/umap/layers
|
rapidsai_public_repos/node/modules/demo/ipc/umap/layers/edge/bezier-curve-layer-vertex.glsl.js
|
// Copyright (c) 2015 - 2017 Uber Technologies, Inc.
//
// Permission is hereby granted, free of charge, to any person obtaining a copy
// of this software and associated documentation files (the "Software"), to deal
// in the Software without restriction, including without limitation the rights
// to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
// copies of the Software, and to permit persons to whom the Software is
// furnished to do so, subject to the following conditions:
//
// The above copyright notice and this permission notice shall be included in
// all copies or substantial portions of the Software.
//
// THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
// IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
// FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
// AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
// LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
// OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN
// THE SOFTWARE.
// Copyright (c) 2020-2021, NVIDIA CORPORATION.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
export default `\
#version 410
#define SHADER_NAME bezier-curve-layer-vertex-shader
in vec3 positions;
in vec3 instanceSourcePositions;
in vec3 instanceTargetPositions;
in vec3 instanceControlPoints;
in vec4 instanceSourceColors;
in vec4 instanceTargetColors;
in vec3 instancePickingColors;
uniform float numSegments;
uniform float strokeWidth;
uniform float opacity;
out vec4 vColor;
out float vDiscard;
// offset vector by strokeWidth pixels
// offset_direction is -1 (left) or 1 (right)
vec2 getExtrusionOffset(vec2 line_clipspace, float offset_direction) {
// normalized direction of the line
vec2 dir_screenspace = normalize(line_clipspace * project_uViewportSize);
// rotate by 90 degrees
dir_screenspace = vec2(-dir_screenspace.y, dir_screenspace.x);
vec2 offset_screenspace = dir_screenspace * offset_direction * strokeWidth / 2.0;
vec2 offset_clipspace = project_pixel_size_to_clipspace(offset_screenspace).xy;
return offset_clipspace;
}
float getSegmentRatio(float index) {
return smoothstep(0.0, 1.0, index / numSegments);
}
vec4 computeBezierCurve(vec4 source, vec4 target, vec4 controlPoint, float segmentRatio) {
float mt = 1.0 - segmentRatio;
float mt2 = pow(mt, 2.0);
float t2 = pow(segmentRatio, 2.0);
// quadratic curve
float a = mt2;
float b = mt * segmentRatio * 2.0;
float c = t2;
// TODO: if depth is not needed remove z computations.
vec4 ret = vec4(
a * source.x + b * controlPoint.x + c * target.x,
a * source.y + b * controlPoint.y + c * target.y,
0.0, // a * source.z + b * controlPoint.z + c * target.z,
1.0
);
return ret;
}
void main(void) {
vDiscard = instanceSourcePositions.z + instanceTargetPositions.z;
// Position
vec3 sourcePos = project_position(instanceSourcePositions);
vec3 targetPos = project_position(instanceTargetPositions);
vec3 controlPointPos = project_position(instanceControlPoints);
vec4 source = project_common_position_to_clipspace(vec4(sourcePos, 1.0));
vec4 target = project_common_position_to_clipspace(vec4(targetPos, 1.0));
vec4 controlPoint = project_common_position_to_clipspace(vec4(controlPointPos, 1.0));
// linear interpolation of source & target to pick right coord
float segmentIndex = positions.x;
float segmentRatio = getSegmentRatio(segmentIndex);
vec4 p = computeBezierCurve(source, target, controlPoint, segmentRatio);
// next point
float indexDir = mix(-1.0, 1.0, step(segmentIndex, 0.0));
float nextSegmentRatio = getSegmentRatio(segmentIndex + indexDir);
vec4 nextP = computeBezierCurve(source, target, controlPoint, nextSegmentRatio);
// extrude
float direction = float(positions.y);
direction = mix(-1.0, 1.0, step(segmentIndex, 0.0)) * direction;
vec2 offset = getExtrusionOffset(nextP.xy - p.xy, direction);
gl_Position = p + vec4(offset, 0.0, 0.0);
// Color
vColor = mix(instanceSourceColors, instanceTargetColors, segmentRatio);
vColor = vec4(vColor.rgb, vColor.a * opacity) / 255.;
// Set color to be rendered to picking fbo (also used to check for selection highlight).
picking_setPickingColor(instancePickingColors);
}
`;
| 0 |
rapidsai_public_repos/node/modules/demo/ipc/umap/layers
|
rapidsai_public_repos/node/modules/demo/ipc/umap/layers/edge/README.md
|
# Bezier Curve Layer
This layer renders qudratic bezier curves. Right now it accepts only one control point.
import BezierCurveLayer from './bezier-curve-layer';
Inherits from all [Base Layer](/docs/layers/base-layer.md) properties.
##### `getSourcePosition` (Function, optional)
- Default: `d => d.sourcePosition`
Each point is defined as an array of three numbers: `[x, y, z]`.
##### `getTargetPosition` (Function, optional)
- Default: `d => d.targetPosition`
Each point is defined as an array of three numbers: `[x, y, z]`.
##### `getControlPoint` (Function, optional)
- Default: `d => d.controlPoint`
Each point is defined as an array of three numbers: `[x, y, z]`.
##### `getColor` (Function|Array, optional)
- Default: `[0, 0, 0, 255]`
The rgba color is in the format of `[r, g, b, [a]]`. Each channel is a number between 0-255 and `a` is 255 if not supplied.
* If an array is provided, it is used as the color for all objects.
* If a function is provided, it is called on each object to retrieve its color.
| 0 |
rapidsai_public_repos/node/modules/demo/ipc/umap/layers
|
rapidsai_public_repos/node/modules/demo/ipc/umap/layers/edge/bezier-curve-layer-fragment.glsl.js
|
// Copyright (c) 2015 - 2017 Uber Technologies, Inc.
//
// Permission is hereby granted, free of charge, to any person obtaining a copy
// of this software and associated documentation files (the "Software"), to deal
// in the Software without restriction, including without limitation the rights
// to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
// copies of the Software, and to permit persons to whom the Software is
// furnished to do so, subject to the following conditions:
//
// The above copyright notice and this permission notice shall be included in
// all copies or substantial portions of the Software.
//
// THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
// IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
// FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
// AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
// LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
// OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN
// THE SOFTWARE.
// Copyright (c) 2020-2021, NVIDIA CORPORATION.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
export default `\
#version 410
#define SHADER_NAME bezier-curve-layer-fragment-shader
precision highp float;
in vec4 vColor;
in float vDiscard;
void main(void) {
if (vDiscard > 0.5) {
discard;
}
gl_FragColor = vColor;
// use highlight color if this fragment belongs to the selected object.
gl_FragColor = picking_filterHighlightColor(gl_FragColor);
// use picking color if rendering to picking FBO.
gl_FragColor = picking_filterPickingColor(gl_FragColor);
}
`;
| 0 |
Subsets and Splits
No community queries yet
The top public SQL queries from the community will appear here once available.