chia-blockchain/tests/setup_nodes.py

545 lines
15 KiB
Python
Raw Normal View History

import asyncio
import signal
2020-03-30 04:24:47 +03:00
2020-06-18 10:09:34 +03:00
from secrets import token_bytes
2020-06-27 03:31:45 +03:00
from typing import Dict, Tuple, List, Optional
from src.consensus.constants import ConsensusConstants
from src.full_node.full_node import FullNode
from src.server.connection import NodeType
2020-06-27 03:31:45 +03:00
from src.server.server import ChiaServer
2020-03-10 01:23:04 +03:00
from src.simulator.full_node_simulator import FullNodeSimulator
2020-03-21 08:29:39 +03:00
from src.timelord_launcher import spawn_process, kill_processes
from src.util.keychain import Keychain, bytes_to_mnemonic
2020-03-06 11:23:03 +03:00
from src.wallet.wallet_node import WalletNode
2020-01-30 11:57:47 +03:00
from src.util.config import load_config
from src.harvester import Harvester
from src.farmer import Farmer
from src.introducer import Introducer
from src.timelord import Timelord
from src.server.connection import PeerInfo
2020-04-04 02:09:30 +03:00
from src.util.ints import uint16, uint32
from src.server.start_service import Service
from src.util.make_test_constants import make_test_constants_with_genesis
2020-06-18 09:11:42 +03:00
from tests.time_out_assert import time_out_assert
from src.util.chech32 import encode_puzzle_hash
2020-07-06 09:06:55 +03:00
test_constants, bt = make_test_constants_with_genesis(
{
"DIFFICULTY_STARTING": 1,
"DISCRIMINANT_SIZE_BITS": 8,
"BLOCK_TIME_TARGET": 10,
"DIFFICULTY_EPOCH": 12, # The number of blocks per epoch
"DIFFICULTY_DELAY": 3, # EPOCH / WARP_FACTOR
"PROPAGATION_THRESHOLD": 10,
"PROPAGATION_DELAY_THRESHOLD": 20,
"TX_PER_SEC": 1,
"MEMPOOL_BLOCK_BUFFER": 10,
"MIN_ITERS_STARTING": 50 * 1,
"NUMBER_ZERO_BITS_CHALLENGE_SIG": 1,
"CLVM_COST_RATIO_CONSTANT": 108,
}
)
global_config = load_config(bt.root_path, "config.yaml")
self_hostname = global_config["self_hostname"]
2020-06-27 01:06:07 +03:00
def constants_for_dic(dic):
return test_constants.replace(**dic)
async def _teardown_nodes(node_aiters: List) -> None:
awaitables = [node_iter.__anext__() for node_iter in node_aiters]
for sublist_awaitable in asyncio.as_completed(awaitables):
try:
await sublist_awaitable
except StopAsyncIteration:
pass
2020-06-18 07:11:51 +03:00
async def setup_full_node(
2020-06-27 01:06:07 +03:00
consensus_constants: ConsensusConstants,
2020-06-18 07:11:51 +03:00
db_name,
port,
introducer_port=None,
simulator=False,
send_uncompact_interval=30,
):
2020-06-27 03:31:45 +03:00
db_path = bt.root_path / f"{db_name}"
if db_path.exists():
db_path.unlink()
config = load_config(bt.root_path, "config.yaml", "full_node")
config["database_path"] = db_name
2020-06-18 07:11:51 +03:00
config["send_uncompact_interval"] = send_uncompact_interval
config["peer_connect_interval"] = 3
config["introducer_peer"]["host"] = "::1"
2020-03-10 01:23:04 +03:00
if introducer_port is not None:
config["introducer_peer"]["port"] = introducer_port
if not simulator:
api: FullNode = FullNode(
config=config,
root_path=bt.root_path,
consensus_constants=consensus_constants,
name=f"full_node_{port}",
)
else:
api = FullNodeSimulator(
config=config,
root_path=bt.root_path,
consensus_constants=consensus_constants,
name=f"full_node_sim_{port}",
bt=bt,
)
2020-03-10 01:23:04 +03:00
started = asyncio.Event()
2020-03-10 01:23:04 +03:00
async def start_callback():
await api._start()
nonlocal started
started.set()
2020-03-10 01:23:04 +03:00
def stop_callback():
api._close()
2020-03-10 01:38:40 +03:00
async def await_closed_callback():
await api._await_closed()
service = Service(
2020-06-27 03:31:45 +03:00
root_path=bt.root_path,
api=api,
node_type=NodeType.FULL_NODE,
advertised_port=port,
service_name="full_node",
server_listen_ports=[port],
auth_connect_peers=False,
on_connect_callback=api._on_connect,
start_callback=start_callback,
stop_callback=stop_callback,
await_closed_callback=await_closed_callback,
2020-06-27 18:44:51 +03:00
parse_cli_args=False,
)
run_task = asyncio.create_task(service.run())
await started.wait()
yield api, api.server
2020-04-28 23:39:11 +03:00
service.stop()
await run_task
if db_path.exists():
db_path.unlink()
Electron react (#226) * clean react * add material ui * add word list * mnemonic v0 * jeepney backup * keychain usage * wallet api * mnemonic ui * mnemonics redux state * handle exceptions correctly * dashboard * wallets * get puzzle hash * tx history * sidebar * start stop wallet node * use existing mnemonics * status info * create cc wallet * theme should be outside of switch * create offer * dbus alternative for linux * key migration * don't autocomplete, don't reset simulator db * reset mnemonics * Refactor keychain, and key migration * Implement UI for changing keys * Removing keys and mnemonic button * Start making farmer and harvester RPCs * start rpx for simulator * Harvester and farmer websocket, and basic UI * Plot display and deletion * launch daemon on start * State changes from full node, harvester, farmer, and full node ui improvements * split balances in react * pending change balance * plotter * dev config * maintain connection / retry * Remove electron-ui, and style fixes * Better farmer and full node control * Remove electron ui references * Uncomment out starting the dameon * Remove timelord tab, and change full node style * Clean up new wallet login * Refactor RPCs * Now that the GH runner uses python 3.7.7 - use for windows installer * add balance split to coloured coin wallet * spendable balance fix * Import private key from UI fix * mac build/installer Co-authored-by: Mariano Sorgente <sorgente711@gmail.com> Co-authored-by: Lipa Long <lipa@chia.net> Co-authored-by: Gene Hoffman <hoffmang@hoffmang.com>
2020-05-20 10:41:10 +03:00
async def setup_wallet_node(
2020-07-09 02:05:51 +03:00
port,
consensus_constants: ConsensusConstants,
2020-07-09 02:05:51 +03:00
full_node_port=None,
introducer_port=None,
key_seed=None,
starting_height=None,
Electron react (#226) * clean react * add material ui * add word list * mnemonic v0 * jeepney backup * keychain usage * wallet api * mnemonic ui * mnemonics redux state * handle exceptions correctly * dashboard * wallets * get puzzle hash * tx history * sidebar * start stop wallet node * use existing mnemonics * status info * create cc wallet * theme should be outside of switch * create offer * dbus alternative for linux * key migration * don't autocomplete, don't reset simulator db * reset mnemonics * Refactor keychain, and key migration * Implement UI for changing keys * Removing keys and mnemonic button * Start making farmer and harvester RPCs * start rpx for simulator * Harvester and farmer websocket, and basic UI * Plot display and deletion * launch daemon on start * State changes from full node, harvester, farmer, and full node ui improvements * split balances in react * pending change balance * plotter * dev config * maintain connection / retry * Remove electron-ui, and style fixes * Better farmer and full node control * Remove electron ui references * Uncomment out starting the dameon * Remove timelord tab, and change full node style * Clean up new wallet login * Refactor RPCs * Now that the GH runner uses python 3.7.7 - use for windows installer * add balance split to coloured coin wallet * spendable balance fix * Import private key from UI fix * mac build/installer Co-authored-by: Mariano Sorgente <sorgente711@gmail.com> Co-authored-by: Lipa Long <lipa@chia.net> Co-authored-by: Gene Hoffman <hoffmang@hoffmang.com>
2020-05-20 10:41:10 +03:00
):
2020-06-27 03:31:45 +03:00
config = load_config(bt.root_path, "config.yaml", "wallet")
if starting_height is not None:
config["starting_height"] = starting_height
config["initial_num_public_keys"] = 5
Electron react (#226) * clean react * add material ui * add word list * mnemonic v0 * jeepney backup * keychain usage * wallet api * mnemonic ui * mnemonics redux state * handle exceptions correctly * dashboard * wallets * get puzzle hash * tx history * sidebar * start stop wallet node * use existing mnemonics * status info * create cc wallet * theme should be outside of switch * create offer * dbus alternative for linux * key migration * don't autocomplete, don't reset simulator db * reset mnemonics * Refactor keychain, and key migration * Implement UI for changing keys * Removing keys and mnemonic button * Start making farmer and harvester RPCs * start rpx for simulator * Harvester and farmer websocket, and basic UI * Plot display and deletion * launch daemon on start * State changes from full node, harvester, farmer, and full node ui improvements * split balances in react * pending change balance * plotter * dev config * maintain connection / retry * Remove electron-ui, and style fixes * Better farmer and full node control * Remove electron ui references * Uncomment out starting the dameon * Remove timelord tab, and change full node style * Clean up new wallet login * Refactor RPCs * Now that the GH runner uses python 3.7.7 - use for windows installer * add balance split to coloured coin wallet * spendable balance fix * Import private key from UI fix * mac build/installer Co-authored-by: Mariano Sorgente <sorgente711@gmail.com> Co-authored-by: Lipa Long <lipa@chia.net> Co-authored-by: Gene Hoffman <hoffmang@hoffmang.com>
2020-05-20 10:41:10 +03:00
entropy = token_bytes(32)
keychain = Keychain(entropy.hex(), True)
keychain.add_private_key(bytes_to_mnemonic(entropy), "")
first_pk = keychain.get_first_public_key()
assert first_pk is not None
db_path_key_suffix = str(first_pk.get_fingerprint())
db_name = f"test-wallet-db-{port}"
2020-06-27 03:31:45 +03:00
db_path = bt.root_path / f"test-wallet-db-{port}-{db_path_key_suffix}"
if db_path.exists():
db_path.unlink()
config["database_path"] = str(db_name)
2020-09-04 06:54:37 +03:00
config["testing"] = True
api = WalletNode(
config,
keychain,
2020-06-27 03:31:45 +03:00
bt.root_path,
2020-06-27 01:06:07 +03:00
consensus_constants=consensus_constants,
name="wallet1",
2020-03-06 11:23:03 +03:00
)
config["introducer_peer"]["host"] = "::1"
if introducer_port is not None:
config["introducer_peer"]["port"] = introducer_port
config["peer_connect_interval"] = 10
connect_peers: List[PeerInfo] = []
if full_node_port is not None:
connect_peers = [PeerInfo(self_hostname, full_node_port)]
started = asyncio.Event()
async def start_callback():
2020-07-02 15:44:40 +03:00
await api._start(new_wallet=True)
nonlocal started
started.set()
def stop_callback():
api._close()
async def await_closed_callback():
await api._await_closed()
service = Service(
2020-06-27 03:31:45 +03:00
root_path=bt.root_path,
api=api,
node_type=NodeType.WALLET,
advertised_port=port,
service_name="wallet",
server_listen_ports=[port],
connect_peers=connect_peers,
auth_connect_peers=False,
on_connect_callback=api._on_connect,
start_callback=start_callback,
stop_callback=stop_callback,
await_closed_callback=await_closed_callback,
2020-06-27 18:44:51 +03:00
parse_cli_args=False,
2020-04-08 11:02:04 +03:00
)
2020-03-06 11:23:03 +03:00
run_task = asyncio.create_task(service.run())
await started.wait()
2020-03-06 11:23:03 +03:00
yield api, api.server
service.stop()
await run_task
if db_path.exists():
db_path.unlink()
keychain.delete_all_keys()
2020-03-06 11:23:03 +03:00
async def setup_harvester(port, farmer_port, consensus_constants: ConsensusConstants):
2020-07-18 01:54:23 +03:00
api = Harvester(bt.root_path, consensus_constants)
started = asyncio.Event()
async def start_callback():
await api._start()
nonlocal started
started.set()
def stop_callback():
api._close()
async def await_closed_callback():
await api._await_closed()
service = Service(
2020-06-27 03:31:45 +03:00
root_path=bt.root_path,
api=api,
node_type=NodeType.HARVESTER,
advertised_port=port,
service_name="harvester",
server_listen_ports=[port],
connect_peers=[PeerInfo(self_hostname, farmer_port)],
auth_connect_peers=True,
start_callback=start_callback,
stop_callback=stop_callback,
await_closed_callback=await_closed_callback,
2020-06-27 18:44:51 +03:00
parse_cli_args=False,
2020-04-21 07:29:47 +03:00
)
run_task = asyncio.create_task(service.run())
await started.wait()
yield api, api.server
service.stop()
await run_task
async def setup_farmer(
port,
consensus_constants: ConsensusConstants,
full_node_port: Optional[uint16] = None,
):
config = load_config(bt.root_path, "config.yaml", "farmer")
2020-07-09 02:05:51 +03:00
config_pool = load_config(bt.root_path, "config.yaml", "pool")
2020-09-14 07:38:08 +03:00
config["xch_target_address"] = encode_puzzle_hash(bt.farmer_ph)
config["pool_public_keys"] = [bytes(pk).hex() for pk in bt.pool_pubkeys]
2020-09-14 07:38:08 +03:00
config_pool["xch_target_address"] = encode_puzzle_hash(bt.pool_ph)
2020-06-18 09:35:13 +03:00
if full_node_port:
connect_peers = [PeerInfo(self_hostname, full_node_port)]
2020-06-18 09:35:13 +03:00
else:
connect_peers = []
Electron react (#226) * clean react * add material ui * add word list * mnemonic v0 * jeepney backup * keychain usage * wallet api * mnemonic ui * mnemonics redux state * handle exceptions correctly * dashboard * wallets * get puzzle hash * tx history * sidebar * start stop wallet node * use existing mnemonics * status info * create cc wallet * theme should be outside of switch * create offer * dbus alternative for linux * key migration * don't autocomplete, don't reset simulator db * reset mnemonics * Refactor keychain, and key migration * Implement UI for changing keys * Removing keys and mnemonic button * Start making farmer and harvester RPCs * start rpx for simulator * Harvester and farmer websocket, and basic UI * Plot display and deletion * launch daemon on start * State changes from full node, harvester, farmer, and full node ui improvements * split balances in react * pending change balance * plotter * dev config * maintain connection / retry * Remove electron-ui, and style fixes * Better farmer and full node control * Remove electron ui references * Uncomment out starting the dameon * Remove timelord tab, and change full node style * Clean up new wallet login * Refactor RPCs * Now that the GH runner uses python 3.7.7 - use for windows installer * add balance split to coloured coin wallet * spendable balance fix * Import private key from UI fix * mac build/installer Co-authored-by: Mariano Sorgente <sorgente711@gmail.com> Co-authored-by: Lipa Long <lipa@chia.net> Co-authored-by: Gene Hoffman <hoffmang@hoffmang.com>
2020-05-20 10:41:10 +03:00
2020-06-27 01:06:07 +03:00
api = Farmer(config, config_pool, bt.keychain, consensus_constants)
started = asyncio.Event()
async def start_callback():
nonlocal started
started.set()
service = Service(
2020-06-27 03:31:45 +03:00
root_path=bt.root_path,
api=api,
node_type=NodeType.FARMER,
advertised_port=port,
service_name="farmer",
server_listen_ports=[port],
on_connect_callback=api._on_connect,
2020-06-18 09:35:13 +03:00
connect_peers=connect_peers,
auth_connect_peers=False,
start_callback=start_callback,
2020-06-27 18:44:51 +03:00
parse_cli_args=False,
2020-04-21 07:29:47 +03:00
)
run_task = asyncio.create_task(service.run())
await started.wait()
yield api, api.server
service.stop()
await run_task
async def setup_introducer(port):
config = load_config(bt.root_path, "config.yaml", "introducer")
api = Introducer(config["max_peers_to_send"], config["recent_peer_threshold"])
started = asyncio.Event()
async def start_callback():
await api._start()
nonlocal started
started.set()
def stop_callback():
api._close()
async def await_closed_callback():
await api._await_closed()
service = Service(
2020-06-27 03:31:45 +03:00
root_path=bt.root_path,
api=api,
node_type=NodeType.INTRODUCER,
advertised_port=port,
service_name="introducer",
server_listen_ports=[port],
auth_connect_peers=False,
start_callback=start_callback,
stop_callback=stop_callback,
await_closed_callback=await_closed_callback,
2020-06-27 18:44:51 +03:00
parse_cli_args=False,
2020-04-08 11:02:04 +03:00
)
run_task = asyncio.create_task(service.run())
await started.wait()
yield api, api.server
service.stop()
await run_task
2020-03-21 08:33:41 +03:00
2020-03-21 08:29:39 +03:00
async def setup_vdf_clients(port):
vdf_task = asyncio.create_task(spawn_process(self_hostname, port, 1))
2020-03-21 08:29:39 +03:00
def stop():
asyncio.create_task(kill_processes())
2020-03-21 08:29:39 +03:00
asyncio.get_running_loop().add_signal_handler(signal.SIGTERM, stop)
asyncio.get_running_loop().add_signal_handler(signal.SIGINT, stop)
yield vdf_task
await kill_processes()
2020-03-21 08:33:41 +03:00
async def setup_timelord(
port, full_node_port, sanitizer, consensus_constants: ConsensusConstants
):
config = load_config(bt.root_path, "config.yaml", "timelord")
2020-06-11 17:56:59 +03:00
config["sanitizer_mode"] = sanitizer
if sanitizer:
config["vdf_server"]["port"] = 7999
2020-06-11 17:56:59 +03:00
api = Timelord(config, consensus_constants.DISCRIMINANT_SIZE_BITS)
started = asyncio.Event()
2020-03-21 08:29:39 +03:00
async def start_callback():
await api._start()
nonlocal started
started.set()
2020-06-11 17:56:59 +03:00
def stop_callback():
api._close()
2020-03-21 08:29:39 +03:00
async def await_closed_callback():
await api._await_closed()
2020-03-21 08:29:39 +03:00
service = Service(
2020-06-27 03:31:45 +03:00
root_path=bt.root_path,
api=api,
node_type=NodeType.TIMELORD,
advertised_port=port,
service_name="timelord",
server_listen_ports=[port],
connect_peers=[PeerInfo(self_hostname, full_node_port)],
auth_connect_peers=False,
start_callback=start_callback,
stop_callback=stop_callback,
await_closed_callback=await_closed_callback,
2020-06-27 18:44:51 +03:00
parse_cli_args=False,
)
run_task = asyncio.create_task(service.run())
await started.wait()
yield api, api.server
service.stop()
await run_task
async def setup_two_nodes(consensus_constants: ConsensusConstants):
"""
Setup and teardown of two full nodes, with blockchains and separate DBs.
"""
node_iters = [
2020-07-09 02:05:51 +03:00
setup_full_node(
consensus_constants, "blockchain_test.db", 21234, simulator=False
),
setup_full_node(
consensus_constants, "blockchain_test_2.db", 21235, simulator=False
),
]
fn1, s1 = await node_iters[0].__anext__()
fn2, s2 = await node_iters[1].__anext__()
yield (fn1, fn2, s1, s2)
await _teardown_nodes(node_iters)
async def setup_node_and_wallet(
consensus_constants: ConsensusConstants, starting_height=None
):
2020-03-06 11:23:03 +03:00
node_iters = [
2020-07-09 02:05:51 +03:00
setup_full_node(
consensus_constants, "blockchain_test.db", 21234, simulator=False
),
setup_wallet_node(
21235, consensus_constants, None, starting_height=starting_height
),
2020-03-10 01:23:04 +03:00
]
full_node, s1 = await node_iters[0].__anext__()
wallet, s2 = await node_iters[1].__anext__()
yield (full_node, wallet, s1, s2)
await _teardown_nodes(node_iters)
2020-03-10 01:23:04 +03:00
async def setup_simulators_and_wallets(
2020-09-16 21:11:01 +03:00
simulator_count: int,
wallet_count: int,
dic: Dict,
starting_height=None,
):
2020-04-04 02:09:30 +03:00
simulators: List[Tuple[FullNode, ChiaServer]] = []
wallets = []
node_iters = []
2020-03-17 08:22:59 +03:00
2020-06-27 01:06:07 +03:00
consensus_constants = constants_for_dic(dic)
2020-04-04 02:09:30 +03:00
for index in range(0, simulator_count):
port = 50000 + index
db_name = f"blockchain_test_{port}.db"
2020-06-27 01:06:07 +03:00
sim = setup_full_node(consensus_constants, db_name, port, simulator=True)
2020-04-04 02:09:30 +03:00
simulators.append(await sim.__anext__())
node_iters.append(sim)
2020-03-17 08:22:59 +03:00
2020-04-04 02:09:30 +03:00
for index in range(0, wallet_count):
seed = bytes(uint32(index))
port = 55000 + index
2020-07-09 02:05:51 +03:00
wlt = setup_wallet_node(
port,
consensus_constants,
None,
key_seed=seed,
starting_height=starting_height,
2020-07-09 02:05:51 +03:00
)
2020-04-04 02:09:30 +03:00
wallets.append(await wlt.__anext__())
node_iters.append(wlt)
2020-03-17 08:22:59 +03:00
2020-04-04 02:09:30 +03:00
yield (simulators, wallets)
2020-03-17 08:22:59 +03:00
await _teardown_nodes(node_iters)
2020-03-17 08:22:59 +03:00
2020-03-17 22:38:36 +03:00
async def setup_farmer_harvester(consensus_constants: ConsensusConstants):
2020-06-18 09:11:42 +03:00
node_iters = [
setup_harvester(21234, 21235, consensus_constants),
setup_farmer(21235, consensus_constants),
2020-06-18 09:11:42 +03:00
]
harvester, harvester_server = await node_iters[0].__anext__()
farmer, farmer_server = await node_iters[1].__anext__()
yield (harvester, farmer)
2020-06-18 09:35:13 +03:00
await _teardown_nodes(node_iters)
2020-06-18 09:11:42 +03:00
async def setup_full_system(consensus_constants: ConsensusConstants):
node_iters = [
setup_introducer(21233),
setup_harvester(21234, 21235, consensus_constants),
setup_farmer(21235, consensus_constants, uint16(21237)),
2020-03-21 08:29:39 +03:00
setup_vdf_clients(8000),
setup_timelord(21236, 21237, False, consensus_constants),
2020-07-09 02:05:51 +03:00
setup_full_node(
consensus_constants, "blockchain_test.db", 21237, 21233, False, 10
),
setup_full_node(
consensus_constants, "blockchain_test_2.db", 21238, 21233, False, 10
),
2020-06-11 17:56:59 +03:00
setup_vdf_clients(7999),
setup_timelord(21239, 21238, True, consensus_constants),
]
introducer, introducer_server = await node_iters[0].__anext__()
harvester, harvester_server = await node_iters[1].__anext__()
farmer, farmer_server = await node_iters[2].__anext__()
2020-06-18 09:11:42 +03:00
async def num_connections():
return len(harvester.global_connections.get_connections())
await time_out_assert(10, num_connections, 1)
2020-06-20 07:30:37 +03:00
vdf = await node_iters[3].__anext__()
timelord, timelord_server = await node_iters[4].__anext__()
2020-03-21 08:29:39 +03:00
node1, node1_server = await node_iters[5].__anext__()
node2, node2_server = await node_iters[6].__anext__()
2020-06-20 07:30:37 +03:00
vdf_sanitizer = await node_iters[7].__anext__()
sanitizer, sanitizer_server = await node_iters[8].__anext__()
yield (
node1,
node2,
harvester,
farmer,
introducer,
timelord,
vdf,
sanitizer,
vdf_sanitizer,
2020-06-11 17:56:59 +03:00
)
await _teardown_nodes(node_iters)