bbgo_origin/pkg/strategy/grid2/recover.go

492 lines
15 KiB
Go
Raw Normal View History

2023-04-06 06:59:03 +00:00
package grid2
import (
"context"
"fmt"
"strconv"
"time"
"github.com/pkg/errors"
2023-04-06 06:59:03 +00:00
"github.com/c9s/bbgo/pkg/bbgo"
"github.com/c9s/bbgo/pkg/fixedpoint"
"github.com/c9s/bbgo/pkg/types"
)
2023-04-06 08:12:19 +00:00
func (s *Strategy) recoverByScanningTrades(ctx context.Context, session *bbgo.ExchangeSession) error {
defer func() {
s.updateGridNumOfOrdersMetricsWithLock()
s.updateOpenOrderPricesMetrics(s.orderExecutor.ActiveMakerOrders().Orders())
}()
2023-04-06 06:59:03 +00:00
historyService, implemented := session.Exchange.(types.ExchangeTradeHistoryService)
// if the exchange doesn't support ExchangeTradeHistoryService, do not run recover
if !implemented {
s.logger.Warn("ExchangeTradeHistoryService is not implemented, can not recover grid")
return nil
}
openOrders, err := session.Exchange.QueryOpenOrders(ctx, s.Symbol)
if err != nil {
2023-04-06 09:53:01 +00:00
return errors.Wrapf(err, "unable to query open orders when recovering")
2023-04-06 06:59:03 +00:00
}
s.logger.Infof("found %d open orders left on the %s order book", len(openOrders), s.Symbol)
if s.GridProfitStats.InitialOrderID != 0 {
2023-04-06 09:53:01 +00:00
s.logger.Info("InitialOrderID is already there, need to recover")
2023-04-06 10:00:21 +00:00
} else if len(openOrders) != 0 {
s.logger.Info("even though InitialOrderID is 0, there are open orders so need to recover")
2023-04-06 06:59:03 +00:00
} else {
2023-04-06 10:00:21 +00:00
s.logger.Info("InitialOrderID is 0 and there is no open orders, query trades to check it")
2023-04-06 06:59:03 +00:00
// initial order id may be new strategy or lost data in redis, so we need to check trades + open orders
// if there are open orders or trades, we need to recover
trades, err := historyService.QueryTrades(ctx, s.Symbol, &types.TradeQueryOptions{
// from 1, because some API will ignore 0 last trade id
LastTradeID: 1,
// if there is any trades, we need to recover.
Limit: 1,
})
if err != nil {
2023-04-06 09:53:01 +00:00
return errors.Wrapf(err, "unable to query trades when recovering")
2023-04-06 06:59:03 +00:00
}
if len(trades) == 0 {
2023-04-06 09:53:01 +00:00
s.logger.Info("0 trades found, it's a new strategy so no need to recover")
2023-04-06 06:59:03 +00:00
return nil
}
}
2023-04-06 09:53:01 +00:00
s.logger.Infof("start recovering")
2023-04-06 10:00:21 +00:00
if err := s.recoverWithOpenOrdersByScanningTrades(ctx, historyService, openOrders); err != nil {
2023-04-06 06:59:03 +00:00
return errors.Wrap(err, "grid recover error")
}
2023-04-26 09:30:31 +00:00
// emit ready after recover
s.EmitGridReady()
2023-04-06 15:57:54 +00:00
// debug and send metrics
// wait for the reverse order to be placed
time.Sleep(2 * time.Second)
debugGrid(s.logger, s.grid, s.orderExecutor.ActiveMakerOrders())
2023-04-26 08:14:53 +00:00
defer bbgo.Sync(ctx, s)
if s.EnableProfitFixer {
until := time.Now()
2023-04-26 09:30:31 +00:00
since := until.Add(-7 * 24 * time.Hour)
2023-04-26 08:14:53 +00:00
if s.FixProfitSince != nil {
since = s.FixProfitSince.Time()
}
fixer := newProfitFixer(s.grid, s.Symbol, historyService)
2023-04-26 15:48:02 +00:00
fixer.SetLogger(s.logger)
2023-04-26 08:14:53 +00:00
// set initial order ID = 0 instead of s.GridProfitStats.InitialOrderID because the order ID could be incorrect
2023-04-26 15:48:02 +00:00
if err := fixer.Fix(ctx, since, until, 0, s.GridProfitStats); err != nil {
2023-04-26 15:07:01 +00:00
return err
}
s.logger.Infof("fixed profitStats: %#v", s.GridProfitStats)
s.EmitGridProfit(s.GridProfitStats, nil)
2023-04-26 08:14:53 +00:00
}
2023-04-06 06:59:03 +00:00
return nil
}
2023-04-06 08:12:19 +00:00
func (s *Strategy) recoverWithOpenOrdersByScanningTrades(ctx context.Context, historyService types.ExchangeTradeHistoryService, openOrdersOnGrid []types.Order) error {
2023-04-06 06:59:03 +00:00
if s.orderQueryService == nil {
return fmt.Errorf("orderQueryService is nil, it can't get orders by trade")
}
// set grid
grid := s.newGrid()
s.setGrid(grid)
2023-04-06 16:40:32 +00:00
expectedNumOfOrders := s.GridNum - 1
numGridOpenOrders := int64(len(openOrdersOnGrid))
s.debugLog("open orders nums: %d, expected nums: %d", numGridOpenOrders, expectedNumOfOrders)
if expectedNumOfOrders == numGridOpenOrders {
// no need to recover, only need to add open orders back to active order book
s.addOrdersToActiveOrderBook(openOrdersOnGrid)
2023-04-06 06:59:03 +00:00
return nil
2023-04-06 16:40:32 +00:00
} else if expectedNumOfOrders < numGridOpenOrders {
2023-04-06 06:59:03 +00:00
return fmt.Errorf("amount of grid's open orders should not > amount of expected grid's orders")
}
2023-04-27 13:06:29 +00:00
// 1. build twin-order map
twinOrdersOpen, err := s.buildTwinOrderMap(grid.Pins, openOrdersOnGrid)
2023-04-06 06:59:03 +00:00
if err != nil {
return errors.Wrapf(err, "failed to build pin order map with open orders")
}
2023-04-27 13:06:29 +00:00
// 2. build the filled twin-order map by querying trades
twinOrdersFilled, err := s.buildFilledTwinOrderMapFromTrades(ctx, historyService, twinOrdersOpen)
2023-04-06 06:59:03 +00:00
if err != nil {
return errors.Wrapf(err, "failed to build filled pin order map")
}
2023-04-27 13:06:29 +00:00
// 3. get the filled orders from twin-order map
filledOrders := twinOrdersFilled.AscendingOrders()
2023-04-06 06:59:03 +00:00
// 4. verify the grid
2023-04-27 13:06:29 +00:00
if err := s.verifyFilledTwinGrid(s.grid.Pins, twinOrdersOpen, filledOrders); err != nil {
2023-04-06 06:59:03 +00:00
return errors.Wrapf(err, "verify grid with error")
}
// 5. add open orders to active order book.
s.addOrdersToActiveOrderBook(openOrdersOnGrid)
2023-04-06 06:59:03 +00:00
// 6. emit the filled orders
s.debugOrders("emit filled orders", filledOrders)
2023-04-06 06:59:03 +00:00
activeOrderBook := s.orderExecutor.ActiveMakerOrders()
for _, filledOrder := range filledOrders {
activeOrderBook.EmitFilled(filledOrder)
}
return nil
}
func (s *Strategy) verifyFilledGrid(pins []Pin, pinOrders PinOrderMap, filledOrders []types.Order) error {
2023-04-06 16:40:32 +00:00
s.debugLog("verifying filled grid - pins: %+v", pins)
s.debugLog("verifying filled grid - open pin orders:\n%s", pinOrders.String())
s.debugOrders("verifying filled grid - filled orders", filledOrders)
2023-04-06 06:59:03 +00:00
2023-04-06 16:40:32 +00:00
if err := addOrdersIntoPinOrderMap(pinOrders, filledOrders); err != nil {
return errors.Wrapf(err, "verifying filled grid error when add orders into pin order map")
2023-04-06 06:59:03 +00:00
}
2023-04-06 16:40:32 +00:00
s.debugLog("verifying filled grid - filled pin orders:\n%+v", pinOrders.String())
2023-04-06 06:59:03 +00:00
2023-04-06 16:40:32 +00:00
expectedSide := types.SideTypeBuy
2023-04-06 06:59:03 +00:00
for _, pin := range pins {
order, exist := pinOrders[fixedpoint.Value(pin)]
if !exist {
return fmt.Errorf("there is no order at price (%+v)", pin)
}
// if there is order with OrderID = 0, means we hit the empty pin
// there must be only one empty pin in the grid
// all orders below this pin need to be bid orders, above this pin need to be ask orders
if order.OrderID == 0 {
2023-04-06 16:40:32 +00:00
if expectedSide == types.SideTypeBuy {
expectedSide = types.SideTypeSell
2023-04-06 06:59:03 +00:00
continue
}
2023-04-06 16:40:32 +00:00
return fmt.Errorf("found more than one empty pins")
2023-04-06 06:59:03 +00:00
}
2023-04-06 16:40:32 +00:00
if order.Side != expectedSide {
return fmt.Errorf("the side of order (%s) is wrong, expected: %s", order.Side, expectedSide)
2023-04-06 06:59:03 +00:00
}
}
2023-04-06 16:40:32 +00:00
if expectedSide != types.SideTypeSell {
2023-04-06 06:59:03 +00:00
return fmt.Errorf("there is no empty pin in the grid")
}
return nil
}
// buildPinOrderMap build the pin-order map with grid and open orders.
// The keys of this map contains all required pins of this grid.
// If the Order of the pin is empty types.Order (OrderID == 0), it means there is no open orders at this pin.
func (s *Strategy) buildPinOrderMap(pins []Pin, openOrders []types.Order) (PinOrderMap, error) {
pinOrderMap := make(PinOrderMap)
for _, pin := range pins {
pinOrderMap[fixedpoint.Value(pin)] = types.Order{}
}
for _, openOrder := range openOrders {
pin := openOrder.Price
v, exist := pinOrderMap[pin]
if !exist {
return nil, fmt.Errorf("the price of the order (id: %d) is not in pins", openOrder.OrderID)
}
if v.OrderID != 0 {
return nil, fmt.Errorf("there are duplicated open orders at the same pin")
}
pinOrderMap[pin] = openOrder
}
return pinOrderMap, nil
}
// buildFilledPinOrderMapFromTrades will query the trades from last 24 hour and use them to build a pin order map
// It will skip the orders on pins at which open orders are already
func (s *Strategy) buildFilledPinOrderMapFromTrades(ctx context.Context, historyService types.ExchangeTradeHistoryService, pinOrdersOpen PinOrderMap) (PinOrderMap, error) {
pinOrdersFilled := make(PinOrderMap)
// existedOrders is used to avoid re-query the same orders
existedOrders := pinOrdersOpen.SyncOrderMap()
var limit int64 = 1000
// get the filled orders when bbgo is down in order from trades
// [NOTE] only retrieve from last 24 hours !!!
var fromTradeID uint64 = 0
for {
trades, err := historyService.QueryTrades(ctx, s.Symbol, &types.TradeQueryOptions{
LastTradeID: fromTradeID,
Limit: limit,
})
if err != nil {
return nil, errors.Wrapf(err, "failed to query trades to recover the grid with open orders")
}
s.debugLog("QueryTrades return %d trades", len(trades))
for _, trade := range trades {
s.debugLog(trade.String())
if existedOrders.Exists(trade.OrderID) {
// already queries, skip
continue
}
order, err := s.orderQueryService.QueryOrder(ctx, types.OrderQuery{
OrderID: strconv.FormatUint(trade.OrderID, 10),
})
if err != nil {
return nil, errors.Wrapf(err, "failed to query order by trade")
}
s.debugLog("%s (group_id: %d)", order.String(), order.GroupID)
// avoid query this order again
existedOrders.Add(*order)
// add 1 to avoid duplicate
fromTradeID = trade.ID + 1
// checked the trade's order is filled order
pin := order.Price
v, exist := pinOrdersOpen[pin]
if !exist {
return nil, fmt.Errorf("the price of the order with the same GroupID is not in pins")
}
// skip open orders on grid
if v.OrderID != 0 {
continue
}
// check the order's creation time
if pinOrder, exist := pinOrdersFilled[pin]; exist && pinOrder.CreationTime.Time().After(order.CreationTime.Time()) {
// do not replace the pin order if the order's creation time is not after pin order's creation time
// this situation should not happen actually, because the trades is already sorted.
s.logger.Infof("pinOrder's creation time (%s) should not be after order's creation time (%s)", pinOrder.CreationTime, order.CreationTime)
continue
}
pinOrdersFilled[pin] = *order
}
// stop condition
if int64(len(trades)) < limit {
break
}
}
return pinOrdersFilled, nil
}
2023-04-06 16:40:32 +00:00
func addOrdersIntoPinOrderMap(pinOrders PinOrderMap, orders []types.Order) error {
for _, order := range orders {
price := order.Price
if o, exist := pinOrders[price]; !exist {
return fmt.Errorf("the price (%+v) is not in pins", price)
} else if o.OrderID != 0 {
return fmt.Errorf("there is already an order at this price (%+v)", price)
} else {
pinOrders[price] = order
}
}
return nil
}
2023-04-27 13:06:29 +00:00
func (s *Strategy) verifyFilledTwinGrid(pins []Pin, twinOrders TwinOrderMap, filledOrders []types.Order) error {
s.debugLog("verifying filled grid - pins: %+v", pins)
s.debugOrders("verifying filled grid - filled orders", filledOrders)
2023-04-28 08:02:22 +00:00
s.debugLog("verifying filled grid - open twin orders:\n%s", twinOrders.String())
2023-04-27 13:06:29 +00:00
if err := s.addOrdersIntoTwinOrderMap(twinOrders, filledOrders); err != nil {
return errors.Wrapf(err, "verifying filled grid error when add orders into twin order map")
}
s.debugLog("verifying filled grid - filled twin orders:\n%+v", twinOrders.String())
for i, pin := range pins {
2023-04-28 08:02:22 +00:00
// we use twinOrderMap to make sure there are no duplicated order at one grid, and we use the sell price as key so we skip the pins[0] which is only for buy price
2023-04-27 13:06:29 +00:00
if i == 0 {
continue
}
twin, exist := twinOrders[fixedpoint.Value(pin)]
if !exist {
return fmt.Errorf("there is no order at price (%+v)", pin)
}
if !twin.Exist() {
return fmt.Errorf("all the price need a twin")
}
2023-04-28 08:02:22 +00:00
if !twin.IsValid() {
return fmt.Errorf("all the twins need to be valid")
}
2023-04-27 13:06:29 +00:00
}
return nil
}
// buildTwinOrderMap build the pin-order map with grid and open orders.
// The keys of this map contains all required pins of this grid.
// If the Order of the pin is empty types.Order (OrderID == 0), it means there is no open orders at this pin.
func (s *Strategy) buildTwinOrderMap(pins []Pin, openOrders []types.Order) (TwinOrderMap, error) {
twinOrderMap := make(TwinOrderMap)
for i, pin := range pins {
// twin order map only use sell price as key, so skip 0
if i == 0 {
continue
}
twinOrderMap[fixedpoint.Value(pin)] = TwinOrder{}
}
for _, openOrder := range openOrders {
twinKey, err := findTwinOrderMapKey(s.grid, openOrder)
if err != nil {
return nil, errors.Wrapf(err, "failed to build twin order map")
}
twinOrder, exist := twinOrderMap[twinKey]
if !exist {
return nil, fmt.Errorf("the price of the openOrder (id: %d) is not in pins", openOrder.OrderID)
}
if twinOrder.Exist() {
return nil, fmt.Errorf("there are multiple order in a twin")
}
twinOrder.SetOrder(openOrder)
twinOrderMap[twinKey] = twinOrder
}
return twinOrderMap, nil
}
// buildFilledTwinOrderMapFromTrades will query the trades from last 24 hour and use them to build a pin order map
// It will skip the orders on pins at which open orders are already
func (s *Strategy) buildFilledTwinOrderMapFromTrades(ctx context.Context, historyService types.ExchangeTradeHistoryService, twinOrdersOpen TwinOrderMap) (TwinOrderMap, error) {
twinOrdersFilled := make(TwinOrderMap)
// existedOrders is used to avoid re-query the same orders
existedOrders := twinOrdersOpen.SyncOrderMap()
var limit int64 = 1000
// get the filled orders when bbgo is down in order from trades
// [NOTE] only retrieve from last 24 hours !!!
var fromTradeID uint64 = 0
for {
trades, err := historyService.QueryTrades(ctx, s.Symbol, &types.TradeQueryOptions{
LastTradeID: fromTradeID,
Limit: limit,
})
if err != nil {
return nil, errors.Wrapf(err, "failed to query trades to recover the grid with open orders")
}
s.debugLog("QueryTrades return %d trades", len(trades))
for _, trade := range trades {
s.debugLog(trade.String())
if existedOrders.Exists(trade.OrderID) {
// already queries, skip
continue
}
order, err := s.orderQueryService.QueryOrder(ctx, types.OrderQuery{
OrderID: strconv.FormatUint(trade.OrderID, 10),
})
if err != nil {
return nil, errors.Wrapf(err, "failed to query order by trade")
}
s.debugLog("%s (group_id: %d)", order.String(), order.GroupID)
// avoid query this order again
existedOrders.Add(*order)
2023-04-28 08:02:22 +00:00
if order.GroupID != s.OrderGroupID {
continue
}
2023-04-27 13:06:29 +00:00
// add 1 to avoid duplicate
fromTradeID = trade.ID + 1
twinOrderKey, err := findTwinOrderMapKey(s.grid, *order)
if err != nil {
return nil, errors.Wrapf(err, "failed to find grid order map's key when recover")
}
twinOrderOpen, exist := twinOrdersOpen[twinOrderKey]
if !exist {
return nil, fmt.Errorf("the price of the order with the same GroupID is not in pins")
}
if twinOrderOpen.Exist() {
continue
}
if twinOrder, exist := twinOrdersFilled[twinOrderKey]; exist {
to := twinOrder.GetOrder()
if to.UpdateTime.Time().After(order.UpdateTime.Time()) {
s.logger.Infof("twinOrder's update time (%s) should not be after order's update time (%s)", to.UpdateTime, order.UpdateTime)
continue
}
}
twinOrder := TwinOrder{}
twinOrder.SetOrder(*order)
twinOrdersFilled[twinOrderKey] = twinOrder
}
// stop condition
if int64(len(trades)) < limit {
break
}
}
return twinOrdersFilled, nil
}
func (s *Strategy) addOrdersIntoTwinOrderMap(twinOrders TwinOrderMap, orders []types.Order) error {
for _, order := range orders {
k, err := findTwinOrderMapKey(s.grid, order)
if err != nil {
return errors.Wrap(err, "failed to add orders into twin order map")
}
if v, exist := twinOrders[k]; !exist {
return fmt.Errorf("the price (%+v) is not in pins", k)
} else if v.Exist() {
return fmt.Errorf("there is already a twin order at this price (%+v)", k)
} else {
twin := TwinOrder{}
twin.SetOrder(order)
twinOrders[k] = twin
}
}
return nil
}