summaryrefslogtreecommitdiff
path: root/cpp/common/io/inc
diff options
context:
space:
mode:
authorAlan Conway <aconway@apache.org>2006-10-16 13:50:26 +0000
committerAlan Conway <aconway@apache.org>2006-10-16 13:50:26 +0000
commit8a6ab3aa61d441b9210c05c84dc9998acfc38737 (patch)
tree1eb9d7f39b5c2d04a85a1f66caef3d398567b740 /cpp/common/io/inc
parent9a808fb13aba243d41bbdab75158dae5939a80a4 (diff)
downloadqpid-python-8a6ab3aa61d441b9210c05c84dc9998acfc38737.tar.gz
Build system reorg, see README and Makefile comments for details.
git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/trunk/qpid@464494 13f79535-47bb-0310-9956-ffa450edef68
Diffstat (limited to 'cpp/common/io/inc')
-rw-r--r--cpp/common/io/inc/APRConnector.h95
-rw-r--r--cpp/common/io/inc/APRSocket.h45
-rw-r--r--cpp/common/io/inc/Acceptor.h53
-rw-r--r--cpp/common/io/inc/BlockingAPRAcceptor.h65
-rw-r--r--cpp/common/io/inc/BlockingAPRSessionContext.h94
-rw-r--r--cpp/common/io/inc/Connector.h56
-rw-r--r--cpp/common/io/inc/ConnectorImpl.h53
-rw-r--r--cpp/common/io/inc/LConnector.h48
-rw-r--r--cpp/common/io/inc/LFAcceptor.h74
-rw-r--r--cpp/common/io/inc/LFProcessor.h119
-rw-r--r--cpp/common/io/inc/LFSessionContext.h88
-rw-r--r--cpp/common/io/inc/SessionContext.h37
-rw-r--r--cpp/common/io/inc/SessionHandler.h42
-rw-r--r--cpp/common/io/inc/SessionHandlerFactory.h38
-rw-r--r--cpp/common/io/inc/SessionManager.h40
-rw-r--r--cpp/common/io/inc/ShutdownHandler.h34
-rw-r--r--cpp/common/io/inc/TimeoutHandler.h36
17 files changed, 0 insertions, 1017 deletions
diff --git a/cpp/common/io/inc/APRConnector.h b/cpp/common/io/inc/APRConnector.h
deleted file mode 100644
index c6ed887f78..0000000000
--- a/cpp/common/io/inc/APRConnector.h
+++ /dev/null
@@ -1,95 +0,0 @@
-/*
- *
- * Copyright (c) 2006 The Apache Software Foundation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- *
- */
-#ifndef _APRConnector_
-#define _APRConnector_
-
-#include "apr_network_io.h"
-#include "apr_time.h"
-
-#include "InputHandler.h"
-#include "OutputHandler.h"
-#include "InitiationHandler.h"
-#include "ProtocolInitiation.h"
-#include "ShutdownHandler.h"
-#include "Thread.h"
-#include "ThreadFactory.h"
-#include "Connector.h"
-#include "APRMonitor.h"
-
-namespace qpid {
-namespace io {
-
- class APRConnector : public virtual qpid::framing::OutputHandler,
- public virtual Connector,
- private virtual qpid::concurrent::Runnable
- {
- const bool debug;
- const int receive_buffer_size;
- const int send_buffer_size;
-
- bool closed;
-
- apr_time_t lastIn;
- apr_time_t lastOut;
- apr_interval_time_t timeout;
- u_int32_t idleIn;
- u_int32_t idleOut;
-
- TimeoutHandler* timeoutHandler;
- ShutdownHandler* shutdownHandler;
- qpid::framing::InputHandler* input;
- qpid::framing::InitiationHandler* initialiser;
- qpid::framing::OutputHandler* output;
-
- qpid::framing::Buffer inbuf;
- qpid::framing::Buffer outbuf;
-
- qpid::concurrent::APRMonitor* writeLock;
- qpid::concurrent::ThreadFactory* threadFactory;
- qpid::concurrent::Thread* receiver;
-
- apr_pool_t* pool;
- apr_socket_t* socket;
-
- void checkIdle(apr_status_t status);
- void writeBlock(qpid::framing::AMQDataBlock* data);
- void writeToSocket(char* data, size_t available);
- void setSocketTimeout();
-
- void run();
-
- public:
- APRConnector(bool debug = false, u_int32_t buffer_size = 1024);
- virtual ~APRConnector();
- virtual void connect(const std::string& host, int port);
- virtual void init(qpid::framing::ProtocolInitiation* header);
- virtual void close();
- virtual void setInputHandler(qpid::framing::InputHandler* handler);
- virtual void setTimeoutHandler(TimeoutHandler* handler);
- virtual void setShutdownHandler(ShutdownHandler* handler);
- virtual qpid::framing::OutputHandler* getOutputHandler();
- virtual void send(qpid::framing::AMQFrame* frame);
- virtual void setReadTimeout(u_int16_t timeout);
- virtual void setWriteTimeout(u_int16_t timeout);
- };
-
-}
-}
-
-
-#endif
diff --git a/cpp/common/io/inc/APRSocket.h b/cpp/common/io/inc/APRSocket.h
deleted file mode 100644
index 610cf0e175..0000000000
--- a/cpp/common/io/inc/APRSocket.h
+++ /dev/null
@@ -1,45 +0,0 @@
-/*
- *
- * Copyright (c) 2006 The Apache Software Foundation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- *
- */
-#ifndef _APRSocket_
-#define _APRSocket_
-
-#include "apr_network_io.h"
-#include "Buffer.h"
-
-namespace qpid {
-namespace io {
-
- class APRSocket
- {
- apr_socket_t* const socket;
- volatile bool closed;
- public:
- APRSocket(apr_socket_t* socket);
- void read(qpid::framing::Buffer& b);
- void write(qpid::framing::Buffer& b);
- void close();
- bool isOpen();
- u_int8_t read();
- ~APRSocket();
- };
-
-}
-}
-
-
-#endif
diff --git a/cpp/common/io/inc/Acceptor.h b/cpp/common/io/inc/Acceptor.h
deleted file mode 100644
index d7313b84db..0000000000
--- a/cpp/common/io/inc/Acceptor.h
+++ /dev/null
@@ -1,53 +0,0 @@
-/*
- *
- * Copyright (c) 2006 The Apache Software Foundation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- *
- */
-#ifndef _Acceptor_
-#define _Acceptor_
-
-#include "SessionHandlerFactory.h"
-
-namespace qpid {
-namespace io {
-
- class Acceptor
- {
- public:
- /**
- * Bind to port.
- * @param port Port to bind to, 0 to bind to dynamically chosen port.
- * @return The local bound port.
- */
- virtual int16_t bind(int16_t port) = 0;
-
- /**
- * Run the acceptor.
- */
- virtual void run(SessionHandlerFactory* factory) = 0;
-
- /**
- * Shut down the acceptor.
- */
- virtual void shutdown() = 0;
-
- virtual ~Acceptor();
- };
-
-}
-}
-
-
-#endif
diff --git a/cpp/common/io/inc/BlockingAPRAcceptor.h b/cpp/common/io/inc/BlockingAPRAcceptor.h
deleted file mode 100644
index bd069ed8db..0000000000
--- a/cpp/common/io/inc/BlockingAPRAcceptor.h
+++ /dev/null
@@ -1,65 +0,0 @@
-/*
- *
- * Copyright (c) 2006 The Apache Software Foundation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- *
- */
-#ifndef _BlockingAPRAcceptor_
-#define _BlockingAPRAcceptor_
-
-#include <vector>
-#include "apr_network_io.h"
-#include "apr_poll.h"
-#include "apr_time.h"
-
-#include "Acceptor.h"
-#include "APRMonitor.h"
-#include "BlockingAPRSessionContext.h"
-#include "Runnable.h"
-#include "SessionContext.h"
-#include "SessionHandlerFactory.h"
-#include "Thread.h"
-#include "ThreadFactory.h"
-#include "ThreadPool.h"
-
-namespace qpid {
-namespace io {
-
- class BlockingAPRAcceptor : public virtual Acceptor
- {
- typedef std::vector<BlockingAPRSessionContext*>::iterator iterator;
-
- const bool debug;
- apr_pool_t* apr_pool;
- qpid::concurrent::ThreadFactory* threadFactory;
- std::vector<BlockingAPRSessionContext*> sessions;
- apr_socket_t* socket;
- const int connectionBacklog;
- volatile bool running;
-
- public:
- BlockingAPRAcceptor(bool debug = false, int connectionBacklog = 10);
- virtual int16_t bind(int16_t port);
- virtual int16_t getPort() const;
- virtual void run(SessionHandlerFactory* factory);
- virtual void shutdown();
- virtual ~BlockingAPRAcceptor();
- void closed(BlockingAPRSessionContext* session);
- };
-
-}
-}
-
-
-#endif
diff --git a/cpp/common/io/inc/BlockingAPRSessionContext.h b/cpp/common/io/inc/BlockingAPRSessionContext.h
deleted file mode 100644
index 038ebd6662..0000000000
--- a/cpp/common/io/inc/BlockingAPRSessionContext.h
+++ /dev/null
@@ -1,94 +0,0 @@
-/*
- *
- * Copyright (c) 2006 The Apache Software Foundation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- *
- */
-#ifndef _BlockingAPRSessionContext_
-#define _BlockingAPRSessionContext_
-
-#include <queue>
-#include <vector>
-
-#include "apr_network_io.h"
-#include "apr_time.h"
-
-#include "AMQFrame.h"
-#include "APRMonitor.h"
-#include "Buffer.h"
-#include "Runnable.h"
-#include "SessionContext.h"
-#include "SessionHandler.h"
-#include "SessionHandlerFactory.h"
-#include "ShutdownHandler.h"
-#include "Thread.h"
-#include "ThreadFactory.h"
-
-namespace qpid {
-namespace io {
-
- class BlockingAPRAcceptor;
-
- class BlockingAPRSessionContext : public virtual SessionContext
- {
- class Reader : public virtual qpid::concurrent::Runnable{
- BlockingAPRSessionContext* parent;
- public:
- inline Reader(BlockingAPRSessionContext* p) : parent(p){}
- inline virtual void run(){ parent->read(); }
- inline virtual ~Reader(){}
- };
-
- class Writer : public virtual qpid::concurrent::Runnable{
- BlockingAPRSessionContext* parent;
- public:
- inline Writer(BlockingAPRSessionContext* p) : parent(p){}
- inline virtual void run(){ parent->write(); }
- inline virtual ~Writer(){}
- };
-
- apr_socket_t* socket;
- const bool debug;
- SessionHandler* handler;
- BlockingAPRAcceptor* acceptor;
- std::queue<qpid::framing::AMQFrame*> outframes;
- qpid::framing::Buffer inbuf;
- qpid::framing::Buffer outbuf;
- qpid::concurrent::APRMonitor outlock;
- Reader* reader;
- Writer* writer;
- qpid::concurrent::Thread* rThread;
- qpid::concurrent::Thread* wThread;
-
- volatile bool closed;
-
- void read();
- void write();
- public:
- BlockingAPRSessionContext(apr_socket_t* socket,
- qpid::concurrent::ThreadFactory* factory,
- BlockingAPRAcceptor* acceptor,
- bool debug = false);
- ~BlockingAPRSessionContext();
- virtual void send(qpid::framing::AMQFrame* frame);
- virtual void close();
- void shutdown();
- void init(SessionHandler* handler);
- };
-
-}
-}
-
-
-#endif
diff --git a/cpp/common/io/inc/Connector.h b/cpp/common/io/inc/Connector.h
deleted file mode 100644
index 52684329f1..0000000000
--- a/cpp/common/io/inc/Connector.h
+++ /dev/null
@@ -1,56 +0,0 @@
-/*
- *
- * Copyright (c) 2006 The Apache Software Foundation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- *
- */
-#ifndef _Connector_
-#define _Connector_
-
-#include "InputHandler.h"
-#include "OutputHandler.h"
-#include "InitiationHandler.h"
-#include "ProtocolInitiation.h"
-#include "ShutdownHandler.h"
-#include "TimeoutHandler.h"
-
-namespace qpid {
-namespace io {
-
- class Connector
- {
- public:
- virtual void connect(const std::string& host, int port) = 0;
- virtual void init(qpid::framing::ProtocolInitiation* header) = 0;
- virtual void close() = 0;
- virtual void setInputHandler(qpid::framing::InputHandler* handler) = 0;
- virtual void setTimeoutHandler(TimeoutHandler* handler) = 0;
- virtual void setShutdownHandler(ShutdownHandler* handler) = 0;
- virtual qpid::framing::OutputHandler* getOutputHandler() = 0;
- /**
- * Set the timeout for reads, in secs.
- */
- virtual void setReadTimeout(u_int16_t timeout) = 0;
- /**
- * Set the timeout for writes, in secs.
- */
- virtual void setWriteTimeout(u_int16_t timeout) = 0;
- virtual ~Connector(){}
- };
-
-}
-}
-
-
-#endif
diff --git a/cpp/common/io/inc/ConnectorImpl.h b/cpp/common/io/inc/ConnectorImpl.h
deleted file mode 100644
index 1abb72f32a..0000000000
--- a/cpp/common/io/inc/ConnectorImpl.h
+++ /dev/null
@@ -1,53 +0,0 @@
-/*
- *
- * Copyright (c) 2006 The Apache Software Foundation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- *
- */
-#ifndef _APRConnectorImpl_
-#define _APRConnectorImpl_
-
-#ifdef _USE_APR_IO_
-#include "APRConnector.h"
-#else
-#include "LConnector.h"
-#endif
-
-namespace qpid {
-namespace io {
-
-#ifdef _USE_APR_IO_
- class ConnectorImpl : public virtual APRConnector
- {
-
- public:
- ConnectorImpl(bool _debug = false, u_int32_t buffer_size = 1024):APRConnector(_debug,buffer_size){};
- virtual ~ConnectorImpl(){};
- };
-#else
- class ConnectorImpl : public virtual LConnector
- {
-
- public:
- ConnectorImpl(bool _debug = false, u_int32_t buffer_size = 1024):LConnector(_debug, buffer_size){};
- virtual ~ConnectorImpl(){};
- };
-
-#endif
-
-}
-}
-
-
-#endif
diff --git a/cpp/common/io/inc/LConnector.h b/cpp/common/io/inc/LConnector.h
deleted file mode 100644
index 59d95a6b57..0000000000
--- a/cpp/common/io/inc/LConnector.h
+++ /dev/null
@@ -1,48 +0,0 @@
-/*
- *
- * Copyright (c) 2006 The Apache Software Foundation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- *
- */
-#ifndef _LConnector_
-#define _LConnector_
-
-
-#include "InputHandler.h"
-#include "OutputHandler.h"
-#include "InitiationHandler.h"
-#include "ProtocolInitiation.h"
-#include "Thread.h"
-#include "ThreadFactory.h"
-#include "Connector.h"
-
-namespace qpid {
-namespace io {
-
- class LConnector : public virtual qpid::framing::OutputHandler,
- public virtual Connector,
- private virtual qpid::concurrent::Runnable
- {
-
- public:
- LConnector(bool debug = false, u_int32_t buffer_size = 1024){};
- virtual ~LConnector(){};
-
- };
-
-}
-}
-
-
-#endif
diff --git a/cpp/common/io/inc/LFAcceptor.h b/cpp/common/io/inc/LFAcceptor.h
deleted file mode 100644
index 9a40eed222..0000000000
--- a/cpp/common/io/inc/LFAcceptor.h
+++ /dev/null
@@ -1,74 +0,0 @@
-/*
- *
- * Copyright (c) 2006 The Apache Software Foundation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- *
- */
-#ifndef _LFAcceptor_
-#define _LFAcceptor_
-
-#include <vector>
-#include "apr_network_io.h"
-#include "apr_poll.h"
-#include "apr_time.h"
-
-#include "Acceptor.h"
-#include "APRMonitor.h"
-#include "APRThreadFactory.h"
-#include "APRThreadPool.h"
-#include "LFProcessor.h"
-#include "LFSessionContext.h"
-#include "Runnable.h"
-#include "SessionContext.h"
-#include "SessionHandlerFactory.h"
-#include "Thread.h"
-
-namespace qpid {
-namespace io {
-
- class LFAcceptor : public virtual Acceptor
- {
- class APRPool{
- public:
- apr_pool_t* pool;
- APRPool();
- ~APRPool();
- };
-
- APRPool aprPool;
- LFProcessor processor;
- apr_socket_t* socket;
- const int max_connections_per_processor;
- const bool debug;
- const int connectionBacklog;
-
- volatile bool running;
-
- public:
- LFAcceptor(bool debug = false,
- int connectionBacklog = 10,
- int worker_threads = 5,
- int max_connections_per_processor = 500);
- virtual int16_t bind(int16_t port);
- virtual int16_t getPort() const;
- virtual void run(SessionHandlerFactory* factory);
- virtual void shutdown();
- virtual ~LFAcceptor();
- };
-
-}
-}
-
-
-#endif
diff --git a/cpp/common/io/inc/LFProcessor.h b/cpp/common/io/inc/LFProcessor.h
deleted file mode 100644
index 25a3c8626c..0000000000
--- a/cpp/common/io/inc/LFProcessor.h
+++ /dev/null
@@ -1,119 +0,0 @@
-/*
- *
- * Copyright (c) 2006 The Apache Software Foundation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- *
- */
-#ifndef _LFProcessor_
-#define _LFProcessor_
-
-#include "apr_poll.h"
-#include <iostream>
-#include <vector>
-#include "APRMonitor.h"
-#include "APRThreadFactory.h"
-#include "Runnable.h"
-
-namespace qpid {
-namespace io {
-
- class LFSessionContext;
-
- /**
- * This class processes a poll set using the leaders-followers
- * pattern for thread synchronization: the leader will poll and on
- * the poll returning, it will remove a session, promote a
- * follower to leadership, then process the session.
- */
- class LFProcessor : private virtual qpid::concurrent::Runnable
- {
- typedef std::vector<LFSessionContext*>::iterator iterator;
-
- const int size;
- const apr_interval_time_t timeout;
- apr_pollset_t* pollset;
- int signalledCount;
- int current;
- const apr_pollfd_t* signalledFDs;
- int count;
- const int workerCount;
- bool hasLeader;
- qpid::concurrent::Thread** const workers;
- qpid::concurrent::APRMonitor leadLock;
- qpid::concurrent::APRMonitor countLock;
- qpid::concurrent::APRThreadFactory factory;
- std::vector<LFSessionContext*> sessions;
- volatile bool stopped;
-
- const apr_pollfd_t* getNextEvent();
- void waitToLead();
- void relinquishLead();
- void poll();
- virtual void run();
-
- public:
- LFProcessor(apr_pool_t* pool, int workers, int size, int timeout);
- /**
- * Add the fd to the poll set. Relies on the client_data being
- * an instance of LFSessionContext.
- */
- void add(const apr_pollfd_t* const fd);
- /**
- * Remove the fd from the poll set.
- */
- void remove(const apr_pollfd_t* const fd);
- /**
- * Signal that the fd passed in, already part of the pollset,
- * has had its flags altered.
- */
- void update(const apr_pollfd_t* const fd);
- /**
- * Add an fd back to the poll set after deactivation.
- */
- void reactivate(const apr_pollfd_t* const fd);
- /**
- * Temporarily remove the fd from the poll set. Called when processing
- * is about to begin.
- */
- void deactivate(const apr_pollfd_t* const fd);
- /**
- * Indicates whether the capacity of this processor has been
- * reached (or whether it can still handle further fd's).
- */
- bool full();
- /**
- * Indicates whether there are any fd's registered.
- */
- bool empty();
- /**
- * Stop processing.
- */
- void stop();
- /**
- * Start processing.
- */
- void start();
- /**
- * Is processing stopped?
- */
- bool isStopped();
-
- ~LFProcessor();
- };
-
-}
-}
-
-
-#endif
diff --git a/cpp/common/io/inc/LFSessionContext.h b/cpp/common/io/inc/LFSessionContext.h
deleted file mode 100644
index d07c8910d3..0000000000
--- a/cpp/common/io/inc/LFSessionContext.h
+++ /dev/null
@@ -1,88 +0,0 @@
-/*
- *
- * Copyright (c) 2006 The Apache Software Foundation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- *
- */
-#ifndef _LFSessionContext_
-#define _LFSessionContext_
-
-#include <queue>
-
-#include "apr_network_io.h"
-#include "apr_poll.h"
-#include "apr_time.h"
-
-#include "AMQFrame.h"
-#include "APRMonitor.h"
-#include "APRSocket.h"
-#include "Buffer.h"
-#include "LFProcessor.h"
-#include "SessionContext.h"
-#include "SessionHandler.h"
-
-namespace qpid {
-namespace io {
-
-
- class LFSessionContext : public virtual SessionContext
- {
- const bool debug;
- APRSocket socket;
- bool initiated;
-
- qpid::framing::Buffer in;
- qpid::framing::Buffer out;
-
- SessionHandler* handler;
- LFProcessor* const processor;
-
- apr_pollfd_t fd;
-
- std::queue<qpid::framing::AMQFrame*> framesToWrite;
- qpid::concurrent::APRMonitor writeLock;
-
- bool processing;
- bool closing;
-
- //these are just for debug, as a crude way of detecting concurrent access
- volatile unsigned int reading;
- volatile unsigned int writing;
-
- static qpid::concurrent::APRMonitor logLock;
- void log(const std::string& desc, qpid::framing::AMQFrame* const frame);
-
- public:
- LFSessionContext(apr_pool_t* pool, apr_socket_t* socket,
- LFProcessor* const processor,
- bool debug = false);
- ~LFSessionContext();
- virtual void send(qpid::framing::AMQFrame* frame);
- virtual void close();
- void read();
- void write();
- void init(SessionHandler* handler);
- void startProcessing();
- void stopProcessing();
- void handleClose();
- void shutdown();
- inline apr_pollfd_t* const getFd(){ return &fd; }
- inline bool isClosed(){ return !socket.isOpen(); }
- };
-
-}
-}
-
-
-#endif
diff --git a/cpp/common/io/inc/SessionContext.h b/cpp/common/io/inc/SessionContext.h
deleted file mode 100644
index f223a70daa..0000000000
--- a/cpp/common/io/inc/SessionContext.h
+++ /dev/null
@@ -1,37 +0,0 @@
-/*
- *
- * Copyright (c) 2006 The Apache Software Foundation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- *
- */
-#ifndef _SessionContext_
-#define _SessionContext_
-
-#include "OutputHandler.h"
-
-namespace qpid {
-namespace io {
-
- class SessionContext : public virtual qpid::framing::OutputHandler
- {
- public:
- virtual void close() = 0;
- virtual ~SessionContext(){}
- };
-
-}
-}
-
-
-#endif
diff --git a/cpp/common/io/inc/SessionHandler.h b/cpp/common/io/inc/SessionHandler.h
deleted file mode 100644
index 21a992ab65..0000000000
--- a/cpp/common/io/inc/SessionHandler.h
+++ /dev/null
@@ -1,42 +0,0 @@
-/*
- *
- * Copyright (c) 2006 The Apache Software Foundation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- *
- */
-#ifndef _SessionHandler_
-#define _SessionHandler_
-
-#include "InputHandler.h"
-#include "InitiationHandler.h"
-#include "ProtocolInitiation.h"
-#include "TimeoutHandler.h"
-
-namespace qpid {
-namespace io {
-
- class SessionHandler : public virtual qpid::framing::InitiationHandler,
- public virtual qpid::framing::InputHandler,
- public virtual TimeoutHandler
- {
- public:
- virtual void closed() = 0;
- virtual ~SessionHandler(){}
- };
-
-}
-}
-
-
-#endif
diff --git a/cpp/common/io/inc/SessionHandlerFactory.h b/cpp/common/io/inc/SessionHandlerFactory.h
deleted file mode 100644
index 67d968b72e..0000000000
--- a/cpp/common/io/inc/SessionHandlerFactory.h
+++ /dev/null
@@ -1,38 +0,0 @@
-/*
- *
- * Copyright (c) 2006 The Apache Software Foundation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- *
- */
-#ifndef _SessionHandlerFactory_
-#define _SessionHandlerFactory_
-
-#include "SessionContext.h"
-#include "SessionHandler.h"
-
-namespace qpid {
-namespace io {
-
- class SessionHandlerFactory
- {
- public:
- virtual SessionHandler* create(SessionContext* ctxt) = 0;
- virtual ~SessionHandlerFactory(){}
- };
-
-}
-}
-
-
-#endif
diff --git a/cpp/common/io/inc/SessionManager.h b/cpp/common/io/inc/SessionManager.h
deleted file mode 100644
index 30c5208532..0000000000
--- a/cpp/common/io/inc/SessionManager.h
+++ /dev/null
@@ -1,40 +0,0 @@
-/*
- *
- * Copyright (c) 2006 The Apache Software Foundation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- *
- */
-#ifndef _SessionManager_
-#define _SessionManager_
-
-#include "SessionContext.h"
-#include "SessionHandler.h"
-
-namespace qpid {
-namespace io {
-
- class SessionManager
- {
- public:
- virtual SessionHandler* init(SessionContext* ctxt) = 0;
- virtual void close(SessionContext* ctxt) = 0;
- virtual void updateInterest(SessionContext* ctxt, bool read, bool write) = 0;
- virtual ~SessionManager(){}
- };
-
-}
-}
-
-
-#endif
diff --git a/cpp/common/io/inc/ShutdownHandler.h b/cpp/common/io/inc/ShutdownHandler.h
deleted file mode 100644
index 186d9eeca4..0000000000
--- a/cpp/common/io/inc/ShutdownHandler.h
+++ /dev/null
@@ -1,34 +0,0 @@
-/*
- *
- * Copyright (c) 2006 The Apache Software Foundation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- *
- */
-#ifndef _ShutdownHandler_
-#define _ShutdownHandler_
-
-namespace qpid {
-namespace io {
-
- class ShutdownHandler
- {
- public:
- virtual void shutdown() = 0;
- virtual ~ShutdownHandler(){}
- };
-
-}
-}
-
-#endif
diff --git a/cpp/common/io/inc/TimeoutHandler.h b/cpp/common/io/inc/TimeoutHandler.h
deleted file mode 100644
index c92220fd6e..0000000000
--- a/cpp/common/io/inc/TimeoutHandler.h
+++ /dev/null
@@ -1,36 +0,0 @@
-/*
- *
- * Copyright (c) 2006 The Apache Software Foundation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- *
- */
-#ifndef _TimeoutHandler_
-#define _TimeoutHandler_
-
-namespace qpid {
-namespace io {
-
- class TimeoutHandler
- {
- public:
- virtual void idleOut() = 0;
- virtual void idleIn() = 0;
- virtual ~TimeoutHandler(){}
- };
-
-}
-}
-
-
-#endif