阿里开源分布式事务中间件fescar源码分析
fescar架构及原理
fescar开源后,网络上有不少讲解其原理的文章,这里就引入其中一篇,个人认为也建的比较透彻。文章地址:
《阿里巴巴开源分布式事务解决方案 Fescar》
这里引入上面文章的部分图片及内容, 架构及说明:
- Transaction Coordinator (TC): 事务协调器,维护全局事务的运行状态,负责协调并驱动全局事务的提交或回滚。
- Transaction Manager ™: 控制全局事务的边界,负责开启一个全局事务,并最终发起全局提交或全局回滚的决议。
- Resource Manager (RM):
控制分支事务,负责分支注册、状态汇报,并接收事务协调器的指令,驱动分支(本地)事务的提交和回滚。
一个典型的分布式事务过程:
- TM 向 TC 申请开启一个全局事务,全局事务创建成功并生成一个全局唯一的 XID。
- XID 在微服务调用链路的上下文中传播。
- RM 向 TC 注册分支事务,将其纳入 XID 对应全局事务的管辖。
- TM 向 TC 发起针对 XID 的全局提交或回滚决议。
- TC 调度 XID 下管辖的全部分支事务完成提交或回滚请求。
好,具体架构及过程可以详细读原文, 这里对应架构组成,分析源码。
三个系统,fescar server, 主事务的server, 子事务的server, 系统之间通过netty 完成rpc调用
主事务的server:
这里的代码实现跟本地的事务的事项非常匹配, 通过是 transaction来开启事务,通过transactionManager真正实现事务的逻辑。而使用模板transactionTemplate方便事务的使用。
GlobalTransactiona注解来设置一个接口需要开启分布式事务, 通过AOP, 对注解方法做切面,切入事务代码,加入事务处理。 GlobalTransactionalInterceptor 主要实现:
@Override
public Object invoke(final MethodInvocation methodInvocation) throws Throwable {
final GlobalTransactional anno = getAnnotation(methodInvocation.getMethod());
if (anno != null) {
try {
return transactionalTemplate.execute(new TransactionalExecutor() {
@Override
public Object execute() throws Throwable {
return methodInvocation.proceed();
}
@Override
public int timeout() {
return anno.timeoutMills();
}
@Override
public String name() {
if (anno.name() != null) {
return anno.name();
}
return formatMethod(methodInvocation.getMethod());
}
});
} catch (TransactionalExecutor.ExecutionException e) {
TransactionalExecutor.Code code = e.getCode();
switch (code) {
case RollbackDone:
throw e.getOriginalException();
case BeginFailure:
failureHandler.onBeginFailure(e.getTransaction(), e.getCause());
throw e.getCause();
case CommitFailure:
failureHandler.onCommitFailure(e.getTransaction(), e.getCause());
throw e.getCause();
case RollbackFailure:
failureHandler.onRollbackFailure(e.getTransaction(), e.getCause());
throw e.getCause();
default:
throw new ShouldNeverHappenException("Unknown TransactionalExecutor.Code: " + code);
}
}
}
return methodInvocation.proceed();
}
可以看到Interceptor主要通过template来加入事务, 而template的代码:
// 1. get or create a transaction
GlobalTransaction tx = GlobalTransactionContext.getCurrentOrCreate();
// 2. begin transaction
try {
tx.begin(business.timeout(), business.name());
} catch (TransactionException txe) {
throw new TransactionalExecutor.ExecutionException(tx, txe,
TransactionalExecutor.Code.BeginFailure);
}
Object rs = null;
try {
// Do Your Business
rs = business.execute();
} catch (Throwable ex) {
// 3. any business exception, rollback.
try {
tx.rollback();
// 3.1 Successfully rolled back
throw new TransactionalExecutor.ExecutionException(tx, TransactionalExecutor.Code.RollbackDone, ex);
} catch (TransactionException txe) {
// 3.2 Failed to rollback
throw new TransactionalExecutor.ExecutionException(tx, txe,
TransactionalExecutor.Code.RollbackFailure, ex);
}
}
// 4. everything is fine, commit.
try {
tx.commit();
} catch (TransactionException txe) {
// 4.1 Failed to commit
throw new TransactionalExecutor.ExecutionException(tx, txe,
TransactionalExecutor.Code.CommitFailure);
}
return rs;
}
TransactionalTemplate跟本地事务模板几乎没什么区别, 而差别就是GlobalTransaction引用的TransactionManager上, 默认的实现 DefaultTransactionManager:
@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 {
long txId = XID.getTransactionId(xid);
GlobalCommitRequest globalCommit = new GlobalCommitRequest();
globalCommit.setTransactionId(txId);
GlobalCommitResponse response = (GlobalCommitResponse) syncCall(globalCommit);
return response.getGlobalStatus();
}
@Override
public GlobalStatus rollback(String xid) throws TransactionException {
long txId = XID.getTransactionId(xid);
GlobalRollbackRequest globalRollback = new GlobalRollbackRequest();
globalRollback.setTransactionId(txId);
GlobalRollbackResponse response = (GlobalRollbackResponse) syncCall(globalRollback);
return response.getGlobalStatus();
}
可以看到,所有实现都是一个rpc的请求, 而这个请求都是发送给fescar server。
fescar server
分布事务协调的服务里面,最主要就两个类DefaultCoordinator, DefaultCore, 而Coordinator依赖Core来实现真正的业务逻辑, DefaultCoordinator处理来自主事务和子事务的协调处理。
@Override
public String begin(String applicationId, String transactionServiceGroup, String name, int timeout) throws TransactionException {
GlobalSession session = GlobalSession.createGlobalSession(
applicationId, transactionServiceGroup, name, timeout);
session.addSessionLifecycleListener(SessionHolder.getRootSessionManager());
session.begin();
return XID.generateXID(session.getTransactionId());
}
@Override
protected void doGlobalBegin(GlobalBeginRequest request, GlobalBeginResponse response, RpcContext rpcContext) throws TransactionException {
response.setXid(core.begin(rpcContext.getApplicationId(), rpcContext.getTransactionServiceGroup(), request.getTransactionName(), request.getTimeout()));
}
@Override
protected void doGlobalCommit(GlobalCommitRequest request, GlobalCommitResponse response, RpcContext rpcContext) throws TransactionException {
response.setGlobalStatus(core.commit(XID.generateXID(request.getTransactionId())));
}
@Override
protected void doGlobalRollback(GlobalRollbackRequest request, GlobalRollbackResponse response, RpcContext rpcContext) throws TransactionException {
response.setGlobalStatus(core.rollback(XID.generateXID(request.getTransactionId())));
}
@Override
protected void doGlobalStatus(GlobalStatusRequest request, GlobalStatusResponse response, RpcContext rpcContext) throws TransactionException {
response.setGlobalStatus(core.getStatus(XID.generateXID(request.getTransactionId())));
}
@Override
protected void doBranchRegister(BranchRegisterRequest request, BranchRegisterResponse response, RpcContext rpcContext) throws TransactionException {
response.setTransactionId(request.getTransactionId());
response.setBranchId(core.branchRegister(request.getBranchType(), request.getResourceId(), rpcContext.getClientId(),
XID.generateXID(request.getTransactionId()), request.getLockKey()));
}
可以看到实现都依赖Core。 这里再看DefaultCore的实现:
@Override
public GlobalStatus commit(String xid) throws TransactionException {
GlobalSession globalSession = SessionHolder.findGlobalSession(XID.getTransactionId(xid));
if (globalSession == null) {
return GlobalStatus.Finished;
}
GlobalStatus status = globalSession.getStatus();
globalSession.closeAndClean(); // Highlight: Firstly, close the session, then no more branch can be registered.
if (status == GlobalStatus.Begin) {
if (globalSession.canBeCommittedAsync()) {
asyncCommit(globalSession);
} else {
doGlobalCommit(globalSession, false);
}
}
return globalSession.getStatus();
}
@Override
public void doGlobalCommit(GlobalSession globalSession, boolean retrying) throws TransactionException {
for (BranchSession branchSession : globalSession.getSortedBranches()) {
BranchStatus currentStatus = branchSession.getStatus();
if (currentStatus == BranchStatus.PhaseOne_Failed) {
continue;
}
try {
BranchStatus branchStatus = resourceManagerInbound.branchCommit(XID.generateXID(branchSession.getTransactionId()), branchSession.getBranchId(),
branchSession.getResourceId(), branchSession.getApplicationData());
switch (branchStatus) {
case PhaseTwo_Committed:
globalSession.removeBranch(branchSession);
continue;
case PhaseTwo_CommitFailed_Unretriable:
if (globalSession.canBeCommittedAsync()) {
LOGGER.error("By [" + branchStatus + "], failed to commit branch " + branchSession);
continue;
} else {
globalSession.changeStatus(GlobalStatus.CommitFailed);
globalSession.end();
LOGGER.error("Finally, failed to commit global[" + globalSession.getTransactionId() + "] since branch[" + branchSession.getBranchId() + "] commit failed");
return;
}
default:
if (!retrying) {
queueToRetryCommit(globalSession);
return;
}
if (globalSession.canBeCommittedAsync()) {
LOGGER.error("By [" + branchStatus + "], failed to commit branch " + branchSession);
continue;
} else {
LOGGER.error("Failed to commit global[" + globalSession.getTransactionId() + "] since branch[" + branchSession.getBranchId() + "] commit failed, will retry later.");
return;
}
}
} catch (Exception ex) {
LOGGER.info("Exception committing branch " + branchSession, ex);
if (!retrying) {
queueToRetryCommit(globalSession);
if (ex instanceof TransactionException) {
throw (TransactionException) ex;
} else {
throw new TransactionException(ex);
}
}
}
}
if (globalSession.hasBranch()) {
LOGGER.info("Global[" + globalSession.getTransactionId() + "] committing is NOT done.");
return;
}
globalSession.changeStatus(GlobalStatus.Committed);
globalSession.end();
LOGGER.info("Global[" + globalSession.getTransactionId() + "] committing is successfully done.");
}
@Override
public GlobalStatus rollback(String xid) throws TransactionException {
GlobalSession globalSession = SessionHolder.findGlobalSession(XID.getTransactionId(xid));
if (globalSession == null) {
return GlobalStatus.Finished;
}
GlobalStatus status = globalSession.getStatus();
globalSession.close(); // Highlight: Firstly, close the session, then no more branch can be registered.
if (status == GlobalStatus.Begin) {
globalSession.changeStatus(GlobalStatus.Rollbacking);
doGlobalRollback(globalSession, false);
}
return globalSession.getStatus();
}
@Override
public void doGlobalRollback(GlobalSession globalSession, boolean retrying) throws TransactionException {
for (BranchSession branchSession : globalSession.getReverseSortedBranches()) {
BranchStatus currentBranchStatus = branchSession.getStatus();
if (currentBranchStatus == BranchStatus.PhaseOne_Failed) {
continue;
}
try {
BranchStatus branchStatus = resourceManagerInbound.branchRollback(XID.generateXID(branchSession.getTransactionId()), branchSession.getBranchId(),
branchSession.getResourceId(), branchSession.getApplicationData());
switch (branchStatus) {
case PhaseTwo_Rollbacked:
globalSession.removeBranch(branchSession);
LOGGER.error("Successfully rolled back branch " + branchSession);
continue;
case PhaseTwo_RollbackFailed_Unretriable:
GlobalStatus currentStatus = globalSession.getStatus();
if (currentStatus.name().startsWith("Timeout")) {
globalSession.changeStatus(GlobalStatus.TimeoutRollbackFailed);
} else {
globalSession.changeStatus(GlobalStatus.RollbackFailed);
}
globalSession.end();
LOGGER.error("Failed to rollback global[" + globalSession.getTransactionId() + "] since branch[" + branchSession.getBranchId() + "] rollback failed");
return;
default:
LOGGER.info("Failed to rollback branch " + branchSession);
if (!retrying) {
queueToRetryRollback(globalSession);
}
return;
}
} catch (Exception ex) {
LOGGER.info("Exception rollbacking branch " + branchSession, ex);
if (!retrying) {
queueToRetryRollback(globalSession);
if (ex instanceof TransactionException) {
throw (TransactionException) ex;
} else {
throw new TransactionException(ex);
}
}
}
}
GlobalStatus currentStatus = globalSession.getStatus();
if (currentStatus.name().startsWith("Timeout")) {
globalSession.changeStatus(GlobalStatus.TimeoutRollbacked);
} else {
globalSession.changeStatus(GlobalStatus.Rollbacked);
}
globalSession.end();
}
可以看到开启一个事务,就是创建一个session,并返回xid, xid必须在分布式调用中传递。
而commit和rollback都需要遍历分支事务,通过netty的rpc messge通知子事务的提交或者回滚。
子事务的server
在fescar原理讲解知道, fescar对XA的改进是,它的二段提交,子事务只有在第一段才锁库,只要是正常完成,第二段是不需要锁库,如果需要回滚,则根据记录的undo log来做回退处理。
这样基于DB做操作记录来完成DB回退,只需要在业务失败时候回退,减少锁库的时间,而比起实现正向和反向的幂等接口,这对开发来说更简单。
因此重点看看子事务DataSource的代理类如何实现日记记录,还有AbstractDMLBaseExecutor及UndoLogManager实现DB回滚,代码逻辑:
DataSourceProxy, ConnectionProxy:DataSourceProxy只是通过ConnectionProxy实现日志记录, 重点看ConnectionProxy里的实现逻辑
public void prepareUndoLog(SQLType sqlType, String tableName, TableRecords beforeImage, TableRecords afterImage) throws SQLException {
TableRecords lockKeyRecords = afterImage;
if (sqlType == SQLType.DELETE) {
lockKeyRecords = beforeImage;
}
String lockKeys = buildLockKey(lockKeyRecords);
context.appendLockKey(lockKeys);
SQLUndoLog sqlUndoLog = buildUndoItem(sqlType, tableName, beforeImage, afterImage);
context.appendUndoItem(sqlUndoLog);
}
看到ConnectionProxy的undo日志只是被放入上下文,而在这之前undo日志已经整理并入库,这是在AbstractDMLBaseExecutor 实现:
protected T executeAutoCommitFalse(Object[] args) throws Throwable {
TableRecords beforeImage = beforeImage();
T result = statementCallback.execute(statementProxy.getTargetStatement(), args);
TableRecords afterImage = afterImage(beforeImage);
statementProxy.getConnectionProxy().prepareUndoLog(sqlRecognizer.getSQLType(), sqlRecognizer.getTableName(), beforeImage, afterImage);
return result;
}
protected T executeAutoCommitTrue(Object[] args) throws Throwable {
T result = null;
AbstractConnectionProxy connectionProxy = statementProxy.getConnectionProxy();
LockRetryController lockRetryController = new LockRetryController();
try {
connectionProxy.setAutoCommit(false);
while (true) {
try {
result = executeAutoCommitFalse(args);
connectionProxy.commit();
break;
} catch (LockConflictException lockConflict) {
lockRetryController.sleep(lockConflict);
}
}
} finally {
connectionProxy.setAutoCommit(true);
}
return result;
}
从executeAutoCommitFalse方法看到只是业务sql前先整理beforeImage,执行业务sql,在整理afterImage。而他是怎样整理before和after的镜像,居然可以看对应的实现类,这里就不详细贴上来了。
在正常情况提交不需要做额外的事情,本地事务已经提交了。 而如果回滚则找到undo日志执行回滚。
DataSourceManager
@Override
public BranchStatus branchCommit(String xid, long branchId, String resourceId, String applicationData) throws TransactionException {
return asyncWorker.branchCommit(xid, branchId, resourceId, applicationData);
}
@Override
public BranchStatus branchRollback(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_Unretriable;
} else {
return BranchStatus.PhaseTwo_RollbackFailed_Retriable;
}
}
return BranchStatus.PhaseTwo_Rollbacked;
}
UndoLogManager的undo实现:
public static void undo(DataSourceProxy dataSourceProxy, String xid, long branchId) throws TransactionException {
assertDbSupport(dataSourceProxy.getTargetDataSource().getDbType());
Connection conn = null;
ResultSet rs = null;
PreparedStatement selectPST = null;
try {
conn = dataSourceProxy.getPlainConnection();
// The entire undo process should run in a local transaction.
conn.setAutoCommit(false);
// Find UNDO LOG
selectPST = conn.prepareStatement(SELECT_UNDO_LOG_SQL);
selectPST.setLong(1, branchId);
selectPST.setString(2, xid);
rs = selectPST.executeQuery();
while (rs.next()) {
Blob b = rs.getBlob("rollback_info");
String rollbackInfo = StringUtils.blob2string(b);
BranchUndoLog branchUndoLog = UndoLogParserFactory.getInstance().decode(rollbackInfo);
for (SQLUndoLog sqlUndoLog : branchUndoLog.getSqlUndoLogs()) {
TableMeta tableMeta = TableMetaCache.getTableMeta(dataSourceProxy, sqlUndoLog.getTableName());
sqlUndoLog.setTableMeta(tableMeta);
AbstractUndoExecutor undoExecutor = UndoExecutorFactory.getUndoExecutor(dataSourceProxy.getDbType(), sqlUndoLog);
undoExecutor.executeOn(conn);
}
}
deleteUndoLog(xid, branchId, conn);
conn.commit();
} catch (Throwable e) {
if (conn != null) {
try {
conn.rollback();
} catch (SQLException rollbackEx) {
LOGGER.warn("Failed to close JDBC resource while undo ... ", rollbackEx);
}
}
throw new TransactionException(BranchRollbackFailed_Retriable, String.format("%s/%s", branchId, xid), e);
} finally {
try {
if (rs != null) {
rs.close();
}
if (selectPST != null) {
selectPST.close();
}
if (conn != null) {
conn.close();
}
} catch (SQLException closeEx) {
LOGGER.warn("Failed to close JDBC resource while undo ... ", closeEx);
}
}
}
至此从全局事务到分支事务的begin,commit, rollback已经完成, 下面在看看其中涉及的一些公共部分,netty message rpc。
netty message rpc
虽然fescar是一套CS的request和response模式, 但也可以看做是一个基于message的rpc, 从rpc的几个方面来解析源码。 也可以从中了解rpc架构基本组成:
协议与网络
这通过netty做网络通信,基于socket, 而协议定义了一个rpcmessage,里面分成header和body, 代码如下:
public class RpcMessage {
private static AtomicLong NEXT_ID = new AtomicLong(0);
public static long getNextMessageId() {
return NEXT_ID.incrementAndGet();
}
private long id;
private boolean isAsync;
private boolean isRequest;
private boolean isHeartbeat;
private Object body;
而body则是不同接口的request对象, 从协调server通知分支事务提交的分析
而sendSynRequest的代码处理:
private Object sendAsyncRequest(String address, Channel channel, Object msg, long timeout)
throws TimeoutException {
if (channel == null) {
LOGGER.warn("sendAsyncRequestWithResponse nothing, caused by null channel.");
return null;
}
final RpcMessage rpcMessage = new RpcMessage();
rpcMessage.setId(RpcMessage.getNextMessageId());
rpcMessage.setAsync(false);
rpcMessage.setHeartbeat(false);
rpcMessage.setRequest(true);
rpcMessage.setBody(msg);
final MessageFuture messageFuture = new MessageFuture();
messageFuture.setRequestMessage(rpcMessage);
messageFuture.setTimeout(timeout);
futures.put(rpcMessage.getId(), messageFuture);
if (address != null) {
ConcurrentHashMap<String, BlockingQueue<RpcMessage>> map = basketMap;
BlockingQueue<RpcMessage> basket = map.get(address);
if (basket == null) {
map.putIfAbsent(address, new LinkedBlockingQueue<RpcMessage>());
basket = map.get(address);
}
basket.offer(rpcMessage);
if (LOGGER.isDebugEnabled()) {
LOGGER.debug("offer message: " + rpcMessage.getBody());
}
if (!isSending) {
synchronized (mergeLock) {
mergeLock.notifyAll();
}
}
} else {
ChannelFuture future;
channelWriteableCheck(channel, msg);
future = channel.writeAndFlush(rpcMessage);
future.addListener(new ChannelFutureListener() {
@Override
public void operationComplete(ChannelFuture future) {
if (!future.isSuccess()) {
MessageFuture messageFuture = futures.remove(rpcMessage.getId());
if (messageFuture != null) {
messageFuture.setResultMessage(future.cause());
}
destroyChannel(future.channel());
}
}
});
}
if (timeout > 0) {
try {
return messageFuture.get(timeout, TimeUnit.MILLISECONDS);
} catch (Exception exx) {
LOGGER.error("wait response error:" + exx.getMessage() + ",ip:" + address + ",request:" + msg);
if (exx instanceof TimeoutException) {
throw (TimeoutException)exx;
} else {
throw new RuntimeException(exx);
}
}
} else {
return null;
}
}
可以看到接口的request放入body后再分装成MessageFuture(增加超时信息),然后rpc msg通过netty的ChannelFuture发送出去。
序列化
这里序列化用的java的序列化接口,部分request和reposne重写encode和decode来控制,例如AbstractBranchEndRequest
@Override
public byte[] encode() {
byte[] applicationDataBytes = null;
if (this.applicationData != null) {
applicationDataBytes = applicationData.getBytes(UTF8);
if (applicationDataBytes.length > 512) {
byteBuffer = ByteBuffer.allocate(applicationDataBytes.length + 1024);
}
}
// 1. xid
if (this.xid != null) {
byte[] bs = xid.getBytes(UTF8);
byteBuffer.putShort((short) bs.length);
if (bs.length > 0) {
byteBuffer.put(bs);
}
} else {
byteBuffer.putShort((short) 0);
}
// 2. Branch Id
byteBuffer.putLong(this.branchId);
// 3. Branch Type
byteBuffer.put((byte) this.branchType.ordinal());
// 4. Resource Id
if (this.resourceId != null) {
byte[] bs = resourceId.getBytes(UTF8);
byteBuffer.putShort((short) bs.length);
if (bs.length > 0) {
byteBuffer.put(bs);
}
} else {
byteBuffer.putShort((short) 0);
}
// 5. Application Data
if (this.applicationData != null) {
byteBuffer.putInt(applicationDataBytes.length);
if (applicationDataBytes.length > 0) {
byteBuffer.put(applicationDataBytes);
}
} else {
byteBuffer.putInt(0);
}
byteBuffer.flip();
byte[] content = new byte[byteBuffer.limit()];
byteBuffer.get(content);
return content;
}
@Override
public boolean decode(ByteBuf in) {
int leftLen = in.readableBytes();
int read = 0;
int xidLen = in.readShort();
if (xidLen > 0) {
if (leftLen < xidLen) {
return false;
}
byte[] bs = new byte[xidLen];
in.readBytes(bs);
setXid(new String(bs, UTF8));
leftLen -= xidLen;
}
this.branchId = in.readLong();
leftLen -= 8;
this.branchType = BranchType.get(in.readByte());
leftLen --;
int resourceIdLen = in.readShort();
if (resourceIdLen > 0) {
if (leftLen < resourceIdLen) {
return false;
}
byte[] bs = new byte[resourceIdLen];
in.readBytes(bs);
setResourceId(new String(bs, UTF8));
leftLen -= resourceIdLen;
}
int applicationDataLen = in.readShort();
if (applicationDataLen > 0) {
if (leftLen < applicationDataLen) {
return false;
}
byte[] bs = new byte[applicationDataLen];
in.readBytes(bs);
setApplicationData(new String(bs, UTF8));
leftLen -= applicationDataLen;
}
return true;
}
业务方法的映射
网络通信和message的序列化已经完备, 还剩一个就是message request映射到业务方法并组成reponse返回。 从server收到消息看,是DefaultServerMessageListenerImpl
这里的handler就负责映射业务的处理,这里handler也指向DefaultCoordinator的onRequest
@Override
public AbstractResultMessage onRequest(AbstractMessage request, RpcContext context) {
if (!(request instanceof AbstractTransactionRequestToTC)) {
throw new IllegalArgumentException();
}
AbstractTransactionRequestToTC transactionRequest = (AbstractTransactionRequestToTC) request;
transactionRequest.setTCInboundHandler(this);
return transactionRequest.handle(context);
}
可以看到最终的业务处理都放在request的handler方法完成。 我们拿其中一个request看看
例如BranchRollbackRequest,继承AbstractTransactionRequestToRM,而request的handler方法执行类是RMInboundHandler来执行, 可以看到
@Override
public BranchCommitResponse handle(BranchCommitRequest request) {
BranchCommitResponse response = new BranchCommitResponse();
exceptionHandleTemplate(new Callback<BranchCommitRequest, BranchCommitResponse>() {
@Override
public void execute(BranchCommitRequest request, BranchCommitResponse response) throws TransactionException {
doBranchCommit(request, response);
}
}, request, response);
return response;
}
至此,整个基于message request,response的rpc就完成了, 当然真正的rpc还有更多模块,例如服务的自注册与发行, 服务监控, 服务调度等。
文章到此结束,不想文章太长,主要分析fescar主要功能原理相关的代码, 而fescar还有其他未有提及。