You are viewing a plain text version of this content. The canonical link for it is here.
Posted to scm@geronimo.apache.org by ge...@oio.de on 2004/07/20 10:52:47 UTC

[status] Windows 2000 - Build for project incubator-geronimo build.29 Build Fixed

Build successful. The build results are only sent in case of build failures.

Build at 		: 20.07.2004
OperatingSystem	: Windows 2000
Java Version 	: Sun JDK 1.4.2-b28, mixed mode
Maven Version 	: v. 1.0-rc3

Build participants:
-------------------
djencks
gdamour

Modifications:
--------------

FileName: Msg.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging
Revision: 1.3
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: New MsgHeader defining the version number of the topology to be used when sending/routing Msgs.

FileName: project.xml
FolderName: modules/timer
Revision: 1.1
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Geronimo support for transactional timer that executes in a thread pool.

FileName: MockNode.java
FolderName: sandbox/messaging/src/test/org/apache/geronimo/messaging
Revision: 1.5
Last Modified: 2004/07/17 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Change the way a topology is cascaded. The previous implementation was not dealing correctly with
cyclic topologies.

FileName: RemoteNodeManager.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/remotenode
Revision: 1.3
Last Modified: 2004/07/17 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Better exception handling.

FileName: maven.xml
FolderName: modules/assembly
Revision: 1.18
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: use tranql connector.  Deploy timers for use by ejb timers

FileName: MsgHeaderConstants.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging
Revision: 1.2
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: New MsgHeader defining the version number of the topology to be used when sending/routing Msgs.

FileName: ClusterHBReceiver.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/cluster
Revision: 1.2
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: o queue the operations (add/remove node) to be performed on a cluster in order to have accurate timestamps
associated to node heartbeats;
o prevent the underlying thread of ClockDaemon to fail in case of a reconfiguration problem (such as a node
failing right in the middle of a topology reconfiguration).

FileName: NodeImplTest.java
FolderName: sandbox/messaging/src/test/org/apache/geronimo/messaging
Revision: 1.6
Last Modified: 2004/07/17 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Change the way a topology is cascaded. The previous implementation was not dealing correctly with
cyclic topologies.

FileName: Node.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging
Revision: 1.5
Last Modified: 2004/07/17 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Change the way a topology is cascaded. The previous implementation was not dealing correctly with
cyclic topologies.

FileName: RAR_1_0ConfigBuilderTest.java
FolderName: modules/connector/src/test/org/apache/geronimo/connector/deployment
Revision: 1.10
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Partial fix for removing handles for a connection when is it destroyed.  Adapt to moved TransactionContext impl.

FileName: TransactionEnlistingInterceptorTest.java
FolderName: modules/connector/src/test/org/apache/geronimo/connector/outbound
Revision: 1.8
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Partial fix for removing handles for a connection when is it destroyed.  Adapt to moved TransactionContext impl.

FileName: NodeInfoEditorTest.java
FolderName: sandbox/messaging/src/test/org/apache/geronimo/messaging
Revision: 1.1
Last Modified: 2004/07/17 00:00:00
UserName: gdamour
EmailAddress: null
Comment: NodeInfo PropertyEditor.

FileName: NodeServerImpl.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/remotenode/network
Revision: 1.5
Last Modified: 2004/07/17 00:00:00
UserName: gdamour
EmailAddress: null
Comment: One does not need a BufferProtocol in the Protocol stack.This is required as we want the Join requests to
be synchronous.

FileName: NetworkTransportFactory.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/remotenode/network
Revision: 1.5
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Refactoring of the remote node layer. This new version defines only one connection per RemoteNode. A
RemoteNodeConnection supports now an asynchronous callback when the underlying connection is closed. It is
used to detect and remove a RemoteNode from its RemoteNodeManager when the connection fails.

FileName: RemoteNodeJoinerConnection.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/remotenode/network
Revision: 1.4
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Refactoring of the remote node layer. This new version defines only one connection per RemoteNode. A
RemoteNodeConnection supports now an asynchronous callback when the underlying connection is closed. It is
used to detect and remove a RemoteNode from its RemoteNodeManager when the connection fails.

FileName: UserTransactionImpl.java
FolderName: modules/transaction/src/java/org/apache/geronimo/transaction
Revision: 1.5
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Centralize use of TransactionContext in a TransactionContextManagerGBean

FileName: RemoteNodeJoinedConnection.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/remotenode/network
Revision: 1.2
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Refactoring of the remote node layer. This new version defines only one connection per RemoteNode. A
RemoteNodeConnection supports now an asynchronous callback when the underlying connection is closed. It is
used to detect and remove a RemoteNode from its RemoteNodeManager when the connection fails.

FileName: VMWorkerPersistence.java
FolderName: modules/timer/src/java/org/apache/geronimo/timer/vm
Revision: 1.1
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Geronimo support for transactional timer that executes in a thread pool.

FileName: JDBCWorkerPersistence.java
FolderName: modules/timer/src/java/org/apache/geronimo/timer/jdbc
Revision: 1.1
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Geronimo support for transactional timer that executes in a thread pool.

FileName: MsgHeader.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging
Revision: 1.2
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: New MsgHeader defining the version number of the topology to be used when sending/routing Msgs.

FileName: BeanTransactionContext.java
FolderName: modules/transaction/src/java/org/apache/geronimo/transaction/context
Revision: 1.1
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Centralize use of TransactionContext in a TransactionContextManagerGBean

FileName: NodeEndPointView.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging
Revision: 1.3
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: A primitive 2PC implementation of a topology reconfiguration.

FileName: ManagedConnectionInfo.java
FolderName: modules/connector/src/java/org/apache/geronimo/connector/outbound
Revision: 1.7
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Partial fix for removing handles for a connection when is it destroyed.  Adapt to moved TransactionContext impl.

FileName: UserTaskFactory.java
FolderName: modules/timer/src/java/org/apache/geronimo/timer
Revision: 1.1
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Geronimo support for transactional timer that executes in a thread pool.

FileName: DefaultComponentInterceptor.java
FolderName: modules/connector/src/test/org/apache/geronimo/connector/outbound/connectiontracking
Revision: 1.4
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Partial fix for removing handles for a connection when is it destroyed.  Adapt to moved TransactionContext impl.

FileName: MockConnectorConfigBuilder.java
FolderName: modules/j2ee/src/test/org/apache/geronimo/j2ee/deployment
Revision: 1.2
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Make non-ear j2ee modules deploy with external plans and adapt classes to use TransactionContextManager.  Also includes some modifications for ejb timer impl.

FileName: PersistenceException.java
FolderName: modules/timer/src/java/org/apache/geronimo/timer
Revision: 1.1
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Geronimo support for transactional timer that executes in a thread pool.

FileName: RingTopologyManager.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/cluster/topology
Revision: 1.3
Last Modified: 2004/07/17 00:00:00
UserName: gdamour
EmailAddress: null
Comment: RingTopologyManager does not need to be thread-safe.

FileName: NontransactionalExecutorTaskFactory.java
FolderName: modules/timer/src/java/org/apache/geronimo/timer
Revision: 1.1
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Geronimo support for transactional timer that executes in a thread pool.

FileName: InheritableTransactionContext.java
FolderName: modules/transaction/src/java/org/apache/geronimo/transaction/context
Revision: 1.1
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Centralize use of TransactionContext in a TransactionContextManagerGBean

FileName: TransactionContext.java
FolderName: modules/transaction/src/java/org/apache/geronimo/transaction/context
Revision: 1.1
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Centralize use of TransactionContext in a TransactionContextManagerGBean

FileName: j2ee-server-plan.xml
FolderName: modules/assembly/src/plan
Revision: 1.38
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: use tranql connector.  Deploy timers for use by ejb timers

FileName: VMStoreThreadPooledTransactionalTimer.java
FolderName: modules/timer/src/java/org/apache/geronimo/timer/vm
Revision: 1.1
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Geronimo support for transactional timer that executes in a thread pool.

FileName: EndPointProxyFactoryImpl.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/proxy
Revision: 1.3
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Provides a mean to intercept Msgs being sent by an EndPointProxy.

FileName: GBeanMBeanReference.java
FolderName: modules/kernel/src/java/org/apache/geronimo/gbean/jmx
Revision: 1.11
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Remove nulls from reference patterns before trying to match

FileName: RemoteNodeMonitor.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/remotenode
Revision: 1.4
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Refactoring of the remote node layer. This new version defines only one connection per RemoteNode. A
RemoteNodeConnection supports now an asynchronous callback when the underlying connection is closed. It is
used to detect and remove a RemoteNode from its RemoteNodeManager when the connection fails.

FileName: RemoteNodeManagerImplTest.java
FolderName: sandbox/messaging/src/test/org/apache/geronimo/messaging/remotenode
Revision: 1.5
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Refactoring of the remote node layer. This new version defines only one connection per RemoteNode. A
RemoteNodeConnection supports now an asynchronous callback when the underlying connection is closed. It is
used to detect and remove a RemoteNode from its RemoteNodeManager when the connection fails.

FileName: ThreadPool.java
FolderName: modules/core/src/java/org/apache/geronimo/pool
Revision: 1.6
Last Modified: 2004/07/18 00:00:00
UserName: djencks
EmailAddress: null
Comment: GBEAN_INFO should be public

FileName: project.xml
FolderName: modules/transaction
Revision: 1.20
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Centralize use of TransactionContext in a TransactionContextManagerGBean

FileName: SelectorManager.java
FolderName: modules/network/src/java/org/apache/geronimo/network
Revision: 1.16
Last Modified: 2004/07/19 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Fix the associated GBeanInfo.

FileName: NodeEndPointView.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging
Revision: 1.2
Last Modified: 2004/07/17 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Change the way a topology is cascaded. The previous implementation was not dealing correctly with
cyclic topologies.

FileName: ConnectionManagerStressTest.java
FolderName: modules/connector/src/test/org/apache/geronimo/connector/outbound
Revision: 1.5
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Partial fix for removing handles for a connection when is it destroyed.  Adapt to moved TransactionContext impl.

FileName: EARContextTest.java
FolderName: modules/j2ee/src/test/org/apache/geronimo/j2ee/deployment
Revision: 1.3
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Make non-ear j2ee modules deploy with external plans and adapt classes to use TransactionContextManager.  Also includes some modifications for ejb timer impl.

FileName: WebServiceContainer.java
FolderName: modules/axis/src/java/org/apache/geronimo/axis
Revision: 1.3
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Centralize use of TransactionContext in a TransactionContextManagerGBean

FileName: RingTopologyManagerTest.java
FolderName: sandbox/messaging/src/test/org/apache/geronimo/messaging/cluster/topology
Revision: 1.2
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Improve the JUnit tests of RingTopologyManager.

FileName: AbstractRemoteNode.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/remotenode
Revision: 1.1
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Refactoring of the remote node layer. This new version defines only one connection per RemoteNode. A
RemoteNodeConnection supports now an asynchronous callback when the underlying connection is closed. It is
used to detect and remove a RemoteNode from its RemoteNodeManager when the connection fails.

FileName: ClusterInfoEditorTest.java
FolderName: sandbox/messaging/src/test/org/apache/geronimo/messaging/cluster
Revision: 1.1
Last Modified: 2004/07/17 00:00:00
UserName: gdamour
EmailAddress: null
Comment: o Adds the ClusterInfo notion. It wraps some meta-data (multicast group + port) specific to a given Cluster.
o When a node is added or removed to a Cluster, an Exception is now raised if it is not possible to do so.

FileName: ConnectorModuleBuilder.java
FolderName: modules/connector/src/java/org/apache/geronimo/connector/deployment
Revision: 1.9
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Make non-ear j2ee modules deploy with external plans and adapt classes to use TransactionContextManager.  Also includes some modifications for ejb timer impl.

FileName: default-database-plan.xml
FolderName: modules/assembly/src/plan
Revision: 1.1
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: use tranql connector.  Deploy timers for use by ejb timers

FileName: ClusterHBTest.java
FolderName: sandbox/messaging/src/test/org/apache/geronimo/messaging/cluster
Revision: 1.1
Last Modified: 2004/07/17 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Adds two new services, namely ClusterHBReceiver and ClusterHBSender, which are used to detect and notify
the availability or failure of nodes:
Each node sends periodicaly heartbeats to a given multicast group. A leader in this cluster monitors these
heartbeats. When an heartbeat is received from a new node, it is added to the cluster. Conversely, when
more than a configurable number of heartbeats are missed for a given node, it is removed from the cluster.

FileName: NodeImplTest.java
FolderName: sandbox/messaging/src/test/org/apache/geronimo/messaging
Revision: 1.7
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: A primitive 2PC implementation of a topology reconfiguration.

FileName: project.xml
FolderName: modules/deployment
Revision: 1.21
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Make non-ear j2ee modules deploy with external plans and adapt classes to use TransactionContextManager.  Also includes some modifications for ejb timer impl.

FileName: DDBeanRootImpl.java
FolderName: modules/deployment/src/java/org/apache/geronimo/deployment/tools
Revision: 1.6
Last Modified: 2004/07/18 00:00:00
UserName: djencks
EmailAddress: null
Comment: change DDBean impl to use xmlbeans.  Allows jetty tests to pass offline

FileName: ClusterHBReceiver.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/cluster
Revision: 1.1
Last Modified: 2004/07/17 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Adds two new services, namely ClusterHBReceiver and ClusterHBSender, which are used to detect and notify
the availability or failure of nodes:
Each node sends periodicaly heartbeats to a given multicast group. A leader in this cluster monitors these
heartbeats. When an heartbeat is received from a new node, it is added to the cluster. Conversely, when
more than a configurable number of heartbeats are missed for a given node, it is removed from the cluster.

FileName: MockWARConfigBuilder.java
FolderName: modules/j2ee/src/test/org/apache/geronimo/j2ee/deployment
Revision: 1.2
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Make non-ear j2ee modules deploy with external plans and adapt classes to use TransactionContextManager.  Also includes some modifications for ejb timer impl.

FileName: BeanTransactionContext.java
FolderName: modules/transaction/src/java/org/apache/geronimo/transaction
Revision: 1.4
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Centralize use of TransactionContext in a TransactionContextManagerGBean

FileName: JDBCStoreThreadPooledNonTransactionalTimer.java
FolderName: modules/timer/src/java/org/apache/geronimo/timer/jdbc
Revision: 1.1
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Geronimo support for transactional timer that executes in a thread pool.

FileName: project.properties
FolderName: modules/timer
Revision: 1.1
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Geronimo support for transactional timer that executes in a thread pool.

FileName: EndPointUtil.java
FolderName: sandbox/messaging/src/test/org/apache/geronimo/messaging
Revision: 1.2
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: A primitive 2PC implementation of a topology reconfiguration.

FileName: ClusterInfoEditor.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/cluster
Revision: 1.1
Last Modified: 2004/07/17 00:00:00
UserName: gdamour
EmailAddress: null
Comment: o Adds the ClusterInfo notion. It wraps some meta-data (multicast group + port) specific to a given Cluster.
o When a node is added or removed to a Cluster, an Exception is now raised if it is not possible to do so.

FileName: ConnectionManagerTestUtils.java
FolderName: modules/connector/src/test/org/apache/geronimo/connector/outbound
Revision: 1.13
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Partial fix for removing handles for a connection when is it destroyed.  Adapt to moved TransactionContext impl.

FileName: TopologyManagerEditor.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/cluster/topology
Revision: 1.1
Last Modified: 2004/07/17 00:00:00
UserName: gdamour
EmailAddress: null
Comment: TopologyManager PropertyEditor. TopologyManager must be Serializable as it is a GBean persistent attribute.

FileName: WorkerPersistence.java
FolderName: modules/timer/src/java/org/apache/geronimo/timer
Revision: 1.1
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Geronimo support for transactional timer that executes in a thread pool.

FileName: RemoteNodeJoiner.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/remotenode/network
Revision: 1.4
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Refactoring of the remote node layer. This new version defines only one connection per RemoteNode. A
RemoteNodeConnection supports now an asynchronous callback when the underlying connection is closed. It is
used to detect and remove a RemoteNode from its RemoteNodeManager when the connection fails.

FileName: MockEndPointImpl.java
FolderName: sandbox/messaging/src/test/org/apache/geronimo/messaging
Revision: 1.4
Last Modified: 2004/07/17 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Change the way a topology is cascaded. The previous implementation was not dealing correctly with
cyclic topologies.

FileName: j2ee-deployer-plan.xml
FolderName: modules/assembly/src/plan
Revision: 1.22
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: use tranql connector.  Deploy timers for use by ejb timers

FileName: InheritableTransactionContext.java
FolderName: modules/transaction/src/java/org/apache/geronimo/transaction
Revision: 1.4
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Centralize use of TransactionContext in a TransactionContextManagerGBean

FileName: TransactionContext.java
FolderName: modules/transaction/src/java/org/apache/geronimo/transaction
Revision: 1.8
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Centralize use of TransactionContext in a TransactionContextManagerGBean

FileName: Playback.java
FolderName: modules/timer/src/java/org/apache/geronimo/timer
Revision: 1.1
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Geronimo support for transactional timer that executes in a thread pool.

FileName: template-clustered-plan.xml
FolderName: sandbox/messaging/src/plan
Revision: 1.1
Last Modified: 2004/07/17 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Adds a goal, namely patch, which can be used to patch the distribution folder with some clustered configurations
to simplify the debugging/testing of this proto.

FileName: template-leader-clustered-plan.xml
FolderName: sandbox/messaging/src/plan
Revision: 1.1
Last Modified: 2004/07/17 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Adds a goal, namely patch, which can be used to patch the distribution folder with some clustered configurations
to simplify the debugging/testing of this proto.

FileName: WorkInfo.java
FolderName: modules/timer/src/java/org/apache/geronimo/timer
Revision: 1.1
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Geronimo support for transactional timer that executes in a thread pool.

FileName: AbstractThreadPooledTimerTest.java
FolderName: modules/timer/src/test/org/apache/geronimo/timer
Revision: 1.1
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Geronimo support for transactional timer that executes in a thread pool.

FileName: NodeImpl.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging
Revision: 1.8
Last Modified: 2004/07/17 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Change the way a topology is cascaded. The previous implementation was not dealing correctly with
cyclic topologies.

FileName: NontransactionalExecutorTask.java
FolderName: modules/timer/src/java/org/apache/geronimo/timer
Revision: 1.1
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Geronimo support for transactional timer that executes in a thread pool.

FileName: ModuleBuilder.java
FolderName: modules/j2ee/src/java/org/apache/geronimo/j2ee/deployment
Revision: 1.2
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Make non-ear j2ee modules deploy with external plans and adapt classes to use TransactionContextManager.  Also includes some modifications for ejb timer impl.

FileName: RingTopologyManager.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/cluster/topology
Revision: 1.4
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Makes the Ring topology more clever and faster: it always choose the shortest path between two nodes
and the path are pre-computed upon instantiation.

FileName: template-system-plan.xml
FolderName: sandbox/messaging/src/plan
Revision: 1.1
Last Modified: 2004/07/17 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Adds a goal, namely patch, which can be used to patch the distribution folder with some clustered configurations
to simplify the debugging/testing of this proto.

FileName: TransactionCachingInterceptorTest.java
FolderName: modules/connector/src/test/org/apache/geronimo/connector/outbound
Revision: 1.9
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Partial fix for removing handles for a connection when is it destroyed.  Adapt to moved TransactionContext impl.

FileName: JDBCStoreThreadPooledTransactionalTimer.java
FolderName: modules/timer/src/java/org/apache/geronimo/timer/jdbc
Revision: 1.1
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Geronimo support for transactional timer that executes in a thread pool.

FileName: AbstractRemoteNode.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/remotenode/network
Revision: 1.2
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Refactoring of the remote node layer. This class is no more used.

FileName: maven.xml
FolderName: sandbox/messaging
Revision: 1.1
Last Modified: 2004/07/17 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Adds a goal, namely patch, which can be used to patch the distribution folder with some clustered configurations
to simplify the debugging/testing of this proto.

FileName: RemoteNodeManagerImpl.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/remotenode
Revision: 1.7
Last Modified: 2004/07/17 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Better exception handling.

FileName: VMStoreThreadPooledNonTransactionalTimer.java
FolderName: modules/timer/src/java/org/apache/geronimo/timer/vm
Revision: 1.1
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Geronimo support for transactional timer that executes in a thread pool.

FileName: LogicalCompression.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/remotenode
Revision: 1.4
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: A primitive 2PC implementation of a topology reconfiguration.

FileName: RemoteNodeJoinerConnection.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/remotenode/network
Revision: 1.3
Last Modified: 2004/07/17 00:00:00
UserName: gdamour
EmailAddress: null
Comment: One does not need a BufferProtocol in the Protocol stack.This is required as we want the Join requests to
be synchronous.

FileName: NodeInfoEditor.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging
Revision: 1.1
Last Modified: 2004/07/17 00:00:00
UserName: gdamour
EmailAddress: null
Comment: NodeInfo PropertyEditor.

FileName: DConfigBeanSupport.java
FolderName: modules/deployment/src/java/org/apache/geronimo/deployment/plugin
Revision: 1.13
Last Modified: 2004/07/18 00:00:00
UserName: djencks
EmailAddress: null
Comment: change DDBean impl to use xmlbeans.  Allows jetty tests to pass offline

FileName: ContainerTransactionContext.java
FolderName: modules/transaction/src/java/org/apache/geronimo/transaction
Revision: 1.4
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Centralize use of TransactionContext in a TransactionContextManagerGBean

FileName: TransactionManagerProxy.java
FolderName: modules/transaction/src/java/org/apache/geronimo/transaction
Revision: 1.12
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Centralize use of TransactionContext in a TransactionContextManagerGBean

FileName: NodeServerImpl.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/remotenode/network
Revision: 1.6
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Refactoring of the remote node layer. This new version defines only one connection per RemoteNode. A
RemoteNodeConnection supports now an asynchronous callback when the underlying connection is closed. It is
used to detect and remove a RemoteNode from its RemoteNodeManager when the connection fails.

FileName: RemoteNodeManagerImpl.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/remotenode
Revision: 1.8
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Refactoring of the remote node layer. This new version defines only one connection per RemoteNode. A
RemoteNodeConnection supports now an asynchronous callback when the underlying connection is closed. It is
used to detect and remove a RemoteNode from its RemoteNodeManager when the connection fails.

FileName: EndPointProxy.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/proxy
Revision: 1.3
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Provides a mean to intercept Msgs being sent by an EndPointProxy.

FileName: JettyWebAppJACCContext.java
FolderName: modules/jetty/src/java/org/apache/geronimo/jetty
Revision: 1.4
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Make non-ear j2ee modules deploy with external plans and adapt classes to use TransactionContextManager.  Also includes some modifications for ejb timer impl.

FileName: project.xml
FolderName: modules/axis
Revision: 1.2
Last Modified: 2004/07/18 00:00:00
UserName: djencks
EmailAddress: null
Comment: update concurrent version

FileName: MsgTransformer.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/interceptors
Revision: 1.1
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Provides a mean to intercept Msgs being sent by an EndPointProxy.

FileName: TopologyManager.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/cluster/topology
Revision: 1.2
Last Modified: 2004/07/17 00:00:00
UserName: gdamour
EmailAddress: null
Comment: TopologyManager PropertyEditor. TopologyManager must be Serializable as it is a GBean persistent attribute.

FileName: EARContext.java
FolderName: modules/j2ee/src/java/org/apache/geronimo/j2ee/deployment
Revision: 1.6
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Make non-ear j2ee modules deploy with external plans and adapt classes to use TransactionContextManager.  Also includes some modifications for ejb timer impl.

FileName: ExecutorTaskFactory.java
FolderName: modules/timer/src/java/org/apache/geronimo/timer
Revision: 1.1
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Geronimo support for transactional timer that executes in a thread pool.

FileName: NodeImpl.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging
Revision: 1.9
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: A primitive 2PC implementation of a topology reconfiguration.

FileName: CallbackSocketProtocol.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/remotenode/network
Revision: 1.1
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Refactoring of the remote node layer. This new version defines only one connection per RemoteNode. A
RemoteNodeConnection supports now an asynchronous callback when the underlying connection is closed. It is
used to detect and remove a RemoteNode from its RemoteNodeManager when the connection fails.

FileName: GBeanBaseEndPoint.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging
Revision: 1.2
Last Modified: 2004/07/17 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Fix the GBean attribute/reference names.

FileName: RemoteNode.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/remotenode
Revision: 1.3
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Refactoring of the remote node layer. This new version defines only one connection per RemoteNode. A
RemoteNodeConnection supports now an asynchronous callback when the underlying connection is closed. It is
used to detect and remove a RemoteNode from its RemoteNodeManager when the connection fails.

FileName: JettyModuleBuilder.java
FolderName: modules/jetty/src/java/org/apache/geronimo/jetty/deployment
Revision: 1.15
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Make non-ear j2ee modules deploy with external plans and adapt classes to use TransactionContextManager.  Also includes some modifications for ejb timer impl.

FileName: DDBeanImpl.java
FolderName: modules/deployment/src/java/org/apache/geronimo/deployment/tools
Revision: 1.6
Last Modified: 2004/07/18 00:00:00
UserName: djencks
EmailAddress: null
Comment: change DDBean impl to use xmlbeans.  Allows jetty tests to pass offline

FileName: ConnectionManagerTest.java
FolderName: modules/connector/src/test/org/apache/geronimo/connector/outbound
Revision: 1.12
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Partial fix for removing handles for a connection when is it destroyed.  Adapt to moved TransactionContext impl.

FileName: TopologyManagerEditorTest.java
FolderName: sandbox/messaging/src/test/org/apache/geronimo/messaging/cluster/topology
Revision: 1.1
Last Modified: 2004/07/17 00:00:00
UserName: gdamour
EmailAddress: null
Comment: TopologyManager PropertyEditor. TopologyManager must be Serializable as it is a GBean persistent attribute.

FileName: ExecutorFeedingTimerTask.java
FolderName: modules/timer/src/java/org/apache/geronimo/timer
Revision: 1.1
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Geronimo support for transactional timer that executes in a thread pool.

FileName: project.xml
FolderName: sandbox/messaging
Revision: 1.6
Last Modified: 2004/07/17 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Adds a goal, namely patch, which can be used to patch the distribution folder with some clustered configurations
to simplify the debugging/testing of this proto.

FileName: GeronimoConnectionEventListener.java
FolderName: modules/connector/src/java/org/apache/geronimo/connector/outbound
Revision: 1.5
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Partial fix for removing handles for a connection when is it destroyed.  Adapt to moved TransactionContext impl.

FileName: HOWLLog.java
FolderName: modules/transaction/src/java/org/apache/geronimo/transaction/log
Revision: 1.5
Last Modified: 2004/07/18 00:00:00
UserName: djencks
EmailAddress: null
Comment: more logging to help users see recovery is progressing

FileName: ClusterImpl.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/cluster
Revision: 1.3
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: A primitive 2PC implementation of a topology reconfiguration.

FileName: MockEJBConfigBuilder.java
FolderName: modules/j2ee/src/test/org/apache/geronimo/j2ee/deployment
Revision: 1.2
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Make non-ear j2ee modules deploy with external plans and adapt classes to use TransactionContextManager.  Also includes some modifications for ejb timer impl.

FileName: ContainerTransactionContext.java
FolderName: modules/transaction/src/java/org/apache/geronimo/transaction/context
Revision: 1.1
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Centralize use of TransactionContext in a TransactionContextManagerGBean

FileName: NodeServer.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/remotenode
Revision: 1.2
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Refactoring of the remote node layer. This new version defines only one connection per RemoteNode. A
RemoteNodeConnection supports now an asynchronous callback when the underlying connection is closed. It is
used to detect and remove a RemoteNode from its RemoteNodeManager when the connection fails.

FileName: ReplicationMemberImpl.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/replication
Revision: 1.5
Last Modified: 2004/07/17 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Fix the GBean attribute/reference names.

FileName: RemoteNodeJoined.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/remotenode/network
Revision: 1.3
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Refactoring of the remote node layer. This new version defines only one connection per RemoteNode. A
RemoteNodeConnection supports now an asynchronous callback when the underlying connection is closed. It is
used to detect and remove a RemoteNode from its RemoteNodeManager when the connection fails.

FileName: RemoteNodeManager.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/remotenode
Revision: 1.4
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Refactoring of the remote node layer. This new version defines only one connection per RemoteNode. A
RemoteNodeConnection supports now an asynchronous callback when the underlying connection is closed. It is
used to detect and remove a RemoteNode from its RemoteNodeManager when the connection fails.

FileName: PersistentTimer.java
FolderName: modules/timer/src/java/org/apache/geronimo/timer
Revision: 1.1
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Geronimo support for transactional timer that executes in a thread pool.

FileName: MockRemoteNode.java
FolderName: sandbox/messaging/src/test/org/apache/geronimo/messaging/remotenode
Revision: 1.4
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Refactoring of the remote node layer. This new version defines only one connection per RemoteNode. A
RemoteNodeConnection supports now an asynchronous callback when the underlying connection is closed. It is
used to detect and remove a RemoteNode from its RemoteNodeManager when the connection fails.

FileName: EARConfigBuilder.java
FolderName: modules/j2ee/src/java/org/apache/geronimo/j2ee/deployment
Revision: 1.13
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Make non-ear j2ee modules deploy with external plans and adapt classes to use TransactionContextManager.  Also includes some modifications for ejb timer impl.

FileName: ConnectionTrackingCoordinator.java
FolderName: modules/connector/src/java/org/apache/geronimo/connector/outbound/connectiontracking
Revision: 1.12
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Partial fix for removing handles for a connection when is it destroyed.  Adapt to moved TransactionContext impl.

FileName: TransactionalExecutorTask.java
FolderName: modules/timer/src/java/org/apache/geronimo/timer
Revision: 1.1
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Geronimo support for transactional timer that executes in a thread pool.

FileName: RAR_1_5ConfigBuilderTest.java
FolderName: modules/connector/src/test/org/apache/geronimo/connector/deployment
Revision: 1.15
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Partial fix for removing handles for a connection when is it destroyed.  Adapt to moved TransactionContext impl.

FileName: TransactionContextManager.java
FolderName: modules/transaction/src/java/org/apache/geronimo/transaction/context
Revision: 1.1
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Centralize use of TransactionContext in a TransactionContextManagerGBean

FileName: NodeTopology.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging
Revision: 1.5
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: A primitive 2PC implementation of a topology reconfiguration.

FileName: MessagingTransportFactory.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/remotenode
Revision: 1.3
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Refactoring of the remote node layer. This new version defines only one connection per RemoteNode. A
RemoteNodeConnection supports now an asynchronous callback when the underlying connection is closed. It is
used to detect and remove a RemoteNode from its RemoteNodeManager when the connection fails.

FileName: project.xml
FolderName: modules/assembly
Revision: 1.33
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: use tranql connector.  Deploy timers for use by ejb timers

FileName: AbstractRemoteNodeConnection.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/remotenode/network
Revision: 1.2
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Refactoring of the remote node layer. This new version defines only one connection per RemoteNode. A
RemoteNodeConnection supports now an asynchronous callback when the underlying connection is closed. It is
used to detect and remove a RemoteNode from its RemoteNodeManager when the connection fails.

FileName: TransactionalExecutorTaskFactory.java
FolderName: modules/timer/src/java/org/apache/geronimo/timer
Revision: 1.1
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Geronimo support for transactional timer that executes in a thread pool.

FileName: ConnectionTrackingCoordinatorTest.java
FolderName: modules/connector/src/test/org/apache/geronimo/connector/outbound/connectiontracking
Revision: 1.9
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Partial fix for removing handles for a connection when is it destroyed.  Adapt to moved TransactionContext impl.

FileName: RemoteNodeMonitor.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/remotenode
Revision: 1.3
Last Modified: 2004/07/17 00:00:00
UserName: gdamour
EmailAddress: null
Comment: RemoteNodeMonitor was not dropping old neighbours as the timestamp test was wrong.

FileName: ClusterHBSender.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/cluster
Revision: 1.1
Last Modified: 2004/07/17 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Adds two new services, namely ClusterHBReceiver and ClusterHBSender, which are used to detect and notify
the availability or failure of nodes:
Each node sends periodicaly heartbeats to a given multicast group. A leader in this cluster monitors these
heartbeats. When an heartbeat is received from a new node, it is added to the cluster. Conversely, when
more than a configurable number of heartbeats are missed for a given node, it is removed from the cluster.

FileName: ClusterInfo.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/cluster
Revision: 1.1
Last Modified: 2004/07/17 00:00:00
UserName: gdamour
EmailAddress: null
Comment: o Adds the ClusterInfo notion. It wraps some meta-data (multicast group + port) specific to a given Cluster.
o When a node is added or removed to a Cluster, an Exception is now raised if it is not possible to do so.

FileName: MockMessagingTransportFactory.java
FolderName: sandbox/messaging/src/test/org/apache/geronimo/messaging/remotenode
Revision: 1.3
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Refactoring of the remote node layer. This new version defines only one connection per RemoteNode. A
RemoteNodeConnection supports now an asynchronous callback when the underlying connection is closed. It is
used to detect and remove a RemoteNode from its RemoteNodeManager when the connection fails.

FileName: ClusterEvent.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/cluster
Revision: 1.2
Last Modified: 2004/07/17 00:00:00
UserName: gdamour
EmailAddress: null
Comment: A member can either be added or removed. So it was not possible to create a ClusterEvent due to this
wrong argument check.

FileName: EndPointCallback.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/proxy
Revision: 1.3
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Provides a mean to intercept Msgs being sent by an EndPointProxy.

FileName: ClusterImpl.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/cluster
Revision: 1.2
Last Modified: 2004/07/17 00:00:00
UserName: gdamour
EmailAddress: null
Comment: o Adds the ClusterInfo notion. It wraps some meta-data (multicast group + port) specific to a given Cluster.
o When a node is added or removed to a Cluster, an Exception is now raised if it is not possible to do so.

FileName: TransactionCachingInterceptor.java
FolderName: modules/connector/src/java/org/apache/geronimo/connector/outbound
Revision: 1.8
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Partial fix for removing handles for a connection when is it destroyed.  Adapt to moved TransactionContext impl.

FileName: TransactionEnlistingInterceptor.java
FolderName: modules/connector/src/java/org/apache/geronimo/connector/outbound
Revision: 1.6
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Partial fix for removing handles for a connection when is it destroyed.  Adapt to moved TransactionContext impl.

FileName: MockNodeServer.java
FolderName: sandbox/messaging/src/test/org/apache/geronimo/messaging/remotenode
Revision: 1.2
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Refactoring of the remote node layer. This new version defines only one connection per RemoteNode. A
RemoteNodeConnection supports now an asynchronous callback when the underlying connection is closed. It is
used to detect and remove a RemoteNode from its RemoteNodeManager when the connection fails.

FileName: EARConfigBuilderTest.java
FolderName: modules/j2ee/src/test/org/apache/geronimo/j2ee/deployment
Revision: 1.4
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Make non-ear j2ee modules deploy with external plans and adapt classes to use TransactionContextManager.  Also includes some modifications for ejb timer impl.

FileName: JettyWebAppContext.java
FolderName: modules/jetty/src/java/org/apache/geronimo/jetty
Revision: 1.3
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Make non-ear j2ee modules deploy with external plans and adapt classes to use TransactionContextManager.  Also includes some modifications for ejb timer impl.

FileName: NontransactionalThreadPooledTimerTest.java
FolderName: modules/timer/src/test/org/apache/geronimo/timer
Revision: 1.1
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Geronimo support for transactional timer that executes in a thread pool.

FileName: UnspecifiedTransactionContext.java
FolderName: modules/transaction/src/java/org/apache/geronimo/transaction/context
Revision: 1.1
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Centralize use of TransactionContext in a TransactionContextManagerGBean

FileName: ExecutorTask.java
FolderName: modules/timer/src/java/org/apache/geronimo/timer
Revision: 1.1
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Geronimo support for transactional timer that executes in a thread pool.

FileName: ApplicationTest.java
FolderName: modules/jetty/src/test/org/apache/geronimo/jetty
Revision: 1.15
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Make non-ear j2ee modules deploy with external plans and adapt classes to use TransactionContextManager.  Also includes some modifications for ejb timer impl.

FileName: UnspecifiedTransactionContext.java
FolderName: modules/transaction/src/java/org/apache/geronimo/transaction
Revision: 1.5
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Centralize use of TransactionContext in a TransactionContextManagerGBean

FileName: Cluster.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/cluster
Revision: 1.2
Last Modified: 2004/07/17 00:00:00
UserName: gdamour
EmailAddress: null
Comment: o Adds the ClusterInfo notion. It wraps some meta-data (multicast group + port) specific to a given Cluster.
o When a node is added or removed to a Cluster, an Exception is now raised if it is not possible to do so.

FileName: TransactionalThreadPooledTimerTest.java
FolderName: modules/timer/src/test/org/apache/geronimo/timer
Revision: 1.1
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Geronimo support for transactional timer that executes in a thread pool.

FileName: ThreadPooledTimer.java
FolderName: modules/timer/src/java/org/apache/geronimo/timer
Revision: 1.1
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Geronimo support for transactional timer that executes in a thread pool.

FileName: RemoteNodeConnection.java
FolderName: sandbox/messaging/src/java/org/apache/geronimo/messaging/remotenode
Revision: 1.2
Last Modified: 2004/07/20 00:00:00
UserName: gdamour
EmailAddress: null
Comment: Refactoring of the remote node layer. This new version defines only one connection per RemoteNode. A
RemoteNodeConnection supports now an asynchronous callback when the underlying connection is closed. It is
used to detect and remove a RemoteNode from its RemoteNodeManager when the connection fails.

FileName: JDBCWorkerPersistenceTest.java
FolderName: modules/timer/src/test/org/apache/geronimo/timer/jdbc
Revision: 1.1
Last Modified: 2004/07/19 00:00:00
UserName: djencks
EmailAddress: null
Comment: Geronimo support for transactional timer that executes in a thread pool.



---
In case of questions please contact geronimo-builds@oio.de
http://www.oio.de