blob: 98ec15269a53ac986fa1ac536d5014b546018c9f [file] [log] [blame]
# ---------------------------------------------------------------------------
# Licensed to the Apache Software Foundation (ASF) under one or more
# contributor license agreements. See the NOTICE file distributed with
# this work for additional information regarding copyright ownership.
# The ASF licenses this file to You 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.
# ---------------------------------------------------------------------------
cc_sources = \
activemq/cmsutil/CachedConsumer.cpp \
activemq/cmsutil/CachedProducer.cpp \
activemq/cmsutil/CmsAccessor.cpp \
activemq/cmsutil/CmsDestinationAccessor.cpp \
activemq/cmsutil/CmsTemplate.cpp \
activemq/cmsutil/DestinationResolver.cpp \
activemq/cmsutil/DynamicDestinationResolver.cpp \
activemq/cmsutil/MessageCreator.cpp \
activemq/cmsutil/PooledSession.cpp \
activemq/cmsutil/ProducerCallback.cpp \
activemq/cmsutil/ResourceLifecycleManager.cpp \
activemq/cmsutil/SessionCallback.cpp \
activemq/cmsutil/SessionPool.cpp \
activemq/commands/ActiveMQBlobMessage.cpp \
activemq/commands/ActiveMQBytesMessage.cpp \
activemq/commands/ActiveMQDestination.cpp \
activemq/commands/ActiveMQMapMessage.cpp \
activemq/commands/ActiveMQMessage.cpp \
activemq/commands/ActiveMQObjectMessage.cpp \
activemq/commands/ActiveMQQueue.cpp \
activemq/commands/ActiveMQStreamMessage.cpp \
activemq/commands/ActiveMQTempDestination.cpp \
activemq/commands/ActiveMQTempQueue.cpp \
activemq/commands/ActiveMQTempTopic.cpp \
activemq/commands/ActiveMQTextMessage.cpp \
activemq/commands/ActiveMQTopic.cpp \
activemq/commands/BrokerError.cpp \
activemq/commands/BrokerId.cpp \
activemq/commands/BrokerInfo.cpp \
activemq/commands/ConnectionControl.cpp \
activemq/commands/ConnectionError.cpp \
activemq/commands/ConnectionId.cpp \
activemq/commands/ConnectionInfo.cpp \
activemq/commands/ConsumerControl.cpp \
activemq/commands/ConsumerId.cpp \
activemq/commands/ConsumerInfo.cpp \
activemq/commands/ControlCommand.cpp \
activemq/commands/DataArrayResponse.cpp \
activemq/commands/DataResponse.cpp \
activemq/commands/DestinationInfo.cpp \
activemq/commands/DiscoveryEvent.cpp \
activemq/commands/ExceptionResponse.cpp \
activemq/commands/FlushCommand.cpp \
activemq/commands/IntegerResponse.cpp \
activemq/commands/JournalQueueAck.cpp \
activemq/commands/JournalTopicAck.cpp \
activemq/commands/JournalTrace.cpp \
activemq/commands/JournalTransaction.cpp \
activemq/commands/KeepAliveInfo.cpp \
activemq/commands/LastPartialCommand.cpp \
activemq/commands/LocalTransactionId.cpp \
activemq/commands/Message.cpp \
activemq/commands/MessageAck.cpp \
activemq/commands/MessageDispatch.cpp \
activemq/commands/MessageDispatchNotification.cpp \
activemq/commands/MessageId.cpp \
activemq/commands/MessagePull.cpp \
activemq/commands/NetworkBridgeFilter.cpp \
activemq/commands/PartialCommand.cpp \
activemq/commands/ProducerAck.cpp \
activemq/commands/ProducerId.cpp \
activemq/commands/ProducerInfo.cpp \
activemq/commands/RemoveInfo.cpp \
activemq/commands/RemoveSubscriptionInfo.cpp \
activemq/commands/ReplayCommand.cpp \
activemq/commands/Response.cpp \
activemq/commands/SessionId.cpp \
activemq/commands/SessionInfo.cpp \
activemq/commands/ShutdownInfo.cpp \
activemq/commands/SubscriptionInfo.cpp \
activemq/commands/TransactionId.cpp \
activemq/commands/TransactionInfo.cpp \
activemq/commands/WireFormatInfo.cpp \
activemq/commands/XATransactionId.cpp \
activemq/core/ActiveMQAckHandler.cpp \
activemq/core/ActiveMQConnection.cpp \
activemq/core/ActiveMQConnectionFactory.cpp \
activemq/core/ActiveMQConnectionMetaData.cpp \
activemq/core/ActiveMQConstants.cpp \
activemq/core/ActiveMQConsumer.cpp \
activemq/core/ActiveMQDestinationEvent.cpp \
activemq/core/ActiveMQDestinationSource.cpp \
activemq/core/ActiveMQMessageAudit.cpp \
activemq/core/ActiveMQProducer.cpp \
activemq/core/ActiveMQQueueBrowser.cpp \
activemq/core/ActiveMQSession.cpp \
activemq/core/ActiveMQSessionExecutor.cpp \
activemq/core/ActiveMQTransactionContext.cpp \
activemq/core/ActiveMQXAConnection.cpp \
activemq/core/ActiveMQXAConnectionFactory.cpp \
activemq/core/ActiveMQXASession.cpp \
activemq/core/AdvisoryConsumer.cpp \
activemq/core/ConnectionAudit.cpp \
activemq/core/DispatchData.cpp \
activemq/core/Dispatcher.cpp \
activemq/core/FifoMessageDispatchChannel.cpp \
activemq/core/MessageDispatchChannel.cpp \
activemq/core/PrefetchPolicy.cpp \
activemq/core/RedeliveryPolicy.cpp \
activemq/core/SimplePriorityMessageDispatchChannel.cpp \
activemq/core/Synchronization.cpp \
activemq/core/kernels/ActiveMQConsumerKernel.cpp \
activemq/core/kernels/ActiveMQProducerKernel.cpp \
activemq/core/kernels/ActiveMQSessionKernel.cpp \
activemq/core/kernels/ActiveMQXASessionKernel.cpp \
activemq/core/policies/DefaultPrefetchPolicy.cpp \
activemq/core/policies/DefaultRedeliveryPolicy.cpp \
activemq/exceptions/ActiveMQException.cpp \
activemq/exceptions/BrokerException.cpp \
activemq/exceptions/ConnectionFailedException.cpp \
activemq/io/LoggingInputStream.cpp \
activemq/io/LoggingOutputStream.cpp \
activemq/library/ActiveMQCPP.cpp \
activemq/state/CommandVisitor.cpp \
activemq/state/CommandVisitorAdapter.cpp \
activemq/state/ConnectionState.cpp \
activemq/state/ConnectionStateTracker.cpp \
activemq/state/ConsumerState.cpp \
activemq/state/ProducerState.cpp \
activemq/state/SessionState.cpp \
activemq/state/Tracked.cpp \
activemq/state/TransactionState.cpp \
activemq/threads/CompositeTask.cpp \
activemq/threads/CompositeTaskRunner.cpp \
activemq/threads/DedicatedTaskRunner.cpp \
activemq/threads/Scheduler.cpp \
activemq/threads/SchedulerTimerTask.cpp \
activemq/threads/Task.cpp \
activemq/threads/TaskRunner.cpp \
activemq/transport/AbstractTransportFactory.cpp \
activemq/transport/CompositeTransport.cpp \
activemq/transport/DefaultTransportListener.cpp \
activemq/transport/FutureResponse.cpp \
activemq/transport/IOTransport.cpp \
activemq/transport/ResponseCallback.cpp \
activemq/transport/Transport.cpp \
activemq/transport/TransportFilter.cpp \
activemq/transport/TransportRegistry.cpp \
activemq/transport/correlator/ResponseCorrelator.cpp \
activemq/transport/discovery/AbstractDiscoveryAgent.cpp \
activemq/transport/discovery/AbstractDiscoveryAgentFactory.cpp \
activemq/transport/discovery/DiscoveredBrokerData.cpp \
activemq/transport/discovery/DiscoveryAgent.cpp \
activemq/transport/discovery/DiscoveryAgentFactory.cpp \
activemq/transport/discovery/DiscoveryAgentRegistry.cpp \
activemq/transport/discovery/DiscoveryListener.cpp \
activemq/transport/discovery/DiscoveryTransport.cpp \
activemq/transport/discovery/DiscoveryTransportFactory.cpp \
activemq/transport/discovery/http/HttpDiscoveryAgent.cpp \
activemq/transport/discovery/http/HttpDiscoveryAgentFactory.cpp \
activemq/transport/failover/BackupTransport.cpp \
activemq/transport/failover/BackupTransportPool.cpp \
activemq/transport/failover/CloseTransportsTask.cpp \
activemq/transport/failover/FailoverTransport.cpp \
activemq/transport/failover/FailoverTransportFactory.cpp \
activemq/transport/failover/FailoverTransportListener.cpp \
activemq/transport/failover/URIPool.cpp \
activemq/transport/inactivity/InactivityMonitor.cpp \
activemq/transport/inactivity/ReadChecker.cpp \
activemq/transport/inactivity/WriteChecker.cpp \
activemq/transport/logging/LoggingTransport.cpp \
activemq/transport/mock/InternalCommandListener.cpp \
activemq/transport/mock/MockTransport.cpp \
activemq/transport/mock/MockTransportFactory.cpp \
activemq/transport/mock/ResponseBuilder.cpp \
activemq/transport/tcp/SslTransport.cpp \
activemq/transport/tcp/SslTransportFactory.cpp \
activemq/transport/tcp/TcpTransport.cpp \
activemq/transport/tcp/TcpTransportFactory.cpp \
activemq/util/ActiveMQMessageTransformation.cpp \
activemq/util/ActiveMQProperties.cpp \
activemq/util/AdvisorySupport.cpp \
activemq/util/CMSExceptionSupport.cpp \
activemq/util/CompositeData.cpp \
activemq/util/IdGenerator.cpp \
activemq/util/LongSequenceGenerator.cpp \
activemq/util/MarshallingSupport.cpp \
activemq/util/MemoryUsage.cpp \
activemq/util/PrimitiveList.cpp \
activemq/util/PrimitiveMap.cpp \
activemq/util/PrimitiveValueConverter.cpp \
activemq/util/PrimitiveValueNode.cpp \
activemq/util/Service.cpp \
activemq/util/ServiceListener.cpp \
activemq/util/ServiceStopper.cpp \
activemq/util/ServiceSupport.cpp \
activemq/util/Suspendable.cpp \
activemq/util/URISupport.cpp \
activemq/util/Usage.cpp \
activemq/wireformat/MarshalAware.cpp \
activemq/wireformat/WireFormat.cpp \
activemq/wireformat/WireFormatFactory.cpp \
activemq/wireformat/WireFormatNegotiator.cpp \
activemq/wireformat/WireFormatRegistry.cpp \
activemq/wireformat/openwire/OpenWireFormat.cpp \
activemq/wireformat/openwire/OpenWireFormatFactory.cpp \
activemq/wireformat/openwire/OpenWireFormatNegotiator.cpp \
activemq/wireformat/openwire/OpenWireResponseBuilder.cpp \
activemq/wireformat/openwire/marshal/BaseDataStreamMarshaller.cpp \
activemq/wireformat/openwire/marshal/DataStreamMarshaller.cpp \
activemq/wireformat/openwire/marshal/PrimitiveTypesMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/ActiveMQBlobMessageMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/ActiveMQBytesMessageMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/ActiveMQDestinationMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/ActiveMQMapMessageMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/ActiveMQMessageMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/ActiveMQObjectMessageMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/ActiveMQQueueMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/ActiveMQStreamMessageMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/ActiveMQTempDestinationMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/ActiveMQTempQueueMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/ActiveMQTempTopicMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/ActiveMQTextMessageMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/ActiveMQTopicMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/BaseCommandMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/BrokerIdMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/BrokerInfoMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/ConnectionControlMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/ConnectionErrorMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/ConnectionIdMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/ConnectionInfoMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/ConsumerControlMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/ConsumerIdMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/ConsumerInfoMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/ControlCommandMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/DataArrayResponseMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/DataResponseMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/DestinationInfoMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/DiscoveryEventMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/ExceptionResponseMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/FlushCommandMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/IntegerResponseMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/JournalQueueAckMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/JournalTopicAckMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/JournalTraceMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/JournalTransactionMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/KeepAliveInfoMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/LastPartialCommandMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/LocalTransactionIdMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/MarshallerFactory.cpp \
activemq/wireformat/openwire/marshal/generated/MessageAckMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/MessageDispatchMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/MessageDispatchNotificationMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/MessageIdMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/MessageMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/MessagePullMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/NetworkBridgeFilterMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/PartialCommandMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/ProducerAckMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/ProducerIdMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/ProducerInfoMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/RemoveInfoMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/RemoveSubscriptionInfoMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/ReplayCommandMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/ResponseMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/SessionIdMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/SessionInfoMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/ShutdownInfoMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/SubscriptionInfoMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/TransactionIdMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/TransactionInfoMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/WireFormatInfoMarshaller.cpp \
activemq/wireformat/openwire/marshal/generated/XATransactionIdMarshaller.cpp \
activemq/wireformat/openwire/utils/BooleanStream.cpp \
activemq/wireformat/openwire/utils/HexTable.cpp \
activemq/wireformat/openwire/utils/MessagePropertyInterceptor.cpp \
activemq/wireformat/stomp/StompCommandConstants.cpp \
activemq/wireformat/stomp/StompFrame.cpp \
activemq/wireformat/stomp/StompHelper.cpp \
activemq/wireformat/stomp/StompWireFormat.cpp \
activemq/wireformat/stomp/StompWireFormatFactory.cpp \
cms/AsyncCallback.cpp \
cms/BytesMessage.cpp \
cms/CMSException.cpp \
cms/CMSProperties.cpp \
cms/CMSSecurityException.cpp \
cms/Closeable.cpp \
cms/Connection.cpp \
cms/ConnectionFactory.cpp \
cms/ConnectionMetaData.cpp \
cms/DeliveryMode.cpp \
cms/Destination.cpp \
cms/DestinationEvent.cpp \
cms/DestinationListener.cpp \
cms/DestinationSource.cpp \
cms/EnhancedConnection.cpp \
cms/ExceptionListener.cpp \
cms/IllegalStateException.cpp \
cms/InvalidClientIdException.cpp \
cms/InvalidDestinationException.cpp \
cms/InvalidSelectorException.cpp \
cms/MapMessage.cpp \
cms/Message.cpp \
cms/MessageAvailableListener.cpp \
cms/MessageConsumer.cpp \
cms/MessageEOFException.cpp \
cms/MessageEnumeration.cpp \
cms/MessageFormatException.cpp \
cms/MessageListener.cpp \
cms/MessageNotReadableException.cpp \
cms/MessageNotWriteableException.cpp \
cms/MessageProducer.cpp \
cms/MessageTransformer.cpp \
cms/ObjectMessage.cpp \
cms/Queue.cpp \
cms/QueueBrowser.cpp \
cms/ResourceAllocationException.cpp \
cms/Session.cpp \
cms/Startable.cpp \
cms/Stoppable.cpp \
cms/StreamMessage.cpp \
cms/TemporaryQueue.cpp \
cms/TemporaryTopic.cpp \
cms/TextMessage.cpp \
cms/Topic.cpp \
cms/TransactionInProgressException.cpp \
cms/TransactionRolledBackException.cpp \
cms/UnsupportedOperationException.cpp \
cms/XAConnection.cpp \
cms/XAConnectionFactory.cpp \
cms/XAException.cpp \
cms/XAResource.cpp \
cms/XASession.cpp \
cms/Xid.cpp \
decaf/internal/AprPool.cpp \
decaf/internal/DecafRuntime.cpp \
decaf/internal/io/StandardErrorOutputStream.cpp \
decaf/internal/io/StandardInputStream.cpp \
decaf/internal/io/StandardOutputStream.cpp \
decaf/internal/net/DefaultServerSocketFactory.cpp \
decaf/internal/net/DefaultSocketFactory.cpp \
decaf/internal/net/Network.cpp \
decaf/internal/net/SocketFileDescriptor.cpp \
decaf/internal/net/URIEncoderDecoder.cpp \
decaf/internal/net/URIHelper.cpp \
decaf/internal/net/URIType.cpp \
decaf/internal/net/URLStreamHandlerManager.cpp \
decaf/internal/net/URLType.cpp \
decaf/internal/net/URLUtils.cpp \
decaf/internal/net/file/FileHandler.cpp \
decaf/internal/net/http/HttpHandler.cpp \
decaf/internal/net/https/HttpsHandler.cpp \
decaf/internal/net/ssl/DefaultSSLContext.cpp \
decaf/internal/net/ssl/DefaultSSLServerSocketFactory.cpp \
decaf/internal/net/ssl/DefaultSSLSocketFactory.cpp \
decaf/internal/net/ssl/openssl/OpenSSLContextSpi.cpp \
decaf/internal/net/ssl/openssl/OpenSSLParameters.cpp \
decaf/internal/net/ssl/openssl/OpenSSLServerSocket.cpp \
decaf/internal/net/ssl/openssl/OpenSSLServerSocketFactory.cpp \
decaf/internal/net/ssl/openssl/OpenSSLSocket.cpp \
decaf/internal/net/ssl/openssl/OpenSSLSocketException.cpp \
decaf/internal/net/ssl/openssl/OpenSSLSocketFactory.cpp \
decaf/internal/net/ssl/openssl/OpenSSLSocketInputStream.cpp \
decaf/internal/net/ssl/openssl/OpenSSLSocketOutputStream.cpp \
decaf/internal/net/tcp/TcpSocket.cpp \
decaf/internal/net/tcp/TcpSocketInputStream.cpp \
decaf/internal/net/tcp/TcpSocketOutputStream.cpp \
decaf/internal/nio/BufferFactory.cpp \
decaf/internal/nio/ByteArrayBuffer.cpp \
decaf/internal/nio/CharArrayBuffer.cpp \
decaf/internal/nio/DoubleArrayBuffer.cpp \
decaf/internal/nio/FloatArrayBuffer.cpp \
decaf/internal/nio/IntArrayBuffer.cpp \
decaf/internal/nio/LongArrayBuffer.cpp \
decaf/internal/nio/ShortArrayBuffer.cpp \
decaf/internal/security/Engine.cpp \
decaf/internal/security/SecurityRuntime.cpp \
decaf/internal/security/ServiceRegistry.cpp \
decaf/internal/security/provider/DefaultMessageDigestProviderService.cpp \
decaf/internal/security/provider/DefaultProvider.cpp \
decaf/internal/security/provider/DefaultSecureRandomProviderService.cpp \
decaf/internal/security/provider/crypto/MD4MessageDigestSpi.cpp \
decaf/internal/security/provider/crypto/MD5MessageDigestSpi.cpp \
decaf/internal/security/provider/crypto/SHA1MessageDigestSpi.cpp \
decaf/internal/security/unix/SecureRandomImpl.cpp \
decaf/internal/util/ByteArrayAdapter.cpp \
decaf/internal/util/GenericResource.cpp \
decaf/internal/util/HexStringParser.cpp \
decaf/internal/util/Resource.cpp \
decaf/internal/util/ResourceLifecycleManager.cpp \
decaf/internal/util/StringUtils.cpp \
decaf/internal/util/TimerTaskHeap.cpp \
decaf/internal/util/concurrent/ExecutorsSupport.cpp \
decaf/internal/util/concurrent/SynchronizableImpl.cpp \
decaf/internal/util/concurrent/ThreadLocalImpl.cpp \
decaf/internal/util/concurrent/Threading.cpp \
decaf/internal/util/concurrent/unix/Atomics.cpp \
decaf/internal/util/concurrent/unix/PlatformThread.cpp \
decaf/internal/util/zip/adler32.c \
decaf/internal/util/zip/crc32.c \
decaf/internal/util/zip/deflate.c \
decaf/internal/util/zip/gzclose.c \
decaf/internal/util/zip/gzlib.c \
decaf/internal/util/zip/gzread.c \
decaf/internal/util/zip/gzwrite.c \
decaf/internal/util/zip/infback.c \
decaf/internal/util/zip/inffast.c \
decaf/internal/util/zip/inflate.c \
decaf/internal/util/zip/inftrees.c \
decaf/internal/util/zip/trees.c \
decaf/internal/util/zip/uncompr.c \
decaf/internal/util/zip/zutil.c \
decaf/io/BlockingByteArrayInputStream.cpp \
decaf/io/BufferedInputStream.cpp \
decaf/io/BufferedOutputStream.cpp \
decaf/io/ByteArrayInputStream.cpp \
decaf/io/ByteArrayOutputStream.cpp \
decaf/io/Closeable.cpp \
decaf/io/DataInput.cpp \
decaf/io/DataInputStream.cpp \
decaf/io/DataOutput.cpp \
decaf/io/DataOutputStream.cpp \
decaf/io/EOFException.cpp \
decaf/io/FileDescriptor.cpp \
decaf/io/FilterInputStream.cpp \
decaf/io/FilterOutputStream.cpp \
decaf/io/Flushable.cpp \
decaf/io/IOException.cpp \
decaf/io/InputStream.cpp \
decaf/io/InputStreamReader.cpp \
decaf/io/InterruptedIOException.cpp \
decaf/io/OutputStream.cpp \
decaf/io/OutputStreamWriter.cpp \
decaf/io/PushbackInputStream.cpp \
decaf/io/Reader.cpp \
decaf/io/UTFDataFormatException.cpp \
decaf/io/UnsupportedEncodingException.cpp \
decaf/io/Writer.cpp \
decaf/lang/AbstractStringBuilder.cpp \
decaf/lang/Appendable.cpp \
decaf/lang/Boolean.cpp \
decaf/lang/Byte.cpp \
decaf/lang/CharSequence.cpp \
decaf/lang/Character.cpp \
decaf/lang/Comparable.cpp \
decaf/lang/Double.cpp \
decaf/lang/Exception.cpp \
decaf/lang/Float.cpp \
decaf/lang/Integer.cpp \
decaf/lang/Iterable.cpp \
decaf/lang/Long.cpp \
decaf/lang/Math.cpp \
decaf/lang/Number.cpp \
decaf/lang/Readable.cpp \
decaf/lang/Runnable.cpp \
decaf/lang/Runtime.cpp \
decaf/lang/Short.cpp \
decaf/lang/String.cpp \
decaf/lang/StringBuffer.cpp \
decaf/lang/StringBuilder.cpp \
decaf/lang/System.cpp \
decaf/lang/Thread.cpp \
decaf/lang/ThreadGroup.cpp \
decaf/lang/ThreadLocal.cpp \
decaf/lang/Throwable.cpp \
decaf/lang/Types.cpp \
decaf/lang/exceptions/ArrayIndexOutOfBoundsException.cpp \
decaf/lang/exceptions/ClassCastException.cpp \
decaf/lang/exceptions/CloneNotSupportedException.cpp \
decaf/lang/exceptions/IllegalArgumentException.cpp \
decaf/lang/exceptions/IllegalMonitorStateException.cpp \
decaf/lang/exceptions/IllegalStateException.cpp \
decaf/lang/exceptions/IllegalThreadStateException.cpp \
decaf/lang/exceptions/IndexOutOfBoundsException.cpp \
decaf/lang/exceptions/InterruptedException.cpp \
decaf/lang/exceptions/InvalidStateException.cpp \
decaf/lang/exceptions/NegativeArraySizeException.cpp \
decaf/lang/exceptions/NullPointerException.cpp \
decaf/lang/exceptions/NumberFormatException.cpp \
decaf/lang/exceptions/OutOfMemoryError.cpp \
decaf/lang/exceptions/RuntimeException.cpp \
decaf/lang/exceptions/SecurityException.cpp \
decaf/lang/exceptions/StringIndexOutOfBoundsException.cpp \
decaf/lang/exceptions/UnsupportedOperationException.cpp \
decaf/net/BindException.cpp \
decaf/net/ConnectException.cpp \
decaf/net/ContentHandlerFactory.cpp \
decaf/net/DatagramPacket.cpp \
decaf/net/FileNameMap.cpp \
decaf/net/HttpRetryException.cpp \
decaf/net/HttpURLConnection.cpp \
decaf/net/Inet4Address.cpp \
decaf/net/Inet6Address.cpp \
decaf/net/InetAddress.cpp \
decaf/net/InetSocketAddress.cpp \
decaf/net/MalformedURLException.cpp \
decaf/net/NoRouteToHostException.cpp \
decaf/net/PortUnreachableException.cpp \
decaf/net/ProtocolException.cpp \
decaf/net/Proxy.cpp \
decaf/net/ServerSocket.cpp \
decaf/net/ServerSocketFactory.cpp \
decaf/net/Socket.cpp \
decaf/net/SocketAddress.cpp \
decaf/net/SocketError.cpp \
decaf/net/SocketException.cpp \
decaf/net/SocketFactory.cpp \
decaf/net/SocketImpl.cpp \
decaf/net/SocketImplFactory.cpp \
decaf/net/SocketOptions.cpp \
decaf/net/SocketTimeoutException.cpp \
decaf/net/URI.cpp \
decaf/net/URISyntaxException.cpp \
decaf/net/URL.cpp \
decaf/net/URLConnection.cpp \
decaf/net/URLDecoder.cpp \
decaf/net/URLEncoder.cpp \
decaf/net/URLStreamHandler.cpp \
decaf/net/URLStreamHandlerFactory.cpp \
decaf/net/UnknownHostException.cpp \
decaf/net/UnknownServiceException.cpp \
decaf/net/ssl/SSLContext.cpp \
decaf/net/ssl/SSLContextSpi.cpp \
decaf/net/ssl/SSLParameters.cpp \
decaf/net/ssl/SSLServerSocket.cpp \
decaf/net/ssl/SSLServerSocketFactory.cpp \
decaf/net/ssl/SSLSocket.cpp \
decaf/net/ssl/SSLSocketFactory.cpp \
decaf/nio/Buffer.cpp \
decaf/nio/BufferOverflowException.cpp \
decaf/nio/BufferUnderflowException.cpp \
decaf/nio/ByteBuffer.cpp \
decaf/nio/CharBuffer.cpp \
decaf/nio/DoubleBuffer.cpp \
decaf/nio/FloatBuffer.cpp \
decaf/nio/IntBuffer.cpp \
decaf/nio/InvalidMarkException.cpp \
decaf/nio/LongBuffer.cpp \
decaf/nio/ReadOnlyBufferException.cpp \
decaf/nio/ShortBuffer.cpp \
decaf/security/DigestException.cpp \
decaf/security/GeneralSecurityException.cpp \
decaf/security/InvalidKeyException.cpp \
decaf/security/Key.cpp \
decaf/security/KeyException.cpp \
decaf/security/KeyManagementException.cpp \
decaf/security/MessageDigest.cpp \
decaf/security/MessageDigestSpi.cpp \
decaf/security/NoSuchAlgorithmException.cpp \
decaf/security/NoSuchProviderException.cpp \
decaf/security/Principal.cpp \
decaf/security/Provider.cpp \
decaf/security/ProviderException.cpp \
decaf/security/ProviderService.cpp \
decaf/security/PublicKey.cpp \
decaf/security/SecureRandom.cpp \
decaf/security/SecureRandomSpi.cpp \
decaf/security/Security.cpp \
decaf/security/SecuritySpi.cpp \
decaf/security/SignatureException.cpp \
decaf/security/auth/x500/X500Principal.cpp \
decaf/security/cert/Certificate.cpp \
decaf/security/cert/CertificateEncodingException.cpp \
decaf/security/cert/CertificateException.cpp \
decaf/security/cert/CertificateExpiredException.cpp \
decaf/security/cert/CertificateNotYetValidException.cpp \
decaf/security/cert/CertificateParsingException.cpp \
decaf/security/cert/X509Certificate.cpp \
decaf/util/AbstractCollection.cpp \
decaf/util/AbstractList.cpp \
decaf/util/AbstractMap.cpp \
decaf/util/AbstractQueue.cpp \
decaf/util/AbstractSequentialList.cpp \
decaf/util/AbstractSet.cpp \
decaf/util/ArrayList.cpp \
decaf/util/Arrays.cpp \
decaf/util/BitSet.cpp \
decaf/util/Collection.cpp \
decaf/util/Collections.cpp \
decaf/util/Comparator.cpp \
decaf/util/ConcurrentModificationException.cpp \
decaf/util/Date.cpp \
decaf/util/Deque.cpp \
decaf/util/HashCode.cpp \
decaf/util/HashMap.cpp \
decaf/util/HashSet.cpp \
decaf/util/Iterator.cpp \
decaf/util/LRUCache.cpp \
decaf/util/LinkedHashMap.cpp \
decaf/util/LinkedHashSet.cpp \
decaf/util/LinkedList.cpp \
decaf/util/List.cpp \
decaf/util/ListIterator.cpp \
decaf/util/Map.cpp \
decaf/util/MapEntry.cpp \
decaf/util/NoSuchElementException.cpp \
decaf/util/PriorityQueue.cpp \
decaf/util/Properties.cpp \
decaf/util/Queue.cpp \
decaf/util/Random.cpp \
decaf/util/Set.cpp \
decaf/util/StlList.cpp \
decaf/util/StlMap.cpp \
decaf/util/StlQueue.cpp \
decaf/util/StlSet.cpp \
decaf/util/StringTokenizer.cpp \
decaf/util/Timer.cpp \
decaf/util/TimerTask.cpp \
decaf/util/UUID.cpp \
decaf/util/comparators/Equals.cpp \
decaf/util/comparators/Less.cpp \
decaf/util/concurrent/AbstractExecutorService.cpp \
decaf/util/concurrent/BlockingQueue.cpp \
decaf/util/concurrent/BrokenBarrierException.cpp \
decaf/util/concurrent/Callable.cpp \
decaf/util/concurrent/CancellationException.cpp \
decaf/util/concurrent/ConcurrentHashMap.cpp \
decaf/util/concurrent/ConcurrentMap.cpp \
decaf/util/concurrent/ConcurrentStlMap.cpp \
decaf/util/concurrent/CopyOnWriteArrayList.cpp \
decaf/util/concurrent/CopyOnWriteArraySet.cpp \
decaf/util/concurrent/CountDownLatch.cpp \
decaf/util/concurrent/Delayed.cpp \
decaf/util/concurrent/ExecutionException.cpp \
decaf/util/concurrent/Executor.cpp \
decaf/util/concurrent/ExecutorService.cpp \
decaf/util/concurrent/Executors.cpp \
decaf/util/concurrent/Future.cpp \
decaf/util/concurrent/FutureTask.cpp \
decaf/util/concurrent/LinkedBlockingQueue.cpp \
decaf/util/concurrent/Lock.cpp \
decaf/util/concurrent/Mutex.cpp \
decaf/util/concurrent/RejectedExecutionException.cpp \
decaf/util/concurrent/RejectedExecutionHandler.cpp \
decaf/util/concurrent/RunnableFuture.cpp \
decaf/util/concurrent/Semaphore.cpp \
decaf/util/concurrent/Synchronizable.cpp \
decaf/util/concurrent/SynchronousQueue.cpp \
decaf/util/concurrent/ThreadFactory.cpp \
decaf/util/concurrent/ThreadPoolExecutor.cpp \
decaf/util/concurrent/TimeUnit.cpp \
decaf/util/concurrent/TimeoutException.cpp \
decaf/util/concurrent/atomic/AtomicBoolean.cpp \
decaf/util/concurrent/atomic/AtomicInteger.cpp \
decaf/util/concurrent/atomic/AtomicRefCounter.cpp \
decaf/util/concurrent/atomic/AtomicReference.cpp \
decaf/util/concurrent/locks/AbstractOwnableSynchronizer.cpp \
decaf/util/concurrent/locks/AbstractQueuedSynchronizer.cpp \
decaf/util/concurrent/locks/Condition.cpp \
decaf/util/concurrent/locks/Lock.cpp \
decaf/util/concurrent/locks/LockSupport.cpp \
decaf/util/concurrent/locks/ReadWriteLock.cpp \
decaf/util/concurrent/locks/ReentrantLock.cpp \
decaf/util/concurrent/locks/ReentrantReadWriteLock.cpp \
decaf/util/logging/ConsoleHandler.cpp \
decaf/util/logging/ErrorManager.cpp \
decaf/util/logging/Formatter.cpp \
decaf/util/logging/Handler.cpp \
decaf/util/logging/Level.cpp \
decaf/util/logging/LogManager.cpp \
decaf/util/logging/LogRecord.cpp \
decaf/util/logging/LogWriter.cpp \
decaf/util/logging/Logger.cpp \
decaf/util/logging/LoggerHierarchy.cpp \
decaf/util/logging/SimpleFormatter.cpp \
decaf/util/logging/SimpleLogger.cpp \
decaf/util/logging/StreamHandler.cpp \
decaf/util/logging/XMLFormatter.cpp \
decaf/util/zip/Adler32.cpp \
decaf/util/zip/CRC32.cpp \
decaf/util/zip/CheckedInputStream.cpp \
decaf/util/zip/CheckedOutputStream.cpp \
decaf/util/zip/Checksum.cpp \
decaf/util/zip/DataFormatException.cpp \
decaf/util/zip/Deflater.cpp \
decaf/util/zip/DeflaterOutputStream.cpp \
decaf/util/zip/Inflater.cpp \
decaf/util/zip/InflaterInputStream.cpp \
decaf/util/zip/ZipException.cpp
h_sources = \
activemq/cmsutil/CachedConsumer.h \
activemq/cmsutil/CachedProducer.h \
activemq/cmsutil/CmsAccessor.h \
activemq/cmsutil/CmsDestinationAccessor.h \
activemq/cmsutil/CmsTemplate.h \
activemq/cmsutil/DestinationResolver.h \
activemq/cmsutil/DynamicDestinationResolver.h \
activemq/cmsutil/MessageCreator.h \
activemq/cmsutil/PooledSession.h \
activemq/cmsutil/ProducerCallback.h \
activemq/cmsutil/ResourceLifecycleManager.h \
activemq/cmsutil/SessionCallback.h \
activemq/cmsutil/SessionPool.h \
activemq/commands/ActiveMQBlobMessage.h \
activemq/commands/ActiveMQBytesMessage.h \
activemq/commands/ActiveMQDestination.h \
activemq/commands/ActiveMQMapMessage.h \
activemq/commands/ActiveMQMessage.h \
activemq/commands/ActiveMQMessageTemplate.h \
activemq/commands/ActiveMQObjectMessage.h \
activemq/commands/ActiveMQQueue.h \
activemq/commands/ActiveMQStreamMessage.h \
activemq/commands/ActiveMQTempDestination.h \
activemq/commands/ActiveMQTempQueue.h \
activemq/commands/ActiveMQTempTopic.h \
activemq/commands/ActiveMQTextMessage.h \
activemq/commands/ActiveMQTopic.h \
activemq/commands/BaseCommand.h \
activemq/commands/BaseDataStructure.h \
activemq/commands/BooleanExpression.h \
activemq/commands/BrokerError.h \
activemq/commands/BrokerId.h \
activemq/commands/BrokerInfo.h \
activemq/commands/Command.h \
activemq/commands/ConnectionControl.h \
activemq/commands/ConnectionError.h \
activemq/commands/ConnectionId.h \
activemq/commands/ConnectionInfo.h \
activemq/commands/ConsumerControl.h \
activemq/commands/ConsumerId.h \
activemq/commands/ConsumerInfo.h \
activemq/commands/ControlCommand.h \
activemq/commands/DataArrayResponse.h \
activemq/commands/DataResponse.h \
activemq/commands/DataStructure.h \
activemq/commands/DestinationInfo.h \
activemq/commands/DiscoveryEvent.h \
activemq/commands/ExceptionResponse.h \
activemq/commands/FlushCommand.h \
activemq/commands/IntegerResponse.h \
activemq/commands/JournalQueueAck.h \
activemq/commands/JournalTopicAck.h \
activemq/commands/JournalTrace.h \
activemq/commands/JournalTransaction.h \
activemq/commands/KeepAliveInfo.h \
activemq/commands/LastPartialCommand.h \
activemq/commands/LocalTransactionId.h \
activemq/commands/Message.h \
activemq/commands/MessageAck.h \
activemq/commands/MessageDispatch.h \
activemq/commands/MessageDispatchNotification.h \
activemq/commands/MessageId.h \
activemq/commands/MessagePull.h \
activemq/commands/NetworkBridgeFilter.h \
activemq/commands/PartialCommand.h \
activemq/commands/ProducerAck.h \
activemq/commands/ProducerId.h \
activemq/commands/ProducerInfo.h \
activemq/commands/RemoveInfo.h \
activemq/commands/RemoveSubscriptionInfo.h \
activemq/commands/ReplayCommand.h \
activemq/commands/Response.h \
activemq/commands/SessionId.h \
activemq/commands/SessionInfo.h \
activemq/commands/ShutdownInfo.h \
activemq/commands/SubscriptionInfo.h \
activemq/commands/TransactionId.h \
activemq/commands/TransactionInfo.h \
activemq/commands/WireFormatInfo.h \
activemq/commands/XATransactionId.h \
activemq/core/ActiveMQAckHandler.h \
activemq/core/ActiveMQConnection.h \
activemq/core/ActiveMQConnectionFactory.h \
activemq/core/ActiveMQConnectionMetaData.h \
activemq/core/ActiveMQConstants.h \
activemq/core/ActiveMQConsumer.h \
activemq/core/ActiveMQDestinationEvent.h \
activemq/core/ActiveMQDestinationSource.h \
activemq/core/ActiveMQMessageAudit.h \
activemq/core/ActiveMQProducer.h \
activemq/core/ActiveMQQueueBrowser.h \
activemq/core/ActiveMQSession.h \
activemq/core/ActiveMQSessionExecutor.h \
activemq/core/ActiveMQTransactionContext.h \
activemq/core/ActiveMQXAConnection.h \
activemq/core/ActiveMQXAConnectionFactory.h \
activemq/core/ActiveMQXASession.h \
activemq/core/AdvisoryConsumer.h \
activemq/core/ConnectionAudit.h \
activemq/core/DispatchData.h \
activemq/core/Dispatcher.h \
activemq/core/FifoMessageDispatchChannel.h \
activemq/core/MessageDispatchChannel.h \
activemq/core/PrefetchPolicy.h \
activemq/core/RedeliveryPolicy.h \
activemq/core/SimplePriorityMessageDispatchChannel.h \
activemq/core/Synchronization.h \
activemq/core/kernels/ActiveMQConsumerKernel.h \
activemq/core/kernels/ActiveMQProducerKernel.h \
activemq/core/kernels/ActiveMQSessionKernel.h \
activemq/core/kernels/ActiveMQXASessionKernel.h \
activemq/core/policies/DefaultPrefetchPolicy.h \
activemq/core/policies/DefaultRedeliveryPolicy.h \
activemq/exceptions/ActiveMQException.h \
activemq/exceptions/BrokerException.h \
activemq/exceptions/ConnectionFailedException.h \
activemq/exceptions/ExceptionDefines.h \
activemq/io/LoggingInputStream.h \
activemq/io/LoggingOutputStream.h \
activemq/library/ActiveMQCPP.h \
activemq/state/CommandVisitor.h \
activemq/state/CommandVisitorAdapter.h \
activemq/state/ConnectionState.h \
activemq/state/ConnectionStateTracker.h \
activemq/state/ConsumerState.h \
activemq/state/ProducerState.h \
activemq/state/SessionState.h \
activemq/state/Tracked.h \
activemq/state/TransactionState.h \
activemq/threads/CompositeTask.h \
activemq/threads/CompositeTaskRunner.h \
activemq/threads/DedicatedTaskRunner.h \
activemq/threads/Scheduler.h \
activemq/threads/SchedulerTimerTask.h \
activemq/threads/Task.h \
activemq/threads/TaskRunner.h \
activemq/transport/AbstractTransportFactory.h \
activemq/transport/CompositeTransport.h \
activemq/transport/DefaultTransportListener.h \
activemq/transport/FutureResponse.h \
activemq/transport/IOTransport.h \
activemq/transport/ResponseCallback.h \
activemq/transport/Transport.h \
activemq/transport/TransportFactory.h \
activemq/transport/TransportFilter.h \
activemq/transport/TransportListener.h \
activemq/transport/TransportRegistry.h \
activemq/transport/correlator/ResponseCorrelator.h \
activemq/transport/discovery/AbstractDiscoveryAgent.h \
activemq/transport/discovery/AbstractDiscoveryAgentFactory.h \
activemq/transport/discovery/DiscoveredBrokerData.h \
activemq/transport/discovery/DiscoveryAgent.h \
activemq/transport/discovery/DiscoveryAgentFactory.h \
activemq/transport/discovery/DiscoveryAgentRegistry.h \
activemq/transport/discovery/DiscoveryListener.h \
activemq/transport/discovery/DiscoveryTransport.h \
activemq/transport/discovery/DiscoveryTransportFactory.h \
activemq/transport/discovery/http/HttpDiscoveryAgent.h \
activemq/transport/discovery/http/HttpDiscoveryAgentFactory.h \
activemq/transport/failover/BackupTransport.h \
activemq/transport/failover/BackupTransportPool.h \
activemq/transport/failover/CloseTransportsTask.h \
activemq/transport/failover/FailoverTransport.h \
activemq/transport/failover/FailoverTransportFactory.h \
activemq/transport/failover/FailoverTransportListener.h \
activemq/transport/failover/URIPool.h \
activemq/transport/inactivity/InactivityMonitor.h \
activemq/transport/inactivity/ReadChecker.h \
activemq/transport/inactivity/WriteChecker.h \
activemq/transport/logging/LoggingTransport.h \
activemq/transport/mock/InternalCommandListener.h \
activemq/transport/mock/MockTransport.h \
activemq/transport/mock/MockTransportFactory.h \
activemq/transport/mock/ResponseBuilder.h \
activemq/transport/tcp/SslTransport.h \
activemq/transport/tcp/SslTransportFactory.h \
activemq/transport/tcp/TcpTransport.h \
activemq/transport/tcp/TcpTransportFactory.h \
activemq/util/ActiveMQMessageTransformation.h \
activemq/util/ActiveMQProperties.h \
activemq/util/AdvisorySupport.h \
activemq/util/CMSExceptionSupport.h \
activemq/util/CompositeData.h \
activemq/util/Config.h \
activemq/util/IdGenerator.h \
activemq/util/LongSequenceGenerator.h \
activemq/util/MarshallingSupport.h \
activemq/util/MemoryUsage.h \
activemq/util/PrimitiveList.h \
activemq/util/PrimitiveMap.h \
activemq/util/PrimitiveValueConverter.h \
activemq/util/PrimitiveValueNode.h \
activemq/util/Service.h \
activemq/util/ServiceListener.h \
activemq/util/ServiceStopper.h \
activemq/util/ServiceSupport.h \
activemq/util/Suspendable.h \
activemq/util/URISupport.h \
activemq/util/Usage.h \
activemq/wireformat/MarshalAware.h \
activemq/wireformat/WireFormat.h \
activemq/wireformat/WireFormatFactory.h \
activemq/wireformat/WireFormatNegotiator.h \
activemq/wireformat/WireFormatRegistry.h \
activemq/wireformat/openwire/OpenWireFormat.h \
activemq/wireformat/openwire/OpenWireFormatFactory.h \
activemq/wireformat/openwire/OpenWireFormatNegotiator.h \
activemq/wireformat/openwire/OpenWireResponseBuilder.h \
activemq/wireformat/openwire/marshal/BaseDataStreamMarshaller.h \
activemq/wireformat/openwire/marshal/DataStreamMarshaller.h \
activemq/wireformat/openwire/marshal/PrimitiveTypesMarshaller.h \
activemq/wireformat/openwire/marshal/generated/ActiveMQBlobMessageMarshaller.h \
activemq/wireformat/openwire/marshal/generated/ActiveMQBytesMessageMarshaller.h \
activemq/wireformat/openwire/marshal/generated/ActiveMQDestinationMarshaller.h \
activemq/wireformat/openwire/marshal/generated/ActiveMQMapMessageMarshaller.h \
activemq/wireformat/openwire/marshal/generated/ActiveMQMessageMarshaller.h \
activemq/wireformat/openwire/marshal/generated/ActiveMQObjectMessageMarshaller.h \
activemq/wireformat/openwire/marshal/generated/ActiveMQQueueMarshaller.h \
activemq/wireformat/openwire/marshal/generated/ActiveMQStreamMessageMarshaller.h \
activemq/wireformat/openwire/marshal/generated/ActiveMQTempDestinationMarshaller.h \
activemq/wireformat/openwire/marshal/generated/ActiveMQTempQueueMarshaller.h \
activemq/wireformat/openwire/marshal/generated/ActiveMQTempTopicMarshaller.h \
activemq/wireformat/openwire/marshal/generated/ActiveMQTextMessageMarshaller.h \
activemq/wireformat/openwire/marshal/generated/ActiveMQTopicMarshaller.h \
activemq/wireformat/openwire/marshal/generated/BaseCommandMarshaller.h \
activemq/wireformat/openwire/marshal/generated/BrokerIdMarshaller.h \
activemq/wireformat/openwire/marshal/generated/BrokerInfoMarshaller.h \
activemq/wireformat/openwire/marshal/generated/ConnectionControlMarshaller.h \
activemq/wireformat/openwire/marshal/generated/ConnectionErrorMarshaller.h \
activemq/wireformat/openwire/marshal/generated/ConnectionIdMarshaller.h \
activemq/wireformat/openwire/marshal/generated/ConnectionInfoMarshaller.h \
activemq/wireformat/openwire/marshal/generated/ConsumerControlMarshaller.h \
activemq/wireformat/openwire/marshal/generated/ConsumerIdMarshaller.h \
activemq/wireformat/openwire/marshal/generated/ConsumerInfoMarshaller.h \
activemq/wireformat/openwire/marshal/generated/ControlCommandMarshaller.h \
activemq/wireformat/openwire/marshal/generated/DataArrayResponseMarshaller.h \
activemq/wireformat/openwire/marshal/generated/DataResponseMarshaller.h \
activemq/wireformat/openwire/marshal/generated/DestinationInfoMarshaller.h \
activemq/wireformat/openwire/marshal/generated/DiscoveryEventMarshaller.h \
activemq/wireformat/openwire/marshal/generated/ExceptionResponseMarshaller.h \
activemq/wireformat/openwire/marshal/generated/FlushCommandMarshaller.h \
activemq/wireformat/openwire/marshal/generated/IntegerResponseMarshaller.h \
activemq/wireformat/openwire/marshal/generated/JournalQueueAckMarshaller.h \
activemq/wireformat/openwire/marshal/generated/JournalTopicAckMarshaller.h \
activemq/wireformat/openwire/marshal/generated/JournalTraceMarshaller.h \
activemq/wireformat/openwire/marshal/generated/JournalTransactionMarshaller.h \
activemq/wireformat/openwire/marshal/generated/KeepAliveInfoMarshaller.h \
activemq/wireformat/openwire/marshal/generated/LastPartialCommandMarshaller.h \
activemq/wireformat/openwire/marshal/generated/LocalTransactionIdMarshaller.h \
activemq/wireformat/openwire/marshal/generated/MarshallerFactory.h \
activemq/wireformat/openwire/marshal/generated/MessageAckMarshaller.h \
activemq/wireformat/openwire/marshal/generated/MessageDispatchMarshaller.h \
activemq/wireformat/openwire/marshal/generated/MessageDispatchNotificationMarshaller.h \
activemq/wireformat/openwire/marshal/generated/MessageIdMarshaller.h \
activemq/wireformat/openwire/marshal/generated/MessageMarshaller.h \
activemq/wireformat/openwire/marshal/generated/MessagePullMarshaller.h \
activemq/wireformat/openwire/marshal/generated/NetworkBridgeFilterMarshaller.h \
activemq/wireformat/openwire/marshal/generated/PartialCommandMarshaller.h \
activemq/wireformat/openwire/marshal/generated/ProducerAckMarshaller.h \
activemq/wireformat/openwire/marshal/generated/ProducerIdMarshaller.h \
activemq/wireformat/openwire/marshal/generated/ProducerInfoMarshaller.h \
activemq/wireformat/openwire/marshal/generated/RemoveInfoMarshaller.h \
activemq/wireformat/openwire/marshal/generated/RemoveSubscriptionInfoMarshaller.h \
activemq/wireformat/openwire/marshal/generated/ReplayCommandMarshaller.h \
activemq/wireformat/openwire/marshal/generated/ResponseMarshaller.h \
activemq/wireformat/openwire/marshal/generated/SessionIdMarshaller.h \
activemq/wireformat/openwire/marshal/generated/SessionInfoMarshaller.h \
activemq/wireformat/openwire/marshal/generated/ShutdownInfoMarshaller.h \
activemq/wireformat/openwire/marshal/generated/SubscriptionInfoMarshaller.h \
activemq/wireformat/openwire/marshal/generated/TransactionIdMarshaller.h \
activemq/wireformat/openwire/marshal/generated/TransactionInfoMarshaller.h \
activemq/wireformat/openwire/marshal/generated/WireFormatInfoMarshaller.h \
activemq/wireformat/openwire/marshal/generated/XATransactionIdMarshaller.h \
activemq/wireformat/openwire/utils/BooleanStream.h \
activemq/wireformat/openwire/utils/HexTable.h \
activemq/wireformat/openwire/utils/MessagePropertyInterceptor.h \
activemq/wireformat/stomp/StompCommandConstants.h \
activemq/wireformat/stomp/StompFrame.h \
activemq/wireformat/stomp/StompHelper.h \
activemq/wireformat/stomp/StompWireFormat.h \
activemq/wireformat/stomp/StompWireFormatFactory.h \
cms/AsyncCallback.h \
cms/BytesMessage.h \
cms/CMSException.h \
cms/CMSProperties.h \
cms/CMSSecurityException.h \
cms/Closeable.h \
cms/Config.h \
cms/Connection.h \
cms/ConnectionFactory.h \
cms/ConnectionMetaData.h \
cms/DeliveryMode.h \
cms/Destination.h \
cms/DestinationEvent.h \
cms/DestinationListener.h \
cms/DestinationSource.h \
cms/EnhancedConnection.h \
cms/ExceptionListener.h \
cms/IllegalStateException.h \
cms/InvalidClientIdException.h \
cms/InvalidDestinationException.h \
cms/InvalidSelectorException.h \
cms/MapMessage.h \
cms/Message.h \
cms/MessageAvailableListener.h \
cms/MessageConsumer.h \
cms/MessageEOFException.h \
cms/MessageEnumeration.h \
cms/MessageFormatException.h \
cms/MessageListener.h \
cms/MessageNotReadableException.h \
cms/MessageNotWriteableException.h \
cms/MessageProducer.h \
cms/MessageTransformer.h \
cms/ObjectMessage.h \
cms/Queue.h \
cms/QueueBrowser.h \
cms/ResourceAllocationException.h \
cms/Session.h \
cms/Startable.h \
cms/Stoppable.h \
cms/StreamMessage.h \
cms/TemporaryQueue.h \
cms/TemporaryTopic.h \
cms/TextMessage.h \
cms/Topic.h \
cms/TransactionInProgressException.h \
cms/TransactionRolledBackException.h \
cms/UnsupportedOperationException.h \
cms/XAConnection.h \
cms/XAConnectionFactory.h \
cms/XAException.h \
cms/XAResource.h \
cms/XASession.h \
cms/Xid.h \
decaf/internal/AprPool.h \
decaf/internal/DecafRuntime.h \
decaf/internal/io/StandardErrorOutputStream.h \
decaf/internal/io/StandardInputStream.h \
decaf/internal/io/StandardOutputStream.h \
decaf/internal/net/DefaultServerSocketFactory.h \
decaf/internal/net/DefaultSocketFactory.h \
decaf/internal/net/Network.h \
decaf/internal/net/SocketFileDescriptor.h \
decaf/internal/net/URIEncoderDecoder.h \
decaf/internal/net/URIHelper.h \
decaf/internal/net/URIType.h \
decaf/internal/net/URLStreamHandlerManager.h \
decaf/internal/net/URLType.h \
decaf/internal/net/URLUtils.h \
decaf/internal/net/file/FileHandler.h \
decaf/internal/net/http/HttpHandler.h \
decaf/internal/net/https/HttpsHandler.h \
decaf/internal/net/ssl/DefaultSSLContext.h \
decaf/internal/net/ssl/DefaultSSLServerSocketFactory.h \
decaf/internal/net/ssl/DefaultSSLSocketFactory.h \
decaf/internal/net/ssl/openssl/OpenSSLContextSpi.h \
decaf/internal/net/ssl/openssl/OpenSSLParameters.h \
decaf/internal/net/ssl/openssl/OpenSSLServerSocket.h \
decaf/internal/net/ssl/openssl/OpenSSLServerSocketFactory.h \
decaf/internal/net/ssl/openssl/OpenSSLSocket.h \
decaf/internal/net/ssl/openssl/OpenSSLSocketException.h \
decaf/internal/net/ssl/openssl/OpenSSLSocketFactory.h \
decaf/internal/net/ssl/openssl/OpenSSLSocketInputStream.h \
decaf/internal/net/ssl/openssl/OpenSSLSocketOutputStream.h \
decaf/internal/net/tcp/TcpSocket.h \
decaf/internal/net/tcp/TcpSocketInputStream.h \
decaf/internal/net/tcp/TcpSocketOutputStream.h \
decaf/internal/nio/BufferFactory.h \
decaf/internal/nio/ByteArrayBuffer.h \
decaf/internal/nio/CharArrayBuffer.h \
decaf/internal/nio/DoubleArrayBuffer.h \
decaf/internal/nio/FloatArrayBuffer.h \
decaf/internal/nio/IntArrayBuffer.h \
decaf/internal/nio/LongArrayBuffer.h \
decaf/internal/nio/ShortArrayBuffer.h \
decaf/internal/security/Engine.h \
decaf/internal/security/SecurityRuntime.h \
decaf/internal/security/ServiceRegistry.h \
decaf/internal/security/provider/DefaultMessageDigestProviderService.h \
decaf/internal/security/provider/DefaultProvider.h \
decaf/internal/security/provider/DefaultSecureRandomProviderService.h \
decaf/internal/security/provider/crypto/MD4MessageDigestSpi.h \
decaf/internal/security/provider/crypto/MD5MessageDigestSpi.h \
decaf/internal/security/provider/crypto/SHA1MessageDigestSpi.h \
decaf/internal/security/unix/SecureRandomImpl.h \
decaf/internal/security/windows/SecureRandomImpl.h \
decaf/internal/util/ByteArrayAdapter.h \
decaf/internal/util/GenericResource.h \
decaf/internal/util/HexStringParser.h \
decaf/internal/util/Resource.h \
decaf/internal/util/ResourceLifecycleManager.h \
decaf/internal/util/StringUtils.h \
decaf/internal/util/TimerTaskHeap.h \
decaf/internal/util/concurrent/Atomics.h \
decaf/internal/util/concurrent/ExecutorsSupport.h \
decaf/internal/util/concurrent/PlatformThread.h \
decaf/internal/util/concurrent/SynchronizableImpl.h \
decaf/internal/util/concurrent/ThreadLocalImpl.h \
decaf/internal/util/concurrent/Threading.h \
decaf/internal/util/concurrent/ThreadingTypes.h \
decaf/internal/util/concurrent/TransferQueue.h \
decaf/internal/util/concurrent/TransferStack.h \
decaf/internal/util/concurrent/Transferer.h \
decaf/internal/util/concurrent/unix/PlatformDefs.h \
decaf/internal/util/concurrent/windows/PlatformDefs.h \
decaf/internal/util/zip/crc32.h \
decaf/internal/util/zip/deflate.h \
decaf/internal/util/zip/gzguts.h \
decaf/internal/util/zip/inffast.h \
decaf/internal/util/zip/inffixed.h \
decaf/internal/util/zip/inflate.h \
decaf/internal/util/zip/inftrees.h \
decaf/internal/util/zip/trees.h \
decaf/internal/util/zip/zconf.h \
decaf/internal/util/zip/zlib.h \
decaf/internal/util/zip/zutil.h \
decaf/io/BlockingByteArrayInputStream.h \
decaf/io/BufferedInputStream.h \
decaf/io/BufferedOutputStream.h \
decaf/io/ByteArrayInputStream.h \
decaf/io/ByteArrayOutputStream.h \
decaf/io/Closeable.h \
decaf/io/DataInput.h \
decaf/io/DataInputStream.h \
decaf/io/DataOutput.h \
decaf/io/DataOutputStream.h \
decaf/io/EOFException.h \
decaf/io/FileDescriptor.h \
decaf/io/FilterInputStream.h \
decaf/io/FilterOutputStream.h \
decaf/io/Flushable.h \
decaf/io/IOException.h \
decaf/io/InputStream.h \
decaf/io/InputStreamReader.h \
decaf/io/InterruptedIOException.h \
decaf/io/OutputStream.h \
decaf/io/OutputStreamWriter.h \
decaf/io/PushbackInputStream.h \
decaf/io/Reader.h \
decaf/io/UTFDataFormatException.h \
decaf/io/UnsupportedEncodingException.h \
decaf/io/Writer.h \
decaf/lang/AbstractStringBuilder.h \
decaf/lang/Appendable.h \
decaf/lang/ArrayPointer.h \
decaf/lang/Boolean.h \
decaf/lang/Byte.h \
decaf/lang/CharSequence.h \
decaf/lang/Character.h \
decaf/lang/Comparable.h \
decaf/lang/Double.h \
decaf/lang/Exception.h \
decaf/lang/Float.h \
decaf/lang/Integer.h \
decaf/lang/Iterable.h \
decaf/lang/Long.h \
decaf/lang/Math.h \
decaf/lang/Number.h \
decaf/lang/Pointer.h \
decaf/lang/Readable.h \
decaf/lang/Runnable.h \
decaf/lang/Runtime.h \
decaf/lang/Short.h \
decaf/lang/String.h \
decaf/lang/StringBuffer.h \
decaf/lang/StringBuilder.h \
decaf/lang/System.h \
decaf/lang/Thread.h \
decaf/lang/ThreadGroup.h \
decaf/lang/ThreadLocal.h \
decaf/lang/Throwable.h \
decaf/lang/Types.h \
decaf/lang/exceptions/ArrayIndexOutOfBoundsException.h \
decaf/lang/exceptions/ClassCastException.h \
decaf/lang/exceptions/CloneNotSupportedException.h \
decaf/lang/exceptions/ExceptionDefines.h \
decaf/lang/exceptions/IllegalArgumentException.h \
decaf/lang/exceptions/IllegalMonitorStateException.h \
decaf/lang/exceptions/IllegalStateException.h \
decaf/lang/exceptions/IllegalThreadStateException.h \
decaf/lang/exceptions/IndexOutOfBoundsException.h \
decaf/lang/exceptions/InterruptedException.h \
decaf/lang/exceptions/InvalidStateException.h \
decaf/lang/exceptions/NegativeArraySizeException.h \
decaf/lang/exceptions/NullPointerException.h \
decaf/lang/exceptions/NumberFormatException.h \
decaf/lang/exceptions/OutOfMemoryError.h \
decaf/lang/exceptions/RuntimeException.h \
decaf/lang/exceptions/SecurityException.h \
decaf/lang/exceptions/StringIndexOutOfBoundsException.h \
decaf/lang/exceptions/UnsupportedOperationException.h \
decaf/net/BindException.h \
decaf/net/ConnectException.h \
decaf/net/ContentHandlerFactory.h \
decaf/net/DatagramPacket.h \
decaf/net/FileNameMap.h \
decaf/net/HttpRetryException.h \
decaf/net/HttpURLConnection.h \
decaf/net/Inet4Address.h \
decaf/net/Inet6Address.h \
decaf/net/InetAddress.h \
decaf/net/InetSocketAddress.h \
decaf/net/MalformedURLException.h \
decaf/net/NoRouteToHostException.h \
decaf/net/PortUnreachableException.h \
decaf/net/ProtocolException.h \
decaf/net/Proxy.h \
decaf/net/ServerSocket.h \
decaf/net/ServerSocketFactory.h \
decaf/net/Socket.h \
decaf/net/SocketAddress.h \
decaf/net/SocketError.h \
decaf/net/SocketException.h \
decaf/net/SocketFactory.h \
decaf/net/SocketImpl.h \
decaf/net/SocketImplFactory.h \
decaf/net/SocketOptions.h \
decaf/net/SocketTimeoutException.h \
decaf/net/URI.h \
decaf/net/URISyntaxException.h \
decaf/net/URL.h \
decaf/net/URLConnection.h \
decaf/net/URLDecoder.h \
decaf/net/URLEncoder.h \
decaf/net/URLStreamHandler.h \
decaf/net/URLStreamHandlerFactory.h \
decaf/net/UnknownHostException.h \
decaf/net/UnknownServiceException.h \
decaf/net/ssl/SSLContext.h \
decaf/net/ssl/SSLContextSpi.h \
decaf/net/ssl/SSLParameters.h \
decaf/net/ssl/SSLServerSocket.h \
decaf/net/ssl/SSLServerSocketFactory.h \
decaf/net/ssl/SSLSocket.h \
decaf/net/ssl/SSLSocketFactory.h \
decaf/nio/Buffer.h \
decaf/nio/BufferOverflowException.h \
decaf/nio/BufferUnderflowException.h \
decaf/nio/ByteBuffer.h \
decaf/nio/CharBuffer.h \
decaf/nio/DoubleBuffer.h \
decaf/nio/FloatBuffer.h \
decaf/nio/IntBuffer.h \
decaf/nio/InvalidMarkException.h \
decaf/nio/LongBuffer.h \
decaf/nio/ReadOnlyBufferException.h \
decaf/nio/ShortBuffer.h \
decaf/security/DigestException.h \
decaf/security/GeneralSecurityException.h \
decaf/security/InvalidKeyException.h \
decaf/security/Key.h \
decaf/security/KeyException.h \
decaf/security/KeyManagementException.h \
decaf/security/MessageDigest.h \
decaf/security/MessageDigestSpi.h \
decaf/security/NoSuchAlgorithmException.h \
decaf/security/NoSuchProviderException.h \
decaf/security/Principal.h \
decaf/security/Provider.h \
decaf/security/ProviderException.h \
decaf/security/ProviderService.h \
decaf/security/PublicKey.h \
decaf/security/SecureRandom.h \
decaf/security/SecureRandomSpi.h \
decaf/security/Security.h \
decaf/security/SecuritySpi.h \
decaf/security/SignatureException.h \
decaf/security/auth/x500/X500Principal.h \
decaf/security/cert/Certificate.h \
decaf/security/cert/CertificateEncodingException.h \
decaf/security/cert/CertificateException.h \
decaf/security/cert/CertificateExpiredException.h \
decaf/security/cert/CertificateNotYetValidException.h \
decaf/security/cert/CertificateParsingException.h \
decaf/security/cert/X509Certificate.h \
decaf/util/AbstractCollection.h \
decaf/util/AbstractList.h \
decaf/util/AbstractMap.h \
decaf/util/AbstractQueue.h \
decaf/util/AbstractSequentialList.h \
decaf/util/AbstractSet.h \
decaf/util/ArrayList.h \
decaf/util/Arrays.h \
decaf/util/BitSet.h \
decaf/util/Collection.h \
decaf/util/Collections.h \
decaf/util/Comparator.h \
decaf/util/ConcurrentModificationException.h \
decaf/util/Config.h \
decaf/util/Date.h \
decaf/util/Deque.h \
decaf/util/HashCode.h \
decaf/util/HashMap.h \
decaf/util/HashSet.h \
decaf/util/Iterator.h \
decaf/util/LRUCache.h \
decaf/util/LinkedHashMap.h \
decaf/util/LinkedHashSet.h \
decaf/util/LinkedList.h \
decaf/util/List.h \
decaf/util/ListIterator.h \
decaf/util/Map.h \
decaf/util/MapEntry.h \
decaf/util/NoSuchElementException.h \
decaf/util/PriorityQueue.h \
decaf/util/Properties.h \
decaf/util/Queue.h \
decaf/util/Random.h \
decaf/util/Set.h \
decaf/util/StlList.h \
decaf/util/StlMap.h \
decaf/util/StlQueue.h \
decaf/util/StlSet.h \
decaf/util/StringTokenizer.h \
decaf/util/Timer.h \
decaf/util/TimerTask.h \
decaf/util/UUID.h \
decaf/util/comparators/Equals.h \
decaf/util/comparators/Less.h \
decaf/util/concurrent/AbstractExecutorService.h \
decaf/util/concurrent/BlockingQueue.h \
decaf/util/concurrent/BrokenBarrierException.h \
decaf/util/concurrent/Callable.h \
decaf/util/concurrent/CancellationException.h \
decaf/util/concurrent/Concurrent.h \
decaf/util/concurrent/ConcurrentHashMap.h \
decaf/util/concurrent/ConcurrentMap.h \
decaf/util/concurrent/ConcurrentStlMap.h \
decaf/util/concurrent/CopyOnWriteArrayList.h \
decaf/util/concurrent/CopyOnWriteArraySet.h \
decaf/util/concurrent/CountDownLatch.h \
decaf/util/concurrent/Delayed.h \
decaf/util/concurrent/ExecutionException.h \
decaf/util/concurrent/Executor.h \
decaf/util/concurrent/ExecutorService.h \
decaf/util/concurrent/Executors.h \
decaf/util/concurrent/Future.h \
decaf/util/concurrent/FutureTask.h \
decaf/util/concurrent/LinkedBlockingQueue.h \
decaf/util/concurrent/Lock.h \
decaf/util/concurrent/Mutex.h \
decaf/util/concurrent/RejectedExecutionException.h \
decaf/util/concurrent/RejectedExecutionHandler.h \
decaf/util/concurrent/RunnableFuture.h \
decaf/util/concurrent/Semaphore.h \
decaf/util/concurrent/Synchronizable.h \
decaf/util/concurrent/SynchronousQueue.h \
decaf/util/concurrent/ThreadFactory.h \
decaf/util/concurrent/ThreadPoolExecutor.h \
decaf/util/concurrent/TimeUnit.h \
decaf/util/concurrent/TimeoutException.h \
decaf/util/concurrent/atomic/AtomicBoolean.h \
decaf/util/concurrent/atomic/AtomicInteger.h \
decaf/util/concurrent/atomic/AtomicRefCounter.h \
decaf/util/concurrent/atomic/AtomicReference.h \
decaf/util/concurrent/locks/AbstractOwnableSynchronizer.h \
decaf/util/concurrent/locks/AbstractQueuedSynchronizer.h \
decaf/util/concurrent/locks/Condition.h \
decaf/util/concurrent/locks/Lock.h \
decaf/util/concurrent/locks/LockSupport.h \
decaf/util/concurrent/locks/ReadWriteLock.h \
decaf/util/concurrent/locks/ReentrantLock.h \
decaf/util/concurrent/locks/ReentrantReadWriteLock.h \
decaf/util/logging/ConsoleHandler.h \
decaf/util/logging/ErrorManager.h \
decaf/util/logging/Filter.h \
decaf/util/logging/Formatter.h \
decaf/util/logging/Handler.h \
decaf/util/logging/Level.h \
decaf/util/logging/LogManager.h \
decaf/util/logging/LogRecord.h \
decaf/util/logging/LogWriter.h \
decaf/util/logging/Logger.h \
decaf/util/logging/LoggerCommon.h \
decaf/util/logging/LoggerDefines.h \
decaf/util/logging/LoggerHierarchy.h \
decaf/util/logging/MarkBlockLogger.h \
decaf/util/logging/PropertiesChangeListener.h \
decaf/util/logging/SimpleFormatter.h \
decaf/util/logging/SimpleLogger.h \
decaf/util/logging/StreamHandler.h \
decaf/util/logging/XMLFormatter.h \
decaf/util/zip/Adler32.h \
decaf/util/zip/CRC32.h \
decaf/util/zip/CheckedInputStream.h \
decaf/util/zip/CheckedOutputStream.h \
decaf/util/zip/Checksum.h \
decaf/util/zip/DataFormatException.h \
decaf/util/zip/Deflater.h \
decaf/util/zip/DeflaterOutputStream.h \
decaf/util/zip/Inflater.h \
decaf/util/zip/InflaterInputStream.h \
decaf/util/zip/ZipException.h
##
## Compiler / Linker Info
##
lib_LTLIBRARIES= libactivemq-cpp.la
libactivemq_cpp_la_SOURCES= $(h_sources) $(cc_sources)
libactivemq_cpp_la_CXXFLAGS= $(AMQ_CXXFLAGS)
libactivemq_cpp_la_CFLAGS= $(AMQ_CFLAGS)
libactivemq_cpp_la_LDFLAGS= -version-info $(ACTIVEMQ_LIBRARY_VERSION)
libactivemq_cpp_la_LIBADD= $(AMQ_LIBS)
##
## Packaging Info
##
library_includedir=$(includedir)/$(ACTIVEMQ_LIBRARY_NAME)-$(ACTIVEMQ_VERSION)
nobase_library_include_HEADERS = $(h_sources)