From 6b6ef84ebcb5d9dabd8841a46510da88ff7dc4aa Mon Sep 17 00:00:00 2001 From: Illia Malachyn Date: Thu, 17 Oct 2024 13:35:57 +0300 Subject: [PATCH 1/8] refactor subscribe func and stream mock object --- access/grpc/convert/convert.go | 8 +- access/grpc/grpc.go | 339 +++++++--------------------- access/grpc/grpc_test.go | 388 +++++++++------------------------ 3 files changed, 199 insertions(+), 536 deletions(-) diff --git a/access/grpc/convert/convert.go b/access/grpc/convert/convert.go index 7b902a184..0fb768ec3 100644 --- a/access/grpc/convert/convert.go +++ b/access/grpc/convert/convert.go @@ -245,12 +245,16 @@ func MessageToBlockHeader(m *entities.BlockHeader) (flow.BlockHeader, error) { }, nil } -func MessageToBlockDigest(m *access.SubscribeBlockDigestsResponse) flow.BlockDigest { +func MessageToBlockDigest(m *access.SubscribeBlockDigestsResponse) (flow.BlockDigest, error) { + if m == nil { + return flow.BlockDigest{}, ErrEmptyMessage + } + return flow.BlockDigest{ BlockID: flow.BytesToID(m.GetBlockId()), Height: m.GetBlockHeight(), Timestamp: m.GetBlockTimestamp().AsTime(), - } + }, nil } func BlockDigestToMessage(blockDigest flow.BlockDigest) *access.SubscribeBlockDigestsResponse { diff --git a/access/grpc/grpc.go b/access/grpc/grpc.go index c2f668908..ef01017c7 100644 --- a/access/grpc/grpc.go +++ b/access/grpc/grpc.go @@ -1188,14 +1188,10 @@ func (c *BaseClient) SubscribeBlocksFromStartBlockID( return nil, nil, newRPCError(err) } - blocksChan := make(chan flow.Block) - errChan := make(chan error) - - go func() { - defer close(blocksChan) - defer close(errChan) - receiveBlocksFromClient(ctx, subscribeClient, blocksChan, errChan) - }() + convertBlockResponse := func(response *access.SubscribeBlocksResponse) (flow.Block, error) { + return convert.MessageToBlock(response.GetBlock()) + } + blocksChan, errChan := subscribe(ctx, subscribeClient.Recv, convertBlockResponse, "block") return blocksChan, errChan, nil } @@ -1221,14 +1217,10 @@ func (c *BaseClient) SubscribeBlocksFromStartHeight( return nil, nil, newRPCError(err) } - blocksChan := make(chan flow.Block) - errChan := make(chan error) - - go func() { - defer close(blocksChan) - defer close(errChan) - receiveBlocksFromClient(ctx, subscribeClient, blocksChan, errChan) - }() + convertBlockResponse := func(response *access.SubscribeBlocksResponse) (flow.Block, error) { + return convert.MessageToBlock(response.GetBlock()) + } + blocksChan, errChan := subscribe(ctx, subscribeClient.Recv, convertBlockResponse, "block") return blocksChan, errChan, nil } @@ -1252,14 +1244,10 @@ func (c *BaseClient) SubscribeBlocksFromLatest( return nil, nil, newRPCError(err) } - blocksChan := make(chan flow.Block) - errChan := make(chan error) - - go func() { - defer close(blocksChan) - defer close(errChan) - receiveBlocksFromClient(ctx, subscribeClient, blocksChan, errChan) - }() + convertBlockResponse := func(response *access.SubscribeBlocksResponse) (flow.Block, error) { + return convert.MessageToBlock(response.GetBlock()) + } + blocksChan, errChan := subscribe(ctx, subscribeClient.Recv, convertBlockResponse, "block") return blocksChan, errChan, nil } @@ -1301,7 +1289,6 @@ func (c *BaseClient) SendAndSubscribeTransactionStatuses( messageIndex := uint64(0) for { - // Receive the next txResult response txResultsResponse, err := subscribeClient.Recv() if err != nil { if err == io.EOF { @@ -1336,48 +1323,6 @@ func (c *BaseClient) SendAndSubscribeTransactionStatuses( return txStatusChan, errChan, nil } -func receiveBlocksFromClient[Client interface { - Recv() (*access.SubscribeBlocksResponse, error) -}]( - ctx context.Context, - client Client, - blocksChan chan<- flow.Block, - errChan chan<- error, -) { - sendErr := func(err error) { - select { - case <-ctx.Done(): - case errChan <- err: - } - } - - for { - // Receive the next block response - blockResponse, err := client.Recv() - if err != nil { - if err == io.EOF { - // End of stream, return gracefully - return - } - - sendErr(fmt.Errorf("error receiving block: %w", err)) - return - } - - block, err := convert.MessageToBlock(blockResponse.GetBlock()) - if err != nil { - sendErr(fmt.Errorf("error converting message to block: %w", err)) - return - } - - select { - case <-ctx.Done(): - return - case blocksChan <- block: - } - } -} - func (c *BaseClient) SubscribeBlockHeadersFromStartBlockID( ctx context.Context, startBlockID flow.Identifier, @@ -1399,14 +1344,10 @@ func (c *BaseClient) SubscribeBlockHeadersFromStartBlockID( return nil, nil, newRPCError(err) } - blockHeaderChan := make(chan flow.BlockHeader) - errChan := make(chan error) - - go func() { - defer close(blockHeaderChan) - defer close(errChan) - receiveBlockHeadersFromClient(ctx, subscribeClient, blockHeaderChan, errChan) - }() + convertBlockHeaderResponse := func(response *access.SubscribeBlockHeadersResponse) (flow.BlockHeader, error) { + return convert.MessageToBlockHeader(response.GetHeader()) + } + blockHeaderChan, errChan := subscribe(ctx, subscribeClient.Recv, convertBlockHeaderResponse, "block header") return blockHeaderChan, errChan, nil } @@ -1432,14 +1373,10 @@ func (c *BaseClient) SubscribeBlockHeadersFromStartHeight( return nil, nil, newRPCError(err) } - blockHeaderChan := make(chan flow.BlockHeader) - errChan := make(chan error) - - go func() { - defer close(blockHeaderChan) - defer close(errChan) - receiveBlockHeadersFromClient(ctx, subscribeClient, blockHeaderChan, errChan) - }() + convertBlockHeaderResponse := func(response *access.SubscribeBlockHeadersResponse) (flow.BlockHeader, error) { + return convert.MessageToBlockHeader(response.GetHeader()) + } + blockHeaderChan, errChan := subscribe(ctx, subscribeClient.Recv, convertBlockHeaderResponse, "block header") return blockHeaderChan, errChan, nil } @@ -1463,58 +1400,12 @@ func (c *BaseClient) SubscribeBlockHeadersFromLatest( return nil, nil, newRPCError(err) } - blockHeaderChan := make(chan flow.BlockHeader) - errChan := make(chan error) - - go func() { - defer close(blockHeaderChan) - defer close(errChan) - receiveBlockHeadersFromClient(ctx, subscribeClient, blockHeaderChan, errChan) - }() - - return blockHeaderChan, errChan, nil -} - -func receiveBlockHeadersFromClient[Client interface { - Recv() (*access.SubscribeBlockHeadersResponse, error) -}]( - ctx context.Context, - client Client, - blockHeadersChan chan<- flow.BlockHeader, - errChan chan<- error, -) { - sendErr := func(err error) { - select { - case <-ctx.Done(): - case errChan <- err: - } + convertBlockHeaderResponse := func(response *access.SubscribeBlockHeadersResponse) (flow.BlockHeader, error) { + return convert.MessageToBlockHeader(response.GetHeader()) } + blockHeaderChan, errChan := subscribe(ctx, subscribeClient.Recv, convertBlockHeaderResponse, "block header") - for { - // Receive the next blockHeader response - blockHeaderResponse, err := client.Recv() - if err != nil { - if err == io.EOF { - // End of stream, return gracefully - return - } - - sendErr(fmt.Errorf("error receiving blockHeader: %w", err)) - return - } - - blockHeader, err := convert.MessageToBlockHeader(blockHeaderResponse.GetHeader()) - if err != nil { - sendErr(fmt.Errorf("error converting message to block header: %w", err)) - return - } - - select { - case <-ctx.Done(): - return - case blockHeadersChan <- blockHeader: - } - } + return blockHeaderChan, errChan, nil } func (c *BaseClient) SubscribeAccountStatusesFromStartHeight( @@ -1537,14 +1428,10 @@ func (c *BaseClient) SubscribeAccountStatusesFromStartHeight( return nil, nil, newRPCError(err) } - accountStatutesChan := make(chan flow.AccountStatus) - errChan := make(chan error) - - go func() { - defer close(accountStatutesChan) - defer close(errChan) - receiveAccountStatusesFromStream(ctx, subscribeClient, accountStatutesChan, errChan) - }() + convertAccountStatusResponse := func(response *executiondata.SubscribeAccountStatusesResponse) (flow.AccountStatus, error) { + return convert.MessageToAccountStatus(response) + } + accountStatutesChan, errChan := subscribe(ctx, subscribeClient.Recv, convertAccountStatusResponse, "account status") return accountStatutesChan, errChan, nil } @@ -1569,14 +1456,10 @@ func (c *BaseClient) SubscribeAccountStatusesFromStartBlockID( return nil, nil, newRPCError(err) } - accountStatutesChan := make(chan flow.AccountStatus) - errChan := make(chan error) - - go func() { - defer close(accountStatutesChan) - defer close(errChan) - receiveAccountStatusesFromStream(ctx, subscribeClient, accountStatutesChan, errChan) - }() + convertAccountStatusResponse := func(response *executiondata.SubscribeAccountStatusesResponse) (flow.AccountStatus, error) { + return convert.MessageToAccountStatus(response) + } + accountStatutesChan, errChan := subscribe(ctx, subscribeClient.Recv, convertAccountStatusResponse, "account status") return accountStatutesChan, errChan, nil } @@ -1599,64 +1482,12 @@ func (c *BaseClient) SubscribeAccountStatusesFromLatestBlock( return nil, nil, newRPCError(err) } - accountStatutesChan := make(chan flow.AccountStatus) - errChan := make(chan error) - - go func() { - defer close(accountStatutesChan) - defer close(errChan) - receiveAccountStatusesFromStream(ctx, subscribeClient, accountStatutesChan, errChan) - }() - - return accountStatutesChan, errChan, nil -} - -func receiveAccountStatusesFromStream[Stream interface { - Recv() (*executiondata.SubscribeAccountStatusesResponse, error) -}]( - ctx context.Context, - stream Stream, - accountStatutesChan chan<- flow.AccountStatus, - errChan chan<- error, -) { - sendErr := func(err error) { - select { - case <-ctx.Done(): - case errChan <- err: - } + convertAccountStatusResponse := func(response *executiondata.SubscribeAccountStatusesResponse) (flow.AccountStatus, error) { + return convert.MessageToAccountStatus(response) } + accountStatutesChan, errChan := subscribe(ctx, subscribeClient.Recv, convertAccountStatusResponse, "account status") - var nextExpectedMsgIndex uint64 - for { - accountStatusResponse, err := stream.Recv() - if err != nil { - if err == io.EOF { - // End of stream, return gracefully - return - } - - sendErr(fmt.Errorf("error receiving account status: %w", err)) - return - } - - accountStatus, err := convert.MessageToAccountStatus(accountStatusResponse) - if err != nil { - sendErr(fmt.Errorf("error converting message to account status: %w", err)) - return - } - - if accountStatus.MessageIndex != nextExpectedMsgIndex { - sendErr(fmt.Errorf("message received out of order")) - return - } - nextExpectedMsgIndex = accountStatus.MessageIndex + 1 - - select { - case <-ctx.Done(): - return - case accountStatutesChan <- accountStatus: - } - } + return accountStatutesChan, errChan, nil } func (c *BaseClient) SubscribeBlockDigestsFromStartBlockID( @@ -1680,16 +1511,12 @@ func (c *BaseClient) SubscribeBlockDigestsFromStartBlockID( return nil, nil, newRPCError(err) } - blocksChan := make(chan flow.BlockDigest) - errChan := make(chan error) - - go func() { - defer close(blocksChan) - defer close(errChan) - receiveBlockDigestFromClient(ctx, subscribeClient, blocksChan, errChan) - }() + convertBlockDigestResponse := func(response *access.SubscribeBlockDigestsResponse) (flow.BlockDigest, error) { + return convert.MessageToBlockDigest(response) + } + blockDigestChan, errChan := subscribe(ctx, subscribeClient.Recv, convertBlockDigestResponse, "block digest") - return blocksChan, errChan, nil + return blockDigestChan, errChan, nil } func (c *BaseClient) SubscribeBlockDigestsFromStartHeight( @@ -1713,16 +1540,12 @@ func (c *BaseClient) SubscribeBlockDigestsFromStartHeight( return nil, nil, newRPCError(err) } - blocksChan := make(chan flow.BlockDigest) - errChan := make(chan error) - - go func() { - defer close(blocksChan) - defer close(errChan) - receiveBlockDigestFromClient(ctx, subscribeClient, blocksChan, errChan) - }() + convertBlockDigestResponse := func(response *access.SubscribeBlockDigestsResponse) (flow.BlockDigest, error) { + return convert.MessageToBlockDigest(response) + } + blockDigestChan, errChan := subscribe(ctx, subscribeClient.Recv, convertBlockDigestResponse, "block digest") - return blocksChan, errChan, nil + return blockDigestChan, errChan, nil } func (c *BaseClient) SubscribeBlockDigestsFromLatest( @@ -1744,26 +1567,23 @@ func (c *BaseClient) SubscribeBlockDigestsFromLatest( return nil, nil, newRPCError(err) } - blocksChan := make(chan flow.BlockDigest) - errChan := make(chan error) - - go func() { - defer close(blocksChan) - defer close(errChan) - receiveBlockDigestFromClient(ctx, subscribeClient, blocksChan, errChan) - }() + convertBlockDigestResponse := func(response *access.SubscribeBlockDigestsResponse) (flow.BlockDigest, error) { + return convert.MessageToBlockDigest(response) + } + blockDigestChan, errChan := subscribe(ctx, subscribeClient.Recv, convertBlockDigestResponse, "block digest") - return blocksChan, errChan, nil + return blockDigestChan, errChan, nil } -func receiveBlockDigestFromClient[Client interface { - Recv() (*access.SubscribeBlockDigestsResponse, error) -}]( +func subscribe[Response any, ClientResponse any]( ctx context.Context, - client Client, - blockDigestsChan chan<- flow.BlockDigest, - errChan chan<- error, -) { + receive func() (*ClientResponse, error), + convertResponse func(*ClientResponse) (Response, error), + topicNameForErrors string, +) (chan Response, chan error) { + subChan := make(chan Response) + errChan := make(chan error) + sendErr := func(err error) { select { case <-ctx.Done(): @@ -1771,25 +1591,34 @@ func receiveBlockDigestFromClient[Client interface { } } - for { - // Receive the next blockDigest response - blockDigestResponse, err := client.Recv() - if err != nil { - if err == io.EOF { - // End of stream, return gracefully + go func() { + defer close(subChan) + defer close(errChan) + + for { + resp, err := receive() + if err != nil { + if err == io.EOF { + return + } + + sendErr(fmt.Errorf("error receiving %s: %w", topicNameForErrors, err)) return } - sendErr(fmt.Errorf("error receiving blockDigest: %w", err)) - return - } - - blockDigest := convert.MessageToBlockDigest(blockDigestResponse) + response, err := convertResponse(resp) + if err != nil { + sendErr(fmt.Errorf("error converting %s: %w", topicNameForErrors, err)) + return + } - select { - case <-ctx.Done(): - return - case blockDigestsChan <- blockDigest: + select { + case <-ctx.Done(): + return + case subChan <- response: + } } - } + }() + + return subChan, errChan } diff --git a/access/grpc/grpc_test.go b/access/grpc/grpc_test.go index 30844d9a7..d92a8a039 100644 --- a/access/grpc/grpc_test.go +++ b/access/grpc/grpc_test.go @@ -1734,6 +1734,28 @@ func TestClient_GetExecutionResultByID(t *testing.T) { } func TestClient_SubscribeExecutionData(t *testing.T) { + generateExecutionDataResponse := func(t *testing.T, blockID flow.Identifier, height uint64) *executiondata.SubscribeExecutionDataResponse { + return &executiondata.SubscribeExecutionDataResponse{ + BlockHeight: height, + BlockExecutionData: &entities.BlockExecutionData{ + BlockId: blockID[:], + ChunkExecutionData: []*entities.ChunkExecutionData{}, + }, + BlockTimestamp: timestamppb.Now(), + } + } + + assertSubscribeExecutionDataArgs := func(t *testing.T, expected *executiondata.SubscribeExecutionDataRequest) func(args mock.Arguments) { + return func(args mock.Arguments) { + actual, ok := args.Get(1).(*executiondata.SubscribeExecutionDataRequest) + require.True(t, ok) + + assert.Equal(t, expected.EventEncodingVersion, actual.EventEncodingVersion) + assert.Equal(t, expected.StartBlockHeight, actual.StartBlockHeight) + assert.Equal(t, expected.StartBlockId, actual.StartBlockId) + } + } + ids := test.IdentifierGenerator() t.Run("Happy Path - by height", executionDataClientTest(func(t *testing.T, ctx context.Context, rpc *mocks.MockExecutionDataRPCClient, c *BaseClient) { @@ -1746,7 +1768,7 @@ func TestClient_SubscribeExecutionData(t *testing.T) { } ctx, cancel := context.WithCancel(ctx) - stream := &mockExecutionDataStream{ctx: ctx} + stream := &mockClientStream[executiondata.SubscribeExecutionDataResponse]{ctx: ctx} for i := startHeight; i < startHeight+responseCount; i++ { stream.responses = append(stream.responses, generateExecutionDataResponse(t, ids.New(), i)) } @@ -1788,7 +1810,7 @@ func TestClient_SubscribeExecutionData(t *testing.T) { } ctx, cancel := context.WithCancel(ctx) - stream := &mockExecutionDataStream{ctx: ctx} + stream := &mockClientStream[executiondata.SubscribeExecutionDataResponse]{ctx: ctx} for i := startHeight; i < startHeight+responseCount; i++ { stream.responses = append(stream.responses, generateExecutionDataResponse(t, ids.New(), i)) } @@ -1828,7 +1850,7 @@ func TestClient_SubscribeExecutionData(t *testing.T) { EventEncodingVersion: entities.EventEncodingVersion_CCF_V0, } - stream := &mockExecutionDataStream{ + stream := &mockClientStream[executiondata.SubscribeExecutionDataResponse]{ err: status.Error(codes.Internal, "internal error"), } @@ -1841,7 +1863,7 @@ func TestClient_SubscribeExecutionData(t *testing.T) { wg := sync.WaitGroup{} wg.Add(1) - go assertNoEvents(t, eventCh, wg.Done) + go assertNoData(t, eventCh, wg.Done, "events") i := 0 for err := range errCh { @@ -1864,7 +1886,7 @@ func TestClient_SubscribeExecutionData(t *testing.T) { EventEncodingVersion: entities.EventEncodingVersion_CCF_V0, } - stream := &mockExecutionDataStream{ctx: ctx} + stream := &mockClientStream[executiondata.SubscribeExecutionDataResponse]{ctx: ctx} stream.responses = append(stream.responses, &executiondata.SubscribeExecutionDataResponse{ BlockHeight: startHeight, BlockExecutionData: nil, // nil BlockExecutionData should cause an error @@ -1879,7 +1901,7 @@ func TestClient_SubscribeExecutionData(t *testing.T) { wg := sync.WaitGroup{} wg.Add(1) - go assertNoEvents(t, eventCh, wg.Done) + go assertNoData(t, eventCh, wg.Done, "events") i := 0 for err := range errCh { @@ -1907,6 +1929,34 @@ func TestClient_SubscribeEvents(t *testing.T) { return res } + generateEventResponse := func(t *testing.T, blockID flow.Identifier, height uint64, events []flow.Event, encoding flow.EventEncodingVersion) *executiondata.SubscribeEventsResponse { + responseEvents := make([]*entities.Event, 0, len(events)) + for _, e := range events { + eventMsg, err := convert.EventToMessage(e, encoding) + require.NoError(t, err) + responseEvents = append(responseEvents, eventMsg) + } + + return &executiondata.SubscribeEventsResponse{ + BlockHeight: height, + BlockId: blockID[:], + Events: responseEvents, + } + } + + assertSubscribeEventsArgs := func(t *testing.T, expected *executiondata.SubscribeEventsRequest) func(args mock.Arguments) { + return func(args mock.Arguments) { + actual, ok := args.Get(1).(*executiondata.SubscribeEventsRequest) + require.True(t, ok) + + assert.Equal(t, expected.Filter, actual.Filter) + assert.Equal(t, expected.EventEncodingVersion, actual.EventEncodingVersion) + assert.Equal(t, expected.HeartbeatInterval, actual.HeartbeatInterval) + assert.Equal(t, expected.StartBlockHeight, actual.StartBlockHeight) + assert.Equal(t, expected.StartBlockId, actual.StartBlockId) + } + } + t.Run("Happy Path - by height", executionDataClientTest(func(t *testing.T, ctx context.Context, rpc *mocks.MockExecutionDataRPCClient, c *BaseClient) { responseCount := uint64(1000) startHeight := uint64(10) @@ -1928,7 +1978,7 @@ func TestClient_SubscribeEvents(t *testing.T) { } ctx, cancel := context.WithCancel(ctx) - stream := &mockEventStream{ctx: ctx} + stream := &mockClientStream[executiondata.SubscribeEventsResponse]{ctx: ctx} for i := startHeight; i < startHeight+responseCount; i++ { stream.responses = append(stream.responses, generateEventResponse(t, ids.New(), i, getEvents(2), flow.EventEncodingVersionCCF)) } @@ -1981,7 +2031,7 @@ func TestClient_SubscribeEvents(t *testing.T) { } ctx, cancel := context.WithCancel(ctx) - stream := &mockEventStream{ctx: ctx} + stream := &mockClientStream[executiondata.SubscribeEventsResponse]{ctx: ctx} for i := startHeight; i < startHeight+responseCount; i++ { stream.responses = append(stream.responses, generateEventResponse(t, ids.New(), i, getEvents(2), flow.EventEncodingVersionCCF)) } @@ -2028,7 +2078,7 @@ func TestClient_SubscribeEvents(t *testing.T) { StartBlockHeight: startHeight, } - stream := &mockEventStream{ + stream := &mockClientStream[executiondata.SubscribeEventsResponse]{ err: status.Error(codes.Internal, "internal error"), } @@ -2041,7 +2091,7 @@ func TestClient_SubscribeEvents(t *testing.T) { wg := sync.WaitGroup{} wg.Add(1) - go assertNoEvents(t, eventCh, wg.Done) + go assertNoData(t, eventCh, wg.Done, "events") i := 0 for err := range errCh { @@ -2071,7 +2121,7 @@ func TestClient_SubscribeEvents(t *testing.T) { StartBlockHeight: startHeight, } - stream := &mockEventStream{ctx: ctx} + stream := &mockClientStream[executiondata.SubscribeEventsResponse]{ctx: ctx} stream.responses = append(stream.responses, generateEventResponse(t, ids.New(), startHeight, getEvents(2), flow.EventEncodingVersionCCF)) // corrupt the event payload @@ -2086,7 +2136,7 @@ func TestClient_SubscribeEvents(t *testing.T) { wg := sync.WaitGroup{} wg.Add(1) - go assertNoEvents(t, eventCh, wg.Done) + go assertNoData(t, eventCh, wg.Done, "events") i := 0 for err := range errCh { @@ -2134,7 +2184,7 @@ func TestClient_SubscribeAccountStatuses(t *testing.T) { responseCount := uint64(100) ctx, cancel := context.WithCancel(ctx) - stream := &mockAccountStatutesClientStream{ + stream := &mockClientStream[executiondata.SubscribeAccountStatusesResponse]{ ctx: ctx, responses: generateAccountStatusesResponses(responseCount), } @@ -2175,7 +2225,7 @@ func TestClient_SubscribeAccountStatuses(t *testing.T) { responseCount := uint64(100) ctx, cancel := context.WithCancel(ctx) - stream := &mockAccountStatutesClientStream{ + stream := &mockClientStream[executiondata.SubscribeAccountStatusesResponse]{ ctx: ctx, responses: generateAccountStatusesResponses(responseCount), } @@ -2217,7 +2267,7 @@ func TestClient_SubscribeAccountStatuses(t *testing.T) { responseCount := uint64(100) ctx, cancel := context.WithCancel(ctx) - stream := &mockAccountStatutesClientStream{ + stream := &mockClientStream[executiondata.SubscribeAccountStatusesResponse]{ ctx: ctx, responses: generateAccountStatusesResponses(responseCount), } @@ -2256,7 +2306,7 @@ func TestClient_SubscribeAccountStatuses(t *testing.T) { t.Run("Stream returns error", executionDataClientTest(func(t *testing.T, ctx context.Context, rpc *mocks.MockExecutionDataRPCClient, c *BaseClient) { ctx, cancel := context.WithCancel(ctx) - stream := &mockAccountStatutesClientStream{ + stream := &mockClientStream[executiondata.SubscribeAccountStatusesResponse]{ ctx: ctx, err: status.Error(codes.Internal, "internal error"), } @@ -2270,7 +2320,7 @@ func TestClient_SubscribeAccountStatuses(t *testing.T) { wg := sync.WaitGroup{} wg.Add(1) - go assertNoAccountStatuses(t, accountStatuses, wg.Done) + go assertNoData(t, accountStatuses, wg.Done, "account statuses") errorCount := 0 for e := range errCh { @@ -2295,7 +2345,7 @@ func TestClient_SubscribeAccountStatuses(t *testing.T) { ctx, cancel := context.WithCancel(ctx) defer cancel() - stream := &mockAccountStatutesClientStream{ + stream := &mockClientStream[executiondata.SubscribeAccountStatusesResponse]{ ctx: ctx, err: status.Error(codes.Internal, "message received out of order"), responses: generateUnorderedAccountStatusesResponses(2), @@ -2338,123 +2388,6 @@ func TestClient_SubscribeAccountStatuses(t *testing.T) { })) } -func generateEventResponse(t *testing.T, blockID flow.Identifier, height uint64, events []flow.Event, encoding flow.EventEncodingVersion) *executiondata.SubscribeEventsResponse { - responseEvents := make([]*entities.Event, 0, len(events)) - for _, e := range events { - eventMsg, err := convert.EventToMessage(e, encoding) - require.NoError(t, err) - responseEvents = append(responseEvents, eventMsg) - } - - return &executiondata.SubscribeEventsResponse{ - BlockHeight: height, - BlockId: blockID[:], - Events: responseEvents, - } -} - -func generateExecutionDataResponse(t *testing.T, blockID flow.Identifier, height uint64) *executiondata.SubscribeExecutionDataResponse { - return &executiondata.SubscribeExecutionDataResponse{ - BlockHeight: height, - BlockExecutionData: &entities.BlockExecutionData{ - BlockId: blockID[:], - ChunkExecutionData: []*entities.ChunkExecutionData{}, - }, - BlockTimestamp: timestamppb.Now(), - } -} - -func assertSubscribeEventsArgs(t *testing.T, expected *executiondata.SubscribeEventsRequest) func(args mock.Arguments) { - return func(args mock.Arguments) { - actual, ok := args.Get(1).(*executiondata.SubscribeEventsRequest) - require.True(t, ok) - - assert.Equal(t, expected.Filter, actual.Filter) - assert.Equal(t, expected.EventEncodingVersion, actual.EventEncodingVersion) - assert.Equal(t, expected.HeartbeatInterval, actual.HeartbeatInterval) - assert.Equal(t, expected.StartBlockHeight, actual.StartBlockHeight) - assert.Equal(t, expected.StartBlockId, actual.StartBlockId) - } -} - -func assertSubscribeExecutionDataArgs(t *testing.T, expected *executiondata.SubscribeExecutionDataRequest) func(args mock.Arguments) { - return func(args mock.Arguments) { - actual, ok := args.Get(1).(*executiondata.SubscribeExecutionDataRequest) - require.True(t, ok) - - assert.Equal(t, expected.EventEncodingVersion, actual.EventEncodingVersion) - assert.Equal(t, expected.StartBlockHeight, actual.StartBlockHeight) - assert.Equal(t, expected.StartBlockId, actual.StartBlockId) - } -} - -func assertNoErrors(t *testing.T, errCh <-chan error, done func()) { - defer done() - for err := range errCh { - require.NoError(t, err) - } -} - -func assertNoEvents[T any](t *testing.T, eventCh <-chan T, done func()) { - defer done() - for range eventCh { - t.Fatal("should not receive events") - } -} - -func assertNoAccountStatuses(t *testing.T, accountStatusesChan <-chan flow.AccountStatus, done func()) { - defer done() - for range accountStatusesChan { - require.FailNow(t, "should not receive account statuses") - } -} - -type mockEventStream struct { - grpc.ClientStream - - ctx context.Context - err error - offset int - responses []*executiondata.SubscribeEventsResponse -} - -func (m *mockEventStream) Recv() (*executiondata.SubscribeEventsResponse, error) { - if m.err != nil { - return nil, m.err - } - - if m.offset >= len(m.responses) { - <-m.ctx.Done() - return nil, io.EOF - } - defer func() { m.offset++ }() - - return m.responses[m.offset], nil -} - -type mockExecutionDataStream struct { - grpc.ClientStream - - ctx context.Context - err error - offset int - responses []*executiondata.SubscribeExecutionDataResponse -} - -func (m *mockExecutionDataStream) Recv() (*executiondata.SubscribeExecutionDataResponse, error) { - if m.err != nil { - return nil, m.err - } - - if m.offset >= len(m.responses) { - <-m.ctx.Done() - return nil, io.EOF - } - defer func() { m.offset++ }() - - return m.responses[m.offset], nil -} - func TestClient_SubscribeBlocks(t *testing.T) { blocks := test.BlockGenerator() @@ -2478,7 +2411,7 @@ func TestClient_SubscribeBlocks(t *testing.T) { responseCount := uint64(100) ctx, cancel := context.WithCancel(ctx) - stream := &mockBlockClientStream[access.SubscribeBlocksResponse]{ + stream := &mockClientStream[access.SubscribeBlocksResponse]{ ctx: ctx, responses: generateBlockResponses(responseCount), } @@ -2509,7 +2442,7 @@ func TestClient_SubscribeBlocks(t *testing.T) { responseCount := uint64(100) ctx, cancel := context.WithCancel(ctx) - stream := &mockBlockClientStream[access.SubscribeBlocksResponse]{ + stream := &mockClientStream[access.SubscribeBlocksResponse]{ ctx: ctx, responses: generateBlockResponses(responseCount), } @@ -2541,7 +2474,7 @@ func TestClient_SubscribeBlocks(t *testing.T) { responseCount := uint64(100) ctx, cancel := context.WithCancel(ctx) - stream := &mockBlockClientStream[access.SubscribeBlocksResponse]{ + stream := &mockClientStream[access.SubscribeBlocksResponse]{ ctx: ctx, responses: generateBlockResponses(responseCount), } @@ -2571,7 +2504,7 @@ func TestClient_SubscribeBlocks(t *testing.T) { t.Run("Stream returns error", clientTest(func(t *testing.T, ctx context.Context, rpc *mocks.MockRPCClient, c *BaseClient) { ctx, cancel := context.WithCancel(ctx) defer cancel() - stream := &mockBlockClientStream[access.SubscribeBlocksResponse]{ + stream := &mockClientStream[access.SubscribeBlocksResponse]{ ctx: ctx, err: status.Error(codes.Internal, "internal error"), } @@ -2585,7 +2518,7 @@ func TestClient_SubscribeBlocks(t *testing.T) { wg := sync.WaitGroup{} wg.Add(1) - go assertNoBlocks(t, blockCh, wg.Done) + go assertNoData(t, blockCh, wg.Done, "blocks") errorCount := 0 for e := range errCh { @@ -2599,36 +2532,6 @@ func TestClient_SubscribeBlocks(t *testing.T) { })) } -type mockBlockClientStream[SubscribeBlocksResponse any] struct { - grpc.ClientStream - - ctx context.Context - err error - offset int - responses []*SubscribeBlocksResponse -} - -func (s *mockBlockClientStream[SubscribeBlocksResponse]) Recv() (*SubscribeBlocksResponse, error) { - if s.err != nil { - return nil, s.err - } - - if s.offset >= len(s.responses) { - <-s.ctx.Done() - return nil, io.EOF - } - defer func() { s.offset++ }() - - return s.responses[s.offset], nil -} - -func assertNoBlocks[T any](t *testing.T, blocksCh <-chan T, done func()) { - defer done() - for range blocksCh { - require.FailNow(t, "should not receive blocks") - } -} - func TestClient_SendAndSubscribeTransactionStatuses(t *testing.T) { transactions := test.TransactionGenerator() @@ -2656,7 +2559,7 @@ func TestClient_SendAndSubscribeTransactionStatuses(t *testing.T) { tx := transactions.New() ctx, cancel := context.WithCancel(ctx) - stream := &mockTransactionStatusesClientStream{ + stream := &mockClientStream[access.SendAndSubscribeTransactionStatusesResponse]{ ctx: ctx, responses: generateTransactionStatusResponses(responseCount, flow.EventEncodingVersionCCF), } @@ -2691,7 +2594,7 @@ func TestClient_SendAndSubscribeTransactionStatuses(t *testing.T) { tx := transactions.New() ctx, cancel := context.WithCancel(ctx) - stream := &mockTransactionStatusesClientStream{ + stream := &mockClientStream[access.SendAndSubscribeTransactionStatusesResponse]{ ctx: ctx, responses: generateTransactionStatusResponses(responseCount, flow.EventEncodingVersionJSONCDC), } @@ -2722,7 +2625,7 @@ func TestClient_SendAndSubscribeTransactionStatuses(t *testing.T) { t.Run("Stream returns error", clientTest(func(t *testing.T, ctx context.Context, rpc *mocks.MockRPCClient, c *BaseClient) { ctx, cancel := context.WithCancel(ctx) - stream := &mockTransactionStatusesClientStream{ + stream := &mockClientStream[access.SendAndSubscribeTransactionStatusesResponse]{ ctx: ctx, err: status.Error(codes.Internal, "internal error"), } @@ -2736,7 +2639,7 @@ func TestClient_SendAndSubscribeTransactionStatuses(t *testing.T) { wg := sync.WaitGroup{} wg.Add(1) - go assertNoTxResults(t, txResultChan, wg.Done) + go assertNoData(t, txResultChan, wg.Done, "transaction statutes") errorCount := 0 for e := range errCh { @@ -2753,36 +2656,6 @@ func TestClient_SendAndSubscribeTransactionStatuses(t *testing.T) { } -type mockTransactionStatusesClientStream struct { - grpc.ClientStream - - ctx context.Context - err error - offset int - responses []*access.SendAndSubscribeTransactionStatusesResponse -} - -func (m *mockTransactionStatusesClientStream) Recv() (*access.SendAndSubscribeTransactionStatusesResponse, error) { - if m.err != nil { - return nil, m.err - } - - if m.offset >= len(m.responses) { - <-m.ctx.Done() - return nil, io.EOF - } - defer func() { m.offset++ }() - - return m.responses[m.offset], nil -} - -func assertNoTxResults[TxStatus any](t *testing.T, txResultChan <-chan TxStatus, done func()) { - defer done() - for range txResultChan { - require.FailNow(t, "should not receive txStatus") - } -} - func TestClient_SubscribeBlockHeaders(t *testing.T) { blockHeaders := test.BlockHeaderGenerator() @@ -2806,7 +2679,7 @@ func TestClient_SubscribeBlockHeaders(t *testing.T) { responseCount := uint64(100) ctx, cancel := context.WithCancel(ctx) - stream := &mockBlockHeaderClientStream[access.SubscribeBlockHeadersResponse]{ + stream := &mockClientStream[access.SubscribeBlockHeadersResponse]{ ctx: ctx, responses: generateBlockHeaderResponses(responseCount), } @@ -2837,7 +2710,7 @@ func TestClient_SubscribeBlockHeaders(t *testing.T) { responseCount := uint64(100) ctx, cancel := context.WithCancel(ctx) - stream := &mockBlockHeaderClientStream[access.SubscribeBlockHeadersResponse]{ + stream := &mockClientStream[access.SubscribeBlockHeadersResponse]{ ctx: ctx, responses: generateBlockHeaderResponses(responseCount), } @@ -2869,7 +2742,7 @@ func TestClient_SubscribeBlockHeaders(t *testing.T) { responseCount := uint64(100) ctx, cancel := context.WithCancel(ctx) - stream := &mockBlockHeaderClientStream[access.SubscribeBlockHeadersResponse]{ + stream := &mockClientStream[access.SubscribeBlockHeadersResponse]{ ctx: ctx, responses: generateBlockHeaderResponses(responseCount), } @@ -2898,7 +2771,7 @@ func TestClient_SubscribeBlockHeaders(t *testing.T) { t.Run("Stream returns error", clientTest(func(t *testing.T, ctx context.Context, rpc *mocks.MockRPCClient, c *BaseClient) { ctx, cancel := context.WithCancel(ctx) - stream := &mockBlockHeaderClientStream[access.SubscribeBlockHeadersResponse]{ + stream := &mockClientStream[access.SubscribeBlockHeadersResponse]{ ctx: ctx, err: status.Error(codes.Internal, "internal error"), } @@ -2912,7 +2785,7 @@ func TestClient_SubscribeBlockHeaders(t *testing.T) { wg := sync.WaitGroup{} wg.Add(1) - go assertNoBlockHeaders(t, blockHeadersCh, wg.Done) + go assertNoData(t, blockHeadersCh, wg.Done, "block headers") errorCount := 0 for e := range errCh { @@ -2928,36 +2801,6 @@ func TestClient_SubscribeBlockHeaders(t *testing.T) { })) } -type mockBlockHeaderClientStream[SubscribeBlockHeadersResponse any] struct { - grpc.ClientStream - - ctx context.Context - err error - offset int - responses []*SubscribeBlockHeadersResponse -} - -func (s *mockBlockHeaderClientStream[SubscribeBlockHeadersResponse]) Recv() (*SubscribeBlockHeadersResponse, error) { - if s.err != nil { - return nil, s.err - } - - if s.offset >= len(s.responses) { - <-s.ctx.Done() - return nil, io.EOF - } - defer func() { s.offset++ }() - - return s.responses[s.offset], nil -} - -func assertNoBlockHeaders[BlockHeader any](t *testing.T, blockHeadersChan <-chan BlockHeader, done func()) { - defer done() - for range blockHeadersChan { - require.FailNow(t, "should not receive block headers") - } -} - func TestClient_SubscribeBlockDigest(t *testing.T) { blockHeaders := test.BlockHeaderGenerator() @@ -2984,7 +2827,7 @@ func TestClient_SubscribeBlockDigest(t *testing.T) { responseCount := uint64(100) ctx, cancel := context.WithCancel(ctx) - stream := &mockBlockDigestClientStream[access.SubscribeBlockDigestsResponse]{ + stream := &mockClientStream[access.SubscribeBlockDigestsResponse]{ ctx: ctx, responses: generateBlockDigestResponses(responseCount), } @@ -3002,7 +2845,8 @@ func TestClient_SubscribeBlockDigest(t *testing.T) { for i := uint64(0); i < responseCount; i++ { actualDigest := <-blockDigestsCh - expectedDigest := convert.MessageToBlockDigest(stream.responses[i]) + expectedDigest, err := convert.MessageToBlockDigest(stream.responses[i]) + require.NoError(t, err) require.Equal(t, expectedDigest, actualDigest) } cancel() @@ -3014,7 +2858,7 @@ func TestClient_SubscribeBlockDigest(t *testing.T) { responseCount := uint64(100) ctx, cancel := context.WithCancel(ctx) - stream := &mockBlockDigestClientStream[access.SubscribeBlockDigestsResponse]{ + stream := &mockClientStream[access.SubscribeBlockDigestsResponse]{ ctx: ctx, responses: generateBlockDigestResponses(responseCount), } @@ -3033,7 +2877,8 @@ func TestClient_SubscribeBlockDigest(t *testing.T) { for i := uint64(0); i < responseCount; i++ { actualDigest := <-blockDigestsCh - expectedDigest := convert.MessageToBlockDigest(stream.responses[i]) + expectedDigest, err := convert.MessageToBlockDigest(stream.responses[i]) + require.NoError(t, err) require.Equal(t, expectedDigest, actualDigest) } cancel() @@ -3045,7 +2890,7 @@ func TestClient_SubscribeBlockDigest(t *testing.T) { responseCount := uint64(100) ctx, cancel := context.WithCancel(ctx) - stream := &mockBlockDigestClientStream[access.SubscribeBlockDigestsResponse]{ + stream := &mockClientStream[access.SubscribeBlockDigestsResponse]{ ctx: ctx, responses: generateBlockDigestResponses(responseCount), } @@ -3063,7 +2908,8 @@ func TestClient_SubscribeBlockDigest(t *testing.T) { for i := uint64(0); i < responseCount; i++ { actualDigest := <-blockDigestsCh - expectedDigest := convert.MessageToBlockDigest(stream.responses[i]) + expectedDigest, err := convert.MessageToBlockDigest(stream.responses[i]) + require.NoError(t, err) require.Equal(t, expectedDigest, actualDigest) } cancel() @@ -3073,7 +2919,7 @@ func TestClient_SubscribeBlockDigest(t *testing.T) { t.Run("Stream returns error", clientTest(func(t *testing.T, ctx context.Context, rpc *mocks.MockRPCClient, c *BaseClient) { ctx, cancel := context.WithCancel(ctx) - stream := &mockBlockDigestClientStream[access.SubscribeBlockDigestsResponse]{ + stream := &mockClientStream[access.SubscribeBlockDigestsResponse]{ ctx: ctx, err: status.Error(codes.Internal, "internal error"), } @@ -3087,7 +2933,7 @@ func TestClient_SubscribeBlockDigest(t *testing.T) { wg := sync.WaitGroup{} wg.Add(1) - go assertNoBlockDigests(t, blockDigestsCh, wg.Done) + go assertNoData(t, blockDigestsCh, wg.Done, "block digests") errorCount := 0 for e := range errCh { @@ -3103,55 +2949,39 @@ func TestClient_SubscribeBlockDigest(t *testing.T) { })) } -type mockBlockDigestClientStream[SubscribeBlockDigestsResponse any] struct { - grpc.ClientStream - - ctx context.Context - err error - offset int - responses []*SubscribeBlockDigestsResponse -} - -func (s *mockBlockDigestClientStream[SubscribeBlockDigestsResponse]) Recv() (*SubscribeBlockDigestsResponse, error) { - if s.err != nil { - return nil, s.err - } - - if s.offset >= len(s.responses) { - <-s.ctx.Done() - return nil, io.EOF +func assertNoErrors(t *testing.T, errCh <-chan error, done func()) { + defer done() + for err := range errCh { + require.NoError(t, err) } - defer func() { s.offset++ }() - - return s.responses[s.offset], nil } -func assertNoBlockDigests[BlockDigest any](t *testing.T, blockDigestsChan <-chan BlockDigest, done func()) { +func assertNoData[T any](t *testing.T, dataCh <-chan T, done func(), topicNameForError string) { defer done() - for range blockDigestsChan { - require.FailNow(t, "should not receive block digests") + for range dataCh { + t.Fatalf("should not receive %s", topicNameForError) } } -type mockAccountStatutesClientStream struct { +type mockClientStream[Response any] struct { grpc.ClientStream ctx context.Context err error offset int - responses []*executiondata.SubscribeAccountStatusesResponse + responses []*Response } -func (m *mockAccountStatutesClientStream) Recv() (*executiondata.SubscribeAccountStatusesResponse, error) { - if m.err != nil { - return nil, m.err +func (s *mockClientStream[Response]) Recv() (*Response, error) { + if s.err != nil { + return nil, s.err } - if m.offset >= len(m.responses) { - <-m.ctx.Done() + if s.offset >= len(s.responses) { + <-s.ctx.Done() return nil, io.EOF } - defer func() { m.offset++ }() + defer func() { s.offset++ }() - return m.responses[m.offset], nil + return s.responses[s.offset], nil } From 5ba2321801ab95108a4face14aef9c2db7389e68 Mon Sep 17 00:00:00 2001 From: Illia Malachyn Date: Tue, 22 Oct 2024 17:07:09 +0300 Subject: [PATCH 2/8] replace topic for errors with obj type name --- access/grpc/grpc.go | 46 +++++++++++++++++---------------------------- examples/go.mod | 2 +- examples/go.sum | 1 + 3 files changed, 19 insertions(+), 30 deletions(-) diff --git a/access/grpc/grpc.go b/access/grpc/grpc.go index ef01017c7..3c0e2a8b1 100644 --- a/access/grpc/grpc.go +++ b/access/grpc/grpc.go @@ -26,6 +26,7 @@ import ( "errors" "fmt" "io" + "reflect" "github.com/onflow/flow/protobuf/go/flow/entities" "google.golang.org/grpc" @@ -1191,9 +1192,8 @@ func (c *BaseClient) SubscribeBlocksFromStartBlockID( convertBlockResponse := func(response *access.SubscribeBlocksResponse) (flow.Block, error) { return convert.MessageToBlock(response.GetBlock()) } - blocksChan, errChan := subscribe(ctx, subscribeClient.Recv, convertBlockResponse, "block") - return blocksChan, errChan, nil + return subscribe(ctx, subscribeClient.Recv, convertBlockResponse) } func (c *BaseClient) SubscribeBlocksFromStartHeight( @@ -1220,9 +1220,8 @@ func (c *BaseClient) SubscribeBlocksFromStartHeight( convertBlockResponse := func(response *access.SubscribeBlocksResponse) (flow.Block, error) { return convert.MessageToBlock(response.GetBlock()) } - blocksChan, errChan := subscribe(ctx, subscribeClient.Recv, convertBlockResponse, "block") - return blocksChan, errChan, nil + return subscribe(ctx, subscribeClient.Recv, convertBlockResponse) } func (c *BaseClient) SubscribeBlocksFromLatest( @@ -1247,9 +1246,8 @@ func (c *BaseClient) SubscribeBlocksFromLatest( convertBlockResponse := func(response *access.SubscribeBlocksResponse) (flow.Block, error) { return convert.MessageToBlock(response.GetBlock()) } - blocksChan, errChan := subscribe(ctx, subscribeClient.Recv, convertBlockResponse, "block") - return blocksChan, errChan, nil + return subscribe(ctx, subscribeClient.Recv, convertBlockResponse) } func (c *BaseClient) SendAndSubscribeTransactionStatuses( @@ -1347,9 +1345,8 @@ func (c *BaseClient) SubscribeBlockHeadersFromStartBlockID( convertBlockHeaderResponse := func(response *access.SubscribeBlockHeadersResponse) (flow.BlockHeader, error) { return convert.MessageToBlockHeader(response.GetHeader()) } - blockHeaderChan, errChan := subscribe(ctx, subscribeClient.Recv, convertBlockHeaderResponse, "block header") - return blockHeaderChan, errChan, nil + return subscribe(ctx, subscribeClient.Recv, convertBlockHeaderResponse) } func (c *BaseClient) SubscribeBlockHeadersFromStartHeight( @@ -1376,9 +1373,8 @@ func (c *BaseClient) SubscribeBlockHeadersFromStartHeight( convertBlockHeaderResponse := func(response *access.SubscribeBlockHeadersResponse) (flow.BlockHeader, error) { return convert.MessageToBlockHeader(response.GetHeader()) } - blockHeaderChan, errChan := subscribe(ctx, subscribeClient.Recv, convertBlockHeaderResponse, "block header") - return blockHeaderChan, errChan, nil + return subscribe(ctx, subscribeClient.Recv, convertBlockHeaderResponse) } func (c *BaseClient) SubscribeBlockHeadersFromLatest( @@ -1403,9 +1399,8 @@ func (c *BaseClient) SubscribeBlockHeadersFromLatest( convertBlockHeaderResponse := func(response *access.SubscribeBlockHeadersResponse) (flow.BlockHeader, error) { return convert.MessageToBlockHeader(response.GetHeader()) } - blockHeaderChan, errChan := subscribe(ctx, subscribeClient.Recv, convertBlockHeaderResponse, "block header") - return blockHeaderChan, errChan, nil + return subscribe(ctx, subscribeClient.Recv, convertBlockHeaderResponse) } func (c *BaseClient) SubscribeAccountStatusesFromStartHeight( @@ -1431,9 +1426,8 @@ func (c *BaseClient) SubscribeAccountStatusesFromStartHeight( convertAccountStatusResponse := func(response *executiondata.SubscribeAccountStatusesResponse) (flow.AccountStatus, error) { return convert.MessageToAccountStatus(response) } - accountStatutesChan, errChan := subscribe(ctx, subscribeClient.Recv, convertAccountStatusResponse, "account status") - return accountStatutesChan, errChan, nil + return subscribe(ctx, subscribeClient.Recv, convertAccountStatusResponse) } func (c *BaseClient) SubscribeAccountStatusesFromStartBlockID( @@ -1459,9 +1453,8 @@ func (c *BaseClient) SubscribeAccountStatusesFromStartBlockID( convertAccountStatusResponse := func(response *executiondata.SubscribeAccountStatusesResponse) (flow.AccountStatus, error) { return convert.MessageToAccountStatus(response) } - accountStatutesChan, errChan := subscribe(ctx, subscribeClient.Recv, convertAccountStatusResponse, "account status") - return accountStatutesChan, errChan, nil + return subscribe(ctx, subscribeClient.Recv, convertAccountStatusResponse) } func (c *BaseClient) SubscribeAccountStatusesFromLatestBlock( @@ -1485,9 +1478,8 @@ func (c *BaseClient) SubscribeAccountStatusesFromLatestBlock( convertAccountStatusResponse := func(response *executiondata.SubscribeAccountStatusesResponse) (flow.AccountStatus, error) { return convert.MessageToAccountStatus(response) } - accountStatutesChan, errChan := subscribe(ctx, subscribeClient.Recv, convertAccountStatusResponse, "account status") - return accountStatutesChan, errChan, nil + return subscribe(ctx, subscribeClient.Recv, convertAccountStatusResponse) } func (c *BaseClient) SubscribeBlockDigestsFromStartBlockID( @@ -1514,9 +1506,8 @@ func (c *BaseClient) SubscribeBlockDigestsFromStartBlockID( convertBlockDigestResponse := func(response *access.SubscribeBlockDigestsResponse) (flow.BlockDigest, error) { return convert.MessageToBlockDigest(response) } - blockDigestChan, errChan := subscribe(ctx, subscribeClient.Recv, convertBlockDigestResponse, "block digest") - return blockDigestChan, errChan, nil + return subscribe(ctx, subscribeClient.Recv, convertBlockDigestResponse) } func (c *BaseClient) SubscribeBlockDigestsFromStartHeight( @@ -1543,9 +1534,8 @@ func (c *BaseClient) SubscribeBlockDigestsFromStartHeight( convertBlockDigestResponse := func(response *access.SubscribeBlockDigestsResponse) (flow.BlockDigest, error) { return convert.MessageToBlockDigest(response) } - blockDigestChan, errChan := subscribe(ctx, subscribeClient.Recv, convertBlockDigestResponse, "block digest") - return blockDigestChan, errChan, nil + return subscribe(ctx, subscribeClient.Recv, convertBlockDigestResponse) } func (c *BaseClient) SubscribeBlockDigestsFromLatest( @@ -1570,17 +1560,15 @@ func (c *BaseClient) SubscribeBlockDigestsFromLatest( convertBlockDigestResponse := func(response *access.SubscribeBlockDigestsResponse) (flow.BlockDigest, error) { return convert.MessageToBlockDigest(response) } - blockDigestChan, errChan := subscribe(ctx, subscribeClient.Recv, convertBlockDigestResponse, "block digest") - return blockDigestChan, errChan, nil + return subscribe(ctx, subscribeClient.Recv, convertBlockDigestResponse) } func subscribe[Response any, ClientResponse any]( ctx context.Context, receive func() (*ClientResponse, error), convertResponse func(*ClientResponse) (Response, error), - topicNameForErrors string, -) (chan Response, chan error) { +) (<-chan Response, <-chan error, error) { subChan := make(chan Response) errChan := make(chan error) @@ -1602,13 +1590,13 @@ func subscribe[Response any, ClientResponse any]( return } - sendErr(fmt.Errorf("error receiving %s: %w", topicNameForErrors, err)) + sendErr(fmt.Errorf("error receiving %s: %w", reflect.TypeOf(resp).Name(), err)) return } response, err := convertResponse(resp) if err != nil { - sendErr(fmt.Errorf("error converting %s: %w", topicNameForErrors, err)) + sendErr(fmt.Errorf("error converting %s: %w", reflect.TypeOf(resp).Name(), err)) return } @@ -1620,5 +1608,5 @@ func subscribe[Response any, ClientResponse any]( } }() - return subChan, errChan + return subChan, errChan, nil } diff --git a/examples/go.mod b/examples/go.mod index c58c5e374..25d222804 100644 --- a/examples/go.mod +++ b/examples/go.mod @@ -7,7 +7,7 @@ toolchain go1.22.4 replace github.com/onflow/flow-go-sdk => ../ require ( - github.com/onflow/cadence v1.0.1-0.20241018173327-2e72919b18ac + github.com/onflow/cadence v1.2.1 github.com/onflow/flow-cli/flowkit v1.11.0 github.com/onflow/flow-go-sdk v0.41.17 github.com/spf13/afero v1.11.0 diff --git a/examples/go.sum b/examples/go.sum index 6ef27de99..e80f1bdfe 100644 --- a/examples/go.sum +++ b/examples/go.sum @@ -120,6 +120,7 @@ github.com/onflow/cadence v1.0.0-preview.38/go.mod h1:jOwvPSSLTr9TvaKMs7KKiBYMmp github.com/onflow/cadence v1.0.0-preview.52/go.mod h1:7wvvecnAZtYOspLOS3Lh+FuAmMeSrXhAWiycC3kQ1UU= github.com/onflow/cadence v1.0.0/go.mod h1:7wvvecnAZtYOspLOS3Lh+FuAmMeSrXhAWiycC3kQ1UU= github.com/onflow/cadence v1.0.1-0.20241018173327-2e72919b18ac/go.mod h1:fJxxOAp1wnWDfOHT8GOc1ypsU0RR5E3z51AhG8Yf5jg= +github.com/onflow/cadence v1.2.1/go.mod h1:fJxxOAp1wnWDfOHT8GOc1ypsU0RR5E3z51AhG8Yf5jg= github.com/onflow/crypto v0.25.0 h1:BeWbLsh3ZD13Ej+Uky6kg1PL1ZIVBDVX+2MVBNwqddg= github.com/onflow/crypto v0.25.0/go.mod h1:C8FbaX0x8y+FxWjbkHy0Q4EASCDR9bSPWZqlpCLYyVI= github.com/onflow/crypto v0.25.1/go.mod h1:C8FbaX0x8y+FxWjbkHy0Q4EASCDR9bSPWZqlpCLYyVI= From 92a96e3f15ae007ba7eb4ffd1c85d4fb9edbb750 Mon Sep 17 00:00:00 2001 From: Illia Malachyn Date: Tue, 22 Oct 2024 18:23:40 +0300 Subject: [PATCH 3/8] introduce a new subscribe function for ordered responses --- access/grpc/grpc.go | 78 +++++++++++++++++++++++++++++++++++++++++++-- account.go | 4 +++ 2 files changed, 79 insertions(+), 3 deletions(-) diff --git a/access/grpc/grpc.go b/access/grpc/grpc.go index 3c0e2a8b1..88b3fdceb 100644 --- a/access/grpc/grpc.go +++ b/access/grpc/grpc.go @@ -1427,7 +1427,7 @@ func (c *BaseClient) SubscribeAccountStatusesFromStartHeight( return convert.MessageToAccountStatus(response) } - return subscribe(ctx, subscribeClient.Recv, convertAccountStatusResponse) + return subscribeContinuouslyIndexed(ctx, subscribeClient.Recv, convertAccountStatusResponse) } func (c *BaseClient) SubscribeAccountStatusesFromStartBlockID( @@ -1454,7 +1454,7 @@ func (c *BaseClient) SubscribeAccountStatusesFromStartBlockID( return convert.MessageToAccountStatus(response) } - return subscribe(ctx, subscribeClient.Recv, convertAccountStatusResponse) + return subscribeContinuouslyIndexed(ctx, subscribeClient.Recv, convertAccountStatusResponse) } func (c *BaseClient) SubscribeAccountStatusesFromLatestBlock( @@ -1479,7 +1479,7 @@ func (c *BaseClient) SubscribeAccountStatusesFromLatestBlock( return convert.MessageToAccountStatus(response) } - return subscribe(ctx, subscribeClient.Recv, convertAccountStatusResponse) + return subscribeContinuouslyIndexed(ctx, subscribeClient.Recv, convertAccountStatusResponse) } func (c *BaseClient) SubscribeBlockDigestsFromStartBlockID( @@ -1564,6 +1564,13 @@ func (c *BaseClient) SubscribeBlockDigestsFromLatest( return subscribe(ctx, subscribeClient.Recv, convertBlockDigestResponse) } +// subscribe sets up a generic subscription that continuously receives and processes messages +// from a data source. It does not enforce any message ordering or indexing. The function takes +// three parameters: a receive() function for getting the next message, a convertResponse() function +// for transforming the message into the desired response type, and a context for cancellation. +// It returns two channels: one for the converted responses and another for errors. The function +// runs in a separate goroutine and handles errors gracefully, signaling completion when the +// context is canceled or an error occurs. func subscribe[Response any, ClientResponse any]( ctx context.Context, receive func() (*ClientResponse, error), @@ -1610,3 +1617,68 @@ func subscribe[Response any, ClientResponse any]( return subChan, errChan, nil } + +type IndexedMessage interface { + GetMessageIndex() uint64 +} + +// subscribeContinuouslyIndexed is a specialized version of the subscription function for cases +// where messages contain an index to ensure order. The Response type must implement the +// IndexedMessage interface, providing a GetMessageIndex method. The function checks that each +// received message's index matches the expected sequence, starting from zero and incrementing +// by one. If a message arrives out of order, an error is sent. This function helps clients +// detect any missed messages and ensures consistent message processing. +func subscribeContinuouslyIndexed[Response IndexedMessage, ClientResponse any]( + ctx context.Context, + receive func() (*ClientResponse, error), + convertResponse func(*ClientResponse) (Response, error), +) (<-chan Response, <-chan error, error) { + subChan := make(chan Response) + errChan := make(chan error) + + sendErr := func(err error) { + select { + case <-ctx.Done(): + case errChan <- err: + } + } + + go func() { + defer close(subChan) + defer close(errChan) + + var nextExpectedMessageIndex uint64 + + for { + resp, err := receive() + if err != nil { + if err == io.EOF { + return + } + + sendErr(fmt.Errorf("error receiving %s: %w", reflect.TypeOf(resp).Name(), err)) + return + } + + response, err := convertResponse(resp) + if err != nil { + sendErr(fmt.Errorf("error converting %s: %w", reflect.TypeOf(resp).Name(), err)) + return + } + + if response.GetMessageIndex() != nextExpectedMessageIndex { + sendErr(fmt.Errorf("message received out of order")) + return + } + nextExpectedMessageIndex += 1 + + select { + case <-ctx.Done(): + return + case subChan <- response: + } + } + }() + + return subChan, errChan, nil +} diff --git a/account.go b/account.go index a2baee8cd..f91e9045b 100644 --- a/account.go +++ b/account.go @@ -166,6 +166,10 @@ type AccountStatus struct { Results []*AccountStatusResult } +func (a AccountStatus) GetMessageIndex() uint64 { + return a.MessageIndex +} + type AccountStatusResult struct { Address Address Events []Event From c9e1ac3f714d01f3292ce01a3ed112cc65b4ba65 Mon Sep 17 00:00:00 2001 From: Illia Malachyn Date: Thu, 24 Oct 2024 13:10:13 +0300 Subject: [PATCH 4/8] return array of pointers in get account keys for consistency --- access/grpc/client.go | 4 ++-- access/grpc/convert/convert.go | 6 +++--- access/grpc/grpc.go | 4 ++-- access/grpc/grpc_test.go | 4 ++-- 4 files changed, 9 insertions(+), 9 deletions(-) diff --git a/access/grpc/client.go b/access/grpc/client.go index 73c174f0f..c9d308dfb 100644 --- a/access/grpc/client.go +++ b/access/grpc/client.go @@ -239,11 +239,11 @@ func (c *Client) GetAccountKeyAtBlockHeight(ctx context.Context, address flow.Ad return c.grpc.GetAccountKeyAtBlockHeight(ctx, address, keyIndex, height) } -func (c *Client) GetAccountKeysAtLatestBlock(ctx context.Context, address flow.Address) ([]flow.AccountKey, error) { +func (c *Client) GetAccountKeysAtLatestBlock(ctx context.Context, address flow.Address) ([]*flow.AccountKey, error) { return c.grpc.GetAccountKeysAtLatestBlock(ctx, address) } -func (c *Client) GetAccountKeysAtBlockHeight(ctx context.Context, address flow.Address, height uint64) ([]flow.AccountKey, error) { +func (c *Client) GetAccountKeysAtBlockHeight(ctx context.Context, address flow.Address, height uint64) ([]*flow.AccountKey, error) { return c.grpc.GetAccountKeysAtBlockHeight(ctx, address, height) } diff --git a/access/grpc/convert/convert.go b/access/grpc/convert/convert.go index b93003231..86fdce62a 100644 --- a/access/grpc/convert/convert.go +++ b/access/grpc/convert/convert.go @@ -150,8 +150,8 @@ func MessageToAccountKey(m *entities.AccountKey) (*flow.AccountKey, error) { }, nil } -func MessageToAccountKeys(m []*entities.AccountKey) ([]flow.AccountKey, error) { - var accountKeys []flow.AccountKey +func MessageToAccountKeys(m []*entities.AccountKey) ([]*flow.AccountKey, error) { + var accountKeys []*flow.AccountKey for _, entity := range m { accountKey, err := MessageToAccountKey(entity) @@ -159,7 +159,7 @@ func MessageToAccountKeys(m []*entities.AccountKey) ([]flow.AccountKey, error) { return nil, err } - accountKeys = append(accountKeys, *accountKey) + accountKeys = append(accountKeys, accountKey) } return accountKeys, nil diff --git a/access/grpc/grpc.go b/access/grpc/grpc.go index c2f668908..2b462bda3 100644 --- a/access/grpc/grpc.go +++ b/access/grpc/grpc.go @@ -703,7 +703,7 @@ func (c *BaseClient) GetAccountKeyAtBlockHeight( func (c *BaseClient) GetAccountKeysAtLatestBlock( ctx context.Context, address flow.Address, -) ([]flow.AccountKey, error) { +) ([]*flow.AccountKey, error) { request := &access.GetAccountKeysAtLatestBlockRequest{ Address: address.Bytes(), } @@ -725,7 +725,7 @@ func (c *BaseClient) GetAccountKeysAtBlockHeight( ctx context.Context, address flow.Address, height uint64, -) ([]flow.AccountKey, error) { +) ([]*flow.AccountKey, error) { request := &access.GetAccountKeysAtBlockHeightRequest{ Address: address.Bytes(), BlockHeight: height, diff --git a/access/grpc/grpc_test.go b/access/grpc/grpc_test.go index 30844d9a7..fb6099efc 100644 --- a/access/grpc/grpc_test.go +++ b/access/grpc/grpc_test.go @@ -1069,7 +1069,7 @@ func TestClient_GetAccountKeysAtLatestBlock(t *testing.T) { keys, err := c.GetAccountKeysAtLatestBlock(ctx, account.Address) require.NoError(t, err) - assert.Equal(t, *account.Keys[index], keys[index]) + assert.Equal(t, *account.Keys[index], *keys[index]) })) t.Run("Not found error", clientTest(func(t *testing.T, ctx context.Context, rpc *mocks.MockRPCClient, c *BaseClient) { @@ -1105,7 +1105,7 @@ func TestClient_GetAccountKeysAtBlockHeight(t *testing.T) { keys, err := c.GetAccountKeysAtBlockHeight(ctx, account.Address, height) require.NoError(t, err) - assert.Equal(t, *account.Keys[index], keys[index]) + assert.Equal(t, *account.Keys[index], *keys[index]) })) t.Run("Not found error", clientTest(func(t *testing.T, ctx context.Context, rpc *mocks.MockRPCClient, c *BaseClient) { From 680558583065d6456b70e61adadfa186a16f4fb7 Mon Sep 17 00:00:00 2001 From: =?UTF-8?q?Bastian=20M=C3=BCller?= Date: Wed, 30 Oct 2024 12:27:08 -0700 Subject: [PATCH 5/8] Update to Cadence v1.2.2 --- go.mod | 10 +++++----- go.sum | 28 ++++++++++++++-------------- 2 files changed, 19 insertions(+), 19 deletions(-) diff --git a/go.mod b/go.mod index a6700c19d..dba86088d 100644 --- a/go.mod +++ b/go.mod @@ -9,7 +9,7 @@ require ( github.com/aws/aws-sdk-go-v2 v1.27.0 github.com/aws/aws-sdk-go-v2/config v1.27.15 github.com/aws/aws-sdk-go-v2/service/kms v1.31.0 - github.com/onflow/cadence v1.2.1 + github.com/onflow/cadence v1.2.2 github.com/onflow/crypto v0.25.1 github.com/onflow/flow/protobuf/go/flow v0.4.7 github.com/onflow/go-ethereum v1.13.4 @@ -76,14 +76,14 @@ require ( go.opentelemetry.io/otel/metric v1.24.0 // indirect go.opentelemetry.io/otel/sdk v1.24.0 // indirect go.opentelemetry.io/otel/trace v1.24.0 // indirect - golang.org/x/crypto v0.19.0 // indirect + golang.org/x/crypto v0.28.0 // indirect golang.org/x/exp v0.0.0-20240119083558-1b970713d09a // indirect golang.org/x/lint v0.0.0-20210508222113-6edffad5e616 // indirect golang.org/x/net v0.21.0 // indirect golang.org/x/oauth2 v0.17.0 // indirect - golang.org/x/sync v0.6.0 // indirect - golang.org/x/sys v0.17.0 // indirect - golang.org/x/text v0.14.0 // indirect + golang.org/x/sync v0.8.0 // indirect + golang.org/x/sys v0.26.0 // indirect + golang.org/x/text v0.19.0 // indirect golang.org/x/time v0.5.0 // indirect golang.org/x/xerrors v0.0.0-20231012003039-104605ab7028 // indirect gonum.org/v1/gonum v0.14.0 // indirect diff --git a/go.sum b/go.sum index 40e2d7933..562d93782 100644 --- a/go.sum +++ b/go.sum @@ -133,8 +133,8 @@ github.com/mattn/go-isatty v0.0.20 h1:xfD0iDuEKnDkl03q4limB+vH+GxLEtL/jb4xVJSWWE github.com/mattn/go-isatty v0.0.20/go.mod h1:W+V8PltTTMOvKvAeJH7IuucS94S2C6jfK/D7dTCTo3Y= github.com/onflow/atree v0.8.0 h1:qg5c6J1gVDNObughpEeWm8oxqhPGdEyGrda121GM4u0= github.com/onflow/atree v0.8.0/go.mod h1:yccR+LR7xc1Jdic0mrjocbHvUD7lnVvg8/Ct1AA5zBo= -github.com/onflow/cadence v1.2.1 h1:hmSsgX3rTsp2E5qTSl1JXINt8qepdRrHTwDSYqN5Nxs= -github.com/onflow/cadence v1.2.1/go.mod h1:fJxxOAp1wnWDfOHT8GOc1ypsU0RR5E3z51AhG8Yf5jg= +github.com/onflow/cadence v1.2.2 h1:LwigF/2lPiXlwX5rFn71KeMpmW5Iu/f/JtsPLLULBCc= +github.com/onflow/cadence v1.2.2/go.mod h1:PYX1xLejqswtDsQzN93x/VpfSKNyjUk6hrkc/mpv7xs= github.com/onflow/crypto v0.25.1 h1:0txy2PKPMM873JbpxQNbJmuOJtD56bfs48RQfm0ts5A= github.com/onflow/crypto v0.25.1/go.mod h1:C8FbaX0x8y+FxWjbkHy0Q4EASCDR9bSPWZqlpCLYyVI= github.com/onflow/flow/protobuf/go/flow v0.4.7 h1:iP6DFx4wZ3ETORsyeqzHu7neFT3d1CXF6wdK+AOOjmc= @@ -201,8 +201,8 @@ golang.org/x/crypto v0.0.0-20190308221718-c2843e01d9a2/go.mod h1:djNgcEr1/C05ACk golang.org/x/crypto v0.0.0-20191011191535-87dc89f01550/go.mod h1:yigFU9vqHzYiE8UmvKecakEJjdnWj3jj499lnFckfCI= golang.org/x/crypto v0.0.0-20200622213623-75b288015ac9/go.mod h1:LzIPMQfyMNhhGPhUkYOs5KpL4U8rLKemX1yGLhDgUto= golang.org/x/crypto v0.0.0-20210921155107-089bfa567519/go.mod h1:GvvjBRRGRdwPK5ydBHafDWAxML/pGHZbMvKqRZ5+Abc= -golang.org/x/crypto v0.19.0 h1:ENy+Az/9Y1vSrlrvBSyna3PITt4tiZLf7sgCjZBX7Wo= -golang.org/x/crypto v0.19.0/go.mod h1:Iy9bg/ha4yyC70EfRS8jz+B6ybOBKMaSxLj6P6oBDfU= +golang.org/x/crypto v0.28.0 h1:GBDwsMXVQi34v5CCYUm2jkJvu4cbtru2U4TN2PSyQnw= +golang.org/x/crypto v0.28.0/go.mod h1:rmgy+3RHxRZMyY0jjAJShp2zgEdOqj2AO7U0pYmeQ7U= golang.org/x/exp v0.0.0-20190121172915-509febef88a4/go.mod h1:CJ0aWSM057203Lf6IL+f9T1iT9GByDxfZKAQTCR3kQA= golang.org/x/exp v0.0.0-20240119083558-1b970713d09a h1:Q8/wZp0KX97QFTc2ywcOE0YRjZPVIx+MXInMzdvQqcA= golang.org/x/exp v0.0.0-20240119083558-1b970713d09a/go.mod h1:idGWGoKP1toJGkd5/ig9ZLuPcZBC3ewk7SzmH0uou08= @@ -213,8 +213,8 @@ golang.org/x/lint v0.0.0-20210508222113-6edffad5e616 h1:VLliZ0d+/avPrXXH+OakdXhp golang.org/x/lint v0.0.0-20210508222113-6edffad5e616/go.mod h1:3xt1FjdF8hUf6vQPIChWIBhFzV8gjjsPE/fR3IyQdNY= golang.org/x/mod v0.1.1-0.20191105210325-c90efee705ee/go.mod h1:QqPTAvyqsEbceGzBzNggFXnrqF1CaUcvgkdR5Ot7KZg= golang.org/x/mod v0.6.0-dev.0.20220419223038-86c51ed26bb4/go.mod h1:jJ57K6gSWd91VN4djpZkiMVwK6gcyfeH4XE8wZrZaV4= -golang.org/x/mod v0.14.0 h1:dGoOF9QVLYng8IHTm7BAyWqCqSheQ5pYWGhzW00YJr0= -golang.org/x/mod v0.14.0/go.mod h1:hTbmBsO62+eylJbnUtE2MGJUyE7QWk4xUqPFrRgJ+7c= +golang.org/x/mod v0.17.0 h1:zY54UmvipHiNd+pm+m0x9KhZ9hl1/7QNMyxXbc6ICqA= +golang.org/x/mod v0.17.0/go.mod h1:hTbmBsO62+eylJbnUtE2MGJUyE7QWk4xUqPFrRgJ+7c= golang.org/x/net v0.0.0-20180724234803-3673e40ba225/go.mod h1:mL1N/T3taQHkDXs73rZJwtUhF3w3ftmwwsq0BUmARs4= golang.org/x/net v0.0.0-20180826012351-8a410e7b638d/go.mod h1:mL1N/T3taQHkDXs73rZJwtUhF3w3ftmwwsq0BUmARs4= golang.org/x/net v0.0.0-20190213061140-3a22650c66bd/go.mod h1:mL1N/T3taQHkDXs73rZJwtUhF3w3ftmwwsq0BUmARs4= @@ -233,8 +233,8 @@ golang.org/x/sync v0.0.0-20180314180146-1d60e4601c6f/go.mod h1:RxMgew5VJxzue5/jJ golang.org/x/sync v0.0.0-20181108010431-42b317875d0f/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= golang.org/x/sync v0.0.0-20190423024810-112230192c58/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= golang.org/x/sync v0.0.0-20220722155255-886fb9371eb4/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= -golang.org/x/sync v0.6.0 h1:5BMeUDZ7vkXGfEr1x9B4bRcTH4lpkTkpdh0T/J+qjbQ= -golang.org/x/sync v0.6.0/go.mod h1:Czt+wKu1gCyEFDUtn0jG5QVvpJ6rzVqr5aXyt9drQfk= +golang.org/x/sync v0.8.0 h1:3NFvSEYkUoMifnESzZl15y791HH1qU2xm6eCJU5ZPXQ= +golang.org/x/sync v0.8.0/go.mod h1:Czt+wKu1gCyEFDUtn0jG5QVvpJ6rzVqr5aXyt9drQfk= golang.org/x/sys v0.0.0-20180830151530-49385e6e1522/go.mod h1:STP8DvDyc/dI5b8T5hshtkjS+E42TnysNCUPdjciGhY= golang.org/x/sys v0.0.0-20190215142949-d0b11bdaac8a/go.mod h1:STP8DvDyc/dI5b8T5hshtkjS+E42TnysNCUPdjciGhY= golang.org/x/sys v0.0.0-20190412213103-97732733099d/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= @@ -247,16 +247,16 @@ golang.org/x/sys v0.0.0-20220722155257-8c9f86f7a55f/go.mod h1:oPkhp1MJrh7nUepCBc golang.org/x/sys v0.0.0-20220811171246-fbc7d0a398ab/go.mod h1:oPkhp1MJrh7nUepCBck5+mAzfO9JrbApNNgaTdGDITg= golang.org/x/sys v0.5.0/go.mod h1:oPkhp1MJrh7nUepCBck5+mAzfO9JrbApNNgaTdGDITg= golang.org/x/sys v0.6.0/go.mod h1:oPkhp1MJrh7nUepCBck5+mAzfO9JrbApNNgaTdGDITg= -golang.org/x/sys v0.17.0 h1:25cE3gD+tdBA7lp7QfhuV+rJiE9YXTcS3VG1SqssI/Y= -golang.org/x/sys v0.17.0/go.mod h1:/VUhepiaJMQUp4+oa/7Zr1D23ma6VTLIYjOOTFZPUcA= +golang.org/x/sys v0.26.0 h1:KHjCJyddX0LoSTb3J+vWpupP9p0oznkqVk/IfjymZbo= +golang.org/x/sys v0.26.0/go.mod h1:/VUhepiaJMQUp4+oa/7Zr1D23ma6VTLIYjOOTFZPUcA= golang.org/x/term v0.0.0-20201126162022-7de9c90e9dd1/go.mod h1:bj7SfCRtBDWHUb9snDiAeCFNEtKQo2Wmx5Cou7ajbmo= golang.org/x/term v0.0.0-20210927222741-03fcf44c2211/go.mod h1:jbD1KX2456YbFQfuXm/mYQcufACuNUgVhRMnK/tPxf8= golang.org/x/text v0.3.0/go.mod h1:NqM8EUOU14njkJ3fqMW+pc6Ldnwhi/IjpwHt7yyuwOQ= golang.org/x/text v0.3.3/go.mod h1:5Zoc/QRtKVWzQhOtBMvqHzDpF6irO9z98xDceosuGiQ= golang.org/x/text v0.3.7/go.mod h1:u+2+/6zg+i71rQMx5EYifcz6MCKuco9NR6JIITiCfzQ= golang.org/x/text v0.3.8/go.mod h1:E6s5w1FMmriuDzIBO73fBruAKo1PCIq6d2Q6DHfQ8WQ= -golang.org/x/text v0.14.0 h1:ScX5w1eTa3QqT8oi6+ziP7dTV1S2+ALU0bI+0zXKWiQ= -golang.org/x/text v0.14.0/go.mod h1:18ZOQIKpY8NJVqYksKHtTdi31H5itFRjB5/qKTNYzSU= +golang.org/x/text v0.19.0 h1:kTxAhCbGbxhK0IwgSKiMO5awPoDQ0RpfiVYBfK860YM= +golang.org/x/text v0.19.0/go.mod h1:BuEKDfySbSR4drPmRPG/7iBdf8hvFMuRexcpahXilzY= golang.org/x/time v0.5.0 h1:o7cqy6amK/52YcAKIPlM3a+Fpj35zvRj2TP+e1xFSfk= golang.org/x/time v0.5.0/go.mod h1:3BpzKBy/shNhVucY/MWOyx10tF3SFh9QdLuxbVysPQM= golang.org/x/tools v0.0.0-20180917221912-90fa682c2a6e/go.mod h1:n7NCudcB/nEzxVGmLbDWY5pfWTLqBcC2KZ6jyYvM4mQ= @@ -267,8 +267,8 @@ golang.org/x/tools v0.0.0-20190524140312-2c0ae7006135/go.mod h1:RgjU9mgBXZiqYHBn golang.org/x/tools v0.0.0-20191119224855-298f0cb1881e/go.mod h1:b+2E5dAYhXwXZwtnZ6UAqBI28+e2cm9otk0dWdXHAEo= golang.org/x/tools v0.0.0-20200130002326-2f3ba24bd6e7/go.mod h1:TB2adYChydJhpapKDTa4BR/hXlZSLoq2Wpct/0txZ28= golang.org/x/tools v0.1.12/go.mod h1:hNGJHUnrk76NpqgfD5Aqm5Crs+Hm0VOH/i9J2+nxYbc= -golang.org/x/tools v0.17.0 h1:FvmRgNOcs3kOa+T20R1uhfP9F6HgG2mfxDv1vrx1Htc= -golang.org/x/tools v0.17.0/go.mod h1:xsh6VxdV005rRVaS6SSAf9oiAqljS7UZUacMZ8Bnsps= +golang.org/x/tools v0.21.1-0.20240508182429-e35e4ccd0d2d h1:vU5i/LfpvrRCpgM/VPfJLg5KjxD3E+hfT1SH+d9zLwg= +golang.org/x/tools v0.21.1-0.20240508182429-e35e4ccd0d2d/go.mod h1:aiJjzUbINMkxbQROHiO6hDPo2LHcIPhhQsa9DLh0yGk= golang.org/x/xerrors v0.0.0-20190717185122-a985d3407aa7/go.mod h1:I/5z698sn9Ka8TeJc9MKroUUfqBBauWjQqLJ2OPfmY0= golang.org/x/xerrors v0.0.0-20191011141410-1b5146add898/go.mod h1:I/5z698sn9Ka8TeJc9MKroUUfqBBauWjQqLJ2OPfmY0= golang.org/x/xerrors v0.0.0-20191204190536-9bdfabe68543/go.mod h1:I/5z698sn9Ka8TeJc9MKroUUfqBBauWjQqLJ2OPfmY0= From 2f2220bc9f643f6e52d6c068a09ff14b0e0baa69 Mon Sep 17 00:00:00 2001 From: =?UTF-8?q?Bastian=20M=C3=BCller?= Date: Wed, 30 Oct 2024 12:43:33 -0700 Subject: [PATCH 6/8] go mod tidy --- examples/go.mod | 22 ++++-- examples/go.sum | 182 +++++++++++++++++++++--------------------------- 2 files changed, 95 insertions(+), 109 deletions(-) diff --git a/examples/go.mod b/examples/go.mod index 25d222804..cd63b0260 100644 --- a/examples/go.mod +++ b/examples/go.mod @@ -7,7 +7,7 @@ toolchain go1.22.4 replace github.com/onflow/flow-go-sdk => ../ require ( - github.com/onflow/cadence v1.2.1 + github.com/onflow/cadence v1.2.2 github.com/onflow/flow-cli/flowkit v1.11.0 github.com/onflow/flow-go-sdk v0.41.17 github.com/spf13/afero v1.11.0 @@ -19,13 +19,16 @@ require ( cloud.google.com/go/compute/metadata v0.2.3 // indirect cloud.google.com/go/iam v1.1.6 // indirect cloud.google.com/go/kms v1.15.7 // indirect + github.com/SaveTheRbtz/mph v0.1.1-0.20240117162131-4166ec7869bc // indirect github.com/bits-and-blooms/bitset v1.10.0 // indirect github.com/btcsuite/btcd/btcec/v2 v2.2.1 // indirect github.com/davecgh/go-spew v1.1.1 // indirect github.com/decred/dcrd/dcrec/secp256k1/v4 v4.2.0 // indirect - github.com/ethereum/go-ethereum v1.13.5 // indirect + github.com/felixge/httpsnoop v1.0.4 // indirect github.com/fxamacker/cbor/v2 v2.4.1-0.20230228173756-c0c9f774e40c // indirect github.com/fxamacker/circlehash v0.3.0 // indirect + github.com/go-logr/logr v1.4.1 // indirect + github.com/go-logr/stdr v1.2.2 // indirect github.com/golang/groupcache v0.0.0-20210331224755-41bb18bfe9da // indirect github.com/golang/protobuf v1.5.4 // indirect github.com/google/s2a-go v0.1.7 // indirect @@ -34,7 +37,7 @@ require ( github.com/holiman/uint256 v1.2.4 // indirect github.com/iancoleman/orderedmap v0.0.0-20190318233801-ac98e3ecb4b0 // indirect github.com/invopop/jsonschema v0.7.0 // indirect - github.com/k0kubun/pp/v3 v3.2.0 // indirect + github.com/k0kubun/pp v3.0.1+incompatible // indirect github.com/klauspost/cpuid/v2 v2.2.6 // indirect github.com/kr/pretty v0.3.1 // indirect github.com/kr/text v0.2.0 // indirect @@ -44,6 +47,7 @@ require ( github.com/onflow/atree v0.8.0 // indirect github.com/onflow/crypto v0.25.1 // indirect github.com/onflow/flow/protobuf/go/flow v0.4.7 // indirect + github.com/onflow/go-ethereum v1.13.4 // indirect github.com/onflow/sdks v0.6.0-preview.1 // indirect github.com/pkg/errors v0.9.1 // indirect github.com/pmezard/go-difflib v1.0.0 // indirect @@ -56,14 +60,18 @@ require ( github.com/x448/float16 v0.8.4 // indirect github.com/zeebo/blake3 v0.2.3 // indirect go.opencensus.io v0.24.0 // indirect + go.opentelemetry.io/contrib/instrumentation/google.golang.org/grpc/otelgrpc v0.47.0 // indirect + go.opentelemetry.io/contrib/instrumentation/net/http/otelhttp v0.47.0 // indirect go.opentelemetry.io/otel v1.24.0 // indirect - golang.org/x/crypto v0.19.0 // indirect + go.opentelemetry.io/otel/metric v1.24.0 // indirect + go.opentelemetry.io/otel/trace v1.24.0 // indirect + golang.org/x/crypto v0.28.0 // indirect golang.org/x/exp v0.0.0-20240119083558-1b970713d09a // indirect golang.org/x/net v0.21.0 // indirect golang.org/x/oauth2 v0.17.0 // indirect - golang.org/x/sync v0.6.0 // indirect - golang.org/x/sys v0.17.0 // indirect - golang.org/x/text v0.14.0 // indirect + golang.org/x/sync v0.8.0 // indirect + golang.org/x/sys v0.26.0 // indirect + golang.org/x/text v0.19.0 // indirect golang.org/x/time v0.5.0 // indirect golang.org/x/xerrors v0.0.0-20231012003039-104605ab7028 // indirect gonum.org/v1/gonum v0.14.0 // indirect diff --git a/examples/go.sum b/examples/go.sum index e80f1bdfe..0fd4d1aa5 100644 --- a/examples/go.sum +++ b/examples/go.sum @@ -1,26 +1,26 @@ cloud.google.com/go v0.26.0/go.mod h1:aQUYkXzVsufM+DwF1aE+0xfcU+56JwCaLick0ClmMTw= -cloud.google.com/go v0.110.10 h1:LXy9GEO+timppncPIAZoOj3l58LIU9k+kn48AN7IO3Y= -cloud.google.com/go v0.110.10/go.mod h1:v1OoFqYxiBkUrruItNM3eT4lLByNjxmJSV/xDKJNnic= -cloud.google.com/go/compute v1.23.3 h1:6sVlXXBmbd7jNX0Ipq0trII3e4n1/MsADLK6a+aiVlk= -cloud.google.com/go/compute v1.23.3/go.mod h1:VCgBUoMnIVIR0CscqQiPJLAG25E3ZRZMzcFZeQ+h8CI= +cloud.google.com/go v0.112.0 h1:tpFCD7hpHFlQ8yPwT3x+QeXqc2T6+n6T+hmABHfDUSM= +cloud.google.com/go v0.112.0/go.mod h1:3jEEVwZ/MHU4djK5t5RHuKOA/GbLddgTdVubX1qnPD4= +cloud.google.com/go/compute v1.24.0 h1:phWcR2eWzRJaL/kOiJwfFsPs4BaKq1j6vnpZrc1YlVg= cloud.google.com/go/compute v1.24.0/go.mod h1:kw1/T+h/+tK2LJK0wiPPx1intgdAM3j/g3hFDlscY40= cloud.google.com/go/compute/metadata v0.2.3 h1:mg4jlk7mCAj6xXp9UJ4fjI9VUI5rubuGBW5aJ7UnBMY= cloud.google.com/go/compute/metadata v0.2.3/go.mod h1:VAV5nSsACxMJvgaAuX6Pk2AawlZn8kiOGuCv6gTkwuA= -cloud.google.com/go/iam v1.1.5 h1:1jTsCu4bcsNsE4iiqNT5SHwrDRCfRmIaaaVFhRveTJI= -cloud.google.com/go/iam v1.1.5/go.mod h1:rB6P/Ic3mykPbFio+vo7403drjlgvoWfYpJhMXEbzv8= +cloud.google.com/go/iam v1.1.6 h1:bEa06k05IO4f4uJonbB5iAgKTPpABy1ayxaIZV/GHVc= cloud.google.com/go/iam v1.1.6/go.mod h1:O0zxdPeGBoFdWW3HWmBxJsk0pfvNM/p/qa82rWOGTwI= -cloud.google.com/go/kms v1.15.5 h1:pj1sRfut2eRbD9pFRjNnPNg/CzJPuQAzUujMIM1vVeM= -cloud.google.com/go/kms v1.15.5/go.mod h1:cU2H5jnp6G2TDpUGZyqTCoy1n16fbubHZjmVXSMtwDI= +cloud.google.com/go/kms v1.15.7 h1:7caV9K3yIxvlQPAcaFffhlT7d1qpxjB1wHBtjWa13SM= cloud.google.com/go/kms v1.15.7/go.mod h1:ub54lbsa6tDkUwnu4W7Yt1aAIFLnspgh0kPGToDukeI= github.com/BurntSushi/toml v0.3.1/go.mod h1:xHWCNGjB5oqiDr8zfno3MHue2Ht5sIBksp03qcyfWMU= -github.com/bits-and-blooms/bitset v1.7.0 h1:YjAGVd3XmtK9ktAbX8Zg2g2PwLIMjGREZJHlV4j7NEo= -github.com/bits-and-blooms/bitset v1.7.0/go.mod h1:gIdJ4wp64HaoK2YrL1Q5/N7Y16edYb8uY+O0FJTyyDA= +github.com/SaveTheRbtz/mph v0.1.1-0.20240117162131-4166ec7869bc h1:DCHzPQOcU/7gwDTWbFQZc5qHMPS1g0xTO56k8NXsv9M= +github.com/SaveTheRbtz/mph v0.1.1-0.20240117162131-4166ec7869bc/go.mod h1:LJM5a3zcIJ/8TmZwlUczvROEJT8ntOdhdG9jjcR1B0I= +github.com/bits-and-blooms/bitset v1.10.0 h1:ePXTeiPEazB5+opbv5fr8umg2R/1NlzgDsyepwsSr88= github.com/bits-and-blooms/bitset v1.10.0/go.mod h1:7hO7Gc7Pp1vODcmWvKMRA9BNmbv6a/7QIWpPxHddWR8= github.com/btcsuite/btcd/btcec/v2 v2.2.1 h1:xP60mv8fvp+0khmrN0zTdPC3cNm24rfeE6lh2R/Yv3E= github.com/btcsuite/btcd/btcec/v2 v2.2.1/go.mod h1:9/CSmJxmuvqzX9Wh2fXMWToLOHhPd11lSPuIupwTkI8= github.com/census-instrumentation/opencensus-proto v0.2.1/go.mod h1:f6KPmirojxKA12rnyqOA5BBL4O983OfeGPqjHWSTneU= github.com/client9/misspell v0.3.4/go.mod h1:qj6jICC3Q7zFZvVWo7KLAzC3yx5G7kyvSDkc90ppPyw= github.com/cncf/udpa/go v0.0.0-20191209042840-269d4d468f6f/go.mod h1:M8M6+tZqaGXZJjfX53e64911xZQV5JYwmTeXPW+k8Sc= +github.com/cncf/xds/go v0.0.0-20231128003011-0fa0005c9caa h1:jQCWAUqqlij9Pgj2i/PB79y4KOPYVyFYdROxgaCwdTQ= +github.com/cncf/xds/go v0.0.0-20231128003011-0fa0005c9caa/go.mod h1:x/1Gn8zydmfq8dk6e9PdstVsDgu9RuyIIJqAaF//0IM= github.com/creack/pty v1.1.9/go.mod h1:oKZEueFk5CKHvIhNR5MUki03XCEU+Q6VDXinZuGJ33E= github.com/davecgh/go-spew v1.1.0/go.mod h1:J7Y8YcW2NihsgmVo/mv3lAwl/skON4iLHjSsI+c5H38= github.com/davecgh/go-spew v1.1.1 h1:vj9j/u1bqnvCEfJOwUhtlOARqs3+rkHYY13jYWTU97c= @@ -31,12 +31,19 @@ github.com/envoyproxy/go-control-plane v0.9.0/go.mod h1:YTl/9mNaCwkRvm6d1a2C3ymF github.com/envoyproxy/go-control-plane v0.9.1-0.20191026205805-5f8ba28d4473/go.mod h1:YTl/9mNaCwkRvm6d1a2C3ymFceY/DCBVvsKhRF0iEA4= github.com/envoyproxy/go-control-plane v0.9.4/go.mod h1:6rpuAdCZL397s3pYoYcLgu1mIlRU8Am5FuJP05cCM98= github.com/envoyproxy/protoc-gen-validate v0.1.0/go.mod h1:iSmxcyjqTsJpI2R4NaDN7+kN2VEUnK/pcBlmesArF7c= -github.com/ethereum/go-ethereum v1.13.5 h1:U6TCRciCqZRe4FPXmy1sMGxTfuk8P7u2UoinF3VbaFk= -github.com/ethereum/go-ethereum v1.13.5/go.mod h1:yMTu38GSuyxaYzQMViqNmQ1s3cE84abZexQmTgenWk0= +github.com/envoyproxy/protoc-gen-validate v1.0.4 h1:gVPz/FMfvh57HdSJQyvBtF00j8JU4zdyUgIUNhlgg0A= +github.com/envoyproxy/protoc-gen-validate v1.0.4/go.mod h1:qys6tmnRsYrQqIhm2bvKZH4Blx/1gTIZ2UKVY1M+Yew= +github.com/felixge/httpsnoop v1.0.4 h1:NFTV2Zj1bL4mc9sqWACXbQFVBBg2W3GPvqp8/ESS2Wg= +github.com/felixge/httpsnoop v1.0.4/go.mod h1:m8KPJKqk1gH5J9DgRY2ASl2lWCfGKXixSwevea8zH2U= github.com/fxamacker/cbor/v2 v2.4.1-0.20230228173756-c0c9f774e40c h1:5tm/Wbs9d9r+qZaUFXk59CWDD0+77PBqDREffYkyi5c= github.com/fxamacker/cbor/v2 v2.4.1-0.20230228173756-c0c9f774e40c/go.mod h1:TA1xS00nchWmaBnEIxPSE5oHLuJBAVvqrtAnWBwBCVo= github.com/fxamacker/circlehash v0.3.0 h1:XKdvTtIJV9t7DDUtsf0RIpC1OcxZtPbmgIH7ekx28WA= github.com/fxamacker/circlehash v0.3.0/go.mod h1:3aq3OfVvsWtkWMb6A1owjOQFA+TLsD5FgJflnaQwtMM= +github.com/go-logr/logr v1.2.2/go.mod h1:jdQByPbusPIv2/zmleS9BjJVeZ6kBagPoEUsqbVz/1A= +github.com/go-logr/logr v1.4.1 h1:pKouT5E8xu9zeFC39JXRDukb6JFQPXM5p5I91188VAQ= +github.com/go-logr/logr v1.4.1/go.mod h1:9T104GzyrTigFIr8wt5mBrctHMim0Nb2HLGrmQ40KvY= +github.com/go-logr/stdr v1.2.2 h1:hSWxHoqTgW2S2qGc0LTAI563KZ5YKYRhT3MFKZMbjag= +github.com/go-logr/stdr v1.2.2/go.mod h1:mMo/vtBO5dYbehREoey6XUKy/eSumjCCveDpRre4VKE= github.com/golang/glog v0.0.0-20160126235308-23def4e6c14b/go.mod h1:SBH7ygxi8pfUlaOkMMuAQtPIUF8ecWP5IEl/CR7VP2Q= github.com/golang/groupcache v0.0.0-20200121045136-8c9f03a8e57e/go.mod h1:cIg4eruTrX1D+g88fzRXU5OdNfaM+9IcxsU14FzY7Hc= github.com/golang/groupcache v0.0.0-20210331224755-41bb18bfe9da h1:oI5xCqsCo564l8iNU+DwB5epxmsaqB+rhGL0m5jtYqE= @@ -53,8 +60,7 @@ github.com/golang/protobuf v1.4.1/go.mod h1:U8fpvMrcmy5pZrNK1lt4xCsGvpyWQ/VVv6QD github.com/golang/protobuf v1.4.3/go.mod h1:oDoupMAO8OvCJWAcko0GGGIgR6R6ocIYbsSw735rRwI= github.com/golang/protobuf v1.5.0/go.mod h1:FsONVRAS9T7sI+LIUmWTfcYkHO4aIWwzhcaSAoJOfIk= github.com/golang/protobuf v1.5.2/go.mod h1:XVQd3VNwM+JqD3oG2Ue2ip4fOMUkwXdXDdiuN0vRsmY= -github.com/golang/protobuf v1.5.3 h1:KhyjKVUg7Usr/dYsdSqoFveMYd5ko72D+zANwlG1mmg= -github.com/golang/protobuf v1.5.3/go.mod h1:XVQd3VNwM+JqD3oG2Ue2ip4fOMUkwXdXDdiuN0vRsmY= +github.com/golang/protobuf v1.5.4 h1:i7eJL8qZTpSEXOPTxNKhASYpMn+8e5Q6AdndVa1dWek= github.com/golang/protobuf v1.5.4/go.mod h1:lnTiLA8Wa4RWRcIUkrtSVa5nRhsEGBg48fD6rSs7xps= github.com/google/go-cmp v0.2.0/go.mod h1:oXzfMopK8JAjlY9xF4vHSVASa0yLyX7SntLO5aqRK0M= github.com/google/go-cmp v0.3.0/go.mod h1:8QqcDgzrUqlUb/G2PQTWiueGozuR1884gddMywk6iLU= @@ -72,18 +78,18 @@ github.com/googleapis/enterprise-certificate-proxy v0.3.2 h1:Vie5ybvEvT75RniqhfF github.com/googleapis/enterprise-certificate-proxy v0.3.2/go.mod h1:VLSiSSBs/ksPL8kq3OBOQ6WRI2QnaFynd1DCjZ62+V0= github.com/googleapis/gax-go/v2 v2.12.0 h1:A+gCJKdRfqXkr+BIRGtZLibNXf0m1f9E4HG56etFpas= github.com/googleapis/gax-go/v2 v2.12.0/go.mod h1:y+aIqrI5eb1YGMVJfuV3185Ts/D7qKpsEkdD5+I6QGU= -github.com/holiman/uint256 v1.2.3 h1:K8UWO1HUJpRMXBxbmaY1Y8IAMZC/RsKB+ArEnnK4l5o= -github.com/holiman/uint256 v1.2.3/go.mod h1:SC8Ryt4n+UBbPbIBKaG9zbbDlp4jOru9xFZmPzLUTxw= +github.com/holiman/uint256 v1.2.4 h1:jUc4Nk8fm9jZabQuqr2JzednajVmBpC+oiTiXZJEApU= github.com/holiman/uint256 v1.2.4/go.mod h1:EOMSn4q6Nyt9P6efbI3bueV4e1b3dGlUCXeiRV4ng7E= github.com/iancoleman/orderedmap v0.0.0-20190318233801-ac98e3ecb4b0 h1:i462o439ZjprVSFSZLZxcsoAe592sZB1rci2Z8j4wdk= github.com/iancoleman/orderedmap v0.0.0-20190318233801-ac98e3ecb4b0/go.mod h1:N0Wam8K1arqPXNWjMo21EXnBPOPp36vB07FNRdD2geA= github.com/invopop/jsonschema v0.7.0 h1:2vgQcBz1n256N+FpX3Jq7Y17AjYt46Ig3zIWyy770So= github.com/invopop/jsonschema v0.7.0/go.mod h1:O9uiLokuu0+MGFlyiaqtWxwqJm41/+8Nj0lD7A36YH0= -github.com/k0kubun/pp/v3 v3.2.0 h1:h33hNTZ9nVFNP3u2Fsgz8JXiF5JINoZfFq4SvKJwNcs= -github.com/k0kubun/pp/v3 v3.2.0/go.mod h1:ODtJQbQcIRfAD3N+theGCV1m/CBxweERz2dapdz1EwA= +github.com/k0kubun/colorstring v0.0.0-20150214042306-9440f1994b88 h1:uC1QfSlInpQF+M0ao65imhwqKnz3Q2z/d8PWZRMQvDM= +github.com/k0kubun/colorstring v0.0.0-20150214042306-9440f1994b88/go.mod h1:3w7q1U84EfirKl04SVQ/s7nPm1ZPhiXd34z40TNz36k= +github.com/k0kubun/pp v3.0.1+incompatible h1:3tqvf7QgUnZ5tXO6pNAZlrvHgl6DvifjDrd9g2S9Z40= +github.com/k0kubun/pp v3.0.1+incompatible/go.mod h1:GWse8YhT0p8pT4ir3ZgBbfZild3tgzSScAn6HmfYukg= github.com/klauspost/cpuid/v2 v2.0.12/go.mod h1:g2LTdtYhdyuGPqyWyv7qRAmj1WBqxuObKfj5c0PQa7c= -github.com/klauspost/cpuid/v2 v2.2.5 h1:0E5MSMDEoAulmXNFquVs//DdoomxaoTY1kUhbc/qbZg= -github.com/klauspost/cpuid/v2 v2.2.5/go.mod h1:Lcz8mBdAVJIBVzewtcLocK12l3Y+JytZYpaMropDUws= +github.com/klauspost/cpuid/v2 v2.2.6 h1:ndNyv040zDGIDh8thGkXYjnFtiN02M1PVVF+JE/48xc= github.com/klauspost/cpuid/v2 v2.2.6/go.mod h1:Lcz8mBdAVJIBVzewtcLocK12l3Y+JytZYpaMropDUws= github.com/kr/pretty v0.3.1 h1:flRD4NNwYAUpkphVc1HcthR4KEIFJ65n8Mw5qdRn3LE= github.com/kr/pretty v0.3.1/go.mod h1:hoEshYVHaxMs3cyo3Yncou5ZscifuDolrwPKZanG3xk= @@ -96,44 +102,21 @@ github.com/logrusorgru/aurora/v4 v4.0.0/go.mod h1:lP0iIa2nrnT/qoFXcOZSrZQpJ1o6n2 github.com/mattn/go-colorable v0.1.13 h1:fFA4WZxdEF4tXPZVKMLwD8oUnCTTo08duU7wxecdEvA= github.com/mattn/go-colorable v0.1.13/go.mod h1:7S9/ev0klgBDR4GtXTXX8a3vIGJpMovkB8vQcUbaXHg= github.com/mattn/go-isatty v0.0.16/go.mod h1:kYGgaQfpe5nmfYZH+SKPsOc2e4SrIfOl2e/yFXSvRLM= -github.com/mattn/go-isatty v0.0.19 h1:JITubQf0MOLdlGRuRq+jtsDlekdYPia9ZFsB8h/APPA= -github.com/mattn/go-isatty v0.0.19/go.mod h1:W+V8PltTTMOvKvAeJH7IuucS94S2C6jfK/D7dTCTo3Y= +github.com/mattn/go-isatty v0.0.20 h1:xfD0iDuEKnDkl03q4limB+vH+GxLEtL/jb4xVJSWWEY= github.com/mattn/go-isatty v0.0.20/go.mod h1:W+V8PltTTMOvKvAeJH7IuucS94S2C6jfK/D7dTCTo3Y= -github.com/onflow/atree v0.6.0 h1:j7nQ2r8npznx4NX39zPpBYHmdy45f4xwoi+dm37Jk7c= -github.com/onflow/atree v0.6.0/go.mod h1:gBHU0M05qCbv9NN0kijLWMgC47gHVNBIp4KmsVFi0tc= -github.com/onflow/atree v0.6.1-0.20230711151834-86040b30171f/go.mod h1:xvP61FoOs95K7IYdIYRnNcYQGf4nbF/uuJ0tHf4DRuM= -github.com/onflow/atree v0.6.1-0.20240429171449-cb486ceb1f9c/go.mod h1:xvP61FoOs95K7IYdIYRnNcYQGf4nbF/uuJ0tHf4DRuM= -github.com/onflow/atree v0.7.0-rc.2/go.mod h1:xvP61FoOs95K7IYdIYRnNcYQGf4nbF/uuJ0tHf4DRuM= -github.com/onflow/atree v0.8.0-rc.6/go.mod h1:yccR+LR7xc1Jdic0mrjocbHvUD7lnVvg8/Ct1AA5zBo= +github.com/onflow/atree v0.8.0 h1:qg5c6J1gVDNObughpEeWm8oxqhPGdEyGrda121GM4u0= github.com/onflow/atree v0.8.0/go.mod h1:yccR+LR7xc1Jdic0mrjocbHvUD7lnVvg8/Ct1AA5zBo= -github.com/onflow/cadence v0.42.7 h1:Qp9VYX901saO7wPwF/rwV4cMS+0mfWxnm9EqbYElYy4= -github.com/onflow/cadence v0.42.7/go.mod h1:raU8va8QRyTa/eUbhej4mbyW2ETePfSaywoo36MddgE= -github.com/onflow/cadence v1.0.0-M3/go.mod h1:odXGZZ/wGNA5mwT8bC9v8u8EXACHllB2ABSZK65TGL8= -github.com/onflow/cadence v1.0.0-M5/go.mod h1:a4mccDU90hmuxCLUFzs9J/ANG/rYbFa36h4Z0bBAqNU= -github.com/onflow/cadence v1.0.0-preview.25/go.mod h1:fGhLBbuEmv5rh48qv0ZS0tUz53gxWsHpB4dPsF09h6E= -github.com/onflow/cadence v1.0.0-preview.26/go.mod h1:fGhLBbuEmv5rh48qv0ZS0tUz53gxWsHpB4dPsF09h6E= -github.com/onflow/cadence v1.0.0-preview.29/go.mod h1:3LM1VgE9HkJ815whY/F0LYWULwJa8p2nJiKyIIxpGAE= -github.com/onflow/cadence v1.0.0-preview.31/go.mod h1:3LM1VgE9HkJ815whY/F0LYWULwJa8p2nJiKyIIxpGAE= -github.com/onflow/cadence v1.0.0-preview.35/go.mod h1:jOwvPSSLTr9TvaKMs7KKiBYMmpdpNNAFxBsjMlrqVD0= -github.com/onflow/cadence v1.0.0-preview.36/go.mod h1:jOwvPSSLTr9TvaKMs7KKiBYMmpdpNNAFxBsjMlrqVD0= -github.com/onflow/cadence v1.0.0-preview.38/go.mod h1:jOwvPSSLTr9TvaKMs7KKiBYMmpdpNNAFxBsjMlrqVD0= -github.com/onflow/cadence v1.0.0-preview.52/go.mod h1:7wvvecnAZtYOspLOS3Lh+FuAmMeSrXhAWiycC3kQ1UU= -github.com/onflow/cadence v1.0.0/go.mod h1:7wvvecnAZtYOspLOS3Lh+FuAmMeSrXhAWiycC3kQ1UU= -github.com/onflow/cadence v1.0.1-0.20241018173327-2e72919b18ac/go.mod h1:fJxxOAp1wnWDfOHT8GOc1ypsU0RR5E3z51AhG8Yf5jg= -github.com/onflow/cadence v1.2.1/go.mod h1:fJxxOAp1wnWDfOHT8GOc1ypsU0RR5E3z51AhG8Yf5jg= -github.com/onflow/crypto v0.25.0 h1:BeWbLsh3ZD13Ej+Uky6kg1PL1ZIVBDVX+2MVBNwqddg= -github.com/onflow/crypto v0.25.0/go.mod h1:C8FbaX0x8y+FxWjbkHy0Q4EASCDR9bSPWZqlpCLYyVI= +github.com/onflow/cadence v1.2.2 h1:LwigF/2lPiXlwX5rFn71KeMpmW5Iu/f/JtsPLLULBCc= +github.com/onflow/cadence v1.2.2/go.mod h1:PYX1xLejqswtDsQzN93x/VpfSKNyjUk6hrkc/mpv7xs= +github.com/onflow/crypto v0.25.1 h1:0txy2PKPMM873JbpxQNbJmuOJtD56bfs48RQfm0ts5A= github.com/onflow/crypto v0.25.1/go.mod h1:C8FbaX0x8y+FxWjbkHy0Q4EASCDR9bSPWZqlpCLYyVI= github.com/onflow/flow-cli/flowkit v1.11.0 h1:RSfKlla/l+ZJwqAmlvA5HPFbQ6ia2wzKSG0kJ8fqVa0= github.com/onflow/flow-cli/flowkit v1.11.0/go.mod h1:aH4shan7Ggxd0GIXZD2S4kYMemNfzP1rLWvzKnb6K3g= -github.com/onflow/flow/protobuf/go/flow v0.3.2-0.20231124194313-106cc495def6 h1:KMN+OEVaw7KAgxL3p8ux7CMuyTvacAlYTbasOqowh4M= -github.com/onflow/flow/protobuf/go/flow v0.3.2-0.20231124194313-106cc495def6/go.mod h1:NA2pX2nw8zuaxfKphhKsk00kWLwfd+tv8mS23YXO4Sk= -github.com/onflow/flow/protobuf/go/flow v0.4.0/go.mod h1:NA2pX2nw8zuaxfKphhKsk00kWLwfd+tv8mS23YXO4Sk= -github.com/onflow/flow/protobuf/go/flow v0.4.3/go.mod h1:NA2pX2nw8zuaxfKphhKsk00kWLwfd+tv8mS23YXO4Sk= +github.com/onflow/flow/protobuf/go/flow v0.4.7 h1:iP6DFx4wZ3ETORsyeqzHu7neFT3d1CXF6wdK+AOOjmc= github.com/onflow/flow/protobuf/go/flow v0.4.7/go.mod h1:NA2pX2nw8zuaxfKphhKsk00kWLwfd+tv8mS23YXO4Sk= -github.com/onflow/sdks v0.5.0 h1:2HCRibwqDaQ1c9oUApnkZtEAhWiNY2GTpRD5+ftdkN8= -github.com/onflow/sdks v0.5.0/go.mod h1:F0dj0EyHC55kknLkeD10js4mo14yTdMotnWMslPirrU= -github.com/onflow/sdks v0.5.1-0.20230912225508-b35402f12bba/go.mod h1:F0dj0EyHC55kknLkeD10js4mo14yTdMotnWMslPirrU= +github.com/onflow/go-ethereum v1.13.4 h1:iNO86fm8RbBbhZ87ZulblInqCdHnAQVY8okBrNsTevc= +github.com/onflow/go-ethereum v1.13.4/go.mod h1:cE/gEUkAffhwbVmMJYz+t1dAfVNHNwZCgc3BWtZxBGY= +github.com/onflow/sdks v0.6.0-preview.1 h1:mb/cUezuqWEP1gFZNAgUI4boBltudv4nlfxke1KBp9k= github.com/onflow/sdks v0.6.0-preview.1/go.mod h1:F0dj0EyHC55kknLkeD10js4mo14yTdMotnWMslPirrU= github.com/pkg/diff v0.0.0-20210226163009-20ebb0f2a09e/go.mod h1:pJLUxLENpZxwdsKMEsNbx1VGcRFpLqf3715MtcvvzbA= github.com/pkg/errors v0.9.1 h1:FEBLx1zS214owpjy7qsBeixbURkuhQAwrK5UwLGTwt4= @@ -143,8 +126,8 @@ github.com/pmezard/go-difflib v1.0.0/go.mod h1:iKH77koFhYxTK1pcRnkKkqfTogsbg7gZN github.com/prometheus/client_model v0.0.0-20190812154241-14fe0d1b01d4/go.mod h1:xMI15A0UPsDsEKsMN9yxemIoYk6Tm2C1GtYGdfGttqA= github.com/rivo/uniseg v0.4.4 h1:8TfxU8dW6PdqD27gjM8MVNuicgxIjxpm4K7x4jp8sis= github.com/rivo/uniseg v0.4.4/go.mod h1:FN3SvrM+Zdj16jyLfmOkMNblXMcoc8DfTHruCPUcx88= -github.com/rogpeppe/go-internal v1.9.0 h1:73kH8U+JUqXU8lRuOHeVHaa/SZPifC7BkcraZVejAe8= github.com/rogpeppe/go-internal v1.9.0/go.mod h1:WtVeX8xhTBvf0smdhujwtBcq4Qrzq/fJaraNFVN+nFs= +github.com/rogpeppe/go-internal v1.10.0 h1:TMyTOH3F/DB16zRVcYyreMH6GnZZrwQVAoYjRBZyWFQ= github.com/rogpeppe/go-internal v1.10.0/go.mod h1:UQnix2H7Ngw/k4C5ijL5+65zddjncjaFoBhdsK/akog= github.com/sirupsen/logrus v1.9.0 h1:trlNQbNUG3OdDrDil03MCb1H2o9nJ1x4/5LYw7byDE0= github.com/sirupsen/logrus v1.9.0/go.mod h1:naHLuLoDiP4jHNo9R0sCBMtWGeIprob74mVsIT4qYEQ= @@ -152,15 +135,14 @@ github.com/spf13/afero v1.11.0 h1:WJQKhtpdm3v2IzqG8VMqrr6Rf3UYpEF239Jy9wNepM8= github.com/spf13/afero v1.11.0/go.mod h1:GH9Y3pIexgf1MTIWtNGyogA5MwRIDXGUr+hbWNoBjkY= github.com/stretchr/objx v0.1.0/go.mod h1:HFkY916IF+rwdDfMAkV7OtwuqBVzrE8GR6GFx+wExME= github.com/stretchr/objx v0.4.0/go.mod h1:YvHI0jy2hoMjB+UWwv71VJQ9isScKT/TqJzVSSt89Yw= -github.com/stretchr/objx v0.5.0 h1:1zr/of2m5FGMsad5YfcqgdqdWrIhu+EBEJRhR1U7z/c= github.com/stretchr/objx v0.5.0/go.mod h1:Yh+to48EsGEfYuaHDzXPcE3xhTkx73EhmCGUpEOglKo= +github.com/stretchr/objx v0.5.2 h1:xuMeJ0Sdp5ZMRXx/aWO6RZxdr3beISkG5/G/aIRr3pY= github.com/stretchr/objx v0.5.2/go.mod h1:FRsXN1f5AsAjCGJKqEizvkpNtU+EGNCLh3NxZ/8L+MA= github.com/stretchr/testify v1.3.1-0.20190311161405-34c6fa2dc709/go.mod h1:M5WIy9Dh21IEIfnGCwXGc5bZfKNJtfHm1UVUgZn+9EI= github.com/stretchr/testify v1.7.1/go.mod h1:6Fq8oRcR53rry900zMqJjRRixrwX3KX962/h/Wwjteg= github.com/stretchr/testify v1.8.0/go.mod h1:yNjHg4UonilssWZ8iaSj1OCr/vHnekPRkoO+kdMU+MU= github.com/stretchr/testify v1.8.1/go.mod h1:w2LPCIKwWwSfY2zedu0+kehJoqGctiVI29o6fzry7u4= -github.com/stretchr/testify v1.8.4 h1:CcVxjf3Q8PM0mHUKJCdn+eZZtm5yQwehR5yeSVQQcUk= -github.com/stretchr/testify v1.8.4/go.mod h1:sz/lmYIOXD/1dqDmKjjqLyZ2RngseejIcXlSw2iwfAo= +github.com/stretchr/testify v1.9.0 h1:HtqpIVDClZ4nwg75+f6Lvsy/wHu+3BoSGCbBAcpTsTg= github.com/stretchr/testify v1.9.0/go.mod h1:r2ic/lqez/lEtzL7wO/rwa5dbSLXVDPFyf8C91i36aY= github.com/texttheater/golang-levenshtein/levenshtein v0.0.0-20200805054039-cae8b0eaed6c h1:HelZ2kAFadG0La9d+4htN4HzQ68Bm2iM9qKMSMES6xg= github.com/texttheater/golang-levenshtein/levenshtein v0.0.0-20200805054039-cae8b0eaed6c/go.mod h1:JlzghshsemAMDGZLytTFY8C1JQxQPhnatWqNwUXjggo= @@ -178,28 +160,36 @@ github.com/zeebo/pcg v1.0.1 h1:lyqfGeWiv4ahac6ttHs+I5hwtH/+1mrhlCtVNQM2kHo= github.com/zeebo/pcg v1.0.1/go.mod h1:09F0S9iiKrwn9rlI5yjLkmrug154/YRW6KnnXVDM/l4= go.opencensus.io v0.24.0 h1:y73uSU6J157QMP2kn2r30vwW1A2W2WFwSCGnAVxeaD0= go.opencensus.io v0.24.0/go.mod h1:vNK8G9p7aAivkbmorf4v+7Hgx+Zs0yY+0fOtgBfjQKo= -go.opentelemetry.io/otel v1.16.0 h1:Z7GVAX/UkAXPKsy94IU+i6thsQS4nb7LviLpnaNeW8s= -go.opentelemetry.io/otel v1.16.0/go.mod h1:vl0h9NUa1D5s1nv3A5vZOYWn8av4K8Ml6JDeHrT/bx4= +go.opentelemetry.io/contrib/instrumentation/google.golang.org/grpc/otelgrpc v0.47.0 h1:UNQQKPfTDe1J81ViolILjTKPr9WetKW6uei2hFgJmFs= +go.opentelemetry.io/contrib/instrumentation/google.golang.org/grpc/otelgrpc v0.47.0/go.mod h1:r9vWsPS/3AQItv3OSlEJ/E4mbrhUbbw18meOjArPtKQ= +go.opentelemetry.io/contrib/instrumentation/net/http/otelhttp v0.47.0 h1:sv9kVfal0MK0wBMCOGr+HeJm9v803BkJxGrk2au7j08= +go.opentelemetry.io/contrib/instrumentation/net/http/otelhttp v0.47.0/go.mod h1:SK2UL73Zy1quvRPonmOmRDiWk1KBV3LyIeeIxcEApWw= +go.opentelemetry.io/otel v1.24.0 h1:0LAOdjNmQeSTzGBzduGe/rU4tZhMwL5rWgtp9Ku5Jfo= go.opentelemetry.io/otel v1.24.0/go.mod h1:W7b9Ozg4nkF5tWI5zsXkaKKDjdVjpD4oAt9Qi/MArHo= -go.uber.org/goleak v1.2.1 h1:NBol2c7O1ZokfZ0LEU9K6Whx/KnwvepVetCUhtKja4A= -go.uber.org/goleak v1.2.1/go.mod h1:qlT2yGI9QafXHhZZLxlSuNsMw3FFLxBr+tBRlmO1xH4= +go.opentelemetry.io/otel/metric v1.24.0 h1:6EhoGWWK28x1fbpA4tYTOWBkPefTDQnb8WSGXlc88kI= +go.opentelemetry.io/otel/metric v1.24.0/go.mod h1:VYhLe1rFfxuTXLgj4CBiyz+9WYBA8pNGJgDcSFRKBco= +go.opentelemetry.io/otel/sdk v1.24.0 h1:YMPPDNymmQN3ZgczicBY3B6sf9n62Dlj9pWD3ucgoDw= +go.opentelemetry.io/otel/sdk v1.24.0/go.mod h1:KVrIYw6tEubO9E96HQpcmpTKDVn9gdv35HoYiQWGDFg= +go.opentelemetry.io/otel/trace v1.24.0 h1:CsKnnL4dUAr/0llH9FKuc698G04IrpWV0MQA/Y1YELI= +go.opentelemetry.io/otel/trace v1.24.0/go.mod h1:HPc3Xr/cOApsBI154IU0OI0HJexz+aw5uPdbs3UCjNU= +go.uber.org/goleak v1.1.10 h1:z+mqJhf6ss6BSfSM671tgKyZBFPTTJM+HLxnhPC3wu0= +go.uber.org/goleak v1.1.10/go.mod h1:8a7PlsEVH3e/a/GLqe5IIrQx6GzcnRmZEufDUTk4A7A= golang.org/x/crypto v0.0.0-20190308221718-c2843e01d9a2/go.mod h1:djNgcEr1/C05ACkg1iLfiJU5Ep61QUkGW8qpdssI0+w= golang.org/x/crypto v0.0.0-20200622213623-75b288015ac9/go.mod h1:LzIPMQfyMNhhGPhUkYOs5KpL4U8rLKemX1yGLhDgUto= golang.org/x/crypto v0.0.0-20210921155107-089bfa567519/go.mod h1:GvvjBRRGRdwPK5ydBHafDWAxML/pGHZbMvKqRZ5+Abc= -golang.org/x/crypto v0.16.0 h1:mMMrFzRSCF0GvB7Ne27XVtVAaXLrPmgPC7/v0tkwHaY= -golang.org/x/crypto v0.16.0/go.mod h1:gCAAfMLgwOJRpTjQ2zCCt2OcSfYMTeZVSRtQlPC7Nq4= -golang.org/x/crypto v0.19.0/go.mod h1:Iy9bg/ha4yyC70EfRS8jz+B6ybOBKMaSxLj6P6oBDfU= +golang.org/x/crypto v0.28.0 h1:GBDwsMXVQi34v5CCYUm2jkJvu4cbtru2U4TN2PSyQnw= +golang.org/x/crypto v0.28.0/go.mod h1:rmgy+3RHxRZMyY0jjAJShp2zgEdOqj2AO7U0pYmeQ7U= golang.org/x/exp v0.0.0-20190121172915-509febef88a4/go.mod h1:CJ0aWSM057203Lf6IL+f9T1iT9GByDxfZKAQTCR3kQA= -golang.org/x/exp v0.0.0-20230905200255-921286631fa9 h1:GoHiUyI/Tp2nVkLI2mCxVkOjsbSXD66ic0XW0js0R9g= -golang.org/x/exp v0.0.0-20230905200255-921286631fa9/go.mod h1:S2oDrQGGwySpoQPVqRShND87VCbxmc6bL1Yd2oYrm6k= -golang.org/x/exp v0.0.0-20240103183307-be819d1f06fc/go.mod h1:iRJReGqOEeBhDZGkGbynYwcHlctCvnjTYIamk7uXpHI= +golang.org/x/exp v0.0.0-20240119083558-1b970713d09a h1:Q8/wZp0KX97QFTc2ywcOE0YRjZPVIx+MXInMzdvQqcA= golang.org/x/exp v0.0.0-20240119083558-1b970713d09a/go.mod h1:idGWGoKP1toJGkd5/ig9ZLuPcZBC3ewk7SzmH0uou08= golang.org/x/lint v0.0.0-20181026193005-c67002cb31c3/go.mod h1:UVdnD1Gm6xHRNCYTkRU2/jEulfH38KcIWyp/GAMgvoE= golang.org/x/lint v0.0.0-20190227174305-5b3e6a55c961/go.mod h1:wehouNa3lNwaWXcvxsM5YxQ5yQlVC4a0KAMCusXpPoU= golang.org/x/lint v0.0.0-20190313153728-d0100b6bd8b3/go.mod h1:6SW0HCj/g11FgYtHlgUYUwCkIfeOF89ocIRzGO/8vkc= +golang.org/x/lint v0.0.0-20210508222113-6edffad5e616 h1:VLliZ0d+/avPrXXH+OakdXhpJuEoBZuwh1m2j7U6Iug= +golang.org/x/lint v0.0.0-20210508222113-6edffad5e616/go.mod h1:3xt1FjdF8hUf6vQPIChWIBhFzV8gjjsPE/fR3IyQdNY= golang.org/x/mod v0.6.0-dev.0.20220419223038-86c51ed26bb4/go.mod h1:jJ57K6gSWd91VN4djpZkiMVwK6gcyfeH4XE8wZrZaV4= -golang.org/x/mod v0.12.0 h1:rmsUpXtvNzj340zd98LZ4KntptpfRHwpFOHG188oHXc= -golang.org/x/mod v0.12.0/go.mod h1:iBbtSCu2XBx23ZKBPSOrRkjjQPZFPuis4dIYUhu/chs= +golang.org/x/mod v0.17.0 h1:zY54UmvipHiNd+pm+m0x9KhZ9hl1/7QNMyxXbc6ICqA= +golang.org/x/mod v0.17.0/go.mod h1:hTbmBsO62+eylJbnUtE2MGJUyE7QWk4xUqPFrRgJ+7c= golang.org/x/net v0.0.0-20180724234803-3673e40ba225/go.mod h1:mL1N/T3taQHkDXs73rZJwtUhF3w3ftmwwsq0BUmARs4= golang.org/x/net v0.0.0-20180826012351-8a410e7b638d/go.mod h1:mL1N/T3taQHkDXs73rZJwtUhF3w3ftmwwsq0BUmARs4= golang.org/x/net v0.0.0-20190213061140-3a22650c66bd/go.mod h1:mL1N/T3taQHkDXs73rZJwtUhF3w3ftmwwsq0BUmARs4= @@ -209,20 +199,17 @@ golang.org/x/net v0.0.0-20190620200207-3b0461eec859/go.mod h1:z5CRVTTTmAJ677TzLL golang.org/x/net v0.0.0-20201110031124-69a78807bb2b/go.mod h1:sp8m0HH+o8qH0wwXwYZr8TS3Oi6o0r6Gce1SSxlDquU= golang.org/x/net v0.0.0-20210226172049-e18ecbb05110/go.mod h1:m0MpNAwzfU5UDzcl9v0D8zg8gWTRqZa9RBIspLL5mdg= golang.org/x/net v0.0.0-20220722155237-a158d28d115b/go.mod h1:XRhObCWvk6IyKnWLug+ECip1KBveYUHfp+8e9klMJ9c= -golang.org/x/net v0.19.0 h1:zTwKpTd2XuCqf8huc7Fo2iSy+4RHPd10s4KzeTnVr1c= -golang.org/x/net v0.19.0/go.mod h1:CfAk/cbD4CthTvqiEl8NpboMuiuOYsAr/7NOjZJtv1U= +golang.org/x/net v0.21.0 h1:AQyQV4dYCvJ7vGmJyKki9+PBdyvhkSd8EIx/qb0AYv4= golang.org/x/net v0.21.0/go.mod h1:bIjVDfnllIU7BJ2DNgfnXvpSvtn8VRwhlsaeUTyUS44= golang.org/x/oauth2 v0.0.0-20180821212333-d2e6202438be/go.mod h1:N/0e6XlmueqKjAGxoOufVs8QHGRruUQn6yWY3a++T0U= -golang.org/x/oauth2 v0.15.0 h1:s8pnnxNVzjWyrvYdFUQq5llS1PX2zhPXmccZv99h7uQ= -golang.org/x/oauth2 v0.15.0/go.mod h1:q48ptWNTY5XWf+JNten23lcvHpLJ0ZSxF5ttTHKVCAM= +golang.org/x/oauth2 v0.17.0 h1:6m3ZPmLEFdVxKKWnKq4VqZ60gutO35zm+zrAHVmHyDQ= golang.org/x/oauth2 v0.17.0/go.mod h1:OzPDGQiuQMguemayvdylqddI7qcD9lnSDb+1FiwQ5HA= golang.org/x/sync v0.0.0-20180314180146-1d60e4601c6f/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= golang.org/x/sync v0.0.0-20181108010431-42b317875d0f/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= golang.org/x/sync v0.0.0-20190423024810-112230192c58/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= golang.org/x/sync v0.0.0-20220722155255-886fb9371eb4/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= -golang.org/x/sync v0.5.0 h1:60k92dhOjHxJkrqnwsfl8KuaHbn/5dl0lUPUklKo3qE= -golang.org/x/sync v0.5.0/go.mod h1:Czt+wKu1gCyEFDUtn0jG5QVvpJ6rzVqr5aXyt9drQfk= -golang.org/x/sync v0.6.0/go.mod h1:Czt+wKu1gCyEFDUtn0jG5QVvpJ6rzVqr5aXyt9drQfk= +golang.org/x/sync v0.8.0 h1:3NFvSEYkUoMifnESzZl15y791HH1qU2xm6eCJU5ZPXQ= +golang.org/x/sync v0.8.0/go.mod h1:Czt+wKu1gCyEFDUtn0jG5QVvpJ6rzVqr5aXyt9drQfk= golang.org/x/sys v0.0.0-20180830151530-49385e6e1522/go.mod h1:STP8DvDyc/dI5b8T5hshtkjS+E42TnysNCUPdjciGhY= golang.org/x/sys v0.0.0-20190215142949-d0b11bdaac8a/go.mod h1:STP8DvDyc/dI5b8T5hshtkjS+E42TnysNCUPdjciGhY= golang.org/x/sys v0.0.0-20190412213103-97732733099d/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= @@ -234,17 +221,16 @@ golang.org/x/sys v0.0.0-20220722155257-8c9f86f7a55f/go.mod h1:oPkhp1MJrh7nUepCBc golang.org/x/sys v0.0.0-20220811171246-fbc7d0a398ab/go.mod h1:oPkhp1MJrh7nUepCBck5+mAzfO9JrbApNNgaTdGDITg= golang.org/x/sys v0.5.0/go.mod h1:oPkhp1MJrh7nUepCBck5+mAzfO9JrbApNNgaTdGDITg= golang.org/x/sys v0.6.0/go.mod h1:oPkhp1MJrh7nUepCBck5+mAzfO9JrbApNNgaTdGDITg= -golang.org/x/sys v0.15.0 h1:h48lPFYpsTvQJZF4EKyI4aLHaev3CxivZmv7yZig9pc= -golang.org/x/sys v0.15.0/go.mod h1:/VUhepiaJMQUp4+oa/7Zr1D23ma6VTLIYjOOTFZPUcA= -golang.org/x/sys v0.17.0/go.mod h1:/VUhepiaJMQUp4+oa/7Zr1D23ma6VTLIYjOOTFZPUcA= +golang.org/x/sys v0.26.0 h1:KHjCJyddX0LoSTb3J+vWpupP9p0oznkqVk/IfjymZbo= +golang.org/x/sys v0.26.0/go.mod h1:/VUhepiaJMQUp4+oa/7Zr1D23ma6VTLIYjOOTFZPUcA= golang.org/x/term v0.0.0-20201126162022-7de9c90e9dd1/go.mod h1:bj7SfCRtBDWHUb9snDiAeCFNEtKQo2Wmx5Cou7ajbmo= golang.org/x/term v0.0.0-20210927222741-03fcf44c2211/go.mod h1:jbD1KX2456YbFQfuXm/mYQcufACuNUgVhRMnK/tPxf8= golang.org/x/text v0.3.0/go.mod h1:NqM8EUOU14njkJ3fqMW+pc6Ldnwhi/IjpwHt7yyuwOQ= golang.org/x/text v0.3.3/go.mod h1:5Zoc/QRtKVWzQhOtBMvqHzDpF6irO9z98xDceosuGiQ= golang.org/x/text v0.3.7/go.mod h1:u+2+/6zg+i71rQMx5EYifcz6MCKuco9NR6JIITiCfzQ= golang.org/x/text v0.3.8/go.mod h1:E6s5w1FMmriuDzIBO73fBruAKo1PCIq6d2Q6DHfQ8WQ= -golang.org/x/text v0.14.0 h1:ScX5w1eTa3QqT8oi6+ziP7dTV1S2+ALU0bI+0zXKWiQ= -golang.org/x/text v0.14.0/go.mod h1:18ZOQIKpY8NJVqYksKHtTdi31H5itFRjB5/qKTNYzSU= +golang.org/x/text v0.19.0 h1:kTxAhCbGbxhK0IwgSKiMO5awPoDQ0RpfiVYBfK860YM= +golang.org/x/text v0.19.0/go.mod h1:BuEKDfySbSR4drPmRPG/7iBdf8hvFMuRexcpahXilzY= golang.org/x/time v0.5.0 h1:o7cqy6amK/52YcAKIPlM3a+Fpj35zvRj2TP+e1xFSfk= golang.org/x/time v0.5.0/go.mod h1:3BpzKBy/shNhVucY/MWOyx10tF3SFh9QdLuxbVysPQM= golang.org/x/tools v0.0.0-20180917221912-90fa682c2a6e/go.mod h1:n7NCudcB/nEzxVGmLbDWY5pfWTLqBcC2KZ6jyYvM4mQ= @@ -254,18 +240,15 @@ golang.org/x/tools v0.0.0-20190311212946-11955173bddd/go.mod h1:LCzVGOaR6xXOjkQ3 golang.org/x/tools v0.0.0-20190524140312-2c0ae7006135/go.mod h1:RgjU9mgBXZiqYHBnxXauZ1Gv1EHHAz9KjViQ78xBX0Q= golang.org/x/tools v0.0.0-20191119224855-298f0cb1881e/go.mod h1:b+2E5dAYhXwXZwtnZ6UAqBI28+e2cm9otk0dWdXHAEo= golang.org/x/tools v0.1.12/go.mod h1:hNGJHUnrk76NpqgfD5Aqm5Crs+Hm0VOH/i9J2+nxYbc= -golang.org/x/tools v0.13.0 h1:Iey4qkscZuv0VvIt8E0neZjtPVQFSc870HQ448QgEmQ= -golang.org/x/tools v0.13.0/go.mod h1:HvlwmtVNQAhOuCjW7xxvovg8wbNq7LwfXh/k7wXUl58= +golang.org/x/tools v0.21.1-0.20240508182429-e35e4ccd0d2d h1:vU5i/LfpvrRCpgM/VPfJLg5KjxD3E+hfT1SH+d9zLwg= +golang.org/x/tools v0.21.1-0.20240508182429-e35e4ccd0d2d/go.mod h1:aiJjzUbINMkxbQROHiO6hDPo2LHcIPhhQsa9DLh0yGk= golang.org/x/xerrors v0.0.0-20190717185122-a985d3407aa7/go.mod h1:I/5z698sn9Ka8TeJc9MKroUUfqBBauWjQqLJ2OPfmY0= golang.org/x/xerrors v0.0.0-20191204190536-9bdfabe68543/go.mod h1:I/5z698sn9Ka8TeJc9MKroUUfqBBauWjQqLJ2OPfmY0= -golang.org/x/xerrors v0.0.0-20220907171357-04be3eba64a2 h1:H2TDz8ibqkAF6YGhCdN3jS9O0/s90v0rJh3X/OLHEUk= -golang.org/x/xerrors v0.0.0-20220907171357-04be3eba64a2/go.mod h1:K8+ghG5WaK9qNqU5K3HdILfMLy1f3aNYFI/wnl100a8= +golang.org/x/xerrors v0.0.0-20231012003039-104605ab7028 h1:+cNy6SZtPcJQH3LJVLOSmiC7MMxXNOb3PU/VUEz+EhU= golang.org/x/xerrors v0.0.0-20231012003039-104605ab7028/go.mod h1:NDW/Ps6MPRej6fsCIbMTohpP40sJ/P/vI1MoTEGwX90= -gonum.org/v1/gonum v0.13.0 h1:a0T3bh+7fhRyqeNbiC3qVHYmkiQgit3wnNan/2c0HMM= -gonum.org/v1/gonum v0.13.0/go.mod h1:/WPYRckkfWrhWefxyYTfrTtQR0KH4iyHNuzxqXAKyAU= +gonum.org/v1/gonum v0.14.0 h1:2NiG67LD1tEH0D7kM+ps2V+fXmsAnpUeec7n8tcr4S0= gonum.org/v1/gonum v0.14.0/go.mod h1:AoWeoz0becf9QMWtE8iWXNXc27fK4fNeHNf/oMejGfU= -google.golang.org/api v0.152.0 h1:t0r1vPnfMc260S2Ci+en7kfCZaLOPs5KI0sVV/6jZrY= -google.golang.org/api v0.152.0/go.mod h1:3qNJX5eOmhiWYc67jRA/3GsDw97UFb5ivv7Y2PrriAY= +google.golang.org/api v0.162.0 h1:Vhs54HkaEpkMBdgGdOT2P6F0csGG/vxDS0hWHJzmmps= google.golang.org/api v0.162.0/go.mod h1:6SulDkfoBIg4NFmCuZ39XeeAgSHCPecfSUuDyYlAHs0= google.golang.org/appengine v1.1.0/go.mod h1:EbEs0AVv82hx2wNQdGPgUI5lhzA/G0D9YwlJXL52JkM= google.golang.org/appengine v1.4.0/go.mod h1:xpcJRLb0r/rnEns0DIKYYv+WjYCduHsrkT7/EB5XEv4= @@ -274,22 +257,18 @@ google.golang.org/appengine v1.6.8/go.mod h1:1jJ3jBArFh5pcgW8gCtRJnepW8FzD1V44FJ google.golang.org/genproto v0.0.0-20180817151627-c66870c02cf8/go.mod h1:JiN7NxoALGmiZfu7CAH4rXhgtRTLTxftemlI0sWmxmc= google.golang.org/genproto v0.0.0-20190819201941-24fa4b261c55/go.mod h1:DMBHOl98Agz4BDEuKkezgsaosCRResVns1a3J2ZsMNc= google.golang.org/genproto v0.0.0-20200526211855-cb27e3aa2013/go.mod h1:NbSheEEYHJ7i3ixzK3sjbqSGDJWnxyFXZblF3eUsNvo= -google.golang.org/genproto v0.0.0-20231106174013-bbf56f31fb17 h1:wpZ8pe2x1Q3f2KyT5f8oP/fa9rHAKgFPr/HZdNuS+PQ= -google.golang.org/genproto v0.0.0-20231106174013-bbf56f31fb17/go.mod h1:J7XzRzVy1+IPwWHZUzoD0IccYZIrXILAQpc+Qy9CMhY= +google.golang.org/genproto v0.0.0-20240227224415-6ceb2ff114de h1:F6qOa9AZTYJXOUEr4jDysRDLrm4PHePlge4v4TGAlxY= google.golang.org/genproto v0.0.0-20240227224415-6ceb2ff114de/go.mod h1:VUhTRKeHn9wwcdrk73nvdC9gF178Tzhmt/qyaFcPLSo= -google.golang.org/genproto/googleapis/api v0.0.0-20231106174013-bbf56f31fb17 h1:JpwMPBpFN3uKhdaekDpiNlImDdkUAyiJ6ez/uxGaUSo= -google.golang.org/genproto/googleapis/api v0.0.0-20231106174013-bbf56f31fb17/go.mod h1:0xJLfVdJqpAPl8tDg1ujOCGzx6LFLttXT5NhllGOXY4= +google.golang.org/genproto/googleapis/api v0.0.0-20240227224415-6ceb2ff114de h1:jFNzHPIeuzhdRwVhbZdiym9q0ory/xY3sA+v2wPg8I0= google.golang.org/genproto/googleapis/api v0.0.0-20240227224415-6ceb2ff114de/go.mod h1:5iCWqnniDlqZHrd3neWVTOwvh/v6s3232omMecelax8= -google.golang.org/genproto/googleapis/rpc v0.0.0-20231120223509-83a465c0220f h1:ultW7fxlIvee4HYrtnaRPon9HpEgFk5zYpmfMgtKB5I= -google.golang.org/genproto/googleapis/rpc v0.0.0-20231120223509-83a465c0220f/go.mod h1:L9KNLi232K1/xB6f7AlSX692koaRnKaWSR0stBki0Yc= +google.golang.org/genproto/googleapis/rpc v0.0.0-20240227224415-6ceb2ff114de h1:cZGRis4/ot9uVm639a+rHCUaG0JJHEsdyzSQTMX+suY= google.golang.org/genproto/googleapis/rpc v0.0.0-20240227224415-6ceb2ff114de/go.mod h1:H4O17MA/PE9BsGx3w+a+W2VOLLD1Qf7oJneAoU6WktY= google.golang.org/grpc v1.19.0/go.mod h1:mqu4LbDTu4XGKhr4mRzUsmM4RtVoemTSY81AxZiDr8c= google.golang.org/grpc v1.23.0/go.mod h1:Y5yQAOtifL1yxbo5wqy6BxZv8vAUGQwXBOALyacEbxg= google.golang.org/grpc v1.25.1/go.mod h1:c3i+UQWmh7LiEpx4sFZnkU36qjEYZ0imhYfXVyQciAY= google.golang.org/grpc v1.27.0/go.mod h1:qbnxyOmOxrQa7FizSgH+ReBfzJrCY1pSN7KXBS8abTk= google.golang.org/grpc v1.33.2/go.mod h1:JMHMWHQWaTccqQQlmk3MJZS+GWXOdAesneDmEnv2fbc= -google.golang.org/grpc v1.61.0 h1:TOvOcuXn30kRao+gfcvsebNEa5iZIiLkisYEkf7R7o0= -google.golang.org/grpc v1.61.0/go.mod h1:VUbo7IFqmF1QtCAstipjG0GIoq49KvMe9+h1jFLBNJs= +google.golang.org/grpc v1.63.2 h1:MUeiw1B2maTVZthpU5xvASfTh3LDbxHd6IJ6QQVU+xM= google.golang.org/grpc v1.63.2/go.mod h1:WAX/8DgncnokcFUldAxq7GeB5DXHDbMF+lLvDomNkRA= google.golang.org/protobuf v0.0.0-20200109180630-ec00e32a8dfd/go.mod h1:DFci5gLYBciE7Vtevhsrf46CRTquxDuWsQurQQe4oz8= google.golang.org/protobuf v0.0.0-20200221191635-4d8936d0db64/go.mod h1:kwYJMbMJ01Woi6D6+Kah6886xMZcty6N08ah7+eCXa0= @@ -302,8 +281,7 @@ google.golang.org/protobuf v1.23.1-0.20200526195155-81db48ad09cc/go.mod h1:EGpAD google.golang.org/protobuf v1.25.0/go.mod h1:9JNX74DMeImyA3h4bdi1ymwjUzf21/xIlbajtzgsN7c= google.golang.org/protobuf v1.26.0-rc.1/go.mod h1:jlhhOSvTdKEhbULTjvd4ARK9grFBp09yW+WbY/TyQbw= google.golang.org/protobuf v1.26.0/go.mod h1:9q0QmTI4eRPtz6boOQmLYwt+qCgq0jsYwAQnmE0givc= -google.golang.org/protobuf v1.31.0 h1:g0LDEJHgrBl9N9r17Ru3sqWhkIx2NB67okBHPwC7hs8= -google.golang.org/protobuf v1.31.0/go.mod h1:HV8QOd/L58Z+nl8r43ehVNZIU/HEI6OcFqwMG9pJV4I= +google.golang.org/protobuf v1.33.0 h1:uNO2rsAINq/JlFpSdYEKIZ0uKD/R9cpdv0T+yoGwGmI= google.golang.org/protobuf v1.33.0/go.mod h1:c6P6GXX6sHbq/GpV6MGZEdwhWPcYBgnhAHhKbcUYpos= gopkg.in/check.v1 v0.0.0-20161208181325-20d25e280405/go.mod h1:Co6ibVJAznAaIkqp8huTwlJQCZ016jof/cbN4VW5Yz0= gopkg.in/check.v1 v1.0.0-20201130134442-10cb98267c6c h1:Hei/4ADfdWqJk1ZMxUNpqntNwaWcugrBjAiHlqqRiVk= @@ -313,7 +291,7 @@ gopkg.in/yaml.v3 v3.0.1 h1:fxVm/GzAzEWqLHuvctI91KS9hhNmmWOoWu0XTYJS7CA= gopkg.in/yaml.v3 v3.0.1/go.mod h1:K4uyk7z7BCEPqu6E+C64Yfv1cQ7kz7rIZviUmN+EgEM= honnef.co/go/tools v0.0.0-20190102054323-c2f93a96b099/go.mod h1:rf3lG4BRIbNafJWhAfAdb/ePZxsR/4RtNHQocxwk9r4= honnef.co/go/tools v0.0.0-20190523083050-ea95bdfd59fc/go.mod h1:rf3lG4BRIbNafJWhAfAdb/ePZxsR/4RtNHQocxwk9r4= -lukechampine.com/blake3 v1.2.1 h1:YuqqRuaqsGV71BV/nm9xlI0MKUv4QC54jQnBChWbGnI= -lukechampine.com/blake3 v1.2.1/go.mod h1:0OFRp7fBtAylGVCO40o87sbupkyIGgbpv1+M1k1LM6k= -pgregory.net/rapid v0.4.7 h1:MTNRktPuv5FNqOO151TM9mDTa+XHcX6ypYeISDVD14g= -pgregory.net/rapid v0.4.7/go.mod h1:UYpPVyjFHzYBGHIxLFoupi8vwk6rXNzRY9OMvVxFIOU= +lukechampine.com/blake3 v1.3.0 h1:sJ3XhFINmHSrYCgl958hscfIa3bw8x4DqMP3u1YvoYE= +lukechampine.com/blake3 v1.3.0/go.mod h1:0OFRp7fBtAylGVCO40o87sbupkyIGgbpv1+M1k1LM6k= +pgregory.net/rapid v1.1.0 h1:CMa0sjHSru3puNx+J0MIAuiiEV4N0qj8/cMWGBBCsjw= +pgregory.net/rapid v1.1.0/go.mod h1:PY5XlDGj0+V1FCq0o192FdRhpKHGTRIWBgqjDBTrq04= From bd09152d58eb3c56d86f7a79fda5ed2415449c4d Mon Sep 17 00:00:00 2001 From: =?UTF-8?q?Bastian=20M=C3=BCller?= Date: Wed, 30 Oct 2024 12:55:58 -0700 Subject: [PATCH 7/8] go mod tidy after make ci --- go.mod | 2 +- go.sum | 4 ++-- 2 files changed, 3 insertions(+), 3 deletions(-) diff --git a/go.mod b/go.mod index dba86088d..b7026b947 100644 --- a/go.mod +++ b/go.mod @@ -79,7 +79,7 @@ require ( golang.org/x/crypto v0.28.0 // indirect golang.org/x/exp v0.0.0-20240119083558-1b970713d09a // indirect golang.org/x/lint v0.0.0-20210508222113-6edffad5e616 // indirect - golang.org/x/net v0.21.0 // indirect + golang.org/x/net v0.25.0 // indirect golang.org/x/oauth2 v0.17.0 // indirect golang.org/x/sync v0.8.0 // indirect golang.org/x/sys v0.26.0 // indirect diff --git a/go.sum b/go.sum index 562d93782..96013eaaa 100644 --- a/go.sum +++ b/go.sum @@ -224,8 +224,8 @@ golang.org/x/net v0.0.0-20190620200207-3b0461eec859/go.mod h1:z5CRVTTTmAJ677TzLL golang.org/x/net v0.0.0-20201110031124-69a78807bb2b/go.mod h1:sp8m0HH+o8qH0wwXwYZr8TS3Oi6o0r6Gce1SSxlDquU= golang.org/x/net v0.0.0-20210226172049-e18ecbb05110/go.mod h1:m0MpNAwzfU5UDzcl9v0D8zg8gWTRqZa9RBIspLL5mdg= golang.org/x/net v0.0.0-20220722155237-a158d28d115b/go.mod h1:XRhObCWvk6IyKnWLug+ECip1KBveYUHfp+8e9klMJ9c= -golang.org/x/net v0.21.0 h1:AQyQV4dYCvJ7vGmJyKki9+PBdyvhkSd8EIx/qb0AYv4= -golang.org/x/net v0.21.0/go.mod h1:bIjVDfnllIU7BJ2DNgfnXvpSvtn8VRwhlsaeUTyUS44= +golang.org/x/net v0.25.0 h1:d/OCCoBEUq33pjydKrGQhw7IlUPI2Oylr+8qLx49kac= +golang.org/x/net v0.25.0/go.mod h1:JkAGAh7GEvH74S6FOH42FLoXpXbE/aqXSrIQjXgsiwM= golang.org/x/oauth2 v0.0.0-20180821212333-d2e6202438be/go.mod h1:N/0e6XlmueqKjAGxoOufVs8QHGRruUQn6yWY3a++T0U= golang.org/x/oauth2 v0.17.0 h1:6m3ZPmLEFdVxKKWnKq4VqZ60gutO35zm+zrAHVmHyDQ= golang.org/x/oauth2 v0.17.0/go.mod h1:OzPDGQiuQMguemayvdylqddI7qcD9lnSDb+1FiwQ5HA= From e84608b33c5042c3cddb7d0dad0b2e9b3127a218 Mon Sep 17 00:00:00 2001 From: Navid TehraniFar Date: Fri, 1 Nov 2024 13:05:06 -0700 Subject: [PATCH 8/8] fix examples (#793) Fix various examples issues --- access/http/handler.go | 2 +- access/http/handler_test.go | 2 +- examples/Makefile | 24 +- examples/deploy_contract/main.go | 4 +- examples/examples.go | 6 +- examples/execute_script/main.go | 38 +- examples/flow.json | 30 +- examples/get_events/main.go | 8 +- examples/get_execution_data/main.go | 5 +- examples/go.mod | 50 ++- examples/go.sum | 338 +++++++++++++++++- examples/great-token.cdc | 26 +- examples/modify_account/main.go | 6 +- examples/send_transactions/main.go | 16 +- examples/storage_usage/main.go | 16 +- examples/stream_events/main.go | 2 +- examples/stream_execution_data/main.go | 2 +- .../transaction_signing/multi_party/main.go | 4 +- .../multi_party_multisig/main.go | 4 +- .../multi_party_two_authorizers/main.go | 6 +- .../transaction_signing/single_party/main.go | 4 +- .../single_party_multisig/main.go | 4 +- examples/verify_events/main.go | 2 +- .../verify_signature/user_signature/main.go | 7 +- .../user_signature_validate_all/main.go | 15 +- .../user_signature_validate_any/main.go | 12 +- 26 files changed, 517 insertions(+), 116 deletions(-) diff --git a/access/http/handler.go b/access/http/handler.go index 26c720571..6f5fb1bf8 100644 --- a/access/http/handler.go +++ b/access/http/handler.go @@ -408,7 +408,7 @@ func (h *httpHandler) getExecutionResults( u := h.mustBuildURL("/execution_results", opts...) q := u.Query() - q.Add("block_ids", strings.Join(blockIDs, ",")) + q.Add("block_id", strings.Join(blockIDs, ",")) u.RawQuery = q.Encode() var results []models.ExecutionResult diff --git a/access/http/handler_test.go b/access/http/handler_test.go index e65bdf597..977e09fb3 100644 --- a/access/http/handler_test.go +++ b/access/http/handler_test.go @@ -569,7 +569,7 @@ func TestHandler_GetExecResult(t *testing.T) { u, _ := url.Parse("/execution_results") q := u.Query() - q.Add("block_ids", strings.Join(ids, ",")) + q.Add("block_id", strings.Join(ids, ",")) u.RawQuery = q.Encode() req.SetData(*u, fixture) diff --git a/examples/Makefile b/examples/Makefile index 6aac78abb..e8a745a7f 100644 --- a/examples/Makefile +++ b/examples/Makefile @@ -1,5 +1,5 @@ .PHONY: all -all: get-blocks get-accounts get-events get-collection get-network-parameters get-transactions execute-script send-transaction create-account add-account-key deploy-contract storage-usage transaction-arguments single-party single-party-multisig multi-party multi-party-multisig user-signature user-signature-validate-all user-signature-validate-any http-grpc-clients modify-account +all: get-blocks get-accounts get-events get-collection get-network-parameters get-transactions execute-script send-transactions create-account add-account-key deploy-contract storage-usage transaction-arguments single-party single-party-multisig multi-party multi-party-multisig user-signature user-signature-validate-all user-signature-validate-any http-grpc-clients modify-account get-execution-data .PHONY: create-account create-account: @@ -47,7 +47,7 @@ multi-party-multisig: .PHONY: user-signature user-signature: - go run ./user_signature/main.go + go run ./verify_signature/user_signature/main.go .PHONY: get-blocks get-blocks: @@ -77,8 +77,8 @@ get-transactions: execute-script: go run ./execute_script/main.go -.PHONY: send-transaction -send-transaction: +.PHONY: send-transactions +send-transactions: go run ./send_transactions/main.go .PHONY: user-signature-validate-all @@ -96,3 +96,19 @@ http-grpc-clients: .PHONY: modify-account modify-account: go run ./modify_account/main.go + +.PHONY: get-execution-data +get-execution-data: + go run ./get_execution_data/main.go + +.PHONY: stream-events +stream-events: + go run ./stream_events/main.go + +.PHONY: stream-events-reconnect +stream-events-reconnect: + go run ./stream_events_reconnect/main.go + +.PHONY: stream-execution-data +stream-execution-data: + go run ./stream_execution_data/main.go \ No newline at end of file diff --git a/examples/deploy_contract/main.go b/examples/deploy_contract/main.go index e55e77d59..5e20ac508 100644 --- a/examples/deploy_contract/main.go +++ b/examples/deploy_contract/main.go @@ -216,7 +216,7 @@ func GenerateMintScript(nftCodeAddr flow.Address) []byte { import GreatToken from 0x%s transaction { - prepare(acct: auth(Storage) &Account) { + prepare(acct: auth(Storage, Capabilities) &Account) { let minter = acct.storage.borrow<&GreatToken.GreatNFTMinter>(from: /storage/GreatNFTMinter)! if let nft <- acct.storage.load<@GreatToken.GreatNFT>(from: /storage/GreatNFT) { destroy nft @@ -236,7 +236,7 @@ func GenerateGetNFTIDScript(nftCodeAddr, userAddr flow.Address) []byte { template := ` import GreatToken from 0x%s - pub fun main(): Int { + access(all) fun main(): Int { let acct = getAccount(0x%s) let nft = acct.capabilities.borrow<&GreatToken.GreatNFT>(/public/GreatNFT)! return nft.id() diff --git a/examples/examples.go b/examples/examples.go index c444707d4..a712e086f 100644 --- a/examples/examples.go +++ b/examples/examples.go @@ -28,7 +28,7 @@ import ( "time" jsoncdc "github.com/onflow/cadence/encoding/json" - "github.com/onflow/flow-cli/flowkit/config" + "github.com/onflow/flowkit/config" "github.com/spf13/afero" "github.com/onflow/flow-go-sdk" @@ -38,7 +38,7 @@ import ( "github.com/onflow/flow-go-sdk/templates" "github.com/onflow/cadence" - "github.com/onflow/flow-cli/flowkit/config/json" + "github.com/onflow/flowkit/config/json" "github.com/onflow/cadence/sema" ) @@ -110,7 +110,7 @@ func RandomTransaction(flowClient access.Client) *flow.Transaction { tx := flow.NewTransaction(). SetPayer(serviceAcctAddr). SetProposalKey(serviceAcctAddr, serviceAcctKey.Index, serviceAcctKey.SequenceNumber). - SetScript([]byte("transaction { prepare(auth: AuthAccount) {} }")). + SetScript([]byte("transaction { prepare(signer: auth(Storage) &Account) {} }")). AddAuthorizer(serviceAcctAddr). SetReferenceBlockID(GetReferenceBlockId(flowClient)) diff --git a/examples/execute_script/main.go b/examples/execute_script/main.go index 162669b62..d4b504719 100644 --- a/examples/execute_script/main.go +++ b/examples/execute_script/main.go @@ -20,6 +20,7 @@ package main import ( "context" + "errors" "fmt" "github.com/onflow/flow-go-sdk/access/http" @@ -41,7 +42,7 @@ func demo() { examples.Handle(err) script := []byte(` - pub fun main(a: Int): Int { + access(all) fun main(a: Int): Int { return a + 10 } `) @@ -52,10 +53,10 @@ func demo() { fmt.Printf("\nValue: %s", value.String()) complexScript := []byte(` - pub struct User { - pub var balance: UFix64 - pub var address: Address - pub var name: String + access(all) struct User { + access(all) var balance: UFix64 + access(all) var address: Address + access(all) var name: String init(name: String, address: Address, balance: UFix64) { self.name = name @@ -64,7 +65,7 @@ func demo() { } } - pub fun main(name: String): User { + access(all) fun main(name: String): User { return User( name: name, address: 0x1, @@ -78,7 +79,7 @@ func demo() { } type User struct { - balance uint64 + balance string address flow.Address name string } @@ -88,15 +89,28 @@ func printComplexScript(value cadence.Value, err error) { fmt.Printf("\nString value: %s", value.String()) s := value.(cadence.Struct) + balanceCdc, ok := s.FieldsMappedByName()["balance"].(cadence.UFix64) + if !ok { + examples.Handle(errors.New("incorrect balance")) + } + addressCdc, ok := s.FieldsMappedByName()["address"].(cadence.Address) + if !ok { + examples.Handle(errors.New("incorrect address")) + } + nameCdc, ok := s.FieldsMappedByName()["name"].(cadence.String) + if !ok { + examples.Handle(errors.New("incorrect name")) + } + u := User{ - balance: s.Fields[0].ToGoValue().(uint64), - address: s.Fields[1].ToGoValue().([flow.AddressLength]byte), - name: s.Fields[2].ToGoValue().(string), + balance: balanceCdc.String(), + address: flow.BytesToAddress(addressCdc.Bytes()), + name: nameCdc.String(), } fmt.Printf("\nName: %s", u.name) - fmt.Printf("\nAddress: %s", u.address.String()) - fmt.Printf("\nBalance: %d", u.balance) + fmt.Printf("\nAddress: 0x%s", u.address.String()) + fmt.Printf("\nBalance: %s", u.balance) } func prepareDemo() { diff --git a/examples/flow.json b/examples/flow.json index c35509238..13f1b9e43 100644 --- a/examples/flow.json +++ b/examples/flow.json @@ -6,11 +6,31 @@ } }, "contracts": { - "FlowServiceAccount": "f8d6e0586b0a20c7", - "FlowFees": "e5a8b7f23e8b548f", - "FlowStorageFees": "f8d6e0586b0a20c7", - "FlowToken": "0ae53cb6e3f42a79", - "FungibleToken": "ee82856bf20e2aa6" + "FlowServiceAccount": { + "aliases": { + "emulator": "f8d6e0586b0a20c7" + } + }, + "FlowFees": { + "aliases": { + "emulator": "e5a8b7f23e8b548f" + } + }, + "FlowStorageFees": { + "aliases": { + "emulator": "f8d6e0586b0a20c7" + } + }, + "FlowToken": { + "aliases": { + "emulator": "0ae53cb6e3f42a79" + } + }, + "FungibleToken": { + "aliases": { + "emulator": "ee82856bf20e2aa6" + } + } }, "networks": { "emulator": "127.0.0.1:3569", diff --git a/examples/get_events/main.go b/examples/get_events/main.go index 2c248ef3d..68e12aeb6 100644 --- a/examples/get_events/main.go +++ b/examples/get_events/main.go @@ -84,10 +84,10 @@ func preapreDemo() (*flow.Account, *flow.Transaction) { // Deploy a contract with an event defined contract := ` - pub contract EventDemo { - pub event Add(x: Int, y: Int, sum: Int) + access(all) contract EventDemo { + access(all) event Add(x: Int, y: Int, sum: Int) - pub fun add(x: Int, y: Int) { + access(all) fun add(x: Int, y: Int) { let sum = x + y emit Add(x: x, y: y, sum: sum) } @@ -105,7 +105,7 @@ func preapreDemo() (*flow.Account, *flow.Transaction) { import EventDemo from 0x%s transaction { - prepare(auth: AuthAccount) {} + prepare(signer: auth(Storage) &Account) {} execute { EventDemo.add(x: 2, y: 3) } diff --git a/examples/get_execution_data/main.go b/examples/get_execution_data/main.go index 315cb462e..313c84cd5 100644 --- a/examples/get_execution_data/main.go +++ b/examples/get_execution_data/main.go @@ -34,11 +34,10 @@ func main() { func demo() { ctx := context.Background() - flowClient, err := grpc.NewClient("access-003.devnet46.nodes.onflow.org:9000") + flowClient, err := grpc.NewClient(grpc.TestnetHost) examples.Handle(err) - // block, err := flowClient.GetLatestBlock(ctx, true) - block, err := flowClient.GetBlockByID(ctx, flow.HexToID("7582cc6e1bb5ca1784e309ca63013e9b7ecf34b74bf7fdb029aa0faa0deb7958err")) + block, err := flowClient.GetLatestBlock(ctx, true) examples.Handle(err) fmt.Printf("Block Height: %d\n", block.Height) fmt.Printf("Block ID: %s\n", block.ID) diff --git a/examples/go.mod b/examples/go.mod index cd63b0260..5612b4c52 100644 --- a/examples/go.mod +++ b/examples/go.mod @@ -8,8 +8,8 @@ replace github.com/onflow/flow-go-sdk => ../ require ( github.com/onflow/cadence v1.2.2 - github.com/onflow/flow-cli/flowkit v1.11.0 - github.com/onflow/flow-go-sdk v0.41.17 + github.com/onflow/flow-go-sdk v1.2.2 + github.com/onflow/flowkit v1.19.0 github.com/spf13/afero v1.11.0 google.golang.org/grpc v1.63.2 ) @@ -21,10 +21,13 @@ require ( cloud.google.com/go/kms v1.15.7 // indirect github.com/SaveTheRbtz/mph v0.1.1-0.20240117162131-4166ec7869bc // indirect github.com/bits-and-blooms/bitset v1.10.0 // indirect - github.com/btcsuite/btcd/btcec/v2 v2.2.1 // indirect + github.com/btcsuite/btcd/btcec/v2 v2.3.4 // indirect + github.com/coreos/go-semver v0.3.0 // indirect github.com/davecgh/go-spew v1.1.1 // indirect github.com/decred/dcrd/dcrec/secp256k1/v4 v4.2.0 // indirect + github.com/ethereum/go-ethereum v1.13.10 // indirect github.com/felixge/httpsnoop v1.0.4 // indirect + github.com/fsnotify/fsnotify v1.6.0 // indirect github.com/fxamacker/cbor/v2 v2.4.1-0.20230228173756-c0c9f774e40c // indirect github.com/fxamacker/circlehash v0.3.0 // indirect github.com/go-logr/logr v1.4.1 // indirect @@ -34,29 +37,59 @@ require ( github.com/google/s2a-go v0.1.7 // indirect github.com/googleapis/enterprise-certificate-proxy v0.3.2 // indirect github.com/googleapis/gax-go/v2 v2.12.0 // indirect - github.com/holiman/uint256 v1.2.4 // indirect + github.com/hashicorp/hcl v1.0.0 // indirect + github.com/holiman/uint256 v1.3.0 // indirect github.com/iancoleman/orderedmap v0.0.0-20190318233801-ac98e3ecb4b0 // indirect + github.com/inconshreveable/mousetrap v1.1.0 // indirect github.com/invopop/jsonschema v0.7.0 // indirect + github.com/ipfs/go-cid v0.4.1 // indirect github.com/k0kubun/pp v3.0.1+incompatible // indirect + github.com/kevinburke/go-bindata v3.24.0+incompatible // indirect github.com/klauspost/cpuid/v2 v2.2.6 // indirect github.com/kr/pretty v0.3.1 // indirect github.com/kr/text v0.2.0 // indirect github.com/logrusorgru/aurora/v4 v4.0.0 // indirect + github.com/magiconair/properties v1.8.7 // indirect github.com/mattn/go-colorable v0.1.13 // indirect github.com/mattn/go-isatty v0.0.20 // indirect + github.com/minio/sha256-simd v1.0.1 // indirect + github.com/mitchellh/mapstructure v1.5.0 // indirect + github.com/mr-tron/base58 v1.2.0 // indirect + github.com/multiformats/go-base32 v0.1.0 // indirect + github.com/multiformats/go-base36 v0.2.0 // indirect + github.com/multiformats/go-multibase v0.2.0 // indirect + github.com/multiformats/go-multihash v0.2.3 // indirect + github.com/multiformats/go-varint v0.0.7 // indirect github.com/onflow/atree v0.8.0 // indirect - github.com/onflow/crypto v0.25.1 // indirect + github.com/onflow/crypto v0.25.2 // indirect + github.com/onflow/flow-core-contracts/lib/go/templates v1.4.0 // indirect + github.com/onflow/flow-ft/lib/go/templates v1.0.1 // indirect + github.com/onflow/flow-go v0.38.0-preview.0.0.20241022154145-6a254edbec23 // indirect + github.com/onflow/flow-nft/lib/go/templates v1.2.1 // indirect github.com/onflow/flow/protobuf/go/flow v0.4.7 // indirect - github.com/onflow/go-ethereum v1.13.4 // indirect + github.com/onflow/go-ethereum v1.14.7 // indirect github.com/onflow/sdks v0.6.0-preview.1 // indirect + github.com/pelletier/go-toml/v2 v2.0.6 // indirect github.com/pkg/errors v0.9.1 // indirect github.com/pmezard/go-difflib v1.0.0 // indirect + github.com/psiemens/sconfig v0.1.0 // indirect github.com/rivo/uniseg v0.4.4 // indirect github.com/rogpeppe/go-internal v1.10.0 // indirect + github.com/sirupsen/logrus v1.9.3 // indirect + github.com/spaolacci/murmur3 v1.1.0 // indirect + github.com/spf13/cast v1.5.0 // indirect + github.com/spf13/cobra v1.8.0 // indirect + github.com/spf13/jwalterweatherman v1.1.0 // indirect + github.com/spf13/pflag v1.0.5 // indirect + github.com/spf13/viper v1.15.0 // indirect github.com/stretchr/objx v0.5.2 // indirect github.com/stretchr/testify v1.9.0 // indirect + github.com/subosito/gotenv v1.4.2 // indirect github.com/texttheater/golang-levenshtein/levenshtein v0.0.0-20200805054039-cae8b0eaed6c // indirect github.com/turbolent/prettier v0.0.0-20220320183459-661cc755135d // indirect + github.com/vmihailenco/msgpack v4.0.4+incompatible // indirect + github.com/vmihailenco/msgpack/v4 v4.3.11 // indirect + github.com/vmihailenco/tagparser v0.1.1 // indirect github.com/x448/float16 v0.8.4 // indirect github.com/zeebo/blake3 v0.2.3 // indirect go.opencensus.io v0.24.0 // indirect @@ -65,9 +98,10 @@ require ( go.opentelemetry.io/otel v1.24.0 // indirect go.opentelemetry.io/otel/metric v1.24.0 // indirect go.opentelemetry.io/otel/trace v1.24.0 // indirect + go.uber.org/goleak v1.3.0 // indirect golang.org/x/crypto v0.28.0 // indirect golang.org/x/exp v0.0.0-20240119083558-1b970713d09a // indirect - golang.org/x/net v0.21.0 // indirect + golang.org/x/net v0.25.0 // indirect golang.org/x/oauth2 v0.17.0 // indirect golang.org/x/sync v0.8.0 // indirect golang.org/x/sys v0.26.0 // indirect @@ -81,5 +115,7 @@ require ( google.golang.org/genproto/googleapis/api v0.0.0-20240227224415-6ceb2ff114de // indirect google.golang.org/genproto/googleapis/rpc v0.0.0-20240227224415-6ceb2ff114de // indirect google.golang.org/protobuf v1.33.0 // indirect + gopkg.in/ini.v1 v1.67.0 // indirect gopkg.in/yaml.v3 v3.0.1 // indirect + lukechampine.com/blake3 v1.3.0 // indirect ) diff --git a/examples/go.sum b/examples/go.sum index 0fd4d1aa5..0da045614 100644 --- a/examples/go.sum +++ b/examples/go.sum @@ -10,47 +10,120 @@ cloud.google.com/go/iam v1.1.6/go.mod h1:O0zxdPeGBoFdWW3HWmBxJsk0pfvNM/p/qa82rWO cloud.google.com/go/kms v1.15.7 h1:7caV9K3yIxvlQPAcaFffhlT7d1qpxjB1wHBtjWa13SM= cloud.google.com/go/kms v1.15.7/go.mod h1:ub54lbsa6tDkUwnu4W7Yt1aAIFLnspgh0kPGToDukeI= github.com/BurntSushi/toml v0.3.1/go.mod h1:xHWCNGjB5oqiDr8zfno3MHue2Ht5sIBksp03qcyfWMU= +github.com/DataDog/zstd v1.5.2 h1:vUG4lAyuPCXO0TLbXvPv7EB7cNK1QV/luu55UHLrrn8= +github.com/DataDog/zstd v1.5.2/go.mod h1:g4AWEaM3yOg3HYfnJ3YIawPnVdXJh9QME85blwSAmyw= +github.com/OneOfOne/xxhash v1.2.2/go.mod h1:HSdplMjZKSmBqAxg5vPj2TmRDmfkzw+cTzAElWljhcU= github.com/SaveTheRbtz/mph v0.1.1-0.20240117162131-4166ec7869bc h1:DCHzPQOcU/7gwDTWbFQZc5qHMPS1g0xTO56k8NXsv9M= github.com/SaveTheRbtz/mph v0.1.1-0.20240117162131-4166ec7869bc/go.mod h1:LJM5a3zcIJ/8TmZwlUczvROEJT8ntOdhdG9jjcR1B0I= +github.com/alecthomas/template v0.0.0-20160405071501-a0175ee3bccc/go.mod h1:LOuyumcjzFXgccqObfd/Ljyb9UuFJ6TxHnclSeseNhc= +github.com/alecthomas/units v0.0.0-20151022065526-2efee857e7cf/go.mod h1:ybxpYRFXyAe+OPACYpWeL0wqObRcbAqCMya13uyzqw0= +github.com/armon/consul-api v0.0.0-20180202201655-eb2c6b5be1b6/go.mod h1:grANhF5doyWs3UAsr3K4I6qtAmlQcZDesFNEHPZAzj8= +github.com/beorn7/perks v0.0.0-20180321164747-3a771d992973/go.mod h1:Dwedo/Wpr24TaqPxmxbtue+5NUziq4I4S80YR8gNf3Q= +github.com/beorn7/perks v1.0.0/go.mod h1:KWe93zE9D1o94FZ5RNwFwVgaQK1VOXiVxmqh+CedLV8= +github.com/beorn7/perks v1.0.1 h1:VlbKKnNfV8bJzeqoa4cOKqO6bYr3WgKZxO8Z16+hsOM= +github.com/beorn7/perks v1.0.1/go.mod h1:G2ZrVWU2WbWT9wwq4/hrbKbnv/1ERSJQ0ibhJ6rlkpw= github.com/bits-and-blooms/bitset v1.10.0 h1:ePXTeiPEazB5+opbv5fr8umg2R/1NlzgDsyepwsSr88= github.com/bits-and-blooms/bitset v1.10.0/go.mod h1:7hO7Gc7Pp1vODcmWvKMRA9BNmbv6a/7QIWpPxHddWR8= -github.com/btcsuite/btcd/btcec/v2 v2.2.1 h1:xP60mv8fvp+0khmrN0zTdPC3cNm24rfeE6lh2R/Yv3E= -github.com/btcsuite/btcd/btcec/v2 v2.2.1/go.mod h1:9/CSmJxmuvqzX9Wh2fXMWToLOHhPd11lSPuIupwTkI8= +github.com/btcsuite/btcd/btcec/v2 v2.3.4 h1:3EJjcN70HCu/mwqlUsGK8GcNVyLVxFDlWurTXGPFfiQ= +github.com/btcsuite/btcd/btcec/v2 v2.3.4/go.mod h1:zYzJ8etWJQIv1Ogk7OzpWjowwOdXY1W/17j2MW85J04= +github.com/cenkalti/backoff/v4 v4.2.1 h1:y4OZtCnogmCPw98Zjyt5a6+QwPLGkiQsYW5oUqylYbM= +github.com/cenkalti/backoff/v4 v4.2.1/go.mod h1:Y3VNntkOUPxTVeUxJ/G5vcM//AlwfmyYozVcomhLiZE= github.com/census-instrumentation/opencensus-proto v0.2.1/go.mod h1:f6KPmirojxKA12rnyqOA5BBL4O983OfeGPqjHWSTneU= +github.com/cespare/xxhash v1.1.0 h1:a6HrQnmkObjyL+Gs60czilIUGqrzKutQD6XZog3p+ko= +github.com/cespare/xxhash v1.1.0/go.mod h1:XrSqR1VqqWfGrhpAt58auRo0WTKS1nRRg3ghfAqPWnc= +github.com/cespare/xxhash/v2 v2.3.0 h1:UL815xU9SqsFlibzuggzjXhog7bL6oX9BbNZnL2UFvs= +github.com/cespare/xxhash/v2 v2.3.0/go.mod h1:VGX0DQ3Q6kWi7AoAeZDth3/j3BFtOZR5XLFGgcrjCOs= github.com/client9/misspell v0.3.4/go.mod h1:qj6jICC3Q7zFZvVWo7KLAzC3yx5G7kyvSDkc90ppPyw= github.com/cncf/udpa/go v0.0.0-20191209042840-269d4d468f6f/go.mod h1:M8M6+tZqaGXZJjfX53e64911xZQV5JYwmTeXPW+k8Sc= github.com/cncf/xds/go v0.0.0-20231128003011-0fa0005c9caa h1:jQCWAUqqlij9Pgj2i/PB79y4KOPYVyFYdROxgaCwdTQ= github.com/cncf/xds/go v0.0.0-20231128003011-0fa0005c9caa/go.mod h1:x/1Gn8zydmfq8dk6e9PdstVsDgu9RuyIIJqAaF//0IM= +github.com/cockroachdb/errors v1.11.3 h1:5bA+k2Y6r+oz/6Z/RFlNeVCesGARKuC6YymtcDrbC/I= +github.com/cockroachdb/errors v1.11.3/go.mod h1:m4UIW4CDjx+R5cybPsNrRbreomiFqt8o1h1wUVazSd8= +github.com/cockroachdb/fifo v0.0.0-20240606204812-0bbfbd93a7ce h1:giXvy4KSc/6g/esnpM7Geqxka4WSqI1SZc7sMJFd3y4= +github.com/cockroachdb/fifo v0.0.0-20240606204812-0bbfbd93a7ce/go.mod h1:9/y3cnZ5GKakj/H4y9r9GTjCvAFta7KLgSHPJJYc52M= +github.com/cockroachdb/logtags v0.0.0-20230118201751-21c54148d20b h1:r6VH0faHjZeQy818SGhaone5OnYfxFR/+AzdY3sf5aE= +github.com/cockroachdb/logtags v0.0.0-20230118201751-21c54148d20b/go.mod h1:Vz9DsVWQQhf3vs21MhPMZpMGSht7O/2vFW2xusFUVOs= +github.com/cockroachdb/pebble v1.1.1 h1:XnKU22oiCLy2Xn8vp1re67cXg4SAasg/WDt1NtcRFaw= +github.com/cockroachdb/pebble v1.1.1/go.mod h1:4exszw1r40423ZsmkG/09AFEG83I0uDgfujJdbL6kYU= +github.com/cockroachdb/redact v1.1.5 h1:u1PMllDkdFfPWaNGMyLD1+so+aq3uUItthCFqzwPJ30= +github.com/cockroachdb/redact v1.1.5/go.mod h1:BVNblN9mBWFyMyqK1k3AAiSxhvhfK2oOZZ2lK+dpvRg= +github.com/cockroachdb/tokenbucket v0.0.0-20230807174530-cc333fc44b06 h1:zuQyyAKVxetITBuuhv3BI9cMrmStnpT18zmgmTxunpo= +github.com/cockroachdb/tokenbucket v0.0.0-20230807174530-cc333fc44b06/go.mod h1:7nc4anLGjupUW/PeY5qiNYsdNXj7zopG+eqsS7To5IQ= +github.com/coreos/bbolt v1.3.2/go.mod h1:iRUV2dpdMOn7Bo10OQBFzIJO9kkE559Wcmn+qkEiiKk= +github.com/coreos/etcd v3.3.10+incompatible/go.mod h1:uF7uidLiAD3TWHmW31ZFd/JWoc32PjwdhPthX9715RE= +github.com/coreos/go-etcd v2.0.0+incompatible/go.mod h1:Jez6KQU2B/sWsbdaef3ED8NzMklzPG4d5KIOhIy30Tk= +github.com/coreos/go-semver v0.2.0/go.mod h1:nnelYz7RCh+5ahJtPPxZlU+153eP4D4r3EedlOD2RNk= +github.com/coreos/go-semver v0.3.0 h1:wkHLiw0WNATZnSG7epLsujiMCgPAc9xhjJ4tgnAxmfM= +github.com/coreos/go-semver v0.3.0/go.mod h1:nnelYz7RCh+5ahJtPPxZlU+153eP4D4r3EedlOD2RNk= +github.com/coreos/go-systemd v0.0.0-20190321100706-95778dfbb74e/go.mod h1:F5haX7vjVVG0kc13fIWeqUViNPyEJxv/OmvnBo0Yme4= +github.com/coreos/pkg v0.0.0-20180928190104-399ea9e2e55f/go.mod h1:E3G3o1h8I7cfcXa63jLwjI0eiQQMgzzUDFVpN/nH/eA= +github.com/cpuguy83/go-md2man v1.0.10/go.mod h1:SmD6nW6nTyfqj6ABTjUi3V3JVMnlJmwcJI5acqYI6dE= +github.com/cpuguy83/go-md2man/v2 v2.0.3/go.mod h1:tgQtvFlXSQOSOSIRvRPT7W67SCa46tRHOmNcaadrF8o= github.com/creack/pty v1.1.9/go.mod h1:oKZEueFk5CKHvIhNR5MUki03XCEU+Q6VDXinZuGJ33E= github.com/davecgh/go-spew v1.1.0/go.mod h1:J7Y8YcW2NihsgmVo/mv3lAwl/skON4iLHjSsI+c5H38= github.com/davecgh/go-spew v1.1.1 h1:vj9j/u1bqnvCEfJOwUhtlOARqs3+rkHYY13jYWTU97c= github.com/davecgh/go-spew v1.1.1/go.mod h1:J7Y8YcW2NihsgmVo/mv3lAwl/skON4iLHjSsI+c5H38= github.com/decred/dcrd/dcrec/secp256k1/v4 v4.2.0 h1:8UrgZ3GkP4i/CLijOJx79Yu+etlyjdBU4sfcs2WYQMs= github.com/decred/dcrd/dcrec/secp256k1/v4 v4.2.0/go.mod h1:v57UDF4pDQJcEfFUCRop3lJL149eHGSe9Jvczhzjo/0= +github.com/dgraph-io/badger/v2 v2.2007.4 h1:TRWBQg8UrlUhaFdco01nO2uXwzKS7zd+HVdwV/GHc4o= +github.com/dgraph-io/badger/v2 v2.2007.4/go.mod h1:vSw/ax2qojzbN6eXHIx6KPKtCSHJN/Uz0X0VPruTIhk= +github.com/dgraph-io/ristretto v0.1.0 h1:Jv3CGQHp9OjuMBSne1485aDpUkTKEcUqF+jm/LuerPI= +github.com/dgraph-io/ristretto v0.1.0/go.mod h1:fux0lOrBhrVCJd3lcTHsIJhq1T2rokOu6v9Vcb3Q9ug= +github.com/dgrijalva/jwt-go v3.2.0+incompatible/go.mod h1:E3ru+11k8xSBh+hMPgOLZmtrrCbhqsmaPHjLKYnJCaQ= +github.com/dgryski/go-farm v0.0.0-20190423205320-6a90982ecee2 h1:tdlZCpZ/P9DhczCTSixgIKmwPv6+wP5DGjqLYw5SUiA= +github.com/dgryski/go-farm v0.0.0-20190423205320-6a90982ecee2/go.mod h1:SqUrOPUnsFjfmXRMNPybcSiG0BgUW2AuFH8PAnS2iTw= +github.com/dgryski/go-sip13 v0.0.0-20181026042036-e10d5fee7954/go.mod h1:vAd38F8PWV+bWy6jNmig1y/TA+kYO4g3RSRF0IAv0no= +github.com/dustin/go-humanize v1.0.1 h1:GzkhY7T5VNhEkwH0PVJgjz+fX1rhBrR7pRT3mDkpeCY= +github.com/dustin/go-humanize v1.0.1/go.mod h1:Mu1zIs6XwVuF/gI1OepvI0qD18qycQx+mFykh5fBlto= +github.com/ef-ds/deque v1.0.4 h1:iFAZNmveMT9WERAkqLJ+oaABF9AcVQ5AjXem/hroniI= +github.com/ef-ds/deque v1.0.4/go.mod h1:gXDnTC3yqvBcHbq2lcExjtAcVrOnJCbMcZXmuj8Z4tg= github.com/envoyproxy/go-control-plane v0.9.0/go.mod h1:YTl/9mNaCwkRvm6d1a2C3ymFceY/DCBVvsKhRF0iEA4= github.com/envoyproxy/go-control-plane v0.9.1-0.20191026205805-5f8ba28d4473/go.mod h1:YTl/9mNaCwkRvm6d1a2C3ymFceY/DCBVvsKhRF0iEA4= github.com/envoyproxy/go-control-plane v0.9.4/go.mod h1:6rpuAdCZL397s3pYoYcLgu1mIlRU8Am5FuJP05cCM98= github.com/envoyproxy/protoc-gen-validate v0.1.0/go.mod h1:iSmxcyjqTsJpI2R4NaDN7+kN2VEUnK/pcBlmesArF7c= github.com/envoyproxy/protoc-gen-validate v1.0.4 h1:gVPz/FMfvh57HdSJQyvBtF00j8JU4zdyUgIUNhlgg0A= github.com/envoyproxy/protoc-gen-validate v1.0.4/go.mod h1:qys6tmnRsYrQqIhm2bvKZH4Blx/1gTIZ2UKVY1M+Yew= +github.com/ethereum/go-ethereum v1.13.10 h1:Ppdil79nN+Vc+mXfge0AuUgmKWuVv4eMqzoIVSdqZek= +github.com/ethereum/go-ethereum v1.13.10/go.mod h1:sc48XYQxCzH3fG9BcrXCOOgQk2JfZzNAmIKnceogzsA= github.com/felixge/httpsnoop v1.0.4 h1:NFTV2Zj1bL4mc9sqWACXbQFVBBg2W3GPvqp8/ESS2Wg= github.com/felixge/httpsnoop v1.0.4/go.mod h1:m8KPJKqk1gH5J9DgRY2ASl2lWCfGKXixSwevea8zH2U= +github.com/frankban/quicktest v1.14.3 h1:FJKSZTDHjyhriyC81FLQ0LY93eSai0ZyR/ZIkd3ZUKE= +github.com/frankban/quicktest v1.14.3/go.mod h1:mgiwOwqx65TmIk1wJ6Q7wvnVMocbUorkibMOrVTHZps= +github.com/fsnotify/fsnotify v1.4.7/go.mod h1:jwhsz4b93w/PPRr/qN1Yymfu8t87LnFCMoQvtojpjFo= +github.com/fsnotify/fsnotify v1.6.0 h1:n+5WquG0fcWoWp6xPWfHdbskMCQaFnG6PfBrh1Ky4HY= +github.com/fsnotify/fsnotify v1.6.0/go.mod h1:sl3t1tCWJFWoRz9R8WJCbQihKKwmorjAbSClcnxKAGw= github.com/fxamacker/cbor/v2 v2.4.1-0.20230228173756-c0c9f774e40c h1:5tm/Wbs9d9r+qZaUFXk59CWDD0+77PBqDREffYkyi5c= github.com/fxamacker/cbor/v2 v2.4.1-0.20230228173756-c0c9f774e40c/go.mod h1:TA1xS00nchWmaBnEIxPSE5oHLuJBAVvqrtAnWBwBCVo= github.com/fxamacker/circlehash v0.3.0 h1:XKdvTtIJV9t7DDUtsf0RIpC1OcxZtPbmgIH7ekx28WA= github.com/fxamacker/circlehash v0.3.0/go.mod h1:3aq3OfVvsWtkWMb6A1owjOQFA+TLsD5FgJflnaQwtMM= +github.com/getsentry/sentry-go v0.27.0 h1:Pv98CIbtB3LkMWmXi4Joa5OOcwbmnX88sF5qbK3r3Ps= +github.com/getsentry/sentry-go v0.27.0/go.mod h1:lc76E2QywIyW8WuBnwl8Lc4bkmQH4+w1gwTf25trprY= +github.com/ghodss/yaml v1.0.0/go.mod h1:4dBDuWmgqj2HViK6kFavaiC9ZROes6MMH2rRYeMEF04= +github.com/go-kit/kit v0.8.0/go.mod h1:xBxKIO96dXMWWy0MnWVtmwkA9/13aqxPnvrjFYMA2as= +github.com/go-logfmt/logfmt v0.3.0/go.mod h1:Qt1PoO58o5twSAckw1HlFXLmHsOX5/0LbT9GBnD5lWE= +github.com/go-logfmt/logfmt v0.4.0/go.mod h1:3RMwSq7FuexP4Kalkev3ejPJsZTpXXBr9+V4qmtdjCk= github.com/go-logr/logr v1.2.2/go.mod h1:jdQByPbusPIv2/zmleS9BjJVeZ6kBagPoEUsqbVz/1A= github.com/go-logr/logr v1.4.1 h1:pKouT5E8xu9zeFC39JXRDukb6JFQPXM5p5I91188VAQ= github.com/go-logr/logr v1.4.1/go.mod h1:9T104GzyrTigFIr8wt5mBrctHMim0Nb2HLGrmQ40KvY= github.com/go-logr/stdr v1.2.2 h1:hSWxHoqTgW2S2qGc0LTAI563KZ5YKYRhT3MFKZMbjag= github.com/go-logr/stdr v1.2.2/go.mod h1:mMo/vtBO5dYbehREoey6XUKy/eSumjCCveDpRre4VKE= +github.com/go-stack/stack v1.8.0/go.mod h1:v0f6uXyyMGvRgIKkXu+yp6POWl0qKG85gN/melR3HDY= +github.com/gogo/protobuf v1.1.1/go.mod h1:r8qH/GZQm5c6nD/R0oafs1akxWv10x8SbQlK7atdtwQ= +github.com/gogo/protobuf v1.2.1/go.mod h1:hp+jE20tsWTFYpLwKvXlhS1hjn+gTNwPg2I6zVXpSg4= +github.com/gogo/protobuf v1.3.2 h1:Ov1cvc58UF3b5XjBnZv7+opcTcQFZebYjWzi34vdm4Q= +github.com/gogo/protobuf v1.3.2/go.mod h1:P1XiOD3dCwIKUDQYPy72D8LYyHL2YPYrpS2s69NZV8Q= github.com/golang/glog v0.0.0-20160126235308-23def4e6c14b/go.mod h1:SBH7ygxi8pfUlaOkMMuAQtPIUF8ecWP5IEl/CR7VP2Q= +github.com/golang/glog v1.2.0 h1:uCdmnmatrKCgMBlM4rMuJZWOkPDqdbZPnrMXDY4gI68= +github.com/golang/glog v1.2.0/go.mod h1:6AhwSGph0fcJtXVM/PEHPqZlFeoLxhs7/t5UDAwmO+w= +github.com/golang/groupcache v0.0.0-20190129154638-5b532d6fd5ef/go.mod h1:cIg4eruTrX1D+g88fzRXU5OdNfaM+9IcxsU14FzY7Hc= github.com/golang/groupcache v0.0.0-20200121045136-8c9f03a8e57e/go.mod h1:cIg4eruTrX1D+g88fzRXU5OdNfaM+9IcxsU14FzY7Hc= github.com/golang/groupcache v0.0.0-20210331224755-41bb18bfe9da h1:oI5xCqsCo564l8iNU+DwB5epxmsaqB+rhGL0m5jtYqE= github.com/golang/groupcache v0.0.0-20210331224755-41bb18bfe9da/go.mod h1:cIg4eruTrX1D+g88fzRXU5OdNfaM+9IcxsU14FzY7Hc= github.com/golang/mock v1.1.1/go.mod h1:oTYuIxOrZwtPieC+H1uAHpcLFnEyAGVDL/k47Jfbm0A= github.com/golang/protobuf v1.2.0/go.mod h1:6lQm79b+lXiMfvg/cZm0SGofjICqVBUtrP5yJMmIC1U= +github.com/golang/protobuf v1.3.1/go.mod h1:6lQm79b+lXiMfvg/cZm0SGofjICqVBUtrP5yJMmIC1U= github.com/golang/protobuf v1.3.2/go.mod h1:6lQm79b+lXiMfvg/cZm0SGofjICqVBUtrP5yJMmIC1U= +github.com/golang/protobuf v1.3.4/go.mod h1:vzj43D7+SQXF/4pzW/hwtAqwc6iTitCiVSaWz5lYuqw= github.com/golang/protobuf v1.4.0-rc.1/go.mod h1:ceaxUfeHdC40wWswd/P6IGgMaK3YpKi5j83Wpe3EHw8= github.com/golang/protobuf v1.4.0-rc.1.0.20200221234624-67d41d38c208/go.mod h1:xKAWHe0F5eneWXFV3EuXVDTCmh+JuBKY0li0aMyXATA= github.com/golang/protobuf v1.4.0-rc.2/go.mod h1:LlEzMj4AhA7rCAGe4KMBDvJI+AwstrUpVNzEA03Pprs= @@ -62,6 +135,9 @@ github.com/golang/protobuf v1.5.0/go.mod h1:FsONVRAS9T7sI+LIUmWTfcYkHO4aIWwzhcaS github.com/golang/protobuf v1.5.2/go.mod h1:XVQd3VNwM+JqD3oG2Ue2ip4fOMUkwXdXDdiuN0vRsmY= github.com/golang/protobuf v1.5.4 h1:i7eJL8qZTpSEXOPTxNKhASYpMn+8e5Q6AdndVa1dWek= github.com/golang/protobuf v1.5.4/go.mod h1:lnTiLA8Wa4RWRcIUkrtSVa5nRhsEGBg48fD6rSs7xps= +github.com/golang/snappy v0.0.5-0.20220116011046-fa5810519dcb h1:PBC98N2aIaM3XXiurYmW7fx4GZkL8feAMVq7nEjURHk= +github.com/golang/snappy v0.0.5-0.20220116011046-fa5810519dcb/go.mod h1:/XxbfmMg8lxefKM7IXC3fBNl/7bRcc72aCRzEWrmP2Q= +github.com/google/btree v1.0.0/go.mod h1:lNA+9X1NB3Zf8V7Ke586lFgjr2dZNuvo3lPJSGZ5JPQ= github.com/google/go-cmp v0.2.0/go.mod h1:oXzfMopK8JAjlY9xF4vHSVASa0yLyX7SntLO5aqRK0M= github.com/google/go-cmp v0.3.0/go.mod h1:8QqcDgzrUqlUb/G2PQTWiueGozuR1884gddMywk6iLU= github.com/google/go-cmp v0.3.1/go.mod h1:8QqcDgzrUqlUb/G2PQTWiueGozuR1884gddMywk6iLU= @@ -74,82 +150,263 @@ github.com/google/go-cmp v0.6.0/go.mod h1:17dUlkBOakJ0+DkrSSNjCkIjxS6bF9zb3elmeN github.com/google/s2a-go v0.1.7 h1:60BLSyTrOV4/haCDW4zb1guZItoSq8foHCXrAnjBo/o= github.com/google/s2a-go v0.1.7/go.mod h1:50CgR4k1jNlWBu4UfS4AcfhVe1r6pdZPygJ3R8F0Qdw= github.com/google/uuid v1.1.2/go.mod h1:TIyPZe4MgqvfeYDBFedMoGGpEw/LqOeaOT+nhxU+yHo= +github.com/google/uuid v1.6.0 h1:NIvaJDMOsjHA8n1jAhLSgzrAzy1Hgr+hNrb57e+94F0= +github.com/google/uuid v1.6.0/go.mod h1:TIyPZe4MgqvfeYDBFedMoGGpEw/LqOeaOT+nhxU+yHo= github.com/googleapis/enterprise-certificate-proxy v0.3.2 h1:Vie5ybvEvT75RniqhfFxPRy3Bf7vr3h0cechB90XaQs= github.com/googleapis/enterprise-certificate-proxy v0.3.2/go.mod h1:VLSiSSBs/ksPL8kq3OBOQ6WRI2QnaFynd1DCjZ62+V0= github.com/googleapis/gax-go/v2 v2.12.0 h1:A+gCJKdRfqXkr+BIRGtZLibNXf0m1f9E4HG56etFpas= github.com/googleapis/gax-go/v2 v2.12.0/go.mod h1:y+aIqrI5eb1YGMVJfuV3185Ts/D7qKpsEkdD5+I6QGU= -github.com/holiman/uint256 v1.2.4 h1:jUc4Nk8fm9jZabQuqr2JzednajVmBpC+oiTiXZJEApU= -github.com/holiman/uint256 v1.2.4/go.mod h1:EOMSn4q6Nyt9P6efbI3bueV4e1b3dGlUCXeiRV4ng7E= +github.com/gorilla/websocket v1.4.0/go.mod h1:E7qHFY5m1UJ88s3WnNqhKjPHQ0heANvMoAMk2YaljkQ= +github.com/grpc-ecosystem/go-grpc-middleware v1.0.0/go.mod h1:FiyG127CGDf3tlThmgyCl78X/SZQqEOJBCDaAfeWzPs= +github.com/grpc-ecosystem/go-grpc-prometheus v1.2.0/go.mod h1:8NvIoxWQoOIhqOTXgfV/d3M/q6VIi02HzZEHgUlZvzk= +github.com/grpc-ecosystem/grpc-gateway v1.9.0 h1:bM6ZAFZmc/wPFaRDi0d5L7hGEZEx/2u+Tmr2evNHDiI= +github.com/grpc-ecosystem/grpc-gateway v1.9.0/go.mod h1:vNeuVxBJEsws4ogUvrchl83t/GYV9WGTSLVdBhOQFDY= +github.com/grpc-ecosystem/grpc-gateway/v2 v2.19.0 h1:Wqo399gCIufwto+VfwCSvsnfGpF/w5E9CNxSwbpD6No= +github.com/grpc-ecosystem/grpc-gateway/v2 v2.19.0/go.mod h1:qmOFXW2epJhM0qSnUUYpldc7gVz2KMQwJ/QYCDIa7XU= +github.com/hashicorp/errwrap v1.1.0 h1:OxrOeh75EUXMY8TBjag2fzXGZ40LB6IKw45YeGUDY2I= +github.com/hashicorp/errwrap v1.1.0/go.mod h1:YH+1FKiLXxHSkmPseP+kNlulaMuP3n2brvKWEqk/Jc4= +github.com/hashicorp/go-multierror v1.1.1 h1:H5DkEtf6CXdFp0N0Em5UCwQpXMWke8IA0+lD48awMYo= +github.com/hashicorp/go-multierror v1.1.1/go.mod h1:iw975J/qwKPdAO1clOe2L8331t/9/fmwbPZ6JB6eMoM= +github.com/hashicorp/golang-lru v1.0.2 h1:dV3g9Z/unq5DpblPpw+Oqcv4dU/1omnb4Ok8iPY6p1c= +github.com/hashicorp/golang-lru v1.0.2/go.mod h1:iADmTwqILo4mZ8BN3D2Q6+9jd8WM5uGBxy+E8yxSoD4= +github.com/hashicorp/golang-lru/v2 v2.0.7 h1:a+bsQ5rvGLjzHuww6tVxozPZFVghXaHOwFs4luLUK2k= +github.com/hashicorp/golang-lru/v2 v2.0.7/go.mod h1:QeFd9opnmA6QUJc5vARoKUSoFhyfM2/ZepoAG6RGpeM= +github.com/hashicorp/hcl v1.0.0 h1:0Anlzjpi4vEasTeNFn2mLJgTSwt0+6sfsiTG8qcWGx4= +github.com/hashicorp/hcl v1.0.0/go.mod h1:E5yfLk+7swimpb2L/Alb/PJmXilQ/rhwaUYs4T20WEQ= +github.com/holiman/uint256 v1.3.0 h1:4wdcm/tnd0xXdu7iS3ruNvxkWwrb4aeBQv19ayYn8F4= +github.com/holiman/uint256 v1.3.0/go.mod h1:EOMSn4q6Nyt9P6efbI3bueV4e1b3dGlUCXeiRV4ng7E= +github.com/huandu/go-clone v1.6.0 h1:HMo5uvg4wgfiy5FoGOqlFLQED/VGRm2D9Pi8g1FXPGc= +github.com/huandu/go-clone v1.6.0/go.mod h1:ReGivhG6op3GYr+UY3lS6mxjKp7MIGTknuU5TbTVaXE= +github.com/huandu/go-clone/generic v1.7.2 h1:47pQphxs1Xc9cVADjOHN+Bm5D0hNagwH9UXErbxgVKA= +github.com/huandu/go-clone/generic v1.7.2/go.mod h1:xgd9ZebcMsBWWcBx5mVMCoqMX24gLWr5lQicr+nVXNs= github.com/iancoleman/orderedmap v0.0.0-20190318233801-ac98e3ecb4b0 h1:i462o439ZjprVSFSZLZxcsoAe592sZB1rci2Z8j4wdk= github.com/iancoleman/orderedmap v0.0.0-20190318233801-ac98e3ecb4b0/go.mod h1:N0Wam8K1arqPXNWjMo21EXnBPOPp36vB07FNRdD2geA= +github.com/inconshreveable/mousetrap v1.0.0/go.mod h1:PxqpIevigyE2G7u3NXJIT2ANytuPF1OarO4DADm73n8= +github.com/inconshreveable/mousetrap v1.1.0 h1:wN+x4NVGpMsO7ErUn/mUI3vEoE6Jt13X2s0bqwp9tc8= +github.com/inconshreveable/mousetrap v1.1.0/go.mod h1:vpF70FUmC8bwa3OWnCshd2FqLfsEA9PFc4w1p2J65bw= github.com/invopop/jsonschema v0.7.0 h1:2vgQcBz1n256N+FpX3Jq7Y17AjYt46Ig3zIWyy770So= github.com/invopop/jsonschema v0.7.0/go.mod h1:O9uiLokuu0+MGFlyiaqtWxwqJm41/+8Nj0lD7A36YH0= +github.com/ipfs/bbloom v0.0.4 h1:Gi+8EGJ2y5qiD5FbsbpX/TMNcJw8gSqr7eyjHa4Fhvs= +github.com/ipfs/bbloom v0.0.4/go.mod h1:cS9YprKXpoZ9lT0n/Mw/a6/aFV6DTjTLYHeA+gyqMG0= +github.com/ipfs/boxo v0.17.1-0.20240131173518-89bceff34bf1 h1:5H/HYvdmbxp09+sAvdqJzyrWoyCS6OroeW9Ym06Tb+0= +github.com/ipfs/boxo v0.17.1-0.20240131173518-89bceff34bf1/go.mod h1:pIZgTWdm3k3pLF9Uq6MB8JEcW07UDwNJjlXW1HELW80= +github.com/ipfs/go-block-format v0.2.0 h1:ZqrkxBA2ICbDRbK8KJs/u0O3dlp6gmAuuXUJNiW1Ycs= +github.com/ipfs/go-block-format v0.2.0/go.mod h1:+jpL11nFx5A/SPpsoBn6Bzkra/zaArfSmsknbPMYgzM= +github.com/ipfs/go-cid v0.4.1 h1:A/T3qGvxi4kpKWWcPC/PgbvDA2bjVLO7n4UeVwnbs/s= +github.com/ipfs/go-cid v0.4.1/go.mod h1:uQHwDeX4c6CtyrFwdqyhpNcxVewur1M7l7fNU7LKwZk= +github.com/ipfs/go-datastore v0.6.0 h1:JKyz+Gvz1QEZw0LsX1IBn+JFCJQH4SJVFtM4uWU0Myk= +github.com/ipfs/go-datastore v0.6.0/go.mod h1:rt5M3nNbSO/8q1t4LNkLyUwRs8HupMeN/8O4Vn9YAT8= +github.com/ipfs/go-ipfs-util v0.0.3 h1:2RFdGez6bu2ZlZdI+rWfIdbQb1KudQp3VGwPtdNCmE0= +github.com/ipfs/go-ipfs-util v0.0.3/go.mod h1:LHzG1a0Ig4G+iZ26UUOMjHd+lfM84LZCrn17xAKWBvs= +github.com/ipfs/go-ipld-format v0.6.0 h1:VEJlA2kQ3LqFSIm5Vu6eIlSxD/Ze90xtc4Meten1F5U= +github.com/ipfs/go-ipld-format v0.6.0/go.mod h1:g4QVMTn3marU3qXchwjpKPKgJv+zF+OlaKMyhJ4LHPg= +github.com/ipfs/go-log v1.0.5 h1:2dOuUCB1Z7uoczMWgAyDck5JLb72zHzrMnGnCNNbvY8= +github.com/ipfs/go-log/v2 v2.5.1 h1:1XdUzF7048prq4aBjDQQ4SL5RxftpRGdXhNRwKSAlcY= +github.com/ipfs/go-log/v2 v2.5.1/go.mod h1:prSpmC1Gpllc9UYWxDiZDreBYw7zp4Iqp1kOLU9U5UI= +github.com/ipfs/go-metrics-interface v0.0.1 h1:j+cpbjYvu4R8zbleSs36gvB7jR+wsL2fGD6n0jO4kdg= +github.com/ipfs/go-metrics-interface v0.0.1/go.mod h1:6s6euYU4zowdslK0GKHmqaIZ3j/b/tL7HTWtJ4VPgWY= +github.com/jbenet/goprocess v0.1.4 h1:DRGOFReOMqqDNXwW70QkacFW0YN9QnwLV0Vqk+3oU0o= +github.com/jbenet/goprocess v0.1.4/go.mod h1:5yspPrukOVuOLORacaBi858NqyClJPQxYZlqdZVfqY4= +github.com/jonboulle/clockwork v0.1.0/go.mod h1:Ii8DK3G1RaLaWxj9trq07+26W01tbo22gdxWY5EU2bo= +github.com/julienschmidt/httprouter v1.2.0/go.mod h1:SYymIcj16QtmaHHD7aYtjjsJG7VTCxuUUipMqKk8s4w= github.com/k0kubun/colorstring v0.0.0-20150214042306-9440f1994b88 h1:uC1QfSlInpQF+M0ao65imhwqKnz3Q2z/d8PWZRMQvDM= github.com/k0kubun/colorstring v0.0.0-20150214042306-9440f1994b88/go.mod h1:3w7q1U84EfirKl04SVQ/s7nPm1ZPhiXd34z40TNz36k= github.com/k0kubun/pp v3.0.1+incompatible h1:3tqvf7QgUnZ5tXO6pNAZlrvHgl6DvifjDrd9g2S9Z40= github.com/k0kubun/pp v3.0.1+incompatible/go.mod h1:GWse8YhT0p8pT4ir3ZgBbfZild3tgzSScAn6HmfYukg= +github.com/kevinburke/go-bindata v3.24.0+incompatible h1:qajFA3D0pH94OTLU4zcCCKCDgR+Zr2cZK/RPJHDdFoY= +github.com/kevinburke/go-bindata v3.24.0+incompatible/go.mod h1:/pEEZ72flUW2p0yi30bslSp9YqD9pysLxunQDdb2CPM= +github.com/kisielk/errcheck v1.1.0/go.mod h1:EZBBE59ingxPouuu3KfxchcWSUPOHkagtvWXihfKN4Q= +github.com/kisielk/gotool v1.0.0/go.mod h1:XhKaO+MFFWcvkIS/tQcRk01m1F5IRFswLeQ+oQHNcck= +github.com/klauspost/compress v1.17.4 h1:Ej5ixsIri7BrIjBkRZLTo6ghwrEtHFk7ijlczPW4fZ4= +github.com/klauspost/compress v1.17.4/go.mod h1:/dCuZOvVtNoHsyb+cuJD3itjs3NbnF6KH9zAO4BDxPM= github.com/klauspost/cpuid/v2 v2.0.12/go.mod h1:g2LTdtYhdyuGPqyWyv7qRAmj1WBqxuObKfj5c0PQa7c= github.com/klauspost/cpuid/v2 v2.2.6 h1:ndNyv040zDGIDh8thGkXYjnFtiN02M1PVVF+JE/48xc= github.com/klauspost/cpuid/v2 v2.2.6/go.mod h1:Lcz8mBdAVJIBVzewtcLocK12l3Y+JytZYpaMropDUws= +github.com/konsorten/go-windows-terminal-sequences v1.0.1/go.mod h1:T0+1ngSBFLxvqU3pZ+m/2kptfBszLMUkC4ZK/EgS/cQ= +github.com/kr/logfmt v0.0.0-20140226030751-b84e30acd515/go.mod h1:+0opPa2QZZtGFBFZlji/RkVcI2GknAs/DXo4wKdlNEc= +github.com/kr/pretty v0.1.0/go.mod h1:dAy3ld7l9f0ibDNOQOHHMYYIIbhfbHSm3C4ZsoJORNo= github.com/kr/pretty v0.3.1 h1:flRD4NNwYAUpkphVc1HcthR4KEIFJ65n8Mw5qdRn3LE= github.com/kr/pretty v0.3.1/go.mod h1:hoEshYVHaxMs3cyo3Yncou5ZscifuDolrwPKZanG3xk= +github.com/kr/pty v1.1.1/go.mod h1:pFQYn66WHrOpPYNljwOMqo10TkYh1fy3cYio2l3bCsQ= +github.com/kr/text v0.1.0/go.mod h1:4Jbv+DJW3UT/LiOwJeYQe1efqtUx/iVham/4vfdArNI= github.com/kr/text v0.2.0 h1:5Nx0Ya0ZqY2ygV366QzturHI13Jq95ApcVaJBhpS+AY= github.com/kr/text v0.2.0/go.mod h1:eLer722TekiGuMkidMxC/pM04lWEeraHUUmBw8l2grE= github.com/leanovate/gopter v0.2.9 h1:fQjYxZaynp97ozCzfOyOuAGOU4aU/z37zf/tOujFk7c= github.com/leanovate/gopter v0.2.9/go.mod h1:U2L/78B+KVFIx2VmW6onHJQzXtFb+p5y3y2Sh+Jxxv8= +github.com/libp2p/go-buffer-pool v0.1.0 h1:oK4mSFcQz7cTQIfqbe4MIj9gLW+mnanjyFtc6cdF0Y8= +github.com/libp2p/go-buffer-pool v0.1.0/go.mod h1:N+vh8gMqimBzdKkSMVuydVDq+UV5QTWy5HSiZacSbPg= +github.com/libp2p/go-libp2p v0.32.2 h1:s8GYN4YJzgUoyeYNPdW7JZeZ5Ee31iNaIBfGYMAY4FQ= +github.com/libp2p/go-libp2p v0.32.2/go.mod h1:E0LKe+diV/ZVJVnOJby8VC5xzHF0660osg71skcxJvk= +github.com/libp2p/go-libp2p-pubsub v0.10.0 h1:wS0S5FlISavMaAbxyQn3dxMOe2eegMfswM471RuHJwA= +github.com/libp2p/go-libp2p-pubsub v0.10.0/go.mod h1:1OxbaT/pFRO5h+Dpze8hdHQ63R0ke55XTs6b6NwLLkw= +github.com/libp2p/go-msgio v0.3.0 h1:mf3Z8B1xcFN314sWX+2vOTShIE0Mmn2TXn3YCUQGNj0= +github.com/libp2p/go-msgio v0.3.0/go.mod h1:nyRM819GmVaF9LX3l03RMh10QdOroF++NBbxAb0mmDM= github.com/logrusorgru/aurora/v4 v4.0.0 h1:sRjfPpun/63iADiSvGGjgA1cAYegEWMPCJdUpJYn9JA= github.com/logrusorgru/aurora/v4 v4.0.0/go.mod h1:lP0iIa2nrnT/qoFXcOZSrZQpJ1o6n2CUf/hyHi2Q4ZQ= +github.com/magiconair/properties v1.8.0/go.mod h1:PppfXfuXeibc/6YijjN8zIbojt8czPbwD3XqdrwzmxQ= +github.com/magiconair/properties v1.8.7 h1:IeQXZAiQcpL9mgcAe1Nu6cX9LLw6ExEHKjN0VQdvPDY= +github.com/magiconair/properties v1.8.7/go.mod h1:Dhd985XPs7jluiymwWYZ0G4Z61jb3vdS329zhj2hYo0= github.com/mattn/go-colorable v0.1.13 h1:fFA4WZxdEF4tXPZVKMLwD8oUnCTTo08duU7wxecdEvA= github.com/mattn/go-colorable v0.1.13/go.mod h1:7S9/ev0klgBDR4GtXTXX8a3vIGJpMovkB8vQcUbaXHg= github.com/mattn/go-isatty v0.0.16/go.mod h1:kYGgaQfpe5nmfYZH+SKPsOc2e4SrIfOl2e/yFXSvRLM= github.com/mattn/go-isatty v0.0.20 h1:xfD0iDuEKnDkl03q4limB+vH+GxLEtL/jb4xVJSWWEY= github.com/mattn/go-isatty v0.0.20/go.mod h1:W+V8PltTTMOvKvAeJH7IuucS94S2C6jfK/D7dTCTo3Y= +github.com/matttproud/golang_protobuf_extensions v1.0.1/go.mod h1:D8He9yQNgCq6Z5Ld7szi9bcBfOoFv/3dc6xSMkL2PC0= +github.com/matttproud/golang_protobuf_extensions v1.0.2-0.20181231171920-c182affec369 h1:I0XW9+e1XWDxdcEniV4rQAIOPUGDq67JSCiRCgGCZLI= +github.com/matttproud/golang_protobuf_extensions/v2 v2.0.0 h1:jWpvCLoY8Z/e3VKvlsiIGKtc+UG6U5vzxaoagmhXfyg= +github.com/matttproud/golang_protobuf_extensions/v2 v2.0.0/go.mod h1:QUyp042oQthUoa9bqDv0ER0wrtXnBruoNd7aNjkbP+k= +github.com/minio/sha256-simd v1.0.1 h1:6kaan5IFmwTNynnKKpDHe6FWHohJOHhCPchzK49dzMM= +github.com/minio/sha256-simd v1.0.1/go.mod h1:Pz6AKMiUdngCLpeTL/RJY1M9rUuPMYujV5xJjtbRSN8= +github.com/mitchellh/go-homedir v1.1.0/go.mod h1:SfyaCUpYCn1Vlf4IUYiD9fPX4A5wJrkLzIz1N1q0pr0= +github.com/mitchellh/mapstructure v1.1.2/go.mod h1:FVVH3fgwuzCH5S8UJGiWEs2h04kUh9fWfEaFds41c1Y= +github.com/mitchellh/mapstructure v1.5.0 h1:jeMsZIYE/09sWLaz43PL7Gy6RuMjD2eJVyuac5Z2hdY= +github.com/mitchellh/mapstructure v1.5.0/go.mod h1:bFUtVrKA4DC2yAKiSyO/QUcy7e+RRV2QTWOzhPopBRo= +github.com/mr-tron/base58 v1.2.0 h1:T/HDJBh4ZCPbU39/+c3rRvE0uKBQlU27+QI8LJ4t64o= +github.com/mr-tron/base58 v1.2.0/go.mod h1:BinMc/sQntlIE1frQmRFPUoPA1Zkr8VRgBdjWI2mNwc= +github.com/multiformats/go-base32 v0.1.0 h1:pVx9xoSPqEIQG8o+UbAe7DNi51oej1NtK+aGkbLYxPE= +github.com/multiformats/go-base32 v0.1.0/go.mod h1:Kj3tFY6zNr+ABYMqeUNeGvkIC/UYgtWibDcT0rExnbI= +github.com/multiformats/go-base36 v0.2.0 h1:lFsAbNOGeKtuKozrtBsAkSVhv1p9D0/qedU9rQyccr0= +github.com/multiformats/go-base36 v0.2.0/go.mod h1:qvnKE++v+2MWCfePClUEjE78Z7P2a1UV0xHgWc0hkp4= +github.com/multiformats/go-multiaddr v0.12.2 h1:9G9sTY/wCYajKa9lyfWPmpZAwe6oV+Wb1zcmMS1HG24= +github.com/multiformats/go-multiaddr v0.12.2/go.mod h1:GKyaTYjZRdcUhyOetrxTk9z0cW+jA/YrnqTOvKgi44M= +github.com/multiformats/go-multibase v0.2.0 h1:isdYCVLvksgWlMW9OZRYJEa9pZETFivncJHmHnnd87g= +github.com/multiformats/go-multibase v0.2.0/go.mod h1:bFBZX4lKCA/2lyOFSAoKH5SS6oPyjtnzK/XTFDPkNuk= +github.com/multiformats/go-multicodec v0.9.0 h1:pb/dlPnzee/Sxv/j4PmkDRxCOi3hXTz3IbPKOXWJkmg= +github.com/multiformats/go-multicodec v0.9.0/go.mod h1:L3QTQvMIaVBkXOXXtVmYE+LI16i14xuaojr/H7Ai54k= +github.com/multiformats/go-multihash v0.2.3 h1:7Lyc8XfX/IY2jWb/gI7JP+o7JEq9hOa7BFvVU9RSh+U= +github.com/multiformats/go-multihash v0.2.3/go.mod h1:dXgKXCXjBzdscBLk9JkjINiEsCKRVch90MdaGiKsvSM= +github.com/multiformats/go-multistream v0.5.0 h1:5htLSLl7lvJk3xx3qT/8Zm9J4K8vEOf/QGkvOGQAyiE= +github.com/multiformats/go-multistream v0.5.0/go.mod h1:n6tMZiwiP2wUsR8DgfDWw1dydlEqV3l6N3/GBsX6ILA= +github.com/multiformats/go-varint v0.0.7 h1:sWSGR+f/eu5ABZA2ZpYKBILXTTs9JWpdEM/nEGOHFS8= +github.com/multiformats/go-varint v0.0.7/go.mod h1:r8PUYw/fD/SjBCiKOoDlGF6QawOELpZAu9eioSos/OU= +github.com/mwitkow/go-conntrack v0.0.0-20161129095857-cc309e4a2223/go.mod h1:qRWi+5nqEBWmkhHvq77mSJWrCKwh8bxhgT7d/eI7P4U= +github.com/oklog/ulid v1.3.1/go.mod h1:CirwcVhetQ6Lv90oh/F+FBtV6XMibvdAFo93nm5qn4U= github.com/onflow/atree v0.8.0 h1:qg5c6J1gVDNObughpEeWm8oxqhPGdEyGrda121GM4u0= github.com/onflow/atree v0.8.0/go.mod h1:yccR+LR7xc1Jdic0mrjocbHvUD7lnVvg8/Ct1AA5zBo= github.com/onflow/cadence v1.2.2 h1:LwigF/2lPiXlwX5rFn71KeMpmW5Iu/f/JtsPLLULBCc= github.com/onflow/cadence v1.2.2/go.mod h1:PYX1xLejqswtDsQzN93x/VpfSKNyjUk6hrkc/mpv7xs= -github.com/onflow/crypto v0.25.1 h1:0txy2PKPMM873JbpxQNbJmuOJtD56bfs48RQfm0ts5A= -github.com/onflow/crypto v0.25.1/go.mod h1:C8FbaX0x8y+FxWjbkHy0Q4EASCDR9bSPWZqlpCLYyVI= -github.com/onflow/flow-cli/flowkit v1.11.0 h1:RSfKlla/l+ZJwqAmlvA5HPFbQ6ia2wzKSG0kJ8fqVa0= -github.com/onflow/flow-cli/flowkit v1.11.0/go.mod h1:aH4shan7Ggxd0GIXZD2S4kYMemNfzP1rLWvzKnb6K3g= +github.com/onflow/crypto v0.25.2 h1:GjHunqVt+vPcdqhxxhAXiMIF3YiLX7gTuTR5O+VG2ns= +github.com/onflow/crypto v0.25.2/go.mod h1:fY7eLqUdMKV8EGOw301unP8h7PvLVy8/6gVR++/g0BY= +github.com/onflow/flow-core-contracts/lib/go/templates v1.4.0 h1:u2DAG8pk0xFH7TwS70t1gSZ/FtIIZWMSNyiu4SeXBYg= +github.com/onflow/flow-core-contracts/lib/go/templates v1.4.0/go.mod h1:pN768Al/wLRlf3bwugv9TyxniqJxMu4sxnX9eQJam64= +github.com/onflow/flow-ft/lib/go/templates v1.0.1 h1:FDYKAiGowABtoMNusLuRCILIZDtVqJ/5tYI4VkF5zfM= +github.com/onflow/flow-ft/lib/go/templates v1.0.1/go.mod h1:uQ8XFqmMK2jxyBSVrmyuwdWjTEb+6zGjRYotfDJ5pAE= +github.com/onflow/flow-go v0.38.0-preview.0.0.20241022154145-6a254edbec23 h1:spF44tXZ341oVDTuXzzKTQ0W6rwZFV9r2/SRVVaMReo= +github.com/onflow/flow-go v0.38.0-preview.0.0.20241022154145-6a254edbec23/go.mod h1:6f7CTcguVOBINmraaWMiij5e2zu7W2mKsOmXAfvCZ2g= +github.com/onflow/flow-nft/lib/go/templates v1.2.1 h1:SAALMZPDw9Eb9p5kSLnmnFxjyig1MLiT4JUlLp0/bSE= +github.com/onflow/flow-nft/lib/go/templates v1.2.1/go.mod h1:W6hOWU0xltPqNpv9gQX8Pj8Jtf0OmRxc1XX2V0kzJaI= github.com/onflow/flow/protobuf/go/flow v0.4.7 h1:iP6DFx4wZ3ETORsyeqzHu7neFT3d1CXF6wdK+AOOjmc= github.com/onflow/flow/protobuf/go/flow v0.4.7/go.mod h1:NA2pX2nw8zuaxfKphhKsk00kWLwfd+tv8mS23YXO4Sk= -github.com/onflow/go-ethereum v1.13.4 h1:iNO86fm8RbBbhZ87ZulblInqCdHnAQVY8okBrNsTevc= -github.com/onflow/go-ethereum v1.13.4/go.mod h1:cE/gEUkAffhwbVmMJYz+t1dAfVNHNwZCgc3BWtZxBGY= +github.com/onflow/flowkit v1.19.0 h1:Ru18vfRo8E3COgYTK89maFN7ORyQ2HIo8Z/wKZG01RU= +github.com/onflow/flowkit v1.19.0/go.mod h1:laapt1diM4Pbqt0dotKMH+LbUAOEqgugpH1p4+sPhcw= +github.com/onflow/go-ethereum v1.14.7 h1:gg3awYqI02e3AypRdpJKEvNTJ6kz/OhAqRti0h54Wlc= +github.com/onflow/go-ethereum v1.14.7/go.mod h1:zV14QLrXyYu5ucvcwHUA0r6UaqveqbXaehAVQJlSW+I= github.com/onflow/sdks v0.6.0-preview.1 h1:mb/cUezuqWEP1gFZNAgUI4boBltudv4nlfxke1KBp9k= github.com/onflow/sdks v0.6.0-preview.1/go.mod h1:F0dj0EyHC55kknLkeD10js4mo14yTdMotnWMslPirrU= +github.com/pbnjay/memory v0.0.0-20210728143218-7b4eea64cf58 h1:onHthvaw9LFnH4t2DcNVpwGmV9E1BkGknEliJkfwQj0= +github.com/pbnjay/memory v0.0.0-20210728143218-7b4eea64cf58/go.mod h1:DXv8WO4yhMYhSNPKjeNKa5WY9YCIEBRbNzFFPJbWO6Y= +github.com/pelletier/go-toml v1.2.0/go.mod h1:5z9KED0ma1S8pY6P1sdut58dfprrGBbd/94hg7ilaic= +github.com/pelletier/go-toml/v2 v2.0.6 h1:nrzqCb7j9cDFj2coyLNLaZuJTLjWjlaz6nvTvIwycIU= +github.com/pelletier/go-toml/v2 v2.0.6/go.mod h1:eumQOmlWiOPt5WriQQqoM5y18pDHwha2N+QD+EUNTek= +github.com/pierrec/lz4 v2.6.1+incompatible h1:9UY3+iC23yxF0UfGaYrGplQ+79Rg+h/q9FV9ix19jjM= +github.com/pierrec/lz4 v2.6.1+incompatible/go.mod h1:pdkljMzZIN41W+lC3N2tnIh5sFi+IEE17M5jbnwPHcY= github.com/pkg/diff v0.0.0-20210226163009-20ebb0f2a09e/go.mod h1:pJLUxLENpZxwdsKMEsNbx1VGcRFpLqf3715MtcvvzbA= +github.com/pkg/errors v0.8.0/go.mod h1:bwawxfHBFNV+L2hUp1rHADufV3IMtnDRdf1r5NINEl0= github.com/pkg/errors v0.9.1 h1:FEBLx1zS214owpjy7qsBeixbURkuhQAwrK5UwLGTwt4= github.com/pkg/errors v0.9.1/go.mod h1:bwawxfHBFNV+L2hUp1rHADufV3IMtnDRdf1r5NINEl0= github.com/pmezard/go-difflib v1.0.0 h1:4DBwDE0NGyQoBHbLQYPwSUPoCMWR5BEzIk/f1lZbAQM= github.com/pmezard/go-difflib v1.0.0/go.mod h1:iKH77koFhYxTK1pcRnkKkqfTogsbg7gZNVY4sRDYZ/4= +github.com/prometheus/client_golang v0.9.1/go.mod h1:7SWBe2y4D6OKWSNQJUaRYU/AaXPKyh/dDVn+NZz0KFw= +github.com/prometheus/client_golang v0.9.3/go.mod h1:/TN21ttK/J9q6uSwhBd54HahCDft0ttaMvbicHlPoso= +github.com/prometheus/client_golang v1.18.0 h1:HzFfmkOzH5Q8L8G+kSJKUx5dtG87sewO+FoDDqP5Tbk= +github.com/prometheus/client_golang v1.18.0/go.mod h1:T+GXkCk5wSJyOqMIzVgvvjFDlkOQntgjkJWKrN5txjA= +github.com/prometheus/client_model v0.0.0-20180712105110-5c3871d89910/go.mod h1:MbSGuTsp3dbXC40dX6PRTWyKYBIrTGTE9sqQNg2J8bo= +github.com/prometheus/client_model v0.0.0-20190129233127-fd36f4220a90/go.mod h1:xMI15A0UPsDsEKsMN9yxemIoYk6Tm2C1GtYGdfGttqA= github.com/prometheus/client_model v0.0.0-20190812154241-14fe0d1b01d4/go.mod h1:xMI15A0UPsDsEKsMN9yxemIoYk6Tm2C1GtYGdfGttqA= +github.com/prometheus/client_model v0.5.0 h1:VQw1hfvPvk3Uv6Qf29VrPF32JB6rtbgI6cYPYQjL0Qw= +github.com/prometheus/client_model v0.5.0/go.mod h1:dTiFglRmd66nLR9Pv9f0mZi7B7fk5Pm3gvsjB5tr+kI= +github.com/prometheus/common v0.0.0-20181113130724-41aa239b4cce/go.mod h1:daVV7qP5qjZbuso7PdcryaAu0sAZbrN9i7WWcTMWvro= +github.com/prometheus/common v0.4.0/go.mod h1:TNfzLD0ON7rHzMJeJkieUDPYmFC7Snx/y86RQel1bk4= +github.com/prometheus/common v0.45.0 h1:2BGz0eBc2hdMDLnO/8n0jeB3oPrt2D08CekT0lneoxM= +github.com/prometheus/common v0.45.0/go.mod h1:YJmSTw9BoKxJplESWWxlbyttQR4uaEcGyv9MZjVOJsY= +github.com/prometheus/procfs v0.0.0-20181005140218-185b4288413d/go.mod h1:c3At6R/oaqEKCNdg8wHV1ftS6bRYblBhIjjI8uT2IGk= +github.com/prometheus/procfs v0.0.0-20190507164030-5867b95ac084/go.mod h1:TjEm7ze935MbeOT/UhFTIMYKhuLP4wbCsTZCD3I8kEA= +github.com/prometheus/procfs v0.12.0 h1:jluTpSng7V9hY0O2R9DzzJHYb2xULk9VTR1V1R/k6Bo= +github.com/prometheus/procfs v0.12.0/go.mod h1:pcuDEFsWDnvcgNzo4EEweacyhjeA9Zk3cnaOZAZEfOo= +github.com/prometheus/tsdb v0.7.1/go.mod h1:qhTCs0VvXwvX/y3TZrWD7rabWM+ijKTux40TwIPHuXU= +github.com/psiemens/sconfig v0.1.0 h1:xfWqW+TRpih7mXZIqKYTmpRhlZLQ1kbxV8EjllPv76s= +github.com/psiemens/sconfig v0.1.0/go.mod h1:+MLKqdledP/8G3rOBpknbLh0IclCf4WneJUtS26JB2U= github.com/rivo/uniseg v0.4.4 h1:8TfxU8dW6PdqD27gjM8MVNuicgxIjxpm4K7x4jp8sis= github.com/rivo/uniseg v0.4.4/go.mod h1:FN3SvrM+Zdj16jyLfmOkMNblXMcoc8DfTHruCPUcx88= +github.com/rogpeppe/fastuuid v0.0.0-20150106093220-6724a57986af/go.mod h1:XWv6SoW27p1b0cqNHllgS5HIMJraePCO15w5zCzIWYg= github.com/rogpeppe/go-internal v1.9.0/go.mod h1:WtVeX8xhTBvf0smdhujwtBcq4Qrzq/fJaraNFVN+nFs= github.com/rogpeppe/go-internal v1.10.0 h1:TMyTOH3F/DB16zRVcYyreMH6GnZZrwQVAoYjRBZyWFQ= github.com/rogpeppe/go-internal v1.10.0/go.mod h1:UQnix2H7Ngw/k4C5ijL5+65zddjncjaFoBhdsK/akog= -github.com/sirupsen/logrus v1.9.0 h1:trlNQbNUG3OdDrDil03MCb1H2o9nJ1x4/5LYw7byDE0= -github.com/sirupsen/logrus v1.9.0/go.mod h1:naHLuLoDiP4jHNo9R0sCBMtWGeIprob74mVsIT4qYEQ= +github.com/rs/zerolog v1.29.0 h1:Zes4hju04hjbvkVkOhdl2HpZa+0PmVwigmo8XoORE5w= +github.com/rs/zerolog v1.29.0/go.mod h1:NILgTygv/Uej1ra5XxGf82ZFSLk58MFGAUS2o6usyD0= +github.com/russross/blackfriday v1.5.2/go.mod h1:JO/DiYxRf+HjHt06OyowR9PTA263kcR/rfWxYHBV53g= +github.com/russross/blackfriday/v2 v2.1.0/go.mod h1:+Rmxgy9KzJVeS9/2gXHxylqXiyQDYRxCVz55jmeOWTM= +github.com/sirupsen/logrus v1.2.0/go.mod h1:LxeOpSwHxABJmUn/MG1IvRgCAasNZTLOkJPxbbu5VWo= +github.com/sirupsen/logrus v1.9.3 h1:dueUQJ1C2q9oE3F7wvmSGAaVtTmUizReu6fjN8uqzbQ= +github.com/sirupsen/logrus v1.9.3/go.mod h1:naHLuLoDiP4jHNo9R0sCBMtWGeIprob74mVsIT4qYEQ= +github.com/slok/go-http-metrics v0.10.0 h1:rh0LaYEKza5eaYRGDXujKrOln57nHBi4TtVhmNEpbgM= +github.com/slok/go-http-metrics v0.10.0/go.mod h1:lFqdaS4kWMfUKCSukjC47PdCeTk+hXDUVm8kLHRqJ38= +github.com/soheilhy/cmux v0.1.4/go.mod h1:IM3LyeVVIOuxMH7sFAkER9+bJ4dT7Ms6E4xg4kGIyLM= +github.com/spaolacci/murmur3 v0.0.0-20180118202830-f09979ecbc72/go.mod h1:JwIasOWyU6f++ZhiEuf87xNszmSA2myDM2Kzu9HwQUA= +github.com/spaolacci/murmur3 v1.1.0 h1:7c1g84S4BPRrfL5Xrdp6fOJ206sU9y293DDHaoy0bLI= +github.com/spaolacci/murmur3 v1.1.0/go.mod h1:JwIasOWyU6f++ZhiEuf87xNszmSA2myDM2Kzu9HwQUA= +github.com/spf13/afero v1.1.2/go.mod h1:j4pytiNVoe2o6bmDsKpLACNPDBIoEAkihy7loJ1B0CQ= github.com/spf13/afero v1.11.0 h1:WJQKhtpdm3v2IzqG8VMqrr6Rf3UYpEF239Jy9wNepM8= github.com/spf13/afero v1.11.0/go.mod h1:GH9Y3pIexgf1MTIWtNGyogA5MwRIDXGUr+hbWNoBjkY= +github.com/spf13/cast v1.3.0/go.mod h1:Qx5cxh0v+4UWYiBimWS+eyWzqEqokIECu5etghLkUJE= +github.com/spf13/cast v1.5.0 h1:rj3WzYc11XZaIZMPKmwP96zkFEnnAmV8s6XbB2aY32w= +github.com/spf13/cast v1.5.0/go.mod h1:SpXXQ5YoyJw6s3/6cMTQuxvgRl3PCJiyaX9p6b155UU= +github.com/spf13/cobra v0.0.5/go.mod h1:3K3wKZymM7VvHMDS9+Akkh4K60UwM26emMESw8tLCHU= +github.com/spf13/cobra v1.8.0 h1:7aJaZx1B85qltLMc546zn58BxxfZdR/W22ej9CFoEf0= +github.com/spf13/cobra v1.8.0/go.mod h1:WXLWApfZ71AjXPya3WOlMsY9yMs7YeiHhFVlvLyhcho= +github.com/spf13/jwalterweatherman v1.0.0/go.mod h1:cQK4TGJAtQXfYWX+Ddv3mKDzgVb68N+wFjFa4jdeBTo= +github.com/spf13/jwalterweatherman v1.1.0 h1:ue6voC5bR5F8YxI5S67j9i582FU4Qvo2bmqnqMYADFk= +github.com/spf13/jwalterweatherman v1.1.0/go.mod h1:aNWZUN0dPAAO/Ljvb5BEdw96iTZ0EXowPYD95IqWIGo= +github.com/spf13/pflag v1.0.3/go.mod h1:DYY7MBk1bdzusC3SYhjObp+wFpr4gzcvqqNjLnInEg4= +github.com/spf13/pflag v1.0.5 h1:iy+VFUOCP1a+8yFto/drg2CJ5u0yRoB7fZw3DKv/JXA= +github.com/spf13/pflag v1.0.5/go.mod h1:McXfInJRrz4CZXVZOBLb0bTZqETkiAhM9Iw0y3An2Bg= +github.com/spf13/viper v1.3.2/go.mod h1:ZiWeW+zYFKm7srdB9IoDzzZXaJaI5eL9QjNiN/DMA2s= +github.com/spf13/viper v1.4.0/go.mod h1:PTJ7Z/lr49W6bUbkmS1V3by4uWynFiR9p7+dSq/yZzE= +github.com/spf13/viper v1.15.0 h1:js3yy885G8xwJa6iOISGFwd+qlUo5AvyXb7CiihdtiU= +github.com/spf13/viper v1.15.0/go.mod h1:fFcTBJxvhhzSJiZy8n+PeW6t8l+KeT/uTARa0jHOQLA= github.com/stretchr/objx v0.1.0/go.mod h1:HFkY916IF+rwdDfMAkV7OtwuqBVzrE8GR6GFx+wExME= +github.com/stretchr/objx v0.1.1/go.mod h1:HFkY916IF+rwdDfMAkV7OtwuqBVzrE8GR6GFx+wExME= github.com/stretchr/objx v0.4.0/go.mod h1:YvHI0jy2hoMjB+UWwv71VJQ9isScKT/TqJzVSSt89Yw= github.com/stretchr/objx v0.5.0/go.mod h1:Yh+to48EsGEfYuaHDzXPcE3xhTkx73EhmCGUpEOglKo= github.com/stretchr/objx v0.5.2 h1:xuMeJ0Sdp5ZMRXx/aWO6RZxdr3beISkG5/G/aIRr3pY= github.com/stretchr/objx v0.5.2/go.mod h1:FRsXN1f5AsAjCGJKqEizvkpNtU+EGNCLh3NxZ/8L+MA= +github.com/stretchr/testify v1.2.2/go.mod h1:a8OnRcib4nhh0OaRAV+Yts87kKdq0PP7pXfy6kDkUVs= github.com/stretchr/testify v1.3.1-0.20190311161405-34c6fa2dc709/go.mod h1:M5WIy9Dh21IEIfnGCwXGc5bZfKNJtfHm1UVUgZn+9EI= +github.com/stretchr/testify v1.7.0/go.mod h1:6Fq8oRcR53rry900zMqJjRRixrwX3KX962/h/Wwjteg= github.com/stretchr/testify v1.7.1/go.mod h1:6Fq8oRcR53rry900zMqJjRRixrwX3KX962/h/Wwjteg= github.com/stretchr/testify v1.8.0/go.mod h1:yNjHg4UonilssWZ8iaSj1OCr/vHnekPRkoO+kdMU+MU= github.com/stretchr/testify v1.8.1/go.mod h1:w2LPCIKwWwSfY2zedu0+kehJoqGctiVI29o6fzry7u4= github.com/stretchr/testify v1.9.0 h1:HtqpIVDClZ4nwg75+f6Lvsy/wHu+3BoSGCbBAcpTsTg= github.com/stretchr/testify v1.9.0/go.mod h1:r2ic/lqez/lEtzL7wO/rwa5dbSLXVDPFyf8C91i36aY= +github.com/subosito/gotenv v1.4.2 h1:X1TuBLAMDFbaTAChgCBLu3DU3UPyELpnF2jjJ2cz/S8= +github.com/subosito/gotenv v1.4.2/go.mod h1:ayKnFf/c6rvx/2iiLrJUk1e6plDbT3edrFNGqEflhK0= github.com/texttheater/golang-levenshtein/levenshtein v0.0.0-20200805054039-cae8b0eaed6c h1:HelZ2kAFadG0La9d+4htN4HzQ68Bm2iM9qKMSMES6xg= github.com/texttheater/golang-levenshtein/levenshtein v0.0.0-20200805054039-cae8b0eaed6c/go.mod h1:JlzghshsemAMDGZLytTFY8C1JQxQPhnatWqNwUXjggo= +github.com/tmc/grpc-websocket-proxy v0.0.0-20190109142713-0ad062ec5ee5/go.mod h1:ncp9v5uamzpCO7NfCPTXjqaC+bZgJeR0sMTm6dMHP7U= github.com/turbolent/prettier v0.0.0-20220320183459-661cc755135d h1:5JInRQbk5UBX8JfUvKh2oYTLMVwj3p6n+wapDDm7hko= github.com/turbolent/prettier v0.0.0-20220320183459-661cc755135d/go.mod h1:Nlx5Y115XQvNcIdIy7dZXaNSUpzwBSge4/Ivk93/Yog= +github.com/ugorji/go v1.1.4/go.mod h1:uQMGLiO92mf5W77hV/PUCpI3pbzQx3CRekS0kk+RGrc= +github.com/ugorji/go/codec v0.0.0-20181204163529-d75b2dcb6bc8/go.mod h1:VFNgLljTbGfSG7qAOspJ7OScBnGdDN/yBr0sguwnwf0= +github.com/vmihailenco/msgpack v4.0.4+incompatible h1:dSLoQfGFAo3F6OoNhwUmLwVgaUXK79GlxNBwueZn0xI= +github.com/vmihailenco/msgpack v4.0.4+incompatible/go.mod h1:fy3FlTQTDXWkZ7Bh6AcGMlsjHatGryHQYUTf1ShIgkk= +github.com/vmihailenco/msgpack/v4 v4.3.11 h1:Q47CePddpNGNhk4GCnAx9DDtASi2rasatE0cd26cZoE= +github.com/vmihailenco/msgpack/v4 v4.3.11/go.mod h1:gborTTJjAo/GWTqqRjrLCn9pgNN+NXzzngzBKDPIqw4= +github.com/vmihailenco/tagparser v0.1.1 h1:quXMXlA39OCbd2wAdTsGDlK9RkOk6Wuw+x37wVyIuWY= +github.com/vmihailenco/tagparser v0.1.1/go.mod h1:OeAg3pn3UbLjkWt+rN9oFYB6u/cQgqMEUPoW2WPyhdI= github.com/x448/float16 v0.8.4 h1:qLwI1I70+NjRFUR3zs1JPUCgaCXSh3SW62uAKT1mSBM= github.com/x448/float16 v0.8.4/go.mod h1:14CWIYCyZA/cWjXOioeEpHeN/83MdbZDRQHoFcYsOfg= +github.com/xiang90/probing v0.0.0-20190116061207-43a291ad63a2/go.mod h1:UETIi67q53MR2AWcXfiuqkDkRtnGDLqkBTpCHuJHxtU= +github.com/xordataexchange/crypt v0.0.3-0.20170626215501-b2862e3d0a77/go.mod h1:aYKd//L2LvnjZzWKhF00oedf4jCCReLcmhLdhm1A27Q= github.com/yuin/goldmark v1.4.13/go.mod h1:6yULJ656Px+3vBD8DxQVa3kxgyrAnzto9xy5taEt/CY= github.com/zeebo/assert v1.1.0/go.mod h1:Pq9JiuJQpG8JLJdtkwrJESF0Foym2/D9XMU5ciN/wJ0= github.com/zeebo/assert v1.3.0 h1:g7C04CbJuIDKNPFHmsk4hwZDO5O+kntRxzaUoNXj+IQ= @@ -158,6 +415,7 @@ github.com/zeebo/blake3 v0.2.3 h1:TFoLXsjeXqRNFxSbk35Dk4YtszE/MQQGK10BH4ptoTg= github.com/zeebo/blake3 v0.2.3/go.mod h1:mjJjZpnsyIVtVgTOSpJ9vmRE4wgDeyt2HU3qXvvKCaQ= github.com/zeebo/pcg v1.0.1 h1:lyqfGeWiv4ahac6ttHs+I5hwtH/+1mrhlCtVNQM2kHo= github.com/zeebo/pcg v1.0.1/go.mod h1:09F0S9iiKrwn9rlI5yjLkmrug154/YRW6KnnXVDM/l4= +go.etcd.io/bbolt v1.3.2/go.mod h1:IbVyRI1SCnLcuJnV2u8VeU0CEYM7e686BmAb1XKL+uU= go.opencensus.io v0.24.0 h1:y73uSU6J157QMP2kn2r30vwW1A2W2WFwSCGnAVxeaD0= go.opencensus.io v0.24.0/go.mod h1:vNK8G9p7aAivkbmorf4v+7Hgx+Zs0yY+0fOtgBfjQKo= go.opentelemetry.io/contrib/instrumentation/google.golang.org/grpc/otelgrpc v0.47.0 h1:UNQQKPfTDe1J81ViolILjTKPr9WetKW6uei2hFgJmFs= @@ -166,14 +424,31 @@ go.opentelemetry.io/contrib/instrumentation/net/http/otelhttp v0.47.0 h1:sv9kVfa go.opentelemetry.io/contrib/instrumentation/net/http/otelhttp v0.47.0/go.mod h1:SK2UL73Zy1quvRPonmOmRDiWk1KBV3LyIeeIxcEApWw= go.opentelemetry.io/otel v1.24.0 h1:0LAOdjNmQeSTzGBzduGe/rU4tZhMwL5rWgtp9Ku5Jfo= go.opentelemetry.io/otel v1.24.0/go.mod h1:W7b9Ozg4nkF5tWI5zsXkaKKDjdVjpD4oAt9Qi/MArHo= +go.opentelemetry.io/otel/exporters/otlp/otlptrace v1.21.0 h1:cl5P5/GIfFh4t6xyruOgJP5QiA1pw4fYYdv6nc6CBWw= +go.opentelemetry.io/otel/exporters/otlp/otlptrace v1.21.0/go.mod h1:zgBdWWAu7oEEMC06MMKc5NLbA/1YDXV1sMpSqEeLQLg= +go.opentelemetry.io/otel/exporters/otlp/otlptrace/otlptracegrpc v1.21.0 h1:tIqheXEFWAZ7O8A7m+J0aPTmpJN3YQ7qetUAdkkkKpk= +go.opentelemetry.io/otel/exporters/otlp/otlptrace/otlptracegrpc v1.21.0/go.mod h1:nUeKExfxAQVbiVFn32YXpXZZHZ61Cc3s3Rn1pDBGAb0= go.opentelemetry.io/otel/metric v1.24.0 h1:6EhoGWWK28x1fbpA4tYTOWBkPefTDQnb8WSGXlc88kI= go.opentelemetry.io/otel/metric v1.24.0/go.mod h1:VYhLe1rFfxuTXLgj4CBiyz+9WYBA8pNGJgDcSFRKBco= go.opentelemetry.io/otel/sdk v1.24.0 h1:YMPPDNymmQN3ZgczicBY3B6sf9n62Dlj9pWD3ucgoDw= go.opentelemetry.io/otel/sdk v1.24.0/go.mod h1:KVrIYw6tEubO9E96HQpcmpTKDVn9gdv35HoYiQWGDFg= go.opentelemetry.io/otel/trace v1.24.0 h1:CsKnnL4dUAr/0llH9FKuc698G04IrpWV0MQA/Y1YELI= go.opentelemetry.io/otel/trace v1.24.0/go.mod h1:HPc3Xr/cOApsBI154IU0OI0HJexz+aw5uPdbs3UCjNU= -go.uber.org/goleak v1.1.10 h1:z+mqJhf6ss6BSfSM671tgKyZBFPTTJM+HLxnhPC3wu0= -go.uber.org/goleak v1.1.10/go.mod h1:8a7PlsEVH3e/a/GLqe5IIrQx6GzcnRmZEufDUTk4A7A= +go.opentelemetry.io/proto/otlp v1.0.0 h1:T0TX0tmXU8a3CbNXzEKGeU5mIVOdf0oykP+u2lIVU/I= +go.opentelemetry.io/proto/otlp v1.0.0/go.mod h1:Sy6pihPLfYHkr3NkUbEhGHFhINUSI/v80hjKIs5JXpM= +go.uber.org/atomic v1.4.0/go.mod h1:gD2HeocX3+yG+ygLZcrzQJaqmWj9AIm7n08wl/qW/PE= +go.uber.org/atomic v1.11.0 h1:ZvwS0R+56ePWxUNi+Atn9dWONBPp/AUETXlHW0DxSjE= +go.uber.org/atomic v1.11.0/go.mod h1:LUxbIzbOniOlMKjJjyPfpl4v+PKK2cNJn91OQbhoJI0= +go.uber.org/goleak v1.3.0 h1:2K3zAYmnTNqV73imy9J1T3WC+gmCePx2hEGkimedGto= +go.uber.org/goleak v1.3.0/go.mod h1:CoHD4mav9JJNrW/WLlf7HGZPjdw8EucARQHekz1X6bE= +go.uber.org/multierr v1.1.0/go.mod h1:wR5kodmAFQ0UK8QlbwjlSNy0Z68gJhDJUG5sjR94q/0= +go.uber.org/multierr v1.11.0 h1:blXXJkSxSSfBVBlC76pxqeO+LN3aDfLQo+309xJstO0= +go.uber.org/multierr v1.11.0/go.mod h1:20+QtiLqy0Nd6FdQB9TLXag12DsQkrbs3htMFfDN80Y= +go.uber.org/zap v1.10.0/go.mod h1:vwi/ZaCAaUcBkycHslxD9B2zi4UTXhF60s6SWpuDF0Q= +go.uber.org/zap v1.26.0 h1:sI7k6L95XOKS281NhVKOFCUNIvv9e0w4BF8N3u+tCRo= +go.uber.org/zap v1.26.0/go.mod h1:dtElttAiwGvoJ/vj4IwHBS/gXsEu/pZ50mUIRWuG0so= +golang.org/x/crypto v0.0.0-20180904163835-0709b304e793/go.mod h1:6SG95UA2DQfeDnfUPMdvaQW0Q7yPrPDi9nlGo2tz2b4= +golang.org/x/crypto v0.0.0-20181203042331-505ab145d0a9/go.mod h1:6SG95UA2DQfeDnfUPMdvaQW0Q7yPrPDi9nlGo2tz2b4= golang.org/x/crypto v0.0.0-20190308221718-c2843e01d9a2/go.mod h1:djNgcEr1/C05ACkg1iLfiJU5Ep61QUkGW8qpdssI0+w= golang.org/x/crypto v0.0.0-20200622213623-75b288015ac9/go.mod h1:LzIPMQfyMNhhGPhUkYOs5KpL4U8rLKemX1yGLhDgUto= golang.org/x/crypto v0.0.0-20210921155107-089bfa567519/go.mod h1:GvvjBRRGRdwPK5ydBHafDWAxML/pGHZbMvKqRZ5+Abc= @@ -185,40 +460,50 @@ golang.org/x/exp v0.0.0-20240119083558-1b970713d09a/go.mod h1:idGWGoKP1toJGkd5/i golang.org/x/lint v0.0.0-20181026193005-c67002cb31c3/go.mod h1:UVdnD1Gm6xHRNCYTkRU2/jEulfH38KcIWyp/GAMgvoE= golang.org/x/lint v0.0.0-20190227174305-5b3e6a55c961/go.mod h1:wehouNa3lNwaWXcvxsM5YxQ5yQlVC4a0KAMCusXpPoU= golang.org/x/lint v0.0.0-20190313153728-d0100b6bd8b3/go.mod h1:6SW0HCj/g11FgYtHlgUYUwCkIfeOF89ocIRzGO/8vkc= -golang.org/x/lint v0.0.0-20210508222113-6edffad5e616 h1:VLliZ0d+/avPrXXH+OakdXhpJuEoBZuwh1m2j7U6Iug= -golang.org/x/lint v0.0.0-20210508222113-6edffad5e616/go.mod h1:3xt1FjdF8hUf6vQPIChWIBhFzV8gjjsPE/fR3IyQdNY= golang.org/x/mod v0.6.0-dev.0.20220419223038-86c51ed26bb4/go.mod h1:jJ57K6gSWd91VN4djpZkiMVwK6gcyfeH4XE8wZrZaV4= golang.org/x/mod v0.17.0 h1:zY54UmvipHiNd+pm+m0x9KhZ9hl1/7QNMyxXbc6ICqA= golang.org/x/mod v0.17.0/go.mod h1:hTbmBsO62+eylJbnUtE2MGJUyE7QWk4xUqPFrRgJ+7c= golang.org/x/net v0.0.0-20180724234803-3673e40ba225/go.mod h1:mL1N/T3taQHkDXs73rZJwtUhF3w3ftmwwsq0BUmARs4= golang.org/x/net v0.0.0-20180826012351-8a410e7b638d/go.mod h1:mL1N/T3taQHkDXs73rZJwtUhF3w3ftmwwsq0BUmARs4= +golang.org/x/net v0.0.0-20181114220301-adae6a3d119a/go.mod h1:mL1N/T3taQHkDXs73rZJwtUhF3w3ftmwwsq0BUmARs4= +golang.org/x/net v0.0.0-20181220203305-927f97764cc3/go.mod h1:mL1N/T3taQHkDXs73rZJwtUhF3w3ftmwwsq0BUmARs4= golang.org/x/net v0.0.0-20190213061140-3a22650c66bd/go.mod h1:mL1N/T3taQHkDXs73rZJwtUhF3w3ftmwwsq0BUmARs4= golang.org/x/net v0.0.0-20190311183353-d8887717615a/go.mod h1:t9HGtf8HONx5eT2rtn7q6eTqICYqUVnKs3thJo3Qplg= golang.org/x/net v0.0.0-20190404232315-eb5bcb51f2a3/go.mod h1:t9HGtf8HONx5eT2rtn7q6eTqICYqUVnKs3thJo3Qplg= +golang.org/x/net v0.0.0-20190522155817-f3200d17e092/go.mod h1:HSz+uSET+XFnRR8LxR5pz3Of3rY3CfYBVs4xY44aLks= +golang.org/x/net v0.0.0-20190603091049-60506f45cf65/go.mod h1:HSz+uSET+XFnRR8LxR5pz3Of3rY3CfYBVs4xY44aLks= golang.org/x/net v0.0.0-20190620200207-3b0461eec859/go.mod h1:z5CRVTTTmAJ677TzLLGU+0bjPO0LkuOLi4/5GtJWs/s= +golang.org/x/net v0.0.0-20200301022130-244492dfa37a/go.mod h1:z5CRVTTTmAJ677TzLLGU+0bjPO0LkuOLi4/5GtJWs/s= golang.org/x/net v0.0.0-20201110031124-69a78807bb2b/go.mod h1:sp8m0HH+o8qH0wwXwYZr8TS3Oi6o0r6Gce1SSxlDquU= golang.org/x/net v0.0.0-20210226172049-e18ecbb05110/go.mod h1:m0MpNAwzfU5UDzcl9v0D8zg8gWTRqZa9RBIspLL5mdg= golang.org/x/net v0.0.0-20220722155237-a158d28d115b/go.mod h1:XRhObCWvk6IyKnWLug+ECip1KBveYUHfp+8e9klMJ9c= -golang.org/x/net v0.21.0 h1:AQyQV4dYCvJ7vGmJyKki9+PBdyvhkSd8EIx/qb0AYv4= -golang.org/x/net v0.21.0/go.mod h1:bIjVDfnllIU7BJ2DNgfnXvpSvtn8VRwhlsaeUTyUS44= +golang.org/x/net v0.25.0 h1:d/OCCoBEUq33pjydKrGQhw7IlUPI2Oylr+8qLx49kac= +golang.org/x/net v0.25.0/go.mod h1:JkAGAh7GEvH74S6FOH42FLoXpXbE/aqXSrIQjXgsiwM= golang.org/x/oauth2 v0.0.0-20180821212333-d2e6202438be/go.mod h1:N/0e6XlmueqKjAGxoOufVs8QHGRruUQn6yWY3a++T0U= golang.org/x/oauth2 v0.17.0 h1:6m3ZPmLEFdVxKKWnKq4VqZ60gutO35zm+zrAHVmHyDQ= golang.org/x/oauth2 v0.17.0/go.mod h1:OzPDGQiuQMguemayvdylqddI7qcD9lnSDb+1FiwQ5HA= golang.org/x/sync v0.0.0-20180314180146-1d60e4601c6f/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= golang.org/x/sync v0.0.0-20181108010431-42b317875d0f/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= +golang.org/x/sync v0.0.0-20181221193216-37e7f081c4d4/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= golang.org/x/sync v0.0.0-20190423024810-112230192c58/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= golang.org/x/sync v0.0.0-20220722155255-886fb9371eb4/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= golang.org/x/sync v0.8.0 h1:3NFvSEYkUoMifnESzZl15y791HH1qU2xm6eCJU5ZPXQ= golang.org/x/sync v0.8.0/go.mod h1:Czt+wKu1gCyEFDUtn0jG5QVvpJ6rzVqr5aXyt9drQfk= golang.org/x/sys v0.0.0-20180830151530-49385e6e1522/go.mod h1:STP8DvDyc/dI5b8T5hshtkjS+E42TnysNCUPdjciGhY= +golang.org/x/sys v0.0.0-20180905080454-ebe1bf3edb33/go.mod h1:STP8DvDyc/dI5b8T5hshtkjS+E42TnysNCUPdjciGhY= +golang.org/x/sys v0.0.0-20181107165924-66b7b1311ac8/go.mod h1:STP8DvDyc/dI5b8T5hshtkjS+E42TnysNCUPdjciGhY= +golang.org/x/sys v0.0.0-20181116152217-5ac8a444bdc5/go.mod h1:STP8DvDyc/dI5b8T5hshtkjS+E42TnysNCUPdjciGhY= +golang.org/x/sys v0.0.0-20181205085412-a5c9d58dba9a/go.mod h1:STP8DvDyc/dI5b8T5hshtkjS+E42TnysNCUPdjciGhY= golang.org/x/sys v0.0.0-20190215142949-d0b11bdaac8a/go.mod h1:STP8DvDyc/dI5b8T5hshtkjS+E42TnysNCUPdjciGhY= golang.org/x/sys v0.0.0-20190412213103-97732733099d/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= golang.org/x/sys v0.0.0-20200930185726-fdedc70b468f/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= golang.org/x/sys v0.0.0-20201119102817-f84b799fce68/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= golang.org/x/sys v0.0.0-20210615035016-665e8c7367d1/go.mod h1:oPkhp1MJrh7nUepCBck5+mAzfO9JrbApNNgaTdGDITg= golang.org/x/sys v0.0.0-20220520151302-bc2c85ada10a/go.mod h1:oPkhp1MJrh7nUepCBck5+mAzfO9JrbApNNgaTdGDITg= +golang.org/x/sys v0.0.0-20220715151400-c0bba94af5f8/go.mod h1:oPkhp1MJrh7nUepCBck5+mAzfO9JrbApNNgaTdGDITg= golang.org/x/sys v0.0.0-20220722155257-8c9f86f7a55f/go.mod h1:oPkhp1MJrh7nUepCBck5+mAzfO9JrbApNNgaTdGDITg= golang.org/x/sys v0.0.0-20220811171246-fbc7d0a398ab/go.mod h1:oPkhp1MJrh7nUepCBck5+mAzfO9JrbApNNgaTdGDITg= +golang.org/x/sys v0.0.0-20220908164124-27713097b956/go.mod h1:oPkhp1MJrh7nUepCBck5+mAzfO9JrbApNNgaTdGDITg= golang.org/x/sys v0.5.0/go.mod h1:oPkhp1MJrh7nUepCBck5+mAzfO9JrbApNNgaTdGDITg= golang.org/x/sys v0.6.0/go.mod h1:oPkhp1MJrh7nUepCBck5+mAzfO9JrbApNNgaTdGDITg= golang.org/x/sys v0.26.0 h1:KHjCJyddX0LoSTb3J+vWpupP9p0oznkqVk/IfjymZbo= @@ -226,13 +511,16 @@ golang.org/x/sys v0.26.0/go.mod h1:/VUhepiaJMQUp4+oa/7Zr1D23ma6VTLIYjOOTFZPUcA= golang.org/x/term v0.0.0-20201126162022-7de9c90e9dd1/go.mod h1:bj7SfCRtBDWHUb9snDiAeCFNEtKQo2Wmx5Cou7ajbmo= golang.org/x/term v0.0.0-20210927222741-03fcf44c2211/go.mod h1:jbD1KX2456YbFQfuXm/mYQcufACuNUgVhRMnK/tPxf8= golang.org/x/text v0.3.0/go.mod h1:NqM8EUOU14njkJ3fqMW+pc6Ldnwhi/IjpwHt7yyuwOQ= +golang.org/x/text v0.3.2/go.mod h1:bEr9sfX3Q8Zfm5fL9x+3itogRgK3+ptLWKqgva+5dAk= golang.org/x/text v0.3.3/go.mod h1:5Zoc/QRtKVWzQhOtBMvqHzDpF6irO9z98xDceosuGiQ= golang.org/x/text v0.3.7/go.mod h1:u+2+/6zg+i71rQMx5EYifcz6MCKuco9NR6JIITiCfzQ= golang.org/x/text v0.3.8/go.mod h1:E6s5w1FMmriuDzIBO73fBruAKo1PCIq6d2Q6DHfQ8WQ= golang.org/x/text v0.19.0 h1:kTxAhCbGbxhK0IwgSKiMO5awPoDQ0RpfiVYBfK860YM= golang.org/x/text v0.19.0/go.mod h1:BuEKDfySbSR4drPmRPG/7iBdf8hvFMuRexcpahXilzY= +golang.org/x/time v0.0.0-20190308202827-9d24e82272b4/go.mod h1:tRJNPiyCQ0inRvYxbN9jk5I+vvW/OXSQhTDSoE431IQ= golang.org/x/time v0.5.0 h1:o7cqy6amK/52YcAKIPlM3a+Fpj35zvRj2TP+e1xFSfk= golang.org/x/time v0.5.0/go.mod h1:3BpzKBy/shNhVucY/MWOyx10tF3SFh9QdLuxbVysPQM= +golang.org/x/tools v0.0.0-20180221164845-07fd8470d635/go.mod h1:n7NCudcB/nEzxVGmLbDWY5pfWTLqBcC2KZ6jyYvM4mQ= golang.org/x/tools v0.0.0-20180917221912-90fa682c2a6e/go.mod h1:n7NCudcB/nEzxVGmLbDWY5pfWTLqBcC2KZ6jyYvM4mQ= golang.org/x/tools v0.0.0-20190114222345-bf090417da8b/go.mod h1:n7NCudcB/nEzxVGmLbDWY5pfWTLqBcC2KZ6jyYvM4mQ= golang.org/x/tools v0.0.0-20190226205152-f727befe758c/go.mod h1:9Yl7xja0Znq3iFh3HoIrodX9oNMXvdceNzlUR8zjMvY= @@ -252,6 +540,7 @@ google.golang.org/api v0.162.0 h1:Vhs54HkaEpkMBdgGdOT2P6F0csGG/vxDS0hWHJzmmps= google.golang.org/api v0.162.0/go.mod h1:6SulDkfoBIg4NFmCuZ39XeeAgSHCPecfSUuDyYlAHs0= google.golang.org/appengine v1.1.0/go.mod h1:EbEs0AVv82hx2wNQdGPgUI5lhzA/G0D9YwlJXL52JkM= google.golang.org/appengine v1.4.0/go.mod h1:xpcJRLb0r/rnEns0DIKYYv+WjYCduHsrkT7/EB5XEv4= +google.golang.org/appengine v1.6.5/go.mod h1:8WjMMxjGQR8xUklV/ARdw2HLXBOI7O7uCIDZVag1xfc= google.golang.org/appengine v1.6.8 h1:IhEN5q69dyKagZPYMSdIjS2HqprW324FRQZJcGqPAsM= google.golang.org/appengine v1.6.8/go.mod h1:1jJ3jBArFh5pcgW8gCtRJnepW8FzD1V44FJffLiz/Ds= google.golang.org/genproto v0.0.0-20180817151627-c66870c02cf8/go.mod h1:JiN7NxoALGmiZfu7CAH4rXhgtRTLTxftemlI0sWmxmc= @@ -264,6 +553,7 @@ google.golang.org/genproto/googleapis/api v0.0.0-20240227224415-6ceb2ff114de/go. google.golang.org/genproto/googleapis/rpc v0.0.0-20240227224415-6ceb2ff114de h1:cZGRis4/ot9uVm639a+rHCUaG0JJHEsdyzSQTMX+suY= google.golang.org/genproto/googleapis/rpc v0.0.0-20240227224415-6ceb2ff114de/go.mod h1:H4O17MA/PE9BsGx3w+a+W2VOLLD1Qf7oJneAoU6WktY= google.golang.org/grpc v1.19.0/go.mod h1:mqu4LbDTu4XGKhr4mRzUsmM4RtVoemTSY81AxZiDr8c= +google.golang.org/grpc v1.21.0/go.mod h1:oYelfM1adQP15Ek0mdvEgi9Df8B9CZIaU1084ijfRaM= google.golang.org/grpc v1.23.0/go.mod h1:Y5yQAOtifL1yxbo5wqy6BxZv8vAUGQwXBOALyacEbxg= google.golang.org/grpc v1.25.1/go.mod h1:c3i+UQWmh7LiEpx4sFZnkU36qjEYZ0imhYfXVyQciAY= google.golang.org/grpc v1.27.0/go.mod h1:qbnxyOmOxrQa7FizSgH+ReBfzJrCY1pSN7KXBS8abTk= @@ -283,12 +573,24 @@ google.golang.org/protobuf v1.26.0-rc.1/go.mod h1:jlhhOSvTdKEhbULTjvd4ARK9grFBp0 google.golang.org/protobuf v1.26.0/go.mod h1:9q0QmTI4eRPtz6boOQmLYwt+qCgq0jsYwAQnmE0givc= google.golang.org/protobuf v1.33.0 h1:uNO2rsAINq/JlFpSdYEKIZ0uKD/R9cpdv0T+yoGwGmI= google.golang.org/protobuf v1.33.0/go.mod h1:c6P6GXX6sHbq/GpV6MGZEdwhWPcYBgnhAHhKbcUYpos= +gopkg.in/alecthomas/kingpin.v2 v2.2.6/go.mod h1:FMv+mEhP44yOT+4EoQTLFTRgOQ1FBLkstjWtayDeSgw= gopkg.in/check.v1 v0.0.0-20161208181325-20d25e280405/go.mod h1:Co6ibVJAznAaIkqp8huTwlJQCZ016jof/cbN4VW5Yz0= +gopkg.in/check.v1 v1.0.0-20180628173108-788fd7840127/go.mod h1:Co6ibVJAznAaIkqp8huTwlJQCZ016jof/cbN4VW5Yz0= gopkg.in/check.v1 v1.0.0-20201130134442-10cb98267c6c h1:Hei/4ADfdWqJk1ZMxUNpqntNwaWcugrBjAiHlqqRiVk= gopkg.in/check.v1 v1.0.0-20201130134442-10cb98267c6c/go.mod h1:JHkPIbrfpd72SG/EVd6muEfDQjcINNoR0C8j2r3qZ4Q= +gopkg.in/ini.v1 v1.67.0 h1:Dgnx+6+nfE+IfzjUEISNeydPJh9AXNNsWbGP9KzCsOA= +gopkg.in/ini.v1 v1.67.0/go.mod h1:pNLf8WUiyNEtQjuu5G5vTm06TEv9tsIgeAvK8hOrP4k= +gopkg.in/resty.v1 v1.12.0/go.mod h1:mDo4pnntr5jdWRML875a/NmxYqAlA73dVijT2AXvQQo= +gopkg.in/yaml.v2 v2.0.0-20170812160011-eb3733d160e7/go.mod h1:JAlM8MvJe8wmxCU4Bli9HhUf9+ttbYbLASfIpnQbh74= +gopkg.in/yaml.v2 v2.2.1/go.mod h1:hI93XBmqTisBFMUTm0b8Fm+jr3Dg1NNxqwp+5A1VGuI= +gopkg.in/yaml.v2 v2.2.2/go.mod h1:hI93XBmqTisBFMUTm0b8Fm+jr3Dg1NNxqwp+5A1VGuI= +gopkg.in/yaml.v2 v2.4.0 h1:D8xgwECY7CYvx+Y2n4sBz93Jn9JRvxdiyyo8CTfuKaY= +gopkg.in/yaml.v2 v2.4.0/go.mod h1:RDklbk79AGWmwhnvt/jBztapEOGDOx6ZbXqjP6csGnQ= gopkg.in/yaml.v3 v3.0.0-20200313102051-9f266ea9e77c/go.mod h1:K4uyk7z7BCEPqu6E+C64Yfv1cQ7kz7rIZviUmN+EgEM= gopkg.in/yaml.v3 v3.0.1 h1:fxVm/GzAzEWqLHuvctI91KS9hhNmmWOoWu0XTYJS7CA= gopkg.in/yaml.v3 v3.0.1/go.mod h1:K4uyk7z7BCEPqu6E+C64Yfv1cQ7kz7rIZviUmN+EgEM= +gotest.tools v2.2.0+incompatible h1:VsBPFP1AI068pPrMxtb/S8Zkgf9xEmTLJjfM+P5UIEo= +gotest.tools v2.2.0+incompatible/go.mod h1:DsYFclhRJ6vuDpmuTbkuFWG+y2sxOXAzmJt81HFBacw= honnef.co/go/tools v0.0.0-20190102054323-c2f93a96b099/go.mod h1:rf3lG4BRIbNafJWhAfAdb/ePZxsR/4RtNHQocxwk9r4= honnef.co/go/tools v0.0.0-20190523083050-ea95bdfd59fc/go.mod h1:rf3lG4BRIbNafJWhAfAdb/ePZxsR/4RtNHQocxwk9r4= lukechampine.com/blake3 v1.3.0 h1:sJ3XhFINmHSrYCgl958hscfIa3bw8x4DqMP3u1YvoYE= diff --git a/examples/great-token.cdc b/examples/great-token.cdc index ed17cbce2..0539506e6 100644 --- a/examples/great-token.cdc +++ b/examples/great-token.cdc @@ -1,22 +1,22 @@ -pub contract GreatToken { +access(all) contract GreatToken { - pub resource interface NFT { - pub fun id(): Int { + access(all) resource interface NFT { + access(all) fun id(): Int { post { result > 0 } } } - pub resource GreatNFT: NFT { - priv let _id: Int - priv let _special: Bool + access(all) resource GreatNFT: NFT { + access(self) let _id: Int + access(self) let _special: Bool - pub fun id(): Int { + access(all) fun id(): Int { return self._id } - pub fun isSpecial(): Bool { + access(all) fun isSpecial(): Bool { return self._special } @@ -29,11 +29,11 @@ pub contract GreatToken { } } - pub resource GreatNFTMinter { - pub var nextID: Int - pub let specialMod: Int + access(all) resource GreatNFTMinter { + access(all) var nextID: Int + access(all) let specialMod: Int - pub fun mint(): @GreatNFT { + access(all) fun mint(): @GreatNFT { var isSpecial = self.nextID % self.specialMod == 0 let nft <- create GreatNFT(id: self.nextID, isSpecial: isSpecial) self.nextID = self.nextID + 1 @@ -50,7 +50,7 @@ pub contract GreatToken { } } - pub fun createGreatNFTMinter(firstID: Int, specialMod: Int): @GreatNFTMinter { + access(all) fun createGreatNFTMinter(firstID: Int, specialMod: Int): @GreatNFTMinter { return <-create GreatNFTMinter(firstID: firstID, specialMod: specialMod) } } diff --git a/examples/modify_account/main.go b/examples/modify_account/main.go index 26b672d59..f2d4e5ed7 100644 --- a/examples/modify_account/main.go +++ b/examples/modify_account/main.go @@ -76,7 +76,7 @@ func contractsString(contracts map[string][]byte) string { func ModifyAccountDemo() { ctx := context.Background() - flowClient, err := grpc.NewClient("127.0.0.1:3569") + flowClient, err := grpc.NewClient(grpc.EmulatorHost) examples.Handle(err) serviceAcctAddr, _, _ := examples.ServiceAccount(flowClient) @@ -101,7 +101,7 @@ func ModifyAccountDemo() { serviceAcctAddr, templates.Contract{ Name: "Foo", - Source: "pub contract Foo {}", + Source: "access(all) contract Foo {}", }, ) prepareAndSendTx(ctx, flowClient, *addContractTx) @@ -114,7 +114,7 @@ func ModifyAccountDemo() { serviceAcctAddr, templates.Contract{ Name: "Foo", - Source: "pub contract Foo { pub fun hello() {} }", + Source: "access(all) contract Foo { access(all) fun hello() {} }", }, ) prepareAndSendTx(ctx, flowClient, *updateTx) diff --git a/examples/send_transactions/main.go b/examples/send_transactions/main.go index 9bdcd754b..66249bbc1 100644 --- a/examples/send_transactions/main.go +++ b/examples/send_transactions/main.go @@ -40,14 +40,14 @@ func demo() { tx := flow.NewTransaction(). SetPayer(serviceAcctAddr). SetProposalKey(serviceAcctAddr, serviceAcctKey.Index, serviceAcctKey.SequenceNumber). - SetScript([]byte(`transaction { - - prepare(acc: &Account) {} - - execute { - log("test") - } -}`)). + SetScript([]byte(` + transaction { + prepare(signer: auth(Storage) &Account) {} + execute { + log("test") + } + } + `)). AddAuthorizer(serviceAcctAddr). SetReferenceBlockID(examples.GetReferenceBlockId(flowClient)) diff --git a/examples/storage_usage/main.go b/examples/storage_usage/main.go index 435ad5ab4..e1420c59b 100644 --- a/examples/storage_usage/main.go +++ b/examples/storage_usage/main.go @@ -46,14 +46,14 @@ func StorageUsageDemo() { // A contract that defines a resource with a string so its easier to demonstrate adding resources of different sizes contract := ` - pub contract StorageDemo { - pub resource StorageTestResource { - pub let data: String + access(all) contract StorageDemo { + access(all) resource StorageTestResource { + access(all) let data: String init(data: String) { self.data = data } } - pub fun createStorageTestResource(_ data: String): @StorageTestResource { + access(all) fun createStorageTestResource(_ data: String): @StorageTestResource { return <- create StorageTestResource(data: data) } } @@ -135,9 +135,9 @@ func sendSaveLargeResourceTransaction( transaction { prepare(acct: auth(SaveValue) &Account) { - let storageUsed = acct.storageUsed - - // create resource and save it on the account + let storageUsed = acct.storage.used + + // create resource and save it on the account let bigResource <- StorageDemo.createStorageTestResource("%s") acct.storage.save(<-bigResource, to: /storage/StorageDemo) @@ -146,7 +146,7 @@ func sendSaveLargeResourceTransaction( if (storageUsed == storageUsedAfter) { panic("storage used will change") } - + if (storageUsedAfter > acct.storage.capacity) { // this is where we could deposit more flow to acct to increase its storaga capacity if we wanted to log("Storage used is over capacity. This transaction will fail if storage limits are on on this chain.") diff --git a/examples/stream_events/main.go b/examples/stream_events/main.go index dad8d76fb..037cf441e 100644 --- a/examples/stream_events/main.go +++ b/examples/stream_events/main.go @@ -34,7 +34,7 @@ func main() { func demo() { ctx := context.Background() - flowClient, err := grpc.NewClient("access.testnet.nodes.onflow.org:9000") + flowClient, err := grpc.NewClient(grpc.TestnetHost) examples.Handle(err) header, err := flowClient.GetLatestBlockHeader(ctx, true) diff --git a/examples/stream_execution_data/main.go b/examples/stream_execution_data/main.go index 56d874773..09e5b180e 100644 --- a/examples/stream_execution_data/main.go +++ b/examples/stream_execution_data/main.go @@ -34,7 +34,7 @@ func main() { func demo() { ctx := context.Background() - flowClient, err := grpc.NewClient("access-003.devnet46.nodes.onflow.org:9000") + flowClient, err := grpc.NewClient(grpc.TestnetHost) examples.Handle(err) header, err := flowClient.GetLatestBlockHeader(ctx, true) diff --git a/examples/transaction_signing/multi_party/main.go b/examples/transaction_signing/multi_party/main.go index 6da910554..b1f7b3f58 100644 --- a/examples/transaction_signing/multi_party/main.go +++ b/examples/transaction_signing/multi_party/main.go @@ -68,8 +68,8 @@ func MultiPartySingleSignatureDemo() { tx := flow.NewTransaction(). SetScript([]byte(` - transaction { - prepare(signer: AuthAccount) { log(signer.address) } + transaction { + prepare(signer: auth(Storage) &Account) { log(signer.address) } } `)). SetComputeLimit(100). diff --git a/examples/transaction_signing/multi_party_multisig/main.go b/examples/transaction_signing/multi_party_multisig/main.go index cd48bcd65..6149799a4 100644 --- a/examples/transaction_signing/multi_party_multisig/main.go +++ b/examples/transaction_signing/multi_party_multisig/main.go @@ -88,8 +88,8 @@ func MultiPartyMultiSignatureDemo() { tx := flow.NewTransaction(). SetScript([]byte(` - transaction { - prepare(signer: AuthAccount) { log(signer.address) } + transaction { + prepare(signer: auth(Storage) &Account) { log(signer.address) } } `)). SetComputeLimit(100). diff --git a/examples/transaction_signing/multi_party_two_authorizers/main.go b/examples/transaction_signing/multi_party_two_authorizers/main.go index 7c1a38d4f..22f4a99fd 100644 --- a/examples/transaction_signing/multi_party_two_authorizers/main.go +++ b/examples/transaction_signing/multi_party_two_authorizers/main.go @@ -67,9 +67,9 @@ func MultiPartySingleSignatureDemo() { referenceBlockID := examples.GetReferenceBlockId(flowClient) tx := flow.NewTransaction(). SetScript([]byte(` - transaction { - prepare(signer1: AuthAccount, signer2: AuthAccount) { - log(signer1.address) + transaction { + prepare(signer1: auth(Storage) &Account, signer2: auth(Storage) &Account) { + log(signer1.address) log(signer2.address) } }`)). diff --git a/examples/transaction_signing/single_party/main.go b/examples/transaction_signing/single_party/main.go index f1c130faf..117bb91e8 100644 --- a/examples/transaction_signing/single_party/main.go +++ b/examples/transaction_signing/single_party/main.go @@ -55,8 +55,8 @@ func SinglePartySingleSignatureDemo() { referenceBlockID := examples.GetReferenceBlockId(flowClient) tx := flow.NewTransaction(). SetScript([]byte(` - transaction { - prepare(signer: AuthAccount) { log(signer.address) } + transaction { + prepare(signer: auth(Storage) &Account) { log(signer.address) } } `)). SetComputeLimit(100). diff --git a/examples/transaction_signing/single_party_multisig/main.go b/examples/transaction_signing/single_party_multisig/main.go index 4701bc77b..e70f33126 100644 --- a/examples/transaction_signing/single_party_multisig/main.go +++ b/examples/transaction_signing/single_party_multisig/main.go @@ -65,8 +65,8 @@ func SinglePartyMultiSignatureDemo() { referenceBlockID := examples.GetReferenceBlockId(flowClient) tx := flow.NewTransaction(). SetScript([]byte(` - transaction { - prepare(signer: AuthAccount) { log(signer.address) } + transaction { + prepare(signer: auth(Storage) &Account) { log(signer.address) } } `)). SetComputeLimit(100). diff --git a/examples/verify_events/main.go b/examples/verify_events/main.go index 5421df68e..89c116820 100644 --- a/examples/verify_events/main.go +++ b/examples/verify_events/main.go @@ -40,7 +40,7 @@ func main() { // For users, its possible to get all the events for chunk, calculate and compare the resulting hash func VerifyEventsDemo() { ctx := context.Background() - flowClient, err := http.NewClient(http.EmulatorHost) + flowClient, err := http.NewClient(http.TestnetHost) examples.Handle(err) latestBlockHeader, err := flowClient.GetLatestBlockHeader(ctx, true) diff --git a/examples/verify_signature/user_signature/main.go b/examples/verify_signature/user_signature/main.go index 83eee76fc..a719ae979 100644 --- a/examples/verify_signature/user_signature/main.go +++ b/examples/verify_signature/user_signature/main.go @@ -40,13 +40,14 @@ func main() { var script = []byte(` import Crypto -pub fun main( +access(all) fun main( rawPublicKeys: [String], weights: [UFix64], signatures: [String], toAddress: Address, fromAddress: Address, amount: UFix64, + domainSeparationTag: String, ): Bool { let keyList = Crypto.KeyList() @@ -84,6 +85,7 @@ pub fun main( return keyList.verify( signatureSet: signatureSet, signedData: message, + domainSeparationTag: domainSeparationTag, ) } `) @@ -145,6 +147,8 @@ func UserSignatureDemo() { cadence.String(hex.EncodeToString(signatureBob)), }) + domainSeparationTag := cadence.String(flow.UserDomainTag[:]) + // call the script to verify the signatures on chain value, err := flowClient.ExecuteScriptAtLatestBlock( ctx, @@ -156,6 +160,7 @@ func UserSignatureDemo() { toAddress, fromAddress, amount, + domainSeparationTag, }, ) examples.Handle(err) diff --git a/examples/verify_signature/user_signature_validate_all/main.go b/examples/verify_signature/user_signature_validate_all/main.go index 26185df36..8dd49b9ea 100644 --- a/examples/verify_signature/user_signature_validate_all/main.go +++ b/examples/verify_signature/user_signature_validate_all/main.go @@ -39,14 +39,15 @@ func main() { var script = []byte(` import Crypto -pub fun main( +access(all) fun main( address: Address, signatures: [String], keyIndexes: [Int], message: String, + domainSeparationTag: String, ): Bool { let keyList = Crypto.KeyList() - + let account = getAccount(address) let keys = account.keys @@ -69,9 +70,9 @@ pub fun main( return false } } - + let signatureSet: [Crypto.KeyListSignature] = [] - + var i = 0 for signature in signatures { signatureSet.append( @@ -82,10 +83,11 @@ pub fun main( ) i = i + 1 } - + return keyList.verify( signatureSet: signatureSet, signedData: message.utf8, + domainSeparationTag: domainSeparationTag, ) } `) @@ -136,6 +138,8 @@ func UserSignatureValidateAll() { cadence.NewInt(0), }) + domainSeparationTag := flow.UserDomainTag[:] + // call the script to verify the signatures on chain value, err := flowClient.ExecuteScriptAtLatestBlock( ctx, @@ -145,6 +149,7 @@ func UserSignatureValidateAll() { signatures, signatureIndexes, cadence.String(message), + cadence.String(domainSeparationTag), }, ) examples.Handle(err) diff --git a/examples/verify_signature/user_signature_validate_any/main.go b/examples/verify_signature/user_signature_validate_any/main.go index c0fe2a788..68a22acf2 100644 --- a/examples/verify_signature/user_signature_validate_any/main.go +++ b/examples/verify_signature/user_signature_validate_any/main.go @@ -39,13 +39,14 @@ func main() { var script = []byte(` import Crypto -pub fun main( +access(all) fun main( address: Address, signature: String, - message: String + message: String, + domainSeparationTag: String ): Bool { let keyList = Crypto.KeyList() - + let account = getAccount(address) let keys = account.keys @@ -67,7 +68,7 @@ pub fun main( if pk.verify( signature: signatureBytes, signedData: messageBytes, - domainSeparationTag: "FLOW-V0.0-user", + domainSeparationTag: domainSeparationTag, hashAlgorithm: key.hashAlgorithm ) { // this key is good @@ -115,6 +116,8 @@ func UserSignatureValidateAny() { signatureAlice, err := flow.SignUserMessage(signerAlice, message) examples.Handle(err) + domainSeparationTag := flow.UserDomainTag[:] + // call the script to verify the signature on chain value, err := flowClient.ExecuteScriptAtLatestBlock( ctx, @@ -123,6 +126,7 @@ func UserSignatureValidateAny() { cadence.BytesToAddress(account.Address.Bytes()), cadence.String(hex.EncodeToString(signatureAlice)), cadence.String(message), + cadence.String(domainSeparationTag), }, ) examples.Handle(err)