You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@harmony.apache.org by wj...@apache.org on 2006/07/24 01:37:22 UTC

svn commit: r424858 [2/2] - in /incubator/harmony/enhanced/drlvm/trunk/vm/MMTk: ./ ext/ ext/vm/ ext/vm/HarmonyDRLVM/ ext/vm/HarmonyDRLVM/org/ ext/vm/HarmonyDRLVM/org/apache/ ext/vm/HarmonyDRLVM/org/apache/HarmonyDRLVM/ ext/vm/HarmonyDRLVM/org/apache/Ha...

Added: incubator/harmony/enhanced/drlvm/trunk/vm/MMTk/ext/vm/HarmonyDRLVM/org/apache/HarmonyDRLVM/mm/mmtk/SelectedPlan.java
URL: http://svn.apache.org/viewvc/incubator/harmony/enhanced/drlvm/trunk/vm/MMTk/ext/vm/HarmonyDRLVM/org/apache/HarmonyDRLVM/mm/mmtk/SelectedPlan.java?rev=424858&view=auto
==============================================================================
--- incubator/harmony/enhanced/drlvm/trunk/vm/MMTk/ext/vm/HarmonyDRLVM/org/apache/HarmonyDRLVM/mm/mmtk/SelectedPlan.java (added)
+++ incubator/harmony/enhanced/drlvm/trunk/vm/MMTk/ext/vm/HarmonyDRLVM/org/apache/HarmonyDRLVM/mm/mmtk/SelectedPlan.java Sun Jul 23 16:37:20 2006
@@ -0,0 +1,35 @@
+/*
+ *  Copyright 2005-2006 The Apache Software Foundation or its licensors, as applicable.
+ *
+ *  Licensed under the Apache License, Version 2.0 (the "License");
+ *  you may not use this file except in compliance with the License.
+ *  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ *  Unless required by applicable law or agreed to in writing, software
+ *  distributed under the License is distributed on an "AS IS" BASIS,
+ *  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ *  See the License for the specific language governing permissions and
+ *  limitations under the License.
+ */
+
+/*
+ * (C) Copyright Department of Computer Science,
+ * Australian National University. 2004
+ */
+
+package org.apache.HarmonyDRLVM.mm.mmtk;
+
+import org.mmtk.plan.nogc.*;
+import org.vmmagic.pragma.*;
+
+public final class SelectedPlan extends NoGC
+  implements Uninterruptible {
+
+  public static final SelectedPlan singleton = new SelectedPlan();
+  
+  public static final SelectedPlan get() throws InlinePragma {
+    return singleton;
+  }
+}

Added: incubator/harmony/enhanced/drlvm/trunk/vm/MMTk/ext/vm/HarmonyDRLVM/org/apache/HarmonyDRLVM/mm/mmtk/SelectedPlanConstraints.java
URL: http://svn.apache.org/viewvc/incubator/harmony/enhanced/drlvm/trunk/vm/MMTk/ext/vm/HarmonyDRLVM/org/apache/HarmonyDRLVM/mm/mmtk/SelectedPlanConstraints.java?rev=424858&view=auto
==============================================================================
--- incubator/harmony/enhanced/drlvm/trunk/vm/MMTk/ext/vm/HarmonyDRLVM/org/apache/HarmonyDRLVM/mm/mmtk/SelectedPlanConstraints.java (added)
+++ incubator/harmony/enhanced/drlvm/trunk/vm/MMTk/ext/vm/HarmonyDRLVM/org/apache/HarmonyDRLVM/mm/mmtk/SelectedPlanConstraints.java Sun Jul 23 16:37:20 2006
@@ -0,0 +1,41 @@
+/*
+ *  Copyright 2005-2006 The Apache Software Foundation or its licensors, as applicable.
+ *
+ *  Licensed under the Apache License, Version 2.0 (the "License");
+ *  you may not use this file except in compliance with the License.
+ *  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ *  Unless required by applicable law or agreed to in writing, software
+ *  distributed under the License is distributed on an "AS IS" BASIS,
+ *  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ *  See the License for the specific language governing permissions and
+ *  limitations under the License.
+ */
+
+/*
+ * (C) Copyright Department of Computer Science,
+ * Australian National University. 2005
+ */
+
+package org.apache.HarmonyDRLVM.mm.mmtk;
+
+import org.mmtk.plan.nogc.*;
+import org.vmmagic.pragma.*;
+
+/**
+ * This class extends the selected MMTk constraints class. 
+ */
+public final class SelectedPlanConstraints extends NoGCConstraints
+  implements Uninterruptible {
+
+  public static final SelectedPlanConstraints singleton = new SelectedPlanConstraints();
+  
+  /**
+   * Return the instance of the SelectedPlan
+   */
+  public static final SelectedPlanConstraints get() throws InlinePragma {
+    return singleton;
+  }
+}

Added: incubator/harmony/enhanced/drlvm/trunk/vm/MMTk/ext/vm/HarmonyDRLVM/org/apache/HarmonyDRLVM/mm/mmtk/Statistics.java
URL: http://svn.apache.org/viewvc/incubator/harmony/enhanced/drlvm/trunk/vm/MMTk/ext/vm/HarmonyDRLVM/org/apache/HarmonyDRLVM/mm/mmtk/Statistics.java?rev=424858&view=auto
==============================================================================
--- incubator/harmony/enhanced/drlvm/trunk/vm/MMTk/ext/vm/HarmonyDRLVM/org/apache/HarmonyDRLVM/mm/mmtk/Statistics.java (added)
+++ incubator/harmony/enhanced/drlvm/trunk/vm/MMTk/ext/vm/HarmonyDRLVM/org/apache/HarmonyDRLVM/mm/mmtk/Statistics.java Sun Jul 23 16:37:20 2006
@@ -0,0 +1,83 @@
+/*
+ *  Copyright 2005-2006 The Apache Software Foundation or its licensors, as applicable.
+ *
+ *  Licensed under the Apache License, Version 2.0 (the "License");
+ *  you may not use this file except in compliance with the License.
+ *  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ *  Unless required by applicable law or agreed to in writing, software
+ *  distributed under the License is distributed on an "AS IS" BASIS,
+ *  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ *  See the License for the specific language governing permissions and
+ *  limitations under the License.
+ */
+
+/*
+ * (C) Copyright Department of Computer Science,
+ * Australian National University. 2004
+ *
+ * (C) Copyright IBM Corp. 2001, 2003
+ */
+
+package org.apache.HarmonyDRLVM.mm.mmtk;
+
+import org.mmtk.utility.Constants;
+
+import org.vmmagic.unboxed.*;
+import org.vmmagic.pragma.*;
+
+public final class Statistics extends org.mmtk.vm.Statistics implements Constants, Uninterruptible {
+  /**
+   * Returns the number of collections that have occured.
+   *
+   * @return The number of collections that have occured.
+   */
+  public final int getCollectionCount()
+    throws UninterruptiblePragma {
+    //return MM_Interface.getCollectionCount();
+    System.out.println("org.apache.HarmonyDRLVM.mm.mmtk.Statistics.getCollectionCount() was called");
+    return 0;
+  }
+
+  /**
+   * Read cycle counter
+   */
+  public final long cycles() {
+    System.out.println("org.apache.HarmonyDRLVM.mm.mmtk.Statistics.cycles() was called");
+    return 0;
+  }
+
+  /**
+   * Convert cycles to milliseconds
+   */
+  public final double cyclesToMillis(long c) {
+    System.out.println("org.apache.HarmonyDRLVM.mm.mmtk.Statistics.cyclesToMillis() was called -- does this api make sense??");
+    return 0;
+  }
+
+  /**
+   * Convert cycles to seconds
+   */
+  public final double cyclesToSecs(long c) {
+      System.out.println("org.apache.HarmonyDRLVM.mm.mmtk.Statistics.cyclesToSecs() was called -- does this api make sense??");
+      return 0;
+  }
+
+  /**
+   * Convert milliseconds to cycles
+   */
+  public final long millisToCycles(double t) {
+      System.out.println("org.apache.HarmonyDRLVM.mm.mmtk.Statistics.() was called -- does this api make sense??");
+      return 0;
+  }
+
+  /**
+   * Convert seconds to cycles
+   */
+  public final long secsToCycles(double t) {
+      System.out.println("org.apache.HarmonyDRLVM.mm.mmtk.Statistics.millisToCycles() was called -- does this api make sense??");
+      return 0;
+  }
+}

Added: incubator/harmony/enhanced/drlvm/trunk/vm/MMTk/ext/vm/HarmonyDRLVM/org/apache/HarmonyDRLVM/mm/mmtk/Strings.java
URL: http://svn.apache.org/viewvc/incubator/harmony/enhanced/drlvm/trunk/vm/MMTk/ext/vm/HarmonyDRLVM/org/apache/HarmonyDRLVM/mm/mmtk/Strings.java?rev=424858&view=auto
==============================================================================
--- incubator/harmony/enhanced/drlvm/trunk/vm/MMTk/ext/vm/HarmonyDRLVM/org/apache/HarmonyDRLVM/mm/mmtk/Strings.java (added)
+++ incubator/harmony/enhanced/drlvm/trunk/vm/MMTk/ext/vm/HarmonyDRLVM/org/apache/HarmonyDRLVM/mm/mmtk/Strings.java Sun Jul 23 16:37:20 2006
@@ -0,0 +1,89 @@
+/*
+ *  Copyright 2005-2006 The Apache Software Foundation or its licensors, as applicable.
+ *
+ *  Licensed under the Apache License, Version 2.0 (the "License");
+ *  you may not use this file except in compliance with the License.
+ *  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ *  Unless required by applicable law or agreed to in writing, software
+ *  distributed under the License is distributed on an "AS IS" BASIS,
+ *  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ *  See the License for the specific language governing permissions and
+ *  limitations under the License.
+ */
+
+/*
+ * (C) Copyright Department of Computer Science,
+ * Australian National University. 2004
+ *
+ * (C) Copyright IBM Corp. 2001, 2003
+ */
+
+package org.apache.HarmonyDRLVM.mm.mmtk;
+
+import org.vmmagic.unboxed.*;
+import org.vmmagic.pragma.*;
+
+public final class Strings extends org.mmtk.vm.Strings implements Uninterruptible {
+  /**
+   * Log a message.
+   *
+   * @param c character array with message starting at index 0
+   * @param len number of characters in message
+   */
+  public final void write(char [] c, int len) {
+      for (int xx=0; xx < c.length; xx++) 
+      {
+        System.out.print(c[xx]);    
+      }
+      System.out.println("");
+  }
+
+  /**
+   * Log a thread identifier and a message.
+   *
+   * @param c character array with message starting at index 0
+   * @param len number of characters in message
+   */
+  public final void writeThreadId(char [] c, int len) {
+      for (int xx=0; xx < c.length; xx++) 
+      {
+          System.out.print(c[xx]);    
+      }
+      System.out.println("");    
+  }
+
+  /**
+   * Copies characters from the string into the character array.
+   * Thread switching is disabled during this method's execution.
+   * <p>
+   * <b>TODO:</b> There are special memory management semantics here that
+   * someone should document.
+   *
+   * @param src the source string
+   * @param dst the destination array
+   * @param dstBegin the start offset in the desination array
+   * @param dstEnd the index after the last character in the
+   * destination to copy to
+   * @return the number of characters copied.
+   */
+  public final int copyStringToChars(String src, char [] dst,
+                                     int dstBegin, int dstEnd)
+    throws LogicallyUninterruptiblePragma {
+      /*
+    if (VM.runningVM)
+      VM_Processor.getCurrentProcessor().disableThreadSwitching();
+    int len = src.length();
+    int n = (dstBegin + len <= dstEnd) ? len : (dstEnd - dstBegin);
+    for (int i = 0; i < n; i++) 
+      Barriers.setArrayNoBarrierStatic(dst, dstBegin + i, src.charAt(i));
+    if (VM.runningVM)
+      VM_Processor.getCurrentProcessor().enableThreadSwitching();
+    return n;
+    */
+      System.out.println("org.apache.HarmonyDRLVM.mm.mmtk.Strings.copyStringToChars()");
+      return 0;
+  }
+}

Added: incubator/harmony/enhanced/drlvm/trunk/vm/MMTk/ext/vm/HarmonyDRLVM/org/apache/HarmonyDRLVM/mm/mmtk/SynchronizedCounter.java
URL: http://svn.apache.org/viewvc/incubator/harmony/enhanced/drlvm/trunk/vm/MMTk/ext/vm/HarmonyDRLVM/org/apache/HarmonyDRLVM/mm/mmtk/SynchronizedCounter.java?rev=424858&view=auto
==============================================================================
--- incubator/harmony/enhanced/drlvm/trunk/vm/MMTk/ext/vm/HarmonyDRLVM/org/apache/HarmonyDRLVM/mm/mmtk/SynchronizedCounter.java (added)
+++ incubator/harmony/enhanced/drlvm/trunk/vm/MMTk/ext/vm/HarmonyDRLVM/org/apache/HarmonyDRLVM/mm/mmtk/SynchronizedCounter.java Sun Jul 23 16:37:20 2006
@@ -0,0 +1,77 @@
+/*
+ *  Copyright 2005-2006 The Apache Software Foundation or its licensors, as applicable.
+ *
+ *  Licensed under the Apache License, Version 2.0 (the "License");
+ *  you may not use this file except in compliance with the License.
+ *  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ *  Unless required by applicable law or agreed to in writing, software
+ *  distributed under the License is distributed on an "AS IS" BASIS,
+ *  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ *  See the License for the specific language governing permissions and
+ *  limitations under the License.
+ */
+
+/*
+ * (C) Copyright Department of Computer Science,
+ * Australian National University. 2004
+ *
+ * (C) Copyright IBM Corp. 2001, 2003
+ */
+
+package org.apache.HarmonyDRLVM.mm.mmtk;
+
+import org.vmmagic.pragma.*;
+import org.vmmagic.unboxed.Offset;
+
+/**
+ * A counter that supports atomic increment and reset.
+ *
+ * $Id: SynchronizedCounter.java,v 1.2 2005/07/20 14:32:01 dframpton-oss Exp $
+ *
+ * @author Perry Cheng
+ */
+public final class SynchronizedCounter extends org.mmtk.vm.SynchronizedCounter implements Uninterruptible {
+
+  private static Offset offset = Offset.max();
+
+  public static void boot() {
+    //offset = VM_Entrypoints.synchronizedCounterField.getOffset();
+      System.out.println("org.apache.HarmonyDRLVM.mm.mmtk.SynchronizedCounter.boot()");
+  }
+
+  private int count = 0;
+
+  public int reset() {
+    //    int offset = VM_Interface.synchronizedCounterOffset;
+    /* int oldValue = count;
+    int actualOldValue = VM_Synchronization.fetchAndAdd(this, offset, -oldValue);
+    if (actualOldValue != oldValue) {
+      VM.sysWriteln("oldValue = ", oldValue);
+      VM.sysWriteln("actualOldValue = ", actualOldValue);
+      VM.sysFail("Concurrent use of SynchronizedCounter.reset");
+    }
+    return oldValue;
+    */
+    System.out.println("org.apache.HarmonyDRLVM.mm.mmtk.SynchronizedCounter.reset()");
+      return 0;
+  }
+
+  // Returns the value before the add
+  //
+  public int increment() {
+    //if (VM.VerifyAssertions) VM._assert(!offset.isMax());
+    //return VM_Synchronization.fetchAndAdd(this, offset, 1);
+    System.out.println("org.apache.HarmonyDRLVM.mm.mmtk.SynchronizedCounter.increment()");
+    return 0;
+  }
+
+  public int peek () {
+    //return count;
+    System.out.println("org.apache.HarmonyDRLVM.mm.mmtk.SynchronizedCounter.peek()");
+      return 0;
+  }
+
+}

Added: incubator/harmony/enhanced/drlvm/trunk/vm/MMTk/ext/vm/HarmonyDRLVM/org/apache/HarmonyDRLVM/mm/mmtk/TraceInterface.java
URL: http://svn.apache.org/viewvc/incubator/harmony/enhanced/drlvm/trunk/vm/MMTk/ext/vm/HarmonyDRLVM/org/apache/HarmonyDRLVM/mm/mmtk/TraceInterface.java?rev=424858&view=auto
==============================================================================
--- incubator/harmony/enhanced/drlvm/trunk/vm/MMTk/ext/vm/HarmonyDRLVM/org/apache/HarmonyDRLVM/mm/mmtk/TraceInterface.java (added)
+++ incubator/harmony/enhanced/drlvm/trunk/vm/MMTk/ext/vm/HarmonyDRLVM/org/apache/HarmonyDRLVM/mm/mmtk/TraceInterface.java Sun Jul 23 16:37:20 2006
@@ -0,0 +1,190 @@
+/*
+ *  Copyright 2005-2006 The Apache Software Foundation or its licensors, as applicable.
+ *
+ *  Licensed under the Apache License, Version 2.0 (the "License");
+ *  you may not use this file except in compliance with the License.
+ *  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ *  Unless required by applicable law or agreed to in writing, software
+ *  distributed under the License is distributed on an "AS IS" BASIS,
+ *  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ *  See the License for the specific language governing permissions and
+ *  limitations under the License.
+ */
+
+/*
+ * (C) Copyright Department of Computer Science,
+ * Australian National University. 2004
+ *
+ * (C) Copyright IBM Corp. 2001, 2003
+ */
+
+package org.apache.HarmonyDRLVM.mm.mmtk;
+
+import org.mmtk.utility.Constants;
+import org.vmmagic.unboxed.*;
+import org.vmmagic.pragma.*;
+
+/**
+ * Class that supports scanning Objects or Arrays for references
+ * during tracing, handling those references, and computing death times
+ * 
+ * $Id: TraceInterface.java,v 1.3 2006/06/05 04:30:57 steveb-oss Exp $
+ * 
+ * @author <a href="http://www-ali.cs.umass.edu/~hertz">Matthew Hertz</a>
+ * @version $Revision: 1.3 $
+ * @date $Date: 2006/06/05 04:30:57 $
+ */
+public final class TraceInterface extends org.mmtk.vm.TraceInterface implements Uninterruptible {
+
+  /***********************************************************************
+   *
+   * Class variables
+   */
+  private static byte allocCallMethods[][];
+
+  static {
+    /* Build the list of "own methods" */
+      /*
+    allocCallMethods = new byte[13][];
+    allocCallMethods[0] = "postAlloc".getBytes();
+    allocCallMethods[1] = "traceAlloc".getBytes();
+    allocCallMethods[2] = "allocateScalar".getBytes();
+    allocCallMethods[3] = "allocateArray".getBytes();
+    allocCallMethods[4] = "clone".getBytes();
+    allocCallMethods[5] = "alloc".getBytes();
+    allocCallMethods[6] = "buildMultiDimensionalArray".getBytes();
+    allocCallMethods[7] = "resolvedNewScalar".getBytes();
+    allocCallMethods[8] = "resolvedNewArray".getBytes();
+    allocCallMethods[9] = "unresolvedNewScalar".getBytes();
+    allocCallMethods[10] = "unresolvedNewArray".getBytes();
+    allocCallMethods[11] = "cloneScalar".getBytes();
+    allocCallMethods[12] = "cloneArray".getBytes();
+    */
+  }
+
+  /***********************************************************************
+   *
+   * Public Methods
+   */
+
+  /**
+   * Returns if the VM is ready for a garbage collection.
+   *
+   * @return True if the RVM is ready for GC, false otherwise.
+   */
+  public final boolean gcEnabled() {
+    System.out.println("org.apache.HarmonyDRLVM.mm.mmtk.TraceInterface.gcEnabled() was called");
+    return false;
+  }
+
+  /**
+   * Given a method name, determine if it is a "real" method or one
+   * used for allocation/tracing.
+   *
+   * @param name The method name to test as an array of bytes
+   * @return True if the method is a "real" method, false otherwise.
+   */
+  private final boolean isAllocCall(byte[] name) {    
+      System.out.println("org.apache.HarmonyDRLVM.mm.mmtk.TraceInterface.isAllocCall() was called");
+      return false;
+  }
+
+  /**
+   * This adjusts the offset into an object to reflect what it would look like
+   * if the fields were laid out in memory space immediately after the object
+   * pointer.
+   *
+   * @param isScalar If this is a pointer store to a scalar object
+   * @param src The address of the source object
+   * @param slot The address within <code>src</code> into which
+   * the update will be stored
+   * @return The easy to understand offset of the slot
+   */
+  public final Offset adjustSlotOffset(boolean isScalar, 
+                                              ObjectReference src,
+                                              Address slot) {
+      System.out.println("org.apache.HarmonyDRLVM.mm.mmtk.TraceInterface.adjustSlotOffset() was called");
+      return Offset.fromInt(0);
+  }
+
+  /**
+   * This skips over the frames added by the tracing algorithm, outputs 
+   * information identifying the method the containts the "new" call triggering
+   * the allocation, and returns the address of the first non-trace, non-alloc
+   * stack frame.
+   *
+   *@param typeRef The type reference (tib) of the object just allocated
+   *@return The frame pointer address for the method that allocated the object
+   */
+  public final Address skipOwnFramesAndDump(ObjectReference typeRef)
+    throws NoInlinePragma {
+      System.out.println("org.apache.HarmonyDRLVM.mm.mmtk.TraceInterface.skipOwnFramesAndDump() was called");
+      return Address.fromInt(0);
+  }
+
+  /***********************************************************************
+   *
+   * Wrapper methods
+   */
+
+  public final void updateDeathTime(Object obj) throws InlinePragma {
+      System.out.println("org.apache.HarmonyDRLVM.mm.mmtk.TraceInterface.updateDeathTime() was called");
+  }
+
+  public final void setDeathTime(ObjectReference ref, Word time_) 
+    throws InlinePragma {
+      System.out.println("org.apache.HarmonyDRLVM.mm.mmtk.TraceInterface.setDeathTime() was called");
+  }
+
+  public final void setLink(ObjectReference ref, ObjectReference link) 
+    throws InlinePragma {
+      System.out.println("org.apache.HarmonyDRLVM.mm.mmtk.TraceInterface.setLink() was called");
+  }
+
+  public final void updateTime(Word time_) throws InlinePragma {
+      System.out.println("org.apache.HarmonyDRLVM.mm.mmtk.TraceInterface.updateTime() was called");
+  }
+
+  public final Word getOID(ObjectReference ref) throws InlinePragma {
+      System.out.println("org.apache.HarmonyDRLVM.mm.mmtk.TraceInterface.getOID() was called");
+      return Word.fromInt(0);
+  }
+
+  public final Word getDeathTime(ObjectReference ref) throws InlinePragma {
+      System.out.println("org.apache.HarmonyDRLVM.mm.mmtk.TraceInterface.getDeathTime() was called");
+      return Word.fromInt(0);
+  }
+
+  public final ObjectReference getLink(ObjectReference ref)
+    throws InlinePragma {
+      System.out.println("org.apache.HarmonyDRLVM.mm.mmtk.TraceInterface.getLink() was called");
+      return ObjectReference.nullReference();
+  }
+
+  public final Address getBootImageLink() throws InlinePragma {
+      System.out.println("org.apache.HarmonyDRLVM.mm.mmtk.TraceInterface.getBootImageLink() was called");
+      return Address.fromInt(0);
+  }
+
+  public final Word getOID() throws InlinePragma {
+      System.out.println("org.apache.HarmonyDRLVM.mm.mmtk.TraceInterface.getOID() was called");
+      return Word.fromInt(0);
+  }
+
+  public final void setOID(Word oid) throws InlinePragma {
+      System.out.println("org.apache.HarmonyDRLVM.mm.mmtk.TraceInterface.setOID() was called");
+  }
+
+  public final int getHeaderSize() throws InlinePragma {
+      System.out.println("org.apache.HarmonyDRLVM.mm.mmtk.TraceInterface.getHeaderSize() was called");
+      return 0;
+  }
+
+  public final int getHeaderEndOffset() throws InlinePragma {
+      System.out.println("org.apache.HarmonyDRLVM.mm.mmtk.TraceInterface.getHeaderEndOffset() was called");
+      return 0;
+  }
+}