赞
踩
TransactionInterceptor支撑着整个事务功能的架构,调用该类是从invoke方法开始。
- public Object invoke(MethodInvocation invocation) throws Throwable {
- // Work out the target class: may be {@code null}.
- // The TransactionAttributeSource should be passed the target class
- // as well as the method, which may be from an interface.
- Class<?> targetClass = (invocation.getThis() != null ? AopUtils.getTargetClass(invocation.getThis()) : null);
-
- // Adapt to TransactionAspectSupport's invokeWithinTransaction...
- return invokeWithinTransaction(invocation.getMethod(), targetClass, new CoroutinesInvocationCallback() {
- @Override
- @Nullable
- public Object proceedWithInvocation() throws Throwable {
- return invocation.proceed();
- }
- @Override
- public Object getTarget() {
- return invocation.getThis();
- }
- @Override
- public Object[] getArguments() {
- return invocation.getArguments();
- }
- });
- }
- protected Object invokeWithinTransaction(Method method, @Nullable Class<?> targetClass,
- final InvocationCallback invocation) throws Throwable {
-
- // If the transaction attribute is null, the method is non-transactional.
- TransactionAttributeSource tas = getTransactionAttributeSource();
- //1.获取对应事务的属性
- final TransactionAttribute txAttr = (tas != null ? tas.getTransactionAttribute(method, targetClass) : null);
- //2.获取beanFactory中的TransactionManager
- final TransactionManager tm = determineTransactionManager(txAttr);
-
- if (this.reactiveAdapterRegistry != null && tm instanceof ReactiveTransactionManager) {
- boolean isSuspendingFunction = KotlinDetector.isSuspendingFunction(method);
- boolean hasSuspendingFlowReturnType = isSuspendingFunction &&
- COROUTINES_FLOW_CLASS_NAME.equals(new MethodParameter(method, -1).getParameterType().getName());
- if (isSuspendingFunction && !(invocation instanceof CoroutinesInvocationCallback)) {
- throw new IllegalStateException("Coroutines invocation not supported: " + method);
- }
- CoroutinesInvocationCallback corInv = (isSuspendingFunction ? (CoroutinesInvocationCallback) invocation : null);
-
- ReactiveTransactionSupport txSupport = this.transactionSupportCache.computeIfAbsent(method, key -> {
- Class<?> reactiveType =
- (isSuspendingFunction ? (hasSuspendingFlowReturnType ? Flux.class : Mono.class) : method.getReturnType());
- ReactiveAdapter adapter = this.reactiveAdapterRegistry.getAdapter(reactiveType);
- if (adapter == null) {
- throw new IllegalStateException("Cannot apply reactive transaction to non-reactive return type: " +
- method.getReturnType());
- }
- return new ReactiveTransactionSupport(adapter);
- });
-
- InvocationCallback callback = invocation;
- if (corInv != null) {
- callback = () -> CoroutinesUtils.invokeSuspendingFunction(method, corInv.getTarget(), corInv.getArguments());
- }
- Object result = txSupport.invokeWithinTransaction(method, targetClass, callback, txAttr, (ReactiveTransactionManager) tm);
- if (corInv != null) {
- Publisher<?> pr = (Publisher<?>) result;
- return (hasSuspendingFlowReturnType ? KotlinDelegate.asFlow(pr) :
- KotlinDelegate.awaitSingleOrNull(pr, corInv.getContinuation()));
- }
- return result;
- }
-
- PlatformTransactionManager ptm = asPlatformTransactionManager(tm);
- //构造方法唯一标识(类.方法)
- final String joinpointIdentification = methodIdentification(method, targetClass, txAttr);
- //3.声明式事务处理
- if (txAttr == null || !(ptm instanceof CallbackPreferringPlatformTransactionManager)) {
- // Standard transaction demarcation with getTransaction and commit/rollback calls.
- //4.创建TransactionInfo
- TransactionInfo txInfo = createTransactionIfNecessary(ptm, txAttr, joinpointIdentification);
-
- Object retVal;
- try {
- // This is an around advice: Invoke the next interceptor in the chain.
- // This will normally result in a target object being invoked.
- //5.执行被增强方法
- retVal = invocation.proceedWithInvocation();
- }
- catch (Throwable ex) {
- // target invocation exception
- //6.异常回滚
- completeTransactionAfterThrowing(txInfo, ex);
- throw ex;
- }
- finally {
- //清除信息
- cleanupTransactionInfo(txInfo);
- }
-
- if (retVal != null && vavrPresent && VavrDelegate.isVavrTry(retVal)) {
- // Set rollback-only in case of Vavr failure matching our rollback rules...
- TransactionStatus status = txInfo.getTransactionStatus();
- if (status != null && txAttr != null) {
- retVal = VavrDelegate.evaluateTryFailure(retVal, txAttr, status);
- }
- }
- //提交事务
- commitTransactionAfterReturning(txInfo);
- return retVal;
- }
- //编程式事务处理
- else {
- Object result;
- final ThrowableHolder throwableHolder = new ThrowableHolder();
-
- // It's a CallbackPreferringPlatformTransactionManager: pass a TransactionCallback in.
- try {
- result = ((CallbackPreferringPlatformTransactionManager) ptm).execute(txAttr, status -> {
- TransactionInfo txInfo = prepareTransactionInfo(ptm, txAttr, joinpointIdentification, status);
- try {
- Object retVal = invocation.proceedWithInvocation();
- if (retVal != null && vavrPresent && VavrDelegate.isVavrTry(retVal)) {
- // Set rollback-only in case of Vavr failure matching our rollback rules...
- retVal = VavrDelegate.evaluateTryFailure(retVal, txAttr, status);
- }
- return retVal;
- }
- catch (Throwable ex) {
- if (txAttr.rollbackOn(ex)) {
- // A RuntimeException: will lead to a rollback.
- if (ex instanceof RuntimeException) {
- throw (RuntimeException) ex;
- }
- else {
- throw new ThrowableHolderException(ex);
- }
- }
- else {
- // A normal return value: will lead to a commit.
- throwableHolder.throwable = ex;
- return null;
- }
- }
- finally {
- cleanupTransactionInfo(txInfo);
- }
- });
- }
- catch (ThrowableHolderException ex) {
- throw ex.getCause();
- }
- catch (TransactionSystemException ex2) {
- if (throwableHolder.throwable != null) {
- logger.error("Application exception overridden by commit exception", throwableHolder.throwable);
- ex2.initApplicationException(throwableHolder.throwable);
- }
- throw ex2;
- }
- catch (Throwable ex2) {
- if (throwableHolder.throwable != null) {
- logger.error("Application exception overridden by commit exception", throwableHolder.throwable);
- }
- throw ex2;
- }
-
- // Check result state: It might indicate a Throwable to rethrow.
- if (throwableHolder.throwable != null) {
- throw throwableHolder.throwable;
- }
- return result;
- }
- }
(1)创建并获取事务属性
(2)加载配置中配置的TransactionManager
(3)不同的事务处理方式使用不同的逻辑
(4)在目标方法执行前获取食物并收集事务信息
(5)执行目标方法
(6)一旦出现异常,尝试异常处理
(7)提交事务前的事务信息清除
(8)提交事务
- protected TransactionInfo createTransactionIfNecessary(@Nullable PlatformTransactionManager tm,
- @Nullable TransactionAttribute txAttr, final String joinpointIdentification) {
-
- // If no name specified, apply method identification as transaction name.
- //如果没有名称指定则使用方法唯一标识,并使用DelegatingTransactionAttribute封装txAttr
- if (txAttr != null && txAttr.getName() == null) {
- txAttr = new DelegatingTransactionAttribute(txAttr) {
- @Override
- public String getName() {
- return joinpointIdentification;
- }
- };
- }
-
- TransactionStatus status = null;
- if (txAttr != null) {
- //2.获取TransactionStatus
- if (tm != null) {
- status = tm.getTransaction(txAttr);
- }
- else {
- if (logger.isDebugEnabled()) {
- logger.debug("Skipping transactional joinpoint [" + joinpointIdentification +
- "] because no transaction manager has been configured");
- }
- }
- }
- //3.根据指定的属性与status准备一个TransactionInfo
- return prepareTransactionInfo(tm, txAttr, joinpointIdentification, status);
- }
(1)使用DelegatingTransactionAttribute封装传入的TransactionAttribute实例
(2)获取事务
(3)构建事务信息
- public final TransactionStatus getTransaction(@Nullable TransactionDefinition definition)
- throws TransactionException {
-
- // Use defaults if no transaction definition given.
- TransactionDefinition def = (definition != null ? definition : TransactionDefinition.withDefaults());
- //获取事务
- Object transaction = doGetTransaction();
- boolean debugEnabled = logger.isDebugEnabled();
-
- //判断当前线程是否存在事务,判断依据为当前线程记录的连接不为空且连接中connectionHolder中的TransactionActive属性不为空
- if (isExistingTransaction(transaction)) {
- // Existing transaction found -> check propagation behavior to find out how to behave.
- //当前线程已经存在事务
- return handleExistingTransaction(def, transaction, debugEnabled);
- }
-
- // Check definition settings for new transaction.
- //事务超时设置验证
- if (def.getTimeout() < TransactionDefinition.TIMEOUT_DEFAULT) {
- throw new InvalidTimeoutException("Invalid transaction timeout", def.getTimeout());
- }
-
- // No existing transaction found -> check propagation behavior to find out how to proceed.
- //如果当前线程不存在事务,但是PropagationBehavior却被声明为PROPAGATION_MANDATORY则抛出异常
- if (def.getPropagationBehavior() == TransactionDefinition.PROPAGATION_MANDATORY) {
- throw new IllegalTransactionStateException(
- "No existing transaction found for transaction marked with propagation 'mandatory'");
- }
- else if (def.getPropagationBehavior() == TransactionDefinition.PROPAGATION_REQUIRED ||
- def.getPropagationBehavior() == TransactionDefinition.PROPAGATION_REQUIRES_NEW ||
- def.getPropagationBehavior() == TransactionDefinition.PROPAGATION_NESTED) {
- //PROPAGATION_REQUIRED,PROPAGATION_REQUIRES_NEW,PROPAGATION_NESTED都需要新建事务
- //空挂起
- SuspendedResourcesHolder suspendedResources = suspend(null);
- if (debugEnabled) {
- logger.debug("Creating new transaction with name [" + def.getName() + "]: " + def);
- }
- try {
- return startTransaction(def, transaction, debugEnabled, suspendedResources);
- }
- catch (RuntimeException | Error ex) {
- resume(null, suspendedResources);
- throw ex;
- }
- }
- else {
- // Create "empty" transaction: no actual transaction, but potentially synchronization.
- if (def.getIsolationLevel() != TransactionDefinition.ISOLATION_DEFAULT && logger.isWarnEnabled()) {
- logger.warn("Custom isolation level specified but no actual transaction initiated; " +
- "isolation level will effectively be ignored: " + def);
- }
- boolean newSynchronization = (getTransactionSynchronization() == SYNCHRONIZATION_ALWAYS);
- //新同步事务的设置,针对于当前线程的设置
- return prepareTransactionStatus(def, null, true, newSynchronization, debugEnabled, null);
- }
- }
- private TransactionStatus startTransaction(TransactionDefinition definition, Object transaction,
- boolean debugEnabled, @Nullable SuspendedResourcesHolder suspendedResources) {
-
- boolean newSynchronization = (getTransactionSynchronization() != SYNCHRONIZATION_NEVER);
- DefaultTransactionStatus status = newTransactionStatus(
- definition, transaction, true, newSynchronization, debugEnabled, suspendedResources);
- doBegin(transaction, definition);
- prepareSynchronization(status, definition);
- return status;
- }
- protected void doBegin(Object transaction, TransactionDefinition definition) {
- DataSourceTransactionObject txObject = (DataSourceTransactionObject) transaction;
- Connection con = null;
- //尝试获取连接
- try {
- if (!txObject.hasConnectionHolder() ||
- txObject.getConnectionHolder().isSynchronizedWithTransaction()) {
- Connection newCon = obtainDataSource().getConnection();
- if (logger.isDebugEnabled()) {
- logger.debug("Acquired Connection [" + newCon + "] for JDBC transaction");
- }
- txObject.setConnectionHolder(new ConnectionHolder(newCon), true);
- }
-
- txObject.getConnectionHolder().setSynchronizedWithTransaction(true);
- con = txObject.getConnectionHolder().getConnection();
- //设置隔离级别
- Integer previousIsolationLevel = DataSourceUtils.prepareConnectionForTransaction(con, definition);
- txObject.setPreviousIsolationLevel(previousIsolationLevel);
- txObject.setReadOnly(definition.isReadOnly());
-
- // Switch to manual commit if necessary. This is very expensive in some JDBC drivers,
- // so we don't want to do it unnecessarily (for example if we've explicitly
- // configured the connection pool to set it already).
- //更改自动提交设置,由Spring控制提交
- if (con.getAutoCommit()) {
- txObject.setMustRestoreAutoCommit(true);
- if (logger.isDebugEnabled()) {
- logger.debug("Switching JDBC Connection [" + con + "] to manual commit");
- }
- con.setAutoCommit(false);
- }
-
- prepareTransactionalConnection(con, definition);
- //设置判断当前线程是否存在事务的依据
- txObject.getConnectionHolder().setTransactionActive(true);
-
- int timeout = determineTimeout(definition);
- if (timeout != TransactionDefinition.TIMEOUT_DEFAULT) {
- //设置过期时间 txObject.getConnectionHolder().setTimeoutInSeconds(timeout);
- }
-
- // Bind the connection holder to the thread.
- if (txObject.isNewConnectionHolder()) {
- //将当前获取到的连接绑定到当前线程 TransactionSynchronizationManager.bindResource(obtainDataSource(), txObject.getConnectionHolder());
- }
- }
-
- catch (Throwable ex) {
- if (txObject.isNewConnectionHolder()) {
- DataSourceUtils.releaseConnection(con, obtainDataSource());
- txObject.setConnectionHolder(null, false);
- }
- throw new CannotCreateTransactionException("Could not open JDBC Connection for transaction", ex);
- }
- }
(1)尝试获取连接
(2)设置隔离级别以及只读标识
(3)更改默认的提交设置
(4)设置标志位,标识当前连接已经被事务激活
(5)设置过期时间
(6)将connectionHolder绑定到当前线程
(7)将事务信息记录在当前线程中
- private TransactionStatus handleExistingTransaction(
- TransactionDefinition definition, Object transaction, boolean debugEnabled)
- throws TransactionException {
-
- if (definition.getPropagationBehavior() == TransactionDefinition.PROPAGATION_NEVER) {
- throw new IllegalTransactionStateException(
- "Existing transaction found for transaction marked with propagation 'never'");
- }
-
- if (definition.getPropagationBehavior() == TransactionDefinition.PROPAGATION_NOT_SUPPORTED) {
- if (debugEnabled) {
- logger.debug("Suspending current transaction");
- }
- Object suspendedResources = suspend(transaction);
- boolean newSynchronization = (getTransactionSynchronization() == SYNCHRONIZATION_ALWAYS);
- return prepareTransactionStatus(
- definition, null, false, newSynchronization, debugEnabled, suspendedResources);
- }
-
- if (definition.getPropagationBehavior() == TransactionDefinition.PROPAGATION_REQUIRES_NEW) {
- if (debugEnabled) {
- logger.debug("Suspending current transaction, creating new transaction with name [" +
- definition.getName() + "]");
- }
- //新事务的建立
- SuspendedResourcesHolder suspendedResources = suspend(transaction);
- try {
- return startTransaction(definition, transaction, debugEnabled, suspendedResources);
- }
- catch (RuntimeException | Error beginEx) {
- resumeAfterBeginException(transaction, suspendedResources, beginEx);
- throw beginEx;
- }
- }
-
- //嵌入式事务的处理
- if (definition.getPropagationBehavior() == TransactionDefinition.PROPAGATION_NESTED) {
- if (!isNestedTransactionAllowed()) {
- throw new NestedTransactionNotSupportedException(
- "Transaction manager does not allow nested transactions by default - " +
- "specify 'nestedTransactionAllowed' property with value 'true'");
- }
- if (debugEnabled) {
- logger.debug("Creating nested transaction with name [" + definition.getName() + "]");
- }
- if (useSavepointForNestedTransaction()) {
- // Create savepoint within existing Spring-managed transaction,
- // through the SavepointManager API implemented by TransactionStatus.
- // Usually uses JDBC 3.0 savepoints. Never activates Spring synchronization.
- //如果没有可以使用保存点的方式控制事务回滚,那么在嵌入式事务的建立初始建立保存点
- DefaultTransactionStatus status =
- prepareTransactionStatus(definition, transaction, false, false, debugEnabled, null);
- status.createAndHoldSavepoint();
- return status;
- }
- else {
- // Nested transaction through nested begin and commit/rollback calls.
- // Usually only for JTA: Spring synchronization might get activated here
- // in case of a pre-existing JTA transaction.
- return startTransaction(definition, transaction, debugEnabled, null);
- }
- }
-
- // Assumably PROPAGATION_SUPPORTS or PROPAGATION_REQUIRED.
- if (debugEnabled) {
- logger.debug("Participating in existing transaction");
- }
- if (isValidateExistingTransaction()) {
- if (definition.getIsolationLevel() != TransactionDefinition.ISOLATION_DEFAULT) {
- Integer currentIsolationLevel = TransactionSynchronizationManager.getCurrentTransactionIsolationLevel();
- if (currentIsolationLevel == null || currentIsolationLevel != definition.getIsolationLevel()) {
- Constants isoConstants = DefaultTransactionDefinition.constants;
- throw new IllegalTransactionStateException("Participating transaction with definition [" +
- definition + "] specifies isolation level which is incompatible with existing transaction: " +
- (currentIsolationLevel != null ?
- isoConstants.toCode(currentIsolationLevel, DefaultTransactionDefinition.PREFIX_ISOLATION) :
- "(unknown)"));
- }
- }
- if (!definition.isReadOnly()) {
- if (TransactionSynchronizationManager.isCurrentTransactionReadOnly()) {
- throw new IllegalTransactionStateException("Participating transaction with definition [" +
- definition + "] is not marked as read-only but existing transaction is");
- }
- }
- }
- boolean newSynchronization = (getTransactionSynchronization() != SYNCHRONIZATION_NEVER);
- return prepareTransactionStatus(definition, transaction, false, newSynchronization, debugEnabled, null);
- }
(1)PROPAGATION_REQUIRES_NEW 标识当前方法必须在它自己的事务里运行,一个新的事务将被启动,而如果有一个事务正在运行的话,则这个方法运行期间被挂起
(2)PROPAGATION_NESTED 表示如果当前正有一个事务在运行中,则该方法应该运行在一个嵌套的事务中,被嵌套的事务可以独立于封装事务进行提交或者回滚
- protected void completeTransactionAfterThrowing(@Nullable TransactionInfo txInfo, Throwable ex) {
- //当抛出异常时首先判断当前是否存在事务
- if (txInfo != null && txInfo.getTransactionStatus() != null) {
- if (logger.isTraceEnabled()) {
- logger.trace("Completing transaction for [" + txInfo.getJoinpointIdentification() +
- "] after exception: " + ex);
- }
- //这里判断是否回滚默认的依据是抛出的异常是否是RuntimeException
- if (txInfo.transactionAttribute != null && txInfo.transactionAttribute.rollbackOn(ex)) {
- try {
- //根据TransactionStatus信息进行回滚处理
-
- txInfo.getTransactionManager().rollback(txInfo.getTransactionStatus());
- }
- catch (TransactionSystemException ex2) {
- logger.error("Application exception overridden by rollback exception", ex);
- ex2.initApplicationException(ex);
- throw ex2;
- }
- catch (RuntimeException | Error ex2) {
- logger.error("Application exception overridden by rollback exception", ex);
- throw ex2;
- }
- }
- else {
- //如果不满足回滚条件即使抛出异常也同样会提交
- // We don't roll back on this exception.
- // Will still roll back if TransactionStatus.isRollbackOnly() is true.
- try {
- txInfo.getTransactionManager().commit(txInfo.getTransactionStatus());
- }
- catch (TransactionSystemException ex2) {
- logger.error("Application exception overridden by commit exception", ex);
- ex2.initApplicationException(ex);
- throw ex2;
- }
- catch (RuntimeException | Error ex2) {
- logger.error("Application exception overridden by commit exception", ex);
- throw ex2;
- }
- }
- }
- }
1.回滚条件 txInfo.transactionAttribute.rollbackOn(ex)txInfo.transactionAttribute.rollbackOn(ex)
2.回滚处理
3.回滚后的信息清楚
- public final void rollback(TransactionStatus status) throws TransactionException {
- //如果事务已经完成,那么再次回滚会抛出异常
- if (status.isCompleted()) {
- throw new IllegalTransactionStateException(
- "Transaction is already completed - do not call commit or rollback more than once per transaction");
- }
-
- DefaultTransactionStatus defStatus = (DefaultTransactionStatus) status;
- processRollback(defStatus, false);
- }
-
-
- private void processRollback(DefaultTransactionStatus status, boolean unexpected) {
- try {
- boolean unexpectedRollback = unexpected;
-
- try {
- //激活所有TransactionSynchronization中对应的方法
- triggerBeforeCompletion(status);
-
- if (status.hasSavepoint()) {
- if (status.isDebug()) {
- logger.debug("Rolling back transaction to savepoint");
- }
- //如果有保存点,也就是当前事务为单独的线程则会退到保存点
- status.rollbackToHeldSavepoint();
- }
- else if (status.isNewTransaction()) {
- if (status.isDebug()) {
- logger.debug("Initiating transaction rollback");
- }
- //如果当前事务为独立的新事务,则直接回退
- doRollback(status);
- }
- else {
- // Participating in larger transaction
- if (status.hasTransaction()) {
- if (status.isLocalRollbackOnly() || isGlobalRollbackOnParticipationFailure()) {
- if (status.isDebug()) {
- logger.debug("Participating transaction failed - marking existing transaction as rollback-only");
- }
- //如果当前事务不是独立的事务,那么只能标记状态,等到事务链执行完毕后统一回滚
- doSetRollbackOnly(status);
- }
- else {
- if (status.isDebug()) {
- logger.debug("Participating transaction failed - letting transaction originator decide on rollback");
- }
- }
- }
- else {
- logger.debug("Should roll back transaction but cannot - no transaction available");
- }
- // Unexpected rollback only matters here if we're asked to fail early
- if (!isFailEarlyOnGlobalRollbackOnly()) {
- unexpectedRollback = false;
- }
- }
- }
- catch (RuntimeException | Error ex) {
- triggerAfterCompletion(status, TransactionSynchronization.STATUS_UNKNOWN);
- throw ex;
- }
-
- //激活所有TransactionSynchronization中对应的方法
- triggerAfterCompletion(status, TransactionSynchronization.STATUS_ROLLED_BACK);
-
- // Raise UnexpectedRollbackException if we had a global rollback-only marker
- if (unexpectedRollback) {
- throw new UnexpectedRollbackException(
- "Transaction rolled back because it has been marked as rollback-only");
- }
- }
- finally {
- //清空记录的资源并将挂起的资源恢复
- cleanupAfterCompletion(status);
- }
- }
- private void cleanupAfterCompletion(DefaultTransactionStatus status) {
- //设置完成状态
- status.setCompleted();
- if (status.isNewSynchronization()) {
- TransactionSynchronizationManager.clear();
- }
- if (status.isNewTransaction()) {
- //清除资源
- doCleanupAfterCompletion(status.getTransaction());
- }
- if (status.getSuspendedResources() != null) {
- if (status.isDebug()) {
- logger.debug("Resuming suspended transaction after completion of inner transaction");
- }
- Object transaction = (status.hasTransaction() ? status.getTransaction() : null);
- //结束之前事务的挂起状态
- resume(transaction, (SuspendedResourcesHolder) status.getSuspendedResources());
- }
- }
- protected void doCleanupAfterCompletion(Object transaction) {
- DataSourceTransactionObject txObject = (DataSourceTransactionObject) transaction;
-
- // Remove the connection holder from the thread, if exposed.
- if (txObject.isNewConnectionHolder()) {
- //将数据库连接从当前线程中解除绑定
- TransactionSynchronizationManager.unbindResource(obtainDataSource());
- }
-
- // Reset connection.
- //释放连接
- Connection con = txObject.getConnectionHolder().getConnection();
- try {
- if (txObject.isMustRestoreAutoCommit()) {
- //恢复数据库连接的自动提交属性
- con.setAutoCommit(true);
- }
- //重置数据库连接
- DataSourceUtils.resetConnectionAfterTransaction(
- con, txObject.getPreviousIsolationLevel(), txObject.isReadOnly());
- }
- catch (Throwable ex) {
- logger.debug("Could not reset JDBC Connection after transaction", ex);
- }
-
- if (txObject.isNewConnectionHolder()) {
- if (logger.isDebugEnabled()) {
- logger.debug("Releasing JDBC Connection [" + con + "] after transaction");
- }
- //如果当前事务时独立的新创建的事务则在事务完成时释放数据库连接
- DataSourceUtils.releaseConnection(con, this.dataSource);
- }
-
- txObject.getConnectionHolder().clear();
- }
- protected void commitTransactionAfterReturning(@Nullable TransactionInfo txInfo) {
- if (txInfo != null && txInfo.getTransactionStatus() != null) {
- if (logger.isTraceEnabled()) {
- logger.trace("Completing transaction for [" + txInfo.getJoinpointIdentification() + "]");
- }
- txInfo.getTransactionManager().commit(txInfo.getTransactionStatus());
- }
- }
当事务没有被异常捕获的时候并不意味着一定会执行提交的过程
- public final void commit(TransactionStatus status) throws TransactionException {
- if (status.isCompleted()) {
- throw new IllegalTransactionStateException(
- "Transaction is already completed - do not call commit or rollback more than once per transaction");
- }
-
- DefaultTransactionStatus defStatus = (DefaultTransactionStatus) status;
- //如果在事务链中已经被标记回滚,那么不会尝试提交事务,直接回滚
- if (defStatus.isLocalRollbackOnly()) {
- if (defStatus.isDebug()) {
- logger.debug("Transactional code has requested rollback");
- }
- processRollback(defStatus, false);
- return;
- }
-
- if (!shouldCommitOnGlobalRollbackOnly() && defStatus.isGlobalRollbackOnly()) {
- if (defStatus.isDebug()) {
- logger.debug("Global transaction is marked as rollback-only but transactional code requested commit");
- }
- processRollback(defStatus, true);
- return;
- }
-
- //处理事务提交
- processCommit(defStatus);
- }
当事务执行一切都正常的时候,便可以真正的进入提交流程
- private void processCommit(DefaultTransactionStatus status) throws TransactionException {
- try {
- boolean beforeCompletionInvoked = false;
-
- try {
- boolean unexpectedRollback = false;
- //预留
- prepareForCommit(status);
- //添加的TransactionSynchronization中的对应方法的调用
- triggerBeforeCommit(status);
- triggerBeforeCompletion(status);
- beforeCompletionInvoked = true;
-
- if (status.hasSavepoint()) {
- if (status.isDebug()) {
- logger.debug("Releasing transaction savepoint");
- }
- unexpectedRollback = status.isGlobalRollbackOnly();
- //如果存在保存点则清除保存点信息
- status.releaseHeldSavepoint();
- }
- else if (status.isNewTransaction()) {
- if (status.isDebug()) {
- logger.debug("Initiating transaction commit");
- }
- unexpectedRollback = status.isGlobalRollbackOnly();
- //如果是独立的事务则直接提交
- doCommit(status);
- }
- else if (isFailEarlyOnGlobalRollbackOnly()) {
- unexpectedRollback = status.isGlobalRollbackOnly();
- }
-
- // Throw UnexpectedRollbackException if we have a global rollback-only
- // marker but still didn't get a corresponding exception from commit.
- if (unexpectedRollback) {
- throw new UnexpectedRollbackException(
- "Transaction silently rolled back because it has been marked as rollback-only");
- }
- }
- catch (UnexpectedRollbackException ex) {
- // can only be caused by doCommit
- triggerAfterCompletion(status, TransactionSynchronization.STATUS_ROLLED_BACK);
- throw ex;
- }
- catch (TransactionException ex) {
- // can only be caused by doCommit
- if (isRollbackOnCommitFailure()) {
- doRollbackOnCommitException(status, ex);
- }
- else {
- triggerAfterCompletion(status, TransactionSynchronization.STATUS_UNKNOWN);
- }
- throw ex;
- }
- catch (RuntimeException | Error ex) {
- if (!beforeCompletionInvoked) {
- triggerBeforeCompletion(status);
- }
- //提交过程中出现异常则回滚
- doRollbackOnCommitException(status, ex);
- throw ex;
- }
-
- // Trigger afterCommit callbacks, with an exception thrown there
- // propagated to callers but the transaction still considered as committed.
- try {
- //添加的TransactionSynchronization中的对应方法的调用
- triggerAfterCommit(status);
- }
- finally {
- triggerAfterCompletion(status, TransactionSynchronization.STATUS_COMMITTED);
- }
-
- }
- finally {
- cleanupAfterCompletion(status);
- }
- }
- protected void doCommit(DefaultTransactionStatus status) {
- DataSourceTransactionObject txObject = (DataSourceTransactionObject) status.getTransaction();
- Connection con = txObject.getConnectionHolder().getConnection();
- if (status.isDebug()) {
- logger.debug("Committing JDBC transaction on Connection [" + con + "]");
- }
- try {
- con.commit();
- }
- catch (SQLException ex) {
- throw new TransactionSystemException("Could not commit JDBC transaction", ex);
- }
- }
Copyright © 2003-2013 www.wpsshop.cn 版权所有,并保留所有权利。