阿里雙11同款,流量防衛兵 Sentinel go 原始碼解讀
導讀:本文主要分析阿里巴巴集團開源的流量控制中介軟體 Sentinel,其原生支援了 Java/Go/C++ 等多種語言,本文僅僅分析其 Go 語言實現。下文如無特殊說明,sentinel 指代 Sentinel-Go。
1 基本概念 Resource 和 Rule
1.1 Resource
// ResourceType represents classification of the resources
type ResourceType int32
const (
ResTypeCommon ResourceType = iota
ResTypeWeb
ResTypeRPC
)
// TrafficType describes the traffic type: Inbound or Outbound
type TrafficType int32
const (
// Inbound represents the inbound traffic (e.g. provider)
Inbound TrafficType = iota
// Outbound represents the outbound traffic (e.g. consumer)
Outbound
)
// ResourceWrapper represents the invocation
type ResourceWrapper struct {
// global unique resource name
name string
// resource classification
classification ResourceType
// Inbound or Outbound
flowType TrafficType
}
Resource(ResourceWrapper) 儲存了應用場景 ResourceType,以及目標流控的方向 FlowType(TrafficType)。
1.2 Entry
// EntryOptions represents the options of a Sentinel resource entry.
type EntryOptions struct {
resourceType base.ResourceType
entryType base.TrafficType
acquireCount uint32
slotChain *base.SlotChain
}
type EntryContext struct {
entry *SentinelEntry
// Use to calculate RT
startTime uint64
Resource *ResourceWrapper
StatNode StatNode
Input *SentinelInput
// the result of rule slots check
RuleCheckResult *TokenResult
}
type SentinelEntry struct {
res *ResourceWrapper
// one entry bounds with one context
ctx *EntryContext
sc *SlotChain
}
Entry 實體 SentinelEntry 關聯了 Resource(ResourceWrapper) 以及其流控規則集合 SlotChain。每個 Entry 實體有一個上下文環境 EntryContext,儲存每個 Rule 檢測時用到的一些流控引數和流控判定結果。
值得注意的是,SentinelEntry.sc 值來自於 EntryOptions.slotChain,EntryOptions.slotChain 儲存了全域性 SlotChain 物件 api/slot_chain.go:globalSlotChain。
至於何為 SlotChain,就是 sentinel 提供的所有的流控元件的集合,可以簡單地認為每個流控元件就是一個 Slot,其詳細分析見[[3.5 SlotChain]](#3.5)。
sentinel 一些變數和函式命名的可讀性較差,如 EntryOptions.acquireCount 實在無法讓人望文生義,看過函式 core/api.go:WithAcquireCount() 的註釋才明白:EntryOptions.acquireCount 是批量動作執行次數。如有的一次 RPC 請求中呼叫了服務端的一個服務介面,則取值 1【也是 EntryOptions.acquireCount 的預設取值】,如果呼叫了服務端的 3 個服務介面,則取值 3。所以建議改名為 EntryOptions.batchCount 比較好,考慮到最小改動原則,可以在保留 core/api.go:WithAcquireCount() 的同時增加一個同樣功能的 core/api.go:WithBatchCount() 介面。相關改進已經提交到 pr 263。
1.3 Rule
type TokenCalculateStrategy int32
const (
Direct TokenCalculateStrategy = iota
WarmUp
)
type ControlBehavior int32
const (
Reject ControlBehavior = iota
Throttling
)
// Rule describes the strategy of flow control, the flow control strategy is based on QPS statistic metric
type Rule struct {
// Resource represents the resource name.
Resource string `json:"resource"`
ControlBehavior ControlBehavior `json:"controlBehavior"`
// Threshold means the threshold during StatIntervalInMs
// If StatIntervalInMs is 1000(1 second), Threshold means QPS
Threshold float64 `json:"threshold"`
MaxQueueingTimeMs uint32 `json:"maxQueueingTimeMs"`
// StatIntervalInMs indicates the statistic interval and it's the optional setting for flow Rule.
// If user doesn't set StatIntervalInMs, that means using default metric statistic of resource.
// If the StatIntervalInMs user specifies can not reuse the global statistic of resource,
// sentinel will generate independent statistic structure for this rule.
StatIntervalInMs uint32 `json:"statIntervalInMs"`
}
Rule 記錄了某 Resource 的限流判定閾值 Threshold、限流時間視窗計時長度 StatIntervalInMs 以及 觸發限流後的判罰動作 ControlBehavior。
上面核心是 Rule 的介面 RuleCheckSlot,至於 StatSlot 則用於統計 sentinel 自身的執行 metrics。
1.4 Flow
當前章節主要分析流控中的限流(core/flow),根據流控的處理流程梳理 sentinel 整體骨架。
1.4.1 TrafficShapingController
所謂 TrafficShapingController,顧名思義,就是 流量塑形控制器,是流控的具體實施者。
// core/flow/traffic_shaping.go
// TrafficShapingCalculator calculates the actual traffic shaping threshold
// based on the threshold of rule and the traffic shaping strategy.
type TrafficShapingCalculator interface {
CalculateAllowedTokens(acquireCount uint32, flag int32) float64
}
type DirectTrafficShapingCalculator struct {
threshold float64
}
func (d *DirectTrafficShapingCalculator) CalculateAllowedTokens(uint32, int32) float64 {
return d.threshold
}
TrafficShapingCalculator 介面用於計算限流的上限,如果不使用 warm-up 功能,可以不去深究其實現,其實體之一 DirectTrafficShapingCalculator 返回 Rule.Threshold【使用者設定的限流上限】。
// TrafficShapingChecker performs checking according to current metrics and the traffic
// shaping strategy, then yield the token result.
type TrafficShapingChecker interface {
DoCheck(resStat base.StatNode, acquireCount uint32, threshold float64) *base.TokenResult
}
type RejectTrafficShapingChecker struct {
rule *Rule
}
func (d *RejectTrafficShapingChecker) DoCheck(resStat base.StatNode, acquireCount uint32, threshold float64) *base.TokenResult {
metricReadonlyStat := d.BoundOwner().boundStat.readOnlyMetric
if metricReadonlyStat == nil {
return nil
}
curCount := float64(metricReadonlyStat.GetSum(base.MetricEventPass))
if curCount+float64(acquireCount) > threshold {
return base.NewTokenResultBlockedWithCause(base.BlockTypeFlow, "", d.rule, curCount)
}
return nil
}
RejectTrafficShapingChecker 依據 Rule.Threshold 判定 Resource 在當前時間視窗是否超限,其限流結果 TokenResultStatus 只可能是 Pass 或者 Blocked。
sentinel flow 還有一個勻速限流 ThrottlingChecker,它的目的是讓請求勻速被執行,把一個時間視窗【譬如 1s】根據 threshold 再細分為更細的微時間視窗,在每個微時間視窗最多執行一次請求,其限流結果 TokenResultStatus 只可能是 Pass 或者 Blocked 或者 Wait,其相關意義分別為:
- Pass:在微時間視窗內無超限,請求通過;
- Wait:在微時間視窗內超限,被滯後若干時間視窗執行,在這段時間內請求需要等待;
- Blocked:在微時間視窗內超限,且等待時間超過使用者設定的最大願意等待時間長度【Rule.MaxQueueingTimeMs】,請求被拒絕。
type TrafficShapingController struct {
flowCalculator TrafficShapingCalculator
flowChecker TrafficShapingChecker
rule *Rule
// boundStat is the statistic of current TrafficShapingController
boundStat standaloneStatistic
}
func (t *TrafficShapingController) PerformChecking(acquireCount uint32, flag int32) *base.TokenResult {
allowedTokens := t.flowCalculator.CalculateAllowedTokens(acquireCount, flag)
return t.flowChecker.DoCheck(resStat, acquireCount, allowedTokens)
}
在 Direct + Reject 限流的場景下,這三個介面其實並無多大意義,其核心函式 TrafficShapingController.PerformChecking() 的主要流程是:
- 1 從 TrafficShapingController.boundStat 中獲取當前 Resource 的 metrics 值【curCount】;
- 2 如果 curCount + batchNum(acquireCount) > Rule.Threshold,則 pass,否則就 reject。
在限流場景下, TrafficShapingController 四個成員的意義如下:
- flowCalculator 計算限流上限;
- flowChecker 執行限流 Check 動作;
- rule 儲存限流規則;
- boundStat 儲存限流的 Check 結果和時間視窗引數,作為下次限流 Check 動作判定的依據。
1.4.2 TrafficControllerMap
在執行限流判定時,需要根據 Resource 名稱獲取其對應的 TrafficShapingController。
// TrafficControllerMap represents the map storage for TrafficShapingController.
type TrafficControllerMap map[string][]*TrafficShapingController
// core/flow/rule_manager.go
tcMap = make(TrafficControllerMap)
package 級別全域性私有變數 tcMap 儲存了所有的 Rule,其 key 為 Resource 名稱,value 則是與 Resource 對應的 TrafficShapingController。
使用者級別介面函式 core/flow/rule_manager.go:LoadRules() 會根據使用者定義的 Rule 構造其對應的 TrafficShapingController 存入 tcMap,這個介面呼叫函式 generateStatFor(*Rule) 構造 TrafficShapingController.boundStat。
限流場景下,函式 generateStatFor(*Rule) 的核心程式碼如下:
func generateStatFor(rule *Rule) (*standaloneStatistic, error) {
resNode = stat.GetOrCreateResourceNode(rule.Resource, base.ResTypeCommon)
// default case, use the resource's default statistic
readStat := resNode.DefaultMetric()
retStat.reuseResourceStat = true
retStat.readOnlyMetric = readStat
retStat.writeOnlyMetric = nil
return &retStat, nil
}
2 Metrics
Resource 的指標 Metrics 是進行 Rule 判定的基礎。
2.1 原子時間輪 AtomicBucketWrapArray
Sentinel 庫功能豐富,但無論是限流還是熔斷,其儲存基礎都是滑動時間視窗。其間包含了眾多優化:如無鎖定長時間輪。
滑動視窗實現有很多種,時間輪演算法是其中一種比較簡單的實現,在時間輪演算法之上可以實現多種限流方法。時間輪整體框圖如下:
1 BucketWrap
時間輪的最基本單元是一個桶【時間視窗】。
// BucketWrap represent a slot to record metrics
// In order to reduce the usage of memory, BucketWrap don't hold length of BucketWrap
// The length of BucketWrap could be seen in LeapArray.
// The scope of time is [startTime, startTime+bucketLength)
// The size of BucketWrap is 24(8+16) bytes
type BucketWrap struct {
// The start timestamp of this statistic bucket wrapper.
BucketStart uint64
// The actual data structure to record the metrics (e.g. MetricBucket).
Value atomic.Value
}
補充:這裡之所以用指標,是因為以 BucketWrap 為基礎的 AtomicBucketWrapArray 會被多個 sentinel 流控元件使用,每個元件的流控引數不一,例如:
- 1 core/circuitbreaker/circuit_breaker.go:slowRtCircuitBreaker 使用的 slowRequestLeapArray 的底層引數 slowRequestCounter
// core/circuitbreaker/circuit_breaker.go
type slowRequestCounter struct {
slowCount uint64
totalCount uint64
}
- 2 core/circuitbreaker/circuit_breaker.go:errorRatioCircuitBreaker 使用的 errorCounterLeapArray 的底層引數 errorCounter
// core/circuitbreaker/circuit_breaker.go
type errorCounter struct {
errorCount uint64
totalCount uint64
}
1.1 MetricBucket
BucketWrap 可以認作是一種 時間桶模板,具體的桶的實體是 MetricsBucket,其定義如下:
// MetricBucket represents the entity to record metrics per minimum time unit (i.e. the bucket time span).
// Note that all operations of the MetricBucket are required to be thread-safe.
type MetricBucket struct {
// Value of statistic
counter [base.MetricEventTotal]int64
minRt int64
}
MetricBucket 儲存了五種型別的 metric:
// There are five events to record
// pass + block == Total
const (
// sentinel rules check pass
MetricEventPass MetricEvent = iota
// sentinel rules check block
MetricEventBlock
MetricEventComplete
// Biz error, used for circuit breaker
MetricEventError
// request execute rt, unit is millisecond
MetricEventRt
// hack for the number of event
MetricEventTotal
)
2 AtomicBucketWrapArray
每個桶只記錄了其起始時間和 metric 值,至於每個桶的時間視窗長度這種公共值則統一記錄在 AtomicBucketWrapArray 內,AtomicBucketWrapArray 定義如下:
// atomic BucketWrap array to resolve race condition
// AtomicBucketWrapArray can not append or delete element after initializing
type AtomicBucketWrapArray struct {
// The base address for real data array
base unsafe.Pointer
// The length of slice(array), it can not be modified.
length int
data []*BucketWrap
}
AtomicBucketWrapArray.base 的值是 AtomicBucketWrapArray.data slice 的 data 區域的首指標。因為 AtomicBucketWrapArray.data 是一個固定長度的 slice,所以 AtomicBucketWrapArray.base 直接儲存資料記憶體區域的首地址,以加速訪問速度。
其次,AtomicBucketWrapArray.data 中儲存的是 BucketWrap 的指標,而不是 BucketWrap。
NewAtomicBucketWrapArrayWithTime() 函式會預熱一下,把所有的時間桶都生成出來。
2.2 時間輪
1 leapArray
// Give a diagram to illustrate
// Suppose current time is 888, bucketLengthInMs is 200ms,
// intervalInMs is 1000ms, LeapArray will build the below windows
// B0 B1 B2 B3 B4
// |_______|_______|_______|_______|_______|
// 1000 1200 1400 1600 800 (1000)
// ^
// time=888
type LeapArray struct {
bucketLengthInMs uint32
sampleCount uint32
intervalInMs uint32
array *AtomicBucketWrapArray
// update lock
updateLock mutex
}
LeapArray 各個成員解析:
- bucketLengthInMs 是漏桶長度,以毫秒為單位;
- sampleCount 則是時間漏桶個數;
- intervalInMs 是時間視窗長度,以毫秒為單位。
其註釋中的 ASCII 圖很好地解釋了每個欄位的含義。
LeapArray 核心函式是 LeapArray.currentBucketOfTime(),其作用是根據某個時間點獲取其做對應的時間桶 BucketWrap,程式碼如下:
func (la *LeapArray) currentBucketOfTime(now uint64, bg BucketGenerator) (*BucketWrap, error) {
if now <= 0 {
return nil, errors.New("Current time is less than 0.")
}
idx := la.calculateTimeIdx(now)
bucketStart := calculateStartTime(now, la.bucketLengthInMs)
for { //spin to get the current BucketWrap
old := la.array.get(idx)
if old == nil {
// because la.array.data had initiated when new la.array
// theoretically, here is not reachable
newWrap := &BucketWrap{
BucketStart: bucketStart,
Value: atomic.Value{},
}
newWrap.Value.Store(bg.NewEmptyBucket())
if la.array.compareAndSet(idx, nil, newWrap) {
return newWrap, nil
} else {
runtime.Gosched()
}
} else if bucketStart == atomic.LoadUint64(&old.BucketStart) {
return old, nil
} else if bucketStart > atomic.LoadUint64(&old.BucketStart) {
// current time has been next cycle of LeapArray and LeapArray dont't count in last cycle.
// reset BucketWrap
if la.updateLock.TryLock() {
old = bg.ResetBucketTo(old, bucketStart)
la.updateLock.Unlock()
return old, nil
} else {
runtime.Gosched()
}
} else if bucketStart < atomic.LoadUint64(&old.BucketStart) {
// TODO: reserve for some special case (e.g. when occupying "future" buckets).
return nil, errors.New(fmt.Sprintf("Provided time timeMillis=%d is already behind old.BucketStart=%d.", bucketStart, old.BucketStart))
}
}
}
其 for-loop 核心邏輯是:
- 1 獲取時間點對應的時間桶 old;
- 2 如果 old 為空,則新建一個時間桶,以原子操作的方式嘗試存入時間視窗的時間輪中,存入失敗則重新嘗試;
- 3 如果 old 就是當前時間點所在的時間桶,則返回;
- 4 如果 old 的時間起點小於當前時間,則通過樂觀鎖嘗試 reset 桶的起始時間等引數值,加鎖更新成功則返回;
- 5 如果 old 的時間起點大於當前時間,則系統發生了時間扭曲,返回錯誤。
2 BucketLeapArray
leapArray 實現了滑動時間視窗的所有主體,其對外使用介面則是 BucketLeapArray:
// The implementation of sliding window based on LeapArray (as the sliding window infrastructure)
// and MetricBucket (as the data type). The MetricBucket is used to record statistic
// metrics per minimum time unit (i.e. the bucket time span).
type BucketLeapArray struct {
data LeapArray
dataType string
}
從這個 struct 的註釋可見,其時間視窗 BucketWrap 的實體是 MetricBucket。
2.3 Metric 資料讀寫
SlidingWindowMetric
// SlidingWindowMetric represents the sliding window metric wrapper.
// It does not store any data and is the wrapper of BucketLeapArray to adapt to different internal bucket
// SlidingWindowMetric is used for SentinelRules and BucketLeapArray is used for monitor
// BucketLeapArray is per resource, and SlidingWindowMetric support only read operation.
type SlidingWindowMetric struct {
bucketLengthInMs uint32
sampleCount uint32
intervalInMs uint32
real *BucketLeapArray
}
SlidingWindowMetric 是對 BucketLeapArray 的一個封裝,只提供了只讀介面。
ResourceNode
type BaseStatNode struct {
sampleCount uint32
intervalMs uint32
goroutineNum int32
arr *sbase.BucketLeapArray
metric *sbase.SlidingWindowMetric
}
type ResourceNode struct {
BaseStatNode
resourceName string
resourceType base.ResourceType
}
// core/stat/node_storage.go
type ResourceNodeMap map[string]*ResourceNode
var (
inboundNode = NewResourceNode(base.TotalInBoundResourceName, base.ResTypeCommon)
resNodeMap = make(ResourceNodeMap)
rnsMux = new(sync.RWMutex)
)
BaseStatNode 對外提供了讀寫介面,其資料寫入 BaseStatNode.arr,讀取介面則依賴 BaseStatNode.metric。BaseStatNode.arr 是在 NewBaseStatNode() 中建立的,指標 SlidingWindowMetric.real 也指向它。
ResourceNode 則顧名思義,其代表了某資源和它的 Metrics 儲存 ResourceNode.BaseStatNode。
全域性變數 resNodeMap 儲存了所有資源的 Metrics 指標資料。
3 限流流程
本節只分析 Sentinel 庫提供的最基礎的流量整形功能 -- 限流,限流演算法多種多樣,可以使用其內建的演算法,使用者自己也可以進行擴充套件。
限流過程有三步步驟:
- 1 針對特定 Resource 構造其 EntryContext,儲存其 Metrics、限流開始時間等,Sentinel 稱之為 StatPrepareSlot;
- 2 依據 Resource 的限流演算法判定其是否應該進行限流,並給出限流判定結果,Sentinel 稱之為 RuleCheckSlot;補充:這個限流演算法是一系列判斷方法的合集(SlotChain);
- 3 判定之後,除了使用者自身根據判定結果執行相應的 action,Sentinel 也需要根據判定結果執行自身的 Action,以及把整個判定流程所使用的的時間 RT 等指標儲存下來,Sentinel 稱之為 StatSlot。
整體流程如下圖所示:
3.1 Slot
針對 Check 三個步驟,有三個對應的 Slot 分別定義如下:
// StatPrepareSlot is responsible for some preparation before statistic
// For example: init structure and so on
type StatPrepareSlot interface {
// Prepare function do some initialization
// Such as: init statistic structure、node and etc
// The result of preparing would store in EntryContext
// All StatPrepareSlots execute in sequence
// Prepare function should not throw panic.
Prepare(ctx *EntryContext)
}
// RuleCheckSlot is rule based checking strategy
// All checking rule must implement this interface.
type RuleCheckSlot interface {
// Check function do some validation
// It can break off the slot pipeline
// Each TokenResult will return check result
// The upper logic will control pipeline according to SlotResult.
Check(ctx *EntryContext) *TokenResult
}
// StatSlot is responsible for counting all custom biz metrics.
// StatSlot would not handle any panic, and pass up all panic to slot chain
type StatSlot interface {
// OnEntryPass function will be invoked when StatPrepareSlots and RuleCheckSlots execute pass
// StatSlots will do some statistic logic, such as QPS、log、etc
OnEntryPassed(ctx *EntryContext)
// OnEntryBlocked function will be invoked when StatPrepareSlots and RuleCheckSlots fail to execute
// It may be inbound flow control or outbound cir
// StatSlots will do some statistic logic, such as QPS、log、etc
// blockError introduce the block detail
OnEntryBlocked(ctx *EntryContext, blockError *BlockError)
// OnCompleted function will be invoked when chain exits.
// The semantics of OnCompleted is the entry passed and completed
// Note: blocked entry will not call this function
OnCompleted(ctx *EntryContext)
}
拋卻 Prepare 和 Stat,可以簡單的認為:所謂的 slot,就是 sentinel 提供的某個流控元件。
值得注意的是,根據註釋 StatSlot.OnCompleted 只有在 RuleCheckSlot.Check 通過才會執行,用於計算從請求開始到結束所使用的 RT 等 Metrics。
3.2 Prepare
// core/base/slot_chain.go
// StatPrepareSlot is responsible for some preparation before statistic
// For example: init structure and so on
type StatPrepareSlot interface {
// Prepare function do some initialization
// Such as: init statistic structure、node and etc
// The result of preparing would store in EntryContext
// All StatPrepareSlots execute in sequence
// Prepare function should not throw panic.
Prepare(ctx *EntryContext)
}
// core/stat/stat_prepare_slot.go
type ResourceNodePrepareSlot struct {
}
func (s *ResourceNodePrepareSlot) Prepare(ctx *base.EntryContext) {
node := GetOrCreateResourceNode(ctx.Resource.Name(), ctx.Resource.Classification())
// Set the resource node to the context.
ctx.StatNode = node
}
如前面解釋,Prepare 主要是構造儲存 Resource Metrics 所使用的 ResourceNode。所有 Resource 的 StatNode 都會儲存在 package 級別的全域性變數 core/stat/node_storage.go:resNodeMap [type: map[string]*ResourceNode] 中,函式 GetOrCreateResourceNode 用於根據 Resource Name 從 resNodeMap 中獲取其對應的 StatNode,如果不存在則建立一個 StatNode 並存入 resNodeMap。
3.3 Check
RuleCheckSlot.Check() 執行流程:
- 1 根據 Resource 名稱獲取其所有的 Rule 集合;
- 2 遍歷 Rule 集合,對 Resource 依次執行 Check,任何一個 Rule 判定 Resource 需要進行限流【Blocked】則返回,否則放行。
type Slot struct {
}
func (s *Slot) Check(ctx *base.EntryContext) *base.TokenResult {
res := ctx.Resource.Name()
tcs := getTrafficControllerListFor(res)
result := ctx.RuleCheckResult
// Check rules in order
for _, tc := range tcs {
r := canPassCheck(tc, ctx.StatNode, ctx.Input.AcquireCount)
if r == nil {
// nil means pass
continue
}
if r.Status() == base.ResultStatusBlocked {
return r
}
if r.Status() == base.ResultStatusShouldWait {
if waitMs := r.WaitMs(); waitMs > 0 {
// Handle waiting action.
time.Sleep(time.Duration(waitMs) * time.Millisecond)
}
continue
}
}
return result
}
func canPassCheck(tc *TrafficShapingController, node base.StatNode, acquireCount uint32) *base.TokenResult {
return canPassCheckWithFlag(tc, node, acquireCount, 0)
}
func canPassCheckWithFlag(tc *TrafficShapingController, node base.StatNode, acquireCount uint32, flag int32) *base.TokenResult {
return checkInLocal(tc, node, acquireCount, flag)
}
func checkInLocal(tc *TrafficShapingController, resStat base.StatNode, acquireCount uint32, flag int32) *base.TokenResult {
return tc.PerformChecking(resStat, acquireCount, flag)
}
3.4 Exit
sentinel 對 Resource 進行 Check 後,其後續邏輯執行順序是:
- 1 如果 RuleCheckSlot.Check() 判定 pass 通過則執行 StatSlot.OnEntryPassed(),否則 RuleCheckSlot.Check() 判定 reject 則執行 StatSlot.OnEntryBlocked();
- 2 如果 RuleCheckSlot.Check() 判定 pass 通過,則執行本次 Action;
- 3 如果 RuleCheckSlot.Check() 判定 pass 通過,則執行 SentinelEntry.Exit() --> SlotChain.ext() --> StatSlot.OnCompleted() 。
第三步驟的呼叫鏈路如下:
StatSlot.OnCompleted()
// core/flow/standalone_stat_slot.go
type StandaloneStatSlot struct {
}
func (s StandaloneStatSlot) OnEntryPassed(ctx *base.EntryContext) {
res := ctx.Resource.Name()
for _, tc := range getTrafficControllerListFor(res) {
if !tc.boundStat.reuseResourceStat {
if tc.boundStat.writeOnlyMetric != nil {
tc.boundStat.writeOnlyMetric.AddCount(base.MetricEventPass, int64(ctx.Input.AcquireCount))
}
}
}
}
func (s StandaloneStatSlot) OnEntryBlocked(ctx *base.EntryContext, blockError *base.BlockError) {
// Do nothing
}
func (s StandaloneStatSlot) OnCompleted(ctx *base.EntryContext) {
// Do nothing
}
SlotChain.exit()
// core/base/slot_chain.go
type SlotChain struct {
}
func (sc *SlotChain) exit(ctx *EntryContext) {
// The OnCompleted is called only when entry passed
if ctx.IsBlocked() {
return
}
for _, s := range sc.stats {
s.OnCompleted(ctx)
}
}
SentinelEntry.Exit()
// core/base/entry.go
type SentinelEntry struct {
sc *SlotChain
exitCtl sync.Once
}
func (e *SentinelEntry) Exit() {
e.exitCtl.Do(func() {
if e.sc != nil {
e.sc.exit(ctx)
}
})
}
從上面執行可見,StatSlot.OnCompleted() 是在 Action 【如一次 RPC 的請求-響應 Invokation】完成之後呼叫的。如果有的元件需要計算一次 Action 的時間耗費 RT,就在其對應的 StatSlot.OnCompleted() 中依據 EntryContext.startTime 完成時間耗費計算。
3.5 SlotChain
Sentinel 本質是一個流控包,不僅提供了限流功能,還提供了眾多其他諸如自適應流量保護、熔斷降級、冷啟動、全域性流量 Metrics 結果等功能流控元件,Sentinel-Go 包定義了一個 SlotChain 實體儲存其所有的流控元件。
// core/base/slot_chain.go
// SlotChain hold all system slots and customized slot.
// SlotChain support plug-in slots developed by developer.
type SlotChain struct {
statPres []StatPrepareSlot
ruleChecks []RuleCheckSlot
stats []StatSlot
}
// The entrance of slot chain
// Return the TokenResult and nil if internal panic.
func (sc *SlotChain) Entry(ctx *EntryContext) *TokenResult {
// execute prepare slot
sps := sc.statPres
if len(sps) > 0 {
for _, s := range sps {
s.Prepare(ctx)
}
}
// execute rule based checking slot
rcs := sc.ruleChecks
var ruleCheckRet *TokenResult
if len(rcs) > 0 {
for _, s := range rcs {
sr := s.Check(ctx)
if sr == nil {
// nil equals to check pass
continue
}
// check slot result
if sr.IsBlocked() {
ruleCheckRet = sr
break
}
}
}
if ruleCheckRet == nil {
ctx.RuleCheckResult.ResetToPass()
} else {
ctx.RuleCheckResult = ruleCheckRet
}
// execute statistic slot
ss := sc.stats
ruleCheckRet = ctx.RuleCheckResult
if len(ss) > 0 {
for _, s := range ss {
// indicate the result of rule based checking slot.
if !ruleCheckRet.IsBlocked() {
s.OnEntryPassed(ctx)
} else {
// The block error should not be nil.
s.OnEntryBlocked(ctx, ruleCheckRet.blockErr)
}
}
}
return ruleCheckRet
}
func (sc *SlotChain) exit(ctx *EntryContext) {
if ctx == nil || ctx.Entry() == nil {
logging.Error(errors.New("nil EntryContext or SentinelEntry"), "")
return
}
// The OnCompleted is called only when entry passed
if ctx.IsBlocked() {
return
}
for _, s := range sc.stats {
s.OnCompleted(ctx)
}
// relieve the context here
}
建議:Sentinel 包針對某個 Resource 無法確知其使用了那個元件,在執行時會針對某個 Resource 的 EntryContext 依次執行所有的元件的 Rule。Sentinel-golang 為何不給使用者相關使用者提供一個介面讓其設定使用的流控元件集合,以減少下面函式 SlotChain.Entry() 中執行 RuleCheckSlot.Check() 執行次數?相關改進已經提交到 pr 264【補充,程式碼已合併,據負責人壓測後回覆 sentinel-go 效率整體提升 15%】。
globalSlotChain
Sentinel-Go 定義了一個 SlotChain 的 package 級別的全域性私有變數 globalSlotChain 用於儲存其所有的流控元件物件。相關程式碼示例如下。因本文只關注限流元件,所以下面只給出了限流元件的註冊程式碼。
// api/slot_chain.go
func BuildDefaultSlotChain() *base.SlotChain {
sc := base.NewSlotChain()
sc.AddStatPrepareSlotLast(&stat.ResourceNodePrepareSlot{})
sc.AddRuleCheckSlotLast(&flow.Slot{})
sc.AddStatSlotLast(&flow.StandaloneStatSlot{})
return sc
}
var globalSlotChain = BuildDefaultSlotChain()
Entry
在 Sentinel-Go 對外的最重要的入口函式 api/api.go:Entry() 中,globalSlotChain 會作為 EntryOptions 的 SlotChain 引數被使用。
// api/api.go
// Entry is the basic API of Sentinel.
func Entry(resource string, opts ...EntryOption) (*base.SentinelEntry, *base.BlockError) {
options := entryOptsPool.Get().(*EntryOptions)
options.slotChain = globalSlotChain
return entry(resource, options)
}
Sentinel 的演進離不開社群的貢獻。Sentinel Go 1.0 GA 版本即將在近期釋出,帶來更多雲原生相關的特性。我們非常歡迎感興趣的開發者參與貢獻,一起來主導未來版本的演進。我們鼓勵任何形式的貢獻,包括但不限於:
• bug fix
• new features/improvements
• dashboard
• document/website
• test cases
作者簡介
於雨(github @AlexStocks),apache/dubbo-go 專案負責人,一個有十多年服務端基礎架構研發一線工作經驗的程式設計師,目前在螞蟻金服可信原生部從事容器編排和 service mesh 工作。熱愛開源,從 2015 年給 Redis 貢獻程式碼開始,陸續改進過 Muduo/Pika/Dubbo/Dubbo-go 等知名專案。
本文為阿里雲原創內容,未經允許不得轉載。
相關文章
- 阿里 雙11 同款,流量防衛兵 Sentinel go 原始碼解讀阿里Go原始碼
- Spring Cloud Alibaba | Sentinel: 分散式系統的流量防衛兵初探SpringCloud分散式
- 阿里 雙11 同款流控降級元件 Sentinel Go 正式 GA,助力雲原生服務穩穩穩阿里元件Go
- ?【Alibaba中介軟體技術系列】「Sentinel技術專題」分散式系統的流量防衛兵的基本介紹(入門原始碼介紹)分散式原始碼
- Sentinel Go 0.4.0 釋出,支援熱點流量防護能力Go
- 阿里雲 MSE 支援 Go 語言流量防護阿里Go
- go中panic原始碼解讀Go原始碼
- go中errgroup原始碼解讀Go原始碼
- Sentinel-Go 原始碼系列(一)|開篇Go原始碼
- CRIWARE TechSummit 《十三機兵防衛圈》部分採訪整理MIT
- go中waitGroup原始碼解讀GoAI原始碼
- go中sync.Mutex原始碼解讀GoMutex原始碼
- go 中 sort 如何排序,原始碼解讀Go排序原始碼
- GCD原始碼分析之再解 sentinelGC原始碼
- go中semaphore(訊號量)原始碼解讀Go原始碼
- 從《十三機兵防衛圈》看遊戲的群像敘事設計遊戲
- 《十三機兵防衛圈》:青春群像劇外皮下的硬科幻核心
- sentinel流量控制和熔斷降級執行流程之原始碼分析原始碼
- go 中 select 原始碼閱讀Go原始碼
- PostgreSQL 原始碼解讀(3)- 如何閱讀原始碼SQL原始碼
- 基於《十三機兵防衛圈》的音訊整合設計理念及工程分享音訊
- WeakHashMap,原始碼解讀HashMap原始碼
- Handler原始碼解讀原始碼
- Laravel 原始碼解讀Laravel原始碼
- Swoft 原始碼解讀原始碼
- SDWebImage原始碼解讀Web原始碼
- MJExtension原始碼解讀原始碼
- Masonry原始碼解讀原始碼
- HashMap原始碼解讀HashMap原始碼
- Redux原始碼解讀Redux原始碼
- require() 原始碼解讀UI原始碼
- ZooKeeper原始碼解讀原始碼
- FairyGUI原始碼解讀AIGUI原始碼
- SpringCloudAlibaba分散式流量控制元件Sentinel實戰與原始碼分析-中SpringGCCloud分散式控制元件原始碼
- SpringCloudAlibaba分散式流量控制元件Sentinel實戰與原始碼分析(上)SpringGCCloud分散式控制元件原始碼
- 原始碼防洩密解決之道原始碼
- Sentinel基本使用與原始碼分析原始碼
- 【C++】【原始碼解讀】std::is_same函式原始碼解讀C++原始碼函式