Documentation ¶
Overview ¶
Package utils is used for common functions and tools used across the codebase.
Index ¶
- Constants
- Variables
- func AddHexPrefix(str string) string
- func Bytes32FromString(s string) [32]byte
- func Bytes4FromString(s string) [4]byte
- func CheckPasswordHash(password, hash string) bool
- func CheckUint256(n *big.Int) error
- func CombinedContext(signals ...interface{}) (context.Context, context.CancelFunc)
- func ConcatBytes(bufs ...[]byte) []byte
- func ContextFromChan(chStop <-chan struct{}) (context.Context, context.CancelFunc)
- func CopyFileWithMaxPerms(srcPath, dstPath string, perms os.FileMode) error
- func DebugPanic()
- func DecodeEthereumTx(hex string) (types.Transaction, error)
- func DurationFromNow(t time.Time) time.Duration
- func EIP55CapitalizedAddress(possibleAddressString string) bool
- func EVMBytesToUint64(buf []byte) uint64
- func EVMEncodeBytes(input []byte) []byte
- func EVMTranscodeBool(value gjson.Result) ([]byte, error)
- func EVMTranscodeBytes(value gjson.Result) ([]byte, error)
- func EVMTranscodeInt256(value gjson.Result) ([]byte, error)
- func EVMTranscodeJSONWithFormat(value gjson.Result, format string) ([]byte, error)
- func EVMTranscodeUint256(value gjson.Result) ([]byte, error)
- func EVMWordBigInt(val *big.Int) ([]byte, error)
- func EVMWordSignedBigInt(val *big.Int) ([]byte, error)
- func EVMWordUint128(val *big.Int) ([]byte, error)
- func EVMWordUint64(val uint64) []byte
- func EnsureDirAndMaxPerms(path string, perms os.FileMode) error
- func EnsureFileMaxPerms(file *os.File, perms os.FileMode) error
- func EnsureFilepathMaxPerms(filepath string, perms os.FileMode) error
- func FileContents(path string) (string, error)
- func FileExists(name string) bool
- func FilesInDir(dir string) ([]string, error)
- func FormatJSON(v interface{}) ([]byte, error)
- func HasHexPrefix(str string) bool
- func HashPassword(password string) (string, error)
- func HexToBig(s string) *big.Int
- func HexToUint256(s string) (*big.Int, error)
- func ISO8601UTC(t time.Time) string
- func IsEmpty(bytes []byte) bool
- func IsEmptyAddress(addr common.Address) bool
- func IsFileOwnedByChainlink(fileInfo os.FileInfo) (bool, error)
- func IsQuoted(input []byte) bool
- func JustError(_ interface{}, err error) error
- func Keccak256(in []byte) ([]byte, error)
- func LogIfError(err *error, msg string)
- func LogListeningAddress(address common.Address) string
- func MaxBigs(first *big.Int, bigs ...*big.Int) *big.Int
- func MaxInt(first int, ints ...int) int
- func MaxUint32(first uint32, uints ...uint32) uint32
- func MinUint(first uint, vals ...uint) uint
- func MustHash(in string) common.Hash
- func MustUnmarshalToMap(input string) map[string]interface{}
- func NewBytes32ID() string
- func NewSecret(n int) string
- func NormalizedJSON(val []byte) (string, error)
- func NullISO8601UTC(t null.Time) string
- func ParseEthereumAddress(addressString string) (common.Address, error)
- func RemoveHexPrefix(str string) string
- func RemoveQuotes(input []byte) []byte
- func RetryWithBackoff(ctx context.Context, fn func() (retry bool))
- func ReverseString(s string) string
- func Sha256(in string) (string, error)
- func StringToHex(in string) string
- func StripBearer(authorizationStr string) string
- func ToDecimal(input interface{}) (decimal.Decimal, error)
- func TooPermissive(fileMode, maxAllowedPerms os.FileMode) bool
- func Uint256ToBytes(x *big.Int) (uint256 []byte, err error)
- func Uint256ToBytes32(n *big.Int) []byte
- func Uint256ToHex(n *big.Int) (string, error)
- func Uint64ToHex(i uint64) string
- func UnmarshalToMap(input string) (map[string]interface{}, error)
- func WaitGroupChan(wg *sync.WaitGroup) <-chan struct{}
- func WithJitter(d time.Duration) time.Duration
- func WithoutZeroAddresses(addresses []common.Address) []common.Address
- func WrapIfError(err *error, msg string)
- func WriteFileWithMaxPerms(path string, data []byte, perms os.FileMode) error
- type AfterNower
- type Afterer
- type BackoffSleeper
- type BackoffTicker
- type Big
- func (b *Big) Hex() string
- func (b *Big) MarshalJSON() ([]byte, error)
- func (b *Big) MarshalText() ([]byte, error)
- func (b *Big) Scan(value interface{}) error
- func (b *Big) String() string
- func (b *Big) ToInt() *big.Int
- func (b *Big) UnmarshalJSON(input []byte) error
- func (b *Big) UnmarshalText(input []byte) error
- func (b Big) Value() (driver.Value, error)
- type BigFloat
- type BigIntSlice
- type BoundedPriorityQueue
- type BoundedQueue
- type Clock
- type DependentAwaiter
- type HTTPRequest
- type HTTPRequestConfig
- type HTTPResponseTooLargeError
- type KeyedMutex
- type Mailbox
- type MaxBytesReader
- type Nower
- type PausableTicker
- type RemoteServerError
- type ResettableTimer
- type ScryptConfigReader
- type ScryptParams
- type Sleeper
- type SleeperTask
- type SleeperTaskFuncWorker
- type StartStopOnce
- func (once *StartStopOnce) Healthy() error
- func (once *StartStopOnce) IfStarted(f func()) (ok bool)
- func (once *StartStopOnce) Ready() error
- func (once *StartStopOnce) StartOnce(name string, fn func() error) error
- func (once *StartStopOnce) State() StartStopOnceState
- func (once *StartStopOnce) StopOnce(name string, fn func() error) error
- type StartStopOnceState
- type Worker
Constants ¶
const ( // FormatBytes encodes the output as bytes FormatBytes = "bytes" // FormatPreformatted encodes the output, assumed to be hex, as bytes. FormatPreformatted = "preformatted" // FormatUint256 encodes the output as bytes containing a uint256 FormatUint256 = "uint256" // FormatInt256 encodes the output as bytes containing an int256 FormatInt256 = "int256" // FormatBool encodes the output as bytes containing a bool FormatBool = "bool" )
const ( // FastN is a shorter N parameter for testing FastN = 2 // FastP is a shorter P parameter for testing FastP = 1 )
const ( // DefaultSecretSize is the entroy in bytes to generate a base64 string of 64 characters. DefaultSecretSize = 48 // EVMWordByteLen the length of an EVM Word Byte EVMWordByteLen = 32 // EVMWordHexLen the length of an EVM Word Hex EVMWordHexLen = EVMWordByteLen * 2 )
Variables ¶
var ( // MaxUint256 represents the largest number represented by an EVM word MaxUint256 = &big.Int{} // MaxInt256 represents the largest number represented by an EVM word using // signed encoding. MaxInt256 = &big.Int{} // MinInt256 represents the smallest number represented by an EVM word using // signed encoding. MinInt256 = &big.Int{} )
"Constants" used by EVM words
var ( // Client represents a HTTP Client Client *http.Client // UnrestrictedClient represents a HTTP Client with no Transport restrictions UnrestrictedClient *http.Client )
var DefaultScryptParams = ScryptParams{N: keystore.StandardScryptN, P: keystore.StandardScryptP}
DefaultScryptParams is for use in production. It used geth's standard level of encryption and is relatively expensive to decode. Avoid using this in tests.
var EmptyHash = common.Hash{}
EmptyHash is a hash of all zeroes, otherwise in Ethereum as 0x0000000000000000000000000000000000000000000000000000000000000000
var (
ErrNotStarted = errors.New("Not started")
)
var FastScryptParams = ScryptParams{N: FastN, P: FastP}
FastScryptParams is for use in tests, where you don't want to wear out your CPU with expensive key derivations, do not use it in production, or your encrypted keys will be easy to brute-force!
var ZeroAddress = common.Address{}
ZeroAddress is an address of all zeroes, otherwise in Ethereum as 0x0000000000000000000000000000000000000000
Functions ¶
func AddHexPrefix ¶
AddHexPrefix adds the previx (0x) to a given hex string.
func Bytes32FromString ¶
func Bytes4FromString ¶
func CheckPasswordHash ¶
CheckPasswordHash wraps around bcrypt.CompareHashAndPassword for a friendlier API.
func CheckUint256 ¶
CheckUint256 returns an error if n is out of bounds for a uint256
func CombinedContext ¶
func CombinedContext(signals ...interface{}) (context.Context, context.CancelFunc)
CombinedContext creates a context that finishes when any of the provided signals finish. A signal can be a `context.Context`, a `chan struct{}`, or a `time.Duration` (which is transformed into a `context.WithTimeout`).
func ConcatBytes ¶
ConcatBytes appends a bunch of byte arrays into a single byte array
func ContextFromChan ¶
func ContextFromChan(chStop <-chan struct{}) (context.Context, context.CancelFunc)
ContextFromChan creates a context that finishes when the provided channel receives or is closed.
func CopyFileWithMaxPerms ¶
CopyFileWithMaxPerms copies the file at `srcPath` to `dstPath` and ensures that it has permissions that are no more permissive than the given ones.
func DecodeEthereumTx ¶
func DecodeEthereumTx(hex string) (types.Transaction, error)
DecodeEthereumTx takes an RLP hex encoded Ethereum transaction and returns a Transaction struct with all the fields accessible.
func DurationFromNow ¶
DurationFromNow returns the amount of time since the Time field was last updated.
func EIP55CapitalizedAddress ¶
EIP55CapitalizedAddress returns true iff possibleAddressString has the correct capitalization for an Ethereum address, per EIP 55
func EVMBytesToUint64 ¶
EVMBytesToUint64 converts a bytebuffer to uint64
func EVMEncodeBytes ¶
EVMEncodeBytes encodes arbitrary bytes as bytes expected by the EVM
func EVMTranscodeBool ¶
EVMTranscodeBool converts a json input to an EVM bool
func EVMTranscodeBytes ¶
EVMTranscodeBytes converts a json input to an EVM bytes array
func EVMTranscodeInt256 ¶
EVMTranscodeInt256 converts a json input to an EVM int256
func EVMTranscodeJSONWithFormat ¶
EVMTranscodeJSONWithFormat given a JSON input and a format specifier, encode the value for use by the EVM
func EVMTranscodeUint256 ¶
EVMTranscodeUint256 converts a json input to an EVM uint256
func EVMWordBigInt ¶
EVMWordBigInt returns a big.Int as an EVM word byte array, with support for a signed representation. Returns error on overflow.
func EVMWordSignedBigInt ¶
EVMWordSignedBigInt returns a big.Int as an EVM word byte array, with support for a signed representation. Returns error on overflow.
func EVMWordUint128 ¶
EVMWordUint128 returns a uint128 as an EVM word byte array.
func EVMWordUint64 ¶
EVMWordUint64 returns a uint64 as an EVM word byte array.
func EnsureDirAndMaxPerms ¶
EnsureDirAndMaxPerms ensures that the given path exists, that it's a directory, and that it has permissions that are no more permissive than the given ones.
- If the path does not exist, it is created - If the path exists, but is not a directory, an error is returned - If the path exists, and is a directory, but has the wrong perms, it is chmod'ed
func EnsureFileMaxPerms ¶
EnsureFileMaxPerms ensures that the given file has permissions that are no more permissive than the given ones.
func EnsureFilepathMaxPerms ¶
EnsureFilepathMaxPerms ensures that the file at the given filepath has permissions that are no more permissive than the given ones.
func FileContents ¶
FileContents returns the contents of a file as a string.
func FileExists ¶
FileExists returns true if a file at the passed string exists.
func FilesInDir ¶
FilesInDir returns an array of filenames in the directory.
func FormatJSON ¶
FormatJSON applies indent to format a JSON response.
func HasHexPrefix ¶
HasHexPrefix returns true if the string starts with 0x.
func HashPassword ¶
HashPassword wraps around bcrypt.GenerateFromPassword for a friendlier API.
func HexToUint256 ¶
HexToUint256 returns the uint256 represented by s, or an error if it doesn't represent one.
func IsEmptyAddress ¶
IsEmptyAddress checks that the address is empty, synonymous with the zero account/address. No logs can come from this address, as there is no contract present there.
See https://stackoverflow.com/questions/48219716/what-is-address0-in-solidity for the more info on the zero address.
func IsFileOwnedByChainlink ¶
IsFileOwnedByChainlink attempts to read fileInfo to verify file owner
func Keccak256 ¶
Keccak256 is a simplified interface for the legacy SHA3 implementation that Ethereum uses.
func LogListeningAddress ¶
LogListeningAddress returns the LogListeningAddress
func MustUnmarshalToMap ¶
MustUnmarshalToMap performs UnmarshalToMap, panics upon failure
func NewBytes32ID ¶
func NewBytes32ID() string
NewBytes32ID returns a randomly generated UUID that conforms to Ethereum bytes32.
func NewSecret ¶
NewSecret returns a new securely random sequence of n bytes of entropy. The result is a base64 encoded string.
Panics on failed attempts to read from system's PRNG.
func NormalizedJSON ¶
NormalizedJSON returns a JSON representation of an object that has been normalized to produce a consistent output for hashing.
NOTE: If this string is unmarshalled again, there is no guarantee that the final representation will be consistent with the string produced by this function due to differences in JSON implementations and information loss. e.g:
JSON does not have a requirement to respect object key ordering.
func NullISO8601UTC ¶
NullISO8601UTC returns formatted time if valid, empty string otherwise.
func ParseEthereumAddress ¶
ParseEthereumAddress returns addressString as a go-ethereum Address, or an error if it's invalid, e.g. if EIP 55 capitalization check fails
func RemoveHexPrefix ¶
RemoveHexPrefix removes the prefix (0x) of a given hex string.
func RemoveQuotes ¶
RemoveQuotes removes the first and last character if they are both either " or ', otherwise it is a noop.
func RetryWithBackoff ¶
RetryWithBackoff retries the sleeper and backs off if not Done
func ReverseString ¶
ReverseString returns its argument string reversed rune-wise left to right.
func StringToHex ¶
StringToHex converts a standard string to a hex encoded string.
func StripBearer ¶
StripBearer removes the 'Bearer: ' prefix from the HTTP Authorization header.
func TooPermissive ¶
TooPermissive checks if the file has more than the allowed permissions
func Uint256ToBytes ¶
Uint256ToBytes is x represented as the bytes of a uint256
func Uint256ToBytes32 ¶
Uint256ToBytes32 returns the bytes32 encoding of the big int provided
func Uint256ToHex ¶
Uint256ToHex returns the hex representation of n, or error if out of bounds
func Uint64ToHex ¶
Uint64ToHex converts the given uint64 value to a hex-value string.
func UnmarshalToMap ¶
UnmarshalToMap takes an input json string and returns a map[string]interface i.e. a raw object
func WaitGroupChan ¶
WaitGroupChan creates a channel that closes when the provided sync.WaitGroup is done.
func WithJitter ¶
WithJitter adds +/- 10% to a duration
func WithoutZeroAddresses ¶
WithoutZeroAddresses returns a list of addresses excluding the zero address.
func WrapIfError ¶
WrapIfError decorates an error with the given message. It is intended to be used with `defer` statements, like so:
func SomeFunction() (err error) { defer WrapIfError(&err, "error in SomeFunction:") ... }
Types ¶
type AfterNower ¶
AfterNower is an interface that fulfills the `After()` and `Now()` methods.
type Afterer ¶
Afterer is an interface that fulfills the After method, following the behavior of time.After.
type BackoffSleeper ¶
BackoffSleeper is a sleeper that backs off on subsequent attempts.
func NewBackoffSleeper ¶
func NewBackoffSleeper() *BackoffSleeper
NewBackoffSleeper returns a BackoffSleeper that is configured to sleep for 0 seconds initially, then backs off from 1 second minimum to 10 seconds maximum.
func (*BackoffSleeper) After ¶
func (bs *BackoffSleeper) After() time.Duration
After returns the duration for the next stop, and increments the backoff.
func (*BackoffSleeper) Duration ¶
func (bs *BackoffSleeper) Duration() time.Duration
Duration returns the current duration value.
func (*BackoffSleeper) Reset ¶
func (bs *BackoffSleeper) Reset()
Reset resets the backoff intervals.
func (*BackoffSleeper) Sleep ¶
func (bs *BackoffSleeper) Sleep()
Sleep waits for the given duration, incrementing the back off.
type BackoffTicker ¶
func NewBackoffTicker ¶
func NewBackoffTicker(min, max time.Duration) BackoffTicker
func (*BackoffTicker) Start ¶
func (t *BackoffTicker) Start() bool
Start - Starts the ticker Returns true if the ticker was not running yet
func (*BackoffTicker) Stop ¶
func (t *BackoffTicker) Stop() bool
Stop stops the ticker. A ticker can be restarted by calling Start on a stopped ticker. Returns true if the ticker was actually stopped at this invocation (was previously running)
func (*BackoffTicker) Ticks ¶
func (t *BackoffTicker) Ticks() <-chan time.Time
type Big ¶
Big stores large integers and can deserialize a variety of inputs.
func (*Big) MarshalJSON ¶
MarshalJSON marshals this instance to base 10 number as string.
func (*Big) MarshalText ¶
MarshalText marshals this instance to base 10 number as string.
func (*Big) UnmarshalJSON ¶
UnmarshalJSON implements encoding.JSONUnmarshaler.
func (*Big) UnmarshalText ¶
UnmarshalText implements encoding.TextUnmarshaler.
type BigFloat ¶
BigFloat accepts both string and float JSON values.
func (BigFloat) MarshalJSON ¶
MarshalJSON implements the json.Marshaler interface.
func (*BigFloat) UnmarshalJSON ¶
UnmarshalJSON implements the json.Unmarshal interface.
type BigIntSlice ¶
BigIntSlice attaches the methods of sort.Interface to []*big.Int, sorting in increasing order.
func (BigIntSlice) Len ¶
func (s BigIntSlice) Len() int
func (BigIntSlice) Less ¶
func (s BigIntSlice) Less(i, j int) bool
func (BigIntSlice) Min ¶
func (s BigIntSlice) Min() *big.Int
func (BigIntSlice) Swap ¶
func (s BigIntSlice) Swap(i, j int)
type BoundedPriorityQueue ¶
type BoundedPriorityQueue struct {
// contains filtered or unexported fields
}
BoundedPriorityQueue stores a series of BoundedQueues with associated priorities and capacities
func NewBoundedPriorityQueue ¶
func NewBoundedPriorityQueue(capacities map[uint]uint) *BoundedPriorityQueue
NewBoundedPriorityQueue creates a new BoundedPriorityQueue
func (*BoundedPriorityQueue) Add ¶
func (q *BoundedPriorityQueue) Add(priority uint, x interface{})
Add pushes an item into a subque within a BoundedPriorityQueue
func (*BoundedPriorityQueue) Empty ¶
func (q *BoundedPriorityQueue) Empty() bool
Empty checks the BoundedPriorityQueue if all subqueues are empty
func (*BoundedPriorityQueue) Take ¶
func (q *BoundedPriorityQueue) Take() interface{}
Take takes from the BoundedPriorityQueue's subque
type BoundedQueue ¶
type BoundedQueue struct {
// contains filtered or unexported fields
}
BoundedQueue is a FIFO queue that discards older items when it reaches its capacity.
func NewBoundedQueue ¶
func NewBoundedQueue(capacity uint) *BoundedQueue
NewBoundedQueue creates a new BoundedQueue instance
func (*BoundedQueue) Add ¶
func (q *BoundedQueue) Add(x interface{})
Add appends items to a BoundedQueue
func (*BoundedQueue) Empty ¶
func (q *BoundedQueue) Empty() bool
Empty check is a BoundedQueue is empty
func (*BoundedQueue) Full ¶
func (q *BoundedQueue) Full() bool
Full checks if a BoundedQueue is over capacity.
func (*BoundedQueue) Take ¶
func (q *BoundedQueue) Take() interface{}
Take pulls the first item from the array and removes it
type Clock ¶
type Clock struct{}
Clock is a basic type for scheduling events in the application.
type DependentAwaiter ¶
type DependentAwaiter interface { AwaitDependents() <-chan struct{} AddDependents(n int) DependentReady() }
DependentAwaiter contains Dependent funcs
func NewDependentAwaiter ¶
func NewDependentAwaiter() DependentAwaiter
NewDependentAwaiter creates a new DependentAwaiter
type HTTPRequest ¶
type HTTPRequest struct { Request *http.Request Config HTTPRequestConfig }
HTTPRequest holds the request and config struct for a http request
func (*HTTPRequest) SendRequest ¶
func (h *HTTPRequest) SendRequest(ctx context.Context) (responseBody []byte, statusCode int, err error)
SendRequest sends a HTTPRequest, returns a body, status code, and error.
type HTTPRequestConfig ¶
type HTTPRequestConfig struct { Timeout time.Duration MaxAttempts uint SizeLimit int64 AllowUnrestrictedNetworkAccess bool }
HTTPRequestConfig holds the configurable settings for a http request
type HTTPResponseTooLargeError ¶
type HTTPResponseTooLargeError struct {
// contains filtered or unexported fields
}
HTTPResponseTooLargeError stores a limit, used to throw an error for HTTP Responses if they exceed the byte limit
func (*HTTPResponseTooLargeError) Error ¶
func (e *HTTPResponseTooLargeError) Error() string
Error returns an error message for exceeding the HTTP response byte limit
type KeyedMutex ¶
type KeyedMutex struct {
// contains filtered or unexported fields
}
KeyedMutex allows to lock based on particular values
func (*KeyedMutex) LockInt64 ¶
func (m *KeyedMutex) LockInt64(key int64) func()
LockInt64 locks the value for read/write
type Mailbox ¶
type Mailbox struct {
// contains filtered or unexported fields
}
Mailbox contains a notify channel, a mutual exclusive lock, a queue of interfaces, and a queue capacity.
func NewMailbox ¶
NewMailbox creates a new mailbox instance
func (*Mailbox) Notify ¶
func (m *Mailbox) Notify() chan struct{}
Notify returns the contents of the notify channel
func (*Mailbox) RetrieveLatestAndClear ¶
func (m *Mailbox) RetrieveLatestAndClear() interface{}
type MaxBytesReader ¶
type MaxBytesReader struct {
// contains filtered or unexported fields
}
MaxBytesReader is inspired by https://github.com/gin-contrib/size/blob/master/size.go
func NewMaxBytesReader ¶
func NewMaxBytesReader(rc io.ReadCloser, limit int64) *MaxBytesReader
NewMaxBytesReader returns a new MaxBytesReader, accepts a ReadCloser and limit
type Nower ¶
Nower is an interface that fulfills the Now method, following the behavior of time.Now.
type PausableTicker ¶
type PausableTicker struct {
// contains filtered or unexported fields
}
PausableTicker stores a ticker with a duration
func NewPausableTicker ¶
func NewPausableTicker(duration time.Duration) PausableTicker
NewPausableTicker creates a new PausableTicker
func (*PausableTicker) Destroy ¶
func (t *PausableTicker) Destroy()
Destroy pauses the PausibleTicker
func (*PausableTicker) Resume ¶
func (t *PausableTicker) Resume()
Resume resumes a Ticker using a PausibleTicker's duration
func (PausableTicker) Ticks ¶
func (t PausableTicker) Ticks() <-chan time.Time
Ticks retrieves the ticks from a PausableTicker
type RemoteServerError ¶
type RemoteServerError struct {
// contains filtered or unexported fields
}
RemoteServerError stores the response body and status code
func (*RemoteServerError) Error ¶
func (e *RemoteServerError) Error() string
type ResettableTimer ¶
type ResettableTimer struct {
// contains filtered or unexported fields
}
ResettableTimer stores a timer
func NewResettableTimer ¶
func NewResettableTimer() ResettableTimer
NewResettableTimer creates a new ResettableTimer
func (*ResettableTimer) Reset ¶
func (t *ResettableTimer) Reset(duration time.Duration)
Reset stops a ResettableTimer and resets it with a new duration
func (ResettableTimer) Ticks ¶
func (t ResettableTimer) Ticks() <-chan time.Time
Ticks retrieves the ticks from a ResettableTimer
type ScryptConfigReader ¶
type ScryptConfigReader interface {
InsecureFastScrypt() bool
}
ScryptConfigReader can check for an insecure, fast flag
type ScryptParams ¶
type ScryptParams struct{ N, P int }
ScryptParams represents two integers, N and P.
func GetScryptParams ¶
func GetScryptParams(config ScryptConfigReader) ScryptParams
GetScryptParams fetches ScryptParams from a ScryptConfigReader
type Sleeper ¶
Sleeper interface is used for tasks that need to be done on some interval, excluding Cron, like reconnecting.
type SleeperTask ¶
type SleeperTask interface { Stop() error WakeUp() WakeUpIfStarted() }
SleeperTask represents a task that waits in the background to process some work.
func NewSleeperTask ¶
func NewSleeperTask(worker Worker) SleeperTask
NewSleeperTask takes a worker and returns a SleeperTask.
SleeperTask is guaranteed to call Work on the worker at least once for every WakeUp call. If the Worker is busy when WakeUp is called, the Worker will be called again immediately after it is finished. For this reason you should take care to make sure that Worker is idempotent. WakeUp does not block.
type SleeperTaskFuncWorker ¶
type SleeperTaskFuncWorker func()
func (SleeperTaskFuncWorker) Work ¶
func (fn SleeperTaskFuncWorker) Work()
type StartStopOnce ¶
type StartStopOnce struct { sync.RWMutex // lock is held during statup/shutdown, RLock is held while executing functions dependent on a particular state // contains filtered or unexported fields }
StartStopOnce contains a StartStopOnceState integer
func (*StartStopOnce) Healthy ¶
func (once *StartStopOnce) Healthy() error
Override this per-service with more specific implementations
func (*StartStopOnce) IfStarted ¶
func (once *StartStopOnce) IfStarted(f func()) (ok bool)
IfStarted runs the func and returns true only if started, otherwise returns false
func (*StartStopOnce) Ready ¶
func (once *StartStopOnce) Ready() error
func (*StartStopOnce) StartOnce ¶
func (once *StartStopOnce) StartOnce(name string, fn func() error) error
StartOnce sets the state to Started
func (*StartStopOnce) State ¶
func (once *StartStopOnce) State() StartStopOnceState
State retrieves the current state
type StartStopOnceState ¶
type StartStopOnceState int32
StartStopOnceState holds the state for StartStopOnce
const ( StartStopOnce_Unstarted StartStopOnceState = iota StartStopOnce_Started StartStopOnce_Starting StartStopOnce_Stopping StartStopOnce_Stopped )