Spring事务处理机制以及错误使用TransactionSynchronization的afterCompletion方法引起的问题

前言

我们都知道spring有声明式事务和编程式事务,声明式只需要提供@Transactional的注解,然后事务的开启和提交/回滚、资源的清理就都由spring来管控,我们只需要关注业务代码即可;而编程式事务则需要使用spring提供的模板,如TransactionTemplate,或者直接使用底层的PlatformTransactionManager。

声明式事务的最大优点就是对代码的侵入性较小,只需要在方法上加@Transactional的注解就可以实现事务;编程式事务的最大优点就是事务的管控粒度较细,在实现某个代码块的事务。

背景

简单介绍完spring的事务机制那就要引入这一次碰到的问题了,我相信大多数人应该和我一样,只要怎么使用,比如加个注解啥的,但是底层原理不清楚。好一点的知道AOP动态代理,再好一点就是知道事务的传播机制(一般也就用用默认的REQUIRED)。真正底层的事务处理的源码很多人应该是没有看过的,当然我也是没有滴~~ 但是这一次碰到的问题让我不得不去看源码了。

这段时间一直在做代码的重构,既然是重新写的代码,当然想写得漂亮一点,不然是要被后人戳脊梁骨的~~ 结果所有代码都写完,都提测了,在测试环境却报一个诡异的异常

java.sql.SQLException: PooledConnection has already been closed

而且这不是必现的,而一旦出现,那任何涉及数据库连接的接口都有可能报这个错。从字面意思看是用到的数据库连接被关闭了,但是理解不能啊,这种底层的事情不都是spring帮忙做好了么。建议测试重启机器,心中期待不会再现

结果依然出现,而且频率还不低,都阻塞测试了。。那就只好操起久违的调试源码的大刀,硬着头皮上了。

过程

本次源码使用的是spring版本是 4.2.4.RELEASE,事务管理器则是参照项目使用的DataSourceTransactionManager。

入口

  1. 首先是事务的入口,spring用的是动态代理,如果某个方法被标注了@Transactional,则会由TransactionInterceptor拦截,在原始方法的前后增加一些额外的处理。可以看到,调用的是TransactionInterceptor的invoke方法,而内部又调用了invokeWithinTransaction方法,但其实这个并不一定会创建事务(事务传播机制里有几种情况是不需要或者不支持事务的)。
public Object invoke(final 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 InvocationCallback() {
        @Override
        public Object proceedWithInvocation() throws Throwable {
            return invocation.proceed();
        }
    });
}
  1. TransactionInterceptor继承了TransactionAspectSupport这个抽象类,invokeWithinTransaction这个方法是在父类中的。方法里的英文注释是源码中的,中文注释是我加上去的。CallbackPreferringPlatformTransactionManager是实现了PlatformTransactionManager接口,如果使用的事务管理器是CallbackPreferringPlatformTransactionManager的实现,则会将事务的控制交由这个类的execute方法,这里先省略。我们来看一般情况(很多应该用的是DataSourceTransactionManager吧),总的来说可以将这个方法分为几部分:
protected Object invokeWithinTransaction(Method method, Class<?> targetClass, final InvocationCallback invocation) throws Throwable {
    // If the transaction attribute is null, the method is non-transactional.
    final TransactionAttribute txAttr = getTransactionAttributeSource().getTransactionAttribute(method, targetClass);
    final PlatformTransactionManager tm = determineTransactionManager(txAttr);
    final String joinpointIdentification = methodIdentification(method, targetClass);

    if (txAttr == null || !(tm instanceof CallbackPreferringPlatformTransactionManager)) {
        // Standard transaction demarcation with getTransaction and commit/rollback calls.
        // 如果当前方法需要事务则会创建事务(@Transactional不代表一定创建事务,可以看spring的事务传播机制)
        TransactionInfo txInfo = createTransactionIfNecessary(tm, txAttr, joinpointIdentification);
        Object retVal = null;
        try {
            // This is an around advice: Invoke the next interceptor in the chain.
            // This will normally result in a target object being invoked.
            // 可以将这个方法视为调用真正的业务方法(其实内部还有一些拦截器的处理)
            retVal = invocation.proceedWithInvocation();
        }
        catch (Throwable ex) {
            // target invocation exception
            // 事务抛出异常的时候的处理
            completeTransactionAfterThrowing(txInfo, ex);
            throw ex;
        }
        finally {
            // 只做一件事,就是把事务的上下文信息改回本事务开始之前的上下文
            // 因为有可能本事务是被包裹在其他事务中的,可以看spring的事务传播机制
            cleanupTransactionInfo(txInfo);
        }
        // 事务执行成功后将事务的状态信息提交
        commitTransactionAfterReturning(txInfo);
        return retVal;
    }

    else {
        // It's a CallbackPreferringPlatformTransactionManager: pass a TransactionCallback in.
        // 省略
    }
}

createTransactionIfNecessary

这里要知道几个类的含义:

  • TransactionAttribute 事务的属性,比如我们在@Transactional里面的一些定义,使用的事务管理器、事务隔离级别、超时时间等
  • TransactionStatus 事务的运行时状态,如是否已完成等
  • TransactionInfo 事务信息的聚合,包含了事务属性、事务状态、事务管理器、被事务包裹的方法定义信息、本事务执行前的外层事务信息等

这里复杂的是获取事务的方法,其他方法做的事情见我的中文注释。

protected TransactionInfo createTransactionIfNecessary(PlatformTransactionManager tm, TransactionAttribute txAttr, final String joinpointIdentification) {
    // If no name specified, apply method identification as transaction name.
    // 新建一个TransactionAttribute的代理对象,其实用的是装饰器模式
    if (txAttr != null && txAttr.getName() == null) {
        txAttr = new DelegatingTransactionAttribute(txAttr) {
            @Override
            public String getName() {
                return joinpointIdentification;
            }
        };
    }

    TransactionStatus status = null;
    if (txAttr != null) {
        if (tm != null) {
            // 这里会根据事务管理器获取事务对象
            status = tm.getTransaction(txAttr);
        }
        else {
            if (logger.isDebugEnabled()) {
                logger.debug("Skipping transactional joinpoint [" + joinpointIdentification +
                        "] because no transaction manager has been configured");
            }
        }
    }
    // 将事务信息聚合然后返回,这里会有一个事务信息绑定到当前线程的操作(外层事务信息会存下来)
    return prepareTransactionInfo(tm, txAttr, joinpointIdentification, status);
}
  1. getTransaction方法
  • TransactionSynchronizationManager 以threadLocal的方式保存当前线程事务相关信息的对象

这里省略了一些不重要的流程,重点是doBegin方法,这里会开启事务

public final TransactionStatus getTransaction(TransactionDefinition definition) throws TransactionException {
    // 会新建一个事务对象,从TransactionSynchronizationManager中获取当前线程持有的数据库连接的句柄
    //如果是最开始的事务,这个句柄是会为null的,如果是内层事务,则会复用连接
    Object transaction = doGetTransaction();

    // 省略
    
    // 当前线程关联的数据库连接存在且事务处于激活状态,那么当前事务会根据事务传播机制来处理当前事务
    if (isExistingTransaction(transaction)) {
        // Existing transaction found -> check propagation behavior to find out how to behave.
        return handleExistingTransaction(definition, transaction, debugEnabled);
    }

    // 省略

    // No existing transaction found -> check propagation behavior to find out how to proceed.
    if (definition.getPropagationBehavior() == TransactionDefinition.PROPAGATION_MANDATORY) {
        // 省略
    }
    else if (definition.getPropagationBehavior() == TransactionDefinition.PROPAGATION_REQUIRED ||
            definition.getPropagationBehavior() == TransactionDefinition.PROPAGATION_REQUIRES_NEW ||
            definition.getPropagationBehavior() == TransactionDefinition.PROPAGATION_NESTED) {
        SuspendedResourcesHolder suspendedResources = suspend(null);
        if (debugEnabled) {
            logger.debug("Creating new transaction with name [" + definition.getName() + "]: " + definition);
        }
        try {
            boolean newSynchronization = (getTransactionSynchronization() != SYNCHRONIZATION_NEVER);
            DefaultTransactionStatus status = newTransactionStatus(
                    definition, transaction, true, newSynchronization, debugEnabled, suspendedResources);
            // 开启事务
            doBegin(transaction, definition);
            // 将事务信息绑定到当前线程(存在TransactionSynchronizationManager的threadLocal中)
            prepareSynchronization(status, definition);
            return status;
        }
        catch (RuntimeException ex) {
            resume(null, suspendedResources);
            throw ex;
        }
        catch (Error err) {
            resume(null, suspendedResources);
            throw err;
        }
    }
    else {
        // Create "empty" transaction: no actual transaction, but potentially synchronization.
        // 这里就是前面说的不需要事务的情况
        if (definition.getIsolationLevel() != TransactionDefinition.ISOLATION_DEFAULT && logger.isWarnEnabled()) {
            logger.warn("Custom isolation level specified but no actual transaction initiated; " +
                    "isolation level will effectively be ignored: " + definition);
        }
        boolean newSynchronization = (getTransactionSynchronization() == SYNCHRONIZATION_ALWAYS);
        return prepareTransactionStatus(definition, null, true, newSynchronization, debugEnabled, null);
    }
}
  1. doBegin方法
protected void doBegin(Object transaction, TransactionDefinition definition) {
    DataSourceTransactionObject txObject = (DataSourceTransactionObject) transaction;
    Connection con = null;

    try {
        if (txObject.getConnectionHolder() == null ||
                txObject.getConnectionHolder().isSynchronizedWithTransaction()) {
            // 从dataSource从获取一个连接,如果使用了连接池,则会从连接池中获取
            Connection newCon = this.dataSource.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);

        // 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).
        // 省略

        // Bind the session holder to the thread.
        // 绑定数据库连接到当前线程,这里的key是dataSource,所以如果事务中换了dataSource那事务就不生效了
        if (txObject.isNewConnectionHolder()) {
            TransactionSynchronizationManager.bindResource(getDataSource(), txObject.getConnectionHolder());
        }
    }

    catch (Throwable ex) {
        // 释放连接回连接池
        // 当前线程持有的连接句柄也一并释放
    }
}

到此为止,事务的信息全部准备好了,事务也开启了,这个时候业务方法就是在事务中执行了(如果配置了需要事务的话)

<-------------------------------我是罪恶的分割线------------------------------------>

事务执行完毕是需要进行资源的清理和释放的,spring在开启事务的时候绑定了很多信息到线程中,而现在的应用出于资源和性能的考虑,基本用的都是连接池和线程池,会有复用的可能性,如果资源的释放或者清理不到位,会有莫名其妙的问题出现(我这一次的问题就是这么来的。。。当然不是框架的问题,是自己操作有误)。

commitTransactionAfterReturning

这个方法是在业务方法正常返回后执行的,如果当前是存在事务的,则会调用事务管理器的commit方法

protected void commitTransactionAfterReturning(TransactionInfo txInfo) {
    if (txInfo != null && txInfo.hasTransaction()) {
        if (logger.isTraceEnabled()) {
            logger.trace("Completing transaction for [" + txInfo.getJoinpointIdentification() + "]");
        }
        txInfo.getTransactionManager().commit(txInfo.getTransactionStatus());
    }
}
  1. commit方法

这里会有一些标志位的检测,如果设置为true,那事务是不会提交的,会回滚。比如单元测试的时候不管什么情况我们都不想提交,spring就是靠这个标志位实现的。processRollback方法会在后面分析回滚的时候用到,这里先略过。

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);
        return;
    }
    if (!shouldCommitOnGlobalRollbackOnly() && defStatus.isGlobalRollbackOnly()) {
        if (defStatus.isDebug()) {
            logger.debug("Global transaction is marked as rollback-only but transactional code requested commit");
        }
        processRollback(defStatus);
        // Throw UnexpectedRollbackException only at outermost transaction boundary
        // or if explicitly asked to.
        if (status.isNewTransaction() || isFailEarlyOnGlobalRollbackOnly()) {
            throw new UnexpectedRollbackException(
                    "Transaction rolled back because it has been marked as rollback-only");
        }
        return;
    }

    processCommit(defStatus);
}

题外话

还记得TransactionSynchronizationManager这个类吗?里面维护了当前线程的一些信息,其中有一个就是TransactionSynchronization的列表,我们可以自定义实现一个TransactionSynchronization然后在事务中绑定到当前线程,这样可以实现在事务提交前或者提交后或者完成后执行一些我们自定义的操作。这次出现的问题就是因为我们业务代码里有自定义实现的TransactionSynchronization,至于具体原因后面再详述。

  1. processCommit方法

各个方法做的事见中文注释,这里要注意cleanupAfterCompletion方法,会去清理相关的资源。

private void processCommit(DefaultTransactionStatus status) throws TransactionException {
    try {
        boolean beforeCompletionInvoked = false;
        try {
            prepareForCommit(status);
            // 调用当前线程的TransactionSynchronization列表的对应方法
            // 这里注意,beforeCompletion方法的异常是会被吞掉的,beforeCommit的异常则会传播出去
            triggerBeforeCommit(status);
            triggerBeforeCompletion(status);
            beforeCompletionInvoked = true;
            boolean globalRollbackOnly = false;
            if (status.isNewTransaction() || isFailEarlyOnGlobalRollbackOnly()) {
                globalRollbackOnly = status.isGlobalRollbackOnly();
            }
            //如果用到了spring的NESTED传播,底层用到了数据库的savePoint,所以这里会释放
            if (status.hasSavepoint()) {
                if (status.isDebug()) {
                    logger.debug("Releasing transaction savepoint");
                }
                status.releaseHeldSavepoint();
            }
            // 只有最外层的事务这里才是true
            else if (status.isNewTransaction()) {
                if (status.isDebug()) {
                    logger.debug("Initiating transaction commit");
                }
                // 这里调用底层数据库连接的commit方法提交事务
                doCommit(status);
            }
            // Throw UnexpectedRollbackException if we have a global rollback-only
            // marker but still didn't get a corresponding exception from commit.
            if (globalRollbackOnly) {
                throw new UnexpectedRollbackException(
                        "Transaction silently rolled back because it has been marked as rollback-only");
            }
        }
        catch (UnexpectedRollbackException ex) {
            // can only be caused by doCommit
            // 这里调用TransactionSynchronization列表的afterCompletion方法,会吞掉异常
            triggerAfterCompletion(status, TransactionSynchronization.STATUS_ROLLED_BACK);
            throw ex;
        }
        catch (TransactionException ex) {
            // can only be caused by doCommit
            if (isRollbackOnCommitFailure()) {
                // 如果提交异常这里会回滚事务,里层也是调用TransactionSynchronization列表的afterCompletion方法
                // 只不过如果回滚失败,事务状态就是未知
                doRollbackOnCommitException(status, ex);
            }
            else {
                // 单纯调用TransactionSynchronization列表的afterCompletion方法
                triggerAfterCompletion(status, TransactionSynchronization.STATUS_UNKNOWN);
            }
            throw ex;
        }
        catch (RuntimeException ex) {
            if (!beforeCompletionInvoked) {
                // 如果前面beforeCompletion未调用,则这里调一次
                triggerBeforeCompletion(status);
            }
            // 回滚事务
            doRollbackOnCommitException(status, ex);
            throw ex;
        }
        catch (Error err) {
            if (!beforeCompletionInvoked) {
                triggerBeforeCompletion(status);
            }
            doRollbackOnCommitException(status, err);
            throw err;
        }

        // Trigger afterCommit callbacks, with an exception thrown there
        // propagated to callers but the transaction still considered as committed.
        try {
            // 调用TransactionSynchronization列表的afterCommit方法
            triggerAfterCommit(status);
        }
        finally {
            triggerAfterCompletion(status, TransactionSynchronization.STATUS_COMMITTED);
        }

    }
    finally {
        cleanupAfterCompletion(status);
    }
}
  1. cleanupAfterCompletion方法

这里关于资源的清理和释放操作比较多,稍有不慎,万劫不复啊。。。

private void cleanupAfterCompletion(DefaultTransactionStatus status) {
    // 将事务状态设为已完成
    status.setCompleted();
    // 最外层事务会去清理线程绑定的资源,包含TransactionSynchronization列表
    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");
        }
        resume(status.getTransaction(), (SuspendedResourcesHolder) status.getSuspendedResources());
    }
}

completeTransactionAfterThrowing

业务方法抛出异常后会执行本方法,主要就是事务的回滚以及定义的TransactionSynchronization列表的关联事务方法的执行,上面有提到,这里就不详述了。

protected void completeTransactionAfterThrowing(TransactionInfo txInfo, Throwable ex) {
    if (txInfo != null && txInfo.hasTransaction()) {
        if (logger.isTraceEnabled()) {
            logger.trace("Completing transaction for [" + txInfo.getJoinpointIdentification() +
                    "] after exception: " + ex);
        }
        if (txInfo.transactionAttribute.rollbackOn(ex)) {
            try {
                // 里层调用的就是processRollback方法
                txInfo.getTransactionManager().rollback(txInfo.getTransactionStatus());
            }
            catch (TransactionSystemException ex2) {
                logger.error("Application exception overridden by rollback exception", ex);
                ex2.initApplicationException(ex);
                throw ex2;
            }
            catch (RuntimeException ex2) {
                logger.error("Application exception overridden by rollback exception", ex);
                throw ex2;
            }
            catch (Error err) {
                logger.error("Application exception overridden by rollback error", ex);
                throw err;
            }
        }
        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 ex2) {
                logger.error("Application exception overridden by commit exception", ex);
                throw ex2;
            }
            catch (Error err) {
                logger.error("Application exception overridden by commit error", ex);
                throw err;
            }
        }
    }
}
  1. processRollback方法

这里很多方法前面都有提到,不详述了。

private void processRollback(DefaultTransactionStatus status) {
    try {
        try {
            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 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");
            }
        }
        catch (RuntimeException ex) {
            triggerAfterCompletion(status, TransactionSynchronization.STATUS_UNKNOWN);
            throw ex;
        }
        catch (Error err) {
            triggerAfterCompletion(status, TransactionSynchronization.STATUS_UNKNOWN);
            throw err;
        }
        triggerAfterCompletion(status, TransactionSynchronization.STATUS_ROLLED_BACK);
    }
    finally {
        cleanupAfterCompletion(status);
    }
}

总结

到此为止,spring关于事务的处理的源码差不多分析完了,回到正题,为啥会出现连接已关闭的情况呢?因为我们自定义了一个TransactionSynchronization来实现事务事件触发机制,并且在TransactionSynchronization的afterCompletion方法中操作了Dao层,也就是用到了数据库连接。看一下afterCompletion方法的注释,里面有提到这个时候事务已经提交或者回滚了,但是相关资源可能还没有释放,所以一旦有与数据库连接相关的代码,可能会参与到前面的事务中去。如果这里非要执行与数据库连接相关的操作,spring建议明确标注,并且使用新开事务的传播机制。框架封装好,使用需谨慎啊。

/**
 * Invoked after transaction commit/rollback.
 * Can perform resource cleanup <i>after</i> transaction completion.
 * <p><b>NOTE:</b> The transaction will have been committed or rolled back already,
 * but the transactional resources might still be active and accessible. As a
 * consequence, any data access code triggered at this point will still "participate"
 * in the original transaction, allowing to perform some cleanup (with no commit
 * following anymore!), unless it explicitly declares that it needs to run in a
 * separate transaction. Hence: <b>Use {@code PROPAGATION_REQUIRES_NEW}
 * for any transactional operation that is called from here.</b>
 * @param status completion status according to the {@code STATUS_*} constants
 * @throws RuntimeException in case of errors; will be <b>logged but not propagated</b>
 * (note: do not throw TransactionException subclasses here!)
 * @see #STATUS_COMMITTED
 * @see #STATUS_ROLLED_BACK
 * @see #STATUS_UNKNOWN
 * @see #beforeCompletion
 */
void afterCompletion(int status);
最后编辑于
©著作权归作者所有,转载或内容合作请联系作者
  • 序言:七十年代末,一起剥皮案震惊了整个滨河市,随后出现的几起案子,更是在滨河造成了极大的恐慌,老刑警刘岩,带你破解...
    沈念sama阅读 159,219评论 4 362
  • 序言:滨河连续发生了三起死亡事件,死亡现场离奇诡异,居然都是意外死亡,警方通过查阅死者的电脑和手机,发现死者居然都...
    沈念sama阅读 67,363评论 1 293
  • 文/潘晓璐 我一进店门,熙熙楼的掌柜王于贵愁眉苦脸地迎上来,“玉大人,你说我怎么就摊上这事。” “怎么了?”我有些...
    开封第一讲书人阅读 108,933评论 0 243
  • 文/不坏的土叔 我叫张陵,是天一观的道长。 经常有香客问我,道长,这世上最难降的妖魔是什么? 我笑而不...
    开封第一讲书人阅读 44,020评论 0 206
  • 正文 为了忘掉前任,我火速办了婚礼,结果婚礼上,老公的妹妹穿的比我还像新娘。我一直安慰自己,他们只是感情好,可当我...
    茶点故事阅读 52,400评论 3 287
  • 文/花漫 我一把揭开白布。 她就那样静静地躺着,像睡着了一般。 火红的嫁衣衬着肌肤如雪。 梳的纹丝不乱的头发上,一...
    开封第一讲书人阅读 40,640评论 1 219
  • 那天,我揣着相机与录音,去河边找鬼。 笑死,一个胖子当着我的面吹牛,可吹牛的内容都是我干的。 我是一名探鬼主播,决...
    沈念sama阅读 31,896评论 2 313
  • 文/苍兰香墨 我猛地睁开眼,长吁一口气:“原来是场噩梦啊……” “哼!你这毒妇竟也来了?” 一声冷哼从身侧响起,我...
    开封第一讲书人阅读 30,597评论 0 199
  • 序言:老挝万荣一对情侣失踪,失踪者是张志新(化名)和其女友刘颖,没想到半个月后,有当地人在树林里发现了一具尸体,经...
    沈念sama阅读 34,327评论 1 244
  • 正文 独居荒郊野岭守林人离奇死亡,尸身上长有42处带血的脓包…… 初始之章·张勋 以下内容为张勋视角 年9月15日...
    茶点故事阅读 30,581评论 2 246
  • 正文 我和宋清朗相恋三年,在试婚纱的时候发现自己被绿了。 大学时的朋友给我发了我未婚夫和他白月光在一起吃饭的照片。...
    茶点故事阅读 32,072评论 1 261
  • 序言:一个原本活蹦乱跳的男人离奇死亡,死状恐怖,灵堂内的尸体忽然破棺而出,到底是诈尸还是另有隐情,我是刑警宁泽,带...
    沈念sama阅读 28,399评论 2 253
  • 正文 年R本政府宣布,位于F岛的核电站,受9级特大地震影响,放射性物质发生泄漏。R本人自食恶果不足惜,却给世界环境...
    茶点故事阅读 33,054评论 3 236
  • 文/蒙蒙 一、第九天 我趴在偏房一处隐蔽的房顶上张望。 院中可真热闹,春花似锦、人声如沸。这庄子的主人今日做“春日...
    开封第一讲书人阅读 26,083评论 0 8
  • 文/苍兰香墨 我抬头看了看天上的太阳。三九已至,却和暖如春,着一层夹袄步出监牢的瞬间,已是汗流浃背。 一阵脚步声响...
    开封第一讲书人阅读 26,849评论 0 195
  • 我被黑心中介骗来泰国打工, 没想到刚下飞机就差点儿被人妖公主榨干…… 1. 我叫王不留,地道东北人。 一个月前我还...
    沈念sama阅读 35,672评论 2 274
  • 正文 我出身青楼,却偏偏与公主长得像,于是被迫代替她去往敌国和亲。 传闻我的和亲对象是个残疾皇子,可洞房花烛夜当晚...
    茶点故事阅读 35,585评论 2 270

推荐阅读更多精彩内容