在以前的文章中已經介紹過Seata的整體介紹,如何使用以及Seata-Server的原理分析,有興趣的能夠閱讀下面的文章:spring
這篇文章會介紹Seata中另外兩個重要的角色TM
(事務管理器)和RM
(資源管理器),首先仍是來看看下面這張圖:sql
上一個文章對於TC
的原理已經作了詳細介紹,對於TM和RM咱們看見在圖中都是屬於client
的角色,他們分別的功能以下:數據庫
TM
(事務管理器):用來控制整個分佈式事務的管理,發起全局事務的Begin/Commit/Rollback
。RM(資源管理器)
:用來註冊本身的分支事務,接受TC
的Commit
或者Rollback
請求.首先咱們來介紹一些Seata-client
中Spring
模塊,Seata
經過這個模塊對本身的TM
和RM
進行初始化以及掃描AT模式和TCC模式的註解並初始化這些模式須要的資源。 在Seata
的項目中有一個spring
模塊,裏面包含了咱們和spring
相關的邏輯,GlobalTransactionScanner
是其中的核心類:mybatis
public class GlobalTransactionScanner extends AbstractAutoProxyCreator implements InitializingBean,ApplicationContextAware, DisposableBean
上面代碼是類的定義,首先它繼承了AbstractAutoProxyCreator
實現了wrapIfNecessary
方法實現咱們的方法的切面代理,實現了InitializingBean
接口用於初始化咱們的客戶端,實現了ApplicationContextAware
用於保存咱們的spring
容器,實現了DisposableBean
用於優雅關閉。app
首先來看繼承AbstractAutoProxyCreator實現的wrapIfNecessary框架
protected Object wrapIfNecessary(Object bean, String beanName, Object cacheKey) { if (PROXYED_SET.contains(beanName)) { return bean; } interceptor = null; //check TCC proxy if (TCCBeanParserUtils.isTccAutoProxy(bean, beanName, applicationContext)) { //TCC interceptor, proxy bean of sofa:reference/dubbo:reference, and LocalTCC interceptor = new TccActionInterceptor(TCCBeanParserUtils.getRemotingDesc(beanName)); } else { Class<?> serviceInterface = SpringProxyUtils.findTargetClass(bean); Class<?>[] interfacesIfJdk = SpringProxyUtils.findInterfaces(bean); if (!existsAnnotation(new Class[]{serviceInterface}) && !existsAnnotation(interfacesIfJdk)) { return bean; } if (interceptor == null) { interceptor = new GlobalTransactionalInterceptor(failureHandlerHook); } } if (!AopUtils.isAopProxy(bean)) { bean = super.wrapIfNecessary(bean, beanName, cacheKey); } else { AdvisedSupport advised = SpringProxyUtils.getAdvisedSupport(bean); Advisor[] advisor = buildAdvisors(beanName, getAdvicesAndAdvisorsForBean(null, null, null)); for (Advisor avr : advisor) { advised.addAdvisor(0, avr); } } PROXYED_SET.add(beanName); return bean; }
beanName
是否已經處理過 若是處理過本次就不處理。Inteceptor
,這裏有三種狀況第一個TCC
,第二個是全局事務管理TM的攔截器,第三個是沒有註解,若是沒有那麼直接返回便可。interceptor
添加進入當前Bean
。而後再看從InitializingBean
中實現的afterPropertiesSet
,也就是對Seata
的初始化:異步
public void afterPropertiesSet() { initClient(); } private void initClient() { //init TM TMClient.init(applicationId, txServiceGroup); //init RM RMClient.init(applicationId, txServiceGroup); registerSpringShutdownHook(); } private void registerSpringShutdownHook() { if (applicationContext instanceof ConfigurableApplicationContext) { ((ConfigurableApplicationContext) applicationContext).registerShutdownHook(); ShutdownHook.removeRuntimeShutdownHook(); } ShutdownHook.getInstance().addDisposable(TmRpcClient.getInstance(applicationId, txServiceGroup)); ShutdownHook.getInstance().addDisposable(RmRpcClient.getInstance(applicationId, txServiceGroup)); }
上面的代碼邏輯比較清楚:async
TM
客戶端,這裏會向Server
註冊該TM
。RM
客戶端,這裏會向Server註冊該RM
。ShutdownHook
,後續將TM
和RM
優雅關閉。注意這裏初始化的時候會初始化兩個客戶端,分別是TM
客戶端和RM
客戶端,不少人認爲TM
和RM
是用的同一個客戶端,這裏須要注意一下。分佈式
再上面的第一部分邏輯中咱們看到咱們有兩個業務核心Interceptor
,一個是GlobalTransactionalInterceptor
用來處理全局事務的管理(開啓,提交,回滾),另一個是TccActionInterceptor
用來處理TCC模式。熟悉Seata的朋友會問AT模式呢,爲何只有TCC模式,這裏AT模式表明着就是自動處理事務,咱們不須要有切面ide
首先來看看GlobalTransactionalInterceptor#invoke:
public Object invoke(final MethodInvocation methodInvocation) throws Throwable { Class<?> targetClass = (methodInvocation.getThis() != null ? AopUtils.getTargetClass(methodInvocation.getThis()) : null); Method specificMethod = ClassUtils.getMostSpecificMethod(methodInvocation.getMethod(), targetClass); final Method method = BridgeMethodResolver.findBridgedMethod(specificMethod); final GlobalTransactional globalTransactionalAnnotation = getAnnotation(method, GlobalTransactional.class); final GlobalLock globalLockAnnotation = getAnnotation(method, GlobalLock.class); if (globalTransactionalAnnotation != null) { return handleGlobalTransaction(methodInvocation, globalTransactionalAnnotation); } else if (globalLockAnnotation != null) { return handleGlobalLock(methodInvocation); } else { return methodInvocation.proceed(); } }
Method
Method
中的註解@GlobalTransactional
註解執行handleGlobalTransaction切面邏輯,這個也是咱們全局事務的邏輯。@GlobalLock
註解,則執行handleGlobalLock切面邏輯,這個註解是用於一些非AT模式的數據庫加鎖,加上這個註解以後再執行Sql語句以前會查詢對應的數據是否加鎖,可是他不會加入全局事務。handleGlobalTransaction
邏輯以下:
private Object handleGlobalTransaction(final MethodInvocation methodInvocation, final GlobalTransactional globalTrxAnno) throws Throwable { return transactionalTemplate.execute(new TransactionalExecutor() { @Override public Object execute() throws Throwable { return methodInvocation.proceed(); } }); } TransactionalTemplate#execute public Object execute(TransactionalExecutor business) throws Throwable { // 1. get or create a transaction GlobalTransaction tx = GlobalTransactionContext.getCurrentOrCreate(); // 1.1 get transactionInfo TransactionInfo txInfo = business.getTransactionInfo(); if (txInfo == null) { throw new ShouldNeverHappenException("transactionInfo does not exist"); } try { // 2. begin transaction beginTransaction(txInfo, tx); Object rs = null; try { // Do Your Business rs = business.execute(); } catch (Throwable ex) { // 3.the needed business exception to rollback. completeTransactionAfterThrowing(txInfo,tx,ex); throw ex; } // 4. everything is fine, commit. commitTransaction(tx); return rs; } finally { //5. clear triggerAfterCompletion(); cleanUp(); } }
在handleGlobalTransaction
中將具體的實現交給了TransactionalTemplate#execute
去作了,其中具體的步驟以下:
TccActionInterceptor
咱們先看看TccActionInterceptor是如何使用:
@TwoPhaseBusinessAction(name = "TccActionOne" , commitMethod = "commit", rollbackMethod = "rollback") public boolean prepare(BusinessActionContext actionContext, int a); public boolean commit(BusinessActionContext actionContext); public boolean rollback(BusinessActionContext actionContext);
通常來講會定義三個方法一個是階段的try方法,另一個是二階段的commit和rollback,每一個方法的第一個參數是咱們事務上下文,這裏咱們不須要關心他在咱們切面中會自行填充處理。
接下來咱們再看看TCC相關的攔截器是如何處理的:
public Object invoke(final MethodInvocation invocation) throws Throwable { Method method = getActionInterfaceMethod(invocation); TwoPhaseBusinessAction businessAction = method.getAnnotation(TwoPhaseBusinessAction.class); //try method if(businessAction != null) { if(StringUtils.isBlank(RootContext.getXID())){ //not in distribute transaction return invocation.proceed(); } Object[] methodArgs = invocation.getArguments(); //Handler the TCC Aspect Map<String, Object> ret = actionInterceptorHandler.proceed(method, methodArgs, businessAction, new Callback<Object>(){ @Override public Object execute() throws Throwable { return invocation.proceed(); } }); //return the final result return ret.get(Constants.TCC_METHOD_RESULT); } return invocation.proceed(); }
Method
。GlobalTransactionalInterceptor
。若是再也不直接執行便可。TCC
切面,核心邏輯在actionInterceptorHandler#proceed
中。再來看看actionInterceptorHandler#proceed
這個方法:
public Map<String, Object> proceed(Method method, Object[] arguments, TwoPhaseBusinessAction businessAction, Callback<Object> targetCallback) throws Throwable { Map<String, Object> ret = new HashMap<String, Object>(16); //TCC name String actionName = businessAction.name(); String xid = RootContext.getXID(); BusinessActionContext actionContext = new BusinessActionContext(); actionContext.setXid(xid); //set action anme actionContext.setActionName(actionName) //Creating Branch Record String branchId = doTccActionLogStore(method, arguments, businessAction, actionContext); actionContext.setBranchId(branchId); //set the parameter whose type is BusinessActionContext Class<?>[] types = method.getParameterTypes(); int argIndex = 0; for (Class<?> cls : types) { if (cls.getName().equals(BusinessActionContext.class.getName())) { arguments[argIndex] = actionContext; break; } argIndex++; } //the final parameters of the try method ret.put(Constants.TCC_METHOD_ARGUMENTS, arguments); //the final result ret.put(Constants.TCC_METHOD_RESULT, targetCallback.execute()); return ret; }
TCC
名字,本次事務XID
等。Branch
事務,一個是在本地的context
上下文中將它的commit
和rollback
信息保存起來,另外一個是向咱們的Seata-Server
註冊分支事務,用於後續的管理。BusinessActionContext
。Spring的幾個總要的內容已經剖析完畢,核心類主要是三個,一個Scanner
,兩個Interceptor
。總體來講比較簡單,Spring作的基本上也是咱們客戶端一些初始化的事,接下來咱們深刻了解一下TM這個角色。
在上面章節中咱們講了GlobalTransactionalInterceptor
這個切面攔截器,咱們知道了這個攔截器中作了咱們TM應該作的事,事務的開啓,事務的提交,事務的回滾。這裏只是咱們總體邏輯的發起點,其中具體的客戶端邏輯在咱們的DefaultTransactionManager中,這個類中的代碼以下所示:
public class DefaultTransactionManager implements TransactionManager { @Override public String begin(String applicationId, String transactionServiceGroup, String name, int timeout) throws TransactionException { GlobalBeginRequest request = new GlobalBeginRequest(); request.setTransactionName(name); request.setTimeout(timeout); GlobalBeginResponse response = (GlobalBeginResponse)syncCall(request); return response.getXid(); } @Override public GlobalStatus commit(String xid) throws TransactionException { GlobalCommitRequest globalCommit = new GlobalCommitRequest(); globalCommit.setXid(xid); GlobalCommitResponse response = (GlobalCommitResponse)syncCall(globalCommit); return response.getGlobalStatus(); } @Override public GlobalStatus rollback(String xid) throws TransactionException { GlobalRollbackRequest globalRollback = new GlobalRollbackRequest(); globalRollback.setXid(xid); GlobalRollbackResponse response = (GlobalRollbackResponse)syncCall(globalRollback); return response.getGlobalStatus(); } @Override public GlobalStatus getStatus(String xid) throws TransactionException { GlobalStatusRequest queryGlobalStatus = new GlobalStatusRequest(); queryGlobalStatus.setXid(xid); GlobalStatusResponse response = (GlobalStatusResponse)syncCall(queryGlobalStatus); return response.getGlobalStatus(); } private AbstractTransactionResponse syncCall(AbstractTransactionRequest request) throws TransactionException { try { return (AbstractTransactionResponse)TmRpcClient.getInstance().sendMsgWithResponse(request); } catch (TimeoutException toe) { throw new TransactionException(TransactionExceptionCode.IO, toe); } } }
在DefaultTransactionManager
中總體邏輯比較簡單有四個方法:
begin
:向Server
發起GlobalBeginRequest
請求,用於開啓全局事務。commit
:向Server
發起GlobalCommitRequest
請求,用於提交全局事務。rollback
:向Server
發起GlobalRollbackRequest
請求,用於回滾全局事務。getStatus
:向Server
發起GlobalStatusRequest
請求,用於查詢全局事務狀態信息。在Seata
中目前管理RM
有兩種模式:一種是AT
模式,須要事務性數據庫支持,會自動記錄修改前快照和修改後的快照,用於提交和回滾;還有一種是TCC
模式,也能夠看做是MT
模式,用於AT模式不支持的狀況,手動進行提交和回滾。接下來將會深刻剖析一下這兩種模式的實現原理。
AT
模式下須要使用Seata
提供的數據源代理,其總體實現邏輯以下圖所示:
在咱們的程序中執行一個sql
語句,不管你是使用mybatis
,仍是直接使用jdbcTemplate
,都會遵循下面的步驟:
Statement
。sql
語句因此咱們能夠將DataSource
,Connection
,Statement
代理起來而後執行咱們的一些特殊的邏輯,完成咱們的AT模式。
在DataSourceProxy中沒有太多的業務邏輯,只是簡單的將獲取Connection
用咱們的ConnectionProxy
代理類進行了封裝,代碼以下:
public ConnectionProxy getConnection() throws SQLException { Connection targetConnection = targetDataSource.getConnection(); return new ConnectionProxy(this, targetConnection); }
首先經過咱們代理以前的DataSource
獲取鏈接,而後用ConnectionProxy
將其代理起來。
ConnectionProxy
主要作三件事,第一個是生成代理的Statement
,第二個是保存咱們的鏈接上下文:加鎖的Key,undoLog等,第三個是代理執行咱們的本地事務的commit
和rollback
。
首先來看看代理生成的Statement
:
@Override public Statement createStatement() throws SQLException { Statement targetStatement = getTargetConnection().createStatement(); return new StatementProxy(this, targetStatement); } @Override public PreparedStatement prepareStatement(String sql) throws SQLException { PreparedStatement targetPreparedStatement = getTargetConnection().prepareStatement(sql); return new PreparedStatementProxy(this, targetPreparedStatement, sql); }
這裏也是經過咱們原來的鏈接直接生成Statement
,而後將其進行代理。
接下來看看對咱們上下文的管理,你們都知道咱們的一個事務其實對應的是一個數據庫鏈接,在這個事務中的全部sql
的undolog
和lockKey
都會在鏈接的上下文中記錄。以下面代碼所示:
/** * append sqlUndoLog * * @param sqlUndoLog the sql undo log */ public void appendUndoLog(SQLUndoLog sqlUndoLog) { context.appendUndoItem(sqlUndoLog); } /** * append lockKey * * @param lockKey the lock key */ public void appendLockKey(String lockKey) { context.appendLockKey(lockKey); }
這裏的代碼很簡單,lockKey
和undolog
都是用list
保存,直接add
便可。
當咱們的本地事務完成的時候,須要調用Connection
的commit
或rollback
來進行事務的提交或回滾。這裏咱們也須要代理這兩個方法來完成咱們對分支事務的處理,先來看看commit
方法。
public void commit() throws SQLException { if (context.inGlobalTransaction()) { processGlobalTransactionCommit(); } else if (context.isGlobalLockRequire()) { processLocalCommitWithGlobalLocks(); } else { targetConnection.commit(); } } private void processGlobalTransactionCommit() throws SQLException { try { register(); } catch (TransactionException e) { recognizeLockKeyConflictException(e); } try { if (context.hasUndoLog()) { UndoLogManager.flushUndoLogs(this); } targetConnection.commit(); } catch (Throwable ex) { report(false); if (ex instanceof SQLException) { throw new SQLException(ex); } } report(true); context.reset(); }
context
是否再全局事務中,若是在則進行提交,到Step2。context
中有undolog
,那麼將Unlog
刷至數據庫。上面介紹了提交事務的流程,當context
在全局鎖的流程中,會進行全局鎖的查詢,這裏比較簡單就不作贅述,若是context
都沒有在上述的狀況中那麼會直接進行事務提交。
對於咱們rollback
來講代碼比較簡單:
public void rollback() throws SQLException { targetConnection.rollback(); if (context.inGlobalTransaction()) { if (context.isBranchRegistered()) { report(false); } } context.reset(); }
細心的小夥伴可能發現若是咱們的本地事務提交或者回滾以後失敗,那咱們的分佈式事務運行結果還能正確嗎?這裏徹底不用擔憂,再咱們的服務端有完善的超時檢測,重試等機制,來幫助咱們應對這些特殊狀況。
咱們通常用statement
會調用executeXXX
方法來執行咱們的sql
語句,因此在咱們的Proxy
中能夠利用這個方法,再執行sql
的時候作一些咱們須要作的邏輯,下面看看execute
方法的代碼:
public boolean execute(String sql) throws SQLException { this.targetSQL = sql; return ExecuteTemplate.execute(this, new StatementCallback<Boolean, T>() { @Override public Boolean execute(T statement, Object... args) throws SQLException { return statement.execute((String) args[0]); } }, sql); }
這裏直接將邏輯交給咱們的ExecuteTemplate
去執行,有以下代碼:
public static <T, S extends Statement> T execute(SQLRecognizer sqlRecognizer, StatementProxy<S> statementProxy, StatementCallback<T, S> statementCallback, Object... args) throws SQLException { if (!RootContext.inGlobalTransaction() && !RootContext.requireGlobalLock()) { // Just work as original statement return statementCallback.execute(statementProxy.getTargetStatement(), args); } if (sqlRecognizer == null) { sqlRecognizer = SQLVisitorFactory.get( statementProxy.getTargetSQL(), statementProxy.getConnectionProxy().getDbType()); } Executor<T> executor = null; if (sqlRecognizer == null) { executor = new PlainExecutor<T, S>(statementProxy, statementCallback); } else { switch (sqlRecognizer.getSQLType()) { case INSERT: executor = new InsertExecutor<T, S>(statementProxy, statementCallback, sqlRecognizer); break; case UPDATE: executor = new UpdateExecutor<T, S>(statementProxy, statementCallback, sqlRecognizer); break; case DELETE: executor = new DeleteExecutor<T, S>(statementProxy, statementCallback, sqlRecognizer); break; case SELECT_FOR_UPDATE: executor = new SelectForUpdateExecutor<T, S>(statementProxy, statementCallback, sqlRecognizer); break; default: executor = new PlainExecutor<T, S>(statementProxy, statementCallback); break; } } T rs = null; try { rs = executor.execute(args); } catch (Throwable ex) { if (!(ex instanceof SQLException)) { // Turn other exception into SQLException ex = new SQLException(ex); } throw (SQLException)ex; } return rs; } }
這裏是咱們代理執行sql
的核心邏輯,步驟以下:
Statement
。sql
識別器,那麼咱們須要生成sql
識別器,這裏咱們會借用Druid中對sql
的解析,咱們獲取sql
的識別器,咱們經過這個識別器能夠獲取到不一樣類型的sql
語句的一些條件,好比說SQLUpdateRecognizer
是用於update
的sql
識別器,咱們能夠直接獲取到表名,條件語句,更新的字段,更新字段的值等。sql
識別器的類型,來生成咱們不一樣類型的執行器。這裏有五種Executor
:INSERT,UPDATE,DELETE
的執行器會進行undolog記錄而且記錄全局鎖,SELECT_FOR_UPDATE
只會進行查詢全局鎖,有一個默認的表明咱們如今還不支持,什麼都不會作直接執行咱們的sql
語句。
對於INSERT,UPDATE,DELETE的執行器會繼承咱們的AbstractDMLBaseExecutor
:
protected T executeAutoCommitFalse(Object[] args) throws Throwable { TableRecords beforeImage = beforeImage(); T result = statementCallback.execute(statementProxy.getTargetStatement(), args); TableRecords afterImage = afterImage(beforeImage); prepareUndoLog(beforeImage, afterImage); return result; } protected abstract TableRecords beforeImage() throws SQLException; protected abstract TableRecords afterImage(TableRecords beforeImage) throws SQLException;
在AbstractDMLBaseExecutor
中執行邏輯在executeAutoCommitFalse
這個方法,步驟以下:
sql
以前所受影響行的快照,這裏beforeImage
會被不一樣類型的sql語句從新實現。sql
語句,並獲取結果。sql
以後的快照,這裏的afterIamge
也會被不一樣類型的sql語句從新實現。undolog
準備好,這裏會保存到咱們的ConnectionContext
中。protected void prepareUndoLog(TableRecords beforeImage, TableRecords afterImage) throws SQLException { if (beforeImage.getRows().size() == 0 && afterImage.getRows().size() == 0) { return; } ConnectionProxy connectionProxy = statementProxy.getConnectionProxy(); TableRecords lockKeyRecords = sqlRecognizer.getSQLType() == SQLType.DELETE ? beforeImage : afterImage; String lockKeys = buildLockKey(lockKeyRecords); connectionProxy.appendLockKey(lockKeys); SQLUndoLog sqlUndoLog = buildUndoItem(beforeImage, afterImage); connectionProxy.appendUndoLog(sqlUndoLog); }
準備UndoLog
的時候會獲取咱們的ConnectionProxy
,將咱們的Undolog
和LockKey
保存起來,給後面的本地事務commit
和rollback
使用,上面已經講過。
上面的4.1.1-4.1.3都是說的是咱們分佈式事務的第一階段,也就是將咱們的分支事務註冊到Server
,而第二階段分支提交和分支回滾都在咱們的DataSourceManager
中,對於分支事務提交有以下代碼:
public BranchStatus branchCommit(BranchType branchType, String xid, long branchId, String resourceId, String applicationData) throws TransactionException { return asyncWorker.branchCommit(branchType, xid, branchId, resourceId, applicationData); } public BranchStatus branchCommit(BranchType branchType, String xid, long branchId, String resourceId, String applicationData) throws TransactionException { if (!ASYNC_COMMIT_BUFFER.offer(new Phase2Context(branchType, xid, branchId, resourceId, applicationData))) { LOGGER.warn("Async commit buffer is FULL. Rejected branch [" + branchId + "/" + xid + "] will be handled by housekeeping later."); } return BranchStatus.PhaseTwo_Committed; }
這裏將咱們的分支事務提交的信息,放到一個隊列中,異步去處理,也就是異步刪除咱們的undolog
數據,由於提交以後undolog
數據沒用了。
這裏有人可能會問若是當你將這個信息異步提交到隊列中的時候,機器宕機,那麼就不會執行異步刪除undolog
的邏輯,那麼這條undolog
是否是就會成爲永久的髒數據呢?這裏Seata
爲了防止這種事出現,會定時掃描某些較老的undolog數據而後進行刪除,不會污染咱們的數據。
對於咱們的分支事務回滾有以下代碼:
public BranchStatus branchRollback(BranchType branchType, String xid, long branchId, String resourceId, String applicationData) throws TransactionException { DataSourceProxy dataSourceProxy = get(resourceId); if (dataSourceProxy == null) { throw new ShouldNeverHappenException(); } try { UndoLogManager.undo(dataSourceProxy, xid, branchId); } catch (TransactionException te) { if (te.getCode() == TransactionExceptionCode.BranchRollbackFailed_Unretriable) { return BranchStatus.PhaseTwo_RollbackFailed_Unretryable; } else { return BranchStatus.PhaseTwo_RollbackFailed_Retryable; } } return BranchStatus.PhaseTwo_Rollbacked; }
這裏會先獲取到咱們的數據源,接下來調用咱們的重作日誌管理器的undo
方法進行日誌重作,undo
方法較長這裏就不貼上來了,其核心邏輯是查找到咱們的undolog
而後將裏面的快照在咱們數據庫進行重作。
TCC
沒有AT
模式資源管理這麼複雜,部分核心邏輯在以前的Interceptor
中已經講解過了,好比二階段方法的保存等。這裏主要看看TCC
的分支事務提交和分支事務回滾,在TCCResourceManager
中有:
public BranchStatus branchCommit(BranchType branchType, String xid, long branchId, String resourceId, String applicationData) throws TransactionException { TCCResource tccResource = (TCCResource) tccResourceCache.get(resourceId); if (tccResource == null) { throw new ShouldNeverHappenException("TCC resource is not exist, resourceId:" + resourceId); } Object targetTCCBean = tccResource.getTargetBean(); Method commitMethod = tccResource.getCommitMethod(); if (targetTCCBean == null || commitMethod == null) { throw new ShouldNeverHappenException("TCC resource is not available, resourceId:" + resourceId); } boolean result = false; //BusinessActionContext BusinessActionContext businessActionContext = getBusinessActionContext(xid, branchId, resourceId, applicationData); Object ret = commitMethod.invoke(targetTCCBean, businessActionContext); LOGGER.info("TCC resource commit result :" + ret + ", xid:" + xid + ", branchId:" + branchId + ", resourceId:" + resourceId); if (ret != null && ret instanceof TwoPhaseResult) { result = ((TwoPhaseResult) ret).isSuccess(); } else { result = (boolean) ret; } return result ? BranchStatus.PhaseTwo_Committed : BranchStatus.PhaseTwo_CommitFailed_Retryable; }
步驟以下:
TCC
資源,若是沒有拋出異常。commit
方法。commit
方法。Server
,由Server
決定是否重試。這裏的branchRollback
方法也比較簡單,這裏就不作過多分析了。
經過上面分析咱們知道,Seata
的初始化是依賴Spring
去進行,咱們的全局事務的開啓/提交/回滾都是依賴咱們的TM事務管理器,而咱們的分支事務的管理是依靠咱們的RM
,其中提供了兩個模式AT
和TCC
,AT
模式必須使用數據庫,其核心實現是實現數據源的代理,將咱們本身的邏輯注入進去。而咱們的TCC能彌補咱們沒有使用數據庫的狀況,將提交和回滾都交由咱們本身實現,其核心實現邏輯是依賴將一個資源的二階段的方法和咱們的目標對象在咱們的資源上下文中保存下來,方便咱們後續使用。
最後若是你們對分佈式事務感興趣,歡迎你們使用並閱讀Seata
的代碼,並給咱們提出建議。
若是你們以爲這篇文章對你有幫助,你的關注和轉發是對我最大的支持,O(∩_∩)O: