You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@harmony.apache.org by mc...@apache.org on 2008/05/20 20:38:25 UTC

svn commit: r658384 [2/2] - in /harmony/enhanced/drlvm/trunk/vm: em/src/ gc_gen/src/common/ gc_gen/src/finalizer_weakref/ include/open/ jitrino/src/codegenerator/ia32/ jitrino/src/codegenerator/ipf/ jitrino/src/codegenerator/ipf/include/ jitrino/src/je...

Modified: harmony/enhanced/drlvm/trunk/vm/vmcore/src/util/ipf/base/jit_runtime_support_ipf.cpp
URL: http://svn.apache.org/viewvc/harmony/enhanced/drlvm/trunk/vm/vmcore/src/util/ipf/base/jit_runtime_support_ipf.cpp?rev=658384&r1=658383&r2=658384&view=diff
==============================================================================
--- harmony/enhanced/drlvm/trunk/vm/vmcore/src/util/ipf/base/jit_runtime_support_ipf.cpp (original)
+++ harmony/enhanced/drlvm/trunk/vm/vmcore/src/util/ipf/base/jit_runtime_support_ipf.cpp Tue May 20 11:38:23 2008
@@ -214,9 +214,9 @@
     addr = (void *)malloc_fixed_code_for_jit(stub_size, DEFAULT_CODE_ALIGNMENT, CODE_BLOCK_HEAT_MAX/2, CAA_Allocate);
     emitter.copy((char *)addr);
 
-    flush_hw_cache((Byte *)addr, stub_size);
+    flush_hw_cache((U_8*)addr, stub_size);
     sync_i_cache();
-    
+
     return addr;
 } //gen_vm_rt_ljf_wrapper_compactor
 
@@ -258,7 +258,7 @@
                                                          bool inlining_allowed)
 {
     Boolean use_inline_allocation_sequence = TRUE;
-    size_t offset_gc_local = (Byte *)&(p_TLS_vmthread->_gc_private_information) - (Byte *)p_TLS_vmthread;
+    size_t offset_gc_local = (U_8*)&(p_TLS_vmthread->_gc_private_information) - (U_8*)p_TLS_vmthread;
     unsigned current_offset = 1;
     unsigned limit_offset = 1;
     if (gc_supports_frontier_allocation(&current_offset, &limit_offset) && inlining_allowed)
@@ -360,8 +360,8 @@
                                                                 void **fast_obj_alloc_proc,
                                                                 void **slow_obj_alloc_proc)
 {
-    size_t offset_gc_local = (Byte *)&(p_TLS_vmthread->_gc_private_information) - (Byte *)p_TLS_vmthread;
-    
+    size_t offset_gc_local = (U_8*)&(p_TLS_vmthread->_gc_private_information) - (U_8*)p_TLS_vmthread;
+
     emitter.ipf_sxt(sxt_size_4, IN_REG1, IN_REG1);
 
 #ifdef VM_STATS
@@ -443,7 +443,7 @@
     size_t stub_size = emitter.get_size();
     void *addr = (void *)malloc_fixed_code_for_jit(stub_size, DEFAULT_CODE_ALIGNMENT, CODE_BLOCK_HEAT_MAX/2, CAA_Allocate);
     emitter.copy((char *)addr);    
-    flush_hw_cache((Byte *)addr, stub_size);
+    flush_hw_cache((U_8*)addr, stub_size);
     sync_i_cache();
 
 
@@ -653,9 +653,9 @@
     const int offset_is_suitable = (int)Class::get_offset_of_fast_instanceof_flag();
     const int offset_depth = (int)Class::get_offset_of_depth();
 
-    VTable *dummy_vtable = NULL;
-    const int offset_superclasses = (int) ((Byte*)&dummy_vtable->superclasses[-1] - (Byte*)dummy_vtable);
-    const int offset_clss = (int) ((Byte*)&dummy_vtable->clss - (Byte*)dummy_vtable);
+    VTable* dummy_vtable = NULL;
+    const int offset_superclasses = (int) ((U_8*)&dummy_vtable->superclasses[-1] - (U_8*)dummy_vtable);
+    const int offset_clss = (int) ((U_8*)&dummy_vtable->clss - (U_8*)dummy_vtable);
 
     // sc1 = super_class->get_offset_of_fast_instanceof_flag()
     // sc3 = [sub_object]
@@ -806,9 +806,9 @@
     size_t stub_size = emitter.get_size();
     addr = (void *)malloc_fixed_code_for_jit(stub_size, DEFAULT_CODE_ALIGNMENT, CODE_BLOCK_HEAT_MAX/2, CAA_Allocate);
     emitter.copy((char *)addr);
-    flush_hw_cache((Byte *)addr, stub_size);
+    flush_hw_cache((U_8*)addr, stub_size);
     sync_i_cache();
-    
+
     return addr;
 } //get_vm_rt_aastore_address_compactor
 
@@ -865,7 +865,7 @@
     emitter.copy((char *)addr);
 
 
-    flush_hw_cache((Byte *)addr, stub_size);
+    flush_hw_cache((U_8*)addr, stub_size);
     sync_i_cache();
 
     DUMP_STUB(addr, "vm_rt_checkcast", stub_size);
@@ -921,7 +921,7 @@
     emitter.copy((char *)addr);
 
 
-    flush_hw_cache((Byte *)addr, stub_size);
+    flush_hw_cache((U_8*)addr, stub_size);
     sync_i_cache();
 
     DUMP_STUB(addr, "vm_rt_instanceof", stub_size);
@@ -943,7 +943,7 @@
     const int offset_array_element_class = Class::get_offset_of_array_element_class();
 
     VTable *dummy_vtable = NULL;
-    const int offset_clss = (int) ((Byte*)&dummy_vtable->clss - (Byte*)dummy_vtable);
+    const int offset_clss = (int)((U_8*)&dummy_vtable->clss - (U_8*)dummy_vtable);
 
     if (vm_is_vtable_compressed())
     {
@@ -1015,10 +1015,9 @@
     addr = (void *)malloc_fixed_code_for_jit(stub_size, DEFAULT_CODE_ALIGNMENT, CODE_BLOCK_HEAT_MAX/2, CAA_Allocate);
     emitter.copy((char *)addr);
 
-    flush_hw_cache((Byte *)addr, stub_size);
+    flush_hw_cache((U_8*)addr, stub_size);
     sync_i_cache();
 
-
     return addr;
 } //get_vm_rt_aastore_test_address_compactor
 
@@ -1060,7 +1059,7 @@
 #endif // VM_STATS
 
     // Check clss->state==ST_Initialized, quick return if true.
-    //emitter.ipf_adds(SCRATCH_GENERAL_REG, (int)((Byte*)&dummy->state-(Byte*)dummy), IN_REG0);
+    //emitter.ipf_adds(SCRATCH_GENERAL_REG, (int)((U_8*)&dummy->state-(U_8*)dummy), IN_REG0);
     emitter.ipf_adds(SCRATCH_GENERAL_REG3, 0, 0);
 
     Boolean (*p_is_class_initialized)(Class *clss);
@@ -1086,7 +1085,7 @@
     addr = (void *)malloc_fixed_code_for_jit(stub_size, DEFAULT_CODE_ALIGNMENT, CODE_BLOCK_HEAT_COLD, CAA_Allocate);
     emitter.copy((char *)addr);
 
-    flush_hw_cache((Byte *)addr, stub_size);
+    flush_hw_cache((U_8*)addr, stub_size);
     sync_i_cache();
 
 
@@ -1352,7 +1351,7 @@
 
     void *stub = (void *)malloc_fixed_code_for_jit(total_stub_size, DEFAULT_CODE_ALIGNMENT, CODE_BLOCK_HEAT_MAX/2, CAA_Allocate);
     emitter.copy((char *)stub);
-    flush_hw_cache((Byte *)stub, total_stub_size);
+    flush_hw_cache((U_8*)stub, total_stub_size);
     sync_i_cache();
 
     return stub;
@@ -1630,7 +1629,7 @@
     void *addr = (void *)malloc_fixed_code_for_jit(stub_size, DEFAULT_CODE_ALIGNMENT, CODE_BLOCK_HEAT_MAX/2, CAA_Allocate);
     emitter.copy((char *)addr);
 
-    flush_hw_cache((Byte *)addr, stub_size);
+    flush_hw_cache((U_8*)addr, stub_size);
     sync_i_cache();
     
     return addr;
@@ -1759,7 +1758,7 @@
     wrapper = (void *)malloc_fixed_code_for_jit(stub_size, DEFAULT_CODE_ALIGNMENT, CODE_BLOCK_HEAT_MAX/2, CAA_Allocate);
     emitter.copy((char *)wrapper);
 
-    flush_hw_cache((Byte *)wrapper, stub_size);
+    flush_hw_cache((U_8*)wrapper, stub_size);
     sync_i_cache();
     
     helper_wrapper_map.add((void *)f, /*value*/ 0, /*value1*/ wrapper);

Modified: harmony/enhanced/drlvm/trunk/vm/vmcore/src/util/ipf/base/stub_code_utils.cpp
URL: http://svn.apache.org/viewvc/harmony/enhanced/drlvm/trunk/vm/vmcore/src/util/ipf/base/stub_code_utils.cpp?rev=658384&r1=658383&r2=658384&view=diff
==============================================================================
--- harmony/enhanced/drlvm/trunk/vm/vmcore/src/util/ipf/base/stub_code_utils.cpp (original)
+++ harmony/enhanced/drlvm/trunk/vm/vmcore/src/util/ipf/base/stub_code_utils.cpp Tue May 20 11:38:23 2008
@@ -158,7 +158,7 @@
     size_t stub_size = emitter.get_size();
     void *stub = (void *)malloc_fixed_code_for_jit(stub_size, DEFAULT_CODE_ALIGNMENT, CODE_BLOCK_HEAT_DEFAULT, CAA_Allocate);
     emitter.copy((char *)stub);
-    flush_hw_cache((Byte *)stub, stub_size);
+    flush_hw_cache((U_8*)stub, stub_size);
     sync_i_cache();
     return stub;
 } //finalize_stub

Modified: harmony/enhanced/drlvm/trunk/vm/vmcore/src/util/ipf/code_emit/Code_Emitter.cpp
URL: http://svn.apache.org/viewvc/harmony/enhanced/drlvm/trunk/vm/vmcore/src/util/ipf/code_emit/Code_Emitter.cpp?rev=658384&r1=658383&r2=658384&view=diff
==============================================================================
--- harmony/enhanced/drlvm/trunk/vm/vmcore/src/util/ipf/code_emit/Code_Emitter.cpp (original)
+++ harmony/enhanced/drlvm/trunk/vm/vmcore/src/util/ipf/code_emit/Code_Emitter.cpp Tue May 20 11:38:23 2008
@@ -83,7 +83,7 @@
 //               Mappings
 /////////////////////////////////////////////////////////////////////////////
 
-const Byte Merced_Code_Emitter::cmp_ext_to_special_instr[cmp_last] = {
+const U_8 Merced_Code_Emitter::cmp_ext_to_special_instr[cmp_last] = {
     ENC_SI_none, ENC_SI_none, ENC_SI_cmp_and, ENC_SI_cmp_or, ENC_SI_none
 };
 
@@ -387,7 +387,7 @@
 // Encode instruction slot by a given instruction
 // Assumes that the instruction slot contains zeros
 
-static void encode_slot(Byte * bundle, uint64 instr, int slot)
+static void encode_slot(U_8* bundle, uint64 instr, int slot)
 {
   // Instr is in bits 0:40, little endian.
     uint64 * u;
@@ -414,14 +414,14 @@
 }
  
   
-static inline void encode_template(Byte * bundle, EM_Templates tmplt, bool stop_bit) 
+static inline void encode_template(U_8* bundle, EM_Templates tmplt, bool stop_bit) 
 {
     *bundle |= (tmplt << 1);
     if (stop_bit)
         *bundle |= 0x1;
 }
 
-static inline void reset_bundle(Byte * bundle) {
+static inline void reset_bundle(U_8* bundle) {
     memset(bundle,0,IPF_INSTRUCTION_LEN);
 }    
 
@@ -503,7 +503,7 @@
     // copy the register info from fast scheme storage to full bit vectors
 
     for (int r=0;r<ENC_N_REG; r++) { // for all registers
-        Byte pos = reg_map[r];
+        U_8 pos = reg_map[r];
         if (!(pos & 0x80)) { // if register is fast one
             uint64 z=((uint64)0x1)<<pos;
             i=0;
@@ -541,7 +541,7 @@
     // copy the register info from fast scheme storage to full bit vectors
 
     for (int r=0;r<ENC_N_REG; r++) { // for all registers
-        Byte pos = reg_map[r];
+        U_8 pos = reg_map[r];
         if (!(pos & 0x80)) { // if register is fast one
             uint64 z=((uint64)0x1)<<pos;
             if (ir.written_regs.fast & z)
@@ -1555,7 +1555,7 @@
     Merced_Code_Emitter::emit_bundle(bundle);
 }
 
-void Merced_Code_Emitter_GC2::encode_def_ref_bit(Byte def_ref) {
+void Merced_Code_Emitter_GC2::encode_def_ref_bit(U_8 def_ref) {
     unsigned shift = n_ref_bit++ % 8;
     if (shift==0) {
         if (ref_bit_arena->first_avail >= ref_bit_arena->endp) {
@@ -1685,7 +1685,7 @@
 
 
 
-static void dump_bytes(Byte *addr, int num_bytes)
+static void dump_bytes(U_8* addr, int num_bytes)
 {
     for(int i = 0; i < num_bytes; i++) {
         printf("%2d: %2x\n", i, addr[i]);
@@ -1694,13 +1694,13 @@
 
 
 
-void dump_ipf_instructions(void *addr, int num_instr)
+void dump_ipf_instructions(void* addr, int num_instr)
 {
     print_header();
     for(int i = 0; i < num_instr; i++) {
-        dump_ipf_instr((void *)(((Byte *)addr) + (16 * i)));
+        dump_ipf_instr((void *)(((U_8*)addr) + (16 * i)));
     }
-    dump_bytes((Byte *)addr, 16 * num_instr);
+    dump_bytes((U_8*)addr, 16 * num_instr);
 } //dump_ipf_instructions
 
 #endif //DUMP_IPF_INSTRUCTIONS
@@ -1738,7 +1738,7 @@
 {
     uint64 target = patch->get_target();
     uint64 offset = patch->get_offset();
-    Byte *curr_ip = (((Byte *)code_buffer) + offset);
+    U_8* curr_ip = (((U_8*)code_buffer) + offset);
 #ifdef DUMP_IPF_INSTRUCTIONS
     printf("Merced_Code_Emitter::apply_brl_patch: code_buffer=%p, offset=%p (curr_ip=%p), target=%p\n",
            code_buffer, offset, curr_ip, target);

Modified: harmony/enhanced/drlvm/trunk/vm/vmcore/src/util/ipf/include/Code_Emitter.h
URL: http://svn.apache.org/viewvc/harmony/enhanced/drlvm/trunk/vm/vmcore/src/util/ipf/include/Code_Emitter.h?rev=658384&r1=658383&r2=658384&view=diff
==============================================================================
--- harmony/enhanced/drlvm/trunk/vm/vmcore/src/util/ipf/include/Code_Emitter.h (original)
+++ harmony/enhanced/drlvm/trunk/vm/vmcore/src/util/ipf/include/Code_Emitter.h Tue May 20 11:38:23 2008
@@ -803,8 +803,8 @@
     // Return an integer with a register bit set according to a fast scheme.
     // If need to switch to a slow scheme return 0.
 
-    uint64 encode_a_fast_reg(Byte * reg_ptr) {
-        Byte b=*reg_ptr;
+    uint64 encode_a_fast_reg(U_8* reg_ptr) {
+        U_8 b=*reg_ptr;
         if (b & 0x80)  {  // reg is not in the map
             if (n_fast_reg >= ENC_N_FAST_REG)
                 return 0;
@@ -814,7 +814,7 @@
     }
 
     // encode a write to a register
-    void encode_write_reg(Byte * reg_ptr, Encoder_Instr_IR &ir) {
+    void encode_write_reg(U_8* reg_ptr, Encoder_Instr_IR &ir) {
 #ifndef ENC_SLOW_REG_DEP
         if (fast_reg_dep_check) {
             uint64 u=encode_a_fast_reg(reg_ptr);
@@ -832,7 +832,7 @@
     }
 
     // encode a read from a register
-    void encode_read_reg(Byte * reg_ptr, Encoder_Instr_IR &ir) {
+    void encode_read_reg(U_8* reg_ptr, Encoder_Instr_IR &ir) {
 #ifndef ENC_SLOW_REG_DEP
         if (fast_reg_dep_check) {
             uint64 u=encode_a_fast_reg(reg_ptr);
@@ -1399,12 +1399,12 @@
     // Fast scheme data:
     // a mapping from a register number to its bit position.
     // 8-th bit is 1 if register has not bit assigned a bit.
-    Byte     reg_map[ENC_N_REG];
-    Byte * const ireg_map;    // pointers to the beginning of the reg map parts
-    Byte * const freg_map;
-    Byte * const breg_map;
-    Byte * const areg_map;
-    Byte * const preg_map;
+    U_8     reg_map[ENC_N_REG];
+    U_8*    const ireg_map;    // pointers to the beginning of the reg map parts
+    U_8*    const freg_map;
+    U_8*    const breg_map;
+    U_8*    const areg_map;
+    U_8*    const preg_map;
     int    n_fast_reg;          // number of used regs with fast dependency check
 
     // Slow scheme data:
@@ -1428,7 +1428,7 @@
     // current instruction couple can be scheduled in any order
     bool     curr_instr_couple_is_unordered; 
     //mapping from compare extensions to speical instructions 
-    const static Byte     cmp_ext_to_special_instr[cmp_last];
+    const static U_8 cmp_ext_to_special_instr[cmp_last];
 #ifdef _DEBUG
     bool     emit_after_get_code_size;
     bool *   target_offset_is_set;
@@ -1907,7 +1907,7 @@
 
     // Reference bit functions
 
-    void encode_def_ref_bit(Byte def_ref);
+    void encode_def_ref_bit(U_8 def_ref);
 
     // Methods that work with Instruction IR
     virtual void _init_ir (Encoder_Unscheduled_Instr_IR &ir,

Modified: harmony/enhanced/drlvm/trunk/vm/vmcore/src/util/ipf/include/Emitter_IR.h
URL: http://svn.apache.org/viewvc/harmony/enhanced/drlvm/trunk/vm/vmcore/src/util/ipf/include/Emitter_IR.h?rev=658384&r1=658383&r2=658384&view=diff
==============================================================================
--- harmony/enhanced/drlvm/trunk/vm/vmcore/src/util/ipf/include/Emitter_IR.h (original)
+++ harmony/enhanced/drlvm/trunk/vm/vmcore/src/util/ipf/include/Emitter_IR.h Tue May 20 11:38:23 2008
@@ -190,16 +190,16 @@
         uint64              fast; // bit vector for 64 registers
         Enc_All_Reg_BV *    slow; // pointer to a bit vector for all registers
     } written_regs;
-       
+
     uint16              bytecode_addr;
     EM_Syllable_Type    syl_type;
-    Byte                flags;
-    Byte                special_instr;
-    Byte                def_ref;    
+    U_8                 flags;
+    U_8                 special_instr;
+    U_8                 def_ref;
     Encoder_Memory_Type mem_type;
     uint64              mem_value;
     unsigned            patch_target_id;
-    
+
     Encoder_Instr_IR () : code_image1(0), syl_type(ST_null),
         flags(0) {
         read_regs.fast=written_regs.fast=0;
@@ -326,7 +326,7 @@
     Encoder_Instr_IR * slots;
     uint16 avail_tmplts; // a bit vector for 12 templates
     EM_Templates  tmplt_number;
-    Byte   flags;
+    U_8      flags;
     unsigned target_id;
 
     void init(bool fast_reg_dep_check) {

Modified: harmony/enhanced/drlvm/trunk/vm/vmcore/src/util/ipf/include/vm_ipf.h
URL: http://svn.apache.org/viewvc/harmony/enhanced/drlvm/trunk/vm/vmcore/src/util/ipf/include/vm_ipf.h?rev=658384&r1=658383&r2=658384&view=diff
==============================================================================
--- harmony/enhanced/drlvm/trunk/vm/vmcore/src/util/ipf/include/vm_ipf.h (original)
+++ harmony/enhanced/drlvm/trunk/vm/vmcore/src/util/ipf/include/vm_ipf.h Tue May 20 11:38:23 2008
@@ -107,11 +107,11 @@
 extern "C" void do_mf();
 extern "C" void do_loadrs(int loadrs);
 
-void flush_hw_cache(Byte *addr, /*int*/ size_t len);
+void flush_hw_cache(U_8* addr, /*int*/ size_t len);
 
 // Save the unwind info passed as the first argument.  Verify that the address
 // passed as the second argument is correct.
-void *save_unwind_info(void *ar_bsp, void **saved_ar_bsp_addr);
+void* save_unwind_info(void* ar_bsp, void** saved_ar_bsp_addr);
 
 
 

Modified: harmony/enhanced/drlvm/trunk/vm/vmcore/src/util/mem_alloc.cpp
URL: http://svn.apache.org/viewvc/harmony/enhanced/drlvm/trunk/vm/vmcore/src/util/mem_alloc.cpp?rev=658384&r1=658383&r2=658384&view=diff
==============================================================================
--- harmony/enhanced/drlvm/trunk/vm/vmcore/src/util/mem_alloc.cpp (original)
+++ harmony/enhanced/drlvm/trunk/vm/vmcore/src/util/mem_alloc.cpp Tue May 20 11:38:23 2008
@@ -145,8 +145,8 @@
     VM_Statistics::get_vm_stats().total_memory_allocated += size;
 #endif
 
-    pDesc->_begin  = (Byte*)pool_storage;
-    pDesc->_end = ((Byte*)(pool_storage) + size);
+    pDesc->_begin  = (U_8*)pool_storage;
+    pDesc->_end = (U_8*)(pool_storage) + size;
 
     return pDesc;
 }
@@ -167,9 +167,9 @@
     _lock();
 
     assert(_active_pool);
-    Byte *pool_start = _active_pool->_begin;
-    pool_start = (Byte *) ((POINTER_SIZE_INT)(pool_start + mask) & ~(POINTER_SIZE_INT)mask);
-    Byte *pool_end = _active_pool->_end;
+    U_8* pool_start = _active_pool->_begin;
+    pool_start = (U_8*)((POINTER_SIZE_INT)(pool_start + mask) & ~(POINTER_SIZE_INT)mask);
+    U_8* pool_end = _active_pool->_end;
 
     size_t mem_left_in_pool = (pool_end - pool_start);
     while (size > mem_left_in_pool) {
@@ -186,7 +186,7 @@
                 _active_pool = pDesc;
 
                 pool_start = _active_pool->_begin;
-                pool_start = (Byte *) ((POINTER_SIZE_INT)(pool_start + mask) & ~(POINTER_SIZE_INT)mask);
+                pool_start = (U_8*)((POINTER_SIZE_INT)(pool_start + mask) & ~(POINTER_SIZE_INT)mask);
 
                 break;
             }
@@ -214,7 +214,7 @@
         }
 
         pool_start = p_pool->_begin;
-        pool_start = (Byte *) ((POINTER_SIZE_INT)(pool_start + mask) & ~(POINTER_SIZE_INT)mask);
+        pool_start = (U_8*)((POINTER_SIZE_INT)(pool_start + mask) & ~(POINTER_SIZE_INT)mask);
         break;
      }
     void *p = pool_start;
@@ -293,7 +293,7 @@
         size_t new_committed = round_up_to_page_size_multiple(new_allocated);
 
         if (new_committed <= _reserved) {
-            Byte* commit_start = _base + _committed;
+            U_8* commit_start = _base + _committed;
             status = port_vmem_commit((void**) &commit_start, new_committed - _committed, _vmem);
         }
 
@@ -306,7 +306,7 @@
 
     }
 
-    Byte* result = _base + _allocated;
+    U_8* result = _base + _allocated;
     _allocated = new_allocated;
 
     _unlock();
@@ -314,7 +314,7 @@
     return result;
  }
 
-Byte* VirtualMemoryPool::get_base()
+U_8* VirtualMemoryPool::get_base()
 {
     assert(_base);
     return _base;

Modified: harmony/enhanced/drlvm/trunk/vm/vmcore/src/util/vm_strings.cpp
URL: http://svn.apache.org/viewvc/harmony/enhanced/drlvm/trunk/vm/vmcore/src/util/vm_strings.cpp?rev=658384&r1=658383&r2=658384&view=diff
==============================================================================
--- harmony/enhanced/drlvm/trunk/vm/vmcore/src/util/vm_strings.cpp (original)
+++ harmony/enhanced/drlvm/trunk/vm/vmcore/src/util/vm_strings.cpp Tue May 20 11:38:23 2008
@@ -217,7 +217,7 @@
 
     assert(f_value_offset);
 
-    Byte* str_raw = (Byte*)str;
+    U_8* str_raw = (U_8*)str;
     *(uint32*)(str_raw+f_count_offset) = length;
     *(uint32*)(str_raw+f_offset_offset) = offset;
     STORE_REFERENCE(str, str_raw+f_value_offset, chars);
@@ -368,7 +368,7 @@
     assert(str);
 
     if (f_count_offset == 0) init_fields();
-    Byte* str_raw = (Byte*)str;
+    U_8* str_raw = (U_8*)str;
     return *(uint32*)(str_raw+f_count_offset);
 }
 
@@ -415,8 +415,8 @@
     if (f_value_char_offset == 0) init_fields();
     assert(f_value_char_offset);
 
-    Byte* str_raw = (Byte*)str;
-    unsigned offset = *(uint32*)(str_raw+f_offset_offset);
+    U_8* str_raw = (U_8*)str;
+    unsigned offset = *(uint32*)(str_raw + f_offset_offset);
     Vector_Handle char_array = get_raw_reference_pointer((ManagedObject**)(str_raw+f_value_char_offset));
     if (char_array) {
         buf->is_compressed = false;

Modified: harmony/enhanced/drlvm/trunk/vm/vmcore/src/verifier-3363/base/context_base.h
URL: http://svn.apache.org/viewvc/harmony/enhanced/drlvm/trunk/vm/vmcore/src/verifier-3363/base/context_base.h?rev=658384&r1=658383&r2=658384&view=diff
==============================================================================
--- harmony/enhanced/drlvm/trunk/vm/vmcore/src/verifier-3363/base/context_base.h (original)
+++ harmony/enhanced/drlvm/trunk/vm/vmcore/src/verifier-3363/base/context_base.h Tue May 20 11:38:23 2008
@@ -103,7 +103,7 @@
     Method_Handle m_method;
 
     //method's bytecode
-    Byte*         m_bytecode;
+    U_8*          m_bytecode;
 
     //legth of the code in the method being verified
     unsigned       m_code_length;
@@ -181,7 +181,7 @@
         m_max_stack = method_get_max_stack(m_method);
         m_code_length = method_get_bytecode_length(m_method);
         m_handlecount = method_get_exc_handler_number(m_method);
-        m_bytecode = const_cast<Byte*>(method_get_bytecode(m_method));
+        m_bytecode = const_cast<U_8*>(method_get_bytecode(m_method));
 
         m_is_constructor = !strcmp(method_get_name(m_method), "<init>") 
             && class_get_super_class(k_class);
@@ -204,22 +204,22 @@
     int instr_get_len_compound(Address instr, OpCode opcode);
 
     //read two-byte value
-    static uint16 read_uint16(Byte* ptr) {
+    static uint16 read_uint16(U_8* ptr) {
         return (ptr[0] << 8) | ptr[1];
     }
 
     //read four-byte value
-    static uint32 read_uint32(Byte* ptr) {
+    static uint32 read_uint32(U_8* ptr) {
         return (ptr[0] << 24) | (ptr[1] << 16) | (ptr[2] << 8) | ptr[3];
     }
 
     //get a 16-bit jump target
-    static Address instr_get_int16_target(Address instr, Byte* ptr) {
+    static Address instr_get_int16_target(Address instr, U_8* ptr) {
         return (Address) (instr + read_uint16(ptr));
     }
 
     //get a 32-bit jump target
-    static Address instr_get_int32_target(Address instr, Byte* ptr) {
+    static Address instr_get_int32_target(Address instr, U_8* ptr) {
         return (Address) (instr + read_uint32(ptr));
     }
 
@@ -239,7 +239,7 @@
     }
 
     //whether this instruction GOTO, RETURN, ATHROW, or RET
-    static int instr_direct(ParseInfo &pi, OpCode opcode, Byte* code, Address instr) {
+    static int instr_direct(ParseInfo &pi, OpCode opcode, U_8* code, Address instr) {
         return (pi.flags & PI_DIRECT) || (opcode == OP_WIDE && code[instr + 1] == OP_RET);
     }
 
@@ -269,7 +269,7 @@
     }
 
     //return the jump target for the given instruction
-    static Address instr_get_jump_target(ParseInfo &pi, Byte* code, Address instr) {
+    static Address instr_get_jump_target(ParseInfo &pi, U_8* code, Address instr) {
         return ( pi.flags & PI_WIDEJUMP ) ? instr_get_int32_target(instr, code + instr + 1) :
             instr_get_int16_target(instr, code + instr + 1);
     }

Modified: harmony/enhanced/drlvm/trunk/vm/vmcore/src/verifier-3363/java6/context_6.cpp
URL: http://svn.apache.org/viewvc/harmony/enhanced/drlvm/trunk/vm/vmcore/src/verifier-3363/java6/context_6.cpp?rev=658384&r1=658383&r2=658384&view=diff
==============================================================================
--- harmony/enhanced/drlvm/trunk/vm/vmcore/src/verifier-3363/java6/context_6.cpp (original)
+++ harmony/enhanced/drlvm/trunk/vm/vmcore/src/verifier-3363/java6/context_6.cpp Tue May 20 11:38:23 2008
@@ -193,7 +193,7 @@
 vf_Result vf_Context_6::load_stackmaptable() {
     vf_Result tcr;
 
-    Byte* stackmaptable = method_get_stackmaptable(m_method);
+    U_8* stackmaptable = method_get_stackmaptable(m_method);
 
 #ifndef _NDEBUG
     if (substitution) stackmaptable = substitution;
@@ -201,13 +201,13 @@
 
     if(!stackmaptable) return VF_OK;
 
-    Byte* read_ptr = stackmaptable;
+    U_8* read_ptr = stackmaptable;
 
     read_ptr+=2; //skip uint16 attribute_name_index
 
     uint32 attribute_length = read_uint32(read_ptr); 
     read_ptr+=4;
-    Byte *attribute_end = stackmaptable + attribute_length + 6;
+    U_8* attribute_end = stackmaptable + attribute_length + 6;
 
     if( read_ptr + 2 > attribute_end ) return error(VF_ErrorStackmap, "corrupted StackMapTable");
     uint16 number_of_entries = read_uint16(read_ptr);
@@ -373,8 +373,8 @@
  * the specified element. If Long or Double happens in StackMapTable, record SM_HIGH_WORD after SM_LONG or SM_DOUBLE
  * to the workmap and increase cnt. Check space_available when record to the workmap
  */
-vf_Result vf_Context_6::read_types(Byte **attr, Byte *end, WorkmapElement_6* element,
-                                   unsigned *cnt, unsigned space_available) {
+vf_Result vf_Context_6::read_types(U_8** attr, U_8* end, WorkmapElement_6* element,
+                                   unsigned* cnt, unsigned space_available) {
     uint16 idx = 0;
     //read (*cnt) types
     while( idx < *cnt ) {

Modified: harmony/enhanced/drlvm/trunk/vm/vmcore/src/verifier-3363/java6/context_6.h
URL: http://svn.apache.org/viewvc/harmony/enhanced/drlvm/trunk/vm/vmcore/src/verifier-3363/java6/context_6.h?rev=658384&r1=658383&r2=658384&view=diff
==============================================================================
--- harmony/enhanced/drlvm/trunk/vm/vmcore/src/verifier-3363/java6/context_6.h (original)
+++ harmony/enhanced/drlvm/trunk/vm/vmcore/src/verifier-3363/java6/context_6.h Tue May 20 11:38:23 2008
@@ -64,7 +64,7 @@
     //Read cnt types from a row bytearray representing StackMapTable and record to workmap starting at 
     //the specified element. If Long or Double happens in StackMapTable, record SM_HIGH_WORD after SM_LONG or SM_DOUBLE
     //to the workmap and increase cnt. Check space_available when record to the workmap
-    vf_Result read_types(Byte **attr, Byte *end, WorkmapElement_6* element, unsigned *cnt, unsigned space_available);
+    vf_Result read_types(U_8** attr, U_8* end, WorkmapElement_6* element, unsigned* cnt, unsigned space_available);
 
     ///////////////////////////////////  "VIRTUAL" METHODS /////////////////////////////////////////////
 public:
@@ -140,7 +140,7 @@
 
     //recomputed stack map used for testing
 #ifndef _NDEBUG
-    Byte *substitution;
+    U_8* substitution;
 #endif
 };