Move data feed machinery to separate module
							parent
							
								
									31c69a5fae
								
							
						
					
					
						commit
						8fe0c40dde
					
				|  | @ -1,18 +1,11 @@ | |||
| """ | ||||
| Core broker-daemon tasks and API. | ||||
| """ | ||||
| import time | ||||
| import inspect | ||||
| from functools import partial | ||||
| import socket | ||||
| from types import ModuleType | ||||
| from typing import Coroutine, Callable, List, Dict, Any | ||||
| from typing import List, Dict, Any | ||||
| 
 | ||||
| import trio | ||||
| import tractor | ||||
| 
 | ||||
| from ..log import get_logger, get_console_log | ||||
| from . import get_brokermod | ||||
| from ..log import get_logger | ||||
| 
 | ||||
| 
 | ||||
| log = get_logger('broker.core') | ||||
|  | @ -69,281 +62,3 @@ async def option_chain( | |||
|     async with brokermod.get_client() as client: | ||||
|         return await client.option_chains( | ||||
|             await client.get_contracts([symbol])) | ||||
| 
 | ||||
| 
 | ||||
| async def wait_for_network(net_func: Callable, sleep: int = 1) -> dict: | ||||
|     """Wait until the network comes back up. | ||||
|     """ | ||||
|     down = False | ||||
|     while True: | ||||
|         try: | ||||
|             with trio.move_on_after(1) as cancel_scope: | ||||
|                 quotes = await net_func() | ||||
|                 if down: | ||||
|                     log.warn("Network is back up") | ||||
|                 return quotes | ||||
|             if cancel_scope.cancelled_caught: | ||||
|                 log.warn("Quote query timed out") | ||||
|                 continue | ||||
|         except socket.gaierror: | ||||
|             if not down:  # only report/log network down once | ||||
|                 log.warn(f"Network is down waiting for re-establishment...") | ||||
|                 down = True | ||||
|             await trio.sleep(sleep) | ||||
| 
 | ||||
| 
 | ||||
| async def stream_quotes( | ||||
|     brokermod: ModuleType, | ||||
|     get_quotes: Coroutine, | ||||
|     tickers2chans: Dict[str, tractor.Channel], | ||||
|     rate: int = 5,  # delay between quote requests | ||||
|     diff_cached: bool = True,  # only deliver "new" quotes to the queue | ||||
|     cid: str = None, | ||||
| ) -> None: | ||||
|     """Stream quotes for a sequence of tickers at the given ``rate`` | ||||
|     per second. | ||||
| 
 | ||||
|     A stock-broker client ``get_quotes()`` async context manager must be | ||||
|     provided which returns an async quote retrieval function. | ||||
|     """ | ||||
|     broker_limit = getattr(brokermod, '_rate_limit', float('inf')) | ||||
|     if broker_limit < rate: | ||||
|         rate = broker_limit | ||||
|         log.warn(f"Limiting {brokermod.__name__} query rate to {rate}/sec") | ||||
| 
 | ||||
|     sleeptime = round(1. / rate, 3) | ||||
|     _cache = {}  # ticker to quote caching | ||||
| 
 | ||||
|     while True:  # use an event here to trigger exit? | ||||
|         prequote_start = time.time() | ||||
| 
 | ||||
|         if not any(tickers2chans.values()): | ||||
|             log.warn(f"No subs left for broker {brokermod.name}, exiting task") | ||||
|             break | ||||
| 
 | ||||
|         tickers = list(tickers2chans.keys()) | ||||
|         with trio.move_on_after(3) as cancel_scope: | ||||
|             quotes = await get_quotes(tickers) | ||||
| 
 | ||||
|         cancelled = cancel_scope.cancelled_caught | ||||
|         if cancelled: | ||||
|             log.warn("Quote query timed out after 3 seconds, retrying...") | ||||
|             # handle network outages by idling until response is received | ||||
|             quotes = await wait_for_network(partial(get_quotes, tickers)) | ||||
| 
 | ||||
|         postquote_start = time.time() | ||||
|         chan_payloads = {} | ||||
|         for symbol, quote in quotes.items(): | ||||
|             if diff_cached: | ||||
|                 # if cache is enabled then only deliver "new" changes | ||||
|                 last = _cache.setdefault(symbol, {}) | ||||
|                 new = set(quote.items()) - set(last.items()) | ||||
|                 if new: | ||||
|                     log.info( | ||||
|                         f"New quote {quote['symbol']}:\n{new}") | ||||
|                     _cache[symbol] = quote | ||||
|                     for chan, cid in tickers2chans.get(symbol, set()): | ||||
|                         chan_payloads.setdefault( | ||||
|                             chan, | ||||
|                             {'yield': {}, 'cid': cid} | ||||
|                         )['yield'][symbol] = quote | ||||
|             else: | ||||
|                 for chan, cid in tickers2chans[symbol]: | ||||
|                     chan_payloads.setdefault( | ||||
|                         chan, | ||||
|                         {'yield': {}, 'cid': cid} | ||||
|                     )['yield'][symbol] = quote | ||||
| 
 | ||||
|         # deliver to each subscriber (fan out) | ||||
|         if chan_payloads: | ||||
|             for chan, payload in chan_payloads.items(): | ||||
|                 try: | ||||
|                     await chan.send(payload) | ||||
|                 except ( | ||||
|                     # That's right, anything you can think of... | ||||
|                     trio.ClosedStreamError, ConnectionResetError, | ||||
|                     ConnectionRefusedError, | ||||
|                 ): | ||||
|                     log.warn(f"{chan} went down?") | ||||
|                     for chanset in tickers2chans.values(): | ||||
|                         chanset.discard((chan, cid)) | ||||
| 
 | ||||
|         # latency monitoring | ||||
|         req_time = round(postquote_start - prequote_start, 3) | ||||
|         proc_time = round(time.time() - postquote_start, 3) | ||||
|         tot = req_time + proc_time | ||||
|         log.debug(f"Request + processing took {tot}") | ||||
|         delay = sleeptime - tot | ||||
|         if delay <= 0: | ||||
|             log.warn( | ||||
|                 f"Took {req_time} (request) + {proc_time} (processing) " | ||||
|                 f"= {tot} secs (> {sleeptime}) for processing quotes?") | ||||
|         else: | ||||
|             log.debug(f"Sleeping for {delay}") | ||||
|             await trio.sleep(delay) | ||||
| 
 | ||||
|     log.info(f"Terminating stream quoter task for {brokermod.name}") | ||||
| 
 | ||||
| 
 | ||||
| async def get_cached_client(broker, tickers): | ||||
|     """Get or create the current actor's cached broker client. | ||||
|     """ | ||||
|     # check if a cached client is in the local actor's statespace | ||||
|     clients = tractor.current_actor().statespace.setdefault('clients', {}) | ||||
|     try: | ||||
|         return clients[broker] | ||||
|     except KeyError: | ||||
|         log.info(f"Creating new client for broker {broker}") | ||||
|         brokermod = get_brokermod(broker) | ||||
|         # TODO: move to AsyncExitStack in 3.7 | ||||
|         client_cntxmng = brokermod.get_client() | ||||
|         client = await client_cntxmng.__aenter__() | ||||
|         get_quotes = await brokermod.quoter(client, tickers) | ||||
|         clients[broker] = ( | ||||
|             brokermod, client, client_cntxmng, get_quotes) | ||||
| 
 | ||||
|         return brokermod, client, client_cntxmng, get_quotes | ||||
| 
 | ||||
| 
 | ||||
| async def symbol_data(broker, tickers): | ||||
|     """Retrieve baseline symbol info from broker. | ||||
|     """ | ||||
|     _, client, _, get_quotes = await get_cached_client(broker, tickers) | ||||
|     return await client.symbol_data(tickers) | ||||
| 
 | ||||
| 
 | ||||
| async def smoke_quote(get_quotes, tickers, broker): | ||||
|     """Do an initial "smoke" request for symbols in ``tickers`` filtering | ||||
|     out any symbols not supported by the broker queried in the call to | ||||
|     ``get_quotes()``. | ||||
|     """ | ||||
|     # TODO: trim out with #37 | ||||
|     ################################################# | ||||
|     # get a single quote filtering out any bad tickers | ||||
|     # NOTE: this code is always run for every new client | ||||
|     # subscription even when a broker quoter task is already running | ||||
|     # since the new client needs to know what symbols are accepted | ||||
|     log.warn(f"Retrieving smoke quote for symbols {tickers}") | ||||
|     quotes = await get_quotes(tickers) | ||||
|     # report any tickers that aren't returned in the first quote | ||||
|     invalid_tickers = set(tickers) - set(quotes) | ||||
|     for symbol in invalid_tickers: | ||||
|         tickers.remove(symbol) | ||||
|         log.warn( | ||||
|             f"Symbol `{symbol}` not found by broker `{broker}`" | ||||
|         ) | ||||
| 
 | ||||
|     # pop any tickers that return "empty" quotes | ||||
|     payload = {} | ||||
|     for symbol, quote in quotes.items(): | ||||
|         if quote is None: | ||||
|             log.warn( | ||||
|                 f"Symbol `{symbol}` not found by broker" | ||||
|                 f" `{broker}`") | ||||
|             # XXX: not this mutates the input list (for now) | ||||
|             tickers.remove(symbol) | ||||
|             continue | ||||
|         payload[symbol] = quote | ||||
| 
 | ||||
|     return payload | ||||
| 
 | ||||
|     # end of section to be trimmed out with #37 | ||||
|     ########################################### | ||||
| 
 | ||||
| 
 | ||||
| def modify_quote_stream(broker, tickers, chan=None, cid=None): | ||||
|     """Absolute symbol subscription list for each quote stream. | ||||
| 
 | ||||
|     Effectively a consumer subscription api. | ||||
|     """ | ||||
|     log.info(f"{chan} changed symbol subscription to {tickers}") | ||||
|     ss = tractor.current_actor().statespace | ||||
|     broker2tickersubs = ss['broker2tickersubs'] | ||||
|     tickers2chans = broker2tickersubs.get(broker) | ||||
|     # update map from each symbol to requesting client's chan | ||||
|     for ticker in tickers: | ||||
|         tickers2chans.setdefault(ticker, set()).add((chan, cid)) | ||||
| 
 | ||||
|     for ticker in filter( | ||||
|         lambda ticker: ticker not in tickers, tickers2chans.copy() | ||||
|     ): | ||||
|         chanset = tickers2chans.get(ticker) | ||||
|         # XXX: cid will be different on unsub call | ||||
|         for item in chanset.copy(): | ||||
|             if chan in item: | ||||
|                 chanset.discard(item) | ||||
| 
 | ||||
|         if not chanset: | ||||
|             # pop empty sets which will trigger bg quoter task termination | ||||
|             tickers2chans.pop(ticker) | ||||
| 
 | ||||
| 
 | ||||
| async def start_quote_stream( | ||||
|     broker: str, | ||||
|     tickers: [str], | ||||
|     chan: tractor.Channel = None, | ||||
|     cid: str = None, | ||||
| ) -> None: | ||||
|     """Handle per-broker quote stream subscriptions using a "lazy" pub-sub | ||||
|     pattern. | ||||
| 
 | ||||
|     Spawns new quoter tasks for each broker backend on-demand. | ||||
|     Since most brokers seems to support batch quote requests we | ||||
|     limit to one task per process for now. | ||||
|     """ | ||||
|     actor = tractor.current_actor() | ||||
|     # set log level after fork | ||||
|     get_console_log(actor.loglevel) | ||||
|     # pull global vars from local actor | ||||
|     ss = actor.statespace | ||||
|     broker2tickersubs = ss['broker2tickersubs'] | ||||
|     clients = ss['clients'] | ||||
|     dtasks = ss['dtasks'] | ||||
|     tickers = list(tickers) | ||||
|     log.info( | ||||
|         f"{chan.uid} subscribed to {broker} for tickers {tickers}") | ||||
| 
 | ||||
|     brokermod, client, _, get_quotes = await get_cached_client(broker, tickers) | ||||
|     if broker not in broker2tickersubs: | ||||
|         tickers2chans = broker2tickersubs.setdefault(broker, {}) | ||||
|     else: | ||||
|         log.info(f"Subscribing with existing `{broker}` daemon") | ||||
|         tickers2chans = broker2tickersubs[broker] | ||||
| 
 | ||||
|     # do a smoke quote (note this mutates the input list and filters out bad | ||||
|     # symbols for now) | ||||
|     payload = await smoke_quote(get_quotes, tickers, broker) | ||||
|     # push initial smoke quote response for client initialization | ||||
|     await chan.send({'yield': payload, 'cid': cid}) | ||||
| 
 | ||||
|     # update map from each symbol to requesting client's chan | ||||
|     modify_quote_stream(broker, tickers, chan=chan, cid=cid) | ||||
| 
 | ||||
|     try: | ||||
|         if broker not in dtasks: | ||||
|             # no quoter task yet so start a daemon task | ||||
|             log.info(f"Spawning quoter task for {brokermod.name}") | ||||
|             async with trio.open_nursery() as nursery: | ||||
|                 nursery.start_soon(partial( | ||||
|                     stream_quotes, brokermod, get_quotes, tickers2chans, | ||||
|                     cid=cid) | ||||
|                 ) | ||||
|                 dtasks.add(broker) | ||||
| 
 | ||||
|             # unblocks when no more symbols subscriptions exist and the | ||||
|             # quote streamer task terminates (usually because another call | ||||
|             # was made to `modify_quoter` to unsubscribe from streaming | ||||
|             # symbols) | ||||
|             log.info(f"Terminated quoter task for {brokermod.name}") | ||||
| 
 | ||||
|             # TODO: move to AsyncExitStack in 3.7 | ||||
|             for _, _, cntxmng, _ in clients.values(): | ||||
|                 # FIXME: yes I know there's no error handling.. | ||||
|                 await cntxmng.__aexit__(None, None, None) | ||||
|     finally: | ||||
|         # if there are truly no more subscriptions with this broker | ||||
|         # drop from broker subs dict | ||||
|         if not any(tickers2chans.values()): | ||||
|             log.info(f"No more subscriptions for {broker}") | ||||
|             broker2tickersubs.pop(broker, None) | ||||
|             dtasks.discard(broker) | ||||
|  |  | |||
|  | @ -0,0 +1,295 @@ | |||
| """ | ||||
| Live data feed machinery | ||||
| """ | ||||
| import time | ||||
| from functools import partial | ||||
| import socket | ||||
| from types import ModuleType | ||||
| from typing import Coroutine, Callable, Dict | ||||
| 
 | ||||
| import trio | ||||
| import tractor | ||||
| 
 | ||||
| from ..log import get_logger, get_console_log | ||||
| from . import get_brokermod | ||||
| 
 | ||||
| 
 | ||||
| log = get_logger('broker.core') | ||||
| 
 | ||||
| 
 | ||||
| async def wait_for_network(net_func: Callable, sleep: int = 1) -> dict: | ||||
|     """Wait until the network comes back up. | ||||
|     """ | ||||
|     down = False | ||||
|     while True: | ||||
|         try: | ||||
|             with trio.move_on_after(1) as cancel_scope: | ||||
|                 quotes = await net_func() | ||||
|                 if down: | ||||
|                     log.warn("Network is back up") | ||||
|                 return quotes | ||||
|             if cancel_scope.cancelled_caught: | ||||
|                 log.warn("Quote query timed out") | ||||
|                 continue | ||||
|         except socket.gaierror: | ||||
|             if not down:  # only report/log network down once | ||||
|                 log.warn(f"Network is down waiting for re-establishment...") | ||||
|                 down = True | ||||
|             await trio.sleep(sleep) | ||||
| 
 | ||||
| 
 | ||||
| async def stream_quotes( | ||||
|     brokermod: ModuleType, | ||||
|     get_quotes: Coroutine, | ||||
|     tickers2chans: Dict[str, tractor.Channel], | ||||
|     rate: int = 5,  # delay between quote requests | ||||
|     diff_cached: bool = True,  # only deliver "new" quotes to the queue | ||||
|     cid: str = None, | ||||
| ) -> None: | ||||
|     """Stream quotes for a sequence of tickers at the given ``rate`` | ||||
|     per second. | ||||
| 
 | ||||
|     A stock-broker client ``get_quotes()`` async context manager must be | ||||
|     provided which returns an async quote retrieval function. | ||||
|     """ | ||||
|     broker_limit = getattr(brokermod, '_rate_limit', float('inf')) | ||||
|     if broker_limit < rate: | ||||
|         rate = broker_limit | ||||
|         log.warn(f"Limiting {brokermod.__name__} query rate to {rate}/sec") | ||||
| 
 | ||||
|     sleeptime = round(1. / rate, 3) | ||||
|     _cache = {}  # ticker to quote caching | ||||
| 
 | ||||
|     while True:  # use an event here to trigger exit? | ||||
|         prequote_start = time.time() | ||||
| 
 | ||||
|         if not any(tickers2chans.values()): | ||||
|             log.warn(f"No subs left for broker {brokermod.name}, exiting task") | ||||
|             break | ||||
| 
 | ||||
|         tickers = list(tickers2chans.keys()) | ||||
|         with trio.move_on_after(3) as cancel_scope: | ||||
|             quotes = await get_quotes(tickers) | ||||
| 
 | ||||
|         cancelled = cancel_scope.cancelled_caught | ||||
|         if cancelled: | ||||
|             log.warn("Quote query timed out after 3 seconds, retrying...") | ||||
|             # handle network outages by idling until response is received | ||||
|             quotes = await wait_for_network(partial(get_quotes, tickers)) | ||||
| 
 | ||||
|         postquote_start = time.time() | ||||
|         chan_payloads = {} | ||||
|         for symbol, quote in quotes.items(): | ||||
|             if diff_cached: | ||||
|                 # if cache is enabled then only deliver "new" changes | ||||
|                 last = _cache.setdefault(symbol, {}) | ||||
|                 new = set(quote.items()) - set(last.items()) | ||||
|                 if new: | ||||
|                     log.info( | ||||
|                         f"New quote {quote['symbol']}:\n{new}") | ||||
|                     _cache[symbol] = quote | ||||
|                     for chan, cid in tickers2chans.get(symbol, set()): | ||||
|                         chan_payloads.setdefault( | ||||
|                             chan, | ||||
|                             {'yield': {}, 'cid': cid} | ||||
|                         )['yield'][symbol] = quote | ||||
|             else: | ||||
|                 for chan, cid in tickers2chans[symbol]: | ||||
|                     chan_payloads.setdefault( | ||||
|                         chan, | ||||
|                         {'yield': {}, 'cid': cid} | ||||
|                     )['yield'][symbol] = quote | ||||
| 
 | ||||
|         # deliver to each subscriber (fan out) | ||||
|         if chan_payloads: | ||||
|             for chan, payload in chan_payloads.items(): | ||||
|                 try: | ||||
|                     await chan.send(payload) | ||||
|                 except ( | ||||
|                     # That's right, anything you can think of... | ||||
|                     trio.ClosedStreamError, ConnectionResetError, | ||||
|                     ConnectionRefusedError, | ||||
|                 ): | ||||
|                     log.warn(f"{chan} went down?") | ||||
|                     for chanset in tickers2chans.values(): | ||||
|                         chanset.discard((chan, cid)) | ||||
| 
 | ||||
|         # latency monitoring | ||||
|         req_time = round(postquote_start - prequote_start, 3) | ||||
|         proc_time = round(time.time() - postquote_start, 3) | ||||
|         tot = req_time + proc_time | ||||
|         log.debug(f"Request + processing took {tot}") | ||||
|         delay = sleeptime - tot | ||||
|         if delay <= 0: | ||||
|             log.warn( | ||||
|                 f"Took {req_time} (request) + {proc_time} (processing) " | ||||
|                 f"= {tot} secs (> {sleeptime}) for processing quotes?") | ||||
|         else: | ||||
|             log.debug(f"Sleeping for {delay}") | ||||
|             await trio.sleep(delay) | ||||
| 
 | ||||
|     log.info(f"Terminating stream quoter task for {brokermod.name}") | ||||
| 
 | ||||
| 
 | ||||
| async def get_cached_client(broker, tickers): | ||||
|     """Get or create the current actor's cached broker client. | ||||
|     """ | ||||
|     # check if a cached client is in the local actor's statespace | ||||
|     clients = tractor.current_actor().statespace.setdefault('clients', {}) | ||||
|     try: | ||||
|         return clients[broker] | ||||
|     except KeyError: | ||||
|         log.info(f"Creating new client for broker {broker}") | ||||
|         brokermod = get_brokermod(broker) | ||||
|         # TODO: move to AsyncExitStack in 3.7 | ||||
|         client_cntxmng = brokermod.get_client() | ||||
|         client = await client_cntxmng.__aenter__() | ||||
|         get_quotes = await brokermod.quoter(client, tickers) | ||||
|         clients[broker] = ( | ||||
|             brokermod, client, client_cntxmng, get_quotes) | ||||
| 
 | ||||
|         return brokermod, client, client_cntxmng, get_quotes | ||||
| 
 | ||||
| 
 | ||||
| async def symbol_data(broker, tickers): | ||||
|     """Retrieve baseline symbol info from broker. | ||||
|     """ | ||||
|     _, client, _, get_quotes = await get_cached_client(broker, tickers) | ||||
|     return await client.symbol_data(tickers) | ||||
| 
 | ||||
| 
 | ||||
| async def smoke_quote(get_quotes, tickers, broker): | ||||
|     """Do an initial "smoke" request for symbols in ``tickers`` filtering | ||||
|     out any symbols not supported by the broker queried in the call to | ||||
|     ``get_quotes()``. | ||||
|     """ | ||||
|     # TODO: trim out with #37 | ||||
|     ################################################# | ||||
|     # get a single quote filtering out any bad tickers | ||||
|     # NOTE: this code is always run for every new client | ||||
|     # subscription even when a broker quoter task is already running | ||||
|     # since the new client needs to know what symbols are accepted | ||||
|     log.warn(f"Retrieving smoke quote for symbols {tickers}") | ||||
|     quotes = await get_quotes(tickers) | ||||
|     # report any tickers that aren't returned in the first quote | ||||
|     invalid_tickers = set(tickers) - set(quotes) | ||||
|     for symbol in invalid_tickers: | ||||
|         tickers.remove(symbol) | ||||
|         log.warn( | ||||
|             f"Symbol `{symbol}` not found by broker `{broker}`" | ||||
|         ) | ||||
| 
 | ||||
|     # pop any tickers that return "empty" quotes | ||||
|     payload = {} | ||||
|     for symbol, quote in quotes.items(): | ||||
|         if quote is None: | ||||
|             log.warn( | ||||
|                 f"Symbol `{symbol}` not found by broker" | ||||
|                 f" `{broker}`") | ||||
|             # XXX: not this mutates the input list (for now) | ||||
|             tickers.remove(symbol) | ||||
|             continue | ||||
|         payload[symbol] = quote | ||||
| 
 | ||||
|     return payload | ||||
| 
 | ||||
|     # end of section to be trimmed out with #37 | ||||
|     ########################################### | ||||
| 
 | ||||
| 
 | ||||
| def modify_quote_stream(broker, tickers, chan=None, cid=None): | ||||
|     """Absolute symbol subscription list for each quote stream. | ||||
| 
 | ||||
|     Effectively a consumer subscription api. | ||||
|     """ | ||||
|     log.info(f"{chan} changed symbol subscription to {tickers}") | ||||
|     ss = tractor.current_actor().statespace | ||||
|     broker2tickersubs = ss['broker2tickersubs'] | ||||
|     tickers2chans = broker2tickersubs.get(broker) | ||||
|     # update map from each symbol to requesting client's chan | ||||
|     for ticker in tickers: | ||||
|         tickers2chans.setdefault(ticker, set()).add((chan, cid)) | ||||
| 
 | ||||
|     for ticker in filter( | ||||
|         lambda ticker: ticker not in tickers, tickers2chans.copy() | ||||
|     ): | ||||
|         chanset = tickers2chans.get(ticker) | ||||
|         # XXX: cid will be different on unsub call | ||||
|         for item in chanset.copy(): | ||||
|             if chan in item: | ||||
|                 chanset.discard(item) | ||||
| 
 | ||||
|         if not chanset: | ||||
|             # pop empty sets which will trigger bg quoter task termination | ||||
|             tickers2chans.pop(ticker) | ||||
| 
 | ||||
| 
 | ||||
| async def start_quote_stream( | ||||
|     broker: str, | ||||
|     tickers: [str], | ||||
|     chan: tractor.Channel = None, | ||||
|     cid: str = None, | ||||
| ) -> None: | ||||
|     """Handle per-broker quote stream subscriptions using a "lazy" pub-sub | ||||
|     pattern. | ||||
| 
 | ||||
|     Spawns new quoter tasks for each broker backend on-demand. | ||||
|     Since most brokers seems to support batch quote requests we | ||||
|     limit to one task per process for now. | ||||
|     """ | ||||
|     actor = tractor.current_actor() | ||||
|     # set log level after fork | ||||
|     get_console_log(actor.loglevel) | ||||
|     # pull global vars from local actor | ||||
|     ss = actor.statespace | ||||
|     broker2tickersubs = ss['broker2tickersubs'] | ||||
|     clients = ss['clients'] | ||||
|     dtasks = ss['dtasks'] | ||||
|     tickers = list(tickers) | ||||
|     log.info( | ||||
|         f"{chan.uid} subscribed to {broker} for tickers {tickers}") | ||||
| 
 | ||||
|     brokermod, client, _, get_quotes = await get_cached_client(broker, tickers) | ||||
|     if broker not in broker2tickersubs: | ||||
|         tickers2chans = broker2tickersubs.setdefault(broker, {}) | ||||
|     else: | ||||
|         log.info(f"Subscribing with existing `{broker}` daemon") | ||||
|         tickers2chans = broker2tickersubs[broker] | ||||
| 
 | ||||
|     # do a smoke quote (note this mutates the input list and filters out bad | ||||
|     # symbols for now) | ||||
|     payload = await smoke_quote(get_quotes, tickers, broker) | ||||
|     # push initial smoke quote response for client initialization | ||||
|     await chan.send({'yield': payload, 'cid': cid}) | ||||
| 
 | ||||
|     # update map from each symbol to requesting client's chan | ||||
|     modify_quote_stream(broker, tickers, chan=chan, cid=cid) | ||||
| 
 | ||||
|     try: | ||||
|         if broker not in dtasks: | ||||
|             # no quoter task yet so start a daemon task | ||||
|             log.info(f"Spawning quoter task for {brokermod.name}") | ||||
|             async with trio.open_nursery() as nursery: | ||||
|                 nursery.start_soon(partial( | ||||
|                     stream_quotes, brokermod, get_quotes, tickers2chans, | ||||
|                     cid=cid) | ||||
|                 ) | ||||
|                 dtasks.add(broker) | ||||
| 
 | ||||
|             # unblocks when no more symbols subscriptions exist and the | ||||
|             # quote streamer task terminates (usually because another call | ||||
|             # was made to `modify_quoter` to unsubscribe from streaming | ||||
|             # symbols) | ||||
|             log.info(f"Terminated quoter task for {brokermod.name}") | ||||
| 
 | ||||
|             # TODO: move to AsyncExitStack in 3.7 | ||||
|             for _, _, cntxmng, _ in clients.values(): | ||||
|                 # FIXME: yes I know there's no error handling.. | ||||
|                 await cntxmng.__aexit__(None, None, None) | ||||
|     finally: | ||||
|         # if there are truly no more subscriptions with this broker | ||||
|         # drop from broker subs dict | ||||
|         if not any(tickers2chans.values()): | ||||
|             log.info(f"No more subscriptions for {broker}") | ||||
|             broker2tickersubs.pop(broker, None) | ||||
|             dtasks.discard(broker) | ||||
|  | @ -29,7 +29,7 @@ def pikerd(loglevel, host): | |||
|     """ | ||||
|     get_console_log(loglevel) | ||||
|     tractor.run_daemon( | ||||
|         rpc_module_paths=['piker.brokers.core'], | ||||
|         rpc_module_paths=['piker.brokers.data'], | ||||
|         statespace={ | ||||
|             'broker2tickersubs': {}, | ||||
|             'clients': {}, | ||||
|  | @ -123,7 +123,7 @@ def quote(loglevel, broker, tickers, df_output): | |||
| @click.option('--df-output', '-df', flag_value=True, | ||||
|               help='Output in `pandas.DataFrame` format') | ||||
| @click.argument('symbol', required=True) | ||||
| def option_chain(loglevel, broker, symbol, df_output): | ||||
| def option_chain_quote(loglevel, broker, symbol, df_output): | ||||
|     """Retreive symbol quotes on the console in either json or dataframe | ||||
|     format. | ||||
|     """ | ||||
|  | @ -131,7 +131,7 @@ def option_chain(loglevel, broker, symbol, df_output): | |||
|     get_console_log(loglevel) | ||||
|     quotes = trio.run(partial(core.option_chain, brokermod, symbol))[symbol] | ||||
|     if not quotes: | ||||
|         log.error(f"No quotes could be found for {tickers}?") | ||||
|         log.error(f"No quotes could be found for {symbol}?") | ||||
|         return | ||||
| 
 | ||||
|     if df_output: | ||||
|  | @ -181,7 +181,7 @@ def monitor(loglevel, broker, rate, name, dhost): | |||
|                             'clients': {}, | ||||
|                             'dtasks': set(), | ||||
|                         }, | ||||
|                         rpc_module_paths=['piker.brokers.core'], | ||||
|                         rpc_module_paths=['piker.brokers.data'], | ||||
|                         loglevel=loglevel, | ||||
|                     ) | ||||
| 
 | ||||
|  |  | |||
		Loading…
	
		Reference in New Issue