From bb7ce9e6adc63339be776dc6a42eed96ce549231 Mon Sep 17 00:00:00 2001 From: Alex Towle Date: Tue, 28 Jul 2020 17:37:03 -0500 Subject: [PATCH 1/3] Fixed issue that crashed Mesh node (#888) * Fixed issue that crashed Mesh node * Addressed review feedback from @albrow * Fixed a regression in `FilteredPaginationSubprotocolV0` * Fixed bug that caused ordersync subprotocols to be selected at random * Remove debugging logic * Addressed review feedback from @albrow --- core/ordersync/ordersync.go | 56 +++++++++++++++++++------------------ 1 file changed, 29 insertions(+), 27 deletions(-) diff --git a/core/ordersync/ordersync.go b/core/ordersync/ordersync.go index 2d9ff59f6..593468c88 100644 --- a/core/ordersync/ordersync.go +++ b/core/ordersync/ordersync.go @@ -108,23 +108,16 @@ type rawResponse struct { // Service is the main entrypoint for running the ordersync protocol. It handles // responding to and sending ordersync requests. type Service struct { - ctx context.Context - node *p2p.Node - subprotocols map[string]Subprotocol + ctx context.Context + node *p2p.Node + // preferredSubprotocols is the list of supported subprotocol IDs in order of preference. + preferredSubprotocols []string + subprotocolSet map[string]Subprotocol // requestRateLimiter is a rate limiter for incoming ordersync requests. It's // shared between all peers. requestRateLimiter *rate.Limiter } -// SupportedSubprotocols returns the subprotocols that are supported by the service. -func (s *Service) SupportedSubprotocols() []string { - sids := []string{} - for sid := range s.subprotocols { - sids = append(sids, sid) - } - return sids -} - // Subprotocol is a lower-level protocol which defines the details for the // request/response metadata. While the ordersync protocol supports sending // requests and responses in order to synchronize orders between two peers @@ -159,15 +152,18 @@ type Subprotocol interface { // order of preference. The service will automatically pick the most preferred protocol // that is supported by both peers for each request/response. func New(ctx context.Context, node *p2p.Node, subprotocols []Subprotocol) *Service { + sids := []string{} supportedSubprotocols := map[string]Subprotocol{} for _, subp := range subprotocols { + sids = append(sids, subp.Name()) supportedSubprotocols[subp.Name()] = subp } s := &Service{ - ctx: ctx, - node: node, - subprotocols: supportedSubprotocols, - requestRateLimiter: rate.NewLimiter(maxRequestsPerSecond, requestsBurst), + ctx: ctx, + node: node, + subprotocolSet: supportedSubprotocols, + preferredSubprotocols: sids, + requestRateLimiter: rate.NewLimiter(maxRequestsPerSecond, requestsBurst), } s.node.SetStreamHandler(ID, s.HandleStream) return s @@ -177,7 +173,7 @@ func New(ctx context.Context, node *p2p.Node, subprotocols []Subprotocol) *Servi // based on the given request. func (s *Service) GetMatchingSubprotocol(rawReq *rawRequest) (Subprotocol, int, error) { for i, protoID := range rawReq.Subprotocols { - subprotocol, found := s.subprotocols[protoID] + subprotocol, found := s.subprotocolSet[protoID] if found { return subprotocol, i, nil } @@ -185,7 +181,7 @@ func (s *Service) GetMatchingSubprotocol(rawReq *rawRequest) (Subprotocol, int, err := NoMatchingSubprotocolsError{ Requested: rawReq.Subprotocols, - Supported: s.SupportedSubprotocols(), + Supported: s.preferredSubprotocols, } return nil, 0, err } @@ -237,7 +233,16 @@ func (s *Service) HandleStream(stream network.Stream) { if len(rawReq.Subprotocols) > 1 { firstRequests := FirstRequestsForSubprotocols{} err := json.Unmarshal(rawReq.Metadata, &firstRequests) - if err == nil { + + // NOTE(jalextowle): Older versions of Mesh did not include + // metadata in the first ordersync request. In order to handle + // this in a backwards compatible way, we simply avoid updating + // the request metadata if there was an error decoding the + // metadata from the request or if the length of the + // MetadataForSubprotocol is too small (or empty). This latter + // check also ensures that the array is long enough for us + // to access the i-th element. + if err == nil && len(firstRequests.MetadataForSubprotocol) > i { rawReq.Metadata = firstRequests.MetadataForSubprotocol[i] } } @@ -424,12 +429,9 @@ type FirstRequestsForSubprotocols struct { // contains metadata for all of the ordersync subprotocols. func (s *Service) createFirstRequestForAllSubprotocols() (*rawRequest, error) { metadata := []json.RawMessage{} - for _, subprotocolString := range s.SupportedSubprotocols() { - subprotocol, found := s.subprotocols[subprotocolString] - if !found { - return nil, fmt.Errorf("cannot generate first request metadata for subprotocol %s", subprotocolString) - } - m, err := subprotocol.GenerateFirstRequestMetadata() + for _, sid := range s.preferredSubprotocols { + subp, _ := s.subprotocolSet[sid] + m, err := subp.GenerateFirstRequestMetadata() if err != nil { return nil, err } @@ -443,7 +445,7 @@ func (s *Service) createFirstRequestForAllSubprotocols() (*rawRequest, error) { } return &rawRequest{ Type: TypeRequest, - Subprotocols: s.SupportedSubprotocols(), + Subprotocols: s.preferredSubprotocols, Metadata: encodedMetadata, }, nil } @@ -497,7 +499,7 @@ func (s *Service) getOrdersFromPeer(ctx context.Context, providerID peer.ID) err } s.handlePeerScoreEvent(providerID, psValidMessage) - subprotocol, found := s.subprotocols[rawRes.Subprotocol] + subprotocol, found := s.subprotocolSet[rawRes.Subprotocol] if !found { s.handlePeerScoreEvent(providerID, psSubprotocolNegotiationFailed) return fmt.Errorf("unsupported subprotocol: %s", subprotocol) From 649c756b1c01b7abcec82f7822ca5da9390d865a Mon Sep 17 00:00:00 2001 From: Alex Towle Date: Fri, 31 Jul 2020 18:10:54 -0500 Subject: [PATCH 2/3] test: Added more tests for ordersync (#890) * Added a test for orderfilter json encoding * Added ordersync test for nodes with different filters * Added ordersync test for receiving first request from old peer * Fixed ordersync tests with distinct orderfilters * Added another test case * Cleaned up in anticipation of review * Refactored orderfilter tests * Addressed some review feedback from @albrow * Apply suggestions from @albrow Co-authored-by: Alex Browne * Fixed issues caused by suggestions * Fixed naming Co-authored-by: Alex Browne --- core/core_test.go | 242 +++++++++++++++++++++---------- core/message_handler.go | 7 - core/ordersync/ordersync.go | 97 +++++++------ core/ordersync/ordersync_test.go | 210 +++++++++++++++++++++++++++ orderfilter/filter_test.go | 53 ++++++- yarn.lock | 6 +- 6 files changed, 477 insertions(+), 138 deletions(-) diff --git a/core/core_test.go b/core/core_test.go index 993a1ef5a..42d7efac9 100644 --- a/core/core_test.go +++ b/core/core_test.go @@ -5,6 +5,8 @@ package core import ( "context" "flag" + "fmt" + "math/big" "sync" "testing" "time" @@ -92,11 +94,14 @@ func TestConfigChainIDAndRPCMatchDetection(t *testing.T) { wg.Wait() } -func newTestApp(t *testing.T) *App { - return newTestAppWithPrivateConfig(t, defaultPrivateConfig()) +func newTestApp(t *testing.T, ctx context.Context) *App { + return newTestAppWithPrivateConfig(t, ctx, defaultOrderFilter, defaultPrivateConfig()) } -func newTestAppWithPrivateConfig(t *testing.T, pConfig privateConfig) *App { +func newTestAppWithPrivateConfig(t *testing.T, ctx context.Context, customOrderFilter string, pConfig privateConfig) *App { + if customOrderFilter == "" { + customOrderFilter = defaultOrderFilter + } dataDir := "/tmp/test_node/" + uuid.New().String() config := Config{ Verbosity: 2, @@ -113,7 +118,7 @@ func newTestAppWithPrivateConfig(t *testing.T, pConfig privateConfig) *App { EthereumRPCMaxRequestsPer24HrUTC: 99999999999999, EthereumRPCMaxRequestsPerSecond: 99999999999999, MaxOrdersInStorage: 100000, - CustomOrderFilter: "{}", + CustomOrderFilter: customOrderFilter, } app, err := newWithPrivateConfig(config, pConfig) require.NoError(t, err) @@ -177,100 +182,177 @@ func TestOrderSync(t *testing.T) { t.Skip("Serial tests (tests which cannot run in parallel) are disabled. You can enable them with the --serial flag") } - teardownSubTest := setupSubTest(t) - defer teardownSubTest(t) + testCases := []ordersyncTestCase{ + { + name: "FilteredPaginationSubprotocol version 0", + pConfig: privateConfig{ + paginationSubprotocolPerPage: 10, + }, + }, + { + name: "FilteredPaginationSubprotocol version 1", + pConfig: privateConfig{ + paginationSubprotocolPerPage: 10, + }, + }, + { + name: "FilteredPaginationSubprotocol version 1 and version 0", + pConfig: privateConfig{ + paginationSubprotocolPerPage: 10, + }, + }, + { + name: "makerAssetAmount orderfilter - match all orders", + customOrderFilter: `{"properties":{"makerAssetAmount":{"pattern":"^1$","type":"string"}}}`, + orderOptionsForIndex: func(_ int) []orderopts.Option { + return []orderopts.Option{orderopts.MakerAssetAmount(big.NewInt(1))} + }, + pConfig: privateConfig{ + paginationSubprotocolPerPage: 10, + }, + }, + { + name: "makerAssetAmount OrderFilter - matches one order", + customOrderFilter: `{"properties":{"makerAssetAmount":{"pattern":"^1$","type":"string"}}}`, + orderOptionsForIndex: func(i int) []orderopts.Option { + if i == 0 { + return []orderopts.Option{orderopts.MakerAssetAmount(big.NewInt(1))} + } + return []orderopts.Option{} + }, + pConfig: privateConfig{ + paginationSubprotocolPerPage: 10, + }, + }, + } + for i, testCase := range testCases { + testCaseName := fmt.Sprintf("%s (test case %d)", testCase.name, i) + t.Run(testCaseName, runOrdersyncTestCase(t, testCase)) + } +} - // Set up two Mesh nodes. originalNode starts with some orders. newNode enters - // the network without any orders. - ctx, cancel := context.WithTimeout(context.Background(), 60*time.Second) - defer cancel() - wg := &sync.WaitGroup{} +type ordersyncTestCase struct { + name string + customOrderFilter string + orderOptionsForIndex func(int) []orderopts.Option + pConfig privateConfig +} - perPage := 10 - pConfig := privateConfig{ - paginationSubprotocolPerPage: perPage, - } - originalNode := newTestAppWithPrivateConfig(t, pConfig) - wg.Add(1) - go func() { - defer wg.Done() - if err := originalNode.Start(ctx); err != nil && err != context.Canceled { - // context.Canceled is expected. For any other error, fail the test. - require.NoError(t, err) - } - }() +const defaultOrderFilter = "{}" - // Manually add some orders to originalNode. - orderOptions := scenario.OptionsForAll(orderopts.SetupMakerState(true)) - originalOrders := scenario.NewSignedTestOrdersBatch(t, perPage*3+1, orderOptions) +func runOrdersyncTestCase(t *testing.T, testCase ordersyncTestCase) func(t *testing.T) { + return func(t *testing.T) { + teardownSubTest := setupSubTest(t) + defer teardownSubTest(t) + + // Set up two Mesh nodes. originalNode starts with some orders. newNode enters + // the network without any orders. + ctx, cancel := context.WithTimeout(context.Background(), 60*time.Second) + defer cancel() + wg := &sync.WaitGroup{} + originalNode := newTestAppWithPrivateConfig(t, ctx, defaultOrderFilter, testCase.pConfig) + wg.Add(1) + go func() { + defer wg.Done() + if err := originalNode.Start(ctx); err != nil && err != context.Canceled { + // context.Canceled is expected. For any other error, fail the test. + panic(fmt.Sprintf("%s %s", testCase.name, err)) + } + }() - // We have to wait for latest block to be processed by the Mesh node. - time.Sleep(blockProcessingWaitTime) + // Manually add some orders to originalNode. + orderOptionsForIndex := func(i int) []orderopts.Option { + orderOptions := []orderopts.Option{orderopts.SetupMakerState(true)} + if testCase.orderOptionsForIndex != nil { + return append(testCase.orderOptionsForIndex(i), orderOptions...) + } + return orderOptions + } + numOrders := testCase.pConfig.paginationSubprotocolPerPage*3 + 1 + originalOrders := scenario.NewSignedTestOrdersBatch(t, numOrders, orderOptionsForIndex) - results, err := originalNode.orderWatcher.ValidateAndStoreValidOrders(ctx, originalOrders, true, constants.TestChainID) - require.NoError(t, err) - require.Empty(t, results.Rejected, "tried to add orders but some were invalid: \n%s\n", spew.Sdump(results)) + // We have to wait for latest block to be processed by the Mesh node. + time.Sleep(blockProcessingWaitTime) - newNode := newTestApp(t) - wg.Add(1) - go func() { - defer wg.Done() - if err := newNode.Start(ctx); err != nil && err != context.Canceled { - // context.Canceled is expected. For any other error, fail the test. + results, err := originalNode.orderWatcher.ValidateAndStoreValidOrders(ctx, originalOrders, true, constants.TestChainID) + require.NoError(t, err) + require.Empty(t, results.Rejected, "tried to add orders but some were invalid: \n%s\n", spew.Sdump(results)) + + newNode := newTestAppWithPrivateConfig(t, ctx, testCase.customOrderFilter, defaultPrivateConfig()) + wg.Add(1) + go func() { + defer wg.Done() + if err := newNode.Start(ctx); err != nil && err != context.Canceled { + // context.Canceled is expected. For any other error, fail the test. + panic(fmt.Sprintf("%s %s", testCase.name, err)) + } + }() + <-newNode.started + + orderEventsChan := make(chan []*zeroex.OrderEvent) + orderEventsSub := newNode.SubscribeToOrderEvents(orderEventsChan) + defer orderEventsSub.Unsubscribe() + + // Connect the two nodes *after* adding orders to one of them. This should + // trigger the ordersync protocol. + err = originalNode.AddPeer(peer.AddrInfo{ + ID: newNode.node.ID(), + Addrs: newNode.node.Multiaddrs(), + }) + require.NoError(t, err) + + // Only the orders that satisfy the new node's orderfilter should + // be received during ordersync. + filteredOrders := []*zeroex.SignedOrder{} + for _, order := range originalOrders { + matches, err := newNode.orderFilter.MatchOrder(order) require.NoError(t, err) + if matches { + filteredOrders = append(filteredOrders, order) + } } - }() - <-newNode.started - - orderEventsChan := make(chan []*zeroex.OrderEvent) - orderEventsSub := newNode.SubscribeToOrderEvents(orderEventsChan) - defer orderEventsSub.Unsubscribe() - - // Connect the two nodes *after* adding orders to one of them. This should - // trigger the ordersync protocol. - err = originalNode.AddPeer(peer.AddrInfo{ - ID: newNode.node.ID(), - Addrs: newNode.node.Multiaddrs(), - }) - require.NoError(t, err) - // Wait for newNode to get the orders via ordersync. - receivedAddedEvents := []*zeroex.OrderEvent{} -OrderEventLoop: - for { - select { - case <-ctx.Done(): - t.Fatalf("timed out waiting for %d order added events (received %d so far)", len(originalOrders), len(receivedAddedEvents)) - case orderEvents := <-orderEventsChan: - for _, orderEvent := range orderEvents { - if orderEvent.EndState == zeroex.ESOrderAdded { - receivedAddedEvents = append(receivedAddedEvents, orderEvent) + // Wait for newNode to get the orders via ordersync. + receivedAddedEvents := []*zeroex.OrderEvent{} + OrderEventLoop: + for { + select { + case <-ctx.Done(): + t.Fatalf("timed out waiting for %d order added events (received %d so far)", len(originalOrders), len(receivedAddedEvents)) + case orderEvents := <-orderEventsChan: + for _, orderEvent := range orderEvents { + if orderEvent.EndState == zeroex.ESOrderAdded { + receivedAddedEvents = append(receivedAddedEvents, orderEvent) + } + } + if len(receivedAddedEvents) >= len(filteredOrders) { + break OrderEventLoop } } if len(receivedAddedEvents) >= len(originalOrders) { break OrderEventLoop } } - } - // Test that the orders are actually in the database and are returned by - // GetOrders. - newNodeOrdersResp, err := newNode.GetOrders(0, len(originalOrders), "") - require.NoError(t, err) - assert.Len(t, newNodeOrdersResp.OrdersInfos, len(originalOrders), "new node should have %d orders", len(originalOrders)) - for _, expectedOrder := range originalOrders { - orderHash, err := expectedOrder.ComputeOrderHash() + // Test that the orders are actually in the database and are returned by + // GetOrders. + newNodeOrdersResp, err := newNode.GetOrders(0, len(filteredOrders), "") require.NoError(t, err) - expectedOrder.ResetHash() - var dbOrder meshdb.Order - require.NoError(t, newNode.db.Orders.FindByID(orderHash.Bytes(), &dbOrder)) - actualOrder := dbOrder.SignedOrder - assert.Equal(t, expectedOrder, actualOrder, "correct order was not stored in new node database") - } + assert.Len(t, newNodeOrdersResp.OrdersInfos, len(filteredOrders), "new node should have %d orders", len(originalOrders)) + for _, expectedOrder := range filteredOrders { + orderHash, err := expectedOrder.ComputeOrderHash() + require.NoError(t, err) + expectedOrder.ResetHash() + var dbOrder meshdb.Order + require.NoError(t, newNode.db.Orders.FindByID(orderHash.Bytes(), &dbOrder)) + actualOrder := dbOrder.SignedOrder + assert.Equal(t, expectedOrder, actualOrder, "correct order was not stored in new node database") + } - // Wait for nodes to exit without error. - cancel() - wg.Wait() + // Wait for nodes to exit without error. + cancel() + wg.Wait() + } } func setupSubTest(t *testing.T) func(t *testing.T) { diff --git a/core/message_handler.go b/core/message_handler.go index b6f701271..6a4f4f963 100644 --- a/core/message_handler.go +++ b/core/message_handler.go @@ -15,13 +15,6 @@ import ( // Ensure that App implements p2p.MessageHandler. var _ p2p.MessageHandler = &App{} -func min(a int, b int) int { - if a < b { - return a - } - return b -} - func (app *App) HandleMessages(ctx context.Context, messages []*p2p.Message) error { // First we validate the messages and decode them into orders. orders := []*zeroex.SignedOrder{} diff --git a/core/ordersync/ordersync.go b/core/ordersync/ordersync.go index 593468c88..42f3fe25b 100644 --- a/core/ordersync/ordersync.go +++ b/core/ordersync/ordersync.go @@ -158,6 +158,8 @@ func New(ctx context.Context, node *p2p.Node, subprotocols []Subprotocol) *Servi sids = append(sids, subp.Name()) supportedSubprotocols[subp.Name()] = subp } + // TODO(jalextowle): We should ensure that there were no duplicates -- there + // is no reason to support this. s := &Service{ ctx: ctx, node: node, @@ -219,51 +221,10 @@ func (s *Service) HandleStream(stream network.Stream) { log.WithFields(log.Fields{ "requester": stream.Conn().RemotePeer().Pretty(), }).Trace("received ordersync request") - if rawReq.Type != TypeRequest { - log.WithField("gotType", rawReq.Type).Warn("wrong type for Request") - s.handlePeerScoreEvent(requesterID, psInvalidMessage) + rawRes := s.handleRawRequest(rawReq, requesterID) + if rawRes == nil { return } - subprotocol, i, err := s.GetMatchingSubprotocol(rawReq) - if err != nil { - log.WithError(err).Warn("GetMatchingSubprotocol returned error") - s.handlePeerScoreEvent(requesterID, psSubprotocolNegotiationFailed) - return - } - if len(rawReq.Subprotocols) > 1 { - firstRequests := FirstRequestsForSubprotocols{} - err := json.Unmarshal(rawReq.Metadata, &firstRequests) - - // NOTE(jalextowle): Older versions of Mesh did not include - // metadata in the first ordersync request. In order to handle - // this in a backwards compatible way, we simply avoid updating - // the request metadata if there was an error decoding the - // metadata from the request or if the length of the - // MetadataForSubprotocol is too small (or empty). This latter - // check also ensures that the array is long enough for us - // to access the i-th element. - if err == nil && len(firstRequests.MetadataForSubprotocol) > i { - rawReq.Metadata = firstRequests.MetadataForSubprotocol[i] - } - } - res, err := handleRequestWithSubprotocol(s.ctx, subprotocol, requesterID, rawReq) - if err != nil { - log.WithError(err).Warn("subprotocol returned error") - return - } - encodedMetadata, err := json.Marshal(res.Metadata) - if err != nil { - log.WithError(err).Error("could not encode raw metadata") - return - } - s.handlePeerScoreEvent(requesterID, psValidMessage) - rawRes := rawResponse{ - Type: TypeResponse, - Subprotocol: subprotocol.Name(), - Orders: res.Orders, - Complete: res.Complete, - Metadata: encodedMetadata, - } if err := json.NewEncoder(stream).Encode(rawRes); err != nil { log.WithFields(log.Fields{ "error": err.Error(), @@ -272,7 +233,7 @@ func (s *Service) HandleStream(stream network.Stream) { s.handlePeerScoreEvent(requesterID, psUnexpectedDisconnect) return } - if res.Complete { + if rawRes.Complete { return } } @@ -389,6 +350,54 @@ func calculateDelayWithJitter(approxDelay time.Duration, jitterAmount float64) t return approxDelay + time.Duration(delta) } +func (s *Service) handleRawRequest(rawReq *rawRequest, requesterID peer.ID) *rawResponse { + if rawReq.Type != TypeRequest { + log.WithField("gotType", rawReq.Type).Warn("wrong type for Request") + s.handlePeerScoreEvent(requesterID, psInvalidMessage) + return nil + } + subprotocol, i, err := s.GetMatchingSubprotocol(rawReq) + if err != nil { + log.WithError(err).Warn("GetMatchingSubprotocol returned error") + s.handlePeerScoreEvent(requesterID, psSubprotocolNegotiationFailed) + return nil + } + if len(rawReq.Subprotocols) > 1 { + firstRequests := FirstRequestsForSubprotocols{} + err := json.Unmarshal(rawReq.Metadata, &firstRequests) + + // NOTE(jalextowle): Older versions of Mesh did not include + // metadata in the first ordersync request. In order to handle + // this in a backwards compatible way, we simply avoid updating + // the request metadata if there was an error decoding the + // metadata from the request or if the length of the + // MetadataForSubprotocol is too small (or empty). This latter + // check also ensures that the array is long enough for us + // to access the i-th element. + if err == nil && len(firstRequests.MetadataForSubprotocol) > i { + rawReq.Metadata = firstRequests.MetadataForSubprotocol[i] + } + } + res, err := handleRequestWithSubprotocol(s.ctx, subprotocol, requesterID, rawReq) + if err != nil { + log.WithError(err).Warn("subprotocol returned error") + return nil + } + encodedMetadata, err := json.Marshal(res.Metadata) + if err != nil { + log.WithError(err).Error("could not encode raw metadata") + return nil + } + s.handlePeerScoreEvent(requesterID, psValidMessage) + return &rawResponse{ + Type: TypeResponse, + Subprotocol: subprotocol.Name(), + Orders: res.Orders, + Complete: res.Complete, + Metadata: encodedMetadata, + } +} + func handleRequestWithSubprotocol(ctx context.Context, subprotocol Subprotocol, requesterID peer.ID, rawReq *rawRequest) (*Response, error) { req, err := parseRequestWithSubprotocol(subprotocol, requesterID, rawReq) if err != nil { diff --git a/core/ordersync/ordersync_test.go b/core/ordersync/ordersync_test.go index 32e33cd3d..4848e2a37 100644 --- a/core/ordersync/ordersync_test.go +++ b/core/ordersync/ordersync_test.go @@ -1,10 +1,20 @@ package ordersync import ( + "context" + "encoding/json" + "math/big" "testing" "time" + "github.com/0xProject/0x-mesh/constants" + "github.com/0xProject/0x-mesh/ethereum" + "github.com/0xProject/0x-mesh/p2p" + "github.com/0xProject/0x-mesh/scenario" + "github.com/0xProject/0x-mesh/zeroex" + peer "github.com/libp2p/go-libp2p-peer" "github.com/stretchr/testify/assert" + "github.com/stretchr/testify/require" ) func TestCalculateDelayWithJitters(t *testing.T) { @@ -18,3 +28,203 @@ func TestCalculateDelayWithJitters(t *testing.T) { assert.InDelta(t, approxDelay, actualDelay, float64(1*time.Second), "actualDelay: %s", actualDelay) } } + +func TestHandleRawRequest(t *testing.T) { + n, err := p2p.New( + context.Background(), + p2p.Config{ + MessageHandler: &noopMessageHandler{}, + RendezvousPoints: []string{"/test-rendezvous-point"}, + DataDir: "/tmp", + }, + ) + require.NoError(t, err) + subp0 := &oneOrderSubprotocol{ + myPeerID: n.ID(), + } + subp1 := &hostedSubprotocol{ + myPeerID: n.ID(), + hostSubp: subp0, + } + s := New(context.Background(), n, []Subprotocol{subp0, subp1}) + + rawReq := &rawRequest{ + Type: TypeRequest, + Subprotocols: []string{subp0.Name(), subp1.Name()}, + } + // This request has multiple subprotocols included and nil metadata. This + // has the same structure as requests that would have been sent by older + // versions of Mesh, and allows us to test that newer Mesh nodes provide + // backwards compatability as ordersync providers. + res := s.handleRawRequest(rawReq, n.ID()) + require.NotNil(t, res) + assert.True(t, res.Complete) + assert.Equal(t, 1, len(res.Orders)) + assert.Equal(t, res.Subprotocol, subp0.Name()) + // NOTE(jalextowle): Because of the way that nil interfaces are encoded + // in JSON, the value of `res.Metadata` will not be equal to `rawReq.Metadata`. + // We simply ensure that `res.Metadata` unmarshals to an empty request metadata + // object. + var metadata oneOrderSubprotocolRequestMetadata + err = json.Unmarshal(res.Metadata, &metadata) + assert.Equal(t, oneOrderSubprotocolRequestMetadata{}, metadata) + + // Test handling a request from a node that is using the new first request + // encoding scheme. + rawReq, err = s.createFirstRequestForAllSubprotocols() + res = s.handleRawRequest(rawReq, n.ID()) + require.NotNil(t, res) + assert.True(t, res.Complete) + assert.Equal(t, 1, len(res.Orders)) + assert.Equal(t, res.Subprotocol, subp0.Name()) + assert.Equal(t, res.Metadata, rawReq.Metadata) +} + +var _ p2p.MessageHandler = &noopMessageHandler{} + +// noopMessageHandler is a dummy message handler that allows a p2p node to be +// instantiated easily in these tests. +type noopMessageHandler struct{} + +func (*noopMessageHandler) HandleMessages(context.Context, []*p2p.Message) error { + return nil +} + +var _ Subprotocol = &oneOrderSubprotocol{} + +// oneOrderSubprotocol is an ordersync subprotocol that is used for testing +// ordersync. This subprotocol will always respond with a single random test order +// and will duplicate the request metadata in the response. +type oneOrderSubprotocol struct { + myPeerID peer.ID +} + +type oneOrderSubprotocolRequestMetadata struct { + SomeValue interface{} `json:"someValue"` +} + +type oneOrderSubprotocolResponseMetadata struct { + SomeValue interface{} `json:"someValue"` +} + +func (s *oneOrderSubprotocol) Name() string { + return "/simple-order-sync-subprotocol/v0" +} + +func (s *oneOrderSubprotocol) ParseRequestMetadata(metadata json.RawMessage) (interface{}, error) { + if metadata == nil { + return nil, nil + } + var parsed oneOrderSubprotocolRequestMetadata + if err := json.Unmarshal(metadata, &parsed); err != nil { + return nil, err + } + return &parsed, nil +} + +func (s *oneOrderSubprotocol) ParseResponseMetadata(metadata json.RawMessage) (interface{}, error) { + if metadata == nil { + return nil, nil + } + var parsed oneOrderSubprotocolResponseMetadata + if err := json.Unmarshal(metadata, &parsed); err != nil { + return nil, err + } + return &parsed, nil +} + +func (s *oneOrderSubprotocol) HandleOrderSyncRequest(ctx context.Context, req *Request) (*Response, error) { + order := &zeroex.Order{ + ChainID: big.NewInt(constants.TestChainID), + MakerAddress: constants.GanacheAccount1, + TakerAddress: constants.NullAddress, + SenderAddress: constants.NullAddress, + FeeRecipientAddress: constants.NullAddress, + MakerAssetData: scenario.ZRXAssetData, + MakerFeeAssetData: constants.NullBytes, + TakerAssetData: scenario.WETHAssetData, + TakerFeeAssetData: constants.NullBytes, + Salt: big.NewInt(int64(time.Now().Nanosecond())), + MakerFee: big.NewInt(0), + TakerFee: big.NewInt(0), + MakerAssetAmount: big.NewInt(100), + TakerAssetAmount: big.NewInt(42), + ExpirationTimeSeconds: big.NewInt(time.Now().Add(24 * time.Hour).Unix()), + ExchangeAddress: ethereum.GanacheAddresses.Exchange, + } + signedOrder, err := zeroex.SignTestOrder(order) + if err != nil { + return nil, err + } + return &Response{ + ProviderID: s.myPeerID, + Orders: []*zeroex.SignedOrder{signedOrder}, + Complete: true, + Metadata: req.Metadata, + }, nil +} + +func (s *oneOrderSubprotocol) HandleOrderSyncResponse(ctx context.Context, res *Response) (*Request, error) { + return &Request{ + RequesterID: s.myPeerID, + Metadata: res.Metadata, + }, nil +} + +func (s *oneOrderSubprotocol) GenerateFirstRequestMetadata() (json.RawMessage, error) { + return json.Marshal(oneOrderSubprotocolRequestMetadata{ + SomeValue: 0, + }) +} + +var _ Subprotocol = &hostedSubprotocol{} + +// hostedSubprotocol is an ordersync subprotocol that is used for testing +// ordersync. This subprotocol uses oneOrderSubprotocol as a "host" subprotocol +// and delegates the handling of requests and responses to this host. +type hostedSubprotocol struct { + myPeerID peer.ID + hostSubp *oneOrderSubprotocol +} + +type hostedSubprotocolRequestMetadata struct { + AnotherValue interface{} `json:"anotherValue"` +} + +type hostedSubprotocolResponseMetadata struct { + AnotherValue interface{} `json:"anotherValue"` +} + +func (s *hostedSubprotocol) Name() string { + return "/simple-order-sync-subprotocol/v1" +} + +func (s *hostedSubprotocol) ParseRequestMetadata(metadata json.RawMessage) (interface{}, error) { + var parsed hostedSubprotocolRequestMetadata + if err := json.Unmarshal(metadata, &parsed); err != nil { + return nil, err + } + return &parsed, nil +} + +func (s *hostedSubprotocol) ParseResponseMetadata(metadata json.RawMessage) (interface{}, error) { + var parsed hostedSubprotocolResponseMetadata + if err := json.Unmarshal(metadata, &parsed); err != nil { + return nil, err + } + return &parsed, nil +} + +func (s *hostedSubprotocol) HandleOrderSyncRequest(ctx context.Context, req *Request) (*Response, error) { + return s.hostSubp.HandleOrderSyncRequest(ctx, req) +} + +func (s *hostedSubprotocol) HandleOrderSyncResponse(ctx context.Context, res *Response) (*Request, error) { + return s.hostSubp.HandleOrderSyncResponse(ctx, res) +} + +func (s *hostedSubprotocol) GenerateFirstRequestMetadata() (json.RawMessage, error) { + return json.Marshal(hostedSubprotocolRequestMetadata{ + AnotherValue: 1, + }) +} diff --git a/orderfilter/filter_test.go b/orderfilter/filter_test.go index d71edcd0c..5b67d15b0 100644 --- a/orderfilter/filter_test.go +++ b/orderfilter/filter_test.go @@ -21,9 +21,39 @@ var ( contractAddresses = ethereum.GanacheAddresses ) +// NOTE(jalextowle): The way that orderfilters are encoded into JSON is unique due +// to the fact that orderfilters work differently in the native and WebAssembly +// environments, so we make an effort to test these encoding and decoding functions +// rigorously. To accomplish this, all of the orderfilter tests are run twice. The +// first time they are executed, orderfilter.New is used to create the orderfilter +// that will be tested. The second time the tests are executed, we use this function +// to create an orderfilter, encode the orderfilter into JSON, and then return a +// freshly decoded orderfilter. +func generateDecodedFilter(chainID int, customOrderSchema string, contractAddresses ethereum.ContractAddresses) (*Filter, error) { + filter, err := New(chainID, customOrderSchema, contractAddresses) + if err != nil { + return nil, err + } + marshalledFilter, err := filter.MarshalJSON() + if err != nil { + return nil, err + } + newFilter := &Filter{} + err = newFilter.UnmarshalJSON(marshalledFilter) + if err != nil { + return nil, err + } + return newFilter, nil +} + func TestFilterValidateOrder(t *testing.T) { t.Parallel() + testFilterValidateOrder(t, New) + testFilterValidateOrder(t, generateDecodedFilter) +} + +func testFilterValidateOrder(t *testing.T, generateFilter func(int, string, ethereum.ContractAddresses) (*Filter, error)) { testCases := []struct { note string chainID int @@ -149,7 +179,7 @@ func TestFilterValidateOrder(t *testing.T) { for i, tc := range testCases { tcInfo := fmt.Sprintf("test case %d\nchainID: %d\nschema: %s", i, tc.chainID, tc.customOrderSchema) - filter, err := New(tc.chainID, tc.customOrderSchema, contractAddresses) + filter, err := generateFilter(tc.chainID, tc.customOrderSchema, contractAddresses) require.NoError(t, err, tcInfo) signedOrder, err := zeroex.SignTestOrder(tc.order) require.NoError(t, err) @@ -174,6 +204,11 @@ func TestFilterValidateOrder(t *testing.T) { func TestFilterValidateOrderJSON(t *testing.T) { t.Parallel() + testFilterValidateOrderJSON(t, New) + testFilterValidateOrderJSON(t, generateDecodedFilter) +} + +func testFilterValidateOrderJSON(t *testing.T, generateFilter func(int, string, ethereum.ContractAddresses) (*Filter, error)) { testCases := []struct { note string chainID int @@ -236,7 +271,7 @@ func TestFilterValidateOrderJSON(t *testing.T) { for i, tc := range testCases { tcInfo := fmt.Sprintf("test case %d\nchainID: %d\nschema: %s\nnote: %s", i, tc.chainID, tc.customOrderSchema, tc.note) - filter, err := New(tc.chainID, tc.customOrderSchema, contractAddresses) + filter, err := generateFilter(tc.chainID, tc.customOrderSchema, contractAddresses) require.NoError(t, err) actualResult, err := filter.ValidateOrderJSON(tc.orderJSON) require.NoError(t, err, tc.customOrderSchema) @@ -259,6 +294,11 @@ func TestFilterValidateOrderJSON(t *testing.T) { func TestFilterMatchOrderMessageJSON(t *testing.T) { t.Parallel() + testFilterMatchOrderMessageJSON(t, New) + testFilterMatchOrderMessageJSON(t, generateDecodedFilter) +} + +func testFilterMatchOrderMessageJSON(t *testing.T, generateFilter func(int, string, ethereum.ContractAddresses) (*Filter, error)) { testCases := []struct { note string chainID int @@ -326,7 +366,7 @@ func TestFilterMatchOrderMessageJSON(t *testing.T) { for i, tc := range testCases { tcInfo := fmt.Sprintf("test case %d\nchainID: %d\nschema: %s\nnote: %s", i, tc.chainID, tc.customOrderSchema, tc.note) - filter, err := New(tc.chainID, tc.customOrderSchema, contractAddresses) + filter, err := generateFilter(tc.chainID, tc.customOrderSchema, contractAddresses) require.NoError(t, err) actualResult, err := filter.MatchOrderMessageJSON(tc.orderMessageJSON) require.NoError(t, err, tc.customOrderSchema) @@ -335,6 +375,11 @@ func TestFilterMatchOrderMessageJSON(t *testing.T) { } func TestFilterTopic(t *testing.T) { + testFilterTopic(t, New) + testFilterTopic(t, generateDecodedFilter) +} + +func testFilterTopic(t *testing.T, generateFilter func(int, string, ethereum.ContractAddresses) (*Filter, error)) { testCases := []struct { chainID int customOrderSchema string @@ -366,7 +411,7 @@ func TestFilterTopic(t *testing.T) { for i, tc := range testCases { tcInfo := fmt.Sprintf("test case %d\nchainID: %d\nschema: %s", i, tc.chainID, tc.customOrderSchema) - originalFilter, err := New(tc.chainID, tc.customOrderSchema, contractAddresses) + originalFilter, err := generateFilter(tc.chainID, tc.customOrderSchema, contractAddresses) require.NoError(t, err, tcInfo) result, err := originalFilter.ValidateOrderJSON(tc.orderJSON) require.NoError(t, err, tcInfo) diff --git a/yarn.lock b/yarn.lock index 07c4c3267..010b5fe13 100644 --- a/yarn.lock +++ b/yarn.lock @@ -164,7 +164,7 @@ lodash.values "^4.3.0" "@0x/mesh-browser-lite@file:packages/browser-lite": - version "9.3.0" + version "9.4.1" dependencies: "@0x/contract-addresses" "^4.9.0" "@0x/order-utils" "^10.2.0" @@ -175,9 +175,9 @@ ethereum-types "^3.0.0" "@0x/mesh-browser@file:packages/browser": - version "9.3.0" + version "9.4.1" dependencies: - "@0x/mesh-browser-lite" "^9.3.0" + "@0x/mesh-browser-lite" "^9.4.1" base64-arraybuffer "^0.2.0" browserfs "^1.4.3" ethereum-types "^3.0.0" From 09f254e33241caff8eb3961326d12030bfd0e185 Mon Sep 17 00:00:00 2001 From: Alex Towle Date: Fri, 31 Jul 2020 19:10:19 -0500 Subject: [PATCH 3/3] Cut release 9.4.2 --- CHANGELOG.md | 7 + README.md | 2 +- RELEASE_CHANGELOG.md | 11 - core/core.go | 2 +- docs/browser-bindings/browser-lite/README.md | 2 +- .../browser-lite/reference.md | 420 +++++++-------- docs/browser-bindings/browser/README.md | 2 +- docs/browser-bindings/browser/reference.md | 416 +++++++------- docs/deployment.md | 2 +- docs/deployment_with_telemetry.md | 2 +- docs/json_rpc_clients/typescript/README.md | 2 +- docs/json_rpc_clients/typescript/reference.md | 506 +++++++++--------- docs/rpc_api.md | 2 +- packages/browser-lite/package.json | 2 +- packages/browser/package.json | 4 +- packages/rpc-client/package.json | 2 +- 16 files changed, 690 insertions(+), 694 deletions(-) delete mode 100644 RELEASE_CHANGELOG.md diff --git a/CHANGELOG.md b/CHANGELOG.md index 650bf0463..38152b302 100644 --- a/CHANGELOG.md +++ b/CHANGELOG.md @@ -2,6 +2,13 @@ This changelog is a work in progress and may contain notes for versions which have not actually been released. Check the [Releases](https://github.com/0xProject/0x-mesh/releases) page to see full release notes and more information about the latest released versions. +## v9.4.2 + +### Bug fixes 🐞 + +- Fixes a bug that would cause Mesh nodes to crash upon receiving requests from legacy Mesh nodes [#888](https://github.com/0xProject/0x-mesh/pull/888). + + ## v9.4.1 ### Bug fixes 🐞 diff --git a/README.md b/README.md index 9d2eab47f..0cd1f9f37 100644 --- a/README.md +++ b/README.md @@ -1,4 +1,4 @@ -[![Version](https://img.shields.io/badge/version-9.4.1-orange.svg)](https://github.com/0xProject/0x-mesh/releases) +[![Version](https://img.shields.io/badge/version-9.4.2-orange.svg)](https://github.com/0xProject/0x-mesh/releases) [![Docs](https://img.shields.io/badge/docs-website-yellow.svg)](https://0x-org.gitbook.io/mesh) [![Chat with us on Discord](https://img.shields.io/badge/chat-Discord-blueViolet.svg)](https://discord.gg/HF7fHwk) [![Circle CI](https://img.shields.io/circleci/project/0xProject/0x-mesh/master.svg)](https://circleci.com/gh/0xProject/0x-mesh/tree/master) diff --git a/RELEASE_CHANGELOG.md b/RELEASE_CHANGELOG.md deleted file mode 100644 index 163ddc825..000000000 --- a/RELEASE_CHANGELOG.md +++ /dev/null @@ -1,11 +0,0 @@ -- [Docker image](https://hub.docker.com/r/0xorg/mesh/tags) -- [README](https://github.com/0xProject/0x-mesh/blob/v9.4.1/README.md) - -## Summary - -### Bug fixes 🐞 - -- Fixed a problem in the filtered pagination subprotocols of ordersync that caused the nodes to use the wrong orderfilter [#882](https://github.com/0xProject/0x-mesh/pull/882) - - - diff --git a/core/core.go b/core/core.go index 289470649..f6b65c3ad 100644 --- a/core/core.go +++ b/core/core.go @@ -60,7 +60,7 @@ const ( estimatedNonPollingEthereumRPCRequestsPer24Hrs = 50000 // logStatsInterval is how often to log stats for this node. logStatsInterval = 5 * time.Minute - version = "9.4.1" + version = "9.4.2" // ordersyncMinPeers is the minimum amount of peers to receive orders from // before considering the ordersync process finished. ordersyncMinPeers = 5 diff --git a/docs/browser-bindings/browser-lite/README.md b/docs/browser-bindings/browser-lite/README.md index b7f25f85f..76b12f41f 100644 --- a/docs/browser-bindings/browser-lite/README.md +++ b/docs/browser-bindings/browser-lite/README.md @@ -1,4 +1,4 @@ -# @0x/mesh-browser-lite - v9.4.1 +# @0x/mesh-browser-lite - v9.4.2 ## @0x/mesh-browser-lite diff --git a/docs/browser-bindings/browser-lite/reference.md b/docs/browser-bindings/browser-lite/reference.md index eb4af7cd9..d45873763 100644 --- a/docs/browser-bindings/browser-lite/reference.md +++ b/docs/browser-bindings/browser-lite/reference.md @@ -14,7 +14,7 @@ sending orders through the 0x Mesh network. \+ **new Mesh**(`config`: [Config](#interface-config)): *[Mesh](#class-mesh)* -*Defined in [mesh.ts:142](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/mesh.ts#L142)* +*Defined in [mesh.ts:142](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/mesh.ts#L142)* Instantiates a new Mesh instance. @@ -34,7 +34,7 @@ An instance of Mesh ▸ **addOrdersAsync**(`orders`: SignedOrder[], `pinned`: boolean): *Promise‹[ValidationResults](#interface-validationresults)›* -*Defined in [mesh.ts:292](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/mesh.ts#L292)* +*Defined in [mesh.ts:292](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/mesh.ts#L292)* Validates and adds the given orders to Mesh. If an order is successfully added, Mesh will share it with any peers in the network and start @@ -61,7 +61,7 @@ ___ ▸ **getOrdersAsync**(`perPage`: number): *Promise‹[GetOrdersResponse](#interface-getordersresponse)›* -*Defined in [mesh.ts:221](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/mesh.ts#L221)* +*Defined in [mesh.ts:221](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/mesh.ts#L221)* Get all 0x signed orders currently stored in the Mesh node @@ -81,7 +81,7 @@ ___ ▸ **getOrdersForPageAsync**(`page`: number, `perPage`: number, `snapshotID?`: undefined | string): *Promise‹[GetOrdersResponse](#interface-getordersresponse)›* -*Defined in [mesh.ts:263](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/mesh.ts#L263)* +*Defined in [mesh.ts:263](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/mesh.ts#L263)* Get page of 0x signed orders stored on the Mesh node at the specified snapshot @@ -103,7 +103,7 @@ ___ ▸ **getStatsAsync**(): *Promise‹[Stats](#interface-stats)›* -*Defined in [mesh.ts:204](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/mesh.ts#L204)* +*Defined in [mesh.ts:204](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/mesh.ts#L204)* Returns various stats about Mesh, including the total number of orders and the number of peers Mesh is connected to. @@ -116,7 +116,7 @@ ___ ▸ **onError**(`handler`: function): *void* -*Defined in [mesh.ts:162](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/mesh.ts#L162)* +*Defined in [mesh.ts:162](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/mesh.ts#L162)* Registers a handler which will be called in the event of a critical error. Note that the handler will not be called for non-critical errors. @@ -145,7 +145,7 @@ ___ ▸ **onOrderEvents**(`handler`: function): *void* -*Defined in [mesh.ts:177](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/mesh.ts#L177)* +*Defined in [mesh.ts:177](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/mesh.ts#L177)* Registers a handler which will be called for any incoming order events. Order events are fired whenver an order is added, canceled, expired, or @@ -174,7 +174,7 @@ ___ ▸ **startAsync**(): *Promise‹void›* -*Defined in [mesh.ts:188](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/mesh.ts#L188)* +*Defined in [mesh.ts:188](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/mesh.ts#L188)* Starts the Mesh node in the background. Mesh will automatically find peers in the network and begin receiving orders from them. @@ -193,7 +193,7 @@ peers in the network and begin receiving orders from them. • **ERC1155ApprovalForAllEvent**: = "ERC1155ApprovalForAllEvent" -*Defined in [types.ts:468](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L468)* +*Defined in [types.ts:468](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L468)* ___ @@ -201,7 +201,7 @@ ___ • **ERC1155TransferBatchEvent**: = "ERC1155TransferBatchEvent" -*Defined in [types.ts:470](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L470)* +*Defined in [types.ts:470](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L470)* ___ @@ -209,7 +209,7 @@ ___ • **ERC1155TransferSingleEvent**: = "ERC1155TransferSingleEvent" -*Defined in [types.ts:469](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L469)* +*Defined in [types.ts:469](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L469)* ___ @@ -217,7 +217,7 @@ ___ • **ERC20ApprovalEvent**: = "ERC20ApprovalEvent" -*Defined in [types.ts:464](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L464)* +*Defined in [types.ts:464](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L464)* ___ @@ -225,7 +225,7 @@ ___ • **ERC20TransferEvent**: = "ERC20TransferEvent" -*Defined in [types.ts:463](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L463)* +*Defined in [types.ts:463](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L463)* ___ @@ -233,7 +233,7 @@ ___ • **ERC721ApprovalEvent**: = "ERC721ApprovalEvent" -*Defined in [types.ts:466](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L466)* +*Defined in [types.ts:466](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L466)* ___ @@ -241,7 +241,7 @@ ___ • **ERC721ApprovalForAllEvent**: = "ERC721ApprovalForAllEvent" -*Defined in [types.ts:467](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L467)* +*Defined in [types.ts:467](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L467)* ___ @@ -249,7 +249,7 @@ ___ • **ERC721TransferEvent**: = "ERC721TransferEvent" -*Defined in [types.ts:465](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L465)* +*Defined in [types.ts:465](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L465)* ___ @@ -257,7 +257,7 @@ ___ • **ExchangeCancelEvent**: = "ExchangeCancelEvent" -*Defined in [types.ts:472](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L472)* +*Defined in [types.ts:472](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L472)* ___ @@ -265,7 +265,7 @@ ___ • **ExchangeCancelUpToEvent**: = "ExchangeCancelUpToEvent" -*Defined in [types.ts:473](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L473)* +*Defined in [types.ts:473](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L473)* ___ @@ -273,7 +273,7 @@ ___ • **ExchangeFillEvent**: = "ExchangeFillEvent" -*Defined in [types.ts:471](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L471)* +*Defined in [types.ts:471](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L471)* ___ @@ -281,7 +281,7 @@ ___ • **WethDepositEvent**: = "WethDepositEvent" -*Defined in [types.ts:474](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L474)* +*Defined in [types.ts:474](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L474)* ___ @@ -289,7 +289,7 @@ ___ • **WethWithdrawalEvent**: = "WethWithdrawalEvent" -*Defined in [types.ts:475](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L475)* +*Defined in [types.ts:475](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L475)*
@@ -303,7 +303,7 @@ ___ • **Added**: = "ADDED" -*Defined in [types.ts:538](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L538)* +*Defined in [types.ts:538](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L538)* ___ @@ -311,7 +311,7 @@ ___ • **Cancelled**: = "CANCELLED" -*Defined in [types.ts:541](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L541)* +*Defined in [types.ts:541](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L541)* ___ @@ -319,7 +319,7 @@ ___ • **Expired**: = "EXPIRED" -*Defined in [types.ts:542](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L542)* +*Defined in [types.ts:542](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L542)* ___ @@ -327,7 +327,7 @@ ___ • **FillabilityIncreased**: = "FILLABILITY_INCREASED" -*Defined in [types.ts:545](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L545)* +*Defined in [types.ts:545](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L545)* ___ @@ -335,7 +335,7 @@ ___ • **Filled**: = "FILLED" -*Defined in [types.ts:539](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L539)* +*Defined in [types.ts:539](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L539)* ___ @@ -343,7 +343,7 @@ ___ • **FullyFilled**: = "FULLY_FILLED" -*Defined in [types.ts:540](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L540)* +*Defined in [types.ts:540](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L540)* ___ @@ -351,7 +351,7 @@ ___ • **Invalid**: = "INVALID" -*Defined in [types.ts:537](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L537)* +*Defined in [types.ts:537](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L537)* ___ @@ -359,7 +359,7 @@ ___ • **StoppedWatching**: = "STOPPED_WATCHING" -*Defined in [types.ts:546](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L546)* +*Defined in [types.ts:546](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L546)* ___ @@ -367,7 +367,7 @@ ___ • **Unexpired**: = "UNEXPIRED" -*Defined in [types.ts:543](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L543)* +*Defined in [types.ts:543](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L543)* ___ @@ -375,7 +375,7 @@ ___ • **Unfunded**: = "UNFUNDED" -*Defined in [types.ts:544](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L544)* +*Defined in [types.ts:544](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L544)*
@@ -391,7 +391,7 @@ A set of categories for rejected orders. • **CoordinatorError**: = "COORDINATOR_ERROR" -*Defined in [types.ts:630](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L630)* +*Defined in [types.ts:630](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L630)* ___ @@ -399,7 +399,7 @@ ___ • **MeshError**: = "MESH_ERROR" -*Defined in [types.ts:628](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L628)* +*Defined in [types.ts:628](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L628)* ___ @@ -407,7 +407,7 @@ ___ • **MeshValidation**: = "MESH_VALIDATION" -*Defined in [types.ts:629](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L629)* +*Defined in [types.ts:629](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L629)* ___ @@ -415,7 +415,7 @@ ___ • **ZeroExValidation**: = "ZEROEX_VALIDATION" -*Defined in [types.ts:627](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L627)* +*Defined in [types.ts:627](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L627)*
@@ -429,7 +429,7 @@ ___ • **Debug**: = 5 -*Defined in [types.ts:211](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L211)* +*Defined in [types.ts:211](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L211)* ___ @@ -437,7 +437,7 @@ ___ • **Error**: = 2 -*Defined in [types.ts:208](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L208)* +*Defined in [types.ts:208](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L208)* ___ @@ -445,7 +445,7 @@ ___ • **Fatal**: = 1 -*Defined in [types.ts:207](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L207)* +*Defined in [types.ts:207](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L207)* ___ @@ -453,7 +453,7 @@ ___ • **Info**: = 4 -*Defined in [types.ts:210](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L210)* +*Defined in [types.ts:210](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L210)* ___ @@ -461,7 +461,7 @@ ___ • **Panic**: = 0 -*Defined in [types.ts:206](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L206)* +*Defined in [types.ts:206](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L206)* ___ @@ -469,7 +469,7 @@ ___ • **Trace**: = 6 -*Defined in [types.ts:212](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L212)* +*Defined in [types.ts:212](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L212)* ___ @@ -477,7 +477,7 @@ ___ • **Warn**: = 3 -*Defined in [types.ts:209](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L209)* +*Defined in [types.ts:209](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L209)*
@@ -495,7 +495,7 @@ ___ • **errors**: *string[]* -*Defined in [schema_validator.ts:11](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/schema_validator.ts#L11)* +*Defined in [schema_validator.ts:11](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/schema_validator.ts#L11)* ___ @@ -503,7 +503,7 @@ ___ • **fatal**? : *undefined | string* -*Defined in [schema_validator.ts:12](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/schema_validator.ts#L12)* +*Defined in [schema_validator.ts:12](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/schema_validator.ts#L12)* ___ @@ -511,7 +511,7 @@ ___ • **success**: *boolean* -*Defined in [schema_validator.ts:10](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/schema_validator.ts#L10)* +*Defined in [schema_validator.ts:10](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/schema_validator.ts#L10)*
@@ -529,7 +529,7 @@ ___ • **messageValidator**: *function* -*Defined in [schema_validator.ts:17](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/schema_validator.ts#L17)* +*Defined in [schema_validator.ts:17](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/schema_validator.ts#L17)* #### Type declaration: @@ -547,7 +547,7 @@ ___ • **orderValidator**: *function* -*Defined in [schema_validator.ts:16](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/schema_validator.ts#L16)* +*Defined in [schema_validator.ts:16](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/schema_validator.ts#L16)* #### Type declaration: @@ -577,7 +577,7 @@ Info for any orders that were accepted. • **fillableTakerAssetAmount**: *BigNumber* -*Defined in [types.ts:608](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L608)* +*Defined in [types.ts:608](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L608)* ___ @@ -585,7 +585,7 @@ ___ • **isNew**: *boolean* -*Defined in [types.ts:609](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L609)* +*Defined in [types.ts:609](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L609)* ___ @@ -593,7 +593,7 @@ ___ • **orderHash**: *string* -*Defined in [types.ts:606](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L606)* +*Defined in [types.ts:606](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L606)* ___ @@ -601,7 +601,7 @@ ___ • **signedOrder**: *SignedOrder* -*Defined in [types.ts:607](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L607)* +*Defined in [types.ts:607](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L607)*
@@ -621,7 +621,7 @@ A set of configuration options for Mesh. • **blockPollingIntervalSeconds**? : *undefined | number* -*Defined in [types.ts:118](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L118)* +*Defined in [types.ts:118](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L118)* ___ @@ -629,7 +629,7 @@ ___ • **bootstrapList**? : *string[]* -*Defined in [types.ts:111](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L111)* +*Defined in [types.ts:111](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L111)* ___ @@ -637,7 +637,7 @@ ___ • **customContractAddresses**? : *[ContractAddresses](#interface-contractaddresses)* -*Defined in [types.ts:162](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L162)* +*Defined in [types.ts:162](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L162)* ___ @@ -645,7 +645,7 @@ ___ • **customOrderFilter**? : *[JsonSchema](#interface-jsonschema)* -*Defined in [types.ts:187](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L187)* +*Defined in [types.ts:187](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L187)* ___ @@ -653,7 +653,7 @@ ___ • **enableEthereumRPCRateLimiting**? : *undefined | false | true* -*Defined in [types.ts:135](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L135)* +*Defined in [types.ts:135](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L135)* ___ @@ -661,7 +661,7 @@ ___ • **ethereumChainID**: *number* -*Defined in [types.ts:103](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L103)* +*Defined in [types.ts:103](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L103)* ___ @@ -669,7 +669,7 @@ ___ • **ethereumRPCMaxContentLength**? : *undefined | number* -*Defined in [types.ts:127](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L127)* +*Defined in [types.ts:127](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L127)* ___ @@ -677,7 +677,7 @@ ___ • **ethereumRPCMaxRequestsPer24HrUTC**? : *undefined | number* -*Defined in [types.ts:140](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L140)* +*Defined in [types.ts:140](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L140)* ___ @@ -685,7 +685,7 @@ ___ • **ethereumRPCMaxRequestsPerSecond**? : *undefined | number* -*Defined in [types.ts:146](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L146)* +*Defined in [types.ts:146](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L146)* ___ @@ -693,7 +693,7 @@ ___ • **ethereumRPCURL**? : *undefined | string* -*Defined in [types.ts:100](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L100)* +*Defined in [types.ts:100](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L100)* ___ @@ -701,7 +701,7 @@ ___ • **maxOrdersInStorage**? : *undefined | number* -*Defined in [types.ts:167](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L167)* +*Defined in [types.ts:167](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L167)* ___ @@ -709,7 +709,7 @@ ___ • **useBootstrapList**? : *undefined | false | true* -*Defined in [types.ts:106](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L106)* +*Defined in [types.ts:106](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L106)* ___ @@ -717,7 +717,7 @@ ___ • **verbosity**? : *[Verbosity](#enumeration-verbosity)* -*Defined in [types.ts:97](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L97)* +*Defined in [types.ts:97](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L97)* ___ @@ -725,7 +725,7 @@ ___ • **web3Provider**? : *SupportedProvider* -*Defined in [types.ts:190](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L190)* +*Defined in [types.ts:190](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L190)*
@@ -743,7 +743,7 @@ ___ • **coordinator**? : *undefined | string* -*Defined in [types.ts:199](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L199)* +*Defined in [types.ts:199](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L199)* ___ @@ -751,7 +751,7 @@ ___ • **coordinatorRegistry**? : *undefined | string* -*Defined in [types.ts:200](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L200)* +*Defined in [types.ts:200](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L200)* ___ @@ -759,7 +759,7 @@ ___ • **devUtils**: *string* -*Defined in [types.ts:195](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L195)* +*Defined in [types.ts:195](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L195)* ___ @@ -767,7 +767,7 @@ ___ • **erc1155Proxy**: *string* -*Defined in [types.ts:198](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L198)* +*Defined in [types.ts:198](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L198)* ___ @@ -775,7 +775,7 @@ ___ • **erc20Proxy**: *string* -*Defined in [types.ts:196](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L196)* +*Defined in [types.ts:196](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L196)* ___ @@ -783,7 +783,7 @@ ___ • **erc721Proxy**: *string* -*Defined in [types.ts:197](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L197)* +*Defined in [types.ts:197](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L197)* ___ @@ -791,7 +791,7 @@ ___ • **exchange**: *string* -*Defined in [types.ts:194](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L194)* +*Defined in [types.ts:194](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L194)* ___ @@ -799,7 +799,7 @@ ___ • **weth9**? : *undefined | string* -*Defined in [types.ts:201](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L201)* +*Defined in [types.ts:201](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L201)* ___ @@ -807,7 +807,7 @@ ___ • **zrxToken**? : *undefined | string* -*Defined in [types.ts:202](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L202)* +*Defined in [types.ts:202](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L202)*
@@ -825,7 +825,7 @@ ___ • **address**: *string* -*Defined in [types.ts:516](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L516)* +*Defined in [types.ts:516](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L516)* ___ @@ -833,7 +833,7 @@ ___ • **blockHash**: *string* -*Defined in [types.ts:511](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L511)* +*Defined in [types.ts:511](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L511)* ___ @@ -841,7 +841,7 @@ ___ • **isRemoved**: *boolean* -*Defined in [types.ts:515](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L515)* +*Defined in [types.ts:515](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L515)* ___ @@ -849,7 +849,7 @@ ___ • **kind**: *[ContractEventKind](#enumeration-contracteventkind)* -*Defined in [types.ts:517](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L517)* +*Defined in [types.ts:517](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L517)* ___ @@ -857,7 +857,7 @@ ___ • **logIndex**: *number* -*Defined in [types.ts:514](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L514)* +*Defined in [types.ts:514](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L514)* ___ @@ -865,7 +865,7 @@ ___ • **parameters**: *ContractEventParameters* -*Defined in [types.ts:518](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L518)* +*Defined in [types.ts:518](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L518)* ___ @@ -873,7 +873,7 @@ ___ • **txHash**: *string* -*Defined in [types.ts:512](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L512)* +*Defined in [types.ts:512](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L512)* ___ @@ -881,7 +881,7 @@ ___ • **txIndex**: *number* -*Defined in [types.ts:513](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L513)* +*Defined in [types.ts:513](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L513)*
@@ -899,7 +899,7 @@ ___ • **approved**: *boolean* -*Defined in [types.ts:380](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L380)* +*Defined in [types.ts:380](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L380)* ___ @@ -907,7 +907,7 @@ ___ • **operator**: *string* -*Defined in [types.ts:379](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L379)* +*Defined in [types.ts:379](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L379)* ___ @@ -915,7 +915,7 @@ ___ • **owner**: *string* -*Defined in [types.ts:378](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L378)* +*Defined in [types.ts:378](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L378)*
@@ -933,7 +933,7 @@ ___ • **from**: *string* -*Defined in [types.ts:362](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L362)* +*Defined in [types.ts:362](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L362)* ___ @@ -941,7 +941,7 @@ ___ • **ids**: *BigNumber[]* -*Defined in [types.ts:364](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L364)* +*Defined in [types.ts:364](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L364)* ___ @@ -949,7 +949,7 @@ ___ • **operator**: *string* -*Defined in [types.ts:361](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L361)* +*Defined in [types.ts:361](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L361)* ___ @@ -957,7 +957,7 @@ ___ • **to**: *string* -*Defined in [types.ts:363](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L363)* +*Defined in [types.ts:363](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L363)* ___ @@ -965,7 +965,7 @@ ___ • **values**: *BigNumber[]* -*Defined in [types.ts:365](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L365)* +*Defined in [types.ts:365](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L365)*
@@ -983,7 +983,7 @@ ___ • **from**: *string* -*Defined in [types.ts:345](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L345)* +*Defined in [types.ts:345](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L345)* ___ @@ -991,7 +991,7 @@ ___ • **id**: *BigNumber* -*Defined in [types.ts:347](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L347)* +*Defined in [types.ts:347](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L347)* ___ @@ -999,7 +999,7 @@ ___ • **operator**: *string* -*Defined in [types.ts:344](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L344)* +*Defined in [types.ts:344](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L344)* ___ @@ -1007,7 +1007,7 @@ ___ • **to**: *string* -*Defined in [types.ts:346](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L346)* +*Defined in [types.ts:346](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L346)* ___ @@ -1015,7 +1015,7 @@ ___ • **value**: *BigNumber* -*Defined in [types.ts:348](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L348)* +*Defined in [types.ts:348](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L348)*
@@ -1033,7 +1033,7 @@ ___ • **owner**: *string* -*Defined in [types.ts:299](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L299)* +*Defined in [types.ts:299](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L299)* ___ @@ -1041,7 +1041,7 @@ ___ • **spender**: *string* -*Defined in [types.ts:300](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L300)* +*Defined in [types.ts:300](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L300)* ___ @@ -1049,7 +1049,7 @@ ___ • **value**: *BigNumber* -*Defined in [types.ts:301](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L301)* +*Defined in [types.ts:301](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L301)*
@@ -1067,7 +1067,7 @@ ___ • **from**: *string* -*Defined in [types.ts:286](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L286)* +*Defined in [types.ts:286](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L286)* ___ @@ -1075,7 +1075,7 @@ ___ • **to**: *string* -*Defined in [types.ts:287](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L287)* +*Defined in [types.ts:287](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L287)* ___ @@ -1083,7 +1083,7 @@ ___ • **value**: *BigNumber* -*Defined in [types.ts:288](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L288)* +*Defined in [types.ts:288](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L288)*
@@ -1101,7 +1101,7 @@ ___ • **approved**: *string* -*Defined in [types.ts:326](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L326)* +*Defined in [types.ts:326](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L326)* ___ @@ -1109,7 +1109,7 @@ ___ • **owner**: *string* -*Defined in [types.ts:325](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L325)* +*Defined in [types.ts:325](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L325)* ___ @@ -1117,7 +1117,7 @@ ___ • **tokenId**: *BigNumber* -*Defined in [types.ts:327](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L327)* +*Defined in [types.ts:327](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L327)*
@@ -1135,7 +1135,7 @@ ___ • **approved**: *boolean* -*Defined in [types.ts:340](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L340)* +*Defined in [types.ts:340](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L340)* ___ @@ -1143,7 +1143,7 @@ ___ • **operator**: *string* -*Defined in [types.ts:339](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L339)* +*Defined in [types.ts:339](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L339)* ___ @@ -1151,7 +1151,7 @@ ___ • **owner**: *string* -*Defined in [types.ts:338](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L338)* +*Defined in [types.ts:338](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L338)*
@@ -1169,7 +1169,7 @@ ___ • **from**: *string* -*Defined in [types.ts:312](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L312)* +*Defined in [types.ts:312](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L312)* ___ @@ -1177,7 +1177,7 @@ ___ • **to**: *string* -*Defined in [types.ts:313](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L313)* +*Defined in [types.ts:313](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L313)* ___ @@ -1185,7 +1185,7 @@ ___ • **tokenId**: *BigNumber* -*Defined in [types.ts:314](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L314)* +*Defined in [types.ts:314](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L314)*
@@ -1203,7 +1203,7 @@ ___ • **feeRecipientAddress**: *string* -*Defined in [types.ts:421](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L421)* +*Defined in [types.ts:421](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L421)* ___ @@ -1211,7 +1211,7 @@ ___ • **makerAddress**: *string* -*Defined in [types.ts:419](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L419)* +*Defined in [types.ts:419](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L419)* ___ @@ -1219,7 +1219,7 @@ ___ • **makerAssetData**: *string* -*Defined in [types.ts:423](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L423)* +*Defined in [types.ts:423](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L423)* ___ @@ -1227,7 +1227,7 @@ ___ • **orderHash**: *string* -*Defined in [types.ts:422](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L422)* +*Defined in [types.ts:422](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L422)* ___ @@ -1235,7 +1235,7 @@ ___ • **senderAddress**: *string* -*Defined in [types.ts:420](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L420)* +*Defined in [types.ts:420](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L420)* ___ @@ -1243,7 +1243,7 @@ ___ • **takerAssetData**: *string* -*Defined in [types.ts:424](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L424)* +*Defined in [types.ts:424](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L424)*
@@ -1261,7 +1261,7 @@ ___ • **makerAddress**: *string* -*Defined in [types.ts:428](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L428)* +*Defined in [types.ts:428](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L428)* ___ @@ -1269,7 +1269,7 @@ ___ • **orderEpoch**: *BigNumber* -*Defined in [types.ts:430](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L430)* +*Defined in [types.ts:430](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L430)* ___ @@ -1277,7 +1277,7 @@ ___ • **orderSenderAddress**: *string* -*Defined in [types.ts:429](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L429)* +*Defined in [types.ts:429](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L429)*
@@ -1295,7 +1295,7 @@ ___ • **feeRecipientAddress**: *string* -*Defined in [types.ts:387](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L387)* +*Defined in [types.ts:387](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L387)* ___ @@ -1303,7 +1303,7 @@ ___ • **makerAddress**: *string* -*Defined in [types.ts:384](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L384)* +*Defined in [types.ts:384](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L384)* ___ @@ -1311,7 +1311,7 @@ ___ • **makerAssetData**: *string* -*Defined in [types.ts:394](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L394)* +*Defined in [types.ts:394](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L394)* ___ @@ -1319,7 +1319,7 @@ ___ • **makerAssetFilledAmount**: *BigNumber* -*Defined in [types.ts:388](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L388)* +*Defined in [types.ts:388](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L388)* ___ @@ -1327,7 +1327,7 @@ ___ • **makerFeeAssetData**: *string* -*Defined in [types.ts:396](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L396)* +*Defined in [types.ts:396](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L396)* ___ @@ -1335,7 +1335,7 @@ ___ • **makerFeePaid**: *BigNumber* -*Defined in [types.ts:390](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L390)* +*Defined in [types.ts:390](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L390)* ___ @@ -1343,7 +1343,7 @@ ___ • **orderHash**: *string* -*Defined in [types.ts:393](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L393)* +*Defined in [types.ts:393](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L393)* ___ @@ -1351,7 +1351,7 @@ ___ • **protocolFeePaid**: *BigNumber* -*Defined in [types.ts:392](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L392)* +*Defined in [types.ts:392](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L392)* ___ @@ -1359,7 +1359,7 @@ ___ • **senderAddress**: *string* -*Defined in [types.ts:386](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L386)* +*Defined in [types.ts:386](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L386)* ___ @@ -1367,7 +1367,7 @@ ___ • **takerAddress**: *string* -*Defined in [types.ts:385](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L385)* +*Defined in [types.ts:385](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L385)* ___ @@ -1375,7 +1375,7 @@ ___ • **takerAssetData**: *string* -*Defined in [types.ts:395](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L395)* +*Defined in [types.ts:395](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L395)* ___ @@ -1383,7 +1383,7 @@ ___ • **takerAssetFilledAmount**: *BigNumber* -*Defined in [types.ts:389](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L389)* +*Defined in [types.ts:389](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L389)* ___ @@ -1391,7 +1391,7 @@ ___ • **takerFeeAssetData**: *string* -*Defined in [types.ts:397](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L397)* +*Defined in [types.ts:397](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L397)* ___ @@ -1399,7 +1399,7 @@ ___ • **takerFeePaid**: *BigNumber* -*Defined in [types.ts:391](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L391)* +*Defined in [types.ts:391](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L391)*
@@ -1417,7 +1417,7 @@ ___ • **ordersInfos**: *[OrderInfo](#interface-orderinfo)[]* -*Defined in [types.ts:19](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L19)* +*Defined in [types.ts:19](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L19)* ___ @@ -1425,7 +1425,7 @@ ___ • **snapshotID**: *string* -*Defined in [types.ts:17](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L17)* +*Defined in [types.ts:17](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L17)* ___ @@ -1433,7 +1433,7 @@ ___ • **snapshotTimestamp**: *number* -*Defined in [types.ts:18](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L18)* +*Defined in [types.ts:18](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L18)*
@@ -1453,7 +1453,7 @@ An interface for JSON schema types, which are used for custom order filters. • **$ref**? : *undefined | string* -*Defined in [types.ts:41](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L41)* +*Defined in [types.ts:41](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L41)* ___ @@ -1461,7 +1461,7 @@ ___ • **$schema**? : *undefined | string* -*Defined in [types.ts:40](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L40)* +*Defined in [types.ts:40](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L40)* ___ @@ -1469,7 +1469,7 @@ ___ • **additionalItems**? : *boolean | [JsonSchema](#interface-jsonschema)* -*Defined in [types.ts:52](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L52)* +*Defined in [types.ts:52](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L52)* ___ @@ -1477,7 +1477,7 @@ ___ • **additionalProperties**? : *boolean | [JsonSchema](#interface-jsonschema)* -*Defined in [types.ts:60](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L60)* +*Defined in [types.ts:60](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L60)* ___ @@ -1485,7 +1485,7 @@ ___ • **allOf**? : *[JsonSchema](#interface-jsonschema)[]* -*Defined in [types.ts:82](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L82)* +*Defined in [types.ts:82](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L82)* ___ @@ -1493,7 +1493,7 @@ ___ • **anyOf**? : *[JsonSchema](#interface-jsonschema)[]* -*Defined in [types.ts:83](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L83)* +*Defined in [types.ts:83](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L83)* ___ @@ -1501,7 +1501,7 @@ ___ • **const**? : *any* -*Defined in [types.ts:79](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L79)* +*Defined in [types.ts:79](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L79)* ___ @@ -1509,7 +1509,7 @@ ___ • **definitions**? : *undefined | object* -*Defined in [types.ts:61](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L61)* +*Defined in [types.ts:61](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L61)* ___ @@ -1517,7 +1517,7 @@ ___ • **dependencies**? : *undefined | object* -*Defined in [types.ts:70](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L70)* +*Defined in [types.ts:70](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L70)* ___ @@ -1525,7 +1525,7 @@ ___ • **description**? : *undefined | string* -*Defined in [types.ts:43](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L43)* +*Defined in [types.ts:43](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L43)* ___ @@ -1533,7 +1533,7 @@ ___ • **enum**? : *any[]* -*Defined in [types.ts:73](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L73)* +*Defined in [types.ts:73](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L73)* ___ @@ -1541,7 +1541,7 @@ ___ • **exclusiveMaximum**? : *undefined | false | true* -*Defined in [types.ts:46](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L46)* +*Defined in [types.ts:46](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L46)* ___ @@ -1549,7 +1549,7 @@ ___ • **exclusiveMinimum**? : *undefined | false | true* -*Defined in [types.ts:48](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L48)* +*Defined in [types.ts:48](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L48)* ___ @@ -1557,7 +1557,7 @@ ___ • **format**? : *undefined | string* -*Defined in [types.ts:81](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L81)* +*Defined in [types.ts:81](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L81)* ___ @@ -1565,7 +1565,7 @@ ___ • **id**? : *undefined | string* -*Defined in [types.ts:39](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L39)* +*Defined in [types.ts:39](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L39)* ___ @@ -1573,7 +1573,7 @@ ___ • **items**? : *[JsonSchema](#interface-jsonschema) | [JsonSchema](#interface-jsonschema)[]* -*Defined in [types.ts:53](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L53)* +*Defined in [types.ts:53](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L53)* ___ @@ -1581,7 +1581,7 @@ ___ • **maxItems**? : *undefined | number* -*Defined in [types.ts:54](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L54)* +*Defined in [types.ts:54](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L54)* ___ @@ -1589,7 +1589,7 @@ ___ • **maxLength**? : *undefined | number* -*Defined in [types.ts:49](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L49)* +*Defined in [types.ts:49](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L49)* ___ @@ -1597,7 +1597,7 @@ ___ • **maxProperties**? : *undefined | number* -*Defined in [types.ts:57](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L57)* +*Defined in [types.ts:57](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L57)* ___ @@ -1605,7 +1605,7 @@ ___ • **maximum**? : *undefined | number* -*Defined in [types.ts:45](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L45)* +*Defined in [types.ts:45](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L45)* ___ @@ -1613,7 +1613,7 @@ ___ • **minItems**? : *undefined | number* -*Defined in [types.ts:55](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L55)* +*Defined in [types.ts:55](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L55)* ___ @@ -1621,7 +1621,7 @@ ___ • **minLength**? : *undefined | number* -*Defined in [types.ts:50](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L50)* +*Defined in [types.ts:50](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L50)* ___ @@ -1629,7 +1629,7 @@ ___ • **minProperties**? : *undefined | number* -*Defined in [types.ts:58](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L58)* +*Defined in [types.ts:58](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L58)* ___ @@ -1637,7 +1637,7 @@ ___ • **minimum**? : *undefined | number* -*Defined in [types.ts:47](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L47)* +*Defined in [types.ts:47](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L47)* ___ @@ -1645,7 +1645,7 @@ ___ • **multipleOf**? : *undefined | number* -*Defined in [types.ts:44](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L44)* +*Defined in [types.ts:44](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L44)* ___ @@ -1653,7 +1653,7 @@ ___ • **not**? : *[JsonSchema](#interface-jsonschema)* -*Defined in [types.ts:85](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L85)* +*Defined in [types.ts:85](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L85)* ___ @@ -1661,7 +1661,7 @@ ___ • **oneOf**? : *[JsonSchema](#interface-jsonschema)[]* -*Defined in [types.ts:84](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L84)* +*Defined in [types.ts:84](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L84)* ___ @@ -1669,7 +1669,7 @@ ___ • **pattern**? : *string | RegExp* -*Defined in [types.ts:51](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L51)* +*Defined in [types.ts:51](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L51)* ___ @@ -1677,7 +1677,7 @@ ___ • **patternProperties**? : *undefined | object* -*Defined in [types.ts:67](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L67)* +*Defined in [types.ts:67](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L67)* ___ @@ -1685,7 +1685,7 @@ ___ • **properties**? : *undefined | object* -*Defined in [types.ts:64](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L64)* +*Defined in [types.ts:64](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L64)* ___ @@ -1693,7 +1693,7 @@ ___ • **required**? : *string[]* -*Defined in [types.ts:59](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L59)* +*Defined in [types.ts:59](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L59)* ___ @@ -1701,7 +1701,7 @@ ___ • **title**? : *undefined | string* -*Defined in [types.ts:42](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L42)* +*Defined in [types.ts:42](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L42)* ___ @@ -1709,7 +1709,7 @@ ___ • **type**? : *string | string[]* -*Defined in [types.ts:80](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L80)* +*Defined in [types.ts:80](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L80)* ___ @@ -1717,7 +1717,7 @@ ___ • **uniqueItems**? : *undefined | false | true* -*Defined in [types.ts:56](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L56)* +*Defined in [types.ts:56](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L56)*
@@ -1735,7 +1735,7 @@ ___ • **hash**: *string* -*Defined in [types.ts:643](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L643)* +*Defined in [types.ts:643](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L643)* ___ @@ -1743,7 +1743,7 @@ ___ • **number**: *number* -*Defined in [types.ts:642](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L642)* +*Defined in [types.ts:642](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L642)*
@@ -1764,7 +1764,7 @@ or filled. • **contractEvents**: *[ContractEvent](#interface-contractevent)[]* -*Defined in [types.ts:569](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L569)* +*Defined in [types.ts:569](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L569)* ___ @@ -1772,7 +1772,7 @@ ___ • **endState**: *[OrderEventEndState](#enumeration-ordereventendstate)* -*Defined in [types.ts:567](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L567)* +*Defined in [types.ts:567](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L567)* ___ @@ -1780,7 +1780,7 @@ ___ • **fillableTakerAssetAmount**: *BigNumber* -*Defined in [types.ts:568](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L568)* +*Defined in [types.ts:568](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L568)* ___ @@ -1788,7 +1788,7 @@ ___ • **orderHash**: *string* -*Defined in [types.ts:565](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L565)* +*Defined in [types.ts:565](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L565)* ___ @@ -1796,7 +1796,7 @@ ___ • **signedOrder**: *SignedOrder* -*Defined in [types.ts:566](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L566)* +*Defined in [types.ts:566](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L566)* ___ @@ -1804,7 +1804,7 @@ ___ • **timestampMs**: *number* -*Defined in [types.ts:564](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L564)* +*Defined in [types.ts:564](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L564)*
@@ -1822,7 +1822,7 @@ ___ • **fillableTakerAssetAmount**: *BigNumber* -*Defined in [types.ts:32](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L32)* +*Defined in [types.ts:32](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L32)* ___ @@ -1830,7 +1830,7 @@ ___ • **orderHash**: *string* -*Defined in [types.ts:30](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L30)* +*Defined in [types.ts:30](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L30)* ___ @@ -1838,7 +1838,7 @@ ___ • **signedOrder**: *SignedOrder* -*Defined in [types.ts:31](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L31)* +*Defined in [types.ts:31](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L31)*
@@ -1859,7 +1859,7 @@ rejected. • **kind**: *[RejectedOrderKind](#enumeration-rejectedorderkind)* -*Defined in [types.ts:619](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L619)* +*Defined in [types.ts:619](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L619)* ___ @@ -1867,7 +1867,7 @@ ___ • **orderHash**: *string* -*Defined in [types.ts:617](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L617)* +*Defined in [types.ts:617](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L617)* ___ @@ -1875,7 +1875,7 @@ ___ • **signedOrder**: *SignedOrder* -*Defined in [types.ts:618](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L618)* +*Defined in [types.ts:618](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L618)* ___ @@ -1883,7 +1883,7 @@ ___ • **status**: *[RejectedOrderStatus](#interface-rejectedorderstatus)* -*Defined in [types.ts:620](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L620)* +*Defined in [types.ts:620](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L620)*
@@ -1903,7 +1903,7 @@ Provides more information about why an order was rejected. • **code**: *string* -*Defined in [types.ts:637](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L637)* +*Defined in [types.ts:637](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L637)* ___ @@ -1911,7 +1911,7 @@ ___ • **message**: *string* -*Defined in [types.ts:638](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L638)* +*Defined in [types.ts:638](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L638)*
@@ -1929,7 +1929,7 @@ ___ • **ethRPCRateLimitExpiredRequests**: *number* -*Defined in [types.ts:680](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L680)* +*Defined in [types.ts:680](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L680)* ___ @@ -1937,7 +1937,7 @@ ___ • **ethRPCRequestsSentInCurrentUTCDay**: *number* -*Defined in [types.ts:679](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L679)* +*Defined in [types.ts:679](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L679)* ___ @@ -1945,7 +1945,7 @@ ___ • **ethereumChainID**: *number* -*Defined in [types.ts:671](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L671)* +*Defined in [types.ts:671](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L671)* ___ @@ -1953,7 +1953,7 @@ ___ • **latestBlock**: *[LatestBlock](#interface-latestblock)* -*Defined in [types.ts:672](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L672)* +*Defined in [types.ts:672](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L672)* ___ @@ -1961,7 +1961,7 @@ ___ • **maxExpirationTime**: *BigNumber* -*Defined in [types.ts:677](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L677)* +*Defined in [types.ts:677](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L677)* ___ @@ -1969,7 +1969,7 @@ ___ • **numOrders**: *number* -*Defined in [types.ts:674](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L674)* +*Defined in [types.ts:674](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L674)* ___ @@ -1977,7 +1977,7 @@ ___ • **numOrdersIncludingRemoved**: *number* -*Defined in [types.ts:675](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L675)* +*Defined in [types.ts:675](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L675)* ___ @@ -1985,7 +1985,7 @@ ___ • **numPeers**: *number* -*Defined in [types.ts:673](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L673)* +*Defined in [types.ts:673](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L673)* ___ @@ -1993,7 +1993,7 @@ ___ • **numPinnedOrders**: *number* -*Defined in [types.ts:676](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L676)* +*Defined in [types.ts:676](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L676)* ___ @@ -2001,7 +2001,7 @@ ___ • **peerID**: *string* -*Defined in [types.ts:670](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L670)* +*Defined in [types.ts:670](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L670)* ___ @@ -2009,7 +2009,7 @@ ___ • **pubSubTopic**: *string* -*Defined in [types.ts:667](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L667)* +*Defined in [types.ts:667](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L667)* ___ @@ -2017,7 +2017,7 @@ ___ • **rendezvous**: *string* -*Defined in [types.ts:668](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L668)* +*Defined in [types.ts:668](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L668)* ___ @@ -2025,7 +2025,7 @@ ___ • **secondaryRendezvous**: *string[]* -*Defined in [types.ts:669](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L669)* +*Defined in [types.ts:669](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L669)* ___ @@ -2033,7 +2033,7 @@ ___ • **startOfCurrentUTCDay**: *Date* -*Defined in [types.ts:678](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L678)* +*Defined in [types.ts:678](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L678)* ___ @@ -2041,7 +2041,7 @@ ___ • **version**: *string* -*Defined in [types.ts:666](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L666)* +*Defined in [types.ts:666](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L666)*
@@ -2061,7 +2061,7 @@ Indicates which orders where accepted, which were rejected, and why. • **accepted**: *[AcceptedOrderInfo](#interface-acceptedorderinfo)[]* -*Defined in [types.ts:598](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L598)* +*Defined in [types.ts:598](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L598)* ___ @@ -2069,7 +2069,7 @@ ___ • **rejected**: *[RejectedOrderInfo](#interface-rejectedorderinfo)[]* -*Defined in [types.ts:599](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L599)* +*Defined in [types.ts:599](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L599)*
@@ -2087,7 +2087,7 @@ ___ • **owner**: *string* -*Defined in [types.ts:452](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L452)* +*Defined in [types.ts:452](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L452)* ___ @@ -2095,7 +2095,7 @@ ___ • **value**: *BigNumber* -*Defined in [types.ts:453](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L453)* +*Defined in [types.ts:453](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L453)*
@@ -2113,7 +2113,7 @@ ___ • **owner**: *string* -*Defined in [types.ts:441](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L441)* +*Defined in [types.ts:441](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L441)* ___ @@ -2121,7 +2121,7 @@ ___ • **value**: *BigNumber* -*Defined in [types.ts:442](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L442)* +*Defined in [types.ts:442](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L442)*
@@ -2132,7 +2132,7 @@ ___ ## loadMeshStreamingForURLAsync ▸ **loadMeshStreamingWithURLAsync**(`url`: `string`): *Promise‹`void`›* -*Defined in [index.ts:7](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/index.ts#L7)* +*Defined in [index.ts:7](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/index.ts#L7)* Loads the Wasm module that is provided by fetching a url. @@ -2148,7 +2148,7 @@ Name | Type | Description | ▸ **loadMeshStreamingAsync**(`response`: `Response | Promise`): *Promise‹`void`›* -*Defined in [index.ts:15](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/index.ts#L15)* +*Defined in [index.ts:15](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/index.ts#L15)* Loads the Wasm module that is provided by a response. diff --git a/docs/browser-bindings/browser/README.md b/docs/browser-bindings/browser/README.md index 7f542d29c..2f5d8c5c5 100644 --- a/docs/browser-bindings/browser/README.md +++ b/docs/browser-bindings/browser/README.md @@ -1,4 +1,4 @@ -# @0x/mesh-browser - v9.4.1 +# @0x/mesh-browser - v9.4.2 ## @0x/mesh-browser diff --git a/docs/browser-bindings/browser/reference.md b/docs/browser-bindings/browser/reference.md index 80f6a7503..a7f689dac 100644 --- a/docs/browser-bindings/browser/reference.md +++ b/docs/browser-bindings/browser/reference.md @@ -14,7 +14,7 @@ sending orders through the 0x Mesh network. \+ **new Mesh**(`config`: [Config](#interface-config)): *[Mesh](#class-mesh)* -*Defined in [mesh.ts:142](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/mesh.ts#L142)* +*Defined in [mesh.ts:142](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/mesh.ts#L142)* Instantiates a new Mesh instance. @@ -34,7 +34,7 @@ An instance of Mesh ▸ **addOrdersAsync**(`orders`: SignedOrder[], `pinned`: boolean): *Promise‹[ValidationResults](#interface-validationresults)›* -*Defined in [mesh.ts:292](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/mesh.ts#L292)* +*Defined in [mesh.ts:292](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/mesh.ts#L292)* Validates and adds the given orders to Mesh. If an order is successfully added, Mesh will share it with any peers in the network and start @@ -61,7 +61,7 @@ ___ ▸ **getOrdersAsync**(`perPage`: number): *Promise‹[GetOrdersResponse](#interface-getordersresponse)›* -*Defined in [mesh.ts:221](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/mesh.ts#L221)* +*Defined in [mesh.ts:221](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/mesh.ts#L221)* Get all 0x signed orders currently stored in the Mesh node @@ -81,7 +81,7 @@ ___ ▸ **getOrdersForPageAsync**(`page`: number, `perPage`: number, `snapshotID?`: undefined | string): *Promise‹[GetOrdersResponse](#interface-getordersresponse)›* -*Defined in [mesh.ts:263](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/mesh.ts#L263)* +*Defined in [mesh.ts:263](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/mesh.ts#L263)* Get page of 0x signed orders stored on the Mesh node at the specified snapshot @@ -103,7 +103,7 @@ ___ ▸ **getStatsAsync**(): *Promise‹[Stats](#interface-stats)›* -*Defined in [mesh.ts:204](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/mesh.ts#L204)* +*Defined in [mesh.ts:204](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/mesh.ts#L204)* Returns various stats about Mesh, including the total number of orders and the number of peers Mesh is connected to. @@ -116,7 +116,7 @@ ___ ▸ **onError**(`handler`: function): *void* -*Defined in [mesh.ts:162](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/mesh.ts#L162)* +*Defined in [mesh.ts:162](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/mesh.ts#L162)* Registers a handler which will be called in the event of a critical error. Note that the handler will not be called for non-critical errors. @@ -145,7 +145,7 @@ ___ ▸ **onOrderEvents**(`handler`: function): *void* -*Defined in [mesh.ts:177](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/mesh.ts#L177)* +*Defined in [mesh.ts:177](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/mesh.ts#L177)* Registers a handler which will be called for any incoming order events. Order events are fired whenver an order is added, canceled, expired, or @@ -174,7 +174,7 @@ ___ ▸ **startAsync**(): *Promise‹void›* -*Defined in [mesh.ts:188](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/mesh.ts#L188)* +*Defined in [mesh.ts:188](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/mesh.ts#L188)* Starts the Mesh node in the background. Mesh will automatically find peers in the network and begin receiving orders from them. @@ -193,7 +193,7 @@ peers in the network and begin receiving orders from them. • **ERC1155ApprovalForAllEvent**: = "ERC1155ApprovalForAllEvent" -*Defined in [types.ts:468](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L468)* +*Defined in [types.ts:468](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L468)* ___ @@ -201,7 +201,7 @@ ___ • **ERC1155TransferBatchEvent**: = "ERC1155TransferBatchEvent" -*Defined in [types.ts:470](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L470)* +*Defined in [types.ts:470](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L470)* ___ @@ -209,7 +209,7 @@ ___ • **ERC1155TransferSingleEvent**: = "ERC1155TransferSingleEvent" -*Defined in [types.ts:469](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L469)* +*Defined in [types.ts:469](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L469)* ___ @@ -217,7 +217,7 @@ ___ • **ERC20ApprovalEvent**: = "ERC20ApprovalEvent" -*Defined in [types.ts:464](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L464)* +*Defined in [types.ts:464](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L464)* ___ @@ -225,7 +225,7 @@ ___ • **ERC20TransferEvent**: = "ERC20TransferEvent" -*Defined in [types.ts:463](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L463)* +*Defined in [types.ts:463](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L463)* ___ @@ -233,7 +233,7 @@ ___ • **ERC721ApprovalEvent**: = "ERC721ApprovalEvent" -*Defined in [types.ts:466](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L466)* +*Defined in [types.ts:466](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L466)* ___ @@ -241,7 +241,7 @@ ___ • **ERC721ApprovalForAllEvent**: = "ERC721ApprovalForAllEvent" -*Defined in [types.ts:467](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L467)* +*Defined in [types.ts:467](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L467)* ___ @@ -249,7 +249,7 @@ ___ • **ERC721TransferEvent**: = "ERC721TransferEvent" -*Defined in [types.ts:465](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L465)* +*Defined in [types.ts:465](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L465)* ___ @@ -257,7 +257,7 @@ ___ • **ExchangeCancelEvent**: = "ExchangeCancelEvent" -*Defined in [types.ts:472](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L472)* +*Defined in [types.ts:472](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L472)* ___ @@ -265,7 +265,7 @@ ___ • **ExchangeCancelUpToEvent**: = "ExchangeCancelUpToEvent" -*Defined in [types.ts:473](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L473)* +*Defined in [types.ts:473](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L473)* ___ @@ -273,7 +273,7 @@ ___ • **ExchangeFillEvent**: = "ExchangeFillEvent" -*Defined in [types.ts:471](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L471)* +*Defined in [types.ts:471](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L471)* ___ @@ -281,7 +281,7 @@ ___ • **WethDepositEvent**: = "WethDepositEvent" -*Defined in [types.ts:474](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L474)* +*Defined in [types.ts:474](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L474)* ___ @@ -289,7 +289,7 @@ ___ • **WethWithdrawalEvent**: = "WethWithdrawalEvent" -*Defined in [types.ts:475](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L475)* +*Defined in [types.ts:475](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L475)*
@@ -303,7 +303,7 @@ ___ • **Added**: = "ADDED" -*Defined in [types.ts:538](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L538)* +*Defined in [types.ts:538](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L538)* ___ @@ -311,7 +311,7 @@ ___ • **Cancelled**: = "CANCELLED" -*Defined in [types.ts:541](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L541)* +*Defined in [types.ts:541](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L541)* ___ @@ -319,7 +319,7 @@ ___ • **Expired**: = "EXPIRED" -*Defined in [types.ts:542](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L542)* +*Defined in [types.ts:542](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L542)* ___ @@ -327,7 +327,7 @@ ___ • **FillabilityIncreased**: = "FILLABILITY_INCREASED" -*Defined in [types.ts:545](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L545)* +*Defined in [types.ts:545](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L545)* ___ @@ -335,7 +335,7 @@ ___ • **Filled**: = "FILLED" -*Defined in [types.ts:539](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L539)* +*Defined in [types.ts:539](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L539)* ___ @@ -343,7 +343,7 @@ ___ • **FullyFilled**: = "FULLY_FILLED" -*Defined in [types.ts:540](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L540)* +*Defined in [types.ts:540](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L540)* ___ @@ -351,7 +351,7 @@ ___ • **Invalid**: = "INVALID" -*Defined in [types.ts:537](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L537)* +*Defined in [types.ts:537](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L537)* ___ @@ -359,7 +359,7 @@ ___ • **StoppedWatching**: = "STOPPED_WATCHING" -*Defined in [types.ts:546](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L546)* +*Defined in [types.ts:546](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L546)* ___ @@ -367,7 +367,7 @@ ___ • **Unexpired**: = "UNEXPIRED" -*Defined in [types.ts:543](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L543)* +*Defined in [types.ts:543](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L543)* ___ @@ -375,7 +375,7 @@ ___ • **Unfunded**: = "UNFUNDED" -*Defined in [types.ts:544](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L544)* +*Defined in [types.ts:544](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L544)*
@@ -391,7 +391,7 @@ A set of categories for rejected orders. • **CoordinatorError**: = "COORDINATOR_ERROR" -*Defined in [types.ts:630](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L630)* +*Defined in [types.ts:630](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L630)* ___ @@ -399,7 +399,7 @@ ___ • **MeshError**: = "MESH_ERROR" -*Defined in [types.ts:628](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L628)* +*Defined in [types.ts:628](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L628)* ___ @@ -407,7 +407,7 @@ ___ • **MeshValidation**: = "MESH_VALIDATION" -*Defined in [types.ts:629](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L629)* +*Defined in [types.ts:629](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L629)* ___ @@ -415,7 +415,7 @@ ___ • **ZeroExValidation**: = "ZEROEX_VALIDATION" -*Defined in [types.ts:627](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L627)* +*Defined in [types.ts:627](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L627)*
@@ -429,7 +429,7 @@ ___ • **Debug**: = 5 -*Defined in [types.ts:211](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L211)* +*Defined in [types.ts:211](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L211)* ___ @@ -437,7 +437,7 @@ ___ • **Error**: = 2 -*Defined in [types.ts:208](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L208)* +*Defined in [types.ts:208](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L208)* ___ @@ -445,7 +445,7 @@ ___ • **Fatal**: = 1 -*Defined in [types.ts:207](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L207)* +*Defined in [types.ts:207](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L207)* ___ @@ -453,7 +453,7 @@ ___ • **Info**: = 4 -*Defined in [types.ts:210](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L210)* +*Defined in [types.ts:210](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L210)* ___ @@ -461,7 +461,7 @@ ___ • **Panic**: = 0 -*Defined in [types.ts:206](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L206)* +*Defined in [types.ts:206](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L206)* ___ @@ -469,7 +469,7 @@ ___ • **Trace**: = 6 -*Defined in [types.ts:212](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L212)* +*Defined in [types.ts:212](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L212)* ___ @@ -477,7 +477,7 @@ ___ • **Warn**: = 3 -*Defined in [types.ts:209](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L209)* +*Defined in [types.ts:209](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L209)*
@@ -495,7 +495,7 @@ ___ • **errors**: *string[]* -*Defined in [schema_validator.ts:11](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/schema_validator.ts#L11)* +*Defined in [schema_validator.ts:11](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/schema_validator.ts#L11)* ___ @@ -503,7 +503,7 @@ ___ • **fatal**? : *undefined | string* -*Defined in [schema_validator.ts:12](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/schema_validator.ts#L12)* +*Defined in [schema_validator.ts:12](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/schema_validator.ts#L12)* ___ @@ -511,7 +511,7 @@ ___ • **success**: *boolean* -*Defined in [schema_validator.ts:10](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/schema_validator.ts#L10)* +*Defined in [schema_validator.ts:10](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/schema_validator.ts#L10)*
@@ -529,7 +529,7 @@ ___ • **messageValidator**: *function* -*Defined in [schema_validator.ts:17](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/schema_validator.ts#L17)* +*Defined in [schema_validator.ts:17](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/schema_validator.ts#L17)* #### Type declaration: @@ -547,7 +547,7 @@ ___ • **orderValidator**: *function* -*Defined in [schema_validator.ts:16](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/schema_validator.ts#L16)* +*Defined in [schema_validator.ts:16](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/schema_validator.ts#L16)* #### Type declaration: @@ -577,7 +577,7 @@ Info for any orders that were accepted. • **fillableTakerAssetAmount**: *BigNumber* -*Defined in [types.ts:608](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L608)* +*Defined in [types.ts:608](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L608)* ___ @@ -585,7 +585,7 @@ ___ • **isNew**: *boolean* -*Defined in [types.ts:609](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L609)* +*Defined in [types.ts:609](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L609)* ___ @@ -593,7 +593,7 @@ ___ • **orderHash**: *string* -*Defined in [types.ts:606](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L606)* +*Defined in [types.ts:606](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L606)* ___ @@ -601,7 +601,7 @@ ___ • **signedOrder**: *SignedOrder* -*Defined in [types.ts:607](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L607)* +*Defined in [types.ts:607](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L607)*
@@ -621,7 +621,7 @@ A set of configuration options for Mesh. • **blockPollingIntervalSeconds**? : *undefined | number* -*Defined in [types.ts:118](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L118)* +*Defined in [types.ts:118](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L118)* ___ @@ -629,7 +629,7 @@ ___ • **bootstrapList**? : *string[]* -*Defined in [types.ts:111](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L111)* +*Defined in [types.ts:111](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L111)* ___ @@ -637,7 +637,7 @@ ___ • **customContractAddresses**? : *[ContractAddresses](#interface-contractaddresses)* -*Defined in [types.ts:162](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L162)* +*Defined in [types.ts:162](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L162)* ___ @@ -645,7 +645,7 @@ ___ • **customOrderFilter**? : *[JsonSchema](#interface-jsonschema)* -*Defined in [types.ts:187](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L187)* +*Defined in [types.ts:187](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L187)* ___ @@ -653,7 +653,7 @@ ___ • **enableEthereumRPCRateLimiting**? : *undefined | false | true* -*Defined in [types.ts:135](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L135)* +*Defined in [types.ts:135](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L135)* ___ @@ -661,7 +661,7 @@ ___ • **ethereumChainID**: *number* -*Defined in [types.ts:103](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L103)* +*Defined in [types.ts:103](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L103)* ___ @@ -669,7 +669,7 @@ ___ • **ethereumRPCMaxContentLength**? : *undefined | number* -*Defined in [types.ts:127](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L127)* +*Defined in [types.ts:127](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L127)* ___ @@ -677,7 +677,7 @@ ___ • **ethereumRPCMaxRequestsPer24HrUTC**? : *undefined | number* -*Defined in [types.ts:140](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L140)* +*Defined in [types.ts:140](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L140)* ___ @@ -685,7 +685,7 @@ ___ • **ethereumRPCMaxRequestsPerSecond**? : *undefined | number* -*Defined in [types.ts:146](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L146)* +*Defined in [types.ts:146](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L146)* ___ @@ -693,7 +693,7 @@ ___ • **ethereumRPCURL**? : *undefined | string* -*Defined in [types.ts:100](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L100)* +*Defined in [types.ts:100](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L100)* ___ @@ -701,7 +701,7 @@ ___ • **maxOrdersInStorage**? : *undefined | number* -*Defined in [types.ts:167](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L167)* +*Defined in [types.ts:167](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L167)* ___ @@ -709,7 +709,7 @@ ___ • **useBootstrapList**? : *undefined | false | true* -*Defined in [types.ts:106](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L106)* +*Defined in [types.ts:106](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L106)* ___ @@ -717,7 +717,7 @@ ___ • **verbosity**? : *[Verbosity](#enumeration-verbosity)* -*Defined in [types.ts:97](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L97)* +*Defined in [types.ts:97](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L97)* ___ @@ -725,7 +725,7 @@ ___ • **web3Provider**? : *SupportedProvider* -*Defined in [types.ts:190](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L190)* +*Defined in [types.ts:190](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L190)*
@@ -743,7 +743,7 @@ ___ • **coordinator**? : *undefined | string* -*Defined in [types.ts:199](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L199)* +*Defined in [types.ts:199](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L199)* ___ @@ -751,7 +751,7 @@ ___ • **coordinatorRegistry**? : *undefined | string* -*Defined in [types.ts:200](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L200)* +*Defined in [types.ts:200](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L200)* ___ @@ -759,7 +759,7 @@ ___ • **devUtils**: *string* -*Defined in [types.ts:195](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L195)* +*Defined in [types.ts:195](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L195)* ___ @@ -767,7 +767,7 @@ ___ • **erc1155Proxy**: *string* -*Defined in [types.ts:198](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L198)* +*Defined in [types.ts:198](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L198)* ___ @@ -775,7 +775,7 @@ ___ • **erc20Proxy**: *string* -*Defined in [types.ts:196](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L196)* +*Defined in [types.ts:196](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L196)* ___ @@ -783,7 +783,7 @@ ___ • **erc721Proxy**: *string* -*Defined in [types.ts:197](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L197)* +*Defined in [types.ts:197](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L197)* ___ @@ -791,7 +791,7 @@ ___ • **exchange**: *string* -*Defined in [types.ts:194](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L194)* +*Defined in [types.ts:194](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L194)* ___ @@ -799,7 +799,7 @@ ___ • **weth9**? : *undefined | string* -*Defined in [types.ts:201](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L201)* +*Defined in [types.ts:201](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L201)* ___ @@ -807,7 +807,7 @@ ___ • **zrxToken**? : *undefined | string* -*Defined in [types.ts:202](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L202)* +*Defined in [types.ts:202](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L202)*
@@ -825,7 +825,7 @@ ___ • **address**: *string* -*Defined in [types.ts:516](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L516)* +*Defined in [types.ts:516](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L516)* ___ @@ -833,7 +833,7 @@ ___ • **blockHash**: *string* -*Defined in [types.ts:511](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L511)* +*Defined in [types.ts:511](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L511)* ___ @@ -841,7 +841,7 @@ ___ • **isRemoved**: *boolean* -*Defined in [types.ts:515](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L515)* +*Defined in [types.ts:515](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L515)* ___ @@ -849,7 +849,7 @@ ___ • **kind**: *[ContractEventKind](#enumeration-contracteventkind)* -*Defined in [types.ts:517](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L517)* +*Defined in [types.ts:517](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L517)* ___ @@ -857,7 +857,7 @@ ___ • **logIndex**: *number* -*Defined in [types.ts:514](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L514)* +*Defined in [types.ts:514](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L514)* ___ @@ -865,7 +865,7 @@ ___ • **parameters**: *ContractEventParameters* -*Defined in [types.ts:518](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L518)* +*Defined in [types.ts:518](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L518)* ___ @@ -873,7 +873,7 @@ ___ • **txHash**: *string* -*Defined in [types.ts:512](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L512)* +*Defined in [types.ts:512](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L512)* ___ @@ -881,7 +881,7 @@ ___ • **txIndex**: *number* -*Defined in [types.ts:513](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L513)* +*Defined in [types.ts:513](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L513)*
@@ -899,7 +899,7 @@ ___ • **approved**: *boolean* -*Defined in [types.ts:380](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L380)* +*Defined in [types.ts:380](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L380)* ___ @@ -907,7 +907,7 @@ ___ • **operator**: *string* -*Defined in [types.ts:379](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L379)* +*Defined in [types.ts:379](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L379)* ___ @@ -915,7 +915,7 @@ ___ • **owner**: *string* -*Defined in [types.ts:378](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L378)* +*Defined in [types.ts:378](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L378)*
@@ -933,7 +933,7 @@ ___ • **from**: *string* -*Defined in [types.ts:362](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L362)* +*Defined in [types.ts:362](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L362)* ___ @@ -941,7 +941,7 @@ ___ • **ids**: *BigNumber[]* -*Defined in [types.ts:364](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L364)* +*Defined in [types.ts:364](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L364)* ___ @@ -949,7 +949,7 @@ ___ • **operator**: *string* -*Defined in [types.ts:361](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L361)* +*Defined in [types.ts:361](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L361)* ___ @@ -957,7 +957,7 @@ ___ • **to**: *string* -*Defined in [types.ts:363](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L363)* +*Defined in [types.ts:363](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L363)* ___ @@ -965,7 +965,7 @@ ___ • **values**: *BigNumber[]* -*Defined in [types.ts:365](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L365)* +*Defined in [types.ts:365](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L365)*
@@ -983,7 +983,7 @@ ___ • **from**: *string* -*Defined in [types.ts:345](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L345)* +*Defined in [types.ts:345](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L345)* ___ @@ -991,7 +991,7 @@ ___ • **id**: *BigNumber* -*Defined in [types.ts:347](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L347)* +*Defined in [types.ts:347](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L347)* ___ @@ -999,7 +999,7 @@ ___ • **operator**: *string* -*Defined in [types.ts:344](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L344)* +*Defined in [types.ts:344](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L344)* ___ @@ -1007,7 +1007,7 @@ ___ • **to**: *string* -*Defined in [types.ts:346](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L346)* +*Defined in [types.ts:346](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L346)* ___ @@ -1015,7 +1015,7 @@ ___ • **value**: *BigNumber* -*Defined in [types.ts:348](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L348)* +*Defined in [types.ts:348](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L348)*
@@ -1033,7 +1033,7 @@ ___ • **owner**: *string* -*Defined in [types.ts:299](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L299)* +*Defined in [types.ts:299](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L299)* ___ @@ -1041,7 +1041,7 @@ ___ • **spender**: *string* -*Defined in [types.ts:300](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L300)* +*Defined in [types.ts:300](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L300)* ___ @@ -1049,7 +1049,7 @@ ___ • **value**: *BigNumber* -*Defined in [types.ts:301](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L301)* +*Defined in [types.ts:301](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L301)*
@@ -1067,7 +1067,7 @@ ___ • **from**: *string* -*Defined in [types.ts:286](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L286)* +*Defined in [types.ts:286](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L286)* ___ @@ -1075,7 +1075,7 @@ ___ • **to**: *string* -*Defined in [types.ts:287](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L287)* +*Defined in [types.ts:287](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L287)* ___ @@ -1083,7 +1083,7 @@ ___ • **value**: *BigNumber* -*Defined in [types.ts:288](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L288)* +*Defined in [types.ts:288](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L288)*
@@ -1101,7 +1101,7 @@ ___ • **approved**: *string* -*Defined in [types.ts:326](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L326)* +*Defined in [types.ts:326](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L326)* ___ @@ -1109,7 +1109,7 @@ ___ • **owner**: *string* -*Defined in [types.ts:325](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L325)* +*Defined in [types.ts:325](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L325)* ___ @@ -1117,7 +1117,7 @@ ___ • **tokenId**: *BigNumber* -*Defined in [types.ts:327](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L327)* +*Defined in [types.ts:327](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L327)*
@@ -1135,7 +1135,7 @@ ___ • **approved**: *boolean* -*Defined in [types.ts:340](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L340)* +*Defined in [types.ts:340](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L340)* ___ @@ -1143,7 +1143,7 @@ ___ • **operator**: *string* -*Defined in [types.ts:339](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L339)* +*Defined in [types.ts:339](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L339)* ___ @@ -1151,7 +1151,7 @@ ___ • **owner**: *string* -*Defined in [types.ts:338](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L338)* +*Defined in [types.ts:338](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L338)*
@@ -1169,7 +1169,7 @@ ___ • **from**: *string* -*Defined in [types.ts:312](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L312)* +*Defined in [types.ts:312](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L312)* ___ @@ -1177,7 +1177,7 @@ ___ • **to**: *string* -*Defined in [types.ts:313](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L313)* +*Defined in [types.ts:313](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L313)* ___ @@ -1185,7 +1185,7 @@ ___ • **tokenId**: *BigNumber* -*Defined in [types.ts:314](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L314)* +*Defined in [types.ts:314](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L314)*
@@ -1203,7 +1203,7 @@ ___ • **feeRecipientAddress**: *string* -*Defined in [types.ts:421](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L421)* +*Defined in [types.ts:421](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L421)* ___ @@ -1211,7 +1211,7 @@ ___ • **makerAddress**: *string* -*Defined in [types.ts:419](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L419)* +*Defined in [types.ts:419](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L419)* ___ @@ -1219,7 +1219,7 @@ ___ • **makerAssetData**: *string* -*Defined in [types.ts:423](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L423)* +*Defined in [types.ts:423](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L423)* ___ @@ -1227,7 +1227,7 @@ ___ • **orderHash**: *string* -*Defined in [types.ts:422](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L422)* +*Defined in [types.ts:422](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L422)* ___ @@ -1235,7 +1235,7 @@ ___ • **senderAddress**: *string* -*Defined in [types.ts:420](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L420)* +*Defined in [types.ts:420](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L420)* ___ @@ -1243,7 +1243,7 @@ ___ • **takerAssetData**: *string* -*Defined in [types.ts:424](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L424)* +*Defined in [types.ts:424](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L424)*
@@ -1261,7 +1261,7 @@ ___ • **makerAddress**: *string* -*Defined in [types.ts:428](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L428)* +*Defined in [types.ts:428](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L428)* ___ @@ -1269,7 +1269,7 @@ ___ • **orderEpoch**: *BigNumber* -*Defined in [types.ts:430](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L430)* +*Defined in [types.ts:430](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L430)* ___ @@ -1277,7 +1277,7 @@ ___ • **orderSenderAddress**: *string* -*Defined in [types.ts:429](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L429)* +*Defined in [types.ts:429](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L429)*
@@ -1295,7 +1295,7 @@ ___ • **feeRecipientAddress**: *string* -*Defined in [types.ts:387](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L387)* +*Defined in [types.ts:387](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L387)* ___ @@ -1303,7 +1303,7 @@ ___ • **makerAddress**: *string* -*Defined in [types.ts:384](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L384)* +*Defined in [types.ts:384](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L384)* ___ @@ -1311,7 +1311,7 @@ ___ • **makerAssetData**: *string* -*Defined in [types.ts:394](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L394)* +*Defined in [types.ts:394](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L394)* ___ @@ -1319,7 +1319,7 @@ ___ • **makerAssetFilledAmount**: *BigNumber* -*Defined in [types.ts:388](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L388)* +*Defined in [types.ts:388](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L388)* ___ @@ -1327,7 +1327,7 @@ ___ • **makerFeeAssetData**: *string* -*Defined in [types.ts:396](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L396)* +*Defined in [types.ts:396](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L396)* ___ @@ -1335,7 +1335,7 @@ ___ • **makerFeePaid**: *BigNumber* -*Defined in [types.ts:390](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L390)* +*Defined in [types.ts:390](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L390)* ___ @@ -1343,7 +1343,7 @@ ___ • **orderHash**: *string* -*Defined in [types.ts:393](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L393)* +*Defined in [types.ts:393](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L393)* ___ @@ -1351,7 +1351,7 @@ ___ • **protocolFeePaid**: *BigNumber* -*Defined in [types.ts:392](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L392)* +*Defined in [types.ts:392](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L392)* ___ @@ -1359,7 +1359,7 @@ ___ • **senderAddress**: *string* -*Defined in [types.ts:386](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L386)* +*Defined in [types.ts:386](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L386)* ___ @@ -1367,7 +1367,7 @@ ___ • **takerAddress**: *string* -*Defined in [types.ts:385](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L385)* +*Defined in [types.ts:385](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L385)* ___ @@ -1375,7 +1375,7 @@ ___ • **takerAssetData**: *string* -*Defined in [types.ts:395](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L395)* +*Defined in [types.ts:395](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L395)* ___ @@ -1383,7 +1383,7 @@ ___ • **takerAssetFilledAmount**: *BigNumber* -*Defined in [types.ts:389](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L389)* +*Defined in [types.ts:389](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L389)* ___ @@ -1391,7 +1391,7 @@ ___ • **takerFeeAssetData**: *string* -*Defined in [types.ts:397](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L397)* +*Defined in [types.ts:397](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L397)* ___ @@ -1399,7 +1399,7 @@ ___ • **takerFeePaid**: *BigNumber* -*Defined in [types.ts:391](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L391)* +*Defined in [types.ts:391](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L391)*
@@ -1417,7 +1417,7 @@ ___ • **ordersInfos**: *[OrderInfo](#interface-orderinfo)[]* -*Defined in [types.ts:19](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L19)* +*Defined in [types.ts:19](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L19)* ___ @@ -1425,7 +1425,7 @@ ___ • **snapshotID**: *string* -*Defined in [types.ts:17](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L17)* +*Defined in [types.ts:17](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L17)* ___ @@ -1433,7 +1433,7 @@ ___ • **snapshotTimestamp**: *number* -*Defined in [types.ts:18](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L18)* +*Defined in [types.ts:18](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L18)*
@@ -1453,7 +1453,7 @@ An interface for JSON schema types, which are used for custom order filters. • **$ref**? : *undefined | string* -*Defined in [types.ts:41](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L41)* +*Defined in [types.ts:41](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L41)* ___ @@ -1461,7 +1461,7 @@ ___ • **$schema**? : *undefined | string* -*Defined in [types.ts:40](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L40)* +*Defined in [types.ts:40](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L40)* ___ @@ -1469,7 +1469,7 @@ ___ • **additionalItems**? : *boolean | [JsonSchema](#interface-jsonschema)* -*Defined in [types.ts:52](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L52)* +*Defined in [types.ts:52](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L52)* ___ @@ -1477,7 +1477,7 @@ ___ • **additionalProperties**? : *boolean | [JsonSchema](#interface-jsonschema)* -*Defined in [types.ts:60](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L60)* +*Defined in [types.ts:60](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L60)* ___ @@ -1485,7 +1485,7 @@ ___ • **allOf**? : *[JsonSchema](#interface-jsonschema)[]* -*Defined in [types.ts:82](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L82)* +*Defined in [types.ts:82](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L82)* ___ @@ -1493,7 +1493,7 @@ ___ • **anyOf**? : *[JsonSchema](#interface-jsonschema)[]* -*Defined in [types.ts:83](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L83)* +*Defined in [types.ts:83](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L83)* ___ @@ -1501,7 +1501,7 @@ ___ • **const**? : *any* -*Defined in [types.ts:79](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L79)* +*Defined in [types.ts:79](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L79)* ___ @@ -1509,7 +1509,7 @@ ___ • **definitions**? : *undefined | object* -*Defined in [types.ts:61](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L61)* +*Defined in [types.ts:61](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L61)* ___ @@ -1517,7 +1517,7 @@ ___ • **dependencies**? : *undefined | object* -*Defined in [types.ts:70](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L70)* +*Defined in [types.ts:70](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L70)* ___ @@ -1525,7 +1525,7 @@ ___ • **description**? : *undefined | string* -*Defined in [types.ts:43](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L43)* +*Defined in [types.ts:43](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L43)* ___ @@ -1533,7 +1533,7 @@ ___ • **enum**? : *any[]* -*Defined in [types.ts:73](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L73)* +*Defined in [types.ts:73](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L73)* ___ @@ -1541,7 +1541,7 @@ ___ • **exclusiveMaximum**? : *undefined | false | true* -*Defined in [types.ts:46](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L46)* +*Defined in [types.ts:46](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L46)* ___ @@ -1549,7 +1549,7 @@ ___ • **exclusiveMinimum**? : *undefined | false | true* -*Defined in [types.ts:48](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L48)* +*Defined in [types.ts:48](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L48)* ___ @@ -1557,7 +1557,7 @@ ___ • **format**? : *undefined | string* -*Defined in [types.ts:81](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L81)* +*Defined in [types.ts:81](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L81)* ___ @@ -1565,7 +1565,7 @@ ___ • **id**? : *undefined | string* -*Defined in [types.ts:39](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L39)* +*Defined in [types.ts:39](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L39)* ___ @@ -1573,7 +1573,7 @@ ___ • **items**? : *[JsonSchema](#interface-jsonschema) | [JsonSchema](#interface-jsonschema)[]* -*Defined in [types.ts:53](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L53)* +*Defined in [types.ts:53](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L53)* ___ @@ -1581,7 +1581,7 @@ ___ • **maxItems**? : *undefined | number* -*Defined in [types.ts:54](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L54)* +*Defined in [types.ts:54](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L54)* ___ @@ -1589,7 +1589,7 @@ ___ • **maxLength**? : *undefined | number* -*Defined in [types.ts:49](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L49)* +*Defined in [types.ts:49](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L49)* ___ @@ -1597,7 +1597,7 @@ ___ • **maxProperties**? : *undefined | number* -*Defined in [types.ts:57](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L57)* +*Defined in [types.ts:57](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L57)* ___ @@ -1605,7 +1605,7 @@ ___ • **maximum**? : *undefined | number* -*Defined in [types.ts:45](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L45)* +*Defined in [types.ts:45](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L45)* ___ @@ -1613,7 +1613,7 @@ ___ • **minItems**? : *undefined | number* -*Defined in [types.ts:55](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L55)* +*Defined in [types.ts:55](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L55)* ___ @@ -1621,7 +1621,7 @@ ___ • **minLength**? : *undefined | number* -*Defined in [types.ts:50](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L50)* +*Defined in [types.ts:50](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L50)* ___ @@ -1629,7 +1629,7 @@ ___ • **minProperties**? : *undefined | number* -*Defined in [types.ts:58](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L58)* +*Defined in [types.ts:58](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L58)* ___ @@ -1637,7 +1637,7 @@ ___ • **minimum**? : *undefined | number* -*Defined in [types.ts:47](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L47)* +*Defined in [types.ts:47](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L47)* ___ @@ -1645,7 +1645,7 @@ ___ • **multipleOf**? : *undefined | number* -*Defined in [types.ts:44](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L44)* +*Defined in [types.ts:44](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L44)* ___ @@ -1653,7 +1653,7 @@ ___ • **not**? : *[JsonSchema](#interface-jsonschema)* -*Defined in [types.ts:85](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L85)* +*Defined in [types.ts:85](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L85)* ___ @@ -1661,7 +1661,7 @@ ___ • **oneOf**? : *[JsonSchema](#interface-jsonschema)[]* -*Defined in [types.ts:84](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L84)* +*Defined in [types.ts:84](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L84)* ___ @@ -1669,7 +1669,7 @@ ___ • **pattern**? : *string | RegExp* -*Defined in [types.ts:51](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L51)* +*Defined in [types.ts:51](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L51)* ___ @@ -1677,7 +1677,7 @@ ___ • **patternProperties**? : *undefined | object* -*Defined in [types.ts:67](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L67)* +*Defined in [types.ts:67](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L67)* ___ @@ -1685,7 +1685,7 @@ ___ • **properties**? : *undefined | object* -*Defined in [types.ts:64](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L64)* +*Defined in [types.ts:64](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L64)* ___ @@ -1693,7 +1693,7 @@ ___ • **required**? : *string[]* -*Defined in [types.ts:59](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L59)* +*Defined in [types.ts:59](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L59)* ___ @@ -1701,7 +1701,7 @@ ___ • **title**? : *undefined | string* -*Defined in [types.ts:42](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L42)* +*Defined in [types.ts:42](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L42)* ___ @@ -1709,7 +1709,7 @@ ___ • **type**? : *string | string[]* -*Defined in [types.ts:80](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L80)* +*Defined in [types.ts:80](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L80)* ___ @@ -1717,7 +1717,7 @@ ___ • **uniqueItems**? : *undefined | false | true* -*Defined in [types.ts:56](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L56)* +*Defined in [types.ts:56](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L56)*
@@ -1735,7 +1735,7 @@ ___ • **hash**: *string* -*Defined in [types.ts:643](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L643)* +*Defined in [types.ts:643](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L643)* ___ @@ -1743,7 +1743,7 @@ ___ • **number**: *number* -*Defined in [types.ts:642](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L642)* +*Defined in [types.ts:642](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L642)*
@@ -1764,7 +1764,7 @@ or filled. • **contractEvents**: *[ContractEvent](#interface-contractevent)[]* -*Defined in [types.ts:569](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L569)* +*Defined in [types.ts:569](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L569)* ___ @@ -1772,7 +1772,7 @@ ___ • **endState**: *[OrderEventEndState](#enumeration-ordereventendstate)* -*Defined in [types.ts:567](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L567)* +*Defined in [types.ts:567](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L567)* ___ @@ -1780,7 +1780,7 @@ ___ • **fillableTakerAssetAmount**: *BigNumber* -*Defined in [types.ts:568](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L568)* +*Defined in [types.ts:568](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L568)* ___ @@ -1788,7 +1788,7 @@ ___ • **orderHash**: *string* -*Defined in [types.ts:565](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L565)* +*Defined in [types.ts:565](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L565)* ___ @@ -1796,7 +1796,7 @@ ___ • **signedOrder**: *SignedOrder* -*Defined in [types.ts:566](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L566)* +*Defined in [types.ts:566](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L566)* ___ @@ -1804,7 +1804,7 @@ ___ • **timestampMs**: *number* -*Defined in [types.ts:564](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L564)* +*Defined in [types.ts:564](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L564)*
@@ -1822,7 +1822,7 @@ ___ • **fillableTakerAssetAmount**: *BigNumber* -*Defined in [types.ts:32](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L32)* +*Defined in [types.ts:32](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L32)* ___ @@ -1830,7 +1830,7 @@ ___ • **orderHash**: *string* -*Defined in [types.ts:30](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L30)* +*Defined in [types.ts:30](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L30)* ___ @@ -1838,7 +1838,7 @@ ___ • **signedOrder**: *SignedOrder* -*Defined in [types.ts:31](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L31)* +*Defined in [types.ts:31](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L31)*
@@ -1859,7 +1859,7 @@ rejected. • **kind**: *[RejectedOrderKind](#enumeration-rejectedorderkind)* -*Defined in [types.ts:619](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L619)* +*Defined in [types.ts:619](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L619)* ___ @@ -1867,7 +1867,7 @@ ___ • **orderHash**: *string* -*Defined in [types.ts:617](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L617)* +*Defined in [types.ts:617](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L617)* ___ @@ -1875,7 +1875,7 @@ ___ • **signedOrder**: *SignedOrder* -*Defined in [types.ts:618](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L618)* +*Defined in [types.ts:618](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L618)* ___ @@ -1883,7 +1883,7 @@ ___ • **status**: *[RejectedOrderStatus](#interface-rejectedorderstatus)* -*Defined in [types.ts:620](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L620)* +*Defined in [types.ts:620](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L620)*
@@ -1903,7 +1903,7 @@ Provides more information about why an order was rejected. • **code**: *string* -*Defined in [types.ts:637](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L637)* +*Defined in [types.ts:637](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L637)* ___ @@ -1911,7 +1911,7 @@ ___ • **message**: *string* -*Defined in [types.ts:638](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L638)* +*Defined in [types.ts:638](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L638)*
@@ -1929,7 +1929,7 @@ ___ • **ethRPCRateLimitExpiredRequests**: *number* -*Defined in [types.ts:680](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L680)* +*Defined in [types.ts:680](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L680)* ___ @@ -1937,7 +1937,7 @@ ___ • **ethRPCRequestsSentInCurrentUTCDay**: *number* -*Defined in [types.ts:679](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L679)* +*Defined in [types.ts:679](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L679)* ___ @@ -1945,7 +1945,7 @@ ___ • **ethereumChainID**: *number* -*Defined in [types.ts:671](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L671)* +*Defined in [types.ts:671](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L671)* ___ @@ -1953,7 +1953,7 @@ ___ • **latestBlock**: *[LatestBlock](#interface-latestblock)* -*Defined in [types.ts:672](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L672)* +*Defined in [types.ts:672](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L672)* ___ @@ -1961,7 +1961,7 @@ ___ • **maxExpirationTime**: *BigNumber* -*Defined in [types.ts:677](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L677)* +*Defined in [types.ts:677](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L677)* ___ @@ -1969,7 +1969,7 @@ ___ • **numOrders**: *number* -*Defined in [types.ts:674](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L674)* +*Defined in [types.ts:674](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L674)* ___ @@ -1977,7 +1977,7 @@ ___ • **numOrdersIncludingRemoved**: *number* -*Defined in [types.ts:675](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L675)* +*Defined in [types.ts:675](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L675)* ___ @@ -1985,7 +1985,7 @@ ___ • **numPeers**: *number* -*Defined in [types.ts:673](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L673)* +*Defined in [types.ts:673](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L673)* ___ @@ -1993,7 +1993,7 @@ ___ • **numPinnedOrders**: *number* -*Defined in [types.ts:676](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L676)* +*Defined in [types.ts:676](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L676)* ___ @@ -2001,7 +2001,7 @@ ___ • **peerID**: *string* -*Defined in [types.ts:670](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L670)* +*Defined in [types.ts:670](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L670)* ___ @@ -2009,7 +2009,7 @@ ___ • **pubSubTopic**: *string* -*Defined in [types.ts:667](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L667)* +*Defined in [types.ts:667](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L667)* ___ @@ -2017,7 +2017,7 @@ ___ • **rendezvous**: *string* -*Defined in [types.ts:668](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L668)* +*Defined in [types.ts:668](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L668)* ___ @@ -2025,7 +2025,7 @@ ___ • **secondaryRendezvous**: *string[]* -*Defined in [types.ts:669](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L669)* +*Defined in [types.ts:669](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L669)* ___ @@ -2033,7 +2033,7 @@ ___ • **startOfCurrentUTCDay**: *Date* -*Defined in [types.ts:678](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L678)* +*Defined in [types.ts:678](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L678)* ___ @@ -2041,7 +2041,7 @@ ___ • **version**: *string* -*Defined in [types.ts:666](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L666)* +*Defined in [types.ts:666](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L666)*
@@ -2061,7 +2061,7 @@ Indicates which orders where accepted, which were rejected, and why. • **accepted**: *[AcceptedOrderInfo](#interface-acceptedorderinfo)[]* -*Defined in [types.ts:598](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L598)* +*Defined in [types.ts:598](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L598)* ___ @@ -2069,7 +2069,7 @@ ___ • **rejected**: *[RejectedOrderInfo](#interface-rejectedorderinfo)[]* -*Defined in [types.ts:599](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L599)* +*Defined in [types.ts:599](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L599)*
@@ -2087,7 +2087,7 @@ ___ • **owner**: *string* -*Defined in [types.ts:452](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L452)* +*Defined in [types.ts:452](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L452)* ___ @@ -2095,7 +2095,7 @@ ___ • **value**: *BigNumber* -*Defined in [types.ts:453](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L453)* +*Defined in [types.ts:453](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L453)*
@@ -2113,7 +2113,7 @@ ___ • **owner**: *string* -*Defined in [types.ts:441](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L441)* +*Defined in [types.ts:441](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L441)* ___ @@ -2121,7 +2121,7 @@ ___ • **value**: *BigNumber* -*Defined in [types.ts:442](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/browser-lite/src/types.ts#L442)* +*Defined in [types.ts:442](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/browser-lite/src/types.ts#L442)*
diff --git a/docs/deployment.md b/docs/deployment.md index 0f880ed9b..07fcc2150 100644 --- a/docs/deployment.md +++ b/docs/deployment.md @@ -1,4 +1,4 @@ -[![Version](https://img.shields.io/badge/version-9.4.1-orange.svg)](https://github.com/0xProject/0x-mesh/releases) +[![Version](https://img.shields.io/badge/version-9.4.2-orange.svg)](https://github.com/0xProject/0x-mesh/releases) # 0x Mesh Deployment Guide diff --git a/docs/deployment_with_telemetry.md b/docs/deployment_with_telemetry.md index f59f7885f..171e4596c 100644 --- a/docs/deployment_with_telemetry.md +++ b/docs/deployment_with_telemetry.md @@ -1,4 +1,4 @@ -[![Version](https://img.shields.io/badge/version-9.4.1-orange.svg)](https://github.com/0xProject/0x-mesh/releases) +[![Version](https://img.shields.io/badge/version-9.4.2-orange.svg)](https://github.com/0xProject/0x-mesh/releases) ## Deploying a Telemetry-Enabled Mesh Node diff --git a/docs/json_rpc_clients/typescript/README.md b/docs/json_rpc_clients/typescript/README.md index d1a4108ac..6d59d7854 100644 --- a/docs/json_rpc_clients/typescript/README.md +++ b/docs/json_rpc_clients/typescript/README.md @@ -1,4 +1,4 @@ -# @0x/mesh-rpc-client - v9.4.1 +# @0x/mesh-rpc-client - v9.4.2 ## @0x/mesh-rpc-client diff --git a/docs/json_rpc_clients/typescript/reference.md b/docs/json_rpc_clients/typescript/reference.md index 2ff1acc43..a2a114bed 100644 --- a/docs/json_rpc_clients/typescript/reference.md +++ b/docs/json_rpc_clients/typescript/reference.md @@ -31,7 +31,7 @@ websocket endpoint. \+ **new WSClient**(`url`: string, `wsOpts?`: [WSOpts](#interface-wsopts)): *[WSClient](#class-wsclient)* -*Defined in [ws_client.ts:252](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/ws_client.ts#L252)* +*Defined in [ws_client.ts:252](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/ws_client.ts#L252)* Instantiates a new WSClient instance @@ -52,7 +52,7 @@ An instance of WSClient ▸ **addOrdersAsync**(`signedOrders`: SignedOrder[], `pinned`: boolean): *Promise‹[ValidationResults](#interface-validationresults)›* -*Defined in [ws_client.ts:281](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/ws_client.ts#L281)* +*Defined in [ws_client.ts:281](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/ws_client.ts#L281)* Adds an array of 0x signed orders to the Mesh node. @@ -73,7 +73,7 @@ ___ ▸ **destroy**(): *void* -*Defined in [ws_client.ts:421](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/ws_client.ts#L421)* +*Defined in [ws_client.ts:421](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/ws_client.ts#L421)* destroy unsubscribes all active subscriptions, closes the websocket connection and stops the internal heartbeat connection liveness check. @@ -86,7 +86,7 @@ ___ ▸ **getOrdersAsync**(`perPage`: number): *Promise‹[GetOrdersResponse](#interface-getordersresponse)›* -*Defined in [ws_client.ts:311](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/ws_client.ts#L311)* +*Defined in [ws_client.ts:311](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/ws_client.ts#L311)* Get all 0x signed orders currently stored in the Mesh node @@ -106,7 +106,7 @@ ___ ▸ **getOrdersForPageAsync**(`page`: number, `perPage`: number, `snapshotID?`: undefined | string): *Promise‹[GetOrdersResponse](#interface-getordersresponse)›* -*Defined in [ws_client.ts:342](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/ws_client.ts#L342)* +*Defined in [ws_client.ts:342](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/ws_client.ts#L342)* Get page of 0x signed orders stored on the Mesh node at the specified snapshot @@ -128,7 +128,7 @@ ___ ▸ **getStatsAsync**(): *Promise‹[GetStatsResponse](#interface-getstatsresponse)›* -*Defined in [ws_client.ts:302](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/ws_client.ts#L302)* +*Defined in [ws_client.ts:302](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/ws_client.ts#L302)* **Returns:** *Promise‹[GetStatsResponse](#interface-getstatsresponse)›* @@ -138,7 +138,7 @@ ___ ▸ **onClose**(`cb`: function): *void* -*Defined in [ws_client.ts:403](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/ws_client.ts#L403)* +*Defined in [ws_client.ts:403](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/ws_client.ts#L403)* Get notified when the underlying WS connection closes normally. If it closes with an error, WSClient automatically attempts to re-connect without emitting a `close` event. @@ -159,7 +159,7 @@ ___ ▸ **onReconnected**(`cb`: function): *void* -*Defined in [ws_client.ts:412](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/ws_client.ts#L412)* +*Defined in [ws_client.ts:412](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/ws_client.ts#L412)* Get notified when a connection to the underlying WS connection is re-established @@ -179,7 +179,7 @@ ___ ▸ **subscribeToOrdersAsync**(`cb`: function): *Promise‹string›* -*Defined in [ws_client.ts:363](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/ws_client.ts#L363)* +*Defined in [ws_client.ts:363](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/ws_client.ts#L363)* Subscribe to the 'orders' topic and receive order events from Mesh. This method returns a subscriptionId that can be used to `unsubscribe()` from this subscription. @@ -208,7 +208,7 @@ ___ ▸ **unsubscribeAsync**(`subscriptionId`: string): *Promise‹void›* -*Defined in [ws_client.ts:393](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/ws_client.ts#L393)* +*Defined in [ws_client.ts:393](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/ws_client.ts#L393)* Unsubscribe from a subscription @@ -249,7 +249,7 @@ Name | Type | Description | • **ERC1155ApprovalForAllEvent**: = "ERC1155ApprovalForAllEvent" -*Defined in [types.ts:222](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L222)* +*Defined in [types.ts:222](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L222)* ___ @@ -257,7 +257,7 @@ ___ • **ERC1155TransferBatchEvent**: = "ERC1155TransferBatchEvent" -*Defined in [types.ts:224](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L224)* +*Defined in [types.ts:224](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L224)* ___ @@ -265,7 +265,7 @@ ___ • **ERC1155TransferSingleEvent**: = "ERC1155TransferSingleEvent" -*Defined in [types.ts:223](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L223)* +*Defined in [types.ts:223](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L223)* ___ @@ -273,7 +273,7 @@ ___ • **ERC20ApprovalEvent**: = "ERC20ApprovalEvent" -*Defined in [types.ts:218](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L218)* +*Defined in [types.ts:218](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L218)* ___ @@ -281,7 +281,7 @@ ___ • **ERC20TransferEvent**: = "ERC20TransferEvent" -*Defined in [types.ts:217](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L217)* +*Defined in [types.ts:217](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L217)* ___ @@ -289,7 +289,7 @@ ___ • **ERC721ApprovalEvent**: = "ERC721ApprovalEvent" -*Defined in [types.ts:220](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L220)* +*Defined in [types.ts:220](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L220)* ___ @@ -297,7 +297,7 @@ ___ • **ERC721ApprovalForAllEvent**: = "ERC721ApprovalForAllEvent" -*Defined in [types.ts:221](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L221)* +*Defined in [types.ts:221](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L221)* ___ @@ -305,7 +305,7 @@ ___ • **ERC721TransferEvent**: = "ERC721TransferEvent" -*Defined in [types.ts:219](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L219)* +*Defined in [types.ts:219](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L219)* ___ @@ -313,7 +313,7 @@ ___ • **ExchangeCancelEvent**: = "ExchangeCancelEvent" -*Defined in [types.ts:226](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L226)* +*Defined in [types.ts:226](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L226)* ___ @@ -321,7 +321,7 @@ ___ • **ExchangeCancelUpToEvent**: = "ExchangeCancelUpToEvent" -*Defined in [types.ts:227](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L227)* +*Defined in [types.ts:227](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L227)* ___ @@ -329,7 +329,7 @@ ___ • **ExchangeFillEvent**: = "ExchangeFillEvent" -*Defined in [types.ts:225](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L225)* +*Defined in [types.ts:225](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L225)* ___ @@ -337,7 +337,7 @@ ___ • **WethDepositEvent**: = "WethDepositEvent" -*Defined in [types.ts:228](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L228)* +*Defined in [types.ts:228](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L228)* ___ @@ -345,7 +345,7 @@ ___ • **WethWithdrawalEvent**: = "WethWithdrawalEvent" -*Defined in [types.ts:229](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L229)* +*Defined in [types.ts:229](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L229)*
@@ -373,7 +373,7 @@ ___ • **Added**: = "ADDED" -*Defined in [types.ts:286](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L286)* +*Defined in [types.ts:286](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L286)* ___ @@ -381,7 +381,7 @@ ___ • **Cancelled**: = "CANCELLED" -*Defined in [types.ts:289](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L289)* +*Defined in [types.ts:289](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L289)* ___ @@ -389,7 +389,7 @@ ___ • **Expired**: = "EXPIRED" -*Defined in [types.ts:290](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L290)* +*Defined in [types.ts:290](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L290)* ___ @@ -397,7 +397,7 @@ ___ • **FillabilityIncreased**: = "FILLABILITY_INCREASED" -*Defined in [types.ts:294](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L294)* +*Defined in [types.ts:294](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L294)* ___ @@ -405,7 +405,7 @@ ___ • **Filled**: = "FILLED" -*Defined in [types.ts:287](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L287)* +*Defined in [types.ts:287](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L287)* ___ @@ -413,7 +413,7 @@ ___ • **FullyFilled**: = "FULLY_FILLED" -*Defined in [types.ts:288](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L288)* +*Defined in [types.ts:288](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L288)* ___ @@ -421,7 +421,7 @@ ___ • **Invalid**: = "INVALID" -*Defined in [types.ts:285](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L285)* +*Defined in [types.ts:285](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L285)* ___ @@ -429,7 +429,7 @@ ___ • **StoppedWatching**: = "STOPPED_WATCHING" -*Defined in [types.ts:292](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L292)* +*Defined in [types.ts:292](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L292)* ___ @@ -437,7 +437,7 @@ ___ • **Unexpired**: = "UNEXPIRED" -*Defined in [types.ts:291](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L291)* +*Defined in [types.ts:291](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L291)* ___ @@ -445,7 +445,7 @@ ___ • **Unfunded**: = "UNFUNDED" -*Defined in [types.ts:293](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L293)* +*Defined in [types.ts:293](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L293)*
@@ -477,7 +477,7 @@ ___ • **InternalError**: = "InternalError" -*Defined in [types.ts:358](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L358)* +*Defined in [types.ts:358](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L358)* ___ @@ -485,7 +485,7 @@ ___ • **MaxOrderSizeExceeded**: = "MaxOrderSizeExceeded" -*Defined in [types.ts:359](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L359)* +*Defined in [types.ts:359](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L359)* ___ @@ -493,7 +493,7 @@ ___ • **NetworkRequestFailed**: = "NetworkRequestFailed" -*Defined in [types.ts:362](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L362)* +*Defined in [types.ts:362](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L362)* ___ @@ -501,7 +501,7 @@ ___ • **OrderAlreadyStored**: = "OrderAlreadyStored" -*Defined in [types.ts:360](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L360)* +*Defined in [types.ts:360](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L360)* ___ @@ -509,7 +509,7 @@ ___ • **OrderCancelled**: = "OrderCancelled" -*Defined in [types.ts:367](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L367)* +*Defined in [types.ts:367](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L367)* ___ @@ -517,7 +517,7 @@ ___ • **OrderExpired**: = "OrderExpired" -*Defined in [types.ts:365](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L365)* +*Defined in [types.ts:365](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L365)* ___ @@ -525,7 +525,7 @@ ___ • **OrderForIncorrectChain**: = "OrderForIncorrectChain" -*Defined in [types.ts:361](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L361)* +*Defined in [types.ts:361](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L361)* ___ @@ -533,7 +533,7 @@ ___ • **OrderFullyFilled**: = "OrderFullyFilled" -*Defined in [types.ts:366](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L366)* +*Defined in [types.ts:366](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L366)* ___ @@ -541,7 +541,7 @@ ___ • **OrderHasInvalidMakerAssetAmount**: = "OrderHasInvalidMakerAssetAmount" -*Defined in [types.ts:363](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L363)* +*Defined in [types.ts:363](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L363)* ___ @@ -549,7 +549,7 @@ ___ • **OrderHasInvalidMakerAssetData**: = "OrderHasInvalidMakerAssetData" -*Defined in [types.ts:369](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L369)* +*Defined in [types.ts:369](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L369)* ___ @@ -557,7 +557,7 @@ ___ • **OrderHasInvalidSignature**: = "OrderHasInvalidSignature" -*Defined in [types.ts:371](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L371)* +*Defined in [types.ts:371](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L371)* ___ @@ -565,7 +565,7 @@ ___ • **OrderHasInvalidTakerAssetAmount**: = "OrderHasInvalidTakerAssetAmount" -*Defined in [types.ts:364](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L364)* +*Defined in [types.ts:364](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L364)* ___ @@ -573,7 +573,7 @@ ___ • **OrderHasInvalidTakerAssetData**: = "OrderHasInvalidTakerAssetData" -*Defined in [types.ts:370](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L370)* +*Defined in [types.ts:370](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L370)* ___ @@ -581,7 +581,7 @@ ___ • **OrderUnfunded**: = "OrderUnfunded" -*Defined in [types.ts:368](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L368)* +*Defined in [types.ts:368](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L368)*
@@ -602,7 +602,7 @@ ___ • **MeshError**: = "MESH_ERROR" -*Defined in [types.ts:353](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L353)* +*Defined in [types.ts:353](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L353)* ___ @@ -610,7 +610,7 @@ ___ • **MeshValidation**: = "MESH_VALIDATION" -*Defined in [types.ts:354](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L354)* +*Defined in [types.ts:354](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L354)* ___ @@ -618,7 +618,7 @@ ___ • **ZeroexValidation**: = "ZEROEX_VALIDATION" -*Defined in [types.ts:352](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L352)* +*Defined in [types.ts:352](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L352)*
@@ -644,7 +644,7 @@ ___ • **fillableTakerAssetAmount**: *BigNumber* -*Defined in [types.ts:335](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L335)* +*Defined in [types.ts:335](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L335)* ___ @@ -652,7 +652,7 @@ ___ • **isNew**: *boolean* -*Defined in [types.ts:336](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L336)* +*Defined in [types.ts:336](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L336)* ___ @@ -660,7 +660,7 @@ ___ • **orderHash**: *string* -*Defined in [types.ts:333](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L333)* +*Defined in [types.ts:333](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L333)* ___ @@ -668,7 +668,7 @@ ___ • **signedOrder**: *SignedOrder* -*Defined in [types.ts:334](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L334)* +*Defined in [types.ts:334](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L334)*
@@ -701,7 +701,7 @@ Source: https://github.com/theturtle32/WebSocket-Node/blob/master/docs/WebSocket • **assembleFragments**? : *undefined | false | true* -*Defined in [types.ts:16](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L16)* +*Defined in [types.ts:16](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L16)* ___ @@ -709,7 +709,7 @@ ___ • **closeTimeout**? : *undefined | number* -*Defined in [types.ts:17](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L17)* +*Defined in [types.ts:17](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L17)* ___ @@ -717,7 +717,7 @@ ___ • **fragmentOutgoingMessages**? : *undefined | false | true* -*Defined in [types.ts:14](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L14)* +*Defined in [types.ts:14](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L14)* ___ @@ -725,7 +725,7 @@ ___ • **fragmentationThreshold**? : *undefined | number* -*Defined in [types.ts:15](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L15)* +*Defined in [types.ts:15](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L15)* ___ @@ -733,7 +733,7 @@ ___ • **maxReceivedFrameSize**? : *undefined | number* -*Defined in [types.ts:12](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L12)* +*Defined in [types.ts:12](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L12)* ___ @@ -741,7 +741,7 @@ ___ • **maxReceivedMessageSize**? : *undefined | number* -*Defined in [types.ts:13](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L13)* +*Defined in [types.ts:13](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L13)* ___ @@ -749,7 +749,7 @@ ___ • **tlsOptions**? : *any* -*Defined in [types.ts:18](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L18)* +*Defined in [types.ts:18](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L18)* ___ @@ -757,7 +757,7 @@ ___ • **webSocketVersion**? : *undefined | number* -*Defined in [types.ts:11](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L11)* +*Defined in [types.ts:11](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L11)*
@@ -787,7 +787,7 @@ ___ • **address**: *string* -*Defined in [types.ts:279](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L279)* +*Defined in [types.ts:279](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L279)* ___ @@ -795,7 +795,7 @@ ___ • **blockHash**: *string* -*Defined in [types.ts:274](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L274)* +*Defined in [types.ts:274](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L274)* ___ @@ -803,7 +803,7 @@ ___ • **isRemoved**: *string* -*Defined in [types.ts:278](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L278)* +*Defined in [types.ts:278](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L278)* ___ @@ -811,7 +811,7 @@ ___ • **kind**: *[ContractEventKind](#enumeration-contracteventkind)* -*Defined in [types.ts:280](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L280)* +*Defined in [types.ts:280](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L280)* ___ @@ -819,7 +819,7 @@ ___ • **logIndex**: *number* -*Defined in [types.ts:277](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L277)* +*Defined in [types.ts:277](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L277)* ___ @@ -827,7 +827,7 @@ ___ • **parameters**: *[ContractEventParameters](#contracteventparameters)* -*Defined in [types.ts:281](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L281)* +*Defined in [types.ts:281](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L281)* ___ @@ -835,7 +835,7 @@ ___ • **txHash**: *string* -*Defined in [types.ts:275](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L275)* +*Defined in [types.ts:275](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L275)* ___ @@ -843,7 +843,7 @@ ___ • **txIndex**: *number* -*Defined in [types.ts:276](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L276)* +*Defined in [types.ts:276](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L276)*
@@ -868,7 +868,7 @@ ___ • **approved**: *boolean* -*Defined in [types.ts:144](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L144)* +*Defined in [types.ts:144](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L144)* ___ @@ -876,7 +876,7 @@ ___ • **operator**: *string* -*Defined in [types.ts:143](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L143)* +*Defined in [types.ts:143](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L143)* ___ @@ -884,7 +884,7 @@ ___ • **owner**: *string* -*Defined in [types.ts:142](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L142)* +*Defined in [types.ts:142](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L142)*
@@ -911,7 +911,7 @@ ___ • **from**: *string* -*Defined in [types.ts:127](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L127)* +*Defined in [types.ts:127](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L127)* ___ @@ -919,7 +919,7 @@ ___ • **ids**: *BigNumber[]* -*Defined in [types.ts:129](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L129)* +*Defined in [types.ts:129](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L129)* ___ @@ -927,7 +927,7 @@ ___ • **operator**: *string* -*Defined in [types.ts:126](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L126)* +*Defined in [types.ts:126](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L126)* ___ @@ -935,7 +935,7 @@ ___ • **to**: *string* -*Defined in [types.ts:128](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L128)* +*Defined in [types.ts:128](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L128)* ___ @@ -943,7 +943,7 @@ ___ • **values**: *BigNumber[]* -*Defined in [types.ts:130](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L130)* +*Defined in [types.ts:130](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L130)*
@@ -970,7 +970,7 @@ ___ • **from**: *string* -*Defined in [types.ts:111](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L111)* +*Defined in [types.ts:111](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L111)* ___ @@ -978,7 +978,7 @@ ___ • **id**: *BigNumber* -*Defined in [types.ts:113](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L113)* +*Defined in [types.ts:113](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L113)* ___ @@ -986,7 +986,7 @@ ___ • **operator**: *string* -*Defined in [types.ts:110](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L110)* +*Defined in [types.ts:110](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L110)* ___ @@ -994,7 +994,7 @@ ___ • **to**: *string* -*Defined in [types.ts:112](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L112)* +*Defined in [types.ts:112](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L112)* ___ @@ -1002,7 +1002,7 @@ ___ • **value**: *BigNumber* -*Defined in [types.ts:114](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L114)* +*Defined in [types.ts:114](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L114)*
@@ -1027,7 +1027,7 @@ ___ • **owner**: *string* -*Defined in [types.ts:68](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L68)* +*Defined in [types.ts:68](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L68)* ___ @@ -1035,7 +1035,7 @@ ___ • **spender**: *string* -*Defined in [types.ts:69](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L69)* +*Defined in [types.ts:69](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L69)* ___ @@ -1043,7 +1043,7 @@ ___ • **value**: *BigNumber* -*Defined in [types.ts:70](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L70)* +*Defined in [types.ts:70](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L70)*
@@ -1068,7 +1068,7 @@ ___ • **from**: *string* -*Defined in [types.ts:56](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L56)* +*Defined in [types.ts:56](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L56)* ___ @@ -1076,7 +1076,7 @@ ___ • **to**: *string* -*Defined in [types.ts:57](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L57)* +*Defined in [types.ts:57](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L57)* ___ @@ -1084,7 +1084,7 @@ ___ • **value**: *BigNumber* -*Defined in [types.ts:58](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L58)* +*Defined in [types.ts:58](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L58)*
@@ -1109,7 +1109,7 @@ ___ • **approved**: *string* -*Defined in [types.ts:93](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L93)* +*Defined in [types.ts:93](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L93)* ___ @@ -1117,7 +1117,7 @@ ___ • **owner**: *string* -*Defined in [types.ts:92](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L92)* +*Defined in [types.ts:92](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L92)* ___ @@ -1125,7 +1125,7 @@ ___ • **tokenId**: *BigNumber* -*Defined in [types.ts:94](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L94)* +*Defined in [types.ts:94](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L94)*
@@ -1150,7 +1150,7 @@ ___ • **approved**: *boolean* -*Defined in [types.ts:106](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L106)* +*Defined in [types.ts:106](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L106)* ___ @@ -1158,7 +1158,7 @@ ___ • **operator**: *string* -*Defined in [types.ts:105](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L105)* +*Defined in [types.ts:105](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L105)* ___ @@ -1166,7 +1166,7 @@ ___ • **owner**: *string* -*Defined in [types.ts:104](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L104)* +*Defined in [types.ts:104](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L104)*
@@ -1191,7 +1191,7 @@ ___ • **from**: *string* -*Defined in [types.ts:80](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L80)* +*Defined in [types.ts:80](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L80)* ___ @@ -1199,7 +1199,7 @@ ___ • **to**: *string* -*Defined in [types.ts:81](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L81)* +*Defined in [types.ts:81](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L81)* ___ @@ -1207,7 +1207,7 @@ ___ • **tokenId**: *BigNumber* -*Defined in [types.ts:82](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L82)* +*Defined in [types.ts:82](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L82)*
@@ -1235,7 +1235,7 @@ ___ • **feeRecipientAddress**: *string* -*Defined in [types.ts:178](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L178)* +*Defined in [types.ts:178](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L178)* ___ @@ -1243,7 +1243,7 @@ ___ • **makerAddress**: *string* -*Defined in [types.ts:176](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L176)* +*Defined in [types.ts:176](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L176)* ___ @@ -1251,7 +1251,7 @@ ___ • **makerAssetData**: *string* -*Defined in [types.ts:180](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L180)* +*Defined in [types.ts:180](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L180)* ___ @@ -1259,7 +1259,7 @@ ___ • **orderHash**: *string* -*Defined in [types.ts:179](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L179)* +*Defined in [types.ts:179](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L179)* ___ @@ -1267,7 +1267,7 @@ ___ • **senderAddress**: *string* -*Defined in [types.ts:177](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L177)* +*Defined in [types.ts:177](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L177)* ___ @@ -1275,7 +1275,7 @@ ___ • **takerAssetData**: *string* -*Defined in [types.ts:181](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L181)* +*Defined in [types.ts:181](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L181)*
@@ -1300,7 +1300,7 @@ ___ • **makerAddress**: *string* -*Defined in [types.ts:185](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L185)* +*Defined in [types.ts:185](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L185)* ___ @@ -1308,7 +1308,7 @@ ___ • **orderEpoch**: *BigNumber* -*Defined in [types.ts:187](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L187)* +*Defined in [types.ts:187](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L187)* ___ @@ -1316,7 +1316,7 @@ ___ • **senderAddress**: *string* -*Defined in [types.ts:186](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L186)* +*Defined in [types.ts:186](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L186)*
@@ -1349,7 +1349,7 @@ ___ • **feeRecipientAddress**: *string* -*Defined in [types.ts:151](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L151)* +*Defined in [types.ts:151](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L151)* ___ @@ -1357,7 +1357,7 @@ ___ • **makerAddress**: *string* -*Defined in [types.ts:148](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L148)* +*Defined in [types.ts:148](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L148)* ___ @@ -1365,7 +1365,7 @@ ___ • **makerAssetData**: *string* -*Defined in [types.ts:157](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L157)* +*Defined in [types.ts:157](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L157)* ___ @@ -1373,7 +1373,7 @@ ___ • **makerAssetFilledAmount**: *BigNumber* -*Defined in [types.ts:152](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L152)* +*Defined in [types.ts:152](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L152)* ___ @@ -1381,7 +1381,7 @@ ___ • **makerFeePaid**: *BigNumber* -*Defined in [types.ts:154](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L154)* +*Defined in [types.ts:154](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L154)* ___ @@ -1389,7 +1389,7 @@ ___ • **orderHash**: *string* -*Defined in [types.ts:156](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L156)* +*Defined in [types.ts:156](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L156)* ___ @@ -1397,7 +1397,7 @@ ___ • **senderAddress**: *string* -*Defined in [types.ts:150](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L150)* +*Defined in [types.ts:150](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L150)* ___ @@ -1405,7 +1405,7 @@ ___ • **takerAddress**: *string* -*Defined in [types.ts:149](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L149)* +*Defined in [types.ts:149](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L149)* ___ @@ -1413,7 +1413,7 @@ ___ • **takerAssetData**: *string* -*Defined in [types.ts:158](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L158)* +*Defined in [types.ts:158](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L158)* ___ @@ -1421,7 +1421,7 @@ ___ • **takerAssetFilledAmount**: *BigNumber* -*Defined in [types.ts:153](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L153)* +*Defined in [types.ts:153](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L153)* ___ @@ -1429,7 +1429,7 @@ ___ • **takerFeePaid**: *BigNumber* -*Defined in [types.ts:155](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L155)* +*Defined in [types.ts:155](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L155)*
@@ -1454,7 +1454,7 @@ ___ • **ordersInfos**: *[OrderInfo](#interface-orderinfo)[]* -*Defined in [types.ts:415](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L415)* +*Defined in [types.ts:415](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L415)* ___ @@ -1462,7 +1462,7 @@ ___ • **snapshotID**: *string* -*Defined in [types.ts:413](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L413)* +*Defined in [types.ts:413](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L413)* ___ @@ -1470,7 +1470,7 @@ ___ • **snapshotTimestamp**: *number* -*Defined in [types.ts:414](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L414)* +*Defined in [types.ts:414](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L414)*
@@ -1506,7 +1506,7 @@ ___ • **ethRPCRateLimitExpiredRequests**: *number* -*Defined in [types.ts:442](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L442)* +*Defined in [types.ts:442](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L442)* ___ @@ -1514,7 +1514,7 @@ ___ • **ethRPCRequestsSentInCurrentUTCDay**: *number* -*Defined in [types.ts:441](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L441)* +*Defined in [types.ts:441](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L441)* ___ @@ -1522,7 +1522,7 @@ ___ • **ethereumChainID**: *number* -*Defined in [types.ts:433](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L433)* +*Defined in [types.ts:433](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L433)* ___ @@ -1530,7 +1530,7 @@ ___ • **latestBlock**: *[LatestBlock](#interface-latestblock)* -*Defined in [types.ts:434](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L434)* +*Defined in [types.ts:434](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L434)* ___ @@ -1538,7 +1538,7 @@ ___ • **maxExpirationTime**: *string* -*Defined in [types.ts:439](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L439)* +*Defined in [types.ts:439](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L439)* ___ @@ -1546,7 +1546,7 @@ ___ • **numOrders**: *number* -*Defined in [types.ts:436](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L436)* +*Defined in [types.ts:436](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L436)* ___ @@ -1554,7 +1554,7 @@ ___ • **numOrdersIncludingRemoved**: *number* -*Defined in [types.ts:437](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L437)* +*Defined in [types.ts:437](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L437)* ___ @@ -1562,7 +1562,7 @@ ___ • **numPeers**: *number* -*Defined in [types.ts:435](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L435)* +*Defined in [types.ts:435](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L435)* ___ @@ -1570,7 +1570,7 @@ ___ • **numPinnedOrders**: *number* -*Defined in [types.ts:438](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L438)* +*Defined in [types.ts:438](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L438)* ___ @@ -1578,7 +1578,7 @@ ___ • **peerID**: *string* -*Defined in [types.ts:432](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L432)* +*Defined in [types.ts:432](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L432)* ___ @@ -1586,7 +1586,7 @@ ___ • **pubSubTopic**: *string* -*Defined in [types.ts:430](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L430)* +*Defined in [types.ts:430](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L430)* ___ @@ -1594,7 +1594,7 @@ ___ • **rendezvous**: *string* -*Defined in [types.ts:431](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L431)* +*Defined in [types.ts:431](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L431)* ___ @@ -1602,7 +1602,7 @@ ___ • **startOfCurrentUTCDay**: *string* -*Defined in [types.ts:440](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L440)* +*Defined in [types.ts:440](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L440)* ___ @@ -1610,7 +1610,7 @@ ___ • **version**: *string* -*Defined in [types.ts:429](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L429)* +*Defined in [types.ts:429](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L429)*
@@ -1634,7 +1634,7 @@ ___ • **result**: *string* -*Defined in [types.ts:304](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L304)* +*Defined in [types.ts:304](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L304)* ___ @@ -1642,7 +1642,7 @@ ___ • **subscription**: *string* -*Defined in [types.ts:303](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L303)* +*Defined in [types.ts:303](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L303)*
@@ -1666,7 +1666,7 @@ ___ • **hash**: *string* -*Defined in [types.ts:425](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L425)* +*Defined in [types.ts:425](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L425)* ___ @@ -1674,7 +1674,7 @@ ___ • **number**: *number* -*Defined in [types.ts:424](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L424)* +*Defined in [types.ts:424](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L424)*
@@ -1702,7 +1702,7 @@ ___ • **contractEvents**: *[ContractEvent](#interface-contractevent)[]* -*Defined in [types.ts:322](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L322)* +*Defined in [types.ts:322](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L322)* ___ @@ -1710,7 +1710,7 @@ ___ • **endState**: *[OrderEventEndState](#enumeration-ordereventendstate)* -*Defined in [types.ts:320](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L320)* +*Defined in [types.ts:320](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L320)* ___ @@ -1718,7 +1718,7 @@ ___ • **fillableTakerAssetAmount**: *BigNumber* -*Defined in [types.ts:321](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L321)* +*Defined in [types.ts:321](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L321)* ___ @@ -1726,7 +1726,7 @@ ___ • **orderHash**: *string* -*Defined in [types.ts:318](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L318)* +*Defined in [types.ts:318](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L318)* ___ @@ -1734,7 +1734,7 @@ ___ • **signedOrder**: *SignedOrder* -*Defined in [types.ts:319](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L319)* +*Defined in [types.ts:319](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L319)* ___ @@ -1742,7 +1742,7 @@ ___ • **timestampMs**: *number* -*Defined in [types.ts:317](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L317)* +*Defined in [types.ts:317](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L317)*
@@ -1766,7 +1766,7 @@ ___ • **result**: *[RawOrderEvent](#interface-raworderevent)[]* -*Defined in [types.ts:299](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L299)* +*Defined in [types.ts:299](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L299)* ___ @@ -1774,7 +1774,7 @@ ___ • **subscription**: *string* -*Defined in [types.ts:298](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L298)* +*Defined in [types.ts:298](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L298)*
@@ -1799,7 +1799,7 @@ ___ • **fillableTakerAssetAmount**: *BigNumber* -*Defined in [types.ts:348](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L348)* +*Defined in [types.ts:348](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L348)* ___ @@ -1807,7 +1807,7 @@ ___ • **orderHash**: *string* -*Defined in [types.ts:346](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L346)* +*Defined in [types.ts:346](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L346)* ___ @@ -1815,7 +1815,7 @@ ___ • **signedOrder**: *SignedOrder* -*Defined in [types.ts:347](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L347)* +*Defined in [types.ts:347](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L347)*
@@ -1841,7 +1841,7 @@ ___ • **fillableTakerAssetAmount**: *string* -*Defined in [types.ts:328](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L328)* +*Defined in [types.ts:328](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L328)* ___ @@ -1849,7 +1849,7 @@ ___ • **isNew**: *boolean* -*Defined in [types.ts:329](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L329)* +*Defined in [types.ts:329](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L329)* ___ @@ -1857,7 +1857,7 @@ ___ • **orderHash**: *string* -*Defined in [types.ts:326](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L326)* +*Defined in [types.ts:326](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L326)* ___ @@ -1865,7 +1865,7 @@ ___ • **signedOrder**: *[StringifiedSignedOrder](#interface-stringifiedsignedorder)* -*Defined in [types.ts:327](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L327)* +*Defined in [types.ts:327](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L327)*
@@ -1890,7 +1890,7 @@ ___ • **ordersInfos**: *[RawAcceptedOrderInfo](#interface-rawacceptedorderinfo)[]* -*Defined in [types.ts:406](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L406)* +*Defined in [types.ts:406](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L406)* ___ @@ -1898,7 +1898,7 @@ ___ • **snapshotID**: *string* -*Defined in [types.ts:404](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L404)* +*Defined in [types.ts:404](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L404)* ___ @@ -1906,7 +1906,7 @@ ___ • **snapshotTimestamp**: *string* -*Defined in [types.ts:405](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L405)* +*Defined in [types.ts:405](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L405)*
@@ -1934,7 +1934,7 @@ ___ • **contractEvents**: *[StringifiedContractEvent](#interface-stringifiedcontractevent)[]* -*Defined in [types.ts:313](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L313)* +*Defined in [types.ts:313](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L313)* ___ @@ -1942,7 +1942,7 @@ ___ • **endState**: *[OrderEventEndState](#enumeration-ordereventendstate)* -*Defined in [types.ts:311](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L311)* +*Defined in [types.ts:311](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L311)* ___ @@ -1950,7 +1950,7 @@ ___ • **fillableTakerAssetAmount**: *string* -*Defined in [types.ts:312](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L312)* +*Defined in [types.ts:312](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L312)* ___ @@ -1958,7 +1958,7 @@ ___ • **orderHash**: *string* -*Defined in [types.ts:309](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L309)* +*Defined in [types.ts:309](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L309)* ___ @@ -1966,7 +1966,7 @@ ___ • **signedOrder**: *[StringifiedSignedOrder](#interface-stringifiedsignedorder)* -*Defined in [types.ts:310](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L310)* +*Defined in [types.ts:310](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L310)* ___ @@ -1974,7 +1974,7 @@ ___ • **timestamp**: *string* -*Defined in [types.ts:308](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L308)* +*Defined in [types.ts:308](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L308)*
@@ -1999,7 +1999,7 @@ ___ • **fillableTakerAssetAmount**: *string* -*Defined in [types.ts:342](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L342)* +*Defined in [types.ts:342](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L342)* ___ @@ -2007,7 +2007,7 @@ ___ • **orderHash**: *string* -*Defined in [types.ts:340](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L340)* +*Defined in [types.ts:340](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L340)* ___ @@ -2015,7 +2015,7 @@ ___ • **signedOrder**: *[StringifiedSignedOrder](#interface-stringifiedsignedorder)* -*Defined in [types.ts:341](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L341)* +*Defined in [types.ts:341](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L341)*
@@ -2041,7 +2041,7 @@ ___ • **kind**: *[RejectedKind](#enumeration-rejectedkind)* -*Defined in [types.ts:382](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L382)* +*Defined in [types.ts:382](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L382)* ___ @@ -2049,7 +2049,7 @@ ___ • **orderHash**: *string* -*Defined in [types.ts:380](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L380)* +*Defined in [types.ts:380](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L380)* ___ @@ -2057,7 +2057,7 @@ ___ • **signedOrder**: *[StringifiedSignedOrder](#interface-stringifiedsignedorder)* -*Defined in [types.ts:381](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L381)* +*Defined in [types.ts:381](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L381)* ___ @@ -2065,7 +2065,7 @@ ___ • **status**: *[RejectedStatus](#interface-rejectedstatus)* -*Defined in [types.ts:383](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L383)* +*Defined in [types.ts:383](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L383)*
@@ -2089,7 +2089,7 @@ ___ • **accepted**: *[RawAcceptedOrderInfo](#interface-rawacceptedorderinfo)[]* -*Defined in [types.ts:394](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L394)* +*Defined in [types.ts:394](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L394)* ___ @@ -2097,7 +2097,7 @@ ___ • **rejected**: *[RawRejectedOrderInfo](#interface-rawrejectedorderinfo)[]* -*Defined in [types.ts:395](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L395)* +*Defined in [types.ts:395](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L395)*
@@ -2123,7 +2123,7 @@ ___ • **kind**: *[RejectedKind](#enumeration-rejectedkind)* -*Defined in [types.ts:389](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L389)* +*Defined in [types.ts:389](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L389)* ___ @@ -2131,7 +2131,7 @@ ___ • **orderHash**: *string* -*Defined in [types.ts:387](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L387)* +*Defined in [types.ts:387](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L387)* ___ @@ -2139,7 +2139,7 @@ ___ • **signedOrder**: *SignedOrder* -*Defined in [types.ts:388](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L388)* +*Defined in [types.ts:388](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L388)* ___ @@ -2147,7 +2147,7 @@ ___ • **status**: *[RejectedStatus](#interface-rejectedstatus)* -*Defined in [types.ts:390](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L390)* +*Defined in [types.ts:390](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L390)*
@@ -2171,7 +2171,7 @@ ___ • **code**: *[RejectedCode](#enumeration-rejectedcode)* -*Defined in [types.ts:375](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L375)* +*Defined in [types.ts:375](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L375)* ___ @@ -2179,7 +2179,7 @@ ___ • **message**: *string* -*Defined in [types.ts:376](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L376)* +*Defined in [types.ts:376](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L376)*
@@ -2209,7 +2209,7 @@ ___ • **address**: *string* -*Defined in [types.ts:253](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L253)* +*Defined in [types.ts:253](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L253)* ___ @@ -2217,7 +2217,7 @@ ___ • **blockHash**: *string* -*Defined in [types.ts:248](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L248)* +*Defined in [types.ts:248](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L248)* ___ @@ -2225,7 +2225,7 @@ ___ • **isRemoved**: *string* -*Defined in [types.ts:252](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L252)* +*Defined in [types.ts:252](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L252)* ___ @@ -2233,7 +2233,7 @@ ___ • **kind**: *string* -*Defined in [types.ts:254](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L254)* +*Defined in [types.ts:254](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L254)* ___ @@ -2241,7 +2241,7 @@ ___ • **logIndex**: *number* -*Defined in [types.ts:251](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L251)* +*Defined in [types.ts:251](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L251)* ___ @@ -2249,7 +2249,7 @@ ___ • **parameters**: *[StringifiedContractEventParameters](#stringifiedcontracteventparameters)* -*Defined in [types.ts:255](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L255)* +*Defined in [types.ts:255](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L255)* ___ @@ -2257,7 +2257,7 @@ ___ • **txHash**: *string* -*Defined in [types.ts:249](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L249)* +*Defined in [types.ts:249](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L249)* ___ @@ -2265,7 +2265,7 @@ ___ • **txIndex**: *number* -*Defined in [types.ts:250](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L250)* +*Defined in [types.ts:250](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L250)*
@@ -2292,7 +2292,7 @@ ___ • **from**: *string* -*Defined in [types.ts:135](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L135)* +*Defined in [types.ts:135](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L135)* ___ @@ -2300,7 +2300,7 @@ ___ • **ids**: *string[]* -*Defined in [types.ts:137](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L137)* +*Defined in [types.ts:137](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L137)* ___ @@ -2308,7 +2308,7 @@ ___ • **operator**: *string* -*Defined in [types.ts:134](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L134)* +*Defined in [types.ts:134](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L134)* ___ @@ -2316,7 +2316,7 @@ ___ • **to**: *string* -*Defined in [types.ts:136](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L136)* +*Defined in [types.ts:136](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L136)* ___ @@ -2324,7 +2324,7 @@ ___ • **values**: *string[]* -*Defined in [types.ts:138](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L138)* +*Defined in [types.ts:138](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L138)*
@@ -2351,7 +2351,7 @@ ___ • **from**: *string* -*Defined in [types.ts:119](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L119)* +*Defined in [types.ts:119](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L119)* ___ @@ -2359,7 +2359,7 @@ ___ • **id**: *string* -*Defined in [types.ts:121](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L121)* +*Defined in [types.ts:121](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L121)* ___ @@ -2367,7 +2367,7 @@ ___ • **operator**: *string* -*Defined in [types.ts:118](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L118)* +*Defined in [types.ts:118](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L118)* ___ @@ -2375,7 +2375,7 @@ ___ • **to**: *string* -*Defined in [types.ts:120](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L120)* +*Defined in [types.ts:120](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L120)* ___ @@ -2383,7 +2383,7 @@ ___ • **value**: *string* -*Defined in [types.ts:122](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L122)* +*Defined in [types.ts:122](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L122)*
@@ -2408,7 +2408,7 @@ ___ • **owner**: *string* -*Defined in [types.ts:74](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L74)* +*Defined in [types.ts:74](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L74)* ___ @@ -2416,7 +2416,7 @@ ___ • **spender**: *string* -*Defined in [types.ts:75](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L75)* +*Defined in [types.ts:75](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L75)* ___ @@ -2424,7 +2424,7 @@ ___ • **value**: *string* -*Defined in [types.ts:76](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L76)* +*Defined in [types.ts:76](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L76)*
@@ -2449,7 +2449,7 @@ ___ • **from**: *string* -*Defined in [types.ts:62](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L62)* +*Defined in [types.ts:62](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L62)* ___ @@ -2457,7 +2457,7 @@ ___ • **to**: *string* -*Defined in [types.ts:63](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L63)* +*Defined in [types.ts:63](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L63)* ___ @@ -2465,7 +2465,7 @@ ___ • **value**: *string* -*Defined in [types.ts:64](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L64)* +*Defined in [types.ts:64](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L64)*
@@ -2490,7 +2490,7 @@ ___ • **approved**: *string* -*Defined in [types.ts:99](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L99)* +*Defined in [types.ts:99](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L99)* ___ @@ -2498,7 +2498,7 @@ ___ • **owner**: *string* -*Defined in [types.ts:98](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L98)* +*Defined in [types.ts:98](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L98)* ___ @@ -2506,7 +2506,7 @@ ___ • **tokenId**: *string* -*Defined in [types.ts:100](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L100)* +*Defined in [types.ts:100](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L100)*
@@ -2531,7 +2531,7 @@ ___ • **from**: *string* -*Defined in [types.ts:86](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L86)* +*Defined in [types.ts:86](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L86)* ___ @@ -2539,7 +2539,7 @@ ___ • **to**: *string* -*Defined in [types.ts:87](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L87)* +*Defined in [types.ts:87](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L87)* ___ @@ -2547,7 +2547,7 @@ ___ • **tokenId**: *string* -*Defined in [types.ts:88](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L88)* +*Defined in [types.ts:88](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L88)*
@@ -2572,7 +2572,7 @@ ___ • **makerAddress**: *string* -*Defined in [types.ts:191](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L191)* +*Defined in [types.ts:191](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L191)* ___ @@ -2580,7 +2580,7 @@ ___ • **orderEpoch**: *string* -*Defined in [types.ts:193](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L193)* +*Defined in [types.ts:193](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L193)* ___ @@ -2588,7 +2588,7 @@ ___ • **senderAddress**: *string* -*Defined in [types.ts:192](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L192)* +*Defined in [types.ts:192](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L192)*
@@ -2621,7 +2621,7 @@ ___ • **feeRecipientAddress**: *string* -*Defined in [types.ts:165](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L165)* +*Defined in [types.ts:165](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L165)* ___ @@ -2629,7 +2629,7 @@ ___ • **makerAddress**: *string* -*Defined in [types.ts:162](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L162)* +*Defined in [types.ts:162](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L162)* ___ @@ -2637,7 +2637,7 @@ ___ • **makerAssetData**: *string* -*Defined in [types.ts:171](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L171)* +*Defined in [types.ts:171](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L171)* ___ @@ -2645,7 +2645,7 @@ ___ • **makerAssetFilledAmount**: *string* -*Defined in [types.ts:166](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L166)* +*Defined in [types.ts:166](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L166)* ___ @@ -2653,7 +2653,7 @@ ___ • **makerFeePaid**: *string* -*Defined in [types.ts:168](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L168)* +*Defined in [types.ts:168](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L168)* ___ @@ -2661,7 +2661,7 @@ ___ • **orderHash**: *string* -*Defined in [types.ts:170](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L170)* +*Defined in [types.ts:170](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L170)* ___ @@ -2669,7 +2669,7 @@ ___ • **senderAddress**: *string* -*Defined in [types.ts:164](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L164)* +*Defined in [types.ts:164](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L164)* ___ @@ -2677,7 +2677,7 @@ ___ • **takerAddress**: *string* -*Defined in [types.ts:163](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L163)* +*Defined in [types.ts:163](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L163)* ___ @@ -2685,7 +2685,7 @@ ___ • **takerAssetData**: *string* -*Defined in [types.ts:172](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L172)* +*Defined in [types.ts:172](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L172)* ___ @@ -2693,7 +2693,7 @@ ___ • **takerAssetFilledAmount**: *string* -*Defined in [types.ts:167](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L167)* +*Defined in [types.ts:167](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L167)* ___ @@ -2701,7 +2701,7 @@ ___ • **takerFeePaid**: *string* -*Defined in [types.ts:169](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L169)* +*Defined in [types.ts:169](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L169)*
@@ -2737,7 +2737,7 @@ ___ • **exchangeAddress**: *string* -*Defined in [types.ts:49](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L49)* +*Defined in [types.ts:49](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L49)* ___ @@ -2745,7 +2745,7 @@ ___ • **expirationTimeSeconds**: *string* -*Defined in [types.ts:51](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L51)* +*Defined in [types.ts:51](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L51)* ___ @@ -2753,7 +2753,7 @@ ___ • **feeRecipientAddress**: *string* -*Defined in [types.ts:50](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L50)* +*Defined in [types.ts:50](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L50)* ___ @@ -2761,7 +2761,7 @@ ___ • **makerAddress**: *string* -*Defined in [types.ts:40](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L40)* +*Defined in [types.ts:40](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L40)* ___ @@ -2769,7 +2769,7 @@ ___ • **makerAssetAmount**: *string* -*Defined in [types.ts:44](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L44)* +*Defined in [types.ts:44](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L44)* ___ @@ -2777,7 +2777,7 @@ ___ • **makerAssetData**: *string* -*Defined in [types.ts:46](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L46)* +*Defined in [types.ts:46](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L46)* ___ @@ -2785,7 +2785,7 @@ ___ • **makerFee**: *string* -*Defined in [types.ts:42](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L42)* +*Defined in [types.ts:42](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L42)* ___ @@ -2793,7 +2793,7 @@ ___ • **salt**: *string* -*Defined in [types.ts:48](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L48)* +*Defined in [types.ts:48](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L48)* ___ @@ -2801,7 +2801,7 @@ ___ • **senderAddress**: *string* -*Defined in [types.ts:39](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L39)* +*Defined in [types.ts:39](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L39)* ___ @@ -2809,7 +2809,7 @@ ___ • **signature**: *string* -*Defined in [types.ts:52](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L52)* +*Defined in [types.ts:52](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L52)* ___ @@ -2817,7 +2817,7 @@ ___ • **takerAddress**: *string* -*Defined in [types.ts:41](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L41)* +*Defined in [types.ts:41](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L41)* ___ @@ -2825,7 +2825,7 @@ ___ • **takerAssetAmount**: *string* -*Defined in [types.ts:45](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L45)* +*Defined in [types.ts:45](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L45)* ___ @@ -2833,7 +2833,7 @@ ___ • **takerAssetData**: *string* -*Defined in [types.ts:47](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L47)* +*Defined in [types.ts:47](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L47)* ___ @@ -2841,7 +2841,7 @@ ___ • **takerFee**: *string* -*Defined in [types.ts:43](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L43)* +*Defined in [types.ts:43](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L43)*
@@ -2865,7 +2865,7 @@ ___ • **owner**: *string* -*Defined in [types.ts:212](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L212)* +*Defined in [types.ts:212](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L212)* ___ @@ -2873,7 +2873,7 @@ ___ • **value**: *string* -*Defined in [types.ts:213](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L213)* +*Defined in [types.ts:213](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L213)*
@@ -2897,7 +2897,7 @@ ___ • **owner**: *string* -*Defined in [types.ts:202](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L202)* +*Defined in [types.ts:202](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L202)* ___ @@ -2905,7 +2905,7 @@ ___ • **value**: *string* -*Defined in [types.ts:203](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L203)* +*Defined in [types.ts:203](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L203)*
@@ -2929,7 +2929,7 @@ ___ • **accepted**: *[AcceptedOrderInfo](#interface-acceptedorderinfo)[]* -*Defined in [types.ts:399](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L399)* +*Defined in [types.ts:399](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L399)* ___ @@ -2937,7 +2937,7 @@ ___ • **rejected**: *[RejectedOrderInfo](#interface-rejectedorderinfo)[]* -*Defined in [types.ts:400](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L400)* +*Defined in [types.ts:400](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L400)*
@@ -2961,7 +2961,7 @@ ___ • **owner**: *string* -*Defined in [types.ts:207](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L207)* +*Defined in [types.ts:207](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L207)* ___ @@ -2969,7 +2969,7 @@ ___ • **value**: *BigNumber* -*Defined in [types.ts:208](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L208)* +*Defined in [types.ts:208](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L208)*
@@ -2993,7 +2993,7 @@ ___ • **owner**: *string* -*Defined in [types.ts:197](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L197)* +*Defined in [types.ts:197](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L197)* ___ @@ -3001,7 +3001,7 @@ ___ • **value**: *BigNumber* -*Defined in [types.ts:198](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L198)* +*Defined in [types.ts:198](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L198)*
@@ -3025,7 +3025,7 @@ ___ • **type**: *string* -*Defined in [types.ts:419](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L419)* +*Defined in [types.ts:419](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L419)* ___ @@ -3033,7 +3033,7 @@ ___ • **utf8Data**: *string* -*Defined in [types.ts:420](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L420)* +*Defined in [types.ts:420](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L420)*
@@ -3068,7 +3068,7 @@ reconnectDelay: time in milliseconds after which to attempt to reconnect to WS s • **clientConfig**? : *[ClientConfig](#interface-clientconfig)* -*Defined in [types.ts:34](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L34)* +*Defined in [types.ts:34](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L34)* ___ @@ -3076,7 +3076,7 @@ ___ • **headers**? : *undefined | __type* -*Defined in [types.ts:32](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L32)* +*Defined in [types.ts:32](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L32)* ___ @@ -3084,7 +3084,7 @@ ___ • **protocol**? : *undefined | string* -*Defined in [types.ts:33](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L33)* +*Defined in [types.ts:33](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L33)* ___ @@ -3092,7 +3092,7 @@ ___ • **reconnectDelay**? : *undefined | number* -*Defined in [types.ts:35](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L35)* +*Defined in [types.ts:35](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L35)* ___ @@ -3100,7 +3100,7 @@ ___ • **timeout**? : *undefined | number* -*Defined in [types.ts:31](https://github.com/0xProject/0x-mesh/blob/3f64cf7d/packages/rpc-client/src/types.ts#L31)* +*Defined in [types.ts:31](https://github.com/0xProject/0x-mesh/blob/d7f70fc4/packages/rpc-client/src/types.ts#L31)*
diff --git a/docs/rpc_api.md b/docs/rpc_api.md index f4684d267..866c5999d 100644 --- a/docs/rpc_api.md +++ b/docs/rpc_api.md @@ -1,4 +1,4 @@ -[![Version](https://img.shields.io/badge/version-9.4.1-orange.svg)](https://github.com/0xProject/0x-mesh/releases) +[![Version](https://img.shields.io/badge/version-9.4.2-orange.svg)](https://github.com/0xProject/0x-mesh/releases) # 0x Mesh JSON-RPC API Documentation diff --git a/packages/browser-lite/package.json b/packages/browser-lite/package.json index 558a9ca60..767a25328 100644 --- a/packages/browser-lite/package.json +++ b/packages/browser-lite/package.json @@ -1,6 +1,6 @@ { "name": "@0x/mesh-browser-lite", - "version": "9.4.1", + "version": "9.4.2", "description": "TypeScript and JavaScript bindings for running Mesh directly in the browser. To use this packages, you must use your own copy of the Mesh WebAssembly Binary", "main": "./lib/index.js", "license": "Apache-2.0", diff --git a/packages/browser/package.json b/packages/browser/package.json index c3b08abe9..3eaf33651 100644 --- a/packages/browser/package.json +++ b/packages/browser/package.json @@ -1,6 +1,6 @@ { "name": "@0x/mesh-browser", - "version": "9.4.1", + "version": "9.4.2", "description": "TypeScript and JavaScript bindings for running Mesh directly in the browser.", "main": "./lib/index.js", "license": "Apache-2.0", @@ -21,7 +21,7 @@ "docsPath": "../../docs/browser-bindings/browser" }, "dependencies": { - "@0x/mesh-browser-lite": "^9.4.1", + "@0x/mesh-browser-lite": "^9.4.2", "base64-arraybuffer": "^0.2.0", "browserfs": "^1.4.3", "ethereum-types": "^3.0.0" diff --git a/packages/rpc-client/package.json b/packages/rpc-client/package.json index ceb804f50..28e144a2e 100644 --- a/packages/rpc-client/package.json +++ b/packages/rpc-client/package.json @@ -1,6 +1,6 @@ { "name": "@0x/mesh-rpc-client", - "version": "9.4.1", + "version": "9.4.2", "engines": { "node": ">=6.12" },