Bump to odlparent 2.0.0
[openflowjava.git] / openflow-protocol-impl / src / main / java / org / opendaylight / openflowjava / protocol / impl / core / connection / ConnectionAdapterImpl.java
index d81363c7464031cf9c0fb6f39f64860f82428264..8d9c87466a337039f15719754a57ccbf392118c4 100644 (file)
 
 package org.opendaylight.openflowjava.protocol.impl.core.connection;
 
+import com.google.common.base.Preconditions;
 import io.netty.channel.Channel;
-import io.netty.channel.ChannelFuture;
-import io.netty.util.concurrent.GenericFutureListener;
-
 import java.net.InetSocketAddress;
-import java.util.concurrent.Future;
-import java.util.concurrent.RejectedExecutionException;
-import java.util.concurrent.TimeUnit;
-
 import org.opendaylight.openflowjava.protocol.api.connection.ConnectionReadyListener;
-import org.opendaylight.openflowjava.statistics.CounterEventTypes;
-import org.opendaylight.openflowjava.statistics.StatisticsCounters;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.BarrierInput;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.BarrierOutput;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.EchoInput;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.EchoOutput;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.EchoReplyInput;
+import org.opendaylight.openflowjava.protocol.api.connection.OutboundQueueHandler;
+import org.opendaylight.openflowjava.protocol.api.connection.OutboundQueueHandlerRegistration;
+import org.opendaylight.openflowjava.protocol.impl.core.OFVersionDetector;
+import org.opendaylight.openflowjava.protocol.impl.core.PipelineHandlers;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.EchoRequestMessage;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.ErrorMessage;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.ExperimenterInput;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.ExperimenterMessage;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.FlowModInput;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.FlowRemovedMessage;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.GetAsyncInput;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.GetAsyncOutput;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.GetConfigInput;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.GetConfigOutput;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.GetFeaturesInput;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.GetFeaturesOutput;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.GetQueueConfigInput;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.GetQueueConfigOutput;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.GroupModInput;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.HelloInput;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.HelloMessage;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.MeterModInput;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.MultipartReplyMessage;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.MultipartRequestInput;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.OfHeader;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.OpenflowProtocolListener;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.PacketInMessage;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.PacketOutInput;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.PortModInput;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.PortStatusMessage;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.RoleRequestInput;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.RoleRequestOutput;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.SetAsyncInput;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.SetConfigInput;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.TableModInput;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.system.rev130927.DisconnectEvent;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.system.rev130927.SwitchIdleEvent;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.system.rev130927.SystemNotificationsListener;
 import org.opendaylight.yangtools.yang.binding.DataObject;
 import org.opendaylight.yangtools.yang.binding.Notification;
-import org.opendaylight.yangtools.yang.common.RpcResult;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-import com.google.common.base.Preconditions;
-import com.google.common.cache.Cache;
-import com.google.common.cache.CacheBuilder;
-import com.google.common.cache.RemovalCause;
-import com.google.common.cache.RemovalListener;
-import com.google.common.cache.RemovalNotification;
-import com.google.common.util.concurrent.ListenableFuture;
-import com.google.common.util.concurrent.SettableFuture;
-
 /**
- * Handles messages (notifications + rpcs) and connections
+ * Handles messages (notifications + rpcs) and connections.
  * @author mirehak
  * @author michal.polkorab
  */
-public class ConnectionAdapterImpl implements ConnectionFacade {
-    /** after this time, RPC future response objects will be thrown away (in minutes) */
-    public static final int RPC_RESPONSE_EXPIRATION = 1;
+public class ConnectionAdapterImpl extends AbstractConnectionAdapterStatistics implements ConnectionFacade {
 
-    /**
-     * Default depth of write queue, e.g. we allow these many messages
-     * to be queued up before blocking producers.
-     */
-    public static final int DEFAULT_QUEUE_DEPTH = 1024;
-
-    private static final Logger LOG = LoggerFactory
-            .getLogger(ConnectionAdapterImpl.class);
-    private static final Exception QUEUE_FULL_EXCEPTION =
-            new RejectedExecutionException("Output queue is full");
-
-    private static final RemovalListener<RpcResponseKey, ResponseExpectedRpcListener<?>> REMOVAL_LISTENER =
-            new RemovalListener<RpcResponseKey, ResponseExpectedRpcListener<?>>() {
-        @Override
-        public void onRemoval(
-                final RemovalNotification<RpcResponseKey, ResponseExpectedRpcListener<?>> notification) {
-            if (! notification.getCause().equals(RemovalCause.EXPLICIT)) {
-                notification.getValue().discard();
-            }
-        }
-    };
-
-    /** expiring cache for future rpcResponses */
-    private Cache<RpcResponseKey, ResponseExpectedRpcListener<?>> responseCache;
-
-    private final ChannelOutboundQueue output;
-    private final Channel channel;
+    private static final Logger LOG = LoggerFactory.getLogger(ConnectionAdapterImpl.class);
 
     private ConnectionReadyListener connectionReadyListener;
     private OpenflowProtocolListener messageListener;
     private SystemNotificationsListener systemListener;
-    private boolean disconnectOccured = false;
-    private StatisticsCounters statisticsCounters;
+    private AbstractOutboundQueueManager<?, ?> outputManager;
+    private OFVersionDetector versionDetector;
+
+    private final boolean useBarrier;
 
     /**
-     * default ctor
+     * Default constructor.
      * @param channel the channel to be set - used for communication
      * @param address client address (used only in case of UDP communication,
-     *  as there is no need to store address over tcp (stable channel))
+     *                as there is no need to store address over tcp (stable channel))
+     * @param useBarrier value is configurable by configSubsytem
      */
-    public ConnectionAdapterImpl(final Channel channel, final InetSocketAddress address) {
-        responseCache = CacheBuilder.newBuilder()
-                .concurrencyLevel(1)
-                .expireAfterWrite(RPC_RESPONSE_EXPIRATION, TimeUnit.MINUTES)
-                .removalListener(REMOVAL_LISTENER).build();
-        this.channel = Preconditions.checkNotNull(channel);
-        this.output = new ChannelOutboundQueue(channel, DEFAULT_QUEUE_DEPTH, address);
-        channel.pipeline().addLast(output);
-        statisticsCounters = StatisticsCounters.getInstance();
+    public ConnectionAdapterImpl(final Channel channel, final InetSocketAddress address, final boolean useBarrier) {
+        super(channel, address);
+        this.useBarrier = useBarrier;
         LOG.debug("ConnectionAdapter created");
     }
 
     @Override
-    public Future<RpcResult<BarrierOutput>> barrier(final BarrierInput input) {
-        return sendToSwitchExpectRpcResultFuture(
-                input, BarrierOutput.class, "barrier-input sending failed");
-    }
-
-    @Override
-    public Future<RpcResult<EchoOutput>> echo(final EchoInput input) {
-        return sendToSwitchExpectRpcResultFuture(
-                input, EchoOutput.class, "echo-input sending failed");
-    }
-
-    @Override
-    public Future<RpcResult<Void>> echoReply(final EchoReplyInput input) {
-        return sendToSwitchFuture(input, "echo-reply sending failed");
-    }
-
-    @Override
-    public Future<RpcResult<Void>> experimenter(final ExperimenterInput input) {
-        return sendToSwitchFuture(input, "experimenter sending failed");
-    }
-
-    @Override
-    public Future<RpcResult<Void>> flowMod(final FlowModInput input) {
-        statisticsCounters.incrementCounter(CounterEventTypes.DS_FLOW_MODS_ENTERED);
-        return sendToSwitchFuture(input, "flow-mod sending failed");
-    }
-
-    @Override
-    public Future<RpcResult<GetConfigOutput>> getConfig(final GetConfigInput input) {
-        return sendToSwitchExpectRpcResultFuture(
-                input, GetConfigOutput.class, "get-config-input sending failed");
-    }
-
-    @Override
-    public Future<RpcResult<GetFeaturesOutput>> getFeatures(
-            final GetFeaturesInput input) {
-        return sendToSwitchExpectRpcResultFuture(
-                input, GetFeaturesOutput.class, "get-features-input sending failed");
-    }
-
-    @Override
-    public Future<RpcResult<GetQueueConfigOutput>> getQueueConfig(
-            final GetQueueConfigInput input) {
-        return sendToSwitchExpectRpcResultFuture(
-                input, GetQueueConfigOutput.class, "get-queue-config-input sending failed");
-    }
-
-    @Override
-    public Future<RpcResult<Void>> groupMod(final GroupModInput input) {
-        return sendToSwitchFuture(input, "group-mod-input sending failed");
-    }
-
-    @Override
-    public Future<RpcResult<Void>> hello(final HelloInput input) {
-        return sendToSwitchFuture(input, "hello-input sending failed");
-    }
-
-    @Override
-    public Future<RpcResult<Void>> meterMod(final MeterModInput input) {
-        return sendToSwitchFuture(input, "meter-mod-input sending failed");
-    }
-
-    @Override
-    public Future<RpcResult<Void>> packetOut(final PacketOutInput input) {
-        return sendToSwitchFuture(input, "packet-out-input sending failed");
-    }
-
-    @Override
-    public Future<RpcResult<Void>> multipartRequest(final MultipartRequestInput input) {
-        return sendToSwitchFuture(input, "multi-part-request sending failed");
-    }
-
-    @Override
-    public Future<RpcResult<Void>> portMod(final PortModInput input) {
-        return sendToSwitchFuture(input, "port-mod-input sending failed");
-    }
-
-    @Override
-    public Future<RpcResult<RoleRequestOutput>> roleRequest(
-            final RoleRequestInput input) {
-        return sendToSwitchExpectRpcResultFuture(
-                input, RoleRequestOutput.class, "role-request-config-input sending failed");
-    }
-
-    @Override
-    public Future<RpcResult<Void>> setConfig(final SetConfigInput input) {
-        return sendToSwitchFuture(input, "set-config-input sending failed");
-    }
-
-    @Override
-    public Future<RpcResult<Void>> tableMod(final TableModInput input) {
-        return sendToSwitchFuture(input, "table-mod-input sending failed");
-    }
-
-    @Override
-    public Future<RpcResult<GetAsyncOutput>> getAsync(final GetAsyncInput input) {
-        return sendToSwitchExpectRpcResultFuture(
-                input, GetAsyncOutput.class, "get-async-input sending failed");
-    }
-
-    @Override
-    public Future<RpcResult<Void>> setAsync(final SetAsyncInput input) {
-        return sendToSwitchFuture(input, "set-async-input sending failed");
-    }
-
-    @Override
-    public Future<Boolean> disconnect() {
-        ChannelFuture disconnectResult = channel.disconnect();
-        responseCache.invalidateAll();
-        disconnectOccured = true;
-
-        return handleTransportChannelFuture(disconnectResult);
+    public void setMessageListener(final OpenflowProtocolListener messageListener) {
+        this.messageListener = messageListener;
     }
 
     @Override
-    public boolean isAlive() {
-        return channel.isOpen();
+    public void setConnectionReadyListener(final ConnectionReadyListener connectionReadyListener) {
+        this.connectionReadyListener = connectionReadyListener;
     }
 
     @Override
-    public void setMessageListener(final OpenflowProtocolListener messageListener) {
-        this.messageListener = messageListener;
+    public void setSystemListener(final SystemNotificationsListener systemListener) {
+        this.systemListener = systemListener;
     }
 
     @Override
-    public void consume(final DataObject message) {
-        LOG.debug("ConsumeIntern msg");
-        if (disconnectOccured ) {
+    public void consumeDeviceMessage(final DataObject message) {
+        LOG.debug("ConsumeIntern msg on {}", channel);
+        if (disconnectOccured) {
             return;
         }
         if (message instanceof Notification) {
@@ -276,155 +95,64 @@ public class ConnectionAdapterImpl implements ConnectionFacade {
                 disconnectOccured = true;
             } else if (message instanceof SwitchIdleEvent) {
                 systemListener.onSwitchIdleEvent((SwitchIdleEvent) message);
-                // OpenFlow messages
+            // OpenFlow messages
             } else if (message instanceof EchoRequestMessage) {
-                messageListener.onEchoRequestMessage((EchoRequestMessage) message);
-                statisticsCounters.incrementCounter(CounterEventTypes.US_MESSAGE_PASS);
+                if (outputManager != null) {
+                    outputManager.onEchoRequest((EchoRequestMessage) message);
+                } else {
+                    messageListener.onEchoRequestMessage((EchoRequestMessage) message);
+                }
             } else if (message instanceof ErrorMessage) {
-                messageListener.onErrorMessage((ErrorMessage) message);
-                statisticsCounters.incrementCounter(CounterEventTypes.US_MESSAGE_PASS);
+                // Send only unmatched errors
+                if (outputManager == null || !outputManager.onMessage((OfHeader) message)) {
+                    messageListener.onErrorMessage((ErrorMessage) message);
+                }
             } else if (message instanceof ExperimenterMessage) {
+                if (outputManager != null) {
+                    outputManager.onMessage((OfHeader) message);
+                }
                 messageListener.onExperimenterMessage((ExperimenterMessage) message);
-                statisticsCounters.incrementCounter(CounterEventTypes.US_MESSAGE_PASS);
             } else if (message instanceof FlowRemovedMessage) {
                 messageListener.onFlowRemovedMessage((FlowRemovedMessage) message);
-                statisticsCounters.incrementCounter(CounterEventTypes.US_MESSAGE_PASS);
             } else if (message instanceof HelloMessage) {
-                LOG.info("Hello received / branch");
+                LOG.info("Hello received");
                 messageListener.onHelloMessage((HelloMessage) message);
-                statisticsCounters.incrementCounter(CounterEventTypes.US_MESSAGE_PASS);
             } else if (message instanceof MultipartReplyMessage) {
+                if (outputManager != null) {
+                    outputManager.onMessage((OfHeader) message);
+                }
                 messageListener.onMultipartReplyMessage((MultipartReplyMessage) message);
-                statisticsCounters.incrementCounter(CounterEventTypes.US_MESSAGE_PASS);
             } else if (message instanceof PacketInMessage) {
                 messageListener.onPacketInMessage((PacketInMessage) message);
-                statisticsCounters.incrementCounter(CounterEventTypes.US_MESSAGE_PASS);
             } else if (message instanceof PortStatusMessage) {
                 messageListener.onPortStatusMessage((PortStatusMessage) message);
-                statisticsCounters.incrementCounter(CounterEventTypes.US_MESSAGE_PASS);
             } else {
                 LOG.warn("message listening not supported for type: {}", message.getClass());
             }
-        } else {
-            if (message instanceof OfHeader) {
-                LOG.debug("OFheader msg received");
-                RpcResponseKey key = createRpcResponseKey((OfHeader) message);
+        } else if (message instanceof OfHeader) {
+            LOG.debug("OF header msg received");
+
+            if (outputManager == null || !outputManager.onMessage((OfHeader) message)) {
+                final RpcResponseKey key = createRpcResponseKey((OfHeader) message);
                 final ResponseExpectedRpcListener<?> listener = findRpcResponse(key);
                 if (listener != null) {
-                    LOG.debug("corresponding rpcFuture found");
+                    LOG.debug("Corresponding rpcFuture found");
                     listener.completed((OfHeader)message);
-                    statisticsCounters.incrementCounter(CounterEventTypes.US_MESSAGE_PASS);
-                    LOG.debug("after setting rpcFuture");
+                    LOG.debug("After setting rpcFuture");
                     responseCache.invalidate(key);
                 } else {
                     LOG.warn("received unexpected rpc response: {}", key);
                 }
-            } else {
-                LOG.warn("message listening not supported for type: {}", message.getClass());
             }
-        }
-    }
-
-    private <T> ListenableFuture<RpcResult<T>> enqueueMessage(final AbstractRpcListener<T> promise) {
-        LOG.debug("Submitting promise {}", promise);
-
-        if (!output.enqueue(promise)) {
-            LOG.debug("Message queue is full, rejecting execution");
-            promise.failedRpc(QUEUE_FULL_EXCEPTION);
         } else {
-            LOG.debug("Promise enqueued successfully");
+            LOG.warn("message listening not supported for type: {}", message.getClass());
         }
-
-        return promise.getResult();
-    }
-
-    /**
-     * sends given message to switch, sending result will be reported via return value
-     * @param input message to send
-     * @param failureInfo describes, what type of message caused failure by sending
-     * @return future object, <ul>
-     *  <li>if send successful, {@link RpcResult} without errors and successful
-     *  status will be returned, </li>
-     *  <li>else {@link RpcResult} will contain errors and failed status</li>
-     *  </ul>
-     */
-    private ListenableFuture<RpcResult<Void>> sendToSwitchFuture(
-            final DataObject input, final String failureInfo) {
-        statisticsCounters.incrementCounter(CounterEventTypes.DS_ENTERED_OFJAVA);
-        return enqueueMessage(new SimpleRpcListener(input, failureInfo));
-    }
-
-    /**
-     * sends given message to switch, sending result or switch response will be reported via return value
-     * @param input message to send
-     * @param responseClazz type of response
-     * @param failureInfo describes, what type of message caused failure by sending
-     * @return future object, <ul>
-     *  <li>if send fails, {@link RpcResult} will contain errors and failed status </li>
-     *  <li>else {@link RpcResult} will be stored in responseCache and wait for particular timeout
-     *  ({@link ConnectionAdapterImpl#RPC_RESPONSE_EXPIRATION}),
-     *  <ul><li>either switch will manage to answer
-     *  and then corresponding response message will be set into returned future</li>
-     *  <li>or response in cache will expire and returned future will be cancelled</li></ul>
-     *  </li>
-     *  </ul>
-     */
-    private <IN extends OfHeader, OUT extends OfHeader> ListenableFuture<RpcResult<OUT>> sendToSwitchExpectRpcResultFuture(
-            final IN input, final Class<OUT> responseClazz, final String failureInfo) {
-        final RpcResponseKey key = new RpcResponseKey(input.getXid(), responseClazz.getName());
-        final ResponseExpectedRpcListener<OUT> listener =
-                new ResponseExpectedRpcListener<>(input, failureInfo, responseCache, key);
-        statisticsCounters.incrementCounter(CounterEventTypes.DS_ENTERED_OFJAVA);
-        return enqueueMessage(listener);
-    }
-
-    /**
-     * @param resultFuture
-     * @param failureInfo
-     * @param errorSeverity
-     * @param message
-     * @return
-     */
-    private static SettableFuture<Boolean> handleTransportChannelFuture(
-            final ChannelFuture resultFuture) {
-
-        final SettableFuture<Boolean> transportResult = SettableFuture.create();
-
-        resultFuture.addListener(new GenericFutureListener<io.netty.util.concurrent.Future<? super Void>>() {
-
-            @Override
-            public void operationComplete(
-                    final io.netty.util.concurrent.Future<? super Void> future)
-                    throws Exception {
-                transportResult.set(future.isSuccess());
-                if (!future.isSuccess()) {
-                    transportResult.setException(future.cause());
-                }
-            }
-        });
-        return transportResult;
     }
 
-    /**
-     * @param message
-     * @return
-     */
     private static RpcResponseKey createRpcResponseKey(final OfHeader message) {
         return new RpcResponseKey(message.getXid(), message.getImplementedInterface().getName());
     }
 
-    /**
-     * @return
-     */
-    private ResponseExpectedRpcListener<?> findRpcResponse(final RpcResponseKey key) {
-        return responseCache.getIfPresent(key);
-    }
-
-    @Override
-    public void setSystemListener(final SystemNotificationsListener systemListener) {
-        this.systemListener = systemListener;
-    }
-
     @Override
     public void checkListeners() {
         final StringBuilder buffer =  new StringBuilder();
@@ -443,6 +171,9 @@ public class ConnectionAdapterImpl implements ConnectionFacade {
 
     @Override
     public void fireConnectionReadyNotification() {
+        versionDetector = (OFVersionDetector) channel.pipeline().get(PipelineHandlers.OF_VERSION_DETECTOR.name());
+        Preconditions.checkState(versionDetector != null);
+
         new Thread(new Runnable() {
             @Override
             public void run() {
@@ -452,31 +183,44 @@ public class ConnectionAdapterImpl implements ConnectionFacade {
     }
 
     @Override
-    public void setConnectionReadyListener(
-            final ConnectionReadyListener connectionReadyListener) {
-        this.connectionReadyListener = connectionReadyListener;
-    }
+    public <T extends OutboundQueueHandler> OutboundQueueHandlerRegistration<T> registerOutboundQueueHandler(
+            final T handler, final int maxQueueDepth, final long maxBarrierNanos) {
+        Preconditions.checkState(outputManager == null, "Manager %s already registered", outputManager);
 
-    @Override
-    public InetSocketAddress getRemoteAddress() {
-        return (InetSocketAddress) channel.remoteAddress();
-    }
+        final AbstractOutboundQueueManager<T, ?> ret;
+        if (useBarrier) {
+            ret = new OutboundQueueManager<>(this, address, handler, maxQueueDepth, maxBarrierNanos);
+        } else {
+            LOG.warn("OutboundQueueManager without barrier is started.");
+            ret = new OutboundQueueManagerNoBarrier<>(this, address, handler);
+        }
 
-    /**
-     * Used only for testing purposes
-     * @param cache
-     */
-    public void setResponseCache(Cache<RpcResponseKey, ResponseExpectedRpcListener<?>> cache) {
-        this.responseCache = cache;
+        outputManager = ret;
+        /* we don't need it anymore */
+        channel.pipeline().remove(output);
+        // OutboundQueueManager is put before DelegatingInboundHandler because otherwise channelInactive event would
+        // be first processed in OutboundQueueManager and then in ConnectionAdapter (and Openflowplugin). This might
+        // cause problems because we are shutting down the queue before Openflowplugin knows about it.
+        channel.pipeline().addBefore(PipelineHandlers.DELEGATING_INBOUND_HANDLER.name(),
+                PipelineHandlers.CHANNEL_OUTBOUND_QUEUE_MANAGER.name(), outputManager);
+
+        return new OutboundQueueHandlerRegistrationImpl<T>(handler) {
+            @Override
+            protected void removeRegistration() {
+                outputManager.close();
+                channel.pipeline().remove(outputManager);
+                outputManager = null;
+            }
+        };
     }
 
-       @Override
-    public boolean isAutoRead() {
-       return channel.config().isAutoRead();
+    Channel getChannel() {
+        return channel;
     }
-    
-       @Override
-    public void setAutoRead(boolean autoRead) {
-       channel.config().setAutoRead(autoRead);
+
+    @Override
+    public void setPacketInFiltering(final boolean enabled) {
+        versionDetector.setFilterPacketIns(enabled);
+        LOG.debug("PacketIn filtering {}abled", enabled ? "en" : "dis");
     }
 }