Java 类net.floodlightcontroller.core.internal.OFStatisticsFuture 实例源码

项目:QoS-floodlight    文件:OFSwitchBase.java   
@Override
public void deliverStatisticsReply(OFStatisticsReply reply) {
    checkForTableStats(reply);
    OFStatisticsFuture future = this.statsFutureMap.get(reply.getXid());
    if (future != null) {
        future.deliverFuture(this, reply);
        // The future will ultimately unregister itself and call
        // cancelStatisticsReply
        return;
    }
    /* Transaction id was not found in statsFutureMap.check the other map */
    IOFMessageListener caller = this.iofMsgListenersMap.get(reply.getXid());
    if (caller != null) {
        caller.receive(this, reply, null);
    }
}
项目:floodlight_with_topoguard    文件:OFSwitchBase.java   
@Override
public void deliverStatisticsReply(OFStatisticsReply reply) {
    checkForTableStats(reply);
    OFStatisticsFuture future = this.statsFutureMap.get(reply.getXid());
    if (future != null) {
        future.deliverFuture(this, reply);
        // The future will ultimately unregister itself and call
        // cancelStatisticsReply
        return;
    }
    /* Transaction id was not found in statsFutureMap.check the other map */
    IOFMessageListener caller = this.iofMsgListenersMap.get(reply.getXid());
    if (caller != null) {
        caller.receive(this, reply, null);
    }
}
项目:FloodligtModule    文件:OFSwitchBase.java   
@Override
public void deliverStatisticsReply(OFStatisticsReply reply) {
    checkForTableStats(reply);
    OFStatisticsFuture future = this.statsFutureMap.get(reply.getXid());
    if (future != null) {
        future.deliverFuture(this, reply);
        // The future will ultimately unregister itself and call
        // cancelStatisticsReply
        return;
    }
    /* Transaction id was not found in statsFutureMap.check the other map */
    IOFMessageListener caller = this.iofMsgListenersMap.get(reply.getXid());
    if (caller != null) {
        caller.receive(this, reply, null);
    }
}
项目:multicastSDN    文件:OFSwitchBase.java   
@Override
public void deliverStatisticsReply(OFStatisticsReply reply) {
    checkForTableStats(reply);
    OFStatisticsFuture future = this.statsFutureMap.get(reply.getXid());
    if (future != null) {
        future.deliverFuture(this, reply);
        // The future will ultimately unregister itself and call
        // cancelStatisticsReply
        return;
    }
    /* Transaction id was not found in statsFutureMap.check the other map */
    IOFMessageListener caller = this.iofMsgListenersMap.get(reply.getXid());
    if (caller != null) {
        caller.receive(this, reply, null);
    }
}
项目:floodlight-nfv    文件:OFSwitchBase.java   
public OFSwitchBase() {
    this.stringId = null;
    this.attributes = new ConcurrentHashMap<Object, Object>();
    this.connectedSince = new Date();
    this.transactionIdSource = new AtomicInteger();
    this.portLock = new Object();
    this.portsByNumber = new ConcurrentHashMap<Short, OFPhysicalPort>();
    this.portsByName = new ConcurrentHashMap<String, OFPhysicalPort>();
    this.connected = true;
    this.statsFutureMap = new ConcurrentHashMap<Integer,OFStatisticsFuture>();
    this.featuresFutureMap = new ConcurrentHashMap<Integer,OFFeaturesReplyFuture>();
    this.iofMsgListenersMap = new ConcurrentHashMap<Integer,IOFMessageListener>();
    this.role = null;
    this.timedCache = new TimedCache<Long>(100, 5*1000 );  // 5 seconds interval
    this.listenerLock = new ReentrantReadWriteLock();
    this.portBroadcastCacheHitMap = new ConcurrentHashMap<Short, AtomicLong>();

    // Defaults properties for an ideal switch
    this.setAttribute(PROP_FASTWILDCARDS, OFMatch.OFPFW_ALL);
    this.setAttribute(PROP_SUPPORTS_OFPP_FLOOD, new Boolean(true));
    this.setAttribute(PROP_SUPPORTS_OFPP_TABLE, new Boolean(true));
}
项目:floodlight-oss    文件:OFSwitchBase.java   
public OFSwitchBase() {
    this.stringId = null;
    this.attributes = new ConcurrentHashMap<Object, Object>();
    this.connectedSince = new Date();
    this.transactionIdSource = new AtomicInteger();
    this.portLock = new Object();
    this.portsByNumber = new ConcurrentHashMap<Short, OFPhysicalPort>();
    this.portsByName = new ConcurrentHashMap<String, OFPhysicalPort>();
    this.connected = true;
    this.statsFutureMap = new ConcurrentHashMap<Integer,OFStatisticsFuture>();
    this.featuresFutureMap = new ConcurrentHashMap<Integer,OFFeaturesReplyFuture>();
    this.iofMsgListenersMap = new ConcurrentHashMap<Integer,IOFMessageListener>();
    this.role = null;
    this.timedCache = new TimedCache<Long>(100, 5*1000 );  // 5 seconds interval
    this.listenerLock = new ReentrantReadWriteLock();
    this.portBroadcastCacheHitMap = new ConcurrentHashMap<Short, AtomicLong>();

    // Defaults properties for an ideal switch
    this.setAttribute(PROP_FASTWILDCARDS, OFMatch.OFPFW_ALL);
    this.setAttribute(PROP_SUPPORTS_OFPP_FLOOD, new Boolean(true));
    this.setAttribute(PROP_SUPPORTS_OFPP_TABLE, new Boolean(true));
}
项目:FL_HAND    文件:OFSwitchBase.java   
public OFSwitchBase() {
    this.stringId = null;
    this.attributes = new ConcurrentHashMap<Object, Object>();
    this.connectedSince = new Date();
    this.transactionIdSource = new AtomicInteger();
    this.portLock = new Object();
    this.portsByNumber = new ConcurrentHashMap<Short, OFPhysicalPort>();
    this.portsByName = new ConcurrentHashMap<String, OFPhysicalPort>();
    this.connected = true;
    this.statsFutureMap = new ConcurrentHashMap<Integer,OFStatisticsFuture>();
    this.featuresFutureMap = new ConcurrentHashMap<Integer,OFFeaturesReplyFuture>();
    this.iofMsgListenersMap = new ConcurrentHashMap<Integer,IOFMessageListener>();
    this.role = null;
    this.timedCache = new TimedCache<Long>(100, 5*1000 );  // 5 seconds interval
    this.listenerLock = new ReentrantReadWriteLock();
    this.portBroadcastCacheHitMap = new ConcurrentHashMap<Short, Long>();

    // Defaults properties for an ideal switch
    this.setAttribute(PROP_FASTWILDCARDS, OFMatch.OFPFW_ALL);
    this.setAttribute(PROP_SUPPORTS_OFPP_FLOOD, new Boolean(true));
    this.setAttribute(PROP_SUPPORTS_OFPP_TABLE, new Boolean(true));
}
项目:QoS-floodlight    文件:OFSwitchBase.java   
public OFSwitchBase() {
    this.stringId = null;
    this.attributes = new ConcurrentHashMap<Object, Object>();
    this.connectedSince = null;
    this.transactionIdSource = new AtomicInteger();
    this.connected = false;
    this.statsFutureMap = new ConcurrentHashMap<Integer,OFStatisticsFuture>();
    this.featuresFutureMap = new ConcurrentHashMap<Integer,OFFeaturesReplyFuture>();
    this.iofMsgListenersMap = new ConcurrentHashMap<Integer,IOFMessageListener>();
    this.role = null;
    this.timedCache = new TimedCache<Long>(100, 5*1000 );  // 5 seconds interval
    this.portBroadcastCacheHitMap = new ConcurrentHashMap<Short, AtomicLong>();
    this.description = new OFDescriptionStatistics();
    this.lastMessageTime = System.currentTimeMillis();

    this.portManager = new PortManager();

    // Defaults properties for an ideal switch
    this.setAttribute(PROP_FASTWILDCARDS, OFMatch.OFPFW_ALL);
    this.setAttribute(PROP_SUPPORTS_OFPP_FLOOD, Boolean.valueOf(true));
    this.setAttribute(PROP_SUPPORTS_OFPP_TABLE, Boolean.valueOf(true));
    if (packetInRateThresholdHigh == 0) {
        packetInRateThresholdHigh = Integer.MAX_VALUE;
    } else {
        packetInRateThresholdLow = packetInRateThresholdHigh / 2;
    }
}
项目:QoS-floodlight    文件:OFSwitchBase.java   
@Override
public Future<List<OFStatistics>> queryStatistics(OFStatisticsRequest request) throws IOException {
    request.setXid(getNextTransactionId());
    OFStatisticsFuture future = new OFStatisticsFuture(threadPool, this, request.getXid());
    this.statsFutureMap.put(request.getXid(), future);
    List<OFMessage> msglist = new ArrayList<OFMessage>(1);
    msglist.add(request);
    this.write(msglist);
    return future;
}
项目:QoS-floodlight    文件:OFSwitchBase.java   
@Override
public void cancelAllStatisticsReplies() {
    /* we don't need to be synchronized here. Even if another thread
     * modifies the map while we're cleaning up the future will eventuall
     * timeout */
    for (OFStatisticsFuture f : statsFutureMap.values()) {
        f.cancel(true);
    }
    statsFutureMap.clear();
    iofMsgListenersMap.clear();
}
项目:floodlight_with_topoguard    文件:OFSwitchBase.java   
public OFSwitchBase() {
    this.stringId = null;
    this.attributes = new ConcurrentHashMap<Object, Object>();
    this.connectedSince = null;
    this.transactionIdSource = new AtomicInteger();
    this.connected = false;
    this.statsFutureMap = new ConcurrentHashMap<Integer,OFStatisticsFuture>();
    this.featuresFutureMap = new ConcurrentHashMap<Integer,OFFeaturesReplyFuture>();
    this.iofMsgListenersMap = new ConcurrentHashMap<Integer,IOFMessageListener>();
    this.role = null;
    this.timedCache = new TimedCache<Long>(100, 5*1000 );  // 5 seconds interval
    this.portBroadcastCacheHitMap = new ConcurrentHashMap<Short, AtomicLong>();
    this.description = new OFDescriptionStatistics();
    this.lastMessageTime = System.currentTimeMillis();

    this.portManager = new PortManager();

    // Defaults properties for an ideal switch
    this.setAttribute(PROP_FASTWILDCARDS, OFMatch.OFPFW_ALL);
    this.setAttribute(PROP_SUPPORTS_OFPP_FLOOD, Boolean.valueOf(true));
    this.setAttribute(PROP_SUPPORTS_OFPP_TABLE, Boolean.valueOf(true));
    if (packetInRateThresholdHigh == 0) {
        packetInRateThresholdHigh = Integer.MAX_VALUE;
    } else {
        packetInRateThresholdLow = packetInRateThresholdHigh / 2;
    }
}
项目:floodlight_with_topoguard    文件:OFSwitchBase.java   
@Override
public Future<List<OFStatistics>> queryStatistics(OFStatisticsRequest request) throws IOException {
    request.setXid(getNextTransactionId());
    OFStatisticsFuture future = new OFStatisticsFuture(threadPool, this, request.getXid());
    this.statsFutureMap.put(request.getXid(), future);
    List<OFMessage> msglist = new ArrayList<OFMessage>(1);
    msglist.add(request);
    this.write(msglist);
    return future;
}
项目:floodlight_with_topoguard    文件:OFSwitchBase.java   
@Override
public void cancelAllStatisticsReplies() {
    /* we don't need to be synchronized here. Even if another thread
     * modifies the map while we're cleaning up the future will eventuall
     * timeout */
    for (OFStatisticsFuture f : statsFutureMap.values()) {
        f.cancel(true);
    }
    statsFutureMap.clear();
    iofMsgListenersMap.clear();
}
项目:FloodligtModule    文件:OFSwitchBase.java   
public OFSwitchBase() {
    this.stringId = null;
    this.attributes = new ConcurrentHashMap<Object, Object>();
    this.connectedSince = null;
    this.transactionIdSource = new AtomicInteger();
    this.connected = false;
    this.statsFutureMap = new ConcurrentHashMap<Integer,OFStatisticsFuture>();
    this.featuresFutureMap = new ConcurrentHashMap<Integer,OFFeaturesReplyFuture>();
    this.iofMsgListenersMap = new ConcurrentHashMap<Integer,IOFMessageListener>();
    this.role = null;
    this.timedCache = new TimedCache<Long>(100, 5*1000 );  // 5 seconds interval
    this.portBroadcastCacheHitMap = new ConcurrentHashMap<Short, AtomicLong>();
    this.description = new OFDescriptionStatistics();
    this.lastMessageTime = System.currentTimeMillis();

    this.portManager = new PortManager();

    // Defaults properties for an ideal switch
    this.setAttribute(PROP_FASTWILDCARDS, OFMatch.OFPFW_ALL);
    this.setAttribute(PROP_SUPPORTS_OFPP_FLOOD, Boolean.valueOf(true));
    this.setAttribute(PROP_SUPPORTS_OFPP_TABLE, Boolean.valueOf(true));
    if (packetInRateThresholdHigh == 0) {
        packetInRateThresholdHigh = Integer.MAX_VALUE;
    } else {
        packetInRateThresholdLow = packetInRateThresholdHigh / 2;
    }
}
项目:FloodligtModule    文件:OFSwitchBase.java   
@Override
public Future<List<OFStatistics>> queryStatistics(OFStatisticsRequest request) throws IOException {
    request.setXid(getNextTransactionId());
    OFStatisticsFuture future = new OFStatisticsFuture(threadPool, this, request.getXid());
    this.statsFutureMap.put(request.getXid(), future);
    List<OFMessage> msglist = new ArrayList<OFMessage>(1);
    msglist.add(request);
    this.write(msglist);
    return future;
}
项目:FloodligtModule    文件:OFSwitchBase.java   
@Override
public void cancelAllStatisticsReplies() {
    /* we don't need to be synchronized here. Even if another thread
     * modifies the map while we're cleaning up the future will eventuall
     * timeout */
    for (OFStatisticsFuture f : statsFutureMap.values()) {
        f.cancel(true);
    }
    statsFutureMap.clear();
    iofMsgListenersMap.clear();
}
项目:multicastSDN    文件:OFSwitchBase.java   
public OFSwitchBase() {
    this.stringId = null;
    this.attributes = new ConcurrentHashMap<Object, Object>();
    this.connectedSince = null;
    this.transactionIdSource = new AtomicInteger();
    this.connected = false;
    this.statsFutureMap = new ConcurrentHashMap<Integer,OFStatisticsFuture>();
    this.featuresFutureMap = new ConcurrentHashMap<Integer,OFFeaturesReplyFuture>();
    this.iofMsgListenersMap = new ConcurrentHashMap<Integer,IOFMessageListener>();
    this.role = null;
    this.timedCache = new TimedCache<Long>(100, 5*1000 );  // 5 seconds interval
    this.portBroadcastCacheHitMap = new ConcurrentHashMap<Short, AtomicLong>();
    this.description = new OFDescriptionStatistics();
    this.lastMessageTime = System.currentTimeMillis();

    this.portManager = new PortManager();

    // Defaults properties for an ideal switch
    this.setAttribute(PROP_FASTWILDCARDS, OFMatch.OFPFW_ALL);
    this.setAttribute(PROP_SUPPORTS_OFPP_FLOOD, Boolean.valueOf(true));
    this.setAttribute(PROP_SUPPORTS_OFPP_TABLE, Boolean.valueOf(true));
    if (packetInRateThresholdHigh == 0) {
        packetInRateThresholdHigh = Integer.MAX_VALUE;
    } else {
        packetInRateThresholdLow = packetInRateThresholdHigh / 2;
    }
}
项目:multicastSDN    文件:OFSwitchBase.java   
@Override
public Future<List<OFStatistics>> queryStatistics(OFStatisticsRequest request) throws IOException {
    request.setXid(getNextTransactionId());
    OFStatisticsFuture future = new OFStatisticsFuture(threadPool, this, request.getXid());
    this.statsFutureMap.put(request.getXid(), future);
    List<OFMessage> msglist = new ArrayList<OFMessage>(1);
    msglist.add(request);
    this.write(msglist);
    return future;
}
项目:multicastSDN    文件:OFSwitchBase.java   
@Override
public void cancelAllStatisticsReplies() {
    /* we don't need to be synchronized here. Even if another thread
     * modifies the map while we're cleaning up the future will eventuall
     * timeout */
    for (OFStatisticsFuture f : statsFutureMap.values()) {
        f.cancel(true);
    }
    statsFutureMap.clear();
    iofMsgListenersMap.clear();
}
项目:floodlight-nfv    文件:OFSwitchBase.java   
@Override
public Future<List<OFStatistics>> getStatistics(OFStatisticsRequest request) throws IOException {
    request.setXid(getNextTransactionId());
    OFStatisticsFuture future = new OFStatisticsFuture(threadPool, this, request.getXid());
    this.statsFutureMap.put(request.getXid(), future);
    List<OFMessage> msglist = new ArrayList<OFMessage>(1);
    msglist.add(request);
    this.write(msglist);
    return future;
}
项目:floodlight-nfv    文件:OFSwitchBase.java   
@Override
public void deliverStatisticsReply(OFMessage reply) {
    OFStatisticsFuture future = this.statsFutureMap.get(reply.getXid());
    if (future != null) {
        future.deliverFuture(this, reply);
        // The future will ultimately unregister itself and call
        // cancelStatisticsReply
        return;
    }
    /* Transaction id was not found in statsFutureMap.check the other map */
    IOFMessageListener caller = this.iofMsgListenersMap.get(reply.getXid());
    if (caller != null) {
        caller.receive(this, reply, null);
    }
}
项目:floodlight-nfv    文件:OFSwitchBase.java   
@Override
public void cancelAllStatisticsReplies() {
    /* we don't need to be synchronized here. Even if another thread
     * modifies the map while we're cleaning up the future will eventuall
     * timeout */
    for (OFStatisticsFuture f : statsFutureMap.values()) {
        f.cancel(true);
    }
    statsFutureMap.clear();
    iofMsgListenersMap.clear();
}
项目:floodlight-oss    文件:OFSwitchBase.java   
@Override
public Future<List<OFStatistics>> getStatistics(OFStatisticsRequest request) throws IOException {
    request.setXid(getNextTransactionId());
    OFStatisticsFuture future = new OFStatisticsFuture(threadPool, this, request.getXid());
    this.statsFutureMap.put(request.getXid(), future);
    List<OFMessage> msglist = new ArrayList<OFMessage>(1);
    msglist.add(request);
    this.write(msglist);
    return future;
}
项目:floodlight-oss    文件:OFSwitchBase.java   
@Override
public void deliverStatisticsReply(OFMessage reply) {
    OFStatisticsFuture future = this.statsFutureMap.get(reply.getXid());
    if (future != null) {
        future.deliverFuture(this, reply);
        // The future will ultimately unregister itself and call
        // cancelStatisticsReply
        return;
    }
    /* Transaction id was not found in statsFutureMap.check the other map */
    IOFMessageListener caller = this.iofMsgListenersMap.get(reply.getXid());
    if (caller != null) {
        caller.receive(this, reply, null);
    }
}
项目:floodlight-oss    文件:OFSwitchBase.java   
@Override
public void cancelAllStatisticsReplies() {
    /* we don't need to be synchronized here. Even if another thread
     * modifies the map while we're cleaning up the future will eventuall
     * timeout */
    for (OFStatisticsFuture f : statsFutureMap.values()) {
        f.cancel(true);
    }
    statsFutureMap.clear();
    iofMsgListenersMap.clear();
}
项目:FL_HAND    文件:OFSwitchBase.java   
@Override
public Future<List<OFStatistics>> getStatistics(OFStatisticsRequest request) throws IOException {
    request.setXid(getNextTransactionId());
    OFStatisticsFuture future = new OFStatisticsFuture(threadPool, this, request.getXid());
    this.statsFutureMap.put(request.getXid(), future);
    List<OFMessage> msglist = new ArrayList<OFMessage>(1);
    msglist.add(request);
    this.channel.write(msglist);
    return future;
}
项目:FL_HAND    文件:OFSwitchBase.java   
@Override
public void deliverStatisticsReply(OFMessage reply) {
    OFStatisticsFuture future = this.statsFutureMap.get(reply.getXid());
    if (future != null) {
        future.deliverFuture(this, reply);
        // The future will ultimately unregister itself and call
        // cancelStatisticsReply
        return;
    }
    /* Transaction id was not found in statsFutureMap.check the other map */
    IOFMessageListener caller = this.iofMsgListenersMap.get(reply.getXid());
    if (caller != null) {
        caller.receive(this, reply, null);
    }
}
项目:FL_HAND    文件:OFSwitchBase.java   
@Override
public void cancelAllStatisticsReplies() {
    /* we don't need to be synchronized here. Even if another thread
     * modifies the map while we're cleaning up the future will eventuall
     * timeout */
    for (OFStatisticsFuture f : statsFutureMap.values()) {
        f.cancel(true);
    }
    statsFutureMap.clear();
    iofMsgListenersMap.clear();
}