Floodlight 消息监听IOFMessageListener

FloodlightProvider

  1. 处理交换机之间的连接并将 OpenFlow 的消息转化成其他模块可以监听的事件
  2. 决定某些特定的 OpenFlow 消息(即 PacketIn,FlowRemove,PortStatus 等)被分派到该侦听消息的模块的顺序,模块可以决定允许该消息进入下一个监听对象或者停止处理消息

FloodlightProvider 如何工作?

FloodlightProvider 使用 Netty 库来处理到交换机的线程和连接。
每个 OpenFlow 消息将通过一个 Netty 的线程进行处理,并执行与所有模块的消息相关联的所有逻辑
其他模块也可以注册类似交换机连接或断开和端口状态通知特定事件。
为了使模块注册为基于 OpenFlow 消息的,必须实现 IOFMessageListener 接口

要监听 OpenFlow 消息,要先向 FloodlightProvider 注册
调用 IFloodlightProviderService(具体由 Controller 类实现)的 addOFMessageListener 方法进行注册订阅
核心工作是在 ListenerDispatcher 类来完成。
每次增加观察者都会判断是否是终结点(也就是不被其他的 Listener 所依赖),因为最终确定这些观察者顺序的时候就是由这些终结点开始往前进行 DFS 遍历得到

Controller中实现 IFloodlightProviderService 的方法

@Override
public synchronized void addOFMessageListener(OFType type, IOFMessageListener listener) {
    //先判断与type对应的 ListenerDispatcher对象是否存在
    ListenerDispatcher<OFType, IOFMessageListener> ldd =
        messageListeners.get(type);
    if (ldd == null) {
        ldd = new ListenerDispatcher<OFType, IOFMessageListener>();
        messageListeners.put(type, ldd);
    }
  //注册监听type这个消息;
    ldd.addListener(type, listener);
}

ListenerDispatcher 维护这些观察者,有依赖关系

volatile List<T> listeners = new ArrayList<T>();

//每个OF msg都有唯一的ListenerDispatcher对象,观察者存在listeners链表中

private boolean ispre(U type, T l1, T l2) {
    return (l2.isCallbackOrderingPrereq(type, l1.getName()) ||
            l1.isCallbackOrderingPostreq(type, l2.getName()));
}

返回两个传入的监听器的顺序

 public void addListener(U type, T listener) {
    List<T> newlisteners = new ArrayList<T>();
    if (listeners != null)
        newlisteners.addAll(listeners);
    newlisteners.add(listener);
    // Find nodes without outgoing edges
    // 查找没有出边的节点
    List<T> terminals = new ArrayList<T>();
    for (T i : newlisteners) {
        boolean isterm = true;
        for (T j : newlisteners) {
            if (ispre(type, i, j)) {
                //两个都不关心前后顺序的时候
                isterm = false;
                break;
            }
        }
        if (isterm) {
            //关乎有前后顺序的监听模块存入
            terminals.add(i);
        }
    }
    if (terminals.size() == 0) {
        logger.error("No listener dependency solution: " +
                     "No listeners without incoming dependencies");
        listeners = newlisteners;
        return;
    }
    // visit depth-first traversing in the opposite order from
    // the dependencies.  Note we will not generally detect cycles
    /**
     * 以相反顺序访问深度优先遍历依赖。 注意我们通常不会检测周期
     */
    HashSet<T> visited = new HashSet<T>();
    List<T> ordering = new ArrayList<T>();
    for (T term : terminals) {
        //进行排序
        visit(newlisteners, type, visited, ordering, term);
    }
    listeners = ordering;
}

private void visit(List<T> newlisteners, U type, HashSet<T> visited,
                   List<T> ordering, T listener) {
    if (!visited.contains(listener)) {
        visited.add(listener);
        for (T i : newlisteners) {
            if (ispre(type, i, listener)) {
                visit(newlisteners, type, visited, ordering, i);
            }
        }
        ordering.add(listener);
        //
    }
}

监听器具有的方法

public interface IListener<T>

public enum Command {
    CONTINUE, STOP
}

状态值,用来判断是否继续执行

public String getName(); 
//用来判断 name 的这个模块是否要在当前对象之前执行
public boolean isCallbackOrderingPrereq(T type, String name);
//用来判断 name 的这个模块是否要在当前对象之后执行
public boolean isCallbackOrderingPostreq(T type, String name);

IOFMessageListener接口继承了 IListener 接口,同时定义了 receive 方法

public Command receive(IOFSwitch sw, OFMessage msg, FloodlightContext cntx);

返回 CONTINUE 或者 STOP,继续看每个继承这个接口的模块的重写

查看继承了 IOFMessageListener 的Type Hierarchy

TopologyManager 模块的IOFMessageListener 重写的方法

@Override
public String getName() {
    return MODULE_NAME; //此处为 topology,每个模块都有自己的 MODULE_NAME
}

@Override
public boolean isCallbackOrderingPrereq(OFType type, String name) {
    //从此处可以看出,在执行这个模块之前,需要先执行 MODULE_NAME 为 linkiscovery 的模块
    return "linkdiscovery".equals(name);
}

@Override
public boolean isCallbackOrderingPostreq(OFType type, String name) {
    return false;
}

@Override
public Command receive(IOFSwitch sw, OFMessage msg, FloodlightContext cntx) {
    switch (msg.getType()) {
    case PACKET_IN:
        ctrIncoming.increment();//计数器,加一
        //调用这里的执行方法
        return this.processPacketInMessage(sw, (OFPacketIn) msg, cntx);
    default:
        break;
    }

    return Command.CONTINUE;
}

通过 Type Hierarchy 可以找到Packet-In消息处理顺序的几个模块


FloodlightContextStore 数据结构

  • FloodlightContextStore 代表的是一种缓存模型(利用的是ConcurrentHashMap,线程安全的 HashMap)
  • 里面存储的是上下文相关的对象,能够根据相应的key得到具体的 Object
  • 存在的意义是Floodlight中注册监听某个事件的listener可以在被调用的时候直接从中取出上下文信息(context information)

基本数据结构,这是一个上下文对象,Floodlight代码监听器可以注册它,稍后可以检索与事件相关联的上下文信息

public class FloodlightContext {
    protected ConcurrentHashMap<String, Object> storage =
            new ConcurrentHashMap<String, Object>();

    public ConcurrentHashMap<String, Object> getStorage() {
        return storage;
    }
}

创建了一个 HashMap storage,

public class FloodlightContextStore<V> {
    
    @SuppressWarnings("unchecked")
    public V get(FloodlightContext bc, String key) {
        return (V)bc.storage.get(key);
    }
    
    public void put(FloodlightContext bc, String key, V value) {
        bc.storage.put(key, value);
    }
    
    public void remove(FloodlightContext bc, String key) {
        bc.storage.remove(key);
    }
}

一个FloodlightContextStore对象,可用于PACKET-IN有效内容,消息对象是Ethernet类型

public static final FloodlightContextStore<Ethernet> bcStore =
        new FloodlightContextStore<Ethernet>();

LinkDiscoveryManager 模块

  • 链接发现服务负责发现和维护 OpenFlow 网络中的网络连接的状态

IOFMessageListener 的 receive 方法

@Override
public Command receive(IOFSwitch sw, OFMessage msg,
        FloodlightContext cntx) {
    switch (msg.getType()) {
    case PACKET_IN:
        ctrIncoming.increment();
        return this.handlePacketIn(sw.getId(), (OFPacketIn) msg,
                cntx);
    default:
        break;
    }
    return Command.CONTINUE;
}

主要使用了 handlePacketIn()方法

protected Command handlePacketIn(DatapathId sw, OFPacketIn pi,
        FloodlightContext cntx) {
    //提取 Packet-In 的有效分组内容
    Ethernet eth = IFloodlightProviderService.bcStore.get(cntx,
            IFloodlightProviderService.CONTEXT_PI_PAYLOAD);
    OFPort inPort = (pi.getVersion().compareTo(OFVersion.OF_12) < 0 ? pi.getInPort() : pi.getMatch().get(MatchField.IN_PORT));
    if (eth.getPayload() instanceof BSN) {
        BSN bsn = (BSN) eth.getPayload();
        if (bsn == null) return Command.STOP;
        if (bsn.getPayload() == null) return Command.STOP;
        // It could be a packet other than BSN LLDP, therefore
        // continue with the regular processing.
        // 它可以是除BSN LLDP之外的分组,因此继续进行常规处理。
        if (bsn.getPayload() instanceof LLDP == false)
            return Command.CONTINUE;
        return handleLldp((LLDP) bsn.getPayload(), sw, inPort, false, cntx);
    } else if (eth.getPayload() instanceof LLDP) {
        return handleLldp((LLDP) eth.getPayload(), sw, inPort, true, cntx);
    } else if (eth.getEtherType().getValue() < 1536 && eth.getEtherType().getValue() >= 17) {
        long destMac = eth.getDestinationMACAddress().getLong();
        if ((destMac & LINK_LOCAL_MASK) == LINK_LOCAL_VALUE) {
            ctrLinkLocalDrops.increment();
            if (log.isTraceEnabled()) {
                log.trace("Ignoring packet addressed to 802.1D/Q "
                        + "reserved address.");
            }
            return Command.STOP;
        }
    } else if (eth.getEtherType().getValue() < 17) {
        log.error("Received invalid ethertype of {}.", eth.getEtherType());
        return Command.STOP;
    }

    if (ignorePacketInFromSource(eth.getSourceMACAddress())) {
        ctrIgnoreSrcMacDrops.increment();
        return Command.STOP;
    }

    // If packet-in is from a quarantine port, stop processing.
    NodePortTuple npt = new NodePortTuple(sw, inPort);
    if (quarantineQueue.contains(npt)) {
        ctrQuarantineDrops.increment();
        return Command.STOP;
    }

    return Command.CONTINUE;
}

TopolopyManager

  • 为控制器维护拓扑信息,以及在网络中寻找路由

IOFMessageListener 的 receive 方法

@Override
public Command receive(IOFSwitch sw, OFMessage msg, FloodlightContext cntx) {
    switch (msg.getType()) {
    case PACKET_IN:
        ctrIncoming.increment();
        return this.processPacketInMessage(sw, (OFPacketIn) msg, cntx);
    default:
        break;
    }

    return Command.CONTINUE;
}

主要使用了processPacketInMessage()方法

protected Command processPacketInMessage(IOFSwitch sw, OFPacketIn pi, FloodlightContext cntx) {
    // get the packet-in switch.
    Ethernet eth =
            IFloodlightProviderService.bcStore.
            get(cntx,IFloodlightProviderService.CONTEXT_PI_PAYLOAD);

    if (eth.getPayload() instanceof BSN) {
        BSN bsn = (BSN) eth.getPayload();
        if (bsn == null) return Command.STOP;
        if (bsn.getPayload() == null) return Command.STOP;

        // 可能不是 BSN LLDP,继续常规处理
        if (bsn.getPayload() instanceof LLDP == false)
            return Command.CONTINUE;

        doFloodBDDP(sw.getId(), pi, cntx);
        return Command.STOP;
    } else {
        return dropFilter(sw.getId(), pi, cntx);
    }
}

DeviceManagerImpl

  • DeviceManager基于在网络中看到的MAC地址创建设备
  • 它跟踪映射到设备的任何网络地址及其在网络中的位置

设备管理器通过 PACKET-IN 消息请求了解设备,通过 PACKET-IN 消息获取信息,根据实体如何建立进行分类。默认情况下,entity classifies 使用 MAC 地址和 VLAN 来识别设备。这两个属性定义一个独一无二的设备。设备管理器将了解其他属性,如 IP 地址。
信息中的一个重要的部分是设备的连接点,如果一个交换机接受到一个 PACKET-IN 消息,则交换机将会创建一个连接点,设备也会根据时间清空连接点,IP 地址,以及设备本身,最近看到的时间戳是用来保持清空过程的控制

IOFMessageListener 的 receive 方法

@Override
public Command receive(IOFSwitch sw, OFMessage msg,
        FloodlightContext cntx) {
    switch (msg.getType()) {
    case PACKET_IN:
        cntIncoming.increment();
        return this.processPacketInMessage(sw, (OFPacketIn) msg, cntx);
    default:
        break;
    }
    return Command.CONTINUE;
}

主要使用了processPacketInMessage()方法

protected Command processPacketInMessage(IOFSwitch sw, OFPacketIn pi, FloodlightContext cntx) {
    Ethernet eth = IFloodlightProviderService.bcStore.get(cntx,IFloodlightProviderService.CONTEXT_PI_PAYLOAD);
    OFPort inPort = (pi.getVersion().compareTo(OFVersion.OF_12) < 0 ? pi.getInPort() : pi.getMatch().get(MatchField.IN_PORT));
    // Extract source entity information
    Entity srcEntity = getSourceEntityFromPacket(eth, sw.getId(), inPort);
    if (srcEntity == null) {
        cntInvalidSource.increment();
        return Command.STOP;
    }

    // Learn from ARP packet for special VRRP settings.
    // In VRRP settings, the source MAC address and sender MAC
    // addresses can be different.  In such cases, we need to learn
    // the IP to MAC mapping of the VRRP IP address.  The source
    // entity will not have that information.  Hence, a separate call
    // to learn devices in such cases.
    learnDeviceFromArpResponseData(eth, sw.getId(), inPort);

    // Learn/lookup device information
    Device srcDevice = learnDeviceByEntity(srcEntity);
    if (srcDevice == null) {
        cntNoSource.increment();
        return Command.STOP;
    }

    // Store the source device in the context
    fcStore.put(cntx, CONTEXT_SRC_DEVICE, srcDevice);

    // Find the device matching the destination from the entity
    // classes of the source.
    if (eth.getDestinationMACAddress().getLong() == 0) {
        cntInvalidDest.increment();
        return Command.STOP;
    }
    Entity dstEntity = getDestEntityFromPacket(eth);
    Device dstDevice = null;
    if (dstEntity != null) {
        dstDevice = findDestByEntity(srcDevice.getEntityClass(), dstEntity);
        if (dstDevice != null)
            fcStore.put(cntx, CONTEXT_DST_DEVICE, dstDevice);
        else
            cntNoDest.increment();
    } else {
        cntNoDest.increment();
    }

    if (logger.isTraceEnabled()) {
        logger.trace("Received PI: {} on switch {}, port {} *** eth={}" +
                " *** srcDev={} *** dstDev={} *** ",
                new Object[] { pi, sw.getId().toString(), inPort, eth,
                srcDevice, dstDevice });
    }

    snoopDHCPClientName(eth, srcDevice);

    return Command.CONTINUE;
}

vitualNetworkFilter

  • 虚拟网络过滤器模块是基于虚拟化网络的数据链路层,它允许你在独立的数据链路层上创建多个逻辑链路
  • 若是使用 floodlightdefault.properties 则没有这个模块

如何工作

在 Floodlight 启动时,没有虚拟网络创建,这时主机之间不能相互通信。
一旦用户创建虚拟网络,则主机就能够被添加。
在 PACKET-IN 消息转发实现前,模块将启动。
一旦,一条 PACKET-IN 消息被接受,模块将查看源 MAC 地址和目的 MAC 地址,如果2个 MAC 地址是同一个虚拟网络,模块将返回 Command.CONINUE消息,并且继续处理流。如果MAC 地址不在同一个虚拟网络则返回 Command.STOP 消息,并丢弃包

限制

  • 必须在同一个物理数据链路层中
  • 每个虚拟网络只能拥有一个网关()【一个网关可被多个虚拟网络共享】
  • 多播和广播没有被隔离
  • 允许所有的 DHCP 路径

配置

该模块可用于 OpenStack 的部署
包含此模块的默认配置文件位置:
src/main/resources/neutron.properties

IOFMessageListener 的 receive 方法

@Override
public Command receive(IOFSwitch sw, OFMessage msg, FloodlightContext cntx) {
    switch (msg.getType()) {
    case PACKET_IN:
        return processPacketIn(sw, (OFPacketIn)msg, cntx);
    default:
        break;
    }
    log.warn("Received unexpected message {}", msg);
    return Command.CONTINUE;
}

主要使用了processPacketIn()方法

protected Command processPacketIn(IOFSwitch sw, OFPacketIn msg, FloodlightContext cntx) {
    Ethernet eth = IFloodlightProviderService.bcStore.get(cntx,
            IFloodlightProviderService.CONTEXT_PI_PAYLOAD);
    Command ret = Command.STOP;
    String srcNetwork = macToGuid.get(eth.getSourceMACAddress());
    // If the host is on an unknown network we deny it.
    // We make exceptions for ARP and DHCP.
    if (eth.isBroadcast() || eth.isMulticast() || isDefaultGateway(eth) || isDhcpPacket(eth)) {
        ret = Command.CONTINUE;
    } else if (srcNetwork == null) {
        log.trace("Blocking traffic from host {} because it is not attached to any network.",
                eth.getSourceMACAddress().toString());
        ret = Command.STOP;
    } else if (oneSameNetwork(eth.getSourceMACAddress(), eth.getDestinationMACAddress())) {
        // if they are on the same network continue
        ret = Command.CONTINUE;
    }

    if (log.isTraceEnabled())
        log.trace("Results for flow between {} and {} is {}",
                new Object[] {eth.getSourceMACAddress(), eth.getDestinationMACAddress(), ret});
    /*
     * TODO - figure out how to still detect gateways while using
     * drop mods
    if (ret == Command.STOP) {
        if (!(eth.getPayload() instanceof ARP))
            doDropFlow(sw, msg, cntx);
    }
     */
    return ret;
}

LoadBalancer

IOFMessageListener 的 receive 方法

@Override
public net.floodlightcontroller.core.IListener.Command
        receive(IOFSwitch sw, OFMessage msg, FloodlightContext cntx) {
    switch (msg.getType()) {
        case PACKET_IN:
            return processPacketIn(sw, (OFPacketIn)msg, cntx);
        default:
            break;
    }
    log.warn("Received unexpected message {}", msg);
    return Command.CONTINUE;
}

主要使用了processPacketIn()方法

private net.floodlightcontroller.core.IListener.Command processPacketIn(IOFSwitch sw, OFPacketIn pi, FloodlightContext cntx) {
    
    Ethernet eth = IFloodlightProviderService.bcStore.get(cntx, IFloodlightProviderService.CONTEXT_PI_PAYLOAD);
    IPacket pkt = eth.getPayload(); 

    if (eth.isBroadcast() || eth.isMulticast()) {
        // handle ARP for VIP
        if (pkt instanceof ARP) {
            // retrieve arp to determine target IP address                                                       
            ARP arpRequest = (ARP) eth.getPayload();

            IPv4Address targetProtocolAddress = arpRequest.getTargetProtocolAddress();

            if (vipIpToId.containsKey(targetProtocolAddress.getInt())) {
                String vipId = vipIpToId.get(targetProtocolAddress.getInt());
                vipProxyArpReply(sw, pi, cntx, vipId);
                return Command.STOP;
            }
        }
    } else {
        // currently only load balance IPv4 packets - no-op for other traffic 
        if (pkt instanceof IPv4) {
            IPv4 ip_pkt = (IPv4) pkt;
            
            // If match Vip and port, check pool and choose member
            int destIpAddress = ip_pkt.getDestinationAddress().getInt();
            
            if (vipIpToId.containsKey(destIpAddress)){
                IPClient client = new IPClient();
                client.ipAddress = ip_pkt.getSourceAddress();
                client.nw_proto = ip_pkt.getProtocol();
                if (ip_pkt.getPayload() instanceof TCP) {
                    TCP tcp_pkt = (TCP) ip_pkt.getPayload();
                    client.srcPort = tcp_pkt.getSourcePort();
                    client.targetPort = tcp_pkt.getDestinationPort();
                }
                if (ip_pkt.getPayload() instanceof UDP) {
                    UDP udp_pkt = (UDP) ip_pkt.getPayload();
                    client.srcPort = udp_pkt.getSourcePort();
                    client.targetPort = udp_pkt.getDestinationPort();
                }
                if (ip_pkt.getPayload() instanceof ICMP) {
                    client.srcPort = TransportPort.of(8); 
                    client.targetPort = TransportPort.of(0); 
                }
                
                LBVip vip = vips.get(vipIpToId.get(destIpAddress));
                if (vip == null)            // fix dereference violations           
                    return Command.CONTINUE;
                LBPool pool = pools.get(vip.pickPool(client));
                if (pool == null)           // fix dereference violations
                    return Command.CONTINUE;
                LBMember member = members.get(pool.pickMember(client));
                if(member == null)          //fix dereference violations
                    return Command.CONTINUE;
                
                // for chosen member, check device manager and find and push routes, in both directions                    
                pushBidirectionalVipRoutes(sw, pi, cntx, client, member);
               
                // packet out based on table rule
                pushPacket(pkt, sw, pi.getBufferId(), (pi.getVersion().compareTo(OFVersion.OF_12) < 0) ? pi.getInPort() : pi.getMatch().get(MatchField.IN_PORT), OFPort.TABLE,
                            cntx, true);

                return Command.STOP;
            }
        }
    }
    // bypass non-load-balanced traffic for normal processing (forwarding)
    return Command.CONTINUE;
}

ForwardingBase

IOFMessageListener 的 receive 方法

 @Override
public Command receive(IOFSwitch sw, OFMessage msg, FloodlightContext cntx) {
    switch (msg.getType()) {
    case PACKET_IN:
        IRoutingDecision decision = null;
        if (cntx != null) {
            decision = RoutingDecision.rtStore.get(cntx, IRoutingDecision.CONTEXT_DECISION);
        }

        return this.processPacketInMessage(sw, (OFPacketIn) msg, decision, cntx);
    default:
        break;
    }
    return Command.CONTINUE;
}

主要使用了processPacketInMessage()方法

public abstract Command processPacketInMessage(IOFSwitch sw, OFPacketIn pi, 
        IRoutingDecision decision, FloodlightContext cntx);

所有继承了 ForwardingBase 的子类Forwarding重写了这个方法,实现具体的操作

@Override
public Command processPacketInMessage(IOFSwitch sw, OFPacketIn pi, IRoutingDecision decision, FloodlightContext cntx) {
    Ethernet eth = IFloodlightProviderService.bcStore.get(cntx, IFloodlightProviderService.CONTEXT_PI_PAYLOAD);
    // We found a routing decision (i.e. Firewall is enabled... it's the only thing that makes RoutingDecisions)
    if (decision != null) {
        if (log.isTraceEnabled()) {
            log.trace("Forwarding decision={} was made for PacketIn={}", decision.getRoutingAction().toString(), pi);
        }

        switch(decision.getRoutingAction()) {
        case NONE:
            // don't do anything
            return Command.CONTINUE;
        case FORWARD_OR_FLOOD:
        case FORWARD:
            doForwardFlow(sw, pi, decision, cntx, false);
            return Command.CONTINUE;
        case MULTICAST:
            // treat as broadcast
            doFlood(sw, pi, decision, cntx);
            return Command.CONTINUE;
        case DROP:
            doDropFlow(sw, pi, decision, cntx);
            return Command.CONTINUE;
        default:
            log.error("Unexpected decision made for this packet-in={}", pi, decision.getRoutingAction());
            return Command.CONTINUE;
        }
    } else { // No routing decision was found. Forward to destination or flood if bcast or mcast.
        if (log.isTraceEnabled()) {
            log.trace("No decision was made for PacketIn={}, forwarding", pi);
        }

        if (eth.isBroadcast() || eth.isMulticast()) {
            doFlood(sw, pi, decision, cntx);
        } else {
            doForwardFlow(sw, pi, decision, cntx, false);
        }
    }

    return Command.CONTINUE;
}

PACKET-IN

最后编辑于
©著作权归作者所有,转载或内容合作请联系作者
  • 序言:七十年代末,一起剥皮案震惊了整个滨河市,随后出现的几起案子,更是在滨河造成了极大的恐慌,老刑警刘岩,带你破解...
    沈念sama阅读 203,547评论 6 477
  • 序言:滨河连续发生了三起死亡事件,死亡现场离奇诡异,居然都是意外死亡,警方通过查阅死者的电脑和手机,发现死者居然都...
    沈念sama阅读 85,399评论 2 381
  • 文/潘晓璐 我一进店门,熙熙楼的掌柜王于贵愁眉苦脸地迎上来,“玉大人,你说我怎么就摊上这事。” “怎么了?”我有些...
    开封第一讲书人阅读 150,428评论 0 337
  • 文/不坏的土叔 我叫张陵,是天一观的道长。 经常有香客问我,道长,这世上最难降的妖魔是什么? 我笑而不...
    开封第一讲书人阅读 54,599评论 1 274
  • 正文 为了忘掉前任,我火速办了婚礼,结果婚礼上,老公的妹妹穿的比我还像新娘。我一直安慰自己,他们只是感情好,可当我...
    茶点故事阅读 63,612评论 5 365
  • 文/花漫 我一把揭开白布。 她就那样静静地躺着,像睡着了一般。 火红的嫁衣衬着肌肤如雪。 梳的纹丝不乱的头发上,一...
    开封第一讲书人阅读 48,577评论 1 281
  • 那天,我揣着相机与录音,去河边找鬼。 笑死,一个胖子当着我的面吹牛,可吹牛的内容都是我干的。 我是一名探鬼主播,决...
    沈念sama阅读 37,941评论 3 395
  • 文/苍兰香墨 我猛地睁开眼,长吁一口气:“原来是场噩梦啊……” “哼!你这毒妇竟也来了?” 一声冷哼从身侧响起,我...
    开封第一讲书人阅读 36,603评论 0 258
  • 序言:老挝万荣一对情侣失踪,失踪者是张志新(化名)和其女友刘颖,没想到半个月后,有当地人在树林里发现了一具尸体,经...
    沈念sama阅读 40,852评论 1 297
  • 正文 独居荒郊野岭守林人离奇死亡,尸身上长有42处带血的脓包…… 初始之章·张勋 以下内容为张勋视角 年9月15日...
    茶点故事阅读 35,605评论 2 321
  • 正文 我和宋清朗相恋三年,在试婚纱的时候发现自己被绿了。 大学时的朋友给我发了我未婚夫和他白月光在一起吃饭的照片。...
    茶点故事阅读 37,693评论 1 329
  • 序言:一个原本活蹦乱跳的男人离奇死亡,死状恐怖,灵堂内的尸体忽然破棺而出,到底是诈尸还是另有隐情,我是刑警宁泽,带...
    沈念sama阅读 33,375评论 4 318
  • 正文 年R本政府宣布,位于F岛的核电站,受9级特大地震影响,放射性物质发生泄漏。R本人自食恶果不足惜,却给世界环境...
    茶点故事阅读 38,955评论 3 307
  • 文/蒙蒙 一、第九天 我趴在偏房一处隐蔽的房顶上张望。 院中可真热闹,春花似锦、人声如沸。这庄子的主人今日做“春日...
    开封第一讲书人阅读 29,936评论 0 19
  • 文/苍兰香墨 我抬头看了看天上的太阳。三九已至,却和暖如春,着一层夹袄步出监牢的瞬间,已是汗流浃背。 一阵脚步声响...
    开封第一讲书人阅读 31,172评论 1 259
  • 我被黑心中介骗来泰国打工, 没想到刚下飞机就差点儿被人妖公主榨干…… 1. 我叫王不留,地道东北人。 一个月前我还...
    沈念sama阅读 43,970评论 2 349
  • 正文 我出身青楼,却偏偏与公主长得像,于是被迫代替她去往敌国和亲。 传闻我的和亲对象是个残疾皇子,可洞房花烛夜当晚...
    茶点故事阅读 42,414评论 2 342

推荐阅读更多精彩内容