You are viewing a plain text version of this content. The canonical link for it is here.
Posted to notifications@shardingsphere.apache.org by GitBox <gi...@apache.org> on 2020/07/12 15:41:53 UTC

[GitHub] [shardingsphere] chaiyanliang opened a new issue #6328: seata shardingsphere 4.1.1 commit not rollback

chaiyanliang opened a new issue #6328:
URL: https://github.com/apache/shardingsphere/issues/6328


    Actual SQL: ds_0 ::: UPDATE refund_goods  SET refund_code=?,
   brand_code=?,
   crm_id=?   
    WHERE refund_code = ? AND code = ? ::: [111, AA, 333, 111, AA]
   2020-07-12 23:31:34.786 [ WARN][io.seata.common.loader.EnhancedServiceLoader$InnerEnhancedServiceLoader]-(http-nio-50051-exec-1) - The same extension io.seata.sqlparser.druid.mysql.MySQLOperateRecognizerHolder has already been loaded, skipped
   2020-07-12 23:31:34.786 [ WARN][io.seata.common.loader.EnhancedServiceLoader$InnerEnhancedServiceLoader]-(http-nio-50051-exec-1) - The same extension io.seata.sqlparser.druid.oracle.OracleOperateRecognizerHolder has already been loaded, skipped
   2020-07-12 23:31:34.787 [ WARN][io.seata.common.loader.EnhancedServiceLoader$InnerEnhancedServiceLoader]-(http-nio-50051-exec-1) - The same extension io.seata.sqlparser.druid.postgresql.PostgresqlOperateRecognizerHolder has already been loaded, skipped
   <==    Updates: 1
    Time:11062 ms - ID:org.best.data.mapper.RefundGoodsMapper.update
   Execute SQL:
       org.apache.shardingsphere.shardingjdbc.jdbc.core.statement.ShardingPreparedStatement@3d5ad6dd
   
   Closing non transactional SqlSession [org.apache.ibatis.session.defaults.DefaultSqlSession@6702a631]
   2020-07-12 23:31:44.981 [ INFO][com.best.mall.h5order.web.HybrisOrderController]-(http-nio-50051-exec-1) - XID:192.168.1.85:8091:2016758476
   2020-07-12 23:31:45.875 [ INFO][com.netflix.config.ChainedDynamicProperty]-(http-nio-50051-exec-1) - Flipping property: best-push-message.ribbon.ActiveConnectionsLimit to use NEXT property: niws.loadbalancer.availabilityFilteringRule.activeConnectionsLimit = 2147483647
   2020-07-12 23:31:46.038 [ INFO][com.netflix.util.concurrent.ShutdownEnabledTimer]-(http-nio-50051-exec-1) - Shutdown hook installed for: NFLoadBalancer-PingTimer-best-push-message
   2020-07-12 23:31:46.041 [ INFO][com.netflix.loadbalancer.BaseLoadBalancer]-(http-nio-50051-exec-1) - Client: best-push-message instantiated a LoadBalancer: DynamicServerListLoadBalancer:{NFLoadBalancer:name=best-push-message,current list of Servers=[],Load balancer stats=Zone stats: {},Server stats: []}ServerList:null
   2020-07-12 23:31:46.063 [ INFO][com.netflix.loadbalancer.DynamicServerListLoadBalancer]-(http-nio-50051-exec-1) - Using serverListUpdater PollingServerListUpdater
   2020-07-12 23:31:46.110 [ INFO][com.netflix.config.ChainedDynamicProperty]-(http-nio-50051-exec-1) - Flipping property: best-push-message.ribbon.ActiveConnectionsLimit to use NEXT property: niws.loadbalancer.availabilityFilteringRule.activeConnectionsLimit = 2147483647
   2020-07-12 23:31:46.115 [ INFO][com.netflix.loadbalancer.DynamicServerListLoadBalancer]-(http-nio-50051-exec-1) - DynamicServerListLoadBalancer for client best-push-message initialized: DynamicServerListLoadBalancer:{NFLoadBalancer:name=best-push-message,current list of Servers=[DESKTOP-BSTR8V3.bestseller.cn:50042],Load balancer stats=Zone stats: {defaultzone=[Zone:defaultzone;	Instance count:1;	Active connections count: 0;	Circuit breaker tripped count: 0;	Active connections per server: 0.0;]
   },Server stats: [[Server:DESKTOP-BSTR8V3.bestseller.cn:50042;	Zone:defaultZone;	Total Requests:0;	Successive connection failure:0;	Total blackout seconds:0;	Last connection made:Thu Jan 01 08:00:00 CST 1970;	First connection made: Thu Jan 01 08:00:00 CST 1970;	Active Connections:0;	total failure count in last (1000) msecs:0;	average resp time:0.0;	90 percentile resp time:0.0;	95 percentile resp time:0.0;	min resp time:0.0;	max resp time:0.0;	stddev resp time:0.0]
   ]}ServerList:org.springframework.cloud.netflix.ribbon.eureka.DomainExtractingServerList@40f96f18
   2020-07-12 23:31:46.878 [ INFO][com.best.mall.aop.LogAop]-(http-nio-50051-exec-1) - return:Result{success=true, code='200', msg='成功', data=null, extra=null}
   
   2020-07-12 23:31:46.961 [ INFO][io.seata.tm.api.DefaultGlobalTransaction]-(http-nio-50051-exec-1) - [192.168.1.85:8091:2016758476] commit status: Committed
   2020-07-12 23:31:47.073 [ INFO][com.netflix.config.ChainedDynamicProperty]-(PollingServerListUpdater-0) - Flipping property: best-push-message.ribbon.ActiveConnectionsLimit to use NEXT property: niws.loadbalancer.availabilityFilteringRule.activeConnectionsLimit = 2147483647
   2020-07-12 23:31:47.752 [ INFO][io.seata.core.rpc.netty.RmMessageListener]-(rpcDispatch_RMROLE_1_8) - onMessage:xid=192.168.1.85:8091:2016758476,branchId=2016758489,branchType=AT,resourceId=jdbc:mysql://localhost:3306/lzsz_order_only,applicationData=null
   2020-07-12 23:31:47.765 [ INFO][io.seata.rm.AbstractRMHandler]-(rpcDispatch_RMROLE_1_8) - Branch committing: 192.168.1.85:8091:2016758476 2016758489 jdbc:mysql://localhost:3306/lzsz_order0 null
   
   all no problem,transaction not roll back


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [shardingsphere] kimmking commented on issue #6328: seata shardingsphere 4.1.1 commit not rollback

Posted by GitBox <gi...@apache.org>.
kimmking commented on issue #6328:
URL: https://github.com/apache/shardingsphere/issues/6328#issuecomment-665444328


   Can you try a same case without sharding, only seata.


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [shardingsphere] cay914 edited a comment on issue #6328: seata shardingsphere 4.1.1 commit not rollback

Posted by GitBox <gi...@apache.org>.
cay914 edited a comment on issue #6328:
URL: https://github.com/apache/shardingsphere/issues/6328#issuecomment-667483890


   @kimmking 
   SeataATShardingTransactionManager.begin never be call. 
   why ? can you have testing this scenario?
   I have try without sharding jdbc, the undo_log table can insert data. 
   but with sharding-jdbc it can't.
   
   please update **sharding-transaction-base-seata-at** to support seata 1.3.0。
   thanks


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [shardingsphere] songdeweigit commented on issue #6328: seata shardingsphere 4.1.1 commit not rollback

Posted by GitBox <gi...@apache.org>.
songdeweigit commented on issue #6328:
URL: https://github.com/apache/shardingsphere/issues/6328#issuecomment-661528732


   麻烦问下,这个问题你们解决了吗,我这边也出现这个问题了


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [shardingsphere] aasummers commented on issue #6328: seata shardingsphere 4.1.1 commit not rollback

Posted by GitBox <gi...@apache.org>.
aasummers commented on issue #6328:
URL: https://github.com/apache/shardingsphere/issues/6328#issuecomment-711057788


   请问 这个问题解决了吗?


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [shardingsphere] chaiyanliang commented on issue #6328: seata shardingsphere 4.1.1 commit not rollback

Posted by GitBox <gi...@apache.org>.
chaiyanliang commented on issue #6328:
URL: https://github.com/apache/shardingsphere/issues/6328#issuecomment-665321686


   没有解决


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [shardingsphere] kimmking commented on issue #6328: seata shardingsphere 4.1.1 commit not rollback

Posted by GitBox <gi...@apache.org>.
kimmking commented on issue #6328:
URL: https://github.com/apache/shardingsphere/issues/6328#issuecomment-657408327


   Why you say it should rollback.
   Logs impact tx commit successfully.


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [shardingsphere] cay914 edited a comment on issue #6328: seata shardingsphere 4.1.1 commit not rollback

Posted by GitBox <gi...@apache.org>.
cay914 edited a comment on issue #6328:
URL: https://github.com/apache/shardingsphere/issues/6328#issuecomment-667483890


   @kimmking 
   SeataATShardingTransactionManager.begin never be call. 
   why ? can you have testing this scenario?
   I have try without sharding jdbc, the undo_log table can insert data. 
   but with sharding-jdbc it can't.
   
   please update sharding-transaction-base-seata-at to support seata 1.3.0。
   thanks


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [shardingsphere] terrymanu commented on issue #6328: seata shardingsphere 4.1.1 commit not rollback

Posted by GitBox <gi...@apache.org>.
terrymanu commented on issue #6328:
URL: https://github.com/apache/shardingsphere/issues/6328#issuecomment-932693009


   ref #12739


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@shardingsphere.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [shardingsphere] kimmking closed issue #6328: seata shardingsphere 4.1.1 commit not rollback

Posted by GitBox <gi...@apache.org>.
kimmking closed issue #6328:
URL: https://github.com/apache/shardingsphere/issues/6328


   


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [shardingsphere] cay914 commented on issue #6328: seata shardingsphere 4.1.1 commit not rollback

Posted by GitBox <gi...@apache.org>.
cay914 commented on issue #6328:
URL: https://github.com/apache/shardingsphere/issues/6328#issuecomment-667483890


   @kimmking 
   SeataATShardingTransactionManager.begin never be call. 
   why ? can you have testing this scenario?
   I have try with sharding jdbc, the undo_log table can insert data. 
   but with sharding-jdbc it can't.
   
   please update sharding-transaction-base-seata-at to support seata 1.3.0。
   thanks


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org