Compare commits

...

2 Commits

Author SHA1 Message Date
Godmode Galactus 7853684abf
moving lite-rpc libraries to version v0.2.2 2023-06-23 15:30:02 +02:00
Godmode Galactus 33850b1e5f
git status 2023-06-23 15:29:28 +02:00
5 changed files with 102 additions and 40 deletions

4
Cargo.lock generated
View File

@ -5690,7 +5690,7 @@ dependencies = [
[[package]]
name = "solana-lite-rpc-core"
version = "0.2.1"
source = "git+https://github.com/blockworks-foundation/lite-rpc.git?tag=v0.2.1#c1eed987f29417f8a3b8d147f43a112388f02e4f"
source = "git+https://github.com/blockworks-foundation/lite-rpc.git?tag=v0.2.2#b2a15ad913128e2266deed8b41a4c0c1c640aacc"
dependencies = [
"anyhow",
"async-trait",
@ -5722,7 +5722,7 @@ dependencies = [
[[package]]
name = "solana-lite-rpc-services"
version = "0.2.1"
source = "git+https://github.com/blockworks-foundation/lite-rpc.git?tag=v0.2.1#c1eed987f29417f8a3b8d147f43a112388f02e4f"
source = "git+https://github.com/blockworks-foundation/lite-rpc.git?tag=v0.2.2#b2a15ad913128e2266deed8b41a4c0c1c640aacc"
dependencies = [
"anyhow",
"async-channel",

View File

@ -47,8 +47,8 @@ solana-logger = "1.15.2"
solana-transaction-status = "1.15.2"
solana-account-decoder = "1.15.2"
solana-lite-rpc-core = { git = "https://github.com/blockworks-foundation/lite-rpc.git", tag = "v0.2.1" }
solana-lite-rpc-services = { git = "https://github.com/blockworks-foundation/lite-rpc.git", tag = "v0.2.1" }
solana-lite-rpc-core = { git = "https://github.com/blockworks-foundation/lite-rpc.git", tag = "v0.2.2" }
solana-lite-rpc-services = { git = "https://github.com/blockworks-foundation/lite-rpc.git", tag = "v0.2.2" }
# pin program to mango-v3 version of solana sdk

View File

@ -161,7 +161,8 @@ pub fn confirmation_by_lite_rpc_notification_stream(
tx_block_data: tokio::sync::broadcast::Sender<BlockData>,
exit_signal: Arc<AtomicBool>,
) -> Vec<JoinHandle<()>> {
let transaction_map: Arc<DashMap<String, (TransactionSendRecord, Instant)>> = Arc::new(DashMap::new());
let transaction_map: Arc<DashMap<String, (TransactionSendRecord, Instant)>> =
Arc::new(DashMap::new());
let confirming_task = {
let transaction_map = transaction_map.clone();
@ -170,7 +171,7 @@ pub fn confirmation_by_lite_rpc_notification_stream(
tokio::spawn(async move {
let mut tx_record_rx = tx_record_rx;
let mut notification_stream = notification_stream;
while !transaction_map.is_empty() || !exit_signal.load(Ordering::Relaxed) {
tokio::select! {
transaction_record = tx_record_rx.recv() => {
@ -182,7 +183,7 @@ pub fn confirmation_by_lite_rpc_notification_stream(
},
notification = notification_stream.recv() => {
if let Some(notification) = notification {
match notification {
NotificationMsg::BlockNotificationMsg(block_notification) => {
let _ = tx_block_data.send(BlockData {

View File

@ -1,12 +1,8 @@
use mango_simulation::confirmation_strategies::confirmation_by_lite_rpc_notification_stream;
use solana_lite_rpc_core::{block_store::BlockStore, tx_store::{TxStore, empty_tx_store}, notifications::NotificationMsg};
use solana_lite_rpc_services::{transaction_service::{TransactionService, TransactionServiceBuilder}, tx_sender::TxSender, tpu_utils::tpu_service::TpuService, block_listenser::{BlockListener}, transaction_replayer::TransactionReplayer};
use tokio::sync::mpsc::{UnboundedSender, unbounded_channel};
use {
log::info,
mango_simulation::{
cli,
confirmation_strategies::confirmation_by_lite_rpc_notification_stream,
crank::{self, KeeperConfig},
helpers::{
get_latest_blockhash, get_mango_market_perps_cache, start_blockhash_polling_service,
@ -22,6 +18,19 @@ use {
},
serde_json,
solana_client::nonblocking::rpc_client::RpcClient as NbRpcClient,
solana_lite_rpc_core::{
block_store::BlockStore,
notifications::NotificationMsg,
quic_connection_utils::QuicConnectionParameters,
tx_store::{empty_tx_store, TxStore},
},
solana_lite_rpc_services::{
block_listenser::BlockListener,
tpu_utils::tpu_service::{TpuService, TpuServiceConfig},
transaction_replayer::TransactionReplayer,
transaction_service::{TransactionService, TransactionServiceBuilder},
tx_sender::TxSender,
},
solana_program::pubkey::Pubkey,
solana_sdk::{commitment_config::CommitmentConfig, signer::keypair::Keypair},
std::{
@ -31,19 +40,64 @@ use {
sync::Arc,
time::Duration,
},
tokio::sync::mpsc::{unbounded_channel, UnboundedSender},
tokio::{sync::RwLock, task::JoinHandle},
};
const METRICS_NAME: &str = "mango-bencher";
async fn configure_transaction_service(rpc_client: Arc<NbRpcClient>, ws_address: String, identity: Keypair, block_store: BlockStore, tx_store: TxStore, notifier: UnboundedSender<NotificationMsg> ) -> (TransactionService, JoinHandle<String>) {
async fn configure_transaction_service(
rpc_client: Arc<NbRpcClient>,
identity: Keypair,
block_store: BlockStore,
tx_store: TxStore,
notifier: UnboundedSender<NotificationMsg>,
) -> (TransactionService, JoinHandle<anyhow::Result<()>>) {
let slot = rpc_client.get_slot().await.expect("GetSlot should work");
let tpu_service = TpuService::new(slot, 8, Arc::new(identity), rpc_client.clone(), ws_address, tx_store.clone()).await.expect("Should be able to create TPU");
let tpu_config = TpuServiceConfig {
fanout_slots: 12,
number_of_leaders_to_cache: 1024,
clusterinfo_refresh_time: Duration::from_secs(60 * 60),
leader_schedule_update_frequency: Duration::from_secs(10),
maximum_transaction_in_queue: 200_000,
maximum_number_of_errors: 10,
quic_connection_params: QuicConnectionParameters {
connection_timeout: Duration::from_secs(1),
connection_retry_count: 10,
finalize_timeout: Duration::from_millis(200),
max_number_of_connections: 10,
unistream_timeout: Duration::from_millis(500),
write_timeout: Duration::from_secs(1),
number_of_transactions_per_unistream: 10,
},
};
let tpu_service = TpuService::new(
tpu_config,
Arc::new(identity),
slot,
rpc_client.clone(),
tx_store.clone(),
)
.await
.expect("Should be able to create TPU");
let tx_sender = TxSender::new(tx_store.clone(), tpu_service.clone());
let block_listenser = BlockListener::new(rpc_client.clone(), tx_store.clone(), block_store.clone());
let replayer = TransactionReplayer::new(tpu_service.clone(), tx_store.clone(), Duration::from_secs(2));
let builder = TransactionServiceBuilder::new(tx_sender, replayer, block_listenser, tpu_service, 1_000_000);
builder.start(Some(notifier), block_store, 10, Duration::from_secs(300)).await
let block_listenser =
BlockListener::new(rpc_client.clone(), tx_store.clone(), block_store.clone());
let replayer = TransactionReplayer::new(
tpu_service.clone(),
tx_store.clone(),
Duration::from_secs(2),
);
let builder = TransactionServiceBuilder::new(
tx_sender,
replayer,
block_listenser,
tpu_service,
1_000_000,
);
builder.start(Some(notifier), block_store, 10, Duration::from_secs(90))
}
#[tokio::main(flavor = "multi_thread", worker_threads = 10)]
@ -103,9 +157,18 @@ pub async fn main() -> anyhow::Result<()> {
));
let tx_store = empty_tx_store();
let block_store = BlockStore::new(&nb_rpc_client).await.expect("Blockstore should be created");
let block_store = BlockStore::new(&nb_rpc_client)
.await
.expect("Blockstore should be created");
let (notif_sx, notif_rx) = unbounded_channel();
let (transaction_service, tx_service_jh) = configure_transaction_service(nb_rpc_client.clone(), websocket_url.clone(), Keypair::from_bytes(identity.to_bytes().as_slice()).unwrap(), block_store, tx_store, notif_sx).await;
let (transaction_service, tx_service_jh) = configure_transaction_service(
nb_rpc_client.clone(),
Keypair::from_bytes(identity.to_bytes().as_slice()).unwrap(),
block_store,
tx_store,
notif_sx,
)
.await;
let nb_users = account_keys_parsed.len();
@ -148,20 +211,25 @@ pub async fn main() -> anyhow::Result<()> {
duration
);
let mango_program_pk = Pubkey::from_str(mango_group_config.mango_program_id.as_str()).expect("Mango program should be able to convert into pubkey");
let mango_program_pk = Pubkey::from_str(mango_group_config.mango_program_id.as_str())
.expect("Mango program should be able to convert into pubkey");
let perp_market_caches: Vec<PerpMarketCache> =
get_mango_market_perps_cache(nb_rpc_client.clone(), mango_group_config, &mango_program_pk)
.await;
let quote_root_bank =
Pubkey::from_str(mango_group_config.tokens.last().unwrap().root_key.as_str()).expect("Quote root bank should be able to convert into pubkey");();
Pubkey::from_str(mango_group_config.tokens.last().unwrap().root_key.as_str())
.expect("Quote root bank should be able to convert into pubkey");
();
let quote_node_banks = mango_group_config
.tokens
.last()
.unwrap()
.node_keys
.iter()
.map(|x| Pubkey::from_str(x.as_str()).expect("Token mint should be able to convert into pubkey"))
.map(|x| {
Pubkey::from_str(x.as_str()).expect("Token mint should be able to convert into pubkey")
})
.collect();
clean_market_makers(
@ -247,7 +315,7 @@ pub async fn main() -> anyhow::Result<()> {
notif_rx,
tx_status_sx,
block_status_sx,
exit_signal.clone()
exit_signal.clone(),
);
tasks.append(&mut confirmation_threads);
@ -283,21 +351,18 @@ pub async fn main() -> anyhow::Result<()> {
})
};
let other_tasks_wait_task = {
let tpu_manager = tpu_manager.clone();
tokio::spawn(async move {
futures::future::join_all(tasks).await;
info!("finished joining all other services, joining TransactionService");
tpu_manager.stop();
})
};
tasks.push(market_makers_wait_task);
let transaction_service = tokio::spawn(async move {
let _ = tx_service_jh.await;
info!("Transaction service joined");
});
futures::future::join_all([market_makers_wait_task, other_tasks_wait_task, transaction_service]).await;
tokio::select! {
_ = futures::future::join_all(tasks) => {},
_ = transaction_service => {},
};
mango_sim_stats.report(true, METRICS_NAME).await;
Ok(())
}

View File

@ -1,6 +1,6 @@
use log::warn;
use solana_client::connection_cache::ConnectionCache;
use solana_lite_rpc_services::{transaction_service::{TransactionService}};
use solana_lite_rpc_services::transaction_service::TransactionService;
use solana_sdk::transaction::Transaction;
use tokio::sync::mpsc::UnboundedSender;
@ -22,7 +22,6 @@ impl TpuManager {
stats: MangoSimulationStats,
tx_send_record: UnboundedSender<TransactionSendRecord>,
) -> anyhow::Result<Self> {
Ok(Self {
transaction_service,
stats,
@ -49,7 +48,8 @@ impl TpuManager {
let transaction = bincode::serialize(transaction).unwrap();
self.transaction_service
.send_transaction(transaction, None).await
.send_transaction(transaction, None)
.await
.is_ok()
}
@ -63,8 +63,4 @@ impl TpuManager {
}
value
}
pub fn stop(&self) {
self.transaction_service.stop();
}
}