You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@labs.apache.org by ps...@apache.org on 2007/08/24 08:15:26 UTC

svn commit: r569266 - in /labs/pinpoint/trunk: pinpoint-cli/src/main/java/org/apache/logging/pinpoint/ pinpoint-core/src/main/java/org/apache/logging/pinpoint/converter/ pinpoint-core/src/main/java/org/apache/logging/pinpoint/store/ pinpoint-core/src/m...

Author: psmith
Date: Thu Aug 23 23:15:25 2007
New Revision: 569266

URL: http://svn.apache.org/viewvc?rev=569266&view=rev
Log:
Tweaked the CLI options so that other modules can easily add standard CLI options without needing ALL the standard ones.

Changed the way the ignoredProperties is configured, now using a PropertyPlaceholderConfigurer with a set of known defaults.
You can set customized defaults with a 'pinpoint.properties' placed in your Pinpoint home directory.

This PropertyPlaceholderConfigurer is used to configure some other standard defaults as well.

Added a jmx.xml config that enables the configuring of the underlying JMX subsystem to be done by default without the need to pass
ugly System properties.

The Logger name when indexed is now also tokenized so that for a given logger "com.foo.bar.Eeek', you can search for it just by
using term 'Eeek' without needing to do either prefix or suffix searching.  You can still search for things like 'com.foo*' etc.

Rewrote the NIO serialization and deserialization.  After discussing things with an NIO expert (hell, my cat's more experienced 
in this area than I) decided to go with a far less complicated approach.  Apparantly constant MMap'ing not such a good idea here.
This rewrite appears (touch wood) to have fixed this odd corrupted stream problem.  Of course 2 seconds after I commit this
it'll probably come back.



Added:
    labs/pinpoint/trunk/pinpoint-service/src/main/resources/org/apache/logging/pinpoint/service/properties.xml
Modified:
    labs/pinpoint/trunk/pinpoint-cli/src/main/java/org/apache/logging/pinpoint/Shell.java
    labs/pinpoint/trunk/pinpoint-core/src/main/java/org/apache/logging/pinpoint/converter/EventWriter.java
    labs/pinpoint/trunk/pinpoint-core/src/main/java/org/apache/logging/pinpoint/converter/PinpointEventWriterHandler.java
    labs/pinpoint/trunk/pinpoint-core/src/main/java/org/apache/logging/pinpoint/store/SimpleEventStore.java
    labs/pinpoint/trunk/pinpoint-core/src/main/java/org/apache/logging/pinpoint/utils/PinpointUtils.java
    labs/pinpoint/trunk/pinpoint-service/src/main/java/org/apache/logging/pinpoint/service/Service.java
    labs/pinpoint/trunk/pinpoint-service/src/main/resources/org/apache/logging/pinpoint/service/jmx.xml
    labs/pinpoint/trunk/pinpoint-service/src/main/resources/org/apache/logging/pinpoint/service/pinpoint-context.xml

Modified: labs/pinpoint/trunk/pinpoint-cli/src/main/java/org/apache/logging/pinpoint/Shell.java
URL: http://svn.apache.org/viewvc/labs/pinpoint/trunk/pinpoint-cli/src/main/java/org/apache/logging/pinpoint/Shell.java?rev=569266&r1=569265&r2=569266&view=diff
==============================================================================
--- labs/pinpoint/trunk/pinpoint-cli/src/main/java/org/apache/logging/pinpoint/Shell.java (original)
+++ labs/pinpoint/trunk/pinpoint-cli/src/main/java/org/apache/logging/pinpoint/Shell.java Thu Aug 23 23:15:25 2007
@@ -274,7 +274,7 @@
         List<LoggingEvent> pageEvents = new ArrayList<LoggingEvent>(currentResults.getPageSize());
         List<String> pageResults = currentResults.getPageResults();
         for (String eventLocation : pageResults) {
-            pageEvents.add(eventStore.restore(eventLocation));
+            pageEvents.add(eventLocation == null ? null : eventStore.restore(eventLocation));
         }
         displayEvents(pageEvents);
 
@@ -297,7 +297,7 @@
         for (LoggingEvent loggingEvent : iterable) {
             String eventString = loggingEvent != null
                     ? layout.format(loggingEvent)
-                    : "<Invalid/Corrupt LoggingEvent encountered here -- sorry, still haven't worked out why!>";
+                    : "<Invalid/Corrupt LoggingEvent encountered here -- sorry, still haven't worked out why!>\n";
             System.out.print(counter + ">" + eventString);
             counter++;
         }

Modified: labs/pinpoint/trunk/pinpoint-core/src/main/java/org/apache/logging/pinpoint/converter/EventWriter.java
URL: http://svn.apache.org/viewvc/labs/pinpoint/trunk/pinpoint-core/src/main/java/org/apache/logging/pinpoint/converter/EventWriter.java?rev=569266&r1=569265&r2=569266&view=diff
==============================================================================
--- labs/pinpoint/trunk/pinpoint-core/src/main/java/org/apache/logging/pinpoint/converter/EventWriter.java (original)
+++ labs/pinpoint/trunk/pinpoint-core/src/main/java/org/apache/logging/pinpoint/converter/EventWriter.java Thu Aug 23 23:15:25 2007
@@ -121,8 +121,7 @@
                 Store.NO, Index.TOKENIZED));
         doc.add(new Field("thread", StringUtils.defaultString(event.getThreadName().toLowerCase()),
                 Store.NO, Index.UN_TOKENIZED));
-        doc.add(new Field("logger", StringUtils.defaultString(event.getLoggerName()), Store.NO,
-                Index.TOKENIZED));
+        doc.add(new Field("logger", createLoggerTokenStream(event), Store.NO, Index.TOKENIZED));
         doc.add(new Field("ndc", StringUtils.defaultString(event.getNDC()), Store.NO,
                 Index.TOKENIZED));
 
@@ -150,6 +149,25 @@
 
         doc.add(OffsetAndLength.encodeAsField(loc));
         return doc;
+    }
+
+    /**
+     * Creates a tokenizable stream(just a string) space separated that contains the fFQN logger
+     * name plus each segment of the logger name broken by the dotted name hierarchy. So, for logger
+     * 'org.foo.bar', the string return is "org.foo.bar org foo bar". This allows users to find
+     * matching loggers by both prefix searching and just the class name itself (which mostly
+     * uniquely identifies the class and is far easier to find without having to know the complete
+     * class+package name).
+     * 
+     * @param event
+     * @return
+     */
+    private String createLoggerTokenStream(LoggingEvent event) {
+        String loggerName = StringUtils.defaultString(event.getLoggerName());
+        StringBuilder buf = new StringBuilder(loggerName);
+        buf.append(StringUtils.join(StringUtils.split(loggerName, "."), " "));
+        return buf.toString();
+
     }
 
     private void addTimestamp(LoggingEvent event, Document doc) {

Modified: labs/pinpoint/trunk/pinpoint-core/src/main/java/org/apache/logging/pinpoint/converter/PinpointEventWriterHandler.java
URL: http://svn.apache.org/viewvc/labs/pinpoint/trunk/pinpoint-core/src/main/java/org/apache/logging/pinpoint/converter/PinpointEventWriterHandler.java?rev=569266&r1=569265&r2=569266&view=diff
==============================================================================
--- labs/pinpoint/trunk/pinpoint-core/src/main/java/org/apache/logging/pinpoint/converter/PinpointEventWriterHandler.java (original)
+++ labs/pinpoint/trunk/pinpoint-core/src/main/java/org/apache/logging/pinpoint/converter/PinpointEventWriterHandler.java Thu Aug 23 23:15:25 2007
@@ -9,8 +9,10 @@
 package org.apache.logging.pinpoint.converter;
 
 import java.io.IOException;
+import java.util.Arrays;
 import java.util.Collections;
 import java.util.HashMap;
+import java.util.HashSet;
 import java.util.Map;
 import java.util.Set;
 
@@ -46,7 +48,8 @@
     private boolean useExceptionallySlowIndexing = false;
 
     // private IgnornedKeyFactory ignoredMDCKeys
-    private Set<String> ignoredProperties = Collections.EMPTY_SET;
+    private String[] ignoredProperties = new String[] {};
+    private Set<String> ignoredPropertiesSet = Collections.emptySet();
 
     public PinpointEventWriterHandler(PinpointContextSelector selector,
             IndexWriterFactory indexWriterFactory, AnalyzerFactory analyzerFactory, Counter counter) {
@@ -84,7 +87,7 @@
 
                 writer = new EventWriter(store, ctx.getIndexDirectory(), indexWriterFactor,
                         analyserFactory);
-                writer.setIgnoredProperties(getIgnoredProperties());
+                writer.setIgnoredProperties(this.ignoredPropertiesSet);
                 contextMap.put(ctx, writer);
             }
             writer.writeEvent(event);
@@ -119,12 +122,16 @@
         this.useExceptionallySlowIndexing = useExceptionallySlowIndexing;
     }
 
-    public final Set<String> getIgnoredProperties() {
+    @ManagedAttribute(description = "Set of LoggingEvent MDC/Properties keys that are to be ignored for indexing")
+    public final String[] getIgnoredProperties() {
         return ignoredProperties;
     }
 
-    public final void setIgnoredProperties(Set<String> ignoredProperties) {
+    public final void setIgnoredProperties(String[] ignoredProperties) {
         this.ignoredProperties = ignoredProperties;
+        this.ignoredPropertiesSet = Collections.unmodifiableSet(new HashSet<String>(Arrays
+                .asList(ignoredProperties)));
+        ;
     }
 
 }

Modified: labs/pinpoint/trunk/pinpoint-core/src/main/java/org/apache/logging/pinpoint/store/SimpleEventStore.java
URL: http://svn.apache.org/viewvc/labs/pinpoint/trunk/pinpoint-core/src/main/java/org/apache/logging/pinpoint/store/SimpleEventStore.java?rev=569266&r1=569265&r2=569266&view=diff
==============================================================================
--- labs/pinpoint/trunk/pinpoint-core/src/main/java/org/apache/logging/pinpoint/store/SimpleEventStore.java (original)
+++ labs/pinpoint/trunk/pinpoint-core/src/main/java/org/apache/logging/pinpoint/store/SimpleEventStore.java Thu Aug 23 23:15:25 2007
@@ -17,9 +17,7 @@
 import java.io.ObjectOutputStream;
 import java.io.RandomAccessFile;
 import java.nio.ByteBuffer;
-import java.nio.MappedByteBuffer;
 import java.nio.channels.FileChannel;
-import java.nio.channels.FileChannel.MapMode;
 
 import org.apache.log4j.Logger;
 import org.apache.log4j.spi.LoggingEvent;
@@ -34,8 +32,7 @@
  */
 public class SimpleEventStore implements EventStore {
 
-    private static final Logger LOG = PinpointUtils
-            .getLogger(SimpleEventStore.class);
+    private static final Logger LOG = PinpointUtils.getLogger(SimpleEventStore.class);
 
     private final File serializationFie;
     private FileChannel channel;
@@ -48,12 +45,11 @@
         this.serializationFie = serializationFile;
         try {
             // TODO confirm file open mode
-            RandomAccessFile raf = new RandomAccessFile(serializationFile, "rw");
+            RandomAccessFile raf = new RandomAccessFile(serializationFile, "rwd");
             channel = raf.getChannel();
         } catch (FileNotFoundException e) {
-            throw new RuntimeException(
-                    "Failed to create Output channel for file '" +
-                            serializationFile.getAbsolutePath() + "'", e);
+            throw new RuntimeException("Failed to create Output channel for file '"
+                    + serializationFile.getAbsolutePath() + "'", e);
         }
 
     }
@@ -62,36 +58,34 @@
         channel.close();
     }
 
-    public LoggingEvent restore(String eventLocationKey) {
-        OffsetAndLength oal = OffsetAndLength
-                .decodeFromString(eventLocationKey);
+    public synchronized LoggingEvent restore(String eventLocationKey) {
+        OffsetAndLength oal = OffsetAndLength.decodeFromString(eventLocationKey);
 
-        // TODO totally inefficient...
+        // TODO really not sure how efficient this is.
         try {
 
-            MappedByteBuffer byteBuffer = channel.map(MapMode.READ_ONLY,
-                    oal.offset, oal.length);
-            byte[] byteArray = new byte[(int) oal.length];
-            byteBuffer.get(byteArray);
-            LoggingEvent event = (LoggingEvent) new ObjectInputStream(
-                    new ByteArrayInputStream(byteArray)).readObject();
+            channel.position(oal.offset);
+            ByteBuffer buffer = ByteBuffer.allocate((int) oal.length);
+            channel.read(buffer);
+            LoggingEvent event = (LoggingEvent) new ObjectInputStream(new ByteArrayInputStream(
+                    buffer.array())).readObject();
 
             if (LOG.isDebugEnabled()) {
-                LOG.debug("Deserialized event at (offset:" + oal.offset +
-                        ", length:" + oal.length + "), event=" + event);
+                LOG.debug("Deserialized event at (offset:" + oal.offset + ", length:" + oal.length
+                        + "), event=" + event);
             }
             return event;
         } catch (Exception e) {
-            throw new RuntimeException(
-                    "Failed to deserialize an event at position " + oal.offset +
-                            " with length " + oal.length + " for file '" +
-                            serializationFie.getAbsoluteFile() + "'", e);
+            LOG.error("Failed to deserialize an event at position " + oal.offset + " with length "
+                    + oal.length + " for file '" + serializationFie.getAbsoluteFile() + "'", e);
+            return null;
         }
     }
 
-    public String store(LoggingEvent event) {
+    public synchronized String store(LoggingEvent event) {
         try {
             OffsetAndLength loc = new OffsetAndLength();
+            channel.position(channel.size());
             loc.offset = channel.position();
 
             ByteArrayOutputStream baos = new ByteArrayOutputStream(256);

Modified: labs/pinpoint/trunk/pinpoint-core/src/main/java/org/apache/logging/pinpoint/utils/PinpointUtils.java
URL: http://svn.apache.org/viewvc/labs/pinpoint/trunk/pinpoint-core/src/main/java/org/apache/logging/pinpoint/utils/PinpointUtils.java?rev=569266&r1=569265&r2=569266&view=diff
==============================================================================
--- labs/pinpoint/trunk/pinpoint-core/src/main/java/org/apache/logging/pinpoint/utils/PinpointUtils.java (original)
+++ labs/pinpoint/trunk/pinpoint-core/src/main/java/org/apache/logging/pinpoint/utils/PinpointUtils.java Thu Aug 23 23:15:25 2007
@@ -1,20 +1,13 @@
 /**
- 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.
-
-**/
+ * 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.
+ */
 package org.apache.logging.pinpoint.utils;
 
 import java.io.File;
@@ -40,18 +33,24 @@
         return getHomeFromCmdLine(cmdLine).createContext(cmdLine.getOptionValue('c'));
     }
 
-    public static Options getCommonCommandLineOptions() {
-        Options options = new Options();
-
+    public static Options addPinpointHomeOption(Options options) {
         Option home = new Option("h", "home", true, "Pinpoint Home");
-        Option context = new Option("c", "context", true, "Pinpoint Context handle");
+        home.setRequired(false);
+        return options.addOption(home);
+    }
 
-        home.setRequired(true);
+    public static Options addPinpointContextOption(Options options) {
+        Option context = new Option("c", "context", true, "Pinpoint Context handle");
         context.setRequired(true);
+        return options.addOption(context);
+
+    }
 
-        options.addOption(home);
-        options.addOption(context);
+    public static Options getCommonCommandLineOptions() {
+        Options options = new Options();
 
+        addPinpointHomeOption(options);
+        addPinpointContextOption(options);
         return options;
     }
 

Modified: labs/pinpoint/trunk/pinpoint-service/src/main/java/org/apache/logging/pinpoint/service/Service.java
URL: http://svn.apache.org/viewvc/labs/pinpoint/trunk/pinpoint-service/src/main/java/org/apache/logging/pinpoint/service/Service.java?rev=569266&r1=569265&r2=569266&view=diff
==============================================================================
--- labs/pinpoint/trunk/pinpoint-service/src/main/java/org/apache/logging/pinpoint/service/Service.java (original)
+++ labs/pinpoint/trunk/pinpoint-service/src/main/java/org/apache/logging/pinpoint/service/Service.java Thu Aug 23 23:15:25 2007
@@ -16,8 +16,10 @@
 import org.apache.commons.daemon.Daemon;
 import org.apache.commons.daemon.DaemonContext;
 import org.apache.commons.lang.StringUtils;
+import org.apache.commons.lang.SystemUtils;
 import org.apache.log4j.net.SocketHubReceiver;
 import org.apache.log4j.spi.LoggerRepository;
+import org.apache.logging.pinpoint.utils.PinpointUtils;
 import org.springframework.beans.BeansException;
 import org.springframework.beans.factory.config.BeanFactoryPostProcessor;
 import org.springframework.beans.factory.config.ConfigurableListableBeanFactory;
@@ -48,8 +50,9 @@
         Options options = getOptions();
         GnuParser parser = new GnuParser();
 
+        CommandLine cmdLine = null;
         try {
-            CommandLine cmdLine = parser.parse(options, args);
+            cmdLine = parser.parse(options, args);
             /*
              * Extract the requested SocketHubReceivers from the command line
              */
@@ -62,23 +65,23 @@
             throw new IllegalArgumentException("Problematic arguments");
         }
 
+        String pinpointHome = cmdLine.getOptionValue("home", SystemUtils.USER_HOME
+                + SystemUtils.FILE_SEPARATOR + ".pinpoint");
+        System.setProperty("pinpoint.home", pinpointHome);
+
         // TODO configure this? Needs to be done before anything else. Not the
         // best design in Lucene.
 
         System.setProperty("org.apache.lucene.FSDirectory.class",
                 "org.apache.lucene.store.MMapDirectory");
 
-        String basePackage = Service.class.getPackage().getName().replace('.', '/');
         String config = "default-receiver-config.xml";
 
         System.setProperty("log4j.debug", "true");
 
         this.configs = new String[] { "logger-repository.xml", "amq.xml", "jmx.xml", "restlet.xml",
-                "pinpoint-context.xml", config };
+                "properties.xml", "pinpoint-context.xml", config };
 
-        for (int i = 0; i < configs.length; i++) {
-            configs[i] = basePackage + "/" + configs[i];
-        }
     }
 
     private static void showHelp(Options options) {
@@ -88,6 +91,7 @@
 
     private Options getOptions() {
         Options options = new Options();
+        PinpointUtils.addPinpointHomeOption(options);
         options
                 .addOption(OptionBuilder
                         .withLongOpt("socketHub")
@@ -145,7 +149,7 @@
     }
 
     public void start() throws Exception {
-        ctx = new ClassPathXmlApplicationContext(configs);
+        ctx = new ClassPathXmlApplicationContext(configs, this.getClass());
         if (this.configs != null) {
             new ExtraSocketHubReceiverPostProcesser().postProcessBeanFactory(this.ctx
                     .getBeanFactory());

Modified: labs/pinpoint/trunk/pinpoint-service/src/main/resources/org/apache/logging/pinpoint/service/jmx.xml
URL: http://svn.apache.org/viewvc/labs/pinpoint/trunk/pinpoint-service/src/main/resources/org/apache/logging/pinpoint/service/jmx.xml?rev=569266&r1=569265&r2=569266&view=diff
==============================================================================
--- labs/pinpoint/trunk/pinpoint-service/src/main/resources/org/apache/logging/pinpoint/service/jmx.xml (original)
+++ labs/pinpoint/trunk/pinpoint-service/src/main/resources/org/apache/logging/pinpoint/service/jmx.xml Thu Aug 23 23:15:25 2007
@@ -23,5 +23,20 @@
 		
 	</bean>
 	
+	<bean id="mbeanServerFactory" class="org.springframework.jmx.support.MBeanServerFactoryBean" >
+			<property name="locateExistingServerIfPossible" value="true" />
+	</bean>
 	
+	<bean id="serverConnector" class="org.springframework.jmx.support.ConnectorServerFactoryBean"> 
+		<property name="objectName" value="connector:name=rmi"/> 
+		<property name="serviceUrl" value="service:jmx:rmi://localhost/jndi/rmi://localhost:${pinpoint.jmx.port}/myconnector"/>
+		<property name="daemon" value="true" />
+		<property name="threaded" value="true" />
+		<property name="server" ref="mbeanServerFactory" /> 
+	</bean> 
+	
+	<bean id="registry" class="org.springframework.remoting.rmi.RmiRegistryFactoryBean"> 
+		<property name="port" value="pinpoint.rmi.port"/> 
+	</bean> 
+
 </beans>

Modified: labs/pinpoint/trunk/pinpoint-service/src/main/resources/org/apache/logging/pinpoint/service/pinpoint-context.xml
URL: http://svn.apache.org/viewvc/labs/pinpoint/trunk/pinpoint-service/src/main/resources/org/apache/logging/pinpoint/service/pinpoint-context.xml?rev=569266&r1=569265&r2=569266&view=diff
==============================================================================
--- labs/pinpoint/trunk/pinpoint-service/src/main/resources/org/apache/logging/pinpoint/service/pinpoint-context.xml (original)
+++ labs/pinpoint/trunk/pinpoint-service/src/main/resources/org/apache/logging/pinpoint/service/pinpoint-context.xml Thu Aug 23 23:15:25 2007
@@ -23,6 +23,7 @@
   http://activemq.org/config/1.0 http://people.apache.org/repository/org.apache.activemq/xsds/activemq-core-4.1-SNAPSHOT.xsd">
 
   <bean id="pinpointHome" class="org.apache.logging.pinpoint.PinpointHome">
+  		<constructor-arg value="${pinpoint.home}" />
   		<meta key="jmxObjectName" value="Pinpoint:name=PinpointHome" />
   </bean>
   
@@ -51,12 +52,7 @@
   	<constructor-arg ref="indexWriterFactory" />
   	<constructor-arg ref="analyserFactory" />
   	<constructor-arg ref="eventsWrittenCounter" />
-  	<property name="ignoredProperties">
-  		<set>
-  			<value>forward.begin</value>
-  			<value>forward.end</value>
-  		</set>
-  	</property>
+  	<property name="ignoredProperties" value="${pinpoint.ignoredProperties}" />
   </bean>
 
   <bean id="receivedEventsCounter" class="org.apache.logging.pinpoint.metric.Counter" >

Added: labs/pinpoint/trunk/pinpoint-service/src/main/resources/org/apache/logging/pinpoint/service/properties.xml
URL: http://svn.apache.org/viewvc/labs/pinpoint/trunk/pinpoint-service/src/main/resources/org/apache/logging/pinpoint/service/properties.xml?rev=569266&view=auto
==============================================================================
--- labs/pinpoint/trunk/pinpoint-service/src/main/resources/org/apache/logging/pinpoint/service/properties.xml (added)
+++ labs/pinpoint/trunk/pinpoint-service/src/main/resources/org/apache/logging/pinpoint/service/properties.xml Thu Aug 23 23:15:25 2007
@@ -0,0 +1,27 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<beans xmlns="http://www.springframework.org/schema/beans"
+	xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+	xmlns:util="http://www.springframework.org/schema/util"
+	xsi:schemaLocation="http://www.springframework.org/schema/beans http://www.springframework.org/schema/beans/spring-beans.xsd
+		http://www.springframework.org/schema/util http://www.springframework.org/schema/util/spring-util.xsd">
+
+	<bean
+		class="org.springframework.beans.factory.config.PropertyPlaceholderConfigurer">
+		<property name="locations">
+			<list>
+				<value>file://${pinpoint.home}/pinpoint.properties</value>
+			</list>
+		</property>
+		<!-- these form the Pinpoint System defaults, should probably be in a default.properties, but for now explicit -->
+		<property name="properties">
+			<props>
+				<prop key="pinpoint.ignoredProperties"></prop> 
+				<prop key="pinpoint.jmx.port">6767</prop>
+				<prop key="pinpoint.rmi.port">1099</prop>
+			</props>
+		
+		</property>
+		<property name="ignoreResourceNotFound" value="true" />
+		<property name="systemPropertiesModeName" value="SYSTEM_PROPERTIES_MODE_OVERRIDE" />
+	</bean>
+</beans>
\ No newline at end of file



---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@labs.apache.org
For additional commands, e-mail: commits-help@labs.apache.org