scylladb / scylla-jmx

Scylla JMX proxy
GNU Affero General Public License v3.0
28 stars 51 forks source link

ccm fails to start a node because connection to jmx cannot be established (JMX crashes with SIGSEGV) #194

Closed gleb-cloudius closed 1 year ago

gleb-cloudius commented 1 year ago

Seen in CI:

https://jenkins.scylladb.com/job/releng/job/Scylla-CI/4555/testReport/junit/cdc_test/TestCdc/Sanity_Tests___test_change_field_type_with_cdc_Single_cluster_/

self = <cdc_test.TestCdc object at 0x7f9ab9f9d0d0>
request = <FixtureRequest for <Function test_change_field_type_with_cdc[Single_cluster]>>
cluster_config = ClusterConfig(size=[3], replication="{'class': 'SimpleStrategy', 'replication_factor': 3}")

    @pytest.mark.next_gating
    def test_change_field_type_with_cdc(self, request, cluster_config):
>       self.schema_change_template(request, "ALTER TABLE ks.cf ALTER b TYPE blob",
                                    cluster_size=cluster_config.size, replication=cluster_config.replication)

cdc_test.py:449: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
cdc_test.py:414: in schema_change_template
    self.populate_sequentially(n=cluster_size)
cdc_test.py:76: in populate_sequentially
    node.start(wait_for_binary_proto=True, wait_other_notice=wait_other_notice)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <ccmlib.scylla_node.ScyllaNode object at 0x7f9ae4466410>
join_ring = True, no_wait = False, verbose = False, update_pid = True
wait_other_notice = False, replace_token = None, replace_address = None
replace_node_host_id = None
jvm_args = ['--api-address', '127.0.40.2', '--collectd-hostname', '05767ff5161b.node2']
wait_for_binary_proto = True, profile_options = None, use_jna = False
quiet_start = False

    def start(self, join_ring=True, no_wait=False, verbose=False,
              update_pid=True, wait_other_notice=None, replace_token=None,
              replace_address=None, replace_node_host_id=None, jvm_args=None, wait_for_binary_proto=None,
              profile_options=None, use_jna=False, quiet_start=False):
        """
        Start the node. Options includes:
          - join_ring: if false, start the node with -Dcassandra.join_ring=False
          - no_wait: by default, this method returns when the node is started
            and listening to clients.
            If no_wait=True, the method returns sooner.
          - wait_other_notice: if True, this method returns only when all other
            live node of the cluster
            have marked this node UP.
          - replace_token: start the node with the -Dcassandra.replace_token
            option.
          - replace_node_host_id: start the node with the
            --replace-node-first-boot option to replace a given node
            identified by its host_id.
          - replace_address: start the node with the deprecated
            --replace-address option.

        Extra command line options may be passed using the
        SCYLLA_EXT_OPTS environment variable.

        Extra environment variables for running scylla can be passed using the
        SCYLLA_EXT_ENV environment variable.
        Those are represented in a single string comprised of one or more
        pairs of "var=value" separated by either space or semicolon (';')
        """
        if wait_for_binary_proto is None:
            wait_for_binary_proto = self.cluster.force_wait_for_cluster_start and not no_wait
        if wait_other_notice is None:
            wait_other_notice = self.cluster.force_wait_for_cluster_start and not no_wait
        if jvm_args is None:
            jvm_args = []

        scylla_cassandra_mapping = {'-Dcassandra.replace_address_first_boot':
                                    '--replace-address-first-boot'}
        # Replace args in the form
        # ['-Dcassandra.foo=bar'] to ['-Dcassandra.foo', 'bar']
        translated_args = []
        new_jvm_args = []
        for jvm_arg in jvm_args:
            if '=' in jvm_arg:
                split_option = jvm_arg.split("=")
                e_msg = ("Option %s not in the form '-Dcassandra.foo=bar'. "
                         "Please check your test" % jvm_arg)
                assert len(split_option) == 2, e_msg
                option, value = split_option
                # If we have information on how to translate the jvm option,
                # translate it
                if option in scylla_cassandra_mapping:
                    translated_args += [scylla_cassandra_mapping[option],
                                        value]
                # Otherwise, just pass it as is
                else:
                    new_jvm_args.append(jvm_arg)
            else:
                new_jvm_args.append(jvm_arg)
        jvm_args = new_jvm_args

        if self.is_running():
            raise NodeError("%s is already running" % self.name)

        if not self.is_docker():
            for itf in list(self.network_interfaces.values()):
                if itf is not None and replace_address is None:
                    try:
                        common.check_socket_available(itf)
                    except Exception as msg:
                        print("{}. Looking for offending processes...".format(msg))
                        for proc in psutil.process_iter():
                            if any(self.cluster.ipprefix in cmd for cmd in proc.cmdline()):
                                print("name={} pid={} cmdline={}".format(proc.name(), proc.pid, proc.cmdline()))
                        raise msg

        marks = []
        if wait_other_notice:
            marks = [(node, node.mark_log()) for node in
                     list(self.cluster.nodes.values()) if node.is_live()]

        self.mark = self.mark_log()

        launch_bin = common.join_bin(self.get_path(), BIN_DIR, 'scylla')
        options_file = os.path.join(self.get_path(), 'conf', 'scylla.yaml')

        # TODO: we do not support forcing specific settings
        # TODO: workaround for api-address as we do not load it
        # from config file scylla#59
        conf_file = os.path.join(self.get_conf_dir(), common.SCYLLA_CONF)
        with open(conf_file, 'r') as f:
            data = yaml.safe_load(f)
        jvm_args = jvm_args + ['--api-address', data['api_address']]
        jvm_args = jvm_args + ['--collectd-hostname',
                               '%s.%s' % (socket.gethostname(), self.name)]

        # Let's add jvm_args and the translated args

        args = [launch_bin, '--options-file', options_file, '--log-to-stdout', '1'] + jvm_args + translated_args

        # Lets search for default overrides in SCYLLA_EXT_OPTS
        scylla_ext_opts = os.getenv('SCYLLA_EXT_OPTS', "").split()
        opts_i = 0
        orig_args = list(args)
        while opts_i < len(scylla_ext_opts):
            if scylla_ext_opts[opts_i].startswith("--scylla-manager="):
               opts_i += 1
            elif scylla_ext_opts[opts_i].startswith('-'):
                o = scylla_ext_opts[opts_i]
                opts_i += 1
                if '=' in o:
                    opt = o.replace('=', ' ', 1).split()
                else:
                    opt = [ o ]
                    while opts_i < len(scylla_ext_opts) and not scylla_ext_opts[opts_i].startswith('-'):
                        opt.append(scylla_ext_opts[opts_i])
                        opts_i += 1
                if opt[0] not in orig_args:
                    args.extend(opt)

        if '--developer-mode' not in args:
            args += ['--developer-mode', 'true']
        if '--smp' not in args:
            # If --smp is not passed from cmdline, use default (--smp 1)
            args += ['--smp', str(self._smp)]
        elif self._smp_set_during_test:
            # If node.set_smp() is called during the test, ignore the --smp
            # passed from the cmdline.
            args[args.index('--smp') + 1] = str(self._smp)
        else:
            # Update self._smp based on command line parameter.
            # It may be used below, along with self._mem_mb_per_cpu, for calculating --memory
            self._smp = int(args[args.index('--smp') + 1])
        if '--memory' not in args:
            # If --memory is not passed from cmdline, use default (512M per cpu)
            args += ['--memory', '{}M'.format(self._mem_mb_per_cpu * self._smp)]
        elif self._mem_set_during_test:
            # If node.set_mem_mb_per_cpu() is called during the test, ignore the --memory
            # passed from the cmdline.
            args[args.index('--memory') + 1] = '{}M'.format(self._mem_mb_per_cpu * self._smp)
        self._memory = self.parse_size(args[args.index('--memory') + 1])
        if '--default-log-level' not in args:
            args += ['--default-log-level', self.__global_log_level]
        if self.scylla_mode() == 'debug' and '--blocked-reactor-notify-ms' not in args:
            args += ['--blocked-reactor-notify-ms', '5000']
        # TODO add support for classes_log_level
        if '--collectd' not in args:
            args += ['--collectd', '0']
        if '--cpuset' not in args:
            args += ['--overprovisioned']
        if '--prometheus-address' not in args:
            args += ['--prometheus-address', data['api_address']]
        if replace_node_host_id:
            assert replace_address is None, "replace_node_host_id and replace_address cannot be specified together"
            args += ['--replace-node-first-boot', replace_node_host_id]
        elif replace_address:
            args += ['--replace-address', replace_address]
        args += ['--unsafe-bypass-fsync', '1']

        current_node_version = self.node_install_dir_version() or self.cluster.version()
        current_node_is_enterprise = parse_version(current_node_version) > parse_version("2018.1")

        # The '--kernel-page-cache' was introduced by
        # https://github.com/scylladb/scylla/commit/8785dd62cb740522d80eb12f8272081f85be9b7e from 4.5 version
        # and 2022.1 Enterprise version
        kernel_page_cache_supported = not current_node_is_enterprise and parse_version(current_node_version) >= parse_version('4.5.dev')
        kernel_page_cache_supported |= current_node_is_enterprise and parse_version(current_node_version) >= parse_version('2022.1.dev')
        if kernel_page_cache_supported and '--kernel-page-cache' not in args:
            args += ['--kernel-page-cache', '1']
        commitlog_o_dsync_supported = (
            (not current_node_is_enterprise and parse_version(current_node_version) >= parse_version('3.2'))
            or (current_node_is_enterprise and parse_version(current_node_version) >= parse_version('2020.1'))
            )
        if commitlog_o_dsync_supported:
            args += ['--commitlog-use-o-dsync', '0']

        # The '--max-networking-io-control-blocks' was introduced by
        # https://github.com/scylladb/scylla/commit/2cfc517874e98c5780c1b1b4c38440a8123f86f6 from 4.6 version
        # and 2022.1 Enterprise version
        max_networking_io_control_blocks_supported = not current_node_is_enterprise and parse_version(current_node_version) >= parse_version('4.6')
        max_networking_io_control_blocks_supported |= current_node_is_enterprise and parse_version(current_node_version) >= parse_version('2022.1.dev')
        if max_networking_io_control_blocks_supported and '--max-networking-io-control-blocks' not in args:
            args += ['--max-networking-io-control-blocks', '1000']

        ext_env = {}
        scylla_ext_env = os.getenv('SCYLLA_EXT_ENV', "").strip()
        if scylla_ext_env:
            scylla_ext_env = re.split(r'[; ]', scylla_ext_env)
            for s in scylla_ext_env:
                try:
                    [k, v] = s.split('=', 1)
                except ValueError as e:
                    print("Bad SCYLLA_EXT_ENV variable: {}: {}", s, e)
                else:
                    ext_env[k] = v

        message = "Starting scylla: args={} wait_other_notice={} wait_for_binary_proto={}".format(args, wait_other_notice, wait_for_binary_proto)
        self.debug(message)

        scylla_process = self._start_scylla(args, marks, update_pid,
                                            wait_other_notice,
                                            wait_for_binary_proto,
                                            ext_env)
        self._start_jmx(data)

        ip_addr, _ = self.network_interfaces['storage']
        jmx_port = int(self.jmx_port)
        if not self._wait_java_up(ip_addr, jmx_port):
            e_msg = "Error starting node {}: unable to connect to scylla-jmx port {}:{}".format(
                     self.name, ip_addr, jmx_port)
>           raise NodeError(e_msg, scylla_process)
E           ccmlib.node.NodeError: Error starting node node2: unable to connect to scylla-jmx port 127.0.40.2:7199

../scylla/.local/lib/python3.11/site-packages/ccmlib/scylla_node.py:650: NodeError
mykaul commented 1 year ago

On node 2, we can see the following log:

Starting scylla-jmx: args=['/jenkins/workspace/releng/Scylla-CI/scylla/.dtest/dtest-576y7cmy/test/node2/bin/symlinks/scylla-jmx', '-Dapiaddress=127.0.40.2', '-Djavax.management.builder.initial=com.scylladb.jmx.utils.APIBuilder', '-Djava.rmi.server.hostname=127.0.40.2', '-Dcom.sun.management.jmxremote', '-Dcom.sun.management.jmxremote.host=127.0.40.2', '-Dcom.sun.management.jmxremote.port=7199', '-Dcom.sun.management.jmxremote.rmi.port=7199', '-Dcom.sun.management.jmxremote.local.only=false', '-Xmx256m', '-XX:+UseSerialGC', '-Dcom.sun.management.jmxremote.authenticate=false', '-Dcom.sun.management.jmxremote.ssl=false', '-jar', '/jenkins/workspace/releng/Scylla-CI/scylla/.dtest/dtest-576y7cmy/test/node2/bin/scylla-jmx-1.0.jar']
#
# A fatal error has been detected by the Java Runtime Environment:
#
#  SIGSEGV (0xb) at pc=0x00007f5b19fc92a0, pid=43287, tid=0x00007f5b0417d6c0
#
# JRE version: OpenJDK Runtime Environment (8.0_352-b08) (build 1.8.0_352-b08)
# Java VM: OpenJDK 64-Bit Server VM (25.352-b08 mixed mode linux-amd64 compressed oops)
# Problematic frame:
# V  [libjvm.so+0xb222a0]  StubCodeDesc::desc_for(unsigned char*)+0x10
#
# Core dump written. Default location: /jenkins/workspace/releng/Scylla-CI/scylla-dtest/core or core.43287
#
# An error report file with more information is saved as:
# /jenkins/workspace/releng/Scylla-CI/scylla-dtest/hs_err_pid43287.log
#
# Compiler replay data is saved as:
# /jenkins/workspace/releng/Scylla-CI/scylla-dtest/replay_pid43287.log
#
mykaul commented 1 year ago

@yaronkaikov - is there a way we can still get the logs and/or the coredump?

yaronkaikov commented 1 year ago

We have the logs https://jenkins.scylladb.com/job/releng/job/Scylla-CI/4555/artifact/

mykaul commented 1 year ago

/jenkins/workspace/releng/Scylla-CI/scylla-dtest/core or core.43287

?

nyh commented 1 year ago

@mykaul are you planning to debug the JRE? :-) Maybe this is https://bugs.openjdk.org/browse/JDK-8138922, fixed in the JRE 9, while we are using the antediluvian JRE 8? BTW even JRE 8 has newer versions, maybe we can update?

mykaul commented 1 year ago

@mykaul are you planning to debug the JRE? :-) Maybe this is https://bugs.openjdk.org/browse/JDK-8138922, fixed in the JRE 9, while we are using the antediluvian JRE 8? BTW even JRE 8 has newer versions, maybe we can update?

I was hoping to find something, yes. There is more than one option:

  1. Newer, albeit not in Ubuntu, OpenJDK 8 (https://mail.openjdk.org/pipermail/jdk8u-dev/2023-January/016479.html)
  2. We can and probably should at some point use a substantially more modern Java... I don't remember even where it's mentioned, but I have it somewhere in the roadmap
  3. Replace this component with a re-write , in a different lang...
nyh commented 1 year ago

I don't know if newer OpenJDK 8 would have this bug fixed. In fact I doubt it (see release notes in https://bugs.openjdk.org/browse/JDK-8138922). OpenJDK 8 was released 9 years ago (I have a child younger than that ;-)), and support for it ended officially a year ago (they are still doing security patches, but ONLY that).

As I noted in another thread, Cassandra already works correctly on OpenJDK 11 (see test/cql-pytest/run-cassandra for some configuration hacks needed to get it to run properly) so I'm pretty sure that JMX should run there as well. OpenJDK 11 will also reach end of life later this year (!), so hopefully Cassandra will get their act together by then (Cassandra can't run on recent OpenJDK), but even if not, I assume it will be much easier to get just JMX to run than the full Cassandra.

denesb commented 1 year ago

3. Replace this component with a re-write , in a different lang...

We only need to rewrite nodetool in a different lang, for which there were several proposals over the years. That is the only user of JMX (well some users might use it directly, inheriting their dependence on it from C*).

gleb-cloudius commented 1 year ago

May be we can workaround it in ccm? If jmx start fails try one more time.

bhalevy commented 1 year ago

Cc @tchaikov

bhalevy commented 1 year ago

@fruch is scylla-jmx crashing in https://github.com/scylladb/scylla-dtest/issues/3007 related to this issue?

fruch commented 1 year ago

@fruch is scylla-jmx crashing in https://github.com/scylladb/scylla-dtest/issues/3007 related to this issue?

Yes seems the same crash

tchaikov commented 1 year ago

Cc @tchaikov

it seems this is different from the one i am trying fix at #193. the crash came from JRE 8.0.

bhalevy commented 1 year ago

Seen again in https://jenkins.scylladb.com/view/master/job/scylla-master/job/dtest-daily-release/212/artifact/logs-full.release.000/1678258812240_sstableloader_test.py%3A%3ATestMigrationWith%3A%3Atest_migrate_sstable_with_cell_tombstone%5B-3_0_md%5D/node1_system.log.jmx

Starting scylla-jmx: args=['/jenkins/workspace/scylla-master/dtest-daily-release/scylla/.dtest/dtest-2pzsnl3j/test/node1/bin/symlinks/scylla-jmx', '-Dapiaddress=127.0.6.1', '-Djavax.management.builder.initial=com.scylladb.jmx.utils.APIBuilder', '-Djava.rmi.server.hostname=127.0.6.1', '-Dcom.sun.management.jmxremote', '-Dcom.sun.management.jmxremote.host=127.0.6.1', '-Dcom.sun.management.jmxremote.port=7199', '-Dcom.sun.management.jmxremote.rmi.port=7199', '-Dcom.sun.management.jmxremote.local.only=false', '-Xmx256m', '-XX:+UseSerialGC', '-Dcom.sun.management.jmxremote.authenticate=false', '-Dcom.sun.management.jmxremote.ssl=false', '-jar', '/jenkins/workspace/scylla-master/dtest-daily-release/scylla/.dtest/dtest-2pzsnl3j/test/node1/bin/scylla-jmx-1.0.jar']
#
# A fatal error has been detected by the Java Runtime Environment:
#
#  SIGSEGV (0xb) at pc=0x00007f0d9bd9d2a0, pid=255567, tid=0x00007f0d98f7d6c0
#
# JRE version: OpenJDK Runtime Environment (8.0_352-b08) (build 1.8.0_352-b08)
# Java VM: OpenJDK 64-Bit Server VM (25.352-b08 mixed mode linux-amd64 compressed oops)
# Problematic frame:
# V  [libjvm.so+0xb222a0]  StubCodeDesc::desc_for(unsigned char*)+0x10
#
# Core dump written. Default location: /jenkins/workspace/scylla-master/dtest-daily-release/scylla-dtest/core or core.255567
#
# An error report file with more information is saved as:
# /jenkins/workspace/scylla-master/dtest-daily-release/scylla-dtest/hs_err_pid255567.log
#
# Compiler replay data is saved as:
# /jenkins/workspace/scylla-master/dtest-daily-release/scylla-dtest/replay_pid255567.log
#
# If you would like to submit a bug report, please visit:
#   https://bugzilla.redhat.com/enter_bug.cgi?product=Fedora&component=java-1.8.0-openjdk&version=37
#
bhalevy commented 1 year ago

@yaronkaikov can we collect cores and crash logs like mentioned above from the split workers?

yaronkaikov commented 1 year ago

@bhalevy What do you want us to upload?

bhalevy commented 1 year ago

The core dump to start with, from

# Core dump written. Default location: /jenkins/workspace/scylla-master/dtest-daily-release/scylla-dtest/core or core.255567

And those logs, if possible:

# An error report file with more information is saved as:
# /jenkins/workspace/scylla-master/dtest-daily-release/scylla-dtest/hs_err_pid255567.log
#
# Compiler replay data is saved as:
# /jenkins/workspace/scylla-master/dtest-daily-release/scylla-dtest/replay_pid255567.log
fruch commented 1 year ago

The core dump to start with, from

# Core dump written. Default location: /jenkins/workspace/scylla-master/dtest-daily-release/scylla-dtest/core or core.255567

And those logs, if possible:

# An error report file with more information is saved as:
# /jenkins/workspace/scylla-master/dtest-daily-release/scylla-dtest/hs_err_pid255567.log
#
# Compiler replay data is saved as:
# /jenkins/workspace/scylla-master/dtest-daily-release/scylla-dtest/replay_pid255567.log

@bhalevy, I think this might take care of it: https://github.com/scylladb/scylla-dtest/pull/3081

bhalevy commented 1 year ago

thanks

bhalevy commented 1 year ago

We now have the coredump and vm log in https://jenkins.scylladb.com/job/releng/job/Scylla-CI/4915/artifact/logs-gating.release.2/1678736239682_repair_additional_test.py%3A%3ATestRepairAdditional%3A%3Atest_repair_joint_row_3nodes_2/

fruch commented 1 year ago

We now have the coredump and vm log in https://jenkins.scylladb.com/job/releng/job/Scylla-CI/4915/artifact/logs-gating.release.2/1678736239682_repair_additional_test.py%3A%3ATestRepairAdditional%3A%3Atest_repair_joint_row_3nodes_2/

looks like just the logs, no coredump file. I'm guessing it might need some time before it's available. Anyhow I hope that would be enough to figure it out...

tchaikov commented 1 year ago

updated #193 in hope to alleviate this pain.

bhalevy commented 1 year ago

Still happens with scylladb/scylla-jmx@48e16998d92965efe9e7e311e5ad15de6bfdb497

https://jenkins.scylladb.com/view/master/job/scylla-master/job/next/5866/artifact/dtest-raft/logs-full.release.000/1681101392880_replace_address_test.py%3A%3ATestReplaceAddress%3A%3Atest_replace_active_node%5Buse_host_id-rbo_disabled%5D/hs_err_pid34074.log

#
# A fatal error has been detected by the Java Runtime Environment:
#
#  SIGSEGV (0xb) at pc=0x00007f1d153492a0, pid=34074, tid=0x00007f1cf34f56c0
#
# JRE version: OpenJDK Runtime Environment (8.0_352-b08) (build 1.8.0_352-b08)
# Java VM: OpenJDK 64-Bit Server VM (25.352-b08 mixed mode linux-amd64 compressed oops)
# Problematic frame:
# V  [libjvm.so+0xb222a0]  StubCodeDesc::desc_for(unsigned char*)+0x10
#
# Core dump written. Default location: /jenkins/workspace/scylla-master/gating-dtest-release/scylla-dtest/core or core.34074
#
# If you would like to submit a bug report, please visit:
#   https://bugzilla.redhat.com/enter_bug.cgi?product=Fedora&component=java-1.8.0-openjdk&version=37
#

---------------  T H R E A D  ---------------

Current thread (0x00007f1d1015f000):  JavaThread "C1 CompilerThread10" daemon [_thread_in_native, id=34091, stack(0x00007f1cf33f6000,0x00007f1cf34f6000)]

siginfo: si_signo: 11 (SIGSEGV), si_code: 1 (SEGV_MAPERR), si_addr: 0x00000007f1d10195

Registers:
RAX=0x00000007f1d10175, RBX=0x00007f1cf34f4830, RCX=0x00007f1cbc0068ec, RDX=0x00007f1cf34f4370
RSP=0x00007f1cf34f4258, RBP=0x00007f1cf34f4290, RSI=0x00007f1cf34f4830, RDI=0x00007f1d154664d2
R8 =0x0000000000000000, R9 =0x0000000000000000, R10=0x000000000000000f, R11=0x0000000000000081
R12=0x00007f1cf34f4370, R13=0x00007f1cbc0068b4, R14=0x00007f1d154664d2, R15=0x00007f1d156f0e55
RIP=0x00007f1d153492a0, EFLAGS=0x0000000000010202, CSGSFS=0x002b000000000033, ERR=0x0000000000000004
  TRAPNO=0x000000000000000e

Top of Stack: (sp=0x00007f1cf34f4258)
0x00007f1cf34f4258:   00007f1d152843a4 00007f1d010eff3b
0x00007f1cf34f4268:   00007f1cf34f4830 00007f1cbc0068b2
0x00007f1cf34f4278:   00007f1cbc0068b4 00007f1d010efee5
0x00007f1cf34f4288:   00007f1d156f0e55 00007f1cf34f42c0
0x00007f1cf34f4298:   00007f1d15284f78 00007f1d154664d2
0x00007f1cf34f42a8:   00007f1cbc006620 00007f1d154664d2
0x00007f1cf34f42b8:   00007f1cf34f4330 00007f1cf34f42e0
0x00007f1cf34f42c8:   00007f1d14b41048 00007f1cbc006620
0x00007f1cf34f42d8:   00007f1cf34f4370 00007f1cf34f43d0
0x00007f1cf34f42e8:   00007f1d1510557e 00007f1cf34f43a0
0x00007f1cf34f42f8:   fffffffffff7e17b 00007f1cf34f4330
0x00007f1cf34f4308:   00007f1d14b2cfa2 0000000000000000
0x00007f1cf34f4318:   00007f1cbc006620 0000000000000000
0x00007f1cf34f4328:   00007f1cbc006620 00007f1d1562d4f8
0x00007f1cf34f4338:   0000000000000000 00007f1d154664d2
0x00007f1cf34f4348:   0000000000000000 0000000000000000
0x00007f1cf34f4358:   00007f1cbc006600 00007f1d154664d2
0x00007f1cf34f4368:   00007f1d14bb9b55 00007f1d1562d4f8
0x00007f1cf34f4378:   0000000000000000 00007f1d154664d2
0x00007f1cf34f4388:   0000000000000000 0000000000000000
0x00007f1cf34f4398:   00007f1cbc006600 00007f1d154664d2
0x00007f1cf34f43a8:   7dac7595cfe62400 00007f1cf34f4450
0x00007f1cf34f43b8:   0000000000000000 00007f1cbc006620
0x00007f1cf34f43c8:   00007f1d1548f824 00007f1cf34f4440
0x00007f1cf34f43d8:   00007f1d14bbce69 00007f1d15632250
0x00007f1cf34f43e8:   0000000000000000 0000000000000000
0x00007f1cf34f43f8:   0000000000000000 0000000000000000
0x00007f1cf34f4408:   00007f1d14bb9800 00007f1d0106e060
0x00007f1cf34f4418:   7dac7595cfe62400 00007f1cf34f4450
0x00007f1cf34f4428:   00007f1cf34f46c0 00007f1cf34f4450
0x00007f1cf34f4438:   00007f1cf34f46c0 00007f1cf34f44e0
0x00007f1cf34f4448:   00007f1d14b8880e 00007f1cbc006620 

Instructions: (pc=0x00007f1d153492a0)
0x00007f1d15349280:   00 00 31 f6 e8 e7 05 6f ff eb c3 e8 d0 00 6f ff
0x00007f1d15349290:   f3 0f 1e fa 48 8b 05 d5 52 3b 00 48 85 c0 74 0c
0x00007f1d153492a0:   48 3b 78 20 72 0a 48 3b 78 28 73 04 c3 0f 1f 00
0x00007f1d153492b0:   48 8b 00 48 85 c0 75 e8 c3 90 66 0f 1f 44 00 00 

Register to memory mapping:

RAX=0x00000007f1d10175 is an unknown value
RBX=0x00007f1cf34f4830 is pointing into the stack for thread: 0x00007f1d1015f000
RCX=0x00007f1cbc0068ec is an unknown value
RDX=0x00007f1cf34f4370 is pointing into the stack for thread: 0x00007f1d1015f000
RSP=0x00007f1cf34f4258 is pointing into the stack for thread: 0x00007f1d1015f000
RBP=0x00007f1cf34f4290 is pointing into the stack for thread: 0x00007f1d1015f000
RSI=0x00007f1cf34f4830 is pointing into the stack for thread: 0x00007f1d1015f000
RDI=0x00007f1d154664d2: <offset 0xc3f4d2> in /usr/lib/jvm/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/jre/lib/amd64/server/libjvm.so at 0x00007f1d14827000
R8 =0x0000000000000000 is an unknown value
R9 =0x0000000000000000 is an unknown value
R10=0x000000000000000f is an unknown value
R11=0x0000000000000081 is an unknown value
R12=0x00007f1cf34f4370 is pointing into the stack for thread: 0x00007f1d1015f000
R13=0x00007f1cbc0068b4 is an unknown value
R14=0x00007f1d154664d2: <offset 0xc3f4d2> in /usr/lib/jvm/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/jre/lib/amd64/server/libjvm.so at 0x00007f1d14827000
R15=0x00007f1d156f0e55: <offset 0xec9e55> in /usr/lib/jvm/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/jre/lib/amd64/server/libjvm.so at 0x00007f1d14827000

Stack: [0x00007f1cf33f6000,0x00007f1cf34f6000],  sp=0x00007f1cf34f4258,  free space=1016k
Native frames: (J=compiled Java code, j=interpreted, Vv=VM code, C=native code)
V  [libjvm.so+0xb222a0]  StubCodeDesc::desc_for(unsigned char*)+0x10
V  [libjvm.so+0xa5df78]  relocInfo::initialize(CodeSection*, Relocation*)+0x28
V  [libjvm.so+0x31a048]  Assembler::mov_literal64(RegisterImpl*, long, RelocationHolder const&)+0x58
V  [libjvm.so+0x8de57e]  MacroAssembler::stop(char const*)+0x9e
V  [libjvm.so+0x395e69]  LIR_Assembler::emit_exception_handler()+0xb9
V  [libjvm.so+0x36180e]  Compilation::emit_code_body()+0x19e
V  [libjvm.so+0x361c8d]  Compilation::compile_java_method()+0x3cd
V  [libjvm.so+0x361e09]  Compilation::compile_method()+0x59
V  [libjvm.so+0x362238]  Compilation::Compilation(AbstractCompiler*, ciEnv*, ciMethod*, int, BufferBlob*)+0x228
V  [libjvm.so+0x362a81]  Compiler::compile_method(ciEnv*, ciMethod*, int)+0xd1
V  [libjvm.so+0x4bd95e]  CompileBroker::invoke_compiler_on_method(CompileTask*)+0x93e
V  [libjvm.so+0x4bf018]  CompileBroker::compiler_thread_loop()+0x528
V  [libjvm.so+0xb98e06]  JavaThread::thread_main_inner()+0x246
V  [libjvm.so+0x9cb882]  java_start(Thread*)+0x162
C  [libc.so.6+0x8b14d]  start_thread+0x2cd

Current CompileTask:
C1:     48    1       3       java.lang.String::hashCode (55 bytes)

---------------  P R O C E S S  ---------------

Java Threads: ( => current thread )
  0x00007f1d1016c000 JavaThread "Service Thread" daemon [_thread_blocked, id=34096, stack(0x00007f1cf2ef1000,0x00007f1cf2ff1000)]
  0x00007f1d10167000 JavaThread "C1 CompilerThread14" daemon [_thread_in_native, id=34095, stack(0x00007f1cf2ff2000,0x00007f1cf30f2000)]
  0x00007f1d10165000 JavaThread "C1 CompilerThread13" daemon [_thread_blocked, id=34094, stack(0x00007f1cf30f3000,0x00007f1cf31f3000)]
  0x00007f1d10163000 JavaThread "C1 CompilerThread12" daemon [_thread_blocked, id=34093, stack(0x00007f1cf31f4000,0x00007f1cf32f4000)]
  0x00007f1d10161000 JavaThread "C1 CompilerThread11" daemon [_thread_blocked, id=34092, stack(0x00007f1cf32f5000,0x00007f1cf33f5000)]
=>0x00007f1d1015f000 JavaThread "C1 CompilerThread10" daemon [_thread_in_native, id=34091, stack(0x00007f1cf33f6000,0x00007f1cf34f6000)]
  0x00007f1d1015c000 JavaThread "C2 CompilerThread9" daemon [_thread_blocked, id=34090, stack(0x00007f1cf34f7000,0x00007f1cf35f7000)]
  0x00007f1d1015a800 JavaThread "C2 CompilerThread8" daemon [_thread_blocked, id=34089, stack(0x00007f1cf35f8000,0x00007f1cf36f8000)]
  0x00007f1d10158000 JavaThread "C2 CompilerThread7" daemon [_thread_blocked, id=34088, stack(0x00007f1cf36f9000,0x00007f1cf37f9000)]
  0x00007f1d10156000 JavaThread "C2 CompilerThread6" daemon [_thread_blocked, id=34087, stack(0x00007f1cf37fa000,0x00007f1cf38fa000)]
  0x00007f1d10154000 JavaThread "C2 CompilerThread5" daemon [_thread_blocked, id=34086, stack(0x00007f1cf38fb000,0x00007f1cf39fb000)]
  0x00007f1d10151800 JavaThread "C2 CompilerThread4" daemon [_thread_blocked, id=34085, stack(0x00007f1cf39fc000,0x00007f1cf3afc000)]
  0x00007f1d10147800 JavaThread "C2 CompilerThread3" daemon [_thread_blocked, id=34084, stack(0x00007f1cf3afd000,0x00007f1cf3bfd000)]
  0x00007f1d10145800 JavaThread "C2 CompilerThread2" daemon [_thread_blocked, id=34083, stack(0x00007f1cf3bfe000,0x00007f1cf3cfe000)]
  0x00007f1d10143000 JavaThread "C2 CompilerThread1" daemon [_thread_blocked, id=34082, stack(0x00007f1cf3cff000,0x00007f1cf3dff000)]
  0x00007f1d10141800 JavaThread "C2 CompilerThread0" daemon [_thread_blocked, id=34081, stack(0x00007f1cf3e00000,0x00007f1cf3f00000)]
  0x00007f1d10133000 JavaThread "Signal Dispatcher" daemon [_thread_blocked, id=34080, stack(0x00007f1cf3f00000,0x00007f1cf4000000)]
  0x00007f1d10103000 JavaThread "Finalizer" daemon [_thread_blocked, id=34079, stack(0x00007f1d002e0000,0x00007f1d003e0000)]
  0x00007f1d100fe800 JavaThread "Reference Handler" daemon [_thread_blocked, id=34078, stack(0x00007f1d003e0000,0x00007f1d004e0000)]
  0x00007f1d1004c000 JavaThread "main" [_thread_in_Java, id=34076, stack(0x00007f1d14647000,0x00007f1d14747000)]

Other Threads:
  0x00007f1d100f4800 VMThread [stack: 0x00007f1d004e1000,0x00007f1d005e1000] [id=34077]

VM state:not at safepoint (normal execution)

VM Mutex/Monitor currently owned by a thread: None

heap address: 0x00000000f0000000, size: 256 MB, Compressed Oops mode: 32-bit
Narrow klass base: 0x0000000000000000, Narrow klass shift: 3
Compressed class space size: 1073741824 Address: 0x0000000100000000

Heap:
 def new generation   total 78656K, used 1399K [0x00000000f0000000, 0x00000000f5550000, 0x00000000f5550000)
  eden space 69952K,   2% used [0x00000000f0000000, 0x00000000f015dc38, 0x00000000f4450000)
  from space 8704K,   0% used [0x00000000f4450000, 0x00000000f4450000, 0x00000000f4cd0000)
  to   space 8704K,   0% used [0x00000000f4cd0000, 0x00000000f4cd0000, 0x00000000f5550000)
 tenured generation   total 174784K, used 0K [0x00000000f5550000, 0x0000000100000000, 0x0000000100000000)
   the space 174784K,   0% used [0x00000000f5550000, 0x00000000f5550000, 0x00000000f5550200, 0x0000000100000000)
 Metaspace       used 2871K, capacity 4480K, committed 4480K, reserved 1056768K
  class space    used 275K, capacity 384K, committed 384K, reserved 1048576K

Card table byte_map: [0x00007f1d1415e000,0x00007f1d141df000] byte_map_base: 0x00007f1d139de000

Polling page: 0x00007f1d15956000

CodeCache: size=245760Kb used=3367Kb max_used=3367Kb free=242392Kb
 bounds [0x00007f1d01000000, 0x00007f1d01350000, 0x00007f1d10000000]
 total_blobs=250 nmethods=16 adapters=144
 compilation: enabled

Compilation events (1 events):
Event: 0.039 Thread 0x00007f1d1015f000    1       3       java.lang.String::hashCode (55 bytes)

GC Heap History (0 events):
No events

Deoptimization events (0 events):
No events

Classes redefined (0 events):
No events

Internal exceptions (2 events):
Event: 0.018 Thread 0x00007f1d1004c000 Exception <a 'java/lang/NoSuchMethodError': Method sun.misc.Unsafe.defineClass(Ljava/lang/String;[BII)Ljava/lang/Class; name or signature does not match> (0x00000000f0007ce0) thrown at [/builddir/build/BUILD/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/
Event: 0.018 Thread 0x00007f1d1004c000 Exception <a 'java/lang/NoSuchMethodError': Method sun.misc.Unsafe.prefetchRead(Ljava/lang/Object;J)V name or signature does not match> (0x00000000f0007fc8) thrown at [/builddir/build/BUILD/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/openjdk/hotspot/sr

Events (250 events):
Event: 0.026 loading class sun/nio/cs/UTF_8$Encoder
Event: 0.026 loading class sun/nio/cs/ArrayEncoder
Event: 0.026 loading class sun/nio/cs/ArrayEncoder done
Event: 0.026 loading class java/nio/charset/CharsetEncoder
Event: 0.026 loading class java/nio/charset/CharsetEncoder done
Event: 0.026 loading class sun/nio/cs/UTF_8$Encoder done
Event: 0.026 loading class java/nio/ByteBuffer
Event: 0.026 loading class java/nio/ByteBuffer done
Event: 0.026 loading class java/nio/HeapByteBuffer
Event: 0.026 loading class java/nio/HeapByteBuffer done
Event: 0.026 loading class java/nio/Bits
Event: 0.026 loading class java/nio/Bits done
Event: 0.026 loading class java/nio/ByteOrder
Event: 0.027 loading class java/nio/ByteOrder done
Event: 0.027 loading class java/util/concurrent/atomic/AtomicLong
Event: 0.027 loading class java/util/concurrent/atomic/AtomicLong done
Event: 0.027 loading class java/nio/Bits$1
Event: 0.027 loading class sun/misc/JavaNioAccess
Event: 0.027 loading class sun/misc/JavaNioAccess done
Event: 0.027 loading class java/nio/Bits$1 done
Event: 0.027 loading class java/io/BufferedWriter
Event: 0.027 loading class java/io/BufferedWriter done
Event: 0.027 loading class java/io/DefaultFileSystem
Event: 0.027 loading class java/io/DefaultFileSystem done
Event: 0.027 loading class java/io/UnixFileSystem
Event: 0.027 loading class java/io/FileSystem
Event: 0.027 loading class java/io/FileSystem done
Event: 0.027 loading class java/io/UnixFileSystem done
Event: 0.027 loading class java/io/ExpiringCache
Event: 0.027 loading class java/io/ExpiringCache done
Event: 0.027 loading class java/io/ExpiringCache$1
Event: 0.027 loading class java/util/LinkedHashMap
Event: 0.027 loading class java/util/LinkedHashMap done
Event: 0.027 loading class java/io/ExpiringCache$1 done
Event: 0.027 loading class java/io/File$PathStatus
Event: 0.027 loading class java/lang/Enum
Event: 0.027 loading class java/lang/Enum done
Event: 0.027 loading class java/io/File$PathStatus done
Event: 0.027 loading class java/nio/file/Path
Event: 0.027 loading class java/nio/file/Watchable
Event: 0.027 loading class java/nio/file/Watchable done
Event: 0.027 loading class java/nio/file/Path done
Event: 0.028 loading class java/lang/StringCoding$StringEncoder
Event: 0.028 loading class java/lang/StringCoding$StringEncoder done
Event: 0.028 loading class java/lang/ClassLoader$3
Event: 0.028 loading class java/lang/ClassLoader$3 done
Event: 0.028 loading class java/io/ExpiringCache$Entry
Event: 0.028 loading class java/io/ExpiringCache$Entry done
Event: 0.028 loading class java/util/LinkedHashMap$Entry
Event: 0.028 loading class java/util/LinkedHashMap$Entry done
Event: 0.028 loading class java/lang/ClassLoader$NativeLibrary
Event: 0.028 loading class java/lang/ClassLoader$NativeLibrary done
Event: 0.028 loading class java/lang/Terminator
Event: 0.028 loading class java/lang/Terminator done
Event: 0.028 loading class java/lang/Terminator$1
Event: 0.028 loading class sun/misc/SignalHandler
Event: 0.028 loading class sun/misc/SignalHandler done
Event: 0.028 loading class java/lang/Terminator$1 done
Event: 0.028 loading class sun/misc/Signal
Event: 0.028 loading class sun/misc/Signal done
Event: 0.028 loading class sun/misc/NativeSignalHandler
Event: 0.028 loading class sun/misc/NativeSignalHandler done
Event: 0.028 loading class java/lang/Integer$IntegerCache
Event: 0.028 loading class java/lang/Integer$IntegerCache done
Event: 0.029 loading class sun/misc/OSEnvironment
Event: 0.029 loading class sun/misc/OSEnvironment done
Event: 0.029 loading class java/lang/System$2
Event: 0.029 loading class sun/misc/JavaLangAccess
Event: 0.029 loading class sun/misc/JavaLangAccess done
Event: 0.029 loading class java/lang/System$2 done
Event: 0.029 loading class java/lang/IllegalArgumentException
Event: 0.029 loading class java/lang/IllegalArgumentException done
Event: 0.029 loading class java/lang/Compiler
Event: 0.029 loading class java/lang/Compiler done
Event: 0.029 loading class java/lang/Compiler$1
Event: 0.029 loading class java/lang/Compiler$1 done
Event: 0.029 loading class sun/misc/Launcher$Factory
Event: 0.029 loading class java/net/URLStreamHandlerFactory
Event: 0.029 loading class java/net/URLStreamHandlerFactory done
Event: 0.029 loading class sun/misc/Launcher$Factory done
Event: 0.029 loading class sun/security/util/Debug
Event: 0.029 loading class sun/security/util/Debug done
Event: 0.029 loading class java/lang/ClassLoader$ParallelLoaders
Event: 0.029 loading class java/lang/ClassLoader$ParallelLoaders done
Event: 0.029 loading class java/util/WeakHashMap$Entry
Event: 0.029 loading class java/util/WeakHashMap$Entry done
Event: 0.029 loading class java/util/Collections$SetFromMap
Event: 0.029 loading class java/util/Collections$SetFromMap done
Event: 0.029 loading class java/util/WeakHashMap$KeySet
Event: 0.030 loading class java/util/WeakHashMap$KeySet done
Event: 0.030 loading class java/net/URLClassLoader$7
Event: 0.030 loading class sun/misc/JavaNetAccess
Event: 0.030 loading class sun/misc/JavaNetAccess done
Event: 0.030 loading class java/net/URLClassLoader$7 done
Event: 0.030 loading class sun/misc/Launcher$ExtClassLoader$1
Event: 0.030 loading class sun/misc/Launcher$ExtClassLoader$1 done
Event: 0.030 loading class java/util/StringTokenizer
Event: 0.030 loading class java/util/StringTokenizer done
Event: 0.030 loading class sun/misc/MetaIndex
Event: 0.030 loading class sun/misc/MetaIndex done
Event: 0.030 loading class java/io/BufferedReader
Event: 0.030 loading class java/io/Reader
Event: 0.030 loading class java/lang/Readable
Event: 0.030 loading class java/lang/Readable done
Event: 0.030 loading class java/io/Reader done
Event: 0.030 loading class java/io/BufferedReader done
Event: 0.030 loading class java/io/FileReader
Event: 0.030 loading class java/io/InputStreamReader
Event: 0.030 loading class java/io/InputStreamReader done
Event: 0.030 loading class java/io/FileReader done
Event: 0.030 loading class sun/nio/cs/StreamDecoder
Event: 0.030 loading class sun/nio/cs/StreamDecoder done
Event: 0.031 loading class java/nio/CharBuffer
Event: 0.031 loading class java/nio/CharBuffer done
Event: 0.031 loading class java/nio/HeapCharBuffer
Event: 0.031 loading class java/nio/HeapCharBuffer done
Event: 0.031 loading class java/nio/charset/CoderResult
Event: 0.031 loading class java/nio/charset/CoderResult done
Event: 0.031 loading class java/nio/charset/CoderResult$1
Event: 0.031 loading class java/nio/charset/CoderResult$Cache
Event: 0.031 loading class java/nio/charset/CoderResult$Cache done
Event: 0.031 loading class java/nio/charset/CoderResult$1 done
Event: 0.031 loading class java/nio/charset/CoderResult$2
Event: 0.031 loading class java/nio/charset/CoderResult$2 done
Event: 0.031 loading class java/lang/reflect/Array
Event: 0.031 loading class java/lang/reflect/Array done
Event: 0.031 loading class java/util/HashMap$TreeNode
Event: 0.031 loading class java/util/HashMap$TreeNode done
Event: 0.031 loading class java/io/FileInputStream$1
Event: 0.031 loading class java/io/FileInputStream$1 done
Event: 0.032 loading class sun/net/www/ParseUtil
Event: 0.032 loading class sun/net/www/ParseUtil done
Event: 0.032 loading class java/util/BitSet
Event: 0.032 loading class java/util/BitSet done
Event: 0.032 loading class java/util/Locale
Event: 0.033 loading class java/util/Locale done
Event: 0.033 loading class java/util/Locale$Cache
Event: 0.033 loading class sun/util/locale/LocaleObjectCache
Event: 0.033 loading class sun/util/locale/LocaleObjectCache done
Event: 0.033 loading class java/util/Locale$Cache done
Event: 0.033 loading class java/util/concurrent/ConcurrentHashMap
Event: 0.033 loading class java/util/concurrent/ConcurrentMap
Event: 0.033 loading class java/util/concurrent/ConcurrentMap done
Event: 0.033 loading class java/util/concurrent/ConcurrentHashMap done
Event: 0.033 loading class java/util/concurrent/ConcurrentHashMap$Segment
Event: 0.033 loading class java/util/concurrent/locks/ReentrantLock
Event: 0.033 loading class java/util/concurrent/locks/Lock
Event: 0.033 loading class java/util/concurrent/locks/Lock done
Event: 0.033 loading class java/util/concurrent/locks/ReentrantLock done
Event: 0.033 loading class java/util/concurrent/ConcurrentHashMap$Segment done
Event: 0.033 loading class java/util/concurrent/ConcurrentHashMap$Node
Event: 0.034 loading class java/util/concurrent/ConcurrentHashMap$Node done
Event: 0.034 loading class java/util/concurrent/ConcurrentHashMap$CounterCell
Event: 0.034 loading class java/util/concurrent/ConcurrentHashMap$CounterCell done
Event: 0.034 loading class java/util/concurrent/ConcurrentHashMap$KeySetView
Event: 0.034 loading class java/util/concurrent/ConcurrentHashMap$CollectionView
Event: 0.034 loading class java/util/concurrent/ConcurrentHashMap$CollectionView done
Event: 0.034 loading class java/util/concurrent/ConcurrentHashMap$KeySetView done
Event: 0.034 loading class java/util/concurrent/ConcurrentHashMap$ValuesView
Event: 0.034 loading class java/util/concurrent/ConcurrentHashMap$ValuesView done
Event: 0.034 loading class java/util/concurrent/ConcurrentHashMap$EntrySetView
Event: 0.034 loading class java/util/concurrent/ConcurrentHashMap$EntrySetView done
Event: 0.034 loading class sun/util/locale/BaseLocale
Event: 0.034 loading class sun/util/locale/BaseLocale done
Event: 0.034 loading class sun/util/locale/BaseLocale$Cache
Event: 0.034 loading class sun/util/locale/BaseLocale$Cache done
Event: 0.034 loading class sun/util/locale/BaseLocale$Key
Event: 0.034 loading class sun/util/locale/BaseLocale$Key done
Event: 0.034 loading class sun/util/locale/LocaleObjectCache$CacheEntry
Event: 0.034 loading class sun/util/locale/LocaleObjectCache$CacheEntry done
Event: 0.034 loading class java/util/Locale$LocaleKey
Event: 0.034 loading class java/util/Locale$LocaleKey done
Event: 0.034 loading class sun/util/locale/LocaleUtils
Event: 0.034 loading class sun/util/locale/LocaleUtils done
Event: 0.035 loading class java/lang/CharacterData
Event: 0.035 loading class java/lang/CharacterData done
Event: 0.035 loading class java/lang/CharacterDataLatin1
Event: 0.035 loading class java/lang/CharacterDataLatin1 done
Event: 0.035 loading class java/net/Parts
Event: 0.035 loading class java/net/Parts done
Event: 0.035 loading class sun/net/www/protocol/file/Handler
Event: 0.035 loading class java/net/URLStreamHandler
Event: 0.035 loading class java/net/URLStreamHandler done
Event: 0.035 loading class sun/net/www/protocol/file/Handler done
Event: 0.035 loading class sun/net/util/IPAddressUtil
Event: 0.035 loading class sun/net/util/IPAddressUtil done
Event: 0.036 loading class java/security/ProtectionDomain$JavaSecurityAccessImpl
Event: 0.036 loading class sun/misc/JavaSecurityAccess
Event: 0.036 loading class sun/misc/JavaSecurityAccess done
Event: 0.036 loading class java/security/ProtectionDomain$JavaSecurityAccessImpl done
Event: 0.036 loading class java/security/ProtectionDomain$2
Event: 0.036 loading class sun/misc/JavaSecurityProtectionDomainAccess
Event: 0.036 loading class sun/misc/JavaSecurityProtectionDomainAccess done
Event: 0.036 loading class java/security/ProtectionDomain$2 done
Event: 0.036 loading class java/security/ProtectionDomain$Key
Event: 0.036 loading class java/security/ProtectionDomain$Key done
Event: 0.036 loading class java/security/Principal
Event: 0.036 loading class java/security/Principal done
Event: 0.036 loading class sun/misc/URLClassPath
Event: 0.036 loading class sun/misc/URLClassPath done
Event: 0.036 loading class sun/net/www/protocol/jar/Handler
Event: 0.036 loading class sun/net/www/protocol/jar/Handler done
Event: 0.037 loading class sun/misc/Launcher$AppClassLoader$1
Event: 0.037 loading class sun/misc/Launcher$AppClassLoader$1 done
Event: 0.037 loading class java/lang/SystemClassLoaderAction
Event: 0.037 loading class java/lang/SystemClassLoaderAction done
Event: 0.037 Thread 0x00007f1d10133000 Thread added: 0x00007f1d10133000
Event: 0.037 loading class jdk/jfr/internal/EventWriter
Event: 0.037 loading class jdk/jfr/internal/EventWriter done
Event: 0.037 Thread 0x00007f1d10141800 Thread added: 0x00007f1d10141800
Event: 0.037 Thread 0x00007f1d10143000 Thread added: 0x00007f1d10143000
Event: 0.037 Thread 0x00007f1d10145800 Thread added: 0x00007f1d10145800
Event: 0.037 Thread 0x00007f1d10147800 Thread added: 0x00007f1d10147800
Event: 0.037 Thread 0x00007f1d10151800 Thread added: 0x00007f1d10151800
Event: 0.038 Thread 0x00007f1d10154000 Thread added: 0x00007f1d10154000
Event: 0.038 Thread 0x00007f1d10156000 Thread added: 0x00007f1d10156000
Event: 0.038 Thread 0x00007f1d10158000 Thread added: 0x00007f1d10158000
Event: 0.038 Thread 0x00007f1d1015a800 Thread added: 0x00007f1d1015a800
Event: 0.038 Thread 0x00007f1d1015c000 Thread added: 0x00007f1d1015c000
Event: 0.038 Thread 0x00007f1d1015f000 Thread added: 0x00007f1d1015f000
Event: 0.038 Thread 0x00007f1d10161000 Thread added: 0x00007f1d10161000
Event: 0.038 Thread 0x00007f1d10163000 Thread added: 0x00007f1d10163000
Event: 0.038 Thread 0x00007f1d10165000 Thread added: 0x00007f1d10165000
Event: 0.038 Thread 0x00007f1d10167000 Thread added: 0x00007f1d10167000
Event: 0.038 loading class java/lang/invoke/MethodHandleImpl
Event: 0.039 loading class java/lang/invoke/MethodHandleImpl done
Event: 0.039 loading class java/lang/invoke/MethodHandleImpl$1
Event: 0.039 loading class java/lang/invoke/MethodHandleImpl$1 done
Event: 0.039 loading class java/lang/invoke/MethodHandleImpl$2
Event: 0.039 loading class java/util/function/Function
Event: 0.039 loading class java/util/function/Function done
Event: 0.039 loading class java/lang/invoke/MethodHandleImpl$2 done
Event: 0.039 loading class java/lang/invoke/MethodHandleImpl$3
Event: 0.039 loading class java/lang/invoke/MethodHandleImpl$3 done
Event: 0.039 loading class java/lang/invoke/MethodHandleImpl$4
Event: 0.039 loading class java/lang/ClassValue
Event: 0.039 loading class java/lang/ClassValue done
Event: 0.039 loading class java/lang/invoke/MethodHandleImpl$4 done
Event: 0.039 loading class java/lang/ClassValue$Entry
Event: 0.039 loading class java/lang/ClassValue$Entry done
Event: 0.039 loading class java/lang/ClassValue$Identity
Event: 0.039 loading class java/lang/ClassValue$Identity done
Event: 0.039 loading class java/lang/ClassValue$Version
Event: 0.039 loading class java/lang/ClassValue$Version done
Event: 0.039 loading class java/lang/invoke/MemberName$Factory
Event: 0.039 loading class java/lang/invoke/MemberName$Factory done
Event: 0.039 loading class java/lang/invoke/MethodHandleStatics
Event: 0.039 loading class java/lang/invoke/MethodHandleStatics done
Event: 0.039 loading class java/lang/invoke/MethodHandleStatics$1
Event: 0.039 loading class java/lang/invoke/MethodHandleStatics$1 done

Dynamic libraries:
f0000000-100060000 rw-p 00000000 00:00 0 
100060000-140000000 ---p 00000000 00:00 0 
5572e361d000-5572e361e000 r--p 00000000 103:02 1580678                   /usr/lib/jvm/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/jre/bin/java
5572e361e000-5572e361f000 r-xp 00001000 103:02 1580678                   /usr/lib/jvm/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/jre/bin/java
5572e361f000-5572e3620000 r--p 00002000 103:02 1580678                   /usr/lib/jvm/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/jre/bin/java
5572e3620000-5572e3621000 r--p 00002000 103:02 1580678                   /usr/lib/jvm/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/jre/bin/java
5572e3621000-5572e3622000 rw-p 00003000 103:02 1580678                   /usr/lib/jvm/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/jre/bin/java
5572e4f96000-5572e4fb7000 rw-p 00000000 00:00 0                          [heap]
7f1cac000000-7f1cac0d4000 rw-p 00000000 00:00 0 
7f1cac0d4000-7f1cb0000000 ---p 00000000 00:00 0 
7f1cb0000000-7f1cb0021000 rw-p 00000000 00:00 0 
7f1cb0021000-7f1cb4000000 ---p 00000000 00:00 0 
7f1cb4000000-7f1cb4021000 rw-p 00000000 00:00 0 
7f1cb4021000-7f1cb8000000 ---p 00000000 00:00 0 
7f1cb8000000-7f1cb8021000 rw-p 00000000 00:00 0 
7f1cb8021000-7f1cbc000000 ---p 00000000 00:00 0 
7f1cbc000000-7f1cbc075000 rw-p 00000000 00:00 0 
7f1cbc075000-7f1cc0000000 ---p 00000000 00:00 0 
7f1cc0000000-7f1cc0021000 rw-p 00000000 00:00 0 
7f1cc0021000-7f1cc4000000 ---p 00000000 00:00 0 
7f1cc4000000-7f1cc4021000 rw-p 00000000 00:00 0 
7f1cc4021000-7f1cc8000000 ---p 00000000 00:00 0 
7f1cc8000000-7f1cc8021000 rw-p 00000000 00:00 0 
7f1cc8021000-7f1ccc000000 ---p 00000000 00:00 0 
7f1ccc000000-7f1ccc021000 rw-p 00000000 00:00 0 
7f1ccc021000-7f1cd0000000 ---p 00000000 00:00 0 
7f1cd0000000-7f1cd0021000 rw-p 00000000 00:00 0 
7f1cd0021000-7f1cd4000000 ---p 00000000 00:00 0 
7f1cd4000000-7f1cd4021000 rw-p 00000000 00:00 0 
7f1cd4021000-7f1cd8000000 ---p 00000000 00:00 0 
7f1cd8000000-7f1cd8021000 rw-p 00000000 00:00 0 
7f1cd8021000-7f1cdc000000 ---p 00000000 00:00 0 
7f1cdc000000-7f1cdc021000 rw-p 00000000 00:00 0 
7f1cdc021000-7f1ce0000000 ---p 00000000 00:00 0 
7f1ce0000000-7f1ce0021000 rw-p 00000000 00:00 0 
7f1ce0021000-7f1ce4000000 ---p 00000000 00:00 0 
7f1ce4000000-7f1ce4098000 rw-p 00000000 00:00 0 
7f1ce4098000-7f1ce8000000 ---p 00000000 00:00 0 
7f1ce8000000-7f1ce8021000 rw-p 00000000 00:00 0 
7f1ce8021000-7f1cec000000 ---p 00000000 00:00 0 
7f1cec000000-7f1cec021000 rw-p 00000000 00:00 0 
7f1cec021000-7f1cf0000000 ---p 00000000 00:00 0 
7f1cf26c4000-7f1cf2ef1000 rw-p 00000000 00:00 0 
7f1cf2ef1000-7f1cf2ef4000 ---p 00000000 00:00 0 
7f1cf2ef4000-7f1cf2ff1000 rw-p 00000000 00:00 0 
7f1cf2ff1000-7f1cf2ff2000 ---p 00000000 00:00 0 
7f1cf2ff2000-7f1cf2ff5000 ---p 00000000 00:00 0 
7f1cf2ff5000-7f1cf30f2000 rw-p 00000000 00:00 0 
7f1cf30f2000-7f1cf30f3000 ---p 00000000 00:00 0 
7f1cf30f3000-7f1cf30f6000 ---p 00000000 00:00 0 
7f1cf30f6000-7f1cf31f3000 rw-p 00000000 00:00 0 
7f1cf31f3000-7f1cf31f4000 ---p 00000000 00:00 0 
7f1cf31f4000-7f1cf31f7000 ---p 00000000 00:00 0 
7f1cf31f7000-7f1cf32f4000 rw-p 00000000 00:00 0 
7f1cf32f4000-7f1cf32f5000 ---p 00000000 00:00 0 
7f1cf32f5000-7f1cf32f8000 ---p 00000000 00:00 0 
7f1cf32f8000-7f1cf33f5000 rw-p 00000000 00:00 0 
7f1cf33f5000-7f1cf33f6000 ---p 00000000 00:00 0 
7f1cf33f6000-7f1cf33f9000 ---p 00000000 00:00 0 
7f1cf33f9000-7f1cf34f6000 rw-p 00000000 00:00 0 
7f1cf34f6000-7f1cf34f7000 ---p 00000000 00:00 0 
7f1cf34f7000-7f1cf34fa000 ---p 00000000 00:00 0 
7f1cf34fa000-7f1cf35f7000 rw-p 00000000 00:00 0 
7f1cf35f7000-7f1cf35f8000 ---p 00000000 00:00 0 
7f1cf35f8000-7f1cf35fb000 ---p 00000000 00:00 0 
7f1cf35fb000-7f1cf36f8000 rw-p 00000000 00:00 0 
7f1cf36f8000-7f1cf36f9000 ---p 00000000 00:00 0 
7f1cf36f9000-7f1cf36fc000 ---p 00000000 00:00 0 
7f1cf36fc000-7f1cf37f9000 rw-p 00000000 00:00 0 
7f1cf37f9000-7f1cf37fa000 ---p 00000000 00:00 0 
7f1cf37fa000-7f1cf37fd000 ---p 00000000 00:00 0 
7f1cf37fd000-7f1cf38fa000 rw-p 00000000 00:00 0 
7f1cf38fa000-7f1cf38fb000 ---p 00000000 00:00 0 
7f1cf38fb000-7f1cf38fe000 ---p 00000000 00:00 0 
7f1cf38fe000-7f1cf39fb000 rw-p 00000000 00:00 0 
7f1cf39fb000-7f1cf39fc000 ---p 00000000 00:00 0 
7f1cf39fc000-7f1cf39ff000 ---p 00000000 00:00 0 
7f1cf39ff000-7f1cf3afc000 rw-p 00000000 00:00 0 
7f1cf3afc000-7f1cf3afd000 ---p 00000000 00:00 0 
7f1cf3afd000-7f1cf3b00000 ---p 00000000 00:00 0 
7f1cf3b00000-7f1cf3bfd000 rw-p 00000000 00:00 0 
7f1cf3bfd000-7f1cf3bfe000 ---p 00000000 00:00 0 
7f1cf3bfe000-7f1cf3c01000 ---p 00000000 00:00 0 
7f1cf3c01000-7f1cf3cfe000 rw-p 00000000 00:00 0 
7f1cf3cfe000-7f1cf3cff000 ---p 00000000 00:00 0 
7f1cf3cff000-7f1cf3d02000 ---p 00000000 00:00 0 
7f1cf3d02000-7f1cf3dff000 rw-p 00000000 00:00 0 
7f1cf3dff000-7f1cf3e00000 ---p 00000000 00:00 0 
7f1cf3e00000-7f1cf3e03000 ---p 00000000 00:00 0 
7f1cf3e03000-7f1cf3f00000 rw-p 00000000 00:00 0 
7f1cf3f00000-7f1cf3f03000 ---p 00000000 00:00 0 
7f1cf3f03000-7f1cf4000000 rw-p 00000000 00:00 0 
7f1cf4000000-7f1cf4021000 rw-p 00000000 00:00 0 
7f1cf4021000-7f1cf8000000 ---p 00000000 00:00 0 
7f1cf8000000-7f1cf8021000 rw-p 00000000 00:00 0 
7f1cf8021000-7f1cfc000000 ---p 00000000 00:00 0 
7f1cfc000000-7f1cfc021000 rw-p 00000000 00:00 0 
7f1cfc021000-7f1d00000000 ---p 00000000 00:00 0 
7f1d00011000-7f1d00068000 r--p 00000000 103:02 1705193                   /usr/lib/locale/C.utf8/LC_CTYPE
7f1d00068000-7f1d002e0000 r--p 00000000 103:02 1705206                   /usr/lib/locale/en_US.utf8/LC_COLLATE
7f1d002e0000-7f1d002e3000 ---p 00000000 00:00 0 
7f1d002e3000-7f1d003e0000 rw-p 00000000 00:00 0 
7f1d003e0000-7f1d003e3000 ---p 00000000 00:00 0 
7f1d003e3000-7f1d004e0000 rw-p 00000000 00:00 0 
7f1d004e0000-7f1d004e1000 ---p 00000000 00:00 0 
7f1d004e1000-7f1d0062f000 rw-p 00000000 00:00 0 
7f1d0062f000-7f1d00800000 r--s 044b3000 103:02 1580789                   /usr/lib/jvm/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/jre/lib/rt.jar
7f1d00800000-7f1d00c00000 rw-p 00000000 00:00 0 
7f1d00c00000-7f1d01000000 ---p 00000000 00:00 0 
7f1d01000000-7f1d01350000 rwxp 00000000 00:00 0 
7f1d01350000-7f1d10000000 ---p 00000000 00:00 0 
7f1d10000000-7f1d101e2000 rw-p 00000000 00:00 0 
7f1d101e2000-7f1d14000000 ---p 00000000 00:00 0 
7f1d14023000-7f1d14029000 r--s 000f6000 103:02 1580774                   /usr/lib/jvm/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/jre/lib/jfr.jar
7f1d14029000-7f1d1402a000 r--p 00000000 103:02 1705214                   /usr/lib/locale/en_US.utf8/LC_NUMERIC
7f1d1402a000-7f1d1402b000 r--p 00000000 103:02 1705469                   /usr/lib/locale/en_US.utf8/LC_TIME
7f1d1402b000-7f1d1402c000 r--p 00000000 103:02 1705467                   /usr/lib/locale/en_US.utf8/LC_MONETARY
7f1d1402c000-7f1d1402d000 r--p 00000000 103:02 1705211                   /usr/lib/locale/en_US.utf8/LC_MESSAGES/SYS_LC_MESSAGES
7f1d1402d000-7f1d1402e000 r--p 00000000 103:02 1705274                   /usr/lib/locale/en_US.utf8/LC_PAPER
7f1d1402e000-7f1d1402f000 r--p 00000000 103:02 1705213                   /usr/lib/locale/en_US.utf8/LC_NAME
7f1d1402f000-7f1d14030000 r--p 00000000 103:02 1705462                   /usr/lib/locale/en_US.utf8/LC_ADDRESS
7f1d14030000-7f1d14037000 r--s 00000000 103:02 1968281                   /usr/lib64/gconv/gconv-modules.cache
7f1d14037000-7f1d141de000 rw-p 00000000 00:00 0 
7f1d141de000-7f1d1422e000 rw-p 00000000 00:00 0 
7f1d1422e000-7f1d145e0000 ---p 00000000 00:00 0 
7f1d145e0000-7f1d145e3000 r--p 00000000 103:02 1580729                   /usr/lib/jvm/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/jre/lib/amd64/libzip.so
7f1d145e3000-7f1d145f5000 r-xp 00003000 103:02 1580729                   /usr/lib/jvm/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/jre/lib/amd64/libzip.so
7f1d145f5000-7f1d145fc000 r--p 00015000 103:02 1580729                   /usr/lib/jvm/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/jre/lib/amd64/libzip.so
7f1d145fc000-7f1d145fd000 ---p 0001c000 103:02 1580729                   /usr/lib/jvm/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/jre/lib/amd64/libzip.so
7f1d145fd000-7f1d145fe000 r--p 0001c000 103:02 1580729                   /usr/lib/jvm/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/jre/lib/amd64/libzip.so
7f1d145fe000-7f1d145ff000 rw-p 00000000 00:00 0 
7f1d145ff000-7f1d1460c000 r--p 00000000 103:02 1580707                   /usr/lib/jvm/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/jre/lib/amd64/libjava.so
7f1d1460c000-7f1d14625000 r-xp 0000d000 103:02 1580707                   /usr/lib/jvm/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/jre/lib/amd64/libjava.so
7f1d14625000-7f1d1462c000 r--p 00026000 103:02 1580707                   /usr/lib/jvm/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/jre/lib/amd64/libjava.so
7f1d1462c000-7f1d1462d000 r--p 0002c000 103:02 1580707                   /usr/lib/jvm/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/jre/lib/amd64/libjava.so
7f1d1462d000-7f1d1462e000 rw-p 0002d000 103:02 1580707                   /usr/lib/jvm/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/jre/lib/amd64/libjava.so
7f1d1462e000-7f1d1462f000 rw-p 00000000 00:00 0 
7f1d1462f000-7f1d14634000 r--p 00000000 103:02 1580728                   /usr/lib/jvm/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/jre/lib/amd64/libverify.so
7f1d14634000-7f1d1463c000 r-xp 00005000 103:02 1580728                   /usr/lib/jvm/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/jre/lib/amd64/libverify.so
7f1d1463c000-7f1d1463e000 r--p 0000d000 103:02 1580728                   /usr/lib/jvm/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/jre/lib/amd64/libverify.so
7f1d1463e000-7f1d14640000 r--p 0000e000 103:02 1580728                   /usr/lib/jvm/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/jre/lib/amd64/libverify.so
7f1d14640000-7f1d14641000 rw-p 00000000 00:00 0 
7f1d14641000-7f1d14642000 r--p 00000000 103:02 1969992                   /usr/lib64/librt.so.1
7f1d14642000-7f1d14643000 r-xp 00001000 103:02 1969992                   /usr/lib64/librt.so.1
7f1d14643000-7f1d14644000 r--p 00002000 103:02 1969992                   /usr/lib64/librt.so.1
7f1d14644000-7f1d14645000 r--p 00002000 103:02 1969992                   /usr/lib64/librt.so.1
7f1d14645000-7f1d14646000 rw-p 00003000 103:02 1969992                   /usr/lib64/librt.so.1
7f1d14646000-7f1d14647000 ---p 00000000 00:00 0 
7f1d14647000-7f1d1464a000 ---p 00000000 00:00 0 
7f1d1464a000-7f1d14747000 rw-p 00000000 00:00 0 
7f1d14747000-7f1d14757000 r--p 00000000 103:02 1969726                   /usr/lib64/libm.so.6
7f1d14757000-7f1d147cb000 r-xp 00010000 103:02 1969726                   /usr/lib64/libm.so.6
7f1d147cb000-7f1d14825000 r--p 00084000 103:02 1969726                   /usr/lib64/libm.so.6
7f1d14825000-7f1d14826000 r--p 000dd000 103:02 1969726                   /usr/lib64/libm.so.6
7f1d14826000-7f1d14827000 rw-p 000de000 103:02 1969726                   /usr/lib64/libm.so.6
7f1d14827000-7f1d14a39000 r--p 00000000 103:02 1580734                   /usr/lib/jvm/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/jre/lib/amd64/server/libjvm.so
7f1d14a39000-7f1d15451000 r-xp 00212000 103:02 1580734                   /usr/lib/jvm/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/jre/lib/amd64/server/libjvm.so
7f1d15451000-7f1d1561c000 r--p 00c2a000 103:02 1580734                   /usr/lib/jvm/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/jre/lib/amd64/server/libjvm.so
7f1d1561c000-7f1d1561d000 ---p 00df5000 103:02 1580734                   /usr/lib/jvm/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/jre/lib/amd64/server/libjvm.so
7f1d1561d000-7f1d156bd000 r--p 00df5000 103:02 1580734                   /usr/lib/jvm/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/jre/lib/amd64/server/libjvm.so
7f1d156bd000-7f1d156e7000 rw-p 00e95000 103:02 1580734                   /usr/lib/jvm/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/jre/lib/amd64/server/libjvm.so
7f1d156e7000-7f1d1571d000 rw-p 00000000 00:00 0 
7f1d1571d000-7f1d15743000 r--p 00000000 103:02 1969225                   /usr/lib64/libc.so.6
7f1d15743000-7f1d15899000 r-xp 00026000 103:02 1969225                   /usr/lib64/libc.so.6
7f1d15899000-7f1d158ec000 r--p 0017c000 103:02 1969225                   /usr/lib64/libc.so.6
7f1d158ec000-7f1d158f0000 r--p 001ce000 103:02 1969225                   /usr/lib64/libc.so.6
7f1d158f0000-7f1d158f2000 rw-p 001d2000 103:02 1969225                   /usr/lib64/libc.so.6
7f1d158f2000-7f1d158fa000 rw-p 00000000 00:00 0 
7f1d158fa000-7f1d158fb000 r--p 00000000 103:02 1705468                   /usr/lib/locale/en_US.utf8/LC_TELEPHONE
7f1d158fb000-7f1d158fc000 r--p 00000000 103:02 1705465                   /usr/lib/locale/en_US.utf8/LC_MEASUREMENT
7f1d158fc000-7f1d158fd000 r--p 00000000 103:02 1705464                   /usr/lib/locale/en_US.utf8/LC_IDENTIFICATION
7f1d158fd000-7f1d15905000 rw-s 00000000 103:02 2885130                   /tmp/hsperfdata_jenkins/34074
7f1d15905000-7f1d15906000 rw-p 00000000 00:00 0 
7f1d15906000-7f1d15909000 r--p 00000000 103:02 1580693                   /usr/lib/jvm/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/jre/lib/amd64/jli/libjli.so
7f1d15909000-7f1d15919000 r-xp 00003000 103:02 1580693                   /usr/lib/jvm/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/jre/lib/amd64/jli/libjli.so
7f1d15919000-7f1d1591f000 r--p 00013000 103:02 1580693                   /usr/lib/jvm/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/jre/lib/amd64/jli/libjli.so
7f1d1591f000-7f1d15920000 ---p 00019000 103:02 1580693                   /usr/lib/jvm/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/jre/lib/amd64/jli/libjli.so
7f1d15920000-7f1d15921000 r--p 00019000 103:02 1580693                   /usr/lib/jvm/java-1.8.0-openjdk-1.8.0.352.b08-2.fc37.x86_64/jre/lib/amd64/jli/libjli.so
7f1d15921000-7f1d15924000 rw-p 00000000 00:00 0 
7f1d15924000-7f1d15925000 r--p 00000000 103:02 1968865                   /usr/lib64/ld-linux-x86-64.so.2
7f1d15925000-7f1d1594c000 r-xp 00001000 103:02 1968865                   /usr/lib64/ld-linux-x86-64.so.2
7f1d1594c000-7f1d15956000 r--p 00028000 103:02 1968865                   /usr/lib64/ld-linux-x86-64.so.2
7f1d15956000-7f1d15957000 r--p 00000000 00:00 0 
7f1d15957000-7f1d15959000 r--p 00032000 103:02 1968865                   /usr/lib64/ld-linux-x86-64.so.2
7f1d15959000-7f1d1595b000 rw-p 00034000 103:02 1968865                   /usr/lib64/ld-linux-x86-64.so.2
7ffce972f000-7ffce9750000 rw-p 00000000 00:00 0                          [stack]
7ffce978b000-7ffce978f000 r--p 00000000 00:00 0                          [vvar]
7ffce978f000-7ffce9791000 r-xp 00000000 00:00 0                          [vdso]
ffffffffff600000-ffffffffff601000 r-xp 00000000 00:00 0                  [vsyscall]

VM Arguments:
jvm_args: -Dapiaddress=127.0.87.3 -Djavax.management.builder.initial=com.scylladb.jmx.utils.APIBuilder -Djava.rmi.server.hostname=127.0.87.3 -Dcom.sun.management.jmxremote -Dcom.sun.management.jmxremote.host=127.0.87.3 -Dcom.sun.management.jmxremote.port=7199 -Dcom.sun.management.jmxremote.rmi.port=7199 -Dcom.sun.management.jmxremote.local.only=false -Xmx256m -XX:+UseSerialGC -Dcom.sun.management.jmxremote.authenticate=false -Dcom.sun.management.jmxremote.ssl=false 
java_command: /jenkins/workspace/scylla-master/gating-dtest-release/scylla/.dtest/dtest-xu0jw2fn/test/node3/bin/scylla-jmx-1.0.jar
java_class_path (initial): /jenkins/workspace/scylla-master/gating-dtest-release/scylla/.dtest/dtest-xu0jw2fn/test/node3/bin/scylla-jmx-1.0.jar
Launcher Type: SUN_STANDARD

Environment Variables:
PATH=/usr/local/sbin:/usr/local/bin:/usr/sbin:/usr/bin:/sbin:/bin:/jenkins/workspace/scylla-master/gating-dtest-release/scylla/.local/bin

Signal Handlers:
SIGSEGV: [libjvm.so+0xbf3080], sa_mask[0]=11111111011111111101111111111110, sa_flags=SA_RESTART|SA_SIGINFO
SIGBUS: [libjvm.so+0xbf3080], sa_mask[0]=11111111011111111101111111111110, sa_flags=SA_RESTART|SA_SIGINFO
SIGFPE: [libjvm.so+0x9c9800], sa_mask[0]=11111111011111111101111111111110, sa_flags=SA_RESTART|SA_SIGINFO
SIGPIPE: [libjvm.so+0x9c9800], sa_mask[0]=11111111011111111101111111111110, sa_flags=SA_RESTART|SA_SIGINFO
SIGXFSZ: [libjvm.so+0x9c9800], sa_mask[0]=11111111011111111101111111111110, sa_flags=SA_RESTART|SA_SIGINFO
SIGILL: [libjvm.so+0x9c9800], sa_mask[0]=11111111011111111101111111111110, sa_flags=SA_RESTART|SA_SIGINFO
SIGUSR1: SIG_DFL, sa_mask[0]=00000000000000000000000000000000, sa_flags=none
SIGUSR2: [libjvm.so+0x9c9b30], sa_mask[0]=00000000000000000000000000000000, sa_flags=SA_RESTART|SA_SIGINFO
SIGHUP: [libjvm.so+0x9c9a80], sa_mask[0]=11111111011111111101111111111110, sa_flags=SA_RESTART|SA_SIGINFO
SIGINT: [libjvm.so+0x9c9a80], sa_mask[0]=11111111011111111101111111111110, sa_flags=SA_RESTART|SA_SIGINFO
SIGTERM: [libjvm.so+0x9c9a80], sa_mask[0]=11111111011111111101111111111110, sa_flags=SA_RESTART|SA_SIGINFO
SIGQUIT: [libjvm.so+0x9c9a80], sa_mask[0]=11111111011111111101111111111110, sa_flags=SA_RESTART|SA_SIGINFO

---------------  S Y S T E M  ---------------

OS:Fedora release 37 (Thirty Seven)

uname:Linux 5.8.15-301.fc33.x86_64 #1 SMP Thu Oct 15 16:58:06 UTC 2020 x86_64
libc:glibc 2.36 NPTL 2.36 
rlimit: STACK 8192k, CORE infinity, NPROC infinity, NOFILE 40000, AS infinity
load average:1.82 1.53 1.42

/proc/meminfo:
MemTotal:       261054312 kB
MemFree:        246376672 kB
MemAvailable:   253158172 kB
Buffers:          149004 kB
Cached:          8282404 kB
SwapCached:            0 kB
Active:          6184308 kB
Inactive:        7448460 kB
Active(anon):    5202512 kB
Inactive(anon):      512 kB
Active(file):     981796 kB
Inactive(file):  7447948 kB
Unevictable:           0 kB
Mlocked:               0 kB
SwapTotal:             0 kB
SwapFree:              0 kB
Dirty:              6416 kB
Writeback:           208 kB
AnonPages:       5201672 kB
Mapped:           363308 kB
Shmem:              2100 kB
KReclaimable:     586996 kB
Slab:             875376 kB
SReclaimable:     586996 kB
SUnreclaim:       288380 kB
KernelStack:       15344 kB
PageTables:        20864 kB
NFS_Unstable:          0 kB
Bounce:                0 kB
WritebackTmp:          0 kB
CommitLimit:    130527156 kB
Committed_AS:   46649264 kB
VmallocTotal:   34359738367 kB
VmallocUsed:       25724 kB
VmallocChunk:          0 kB
Percpu:            20352 kB
HardwareCorrupted:     0 kB
AnonHugePages:    993280 kB
ShmemHugePages:        0 kB
ShmemPmdMapped:        0 kB
FileHugePages:         0 kB
FilePmdMapped:         0 kB
CmaTotal:              0 kB
CmaFree:               0 kB
HugePages_Total:       0
HugePages_Free:        0
HugePages_Rsvd:        0
HugePages_Surp:        0
Hugepagesize:       2048 kB
Hugetlb:               0 kB
DirectMap4k:      307108 kB
DirectMap2M:    13541376 kB
DirectMap1G:    252706816 kB

CPU:total 32 (initial active 32) (16 cores per cpu, 2 threads per core) family 6 model 85 stepping 7, cmov, cx8, fxsr, mmx, sse, sse2, sse3, ssse3, sse4.1, sse4.2, popcnt, avx, avx2, aes, clmul, erms, 3dnowpref, lzcnt, ht, tsc, tscinvbit, bmi1, bmi2, adx

/proc/cpuinfo:
processor   : 0
vendor_id   : GenuineIntel
cpu family  : 6
model       : 85
model name  : Intel(R) Xeon(R) Platinum 8259CL CPU @ 2.50GHz
stepping    : 7
microcode   : 0x500320a
cpu MHz     : 3176.191
cache size  : 36608 KB
physical id : 0
siblings    : 32
core id     : 0
cpu cores   : 16
apicid      : 0
initial apicid  : 0
fpu     : yes
fpu_exception   : yes
cpuid level : 13
wp      : yes
flags       : fpu vme de pse tsc msr pae mce cx8 apic sep mtrr pge mca cmov pat pse36 clflush mmx fxsr sse sse2 ss ht syscall nx pdpe1gb rdtscp lm constant_tsc rep_good nopl xtopology nonstop_tsc cpuid aperfmperf tsc_known_freq pni pclmulqdq ssse3 fma cx16 pcid sse4_1 sse4_2 x2apic movbe popcnt tsc_deadline_timer aes xsave avx f16c rdrand hypervisor lahf_lm abm 3dnowprefetch invpcid_single pti fsgsbase tsc_adjust bmi1 avx2 smep bmi2 erms invpcid mpx avx512f avx512dq rdseed adx smap clflushopt clwb avx512cd avx512bw avx512vl xsaveopt xsavec xgetbv1 xsaves ida arat pku ospke
bugs        : cpu_meltdown spectre_v1 spectre_v2 spec_store_bypass l1tf mds swapgs itlb_multihit
bogomips    : 4999.98
clflush size    : 64
cache_alignment : 64
address sizes   : 46 bits physical, 48 bits virtual
power management:

processor   : 1
vendor_id   : GenuineIntel
cpu family  : 6
model       : 85
model name  : Intel(R) Xeon(R) Platinum 8259CL CPU @ 2.50GHz
stepping    : 7
microcode   : 0x500320a
cpu MHz     : 3189.455
cache size  : 36608 KB
physical id : 0
siblings    : 32
core id     : 1
cpu cores   : 16
apicid      : 2
initial apicid  : 2
fpu     : yes
fpu_exception   : yes
cpuid level : 13
wp      : yes
flags       : fpu vme de pse tsc msr pae mce cx8 apic sep mtrr pge mca cmov pat pse36 clflush mmx fxsr sse sse2 ss ht syscall nx pdpe1gb rdtscp lm constant_tsc rep_good nopl xtopology nonstop_tsc cpuid aperfmperf tsc_known_freq pni pclmulqdq ssse3 fma cx16 pcid sse4_1 sse4_2 x2apic movbe popcnt tsc_deadline_timer aes xsave avx f16c rdrand hypervisor lahf_lm abm 3dnowprefetch invpcid_single pti fsgsbase tsc_adjust bmi1 avx2 smep bmi2 erms invpcid mpx avx512f avx512dq rdseed adx smap clflushopt clwb avx512cd avx512bw avx512vl xsaveopt xsavec xgetbv1 xsaves ida arat pku ospke
bugs        : cpu_meltdown spectre_v1 spectre_v2 spec_store_bypass l1tf mds swapgs itlb_multihit
bogomips    : 4999.98
clflush size    : 64
cache_alignment : 64
address sizes   : 46 bits physical, 48 bits virtual
power management:

processor   : 2
vendor_id   : GenuineIntel
cpu family  : 6
model       : 85
model name  : Intel(R) Xeon(R) Platinum 8259CL CPU @ 2.50GHz
stepping    : 7
microcode   : 0x500320a
cpu MHz     : 3162.725
cache size  : 36608 KB
physical id : 0
siblings    : 32
core id     : 2
cpu cores   : 16
apicid      : 4
initial apicid  : 4
fpu     : yes
fpu_exception   : yes
cpuid level : 13
wp      : yes
flags       : fpu vme de pse tsc msr pae mce cx8 apic sep mtrr pge mca cmov pat pse36 clflush mmx fxsr sse sse2 ss ht syscall nx pdpe1gb rdtscp lm constant_tsc rep_good nopl xtopology nonstop_tsc cpuid aperfmperf tsc_known_freq pni pclmulqdq ssse3 fma cx16 pcid sse4_1 sse4_2 x2apic movbe popcnt tsc_deadline_timer aes xsave avx f16c rdrand hypervisor lahf_lm abm 3dnowprefetch invpcid_single pti fsgsbase tsc_adjust bmi1 avx2 smep bmi2 erms invpcid mpx avx512f avx512dq rdseed adx smap clflushopt clwb avx512cd avx512bw avx512vl xsaveopt xsavec xgetbv1 xsaves ida arat pku ospke
bugs        : cpu_meltdown spectre_v1 spectre_v2 spec_store_bypass l1tf mds swapgs itlb_multihit
bogomips    : 4999.98
clflush size    : 64
cache_alignment : 64
address sizes   : 46 bits physical, 48 bits virtual
power management:

processor   : 3
vendor_id   : GenuineIntel
cpu family  : 6
model       : 85
model name  : Intel(R) Xeon(R) Platinum 8259CL CPU @ 2.50GHz
stepping    : 7
microcode   : 0x500320a
cpu MHz     : 3171.260
cache size  : 36608 KB
physical id : 0
siblings    : 32
core id     : 3
cpu cores   : 16
apicid      : 6
initial apicid  : 6
fpu     : yes
fpu_exception   : yes
cpuid level : 13
wp      : yes
flags       : fpu vme de pse tsc msr pae mce cx8 apic sep mtrr pge mca cmov pat pse36 clflush mmx fxsr sse sse2 ss ht syscall nx pdpe1gb rdtscp lm constant_tsc rep_good nopl xtopology nonstop_tsc cpuid aperfmperf tsc_known_freq pni pclmulqdq ssse3 fma cx16 pcid sse4_1 sse4_2 x2apic movbe popcnt tsc_deadline_timer aes xsave avx f16c rdrand hypervisor lahf_lm abm 3dnowprefetch invpcid_single pti fsgsbase tsc_adjust bmi1 avx2 smep bmi2 erms invpcid mpx avx512f avx512dq rdseed adx smap clflushopt clwb avx512cd avx512bw avx512vl xsaveopt xsavec xgetbv1 xsaves ida arat pku ospke
bugs        : cpu_meltdown spectre_v1 spectre_v2 spec_store_bypass l1tf mds swapgs itlb_multihit
bogomips    : 4999.98
clflush size    : 64
cache_alignment : 64
address sizes   : 46 bits physical, 48 bits virtual
power management:

processor   : 4
vendor_id   : GenuineIntel
cpu family  : 6
model       : 85
model name  : Intel(R) Xeon(R) Platinum 8259CL CPU @ 2.50GHz
stepping    : 7
microcode   : 0x500320a
cpu MHz     : 3194.171
cache size  : 36608 KB
physical id : 0
siblings    : 32
core id     : 4
cpu cores   : 16
apicid      : 8
initial apicid  : 8
fpu     : yes
fpu_exception   : yes
cpuid level : 13
wp      : yes
flags       : fpu vme de pse tsc msr pae mce cx8 apic sep mtrr pge mca cmov pat pse36 clflush mmx fxsr sse sse2 ss ht syscall nx pdpe1gb rdtscp lm constant_tsc rep_good nopl xtopology nonstop_tsc cpuid aperfmperf tsc_known_freq pni pclmulqdq ssse3 fma cx16 pcid sse4_1 sse4_2 x2apic movbe popcnt tsc_deadline_timer aes xsave avx f16c rdrand hypervisor lahf_lm abm 3dnowprefetch invpcid_single pti fsgsbase tsc_adjust bmi1 avx2 smep bmi2 erms invpcid mpx avx512f avx512dq rdseed adx smap clflushopt clwb avx512cd avx512bw avx512vl xsaveopt xsavec xgetbv1 xsaves ida arat pku ospke
bugs        : cpu_meltdown spectre_v1 spectre_v2 spec_store_bypass l1tf mds swapgs itlb_multihit
bogomips    : 4999.98
clflush size    : 64
cache_alignment : 64
address sizes   : 46 bits physical, 48 bits virtual
power management:

processor   : 5
vendor_id   : GenuineIntel
cpu family  : 6
model       : 85
model name  : Intel(R) Xeon(R) Platinum 8259CL CPU @ 2.50GHz
stepping    : 7
microcode   : 0x500320a
cpu MHz     : 3152.801
cache size  : 36608 KB
physical id : 0
siblings    : 32
core id     : 5
cpu cores   : 16
apicid      : 10
initial apicid  : 10
fpu     : yes
fpu_exception   : yes
cpuid level : 13
wp      : yes
flags       : fpu vme de pse tsc msr pae mce cx8 apic sep mtrr pge mca cmov pat pse36 clflush mmx fxsr sse sse2 ss ht syscall nx pdpe1gb rdtscp lm constant_tsc rep_good nopl xtopology nonstop_tsc cpuid aperfmperf tsc_known_freq pni pclmulqdq ssse3 fma cx16 pcid sse4_1 sse4_2 x2apic movbe popcnt tsc_deadline_timer aes xsave avx f16c rdrand hypervisor lahf_lm abm 3dnowprefetch invpcid_single pti fsgsbase tsc_adjust bmi1 avx2 smep bmi2 erms invpcid mpx avx512f avx512dq rdseed adx smap clflushopt clwb avx512cd avx512bw avx512vl xsaveopt xsavec xgetbv1 xsaves ida arat pku ospke
bugs        : cpu_meltdown spectre_v1 spectre_v2 spec_store_bypass l1tf mds swapgs itlb_multihit
bogomips    : 4999.98
clflush size    : 64
cache_alignment : 64
address sizes   : 46 bits physical, 48 bits virtual
power management:

processor   : 6
vendor_id   : GenuineIntel
cpu family  : 6
model       : 85
model name  : Intel(R) Xeon(R) Platinum 8259CL CPU @ 2.50GHz
stepping    : 7
microcode   : 0x500320a
cpu MHz     : 3181.141
cache size  : 36608 KB
physical id : 0
siblings    : 32
core id     : 6
cpu cores   : 16
apicid      : 12
initial apicid  : 12
fpu     : yes
fpu_exception   : yes
cpuid level : 13
wp      : yes
flags       : fpu vme de pse tsc msr pae mce cx8 apic sep mtrr pge mca cmov pat pse36 clflush mmx fxsr sse sse2 ss ht syscall nx pdpe1gb rdtscp lm constant_tsc rep_good nopl xtopology nonstop_tsc cpuid aperfmperf tsc_known_freq pni pclmulqdq ssse3 fma cx16 pcid sse4_1 sse4_2 x2apic movbe popcnt tsc_deadline_timer aes xsave avx f16c rdrand hypervisor lahf_lm abm 3dnowprefetch invpcid_single pti fsgsbase tsc_adjust bmi1 avx2 smep bmi2 erms invpcid mpx avx512f avx512dq rdseed adx smap clflushopt clwb avx512cd avx512bw avx512vl xsaveopt xsavec xgetbv1 xsaves ida arat pku ospke
bugs        : cpu_meltdown spectre_v1 spectre_v2 spec_store_bypass l1tf mds swapgs itlb_multihit
bogomips    : 4999.98
clflush size    : 64
cache_alignment : 64
address sizes   : 46 bits physical, 48 bits virtual
power management:

processor   : 7
vendor_id   : GenuineIntel
cpu family  : 6
model       : 85
model name  : Intel(R) Xeon(R) Platinum 8259CL CPU @ 2.50GHz
stepping    : 7
microcode   : 0x500320a
cpu MHz     : 3172.845
cache size  : 36608 KB
physical id : 0
siblings    : 32
core id     : 7
cpu cores   : 16
apicid      : 14
initial apicid  : 14
fpu     : yes
fpu_exception   : yes
cpuid level : 13
wp      : yes
flags       : fpu vme de pse tsc msr pae mce cx8 apic sep mtrr pge mca cmov pat pse36 clflush mmx fxsr sse sse2 ss ht syscall nx pdpe1gb rdtscp lm constant_tsc rep_good nopl xtopology nonstop_tsc cpuid aperfmperf tsc_known_freq pni pclmulqdq ssse3 fma cx16 pcid sse4_1 sse4_2 x2apic movbe popcnt tsc_deadline_timer aes xsave avx f16c rdrand hypervisor lahf_lm abm 3dnowprefetch invpcid_single pti fsgsbase tsc_adjust bmi1 avx2 smep bmi2 erms invpcid mpx avx512f avx512dq rdseed adx smap clflushopt clwb avx512cd avx512bw avx512vl xsaveopt xsavec xgetbv1 xsaves ida arat pku ospke
bugs        : cpu_meltdown spectre_v1 spectre_v2 spec_store_bypass l1tf mds swapgs itlb_multihit
bogomips    : 4999.98
clflush size    : 64
cache_alignment : 64
address sizes   : 46 bits physical, 48 bits virtual
power management:

processor   : 8
vendor_id   : GenuineIntel
cpu family  : 6
model       : 85
model name  : Intel(R) Xeon(R) Platinum 8259CL CPU @ 2.50GHz
stepping    : 7
microcode   : 0x500320a
cpu MHz     : 3172.348
cache size  : 36608 KB
physical id : 0
siblings    : 32
core id     : 8
cpu cores   : 16
apicid      : 16
initial apicid  : 16
fpu     : yes
fpu_exception   : yes
cpuid level : 13
wp      : yes
flags       : fpu vme de pse tsc msr pae mce cx8 apic sep mtrr pge mca cmov pat pse36 clflush mmx fxsr sse sse2 ss ht syscall nx pdpe1gb rdtscp lm constant_tsc rep_good nopl xtopology nonstop_tsc cpuid aperfmperf tsc_known_freq pni pclmulqdq ssse3 fma cx16 pcid sse4_1 sse4_2 x2apic movbe popcnt tsc_deadline_timer aes xsave avx f16c rdrand hypervisor lahf_lm abm 3dnowprefetch invpcid_single pti fsgsbase tsc_adjust bmi1 avx2 smep bmi2 erms invpcid mpx avx512f avx512dq rdseed adx smap clflushopt clwb avx512cd avx512bw avx512vl xsaveopt xsavec xgetbv1 xsaves ida arat pku ospke
bugs        : cpu_meltdown spectre_v1 spectre_v2 spec_store_bypass l1tf mds swapgs itlb_multihit
bogomips    : 4999.98
clflush size    : 64
cache_alignment : 64
address sizes   : 46 bits physical, 48 bits virtual
power management:

processor   : 9
vendor_id   : GenuineIntel
cpu family  : 6
model       : 85
model name  : Intel(R) Xeon(R) Platinum 8259CL CPU @ 2.50GHz
stepping    : 7
microcode   : 0x500320a
cpu MHz     : 3162.487
cache size  : 36608 KB
physical id : 0
siblings    : 32
core id     : 9
cpu cores   : 16
apicid      : 18
initial apicid  : 18
fpu     : yes
fpu_exception   : yes
cpuid level : 13
wp      : yes
flags       : fpu vme de pse tsc msr pae mce cx8 apic sep mtrr pge mca cmov pat pse36 clflush mmx fxsr sse sse2 ss ht syscall nx pdpe1gb rdtscp lm constant_tsc rep_good nopl xtopology nonstop_tsc cpuid aperfmperf tsc_known_freq pni pclmulqdq ssse3 fma cx16 pcid sse4_1 sse4_2 x2apic movbe popcnt tsc_deadline_timer aes xsave avx f16c rdrand hypervisor lahf_lm abm 3dnowprefetch invpcid_single pti fsgsbase tsc_adjust bmi1 avx2 smep bmi2 erms invpcid mpx avx512f avx512dq rdseed adx smap clflushopt clwb avx512cd avx512bw avx512vl xsaveopt xsavec xgetbv1 xsaves ida arat pku ospke
bugs        : cpu_meltdown spectre_v1 spectre_v2 spec_store_bypass l1tf mds swapgs itlb_multihit
bogomips    : 4999.98
clflush size    : 64
cache_alignment : 64
address sizes   : 46 bits physical, 48 bits virtual
power management:

processor   : 10
vendor_id   : GenuineIntel
cpu family  : 6
model       : 85
model name  : Intel(R) Xeon(R) Platinum 8259CL CPU @ 2.50GHz
stepping    : 7
microcode   : 0x500320a
cpu MHz     : 3163.418
cache size  : 36608 KB
physical id : 0
siblings    : 32
core id     : 10
cpu cores   : 16
apicid      : 20
initial apicid  : 20
fpu     : yes
fpu_exception   : yes
cpuid level : 13
wp      : yes
flags       : fpu vme de pse tsc msr pae mce cx8 apic sep mtrr pge mca cmov pat pse36 clflush mmx fxsr sse sse2 ss ht syscall nx pdpe1gb rdtscp lm constant_tsc rep_good nopl xtopology nonstop_tsc cpuid aperfmperf tsc_known_freq pni pclmulqdq ssse3 fma cx16 pcid sse4_1 sse4_2 x2apic movbe popcnt tsc_deadline_timer aes xsave avx f16c rdrand hypervisor lahf_lm abm 3dnowprefetch invpcid_single pti fsgsbase tsc_adjust bmi1 avx2 smep bmi2 erms invpcid mpx avx512f avx512dq rdseed adx smap clflushopt clwb avx512cd avx512bw avx512vl xsaveopt xsavec xgetbv1 xsaves ida arat pku ospke
bugs        : cpu_meltdown spectre_v1 spectre_v2 spec_store_bypass l1tf mds swapgs itlb_multihit
bogomips    : 4999.98
clflush size    : 64
cache_alignment : 64
address sizes   : 46 bits physical, 48 bits virtual
power management:

processor   : 11
vendor_id   : GenuineIntel
cpu family  : 6
model       : 85
model name  : Intel(R) Xeon(R) Platinum 8259CL CPU @ 2.50GHz
stepping    : 7
microcode   : 0x500320a
cpu MHz     : 3180.795
cache size  : 36608 KB
physical id : 0
siblings    : 32
core id     : 11
cpu cores   : 16
apicid      : 22
initial apicid  : 22
fpu     : yes
fpu_exception   : yes
cpuid level : 13
wp      : yes
flags       : fpu vme de pse tsc msr pae mce cx8 apic sep mtrr pge mca cmov pat pse36 clflush mmx fxsr sse sse2 ss ht syscall nx pdpe1gb rdtscp lm constant_tsc rep_good nopl xtopology nonstop_tsc cpuid aperfmperf tsc_known_freq pni pclmulqdq ssse3 fma cx16 pcid sse4_1 sse4_2 x2apic movbe popcnt tsc_deadline_timer aes xsave avx f16c rdrand hypervisor lahf_lm abm 3dnowprefetch invpcid_single pti fsgsbase tsc_adjust bmi1 avx2 smep bmi2 erms invpcid mpx avx512f avx512dq rdseed adx smap clflushopt clwb avx512cd avx512bw avx512vl xsaveopt xsavec xgetbv1 xsaves ida arat pku ospke
bugs        : cpu_meltdown spectre_v1 spectre_v2 spec_store_bypass l1tf mds swapgs itlb_multihit
bogomips    : 4999.98
clflush size    : 64
cache_alignment : 64
address sizes   : 46 bits physical, 48 bits virtual
power management:

processor   : 12
vendor_id   : GenuineIntel
cpu family  : 6
model       : 85
model name  : Intel(R) Xeon(R) Platinum 8259CL CPU @ 2.50GHz
stepping    : 7
microcode   : 0x500320a
cpu MHz     : 3168.020
cache size  : 36608 KB
physical id : 0
siblings    : 32
core id     : 12
cpu cores   : 16
apicid      : 24
initial apicid  : 24
fpu     : yes
fpu_exception   : yes
cpuid level : 13
wp      : yes
flags       : fpu vme de pse tsc msr pae mce cx8 apic sep mtrr pge mca cmov pat pse36 clflush mmx fxsr sse sse2 ss ht syscall nx pdpe1gb rdtscp lm constant_tsc rep_good nopl xtopology nonstop_tsc cpuid aperfmperf tsc_known_freq pni pclmulqdq ssse3 fma cx16 pcid sse4_1 sse4_2 x2apic movbe popcnt tsc_deadline_timer aes xsave avx f16c rdrand hypervisor lahf_lm abm 3dnowprefetch invpcid_single pti fsgsbase tsc_adjust bmi1 avx2 smep bmi2 erms invpcid mpx avx512f avx512dq rdseed adx smap clflushopt clwb avx512cd avx512bw avx512vl xsaveopt xsavec xgetbv1 xsaves ida arat pku ospke
bugs        : cpu_meltdown spectre_v1 spectre_v2 spec_store_bypass l1tf mds swapgs itlb_multihit
bogomips    : 4999.98
clflush size    : 64
cache_alignment : 64
address sizes   : 46 bits physical, 48 bits virtual
power management:

processor   : 13
vendor_id   : GenuineIntel
cpu family  : 6
model       : 85
model name  : Intel(R) Xeon(R) Platinum 8259CL CPU @ 2.50GHz
stepping    : 7
microcode   : 0x500320a
cpu MHz     : 3197.560
cache size  : 36608 KB
physical id : 0
siblings    : 32
core id     : 13
cpu cores   : 16
apicid      : 26
initial apicid  : 26
fpu     : yes
fpu_exception   : yes
cpuid level : 13
wp      : yes
flags       : fpu vme de pse tsc msr pae mce cx8 apic sep mtrr pge mca cmov pat pse36 clflush mmx fxsr sse sse2 ss ht syscall nx pdpe1gb rdtscp lm constant_tsc rep_good nopl xtopology nonstop_tsc cpuid aperfmperf tsc_known_freq pni pclmulqdq ssse3 fma cx16 pcid sse4_1 sse4_2 x2apic movbe popcnt tsc_deadline_timer aes xsave avx f16c rdrand hypervisor lahf_lm abm 3dnowprefetch invpcid_single pti fsgsbase tsc_adjust bmi1 avx2 smep bmi2 erms invpcid mpx avx512f avx512dq rdseed adx smap clflushopt clwb avx512cd avx512bw avx512vl xsaveopt xsavec xgetbv1 xsaves ida arat pku ospke
bugs        : cpu_meltdown spectre_v1 spectre_v2 spec_store_bypass l1tf mds swapgs itlb_multihit
bogomips    : 4999.98
clflush size    : 64
cache_alignment : 64
address sizes   : 46 bits physical, 48 bits virtual
power management:

processor   : 14
vendor_id   : GenuineIntel
cpu family  : 6
model       : 85
model name  : Intel(R) Xeon(R) Platinum 8259CL CPU @ 2.50GHz
stepping    : 7
microcode   : 0x500320a
cpu MHz     : 3193.713
cache size  : 36608 KB
physical id : 0
siblings    : 32
core id     : 14
cpu cores   : 16
apicid      : 28
initial apicid  : 28
fpu     : yes
fpu_exception   : yes
cpuid level : 13
wp      : yes
flags       : fpu vme de pse tsc msr pae mce cx8 apic sep mtrr pge mca cmov pat pse36 clflush mmx fxsr sse sse2 ss ht syscall nx pdpe1gb rdtscp lm constant_tsc rep_good nopl xtopology nonstop_tsc cpuid aperfmperf tsc_known_freq pni pclmulqdq ssse3 fma cx16 pcid sse4_1 sse4_2 x2apic movbe popcnt tsc_deadline_timer aes xsave avx f16c rdrand hypervisor lahf_lm abm 3dnowprefetch invpcid_single pti fsgsbase tsc_adjust bmi1 avx2 smep bmi2 erms invpcid mpx avx512f avx512dq rdseed adx smap clflushopt clwb avx512cd avx512bw avx512vl xsaveopt xsavec xgetbv1 xsaves ida arat pku ospke
bugs        : cpu_meltdown spectre_v1 spectre_v2 spec_store_bypass l1tf mds swapgs itlb_multihit
bogomips    : 4999.98
clflush size    : 64
cache_alignment : 64
address sizes   : 46 bits physical, 48 bits virtual
power management:

processor   : 15
vendor_id   : GenuineIntel
cpu family  : 6
model       : 85
model name  : Intel(R) Xeon(R) Platinum 8259CL CPU @ 2.50GHz
stepping    : 7
microcode   : 0x500320a
cpu MHz     : 3172.334
cache size  : 36608 KB
physical id : 0
siblings    : 32
core id     : 15
cpu cores   : 16
apicid      : 30
initial apicid  : 30
fpu     : yes
fpu_exception   : yes
cpuid level : 13
wp      : yes
flags       : fpu vme de pse tsc msr pae mce cx8 apic sep mtrr pge mca cmov pat pse36 clflush mmx fxsr sse sse2 ss ht syscall nx pdpe1gb rdtscp lm constant_tsc rep_good nopl xtopology nonstop_tsc cpuid aperfmperf tsc_known_freq pni pclmulqdq ssse3 fma cx16 pcid sse4_1 sse4_2 x2apic movbe popcnt tsc_deadline_timer aes xsave avx f16c rdrand hypervisor lahf_lm abm 3dnowprefetch invpcid_single pti fsgsbase tsc_adjust bmi1 avx2 smep bmi2 erms invpcid mpx avx512f avx512dq rdseed adx smap clflushopt clwb avx512cd avx512bw avx512vl xsaveopt xsavec xgetbv1 xsaves ida arat pku ospke
bugs        : cpu_meltdown spectre_v1 spectre_v2 spec_store_bypass l1tf mds swapgs itlb_multihit
bogomips    : 4999.98
clflush size    : 64
cache_alignment : 64
address sizes   : 46 bits physical, 48 bits virtual
power management:

processor   : 16
vendor_id   : GenuineIntel
cpu family  : 6
model       : 85
model name  : Intel(R) Xeon(R) Platinum 8259CL CPU @ 2.50GHz
stepping    : 7
microcode   : 0x500320a
cpu MHz     : 3190.130
cache size  : 36608 KB
physical id : 0
siblings    : 32
core id     : 0
cpu cores   : 16
apicid      : 1
initial apicid  : 1
fpu     : yes
fpu_exception   : yes
cpuid level : 13
wp      : yes
flags       : fpu vme de pse tsc msr pae mce cx8 apic sep mtrr pge mca cmov pat pse36 clflush mmx fxsr sse sse2 ss ht syscall nx pdpe1gb rdtscp lm constant_tsc rep_good nopl xtopology nonstop_tsc cpuid aperfmperf tsc_known_freq pni pclmulqdq ssse3 fma cx16 pcid sse4_1 sse4_2 x2apic movbe popcnt tsc_deadline_timer aes xsave avx f16c rdrand hypervisor lahf_lm abm 3dnowprefetch invpcid_single pti fsgsbase tsc_adjust bmi1 avx2 smep bmi2 erms invpcid mpx avx512f avx512dq rdseed adx smap clflushopt clwb avx512cd avx512bw avx512vl xsaveopt xsavec xgetbv1 xsaves ida arat pku ospke
bugs        : cpu_meltdown spectre_v1 spectre_v2 spec_store_bypass l1tf mds swapgs itlb_multihit
bogomips    : 4999.98
clflush size    : 64
cache_alignment : 64
address sizes   : 46 bits physical, 48 bits virtual
power management:

processor   : 17
vendor_id   : GenuineIntel
cpu family  : 6
model       : 85
model name  : Intel(R) Xeon(R) Platinum 8259CL CPU @ 2.50GHz
stepping    : 7
microcode   : 0x500320a
cpu MHz     : 3173.862
cache size  : 36608 KB
physical id : 0
siblings    : 32
core id     : 1
cpu cores   : 16
apicid      : 3
initial apicid  : 3
fpu     : yes
fpu_exception   : yes
cpuid level : 13
wp      : yes
flags       : fpu vme de pse tsc msr pae mce cx8 apic sep mtrr pge mca cmov pat pse36 clflush mmx fxsr sse sse2 ss ht syscall nx pdpe1gb rdtscp lm constant_tsc rep_good nopl xtopology nonstop_tsc cpuid aperfmperf tsc_known_freq pni pclmulqdq ssse3 fma cx16 pcid sse4_1 sse4_2 x2apic movbe popcnt tsc_deadline_timer aes xsave avx f16c rdrand hypervisor lahf_lm abm 3dnowprefetch invpcid_single pti fsgsbase tsc_adjust bmi1 avx2 smep bmi2 erms invpcid mpx avx512f avx512dq rdseed adx smap clflushopt clwb avx512cd avx512bw avx512vl xsaveopt xsavec xgetbv1 xsaves ida arat pku ospke
bugs        : cpu_meltdown spectre_v1 spectre_v2 spec_store_bypass l1tf mds swapgs itlb_multihit
bogomips    : 4999.98
clflush size    : 64
cache_alignment : 64
address sizes   : 46 bits physical, 48 bits virtual
power management:

processor   : 18
vendor_id   : GenuineIntel
cpu family  : 6
model       : 85
model name  : Intel(R) Xeon(R) Platinum 8259CL CPU @ 2.50GHz
stepping    : 7
microcode   : 0x500320a
cpu MHz     : 3173.569
cache size  : 36608 KB
physical id : 0
siblings    : 32
core id     : 2
cpu cores   : 16
apicid      : 5
initial apicid  : 5
fpu     : yes
fpu_exception   : yes
cpuid level : 13
wp      : yes
flags       : fpu vme de pse tsc msr pae mce cx8 apic sep mtrr pge mca cmov pat pse36 clflush mmx fxsr sse sse2 ss ht syscall nx pdpe1gb rdtscp lm constant_tsc rep_good nopl xtopology nonstop_tsc cpuid aperfmperf tsc_known_freq pni pclmulqdq ssse3 fma cx16 pcid sse4_1 sse4_2 x2apic movbe popcnt tsc_deadline_timer aes xsave avx f16c rdrand hypervisor lahf_lm abm 3dnowprefetch invpcid_single pti fsgsbase tsc_adjust bmi1 avx2 smep bmi2 erms invpcid mpx avx512f avx512dq rdseed adx smap clflushopt clwb avx512cd avx512bw avx512vl xsaveopt xsavec xgetbv1 xsaves ida arat pku ospke
bugs        : cpu_meltdown spectre_v1 spectre_v2 spec_store_bypass l1tf mds swapgs itlb_multihit
bogomips    : 4999.98
clflush size    : 64
cache_alignment : 64
address sizes   : 46 bits physical, 48 bits virtual
power management:

processor   : 19
vendor_id   : GenuineIntel
cpu family  : 6
model       : 85
model name  : Intel(R) Xeon(R) Platinum 8259CL CPU @ 2.50GHz
stepping    : 7
microcode   : 0x500320a
cpu MHz     : 3172.710
cache size  : 36608 KB
physical id : 0
siblings    : 32
core id     : 3
cpu cores   : 16
apicid      : 7
initial apicid  : 7
fpu     : yes
fpu_exception   : yes
cpuid level : 13
wp      : yes
flags       : fpu vme de pse tsc msr pae mce cx8 apic sep mtrr pge mca cmov pat pse36 clflush mmx fxsr sse sse2 ss ht syscall nx pdpe1gb rdtscp lm constant_tsc rep_good nopl xtopology nonstop_tsc cpuid aperfmperf tsc_known_freq pni pclmulqdq ssse3 fma cx16 pcid sse4_1 sse4_2 x2apic movbe popcnt tsc_deadline_timer aes xsave avx f16c rdrand hypervisor lahf_lm abm 3dnowprefetch invpcid_single pti fsgsbase tsc_adjust bmi1 avx2 smep bmi2 erms invpcid mpx avx512f avx512dq rdseed adx smap clflushopt clwb avx512cd avx512bw avx512vl xsaveopt xsavec xgetbv1 xsaves ida arat pku ospke
bugs        : cpu_meltdown spectre_v1 spectre_v2 spec_store_bypass l1tf mds swapgs itlb_multihit
bogomips    : 4999.98
clflush size    : 64
cache_alignment : 64
address sizes   : 46 bits physical, 48 bits virtual
power management:

processor   : 20
vendor_id   : GenuineIntel
cpu family  : 6
model       : 85
model name  : Intel(R) Xeon(R) Platinum 8259CL CPU @ 2.50GHz
stepping    : 7
microcode   : 0x500320a
cpu MHz     : 3174.239
cache size  : 36608 KB
physical id : 0
siblings    : 32
core id     : 4
cpu cores   : 16
apicid      : 9
initial apicid  : 9
fpu     : yes
fpu_exception   : yes
cpuid level : 13
wp      : yes
flags       : fpu vme de pse tsc msr pae mce cx8 apic sep mtrr pge mca cmov pat pse36 clflush mmx fxsr sse sse2 ss ht syscall nx pdpe1gb rdtscp lm constant_tsc rep_good nopl xtopology nonstop_tsc cpuid aperfmperf tsc_known_freq pni pclmulqdq ssse3 fma cx16 pcid sse4_1 sse4_2 x2apic movbe popcnt tsc_deadline_timer aes xsave avx f16c rdrand hypervisor lahf_lm abm 3dnowprefetch invpcid_single pti fsgsbase tsc_adjust bmi1 avx2 smep bmi2 erms invpcid mpx avx512f avx512dq rdseed adx smap clflushopt clwb avx512cd avx512bw avx512vl xsaveopt xsavec xgetbv1 xsaves ida arat pku ospke
bugs        : cpu_meltdown spectre_v1 spectre_v2 spec_store_bypass l1tf mds swapgs itlb_multihit
bogomips    : 4999.98
clflush size    : 64
cache_alignment : 64
address sizes   : 46 bits physical, 48 bits virtual
power management:

processor   : 21
vendor_id   : GenuineIntel
cpu family  : 6
model       : 85
model name  : Intel(R) Xeon(R) Platinum 8259CL CPU @ 2.50GHz
stepping    : 7
microcode   : 0x500320a
cpu MHz     : 3164.441
cache size  : 36608 KB
physical id : 0
siblings    : 32
core id     : 5
cpu cores   : 16
apicid      : 11
initial apicid  : 11
fpu     : yes
fpu_exception   : yes
cpuid level : 13
wp      : yes
flags       : fpu vme de pse tsc msr pae mce cx8 apic sep mtrr pge mca cmov pat pse36 clflush mmx fxsr sse sse2 ss ht syscall nx pdpe1gb rdtscp lm constant_tsc rep_good nopl xtopology nonstop_tsc cpuid aperfmperf tsc_known_freq pni pclmulqdq ssse3 fma cx16 pcid sse4_1 sse4_2 x2apic movbe popcnt tsc_deadline_timer aes xsave avx f16c rdrand hypervisor lahf_lm abm 3dnowprefetch invpcid_single pti fsgsbase tsc_adjust bmi1 avx2 smep bmi2 erms invpcid mpx avx512f avx512dq rdseed adx smap clflushopt clwb avx512cd avx512bw avx512vl xsaveopt xsavec xgetbv1 xsaves ida arat pku ospke
bugs        : cpu_meltdown spectre_v1 spectre_v2 spec_store_bypass l1tf mds swapgs itlb_multihit
bogomips    : 4999.98
clflush size    : 64
cache_alignment : 64
address sizes   : 46 bits physical, 48 bits virtual
power management:

processor   : 22
vendor_id   : GenuineIntel
cpu family  : 6
model       : 85
model name  : Intel(R) Xeon(R) Platinum 8259CL CPU @ 2.50GHz
stepping    : 7
microcode   : 0x500320a
cpu MHz     : 3179.396
cache size  : 36608 KB
physical id : 0
siblings    : 32
core id     : 6
cpu cores   : 16
apicid      : 13
initial apicid  : 13
fpu     : yes
fpu_exception   : yes
cpuid level : 13
wp      : yes
flags       : fpu vme de pse tsc msr pae mce cx8 apic sep mtrr pge mca cmov pat pse36 clflush mmx fxsr sse sse2 ss ht syscall nx pdpe1gb rdtscp lm constant_tsc rep_good nopl xtopology nonstop_tsc cpuid aperfmperf tsc_known_freq pni pclmulqdq ssse3 fma cx16 pcid sse4_1 sse4_2 x2apic movbe popcnt tsc_deadline_timer aes xsave avx f16c rdrand hypervisor lahf_lm abm 3dnowprefetch invpcid_single pti fsgsbase tsc_adjust bmi1 avx2 smep bmi2 erms invpcid mpx avx512f avx512dq rdseed adx smap clflushopt clwb avx512cd avx512bw avx512vl xsaveopt xsavec xgetbv1 xsaves ida arat pku ospke
bugs        : cpu_meltdown spectre_v1 spectre_v2 spec_store_bypass l1tf mds swapgs itlb_multihit
bogomips    : 4999.98
clflush size    : 64
cache_alignment : 64
address sizes   : 46 bits physical, 48 bits virtual
power management:

processor   : 23
vendor_id   : GenuineIntel
cpu family  : 6
model       : 85
model name  : Intel(R) Xeon(R) Platinum 8259CL CPU @ 2.50GHz
stepping    : 7
microcode   : 0x500320a
cpu MHz     : 3193.513
cache size  : 36608 KB
physical id : 0
siblings    : 32
core id     : 7
cpu cores   : 16
apicid      : 15
initial apicid  : 15
fpu     : yes
fpu_exception   : yes
cpuid level : 13
wp      : yes
flags       : fpu vme de pse tsc msr pae mce cx8 apic sep mtrr pge mca cmov pat pse36 clflush mmx fxsr sse sse2 ss ht syscall nx pdpe1gb rdtscp lm constant_tsc rep_good nopl xtopology nonstop_tsc cpuid aperfmperf tsc_known_freq pni pclmulqdq ssse3 fma cx16 pcid sse4_1 sse4_2 x2apic movbe popcnt tsc_deadline_timer aes xsave avx f16c rdrand hypervisor lahf_lm abm 3dnowprefetch invpcid_single pti fsgsbase tsc_adjust bmi1 avx2 smep bmi2 erms invpcid mpx avx512f avx512dq rdseed adx smap clflushopt clwb avx512cd avx512bw avx512vl xsaveopt xsavec xgetbv1 xsaves ida arat pku ospke
bugs        : cpu_meltdown spectre_v1 spectre_v2 spec_store_bypass l1tf mds swapgs itlb_multihit
bogomips    : 4999.98
clflush size    : 64
cache_alignment : 64
address sizes   : 46 bits physical, 48 bits virtual
power management:

processor   : 24
vendor_id   : GenuineIntel
cpu family  : 6
model       : 85
model name  : Intel(R) Xeon(R) Platinum 8259CL CPU @ 2.50GHz
stepping    : 7
microcode   : 0x500320a
cpu MHz     : 3175.558
cache size  : 36608 KB
physical id : 0
siblings    : 32
core id     : 8
cpu cores   : 16
apicid      : 17
initial apicid  : 17
fpu     : yes
fpu_exception   : yes
cpuid level : 13
wp      : yes
flags       : fpu vme de pse tsc msr pae mce cx8 apic sep mtrr pge mca cmov pat pse36 clflush mmx fxsr sse sse2 ss ht syscall nx pdpe1gb rdtscp lm constant_tsc rep_good nopl xtopology nonstop_tsc cpuid aperfmperf tsc_known_freq pni pclmulqdq ssse3 fma cx16 pcid sse4_1 sse4_2 x2apic movbe popcnt tsc_deadline_timer aes xsave avx f16c rdrand hypervisor lahf_lm abm 3dnowprefetch invpcid_single pti fsgsbase tsc_adjust bmi1 avx2 smep bmi2 erms invpcid mpx avx512f avx512dq rdseed adx smap clflushopt clwb avx512cd avx512bw avx512vl xsaveopt xsavec xgetbv1 xsaves ida arat pku ospke
bugs        : cpu_meltdown spectre_v1 spectre_v2 spec_store_bypass l1tf mds swapgs itlb_multihit
bogomips    : 4999.98
clflush size    : 64
cache_alignment : 64
address sizes   : 46 bits physical, 48 bits virtual
power management:

processor   : 25
vendor_id   : GenuineIntel
cpu family  : 6
model       : 85
model name  : Intel(R) Xeon(R) Platinum 8259CL CPU @ 2.50GHz
stepping    : 7
microcode   : 0x500320a
cpu MHz     : 3161.494
cache size  : 36608 KB
physical id : 0
siblings    : 32
core id     : 9
cpu cores   : 16
apicid      : 19
initial apicid  : 19
fpu     : yes
fpu_exception   : yes
cpuid level : 13
wp      : yes
flags       : fpu vme de pse tsc msr pae mce cx8 apic sep mtrr pge mca cmov pat pse36 clflush mmx fxsr sse sse2 ss ht syscall nx pdpe1gb rdtscp lm constant_tsc rep_good nopl xtopology nonstop_tsc cpuid aperfmperf tsc_known_freq pni pclmulqdq ssse3 fma cx16 pcid sse4_1 sse4_2 x2apic movbe popcnt tsc_deadline_timer aes xsave avx f16c rdrand hypervisor lahf_lm abm 3dnowprefetch invpcid_single pti fsgsbase tsc_adjust bmi1 avx2 smep bmi2 erms invpcid mpx avx512f avx512dq rdseed adx smap clflushopt clwb avx512cd avx512bw avx512vl xsaveopt xsavec xgetbv1 xsaves ida arat pku ospke
bugs        : cpu_meltdown spectre_v1 spectre_v2 spec_store_bypass l1tf mds swapgs itlb_multihit
bogomips    : 4999.98
clflush size    : 64
cache_alignment : 64
address sizes   : 46 bits physical, 48 bits virtual
power management:

processor   : 26
vendor_id   : GenuineIntel
cpu family  : 6
model       : 85
model name  : Intel(R) Xeon(R) Platinum 8259CL CPU @ 2.50GHz
stepping    : 7
microcode   : 0x500320a
cpu MHz     : 3175.169
cache size  : 36608 KB
physical id : 0
siblings    : 32
core id     : 10
cpu cores   : 16
apicid      : 21
initial apicid  : 21
fpu     : yes
fpu_exception   : yes
cpuid level : 13
wp      : yes
flags       : fpu vme de pse tsc msr pae mce cx8 apic sep mtrr pge mca cmov pat pse36 clflush mmx fxsr sse sse2 ss ht syscall nx pdpe1gb rdtscp lm constant_tsc rep_good nopl xtopology nonstop_tsc cpuid aperfmperf tsc_known_freq pni pclmulqdq ssse3 fma cx16 pcid sse4_1 sse4_2 x2apic movbe popcnt tsc_deadline_timer aes xsave avx f16c rdrand hypervisor lahf_lm abm 3dnowprefetch invpcid_single pti fsgsbase tsc_adjust bmi1 avx2 smep bmi2 erms invpcid mpx avx512f avx512dq rdseed adx smap clflushopt clwb avx512cd avx512bw avx512vl xsaveopt xsavec xgetbv1 xsaves ida arat pku ospke
bugs        : cpu_meltdown spectre_v1 spectre_v2 spec_store_bypass l1tf mds swapgs itlb_multihit
bogomips    : 4999.98
clflush size    : 64
cache_alignment : 64
address sizes   : 46 bits physical, 48 bits virtual
power management:

processor   : 27
vendor_id   : GenuineIntel
cpu family  : 6
model       : 85
model name  : Intel(R) Xeon(R) Platinum 8259CL CPU @ 2.50GHz
stepping    : 7
microcode   : 0x500320a
cpu MHz     : 3192.104
cache size  : 36608 KB
physical id : 0
siblings    : 32
core id     : 11
cpu cores   : 16
apicid      : 23
initial apicid  : 23
fpu     : yes
fpu_exception   : yes
cpuid level : 13
wp      : yes
flags       : fpu vme de pse tsc msr pae mce cx8 apic sep mtrr pge mca cmov pat pse36 clflush mmx fxsr sse sse2 ss ht syscall nx pdpe1gb rdtscp lm constant_tsc rep_good nopl xtopology nonstop_tsc cpuid aperfmperf tsc_known_freq pni pclmulqdq ssse3 fma cx16 pcid sse4_1 sse4_2 x2apic movbe popcnt tsc_deadline_timer aes xsave avx f16c rdrand hypervisor lahf_lm abm 3dnowprefetch invpcid_single pti fsgsbase tsc_adjust bmi1 avx2 smep bmi2 erms invpcid mpx avx512f avx512dq rdseed adx smap clflushopt clwb avx512cd avx512bw avx512vl xsaveopt xsavec xgetbv1 xsaves ida arat pku ospke
bugs        : cpu_meltdown spectre_v1 spectre_v2 spec_store_bypass l1tf mds swapgs itlb_multihit
bogomips    : 4999.98
clflush size    : 64
cache_alignment : 64
address sizes   : 46 bits physical, 48 bits virtual
power management:

processor   : 28
vendor_id   : GenuineIntel
cpu family  : 6
model       : 85
model name  : Intel(R) Xeon(R) Platinum 8259CL CPU @ 2.50GHz
stepping    : 7
microcode   : 0x500320a
cpu MHz     : 3190.961
cache size  : 36608 KB
physical id : 0
siblings    : 32
core id     : 12
cpu cores   : 16
apicid      : 25
initial apicid  : 25
fpu     : yes
fpu_exception   : yes
cpuid level : 13
wp      : yes
flags       : fpu vme de pse tsc msr pae mce cx8 apic sep mtrr pge mca cmov pat pse36 clflush mmx fxsr sse sse2 ss ht syscall nx pdpe1gb rdtscp lm constant_tsc rep_good nopl xtopology nonstop_tsc cpuid aperfmperf tsc_known_freq pni pclmulqdq ssse3 fma cx16 pcid sse4_1 sse4_2 x2apic movbe popcnt tsc_deadline_timer aes xsave avx f16c rdrand hypervisor lahf_lm abm 3dnowprefetch invpcid_single pti fsgsbase tsc_adjust bmi1 avx2 smep bmi2 erms invpcid mpx avx512f avx512dq rdseed adx smap clflushopt clwb avx512cd avx512bw avx512vl xsaveopt xsavec xgetbv1 xsaves ida arat pku ospke
bugs        : cpu_meltdown spectre_v1 spectre_v2 spec_store_bypass l1tf mds swapgs itlb_multihit
bogomips    : 4999.98
clflush size    : 64
cache_alignment : 64
address sizes   : 46 bits physical, 48 bits virtual
power management:

processor   : 29
vendor_id   : GenuineIntel
cpu family  : 6
model       : 85
model name  : Intel(R) Xeon(R) Platinum 8259CL CPU @ 2.50GHz
stepping    : 7
microcode   : 0x500320a
cpu MHz     : 3192.803
cache size  : 36608 KB
physical id : 0
siblings    : 32
core id     : 13
cpu cores   : 16
apicid      : 27
initial apicid  : 27
fpu     : yes
fpu_exception   : yes
cpuid level : 13
wp      : yes
flags       : fpu vme de pse tsc msr pae mce cx8 apic sep mtrr pge mca cmov pat pse36 clflush mmx fxsr sse sse2 ss ht syscall nx pdpe1gb rdtscp lm constant_tsc rep_good nopl xtopology nonstop_tsc cpuid aperfmperf tsc_known_freq pni pclmulqdq ssse3 fma cx16 pcid sse4_1 sse4_2 x2apic movbe popcnt tsc_deadline_timer aes xsave avx f16c rdrand hypervisor lahf_lm abm 3dnowprefetch invpcid_single pti fsgsbase tsc_adjust bmi1 avx2 smep bmi2 erms invpcid mpx avx512f avx512dq rdseed adx smap clflushopt clwb avx512cd avx512bw avx512vl xsaveopt xsavec xgetbv1 xsaves ida arat pku ospke
bugs        : cpu_meltdown spectre_v1 spectre_v2 spec_store_bypass l1tf mds swapgs itlb_multihit
bogomips    : 4999.98
clflush size    : 64
cache_alignment : 64
address sizes   : 46 bits physical, 48 bits virtual
power management:

processor   : 30
vendor_id   : GenuineIntel
cpu family  : 6
model       : 85
model name  : Intel(R) Xeon(R) Platinum 8259CL CPU @ 2.50GHz
stepping    : 7
microcode   : 0x500320a
cpu MHz     : 3195.727
cache size  : 36608 KB
physical id : 0
siblings    : 32
core id     : 14
cpu cores   : 16
apicid      : 29
initial apicid  : 29
fpu     : yes
fpu_exception   : yes
cpuid level : 13
wp      : yes
flags       : fpu vme de pse tsc msr pae mce cx8 apic sep mtrr pge mca cmov pat pse36 clflush mmx fxsr sse sse2 ss ht syscall nx pdpe1gb rdtscp lm constant_tsc rep_good nopl xtopology nonstop_tsc cpuid aperfmperf tsc_known_freq pni pclmulqdq ssse3 fma cx16 pcid sse4_1 sse4_2 x2apic movbe popcnt tsc_deadline_timer aes xsave avx f16c rdrand hypervisor lahf_lm abm 3dnowprefetch invpcid_single pti fsgsbase tsc_adjust bmi1 avx2 smep bmi2 erms invpcid mpx avx512f avx512dq rdseed adx smap clflushopt clwb avx512cd avx512bw avx512vl xsaveopt xsavec xgetbv1 xsaves ida arat pku ospke
bugs        : cpu_meltdown spectre_v1 spectre_v2 spec_store_bypass l1tf mds swapgs itlb_multihit
bogomips    : 4999.98
clflush size    : 64
cache_alignment : 64
address sizes   : 46 bits physical, 48 bits virtual
power management:

processor   : 31
vendor_id   : GenuineIntel
cpu family  : 6
model       : 85
model name  : Intel(R) Xeon(R) Platinum 8259CL CPU @ 2.50GHz
stepping    : 7
microcode   : 0x500320a
cpu MHz     : 3172.080
cache size  : 36608 KB
physical id : 0
siblings    : 32
core id     : 15
cpu cores   : 16
apicid      : 31
initial apicid  : 31
fpu     : yes
fpu_exception   : yes
cpuid level : 13
wp      : yes
flags       : fpu vme de pse tsc msr pae mce cx8 apic sep mtrr pge mca cmov pat pse36 clflush mmx fxsr sse sse2 ss ht syscall nx pdpe1gb rdtscp lm constant_tsc rep_good nopl xtopology nonstop_tsc cpuid aperfmperf tsc_known_freq pni pclmulqdq ssse3 fma cx16 pcid sse4_1 sse4_2 x2apic movbe popcnt tsc_deadline_timer aes xsave avx f16c rdrand hypervisor lahf_lm abm 3dnowprefetch invpcid_single pti fsgsbase tsc_adjust bmi1 avx2 smep bmi2 erms invpcid mpx avx512f avx512dq rdseed adx smap clflushopt clwb avx512cd avx512bw avx512vl xsaveopt xsavec xgetbv1 xsaves ida arat pku ospke
bugs        : cpu_meltdown spectre_v1 spectre_v2 spec_store_bypass l1tf mds swapgs itlb_multihit
bogomips    : 4999.98
clflush size    : 64
cache_alignment : 64
address sizes   : 46 bits physical, 48 bits virtual
power management:

Memory: 4k page, physical 261054312k(246373396k free), swap 0k(0k free)

vm_info: OpenJDK 64-Bit Server VM (25.352-b08) for linux-amd64 JRE (1.8.0_352-b08), built on Oct 19 2022 00:00:00 by "mockbuild" with gcc 12.2.1 20220819 (Red Hat 12.2.1-2)

time: Mon Apr 10 04:36:01 2023
timezone: UTC
elapsed time: 0.065624 seconds (0d 0h 0m 0s)

https://jenkins.scylladb.com/view/master/job/scylla-master/job/next/5866/artifact/dtest-raft/logs-full.release.000/1681101392880_replace_address_test.py%3A%3ATestReplaceAddress%3A%3Atest_replace_active_node%5Buse_host_id-rbo_disabled%5D/replay_pid34074.log

JvmtiExport can_access_local_variables 0
JvmtiExport can_hotswap_or_post_breakpoint 0
JvmtiExport can_post_on_exceptions 0
# 101 ciObject found
instanceKlass com/sun/jmx/interceptor/MBeanServerInterceptor
instanceKlass java/util/concurrent/locks/ReentrantReadWriteLock$WriteLock
instanceKlass java/util/concurrent/locks/ReentrantReadWriteLock$ReadLock
instanceKlass sun/nio/ch/Interruptible
instanceKlass java/util/concurrent/locks/ReentrantReadWriteLock
instanceKlass java/util/concurrent/locks/ReadWriteLock
instanceKlass com/sun/jmx/mbeanserver/JmxMBeanServer$1
instanceKlass com/sun/jmx/mbeanserver/SecureClassLoaderRepository
instanceKlass com/sun/jmx/mbeanserver/MBeanInstantiator
instanceKlass com/sun/jmx/mbeanserver/ClassLoaderRepositorySupport$LoaderEntry
instanceKlass com/sun/jmx/mbeanserver/ClassLoaderRepositorySupport
instanceKlass com/sun/jmx/mbeanserver/ModifiableClassLoaderRepository
instanceKlass javax/management/loading/ClassLoaderRepository
instanceKlass java/util/NavigableSet
instanceKlass java/util/SortedSet
instanceKlass java/util/TreeMap$PrivateEntryIterator
instanceKlass java/util/NavigableMap
instanceKlass java/util/SortedMap
instanceKlass javax/management/ImmutableDescriptor
instanceKlass javax/management/Descriptor
instanceKlass javax/management/NotificationBroadcasterSupport$1
instanceKlass java/util/concurrent/Executor
instanceKlass javax/management/NotificationBroadcasterSupport
instanceKlass java/util/ComparableTimSort
instanceKlass sun/security/action/GetBooleanAction
instanceKlass java/util/Arrays$LegacyMergeSort
instanceKlass javax/management/ObjectName$Property
instanceKlass javax/management/ObjectName
instanceKlass javax/management/QueryExp
instanceKlass com/sun/jmx/mbeanserver/Util
instanceKlass javax/management/MBeanInfo
instanceKlass javax/management/MBeanFeatureInfo
instanceKlass javax/management/DescriptorRead
instanceKlass javax/management/MBeanServerDelegate
instanceKlass javax/management/NotificationEmitter
instanceKlass javax/management/NotificationBroadcaster
instanceKlass javax/management/MBeanServerDelegateMBean
instanceKlass javax/management/MBeanRegistration
instanceKlass javax/management/DynamicMBean
instanceKlass com/sun/jmx/mbeanserver/JmxMBeanServer
instanceKlass com/sun/jmx/mbeanserver/SunJmxMBeanServer
instanceKlass com/sun/jmx/mbeanserver/Repository
instanceKlass javax/management/MBeanServer
instanceKlass javax/management/MBeanServerConnection
instanceKlass javax/management/MBeanServerBuilder
instanceKlass java/io/FilePermission$1
instanceKlass java/net/URI$Parser
instanceKlass java/net/URI
instanceKlass sun/nio/fs/UnixMountEntry
instanceKlass sun/nio/fs/UnixFileStoreAttributes
instanceKlass sun/nio/fs/UnixFileAttributes
instanceKlass java/nio/file/attribute/PosixFileAttributes
instanceKlass java/nio/file/attribute/BasicFileAttributes
instanceKlass sun/nio/fs/UnixNativeDispatcher$1
instanceKlass sun/nio/fs/UnixNativeDispatcher
instanceKlass sun/nio/fs/Util
instanceKlass sun/nio/fs/AbstractPath
instanceKlass java/nio/file/FileSystem
instanceKlass java/nio/file/spi/FileSystemProvider
instanceKlass sun/nio/fs/DefaultFileSystemProvider
instanceKlass sun/net/www/MessageHeader
instanceKlass java/net/URLConnection
instanceKlass java/security/PermissionCollection
instanceKlass sun/nio/ByteBuffered
instanceKlass sun/misc/Resource
instanceKlass sun/misc/IOUtils
instanceKlass sun/misc/ExtensionDependency
instanceKlass sun/misc/JarIndex
instanceKlass sun/nio/ch/DirectBuffer
instanceKlass sun/misc/PerfCounter$CoreCounters
instanceKlass sun/misc/Perf
instanceKlass sun/misc/Perf$GetPerfAction
instanceKlass sun/misc/PerfCounter
instanceKlass java/util/Deque
instanceKlass java/util/Queue
instanceKlass java/util/jar/JavaUtilJarAccessImpl
instanceKlass sun/misc/JavaUtilJarAccess
instanceKlass sun/misc/FileURLMapper
instanceKlass sun/misc/URLClassPath$JarLoader$1
instanceKlass java/util/zip/ZipFile$1
instanceKlass sun/misc/JavaUtilZipFileAccess
instanceKlass java/util/zip/ZipFile
instanceKlass sun/misc/URLClassPath$Loader
instanceKlass sun/misc/URLClassPath$3
instanceKlass sun/net/util/URLUtil
instanceKlass java/net/URLClassLoader$1
instanceKlass com/sun/jmx/mbeanserver/GetPropertyAction
instanceKlass javax/management/MBeanServerFactory
instanceKlass java/lang/management/ManagementFactory
instanceKlass java/util/logging/LogManager$5
instanceKlass java/util/HashMap$HashIterator
instanceKlass sun/reflect/UnsafeFieldAccessorFactory
instanceKlass java/util/logging/LoggingProxyImpl
instanceKlass sun/util/logging/LoggingProxy
instanceKlass sun/util/logging/LoggingSupport$1
instanceKlass sun/util/logging/LoggingSupport
instanceKlass sun/util/logging/PlatformLogger$LoggerProxy
instanceKlass sun/util/logging/PlatformLogger$1
instanceKlass sun/util/logging/PlatformLogger
instanceKlass java/util/logging/LogManager$LoggerContext$1
instanceKlass java/util/ArrayList$Itr
instanceKlass java/util/logging/LogManager$3
instanceKlass java/util/logging/LogManager$2
instanceKlass java/lang/Shutdown$Lock
instanceKlass java/lang/Shutdown
instanceKlass java/lang/ApplicationShutdownHooks$1
instanceKlass java/lang/ApplicationShutdownHooks
instanceKlass java/util/logging/LogManager$LogNode
instanceKlass java/util/logging/LogManager$LoggerContext
instanceKlass java/util/logging/LogManager$1
instanceKlass java/util/logging/LogManager
instanceKlass java/util/concurrent/locks/AbstractQueuedSynchronizer$Node
instanceKlass java/util/concurrent/locks/AbstractOwnableSynchronizer
instanceKlass java/util/concurrent/CopyOnWriteArrayList
instanceKlass java/util/logging/Logger$LoggerBundle
instanceKlass java/util/logging/Level$KnownLevel
instanceKlass java/util/logging/Level
instanceKlass java/util/logging/Handler
instanceKlass sun/misc/ASCIICaseInsensitiveComparator
instanceKlass java/util/jar/Attributes$Name
instanceKlass java/util/jar/Attributes
instanceKlass java/util/zip/ZipEntry
instanceKlass java/util/zip/ZipUtils
instanceKlass java/util/zip/ZipCoder
instanceKlass java/util/zip/CRC32
instanceKlass java/util/zip/Checksum
instanceKlass java/util/zip/ZStreamRef
instanceKlass java/util/zip/Inflater
instanceKlass java/nio/charset/StandardCharsets
instanceKlass java/util/zip/ZipConstants
instanceKlass java/lang/Package$1
instanceKlass java/lang/Package
instanceKlass java/util/logging/Logger
instanceKlass com/sun/jmx/remote/util/ClassLogger
instanceKlass sun/management/jmxremote/ConnectorBootstrap
instanceKlass java/util/Properties$LineReader
instanceKlass sun/management/Agent
instanceKlass java/lang/invoke/MethodHandleStatics$1
instanceKlass java/lang/invoke/MethodHandleStatics
instanceKlass java/lang/invoke/MemberName$Factory
instanceKlass java/lang/ClassValue$Version
instanceKlass java/lang/ClassValue$Identity
instanceKlass java/lang/ClassValue
instanceKlass java/lang/invoke/MethodHandleImpl$3
instanceKlass java/lang/invoke/MethodHandleImpl$2
instanceKlass java/util/function/Function
instanceKlass java/lang/invoke/MethodHandleImpl$1
instanceKlass java/lang/invoke/MethodHandleImpl
instanceKlass jdk/jfr/internal/EventWriter
instanceKlass java/lang/SystemClassLoaderAction
instanceKlass sun/misc/Launcher$AppClassLoader$1
instanceKlass sun/misc/URLClassPath
instanceKlass java/security/Principal
instanceKlass java/security/ProtectionDomain$Key
instanceKlass java/security/ProtectionDomain$2
instanceKlass sun/misc/JavaSecurityProtectionDomainAccess
instanceKlass java/security/ProtectionDomain$JavaSecurityAccessImpl
instanceKlass sun/misc/JavaSecurityAccess
instanceKlass sun/net/util/IPAddressUtil
instanceKlass java/net/URLStreamHandler
instanceKlass java/net/Parts
instanceKlass java/lang/CharacterData
instanceKlass sun/util/locale/LocaleUtils
instanceKlass java/util/Locale$LocaleKey
instanceKlass sun/util/locale/BaseLocale$Key
instanceKlass sun/util/locale/BaseLocale
instanceKlass java/util/concurrent/ConcurrentHashMap$CollectionView
instanceKlass java/util/concurrent/ConcurrentHashMap$CounterCell
instanceKlass java/util/concurrent/ConcurrentHashMap$Node
instanceKlass java/util/concurrent/locks/ReentrantLock
instanceKlass java/util/concurrent/locks/Lock
instanceKlass java/util/concurrent/ConcurrentMap
instanceKlass sun/util/locale/LocaleObjectCache
instanceKlass java/util/Locale
instanceKlass java/util/BitSet
instanceKlass sun/net/www/ParseUtil
instanceKlass java/io/FileInputStream$1
instanceKlass java/lang/reflect/Array
instanceKlass java/nio/charset/CoderResult$Cache
instanceKlass java/nio/charset/CoderResult
instanceKlass java/io/Reader
instanceKlass java/lang/Readable
instanceKlass sun/misc/MetaIndex
instanceKlass java/util/StringTokenizer
instanceKlass sun/misc/Launcher$ExtClassLoader$1
instanceKlass java/net/URLClassLoader$7
instanceKlass sun/misc/JavaNetAccess
instanceKlass java/lang/ClassLoader$ParallelLoaders
instanceKlass sun/security/util/Debug
instanceKlass sun/misc/Launcher$Factory
instanceKlass java/net/URLStreamHandlerFactory
instanceKlass java/lang/Compiler$1
instanceKlass java/lang/Compiler
instanceKlass java/lang/System$2
instanceKlass sun/misc/JavaLangAccess
instanceKlass sun/misc/OSEnvironment
instanceKlass java/lang/Integer$IntegerCache
instanceKlass sun/misc/NativeSignalHandler
instanceKlass sun/misc/Signal
instanceKlass java/lang/Terminator$1
instanceKlass sun/misc/SignalHandler
instanceKlass java/lang/Terminator
instanceKlass java/lang/ClassLoader$NativeLibrary
instanceKlass java/io/ExpiringCache$Entry
instanceKlass java/lang/ClassLoader$3
instanceKlass java/lang/StringCoding$StringEncoder
instanceKlass java/nio/file/Path
instanceKlass java/nio/file/Watchable
instanceKlass java/lang/Enum
instanceKlass java/io/ExpiringCache
instanceKlass java/io/FileSystem
instanceKlass java/io/DefaultFileSystem
instanceKlass java/nio/Bits$1
instanceKlass sun/misc/JavaNioAccess
instanceKlass java/nio/ByteOrder
instanceKlass java/nio/Bits
instanceKlass java/nio/charset/CharsetEncoder
instanceKlass sun/nio/cs/ArrayEncoder
instanceKlass sun/security/action/GetPropertyAction
instanceKlass java/io/Writer
instanceKlass sun/reflect/misc/ReflectUtil
instanceKlass java/util/concurrent/atomic/AtomicReferenceFieldUpdater$AtomicReferenceFieldUpdaterImpl$1
instanceKlass java/security/PrivilegedExceptionAction
instanceKlass java/util/concurrent/atomic/AtomicReferenceFieldUpdater
instanceKlass java/io/OutputStream
instanceKlass java/io/Flushable
instanceKlass java/io/FileDescriptor$1
instanceKlass sun/misc/JavaIOFileDescriptorAccess
instanceKlass java/io/FileDescriptor
instanceKlass sun/misc/Version
instanceKlass jdk/internal/util/StaticProperty
instanceKlass java/lang/Runtime
instanceKlass java/util/Hashtable$Enumerator
instanceKlass java/util/Iterator
instanceKlass java/util/Enumeration
instanceKlass java/util/Objects
instanceKlass java/util/Collections$SynchronizedCollection
instanceKlass java/nio/charset/CodingErrorAction
instanceKlass java/nio/charset/CharsetDecoder
instanceKlass sun/nio/cs/ArrayDecoder
instanceKlass java/lang/StringCoding$StringDecoder
instanceKlass java/lang/ThreadLocal$ThreadLocalMap
instanceKlass java/lang/StringCoding
instanceKlass sun/reflect/ReflectionFactory$1
instanceKlass java/lang/Class$1
instanceKlass sun/nio/cs/HistoricallyNamedCharset
instanceKlass java/util/Arrays
instanceKlass java/lang/reflect/ReflectAccess
instanceKlass sun/reflect/LangReflectAccess
instanceKlass java/lang/reflect/Modifier
instanceKlass sun/reflect/annotation/AnnotationType
instanceKlass java/lang/Class$AnnotationData
instanceKlass sun/reflect/generics/repository/AbstractRepository
instanceKlass java/lang/Class$Atomic
instanceKlass java/lang/Class$ReflectionData
instanceKlass java/lang/Class$3
instanceKlass java/lang/ThreadLocal
instanceKlass java/nio/charset/spi/CharsetProvider
instanceKlass java/nio/charset/Charset
instanceKlass java/lang/Math
instanceKlass java/util/Hashtable$Entry
instanceKlass sun/misc/VM
instanceKlass java/util/HashMap$Node
instanceKlass java/util/Map$Entry
instanceKlass sun/reflect/Reflection
instanceKlass sun/misc/SharedSecrets
instanceKlass java/lang/ref/Reference$1
instanceKlass sun/misc/JavaLangRefAccess
instanceKlass java/lang/ref/ReferenceQueue$Lock
instanceKlass java/util/Collections$UnmodifiableCollection
instanceKlass java/util/AbstractMap
instanceKlass java/util/Set
instanceKlass java/util/Collections
instanceKlass java/lang/ref/Reference$Lock
instanceKlass sun/reflect/ReflectionFactory
instanceKlass java/util/AbstractCollection
instanceKlass java/util/RandomAccess
instanceKlass java/util/List
instanceKlass java/util/Collection
instanceKlass java/lang/Iterable
instanceKlass java/security/cert/Certificate
instanceKlass sun/reflect/ReflectionFactory$GetReflectionFactoryAction
instanceKlass java/security/PrivilegedAction
instanceKlass java/security/AccessController
instanceKlass java/security/Permission
instanceKlass java/security/Guard
instanceKlass java/lang/String$CaseInsensitiveComparator
instanceKlass java/util/Comparator
instanceKlass java/io/ObjectStreamField
instanceKlass java/lang/Number
instanceKlass java/lang/Character
instanceKlass java/lang/Boolean
instanceKlass java/nio/Buffer
instanceKlass java/lang/StackTraceElement
instanceKlass java/security/CodeSource
instanceKlass sun/misc/Launcher
instanceKlass java/util/jar/Manifest
instanceKlass java/net/URL
instanceKlass java/io/File
instanceKlass java/io/InputStream
instanceKlass java/io/Closeable
instanceKlass java/lang/AutoCloseable
instanceKlass sun/misc/Unsafe
instanceKlass java/lang/AbstractStringBuilder
instanceKlass java/lang/Appendable
instanceKlass java/lang/invoke/CallSite
instanceKlass java/lang/invoke/MethodType
instanceKlass java/lang/invoke/LambdaForm
instanceKlass java/lang/invoke/MethodHandleNatives
instanceKlass java/lang/invoke/MemberName
instanceKlass java/lang/invoke/MethodHandle
instanceKlass sun/reflect/CallerSensitive
instanceKlass java/lang/annotation/Annotation
instanceKlass sun/reflect/FieldAccessor
instanceKlass sun/reflect/ConstantPool
instanceKlass sun/reflect/ConstructorAccessor
instanceKlass sun/reflect/MethodAccessor
instanceKlass sun/reflect/MagicAccessorImpl
instanceKlass java/lang/reflect/Parameter
instanceKlass java/lang/reflect/Member
instanceKlass java/lang/reflect/AccessibleObject
instanceKlass java/util/Dictionary
instanceKlass java/util/Map
instanceKlass java/lang/ThreadGroup
instanceKlass java/lang/Thread$UncaughtExceptionHandler
instanceKlass java/lang/Thread
instanceKlass java/lang/Runnable
instanceKlass java/lang/ref/ReferenceQueue
instanceKlass java/lang/ref/Reference
instanceKlass java/security/AccessControlContext
instanceKlass java/security/ProtectionDomain
instanceKlass java/lang/SecurityManager
instanceKlass java/lang/Throwable
instanceKlass java/lang/System
instanceKlass java/lang/ClassLoader
instanceKlass java/lang/Cloneable
instanceKlass java/lang/Class
instanceKlass java/lang/reflect/Type
instanceKlass java/lang/reflect/GenericDeclaration
instanceKlass java/lang/reflect/AnnotatedElement
instanceKlass java/lang/String
instanceKlass java/lang/CharSequence
instanceKlass java/lang/Comparable
instanceKlass java/io/Serializable
ciInstanceKlass java/lang/Object 1 1 86 100 10 10 10 10 8 10 10 10 100 8 10 3 8 10 10 7 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 100 1 1 1 1 1 1 100 1 1 1 1 12 12 100 12 12 1 12 100 12 12 1 1 12 1 12 12 1 1 1 1 1 1 1 1 1 1 1 1
ciInstanceKlass java/io/Serializable 1 0 7 100 100 1 1 1 1
ciInstanceKlass java/lang/String 1 1 680 10 8 9 9 10 100 10 10 10 10 100 10 10 10 10 10 100 8 10 10 8 10 10 10 10 10 10 10 10 10 10 10 100 10 10 10 10 10 10 10 10 10 7 10 10 10 100 100 10 10 11 11 10 10 9 11 10 10 10 10 7 3 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 11 10 10 10 10 10 100 10 10 8 10 10 3 3 100 10 10 10 10 10 11 100 10 10 100 10 10 10 11 11 11 100 3 10 10 10 10 8 8 8 10 10 10 10 10 10 10 10 10 10 10 100 10 10 10 10 8 10 10 8 8 10 10 10 10 7 9 7 10 7 100 100 100 1 1 1 1 1 1 1 1 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 1 100 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 100 1 1 1 1 1 1 100 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 100 100 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 1 12 12 7 12 1 12 12 12 12 1 100 12 12 12 12 12 1 7 12 12 12 12 12 12 12 12 100 12 12 1 12 12 7 12 100 12 12 12 12 1 12 1 1 12 12 12 12 7 12 12 100 12 12 12 12 12 1 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 100 12 12 1 12 12 1 12 1 12 12 12 12 100 12 12 12 1 12 12 100 12 100 12 12 1 12 12 12 7 12 1 1 1 100 12 12 12 12 12 12 12 12 12 12 12 1 12 12 1 12 1 1 100 12 100 12 100 12 12 1 12 1 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
staticfield java/lang/String serialPersistentFields [Ljava/io/ObjectStreamField; 0 [Ljava/io/ObjectStreamField;
staticfield java/lang/String CASE_INSENSITIVE_ORDER Ljava/util/Comparator; java/lang/String$CaseInsensitiveComparator
ciInstanceKlass java/lang/Class 1 1 1350 9 9 10 10 10 10 9 9 9 9 100 10 10 8 10 8 8 10 10 10 10 10 10 10 10 10 8 10 8 8 10 11 10 10 10 10 10 9 10 100 10 9 7 100 8 10 10 7 10 10 100 100 10 10 10 10 9 10 100 10 100 10 10 10 9 10 10 10 10 10 100 100 10 10 10 10 10 9 10 100 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 100 8 10 10 100 10 100 11 10 10 10 10 10 10 10 8 10 10 10 8 10 10 10 8 10 8 10 10 10 10 8 10 100 10 10 10 10 100 10 100 10 10 10 10 10 10 10 10 100 10 10 10 10 10 10 10 10 10 10 10 10 10 9 10 9 100 10 9 10 100 10 9 10 10 10 10 10 10 10 8 10 10 9 10 7 9 10 10 7 10 10 10 10 9 10 9 10 10 10 10 9 9 10 9 100 10 100 10 10 11 11 11 7 11 11 9 9 7 100 10 9 9 10 10 9 100 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 8 100 10 8 8 8 8 10 10 9 9 10 100 9 7 10 7 7 10 10 10 8 10 100 10 100 10 100 8 10 100 10 10 11 10 100 10 10 8 8 10 10 9 11 100 11 9 10 10 10 9 9 10 10 10 10 10 11 11 11 11 100 11 10 10 100 11 10 10 10 11 11 100 10 10 9 9 10 10 10 10 7 9 100 100 100 100 1 1 1 1 7 1 1 1 1 1 3 1 3 1 3 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 100 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 100 100 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 12 12 12 12 12 12 12 12 12 1 12 1 12 1 1 12 12 12 12 100 12 12 12 12 1 12 1 1 12 12 7 12 7 12 12 7 12 100 12 100 12 100 12 1 12 12 1 1 1 12 12 1 12 7 12 1 1 12 12 12 12 12 1 100 12 12 12 12 12 12 12 12 100 1 12 12 7 12 12 12 12 100 12 12 12 12 12 12 12 100 12 12 12 12 12 12 7 12 12 12 1 1 12 1 12 1 12 100 12 12 12 100 12 12 1 12 12 12 1 12 12 12 1 12 1 12 12 12 12 1 12 1 12 12 12 1 12 1 12 12 12 12 12 12 12 12 1 12 12 12 12 12 12 12 12 12 12 12 12 12 12 1 12 12 1 12 12 100 12 12 12 100 12 12 12 12 1 12 12 12 12 1 12 12 12 1 12 12 100 12 100 12 12 12 12 12 12 12 12 12 12 12 12 1 1 12 100 12 12 100 12 1 12 100 12 12 1 12 12 12 12 12 12 1 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 1 1 100 1 1 1 1 12 12 12 12 12 1 12 1 1 1 1 12 100 12 1 12 1 12 1 1 1 12 100 12 12 1 12 1 1 100 12 12 12 12 1 12 12 100 12 100 12 12 12 12 12 12 12 12 12 12 100 12 12 1 12 100 12 12 1 100 12 12 12 12 1 12 12 12 100 12 12 100 12 12 12 1 12 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
staticfield java/lang/Class serialPersistentFields [Ljava/io/ObjectStreamField; 0 [Ljava/io/ObjectStreamField;
ciInstanceKlass java/lang/Cloneable 1 0 7 100 100 1 1 1 1
instanceKlass sun/reflect/DelegatingClassLoader
instanceKlass java/security/SecureClassLoader
ciInstanceKlass java/lang/ClassLoader 1 1 955 9 9 9 10 10 10 10 7 10 7 7 7 10 10 9 7 10 9 9 9 9 9 9 10 10 7 10 9 9 7 9 100 10 10 10 10 10 10 10 10 10 7 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 100 10 100 10 10 10 10 10 100 100 10 8 10 10 10 8 10 100 8 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 8 11 9 11 10 8 8 10 10 10 10 10 10 10 10 100 100 10 10 10 100 10 10 10 7 10 10 10 10 10 10 100 10 10 10 100 10 10 10 9 9 100 8 10 10 10 7 10 10 100 10 100 10 100 10 10 10 10 10 9 10 10 100 10 7 10 10 10 10 10 10 10 10 11 11 11 100 10 9 10 10 7 8 10 9 8 10 9 8 7 10 10 100 8 10 10 10 8 8 10 10 10 8 8 10 10 7 10 10 10 9 10 10 7 9 10 10 8 8 10 10 10 8 10 10 10 10 9 10 10 10 100 10 10 10 10 9 9 9 9 9 10 7 7 10 1 1 7 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 100 100 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 100 1 1 1 1 1 1 1 1 1 12 12 12 12 7 12 100 12 12 1 1 1 12 12 12 1 12 12 12 12 12 12 12 12 1 12 12 1 12 1 12 12 12 12 12 12 12 12 1 12 7 12 12 12 12 12 12 12 12 12 100 12 7 12 12 12 12 1 12 1 12 7 12 12 12 12 1 1 1 12 12 1 12 1 1 12 12 12 12 7 12 12 12 12 12 12 100 12 12 12 12 12 12 12 12 12 12 7 12 12 1 100 12 12 12 12 1 1 12 12 12 12 12 12 12 12 1 12 12 12 1 12 100 12 7 12 1 12 12 12 100 12 100 12 1 12 7 12 1 12 12 12 12 12 1 1 12 12 1 12 12 1 12 1 100 1 12 12 12 12 12 100 12 12 12 1 1 12 12 12 12 12 12 12 100 12 12 12 12 12 1 1 12 1 12 12 1 1 12 1 1 12 12 1 1 12 12 100 12 1 1 12 1 12 12 12 12 12 1 12 12 1 1 12 1 12 12 12 12 12 12 12 12 1 12 12 12 12 100 12 12 12 12 12 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
staticfield java/lang/ClassLoader nocerts [Ljava/security/cert/Certificate; 0 [Ljava/security/cert/Certificate;
ciInstanceKlass java/lang/System 1 1 403 10 10 10 10 10 9 7 10 11 10 10 10 100 8 10 10 8 10 100 10 8 10 10 100 10 10 9 10 9 9 7 10 10 10 10 10 10 100 100 8 10 10 7 10 100 8 10 8 10 100 8 10 100 10 8 10 10 10 8 10 10 10 10 10 10 10 10 10 7 7 10 10 100 10 10 8 10 10 7 9 10 7 9 10 9 7 10 8 10 8 8 10 10 10 10 10 10 10 10 7 10 10 10 9 9 9 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 1 1 1 100 1 1 100 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 12 12 12 12 12 12 1 7 12 100 12 100 12 12 12 1 1 12 100 12 1 12 1 12 12 100 12 1 12 100 12 12 12 12 12 1 12 12 12 12 12 1 1 1 12 12 1 12 1 1 1 12 1 1 1 1 12 12 100 12 1 12 7 12 12 12 12 12 7 12 12 12 1 1 12 12 1 12 7 12 1 7 12 7 12 1 7 12 12 1 12 12 1 12 1 12 1 1 12 7 12 12 7 12 12 7 12 12 12 1 12 12 12 12 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
staticfield java/lang/System in Ljava/io/InputStream; java/io/BufferedInputStream
staticfield java/lang/System out Ljava/io/PrintStream; java/io/PrintStream
staticfield java/lang/System err Ljava/io/PrintStream; java/io/PrintStream
instanceKlass java/lang/Exception
instanceKlass java/lang/Error
ciInstanceKlass java/lang/Throwable 1 1 400 10 9 9 9 9 9 10 9 10 10 100 100 10 8 10 8 10 10 10 100 8 10 10 10 10 8 9 10 100 10 10 100 10 10 11 10 10 10 8 10 10 7 8 8 10 10 8 8 9 10 100 10 11 8 8 10 8 10 8 100 10 9 10 10 100 10 7 10 10 100 8 10 10 10 10 7 10 10 11 11 11 8 8 10 11 10 9 8 7 10 100 8 10 11 8 9 10 9 11 100 10 10 100 100 1 1 1 100 1 100 1 1 1 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 1 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 12 12 12 12 12 12 12 12 12 1 1 1 12 1 100 12 12 1 1 12 7 12 12 1 100 12 12 1 12 12 1 7 12 100 12 12 12 12 1 12 12 1 1 1 12 12 1 1 12 100 12 1 12 1 1 12 1 12 1 1 12 12 12 100 12 12 1 12 100 1 1 12 100 12 100 12 1 100 12 12 100 12 100 12 12 1 1 100 12 1 1 12 1 1 12 1 12 100 12 12 12 12 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
staticfield java/lang/Throwable UNASSIGNED_STACK [Ljava/lang/StackTraceElement; 0 [Ljava/lang/StackTraceElement;
staticfield java/lang/Throwable SUPPRESSED_SENTINEL Ljava/util/List; java/util/Collections$UnmodifiableRandomAccessList
staticfield java/lang/Throwable EMPTY_THROWABLE_ARRAY [Ljava/lang/Throwable; 0 [Ljava/lang/Throwable;
staticfield java/lang/Throwable $assertionsDisabled Z 1
instanceKlass java/lang/VirtualMachineError
instanceKlass java/lang/LinkageError
instanceKlass java/lang/ThreadDeath
ciInstanceKlass java/lang/Error 1 1 40 10 10 10 10 10 100 7 1 1 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 12 12 12 12 1 1
ciInstanceKlass java/lang/ThreadDeath 0 0 21 10 100 100 1 1 1 5 0 1 1 1 1 1 1 1 1 1 12 1 1
instanceKlass java/security/PrivilegedActionException
instanceKlass java/lang/InterruptedException
instanceKlass java/lang/ReflectiveOperationException
instanceKlass java/lang/RuntimeException
ciInstanceKlass java/lang/Exception 1 1 40 10 10 10 10 10 100 7 1 1 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 12 12 12 12 1 1
instanceKlass java/lang/IllegalArgumentException
instanceKlass java/lang/ArithmeticException
instanceKlass java/lang/NullPointerException
instanceKlass java/lang/IllegalMonitorStateException
instanceKlass java/lang/ArrayStoreException
instanceKlass java/lang/ClassCastException
ciInstanceKlass java/lang/RuntimeException 1 1 40 10 10 10 10 10 100 100 1 1 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 12 12 12 12 1 1
ciInstanceKlass java/lang/SecurityManager 0 0 436 9 10 100 9 10 9 100 10 100 8 10 10 10 10 10 10 10 10 10 100 10 10 9 10 10 10 100 8 10 9 9 8 9 100 10 8 10 10 10 100 10 10 100 100 8 10 8 8 8 8 8 8 10 8 8 8 8 8 10 10 8 100 8 10 8 8 8 8 8 10 8 100 8 8 10 8 9 8 9 9 8 10 100 8 10 10 100 10 10 10 8 9 9 100 10 10 10 9 8 8 9 9 100 10 9 8 8 8 10 10 9 100 10 10 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 100 100 100 1 1 1 1 1 1 100 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 12 12 1 12 12 12 1 100 12 1 1 12 12 12 12 12 12 12 100 12 1 12 100 12 12 100 12 1 1 12 12 1 12 1 1 12 12 12 1 12 1 1 1 12 1 1 1 1 1 1 12 1 1 1 1 1 12 12 1 1 1 1 1 1 1 1 100 12 1 1 1 1 1 100 12 1 12 12 1 12 1 1 12 1 12 12 12 1 12 12 1 12 12 12 12 1 1 12 12 1 12 1 1 1 12 100 12 12 1 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
ciInstanceKlass java/security/ProtectionDomain 1 1 322 9 10 9 7 10 9 9 9 10 7 9 9 7 9 10 100 10 10 10 10 9 10 8 100 8 10 10 10 10 10 8 11 8 10 8 8 10 10 10 10 8 10 8 8 10 9 10 9 10 100 100 10 10 7 10 100 10 10 11 11 11 100 10 10 11 11 10 10 11 10 7 10 10 8 10 7 10 10 7 7 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 1 1 1 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 100 100 100 100 1 1 1 1 1 1 1 12 12 12 1 12 12 12 12 12 1 12 12 1 12 100 12 100 100 12 12 12 100 12 1 1 1 12 12 100 12 12 1 1 12 1 1 12 12 12 12 1 12 1 1 100 12 12 12 12 100 12 1 1 100 12 1 1 12 12 100 12 12 100 12 1 12 12 12 12 100 12 12 12 1 12 7 12 1 7 12 1 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
staticfield java/security/ProtectionDomain debug Lsun/security/util/Debug; null
ciInstanceKlass java/security/AccessControlContext 1 1 365 9 9 10 8 10 10 9 9 9 10 100 100 10 11 11 11 11 100 11 10 10 9 10 11 10 100 100 8 10 10 100 9 9 9 9 9 9 9 10 9 10 10 8 10 10 10 100 10 10 10 10 8 10 8 10 8 8 10 8 10 8 10 10 10 8 8 100 10 10 100 10 8 10 10 10 8 10 10 10 7 10 10 10 10 10 10 10 10 7 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 1 100 1 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 12 100 12 1 100 12 12 12 12 12 100 12 1 12 100 12 12 12 12 1 12 12 100 12 100 12 100 12 100 12 1 1 1 12 12 1 12 12 12 12 12 12 12 7 12 12 12 12 1 12 12 100 12 1 12 100 12 1 100 12 1 100 12 1 1 12 1 12 1 12 12 12 1 1 1 12 12 1 12 1 12 1 12 12 12 1 12 12 12 12 12 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
instanceKlass java/net/URLClassLoader
ciInstanceKlass java/security/SecureClassLoader 1 1 156 10 7 10 9 10 10 9 10 10 10 10 10 7 10 10 7 10 10 10 9 100 10 8 10 10 10 10 8 100 8 10 8 10 10 7 7 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 1 1 1 1 12 1 12 12 7 12 100 12 12 12 12 12 12 12 1 12 1 12 12 12 12 1 1 12 12 12 7 12 1 1 1 12 1 12 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
staticfield java/security/SecureClassLoader debug Lsun/security/util/Debug; null
instanceKlass java/lang/ClassNotFoundException
ciInstanceKlass java/lang/ReflectiveOperationException 1 1 34 10 10 10 10 100 7 1 1 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 12 12 12 1 1
ciInstanceKlass java/lang/ClassNotFoundException 1 1 37 100 10 10 9 100 7 1 1 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 12 12 1 1 1
instanceKlass java/lang/IncompatibleClassChangeError
instanceKlass java/lang/BootstrapMethodError
instanceKlass java/lang/NoClassDefFoundError
ciInstanceKlass java/lang/LinkageError 1 1 31 10 10 10 100 7 1 1 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 12 12 1 1
ciInstanceKlass java/lang/NoClassDefFoundError 0 0 26 10 10 100 100 1 1 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 12 12 1 1
ciInstanceKlass java/lang/ClassCastException 1 1 26 10 10 100 100 1 1 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 12 12 1 1
ciInstanceKlass java/lang/ArrayStoreException 1 1 26 10 10 100 100 1 1 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 12 12 1 1
instanceKlass java/lang/StackOverflowError
instanceKlass java/lang/OutOfMemoryError
ciInstanceKlass java/lang/VirtualMachineError 1 1 34 10 10 10 10 100 100 1 1 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 12 12 12 1 1
ciInstanceKlass java/lang/OutOfMemoryError 1 1 26 10 10 100 100 1 1 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 12 12 1 1
ciInstanceKlass java/lang/StackOverflowError 1 1 26 10 10 100 100 1 1 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 12 12 1 1
ciInstanceKlass java/lang/IllegalMonitorStateException 1 1 26 10 10 100 100 1 1 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 12 12 1 1
instanceKlass java/lang/ref/PhantomReference
instanceKlass java/lang/ref/FinalReference
instanceKlass java/lang/ref/WeakReference
instanceKlass java/lang/ref/SoftReference
ciInstanceKlass java/lang/ref/Reference 1 1 164 9 9 100 9 10 100 10 100 10 9 9 10 9 9 100 10 10 10 7 10 10 10 10 7 8 10 7 10 10 10 7 10 10 7 7 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 100 100 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 12 12 1 12 12 1 12 1 12 12 7 12 12 12 12 1 12 12 1 12 12 12 7 12 1 1 12 1 12 12 12 1 7 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
instanceKlass sun/util/locale/LocaleObjectCache$CacheEntry
ciInstanceKlass java/lang/ref/SoftReference 1 1 47 10 9 9 10 10 7 7 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 12 12 12 12 12 1 1 1
instanceKlass java/util/logging/LogManager$LoggerWeakRef
instanceKlass java/lang/ClassValue$Entry
instanceKlass java/util/WeakHashMap$Entry
instanceKlass java/lang/ThreadLocal$ThreadLocalMap$Entry
ciInstanceKlass java/lang/ref/WeakReference 1 1 31 10 10 100 7 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 12 1 1
instanceKlass java/lang/ref/Finalizer
ciInstanceKlass java/lang/ref/FinalReference 1 1 36 10 100 8 10 100 7 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 1 1 12 1 1 1
instanceKlass sun/misc/Cleaner
ciInstanceKlass java/lang/ref/PhantomReference 1 1 30 10 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 1 1
ciInstanceKlass java/lang/ref/Finalizer 1 1 157 10 9 9 9 9 9 10 10 7 10 10 10 10 100 11 100 10 100 10 10 10 100 10 10 7 10 7 10 10 10 10 7 10 7 10 10 10 7 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 12 12 12 12 12 12 12 12 1 12 12 12 12 1 100 12 1 12 1 12 100 12 100 12 1 12 12 1 1 12 12 7 12 1 12 1 12 12 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
staticfield java/lang/ref/Finalizer lock Ljava/lang/Object; java/lang/Object
instanceKlass java/lang/ref/ReferenceQueue$Null
ciInstanceKlass java/lang/ref/ReferenceQueue 1 1 146 10 7 10 9 9 9 9 9 9 9 100 10 9 100 10 10 10 100 8 10 10 10 5 0 10 11 7 10 7 10 7 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 100 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 12 1 12 12 12 12 100 12 12 12 12 1 12 1 100 12 12 12 1 1 12 100 12 12 12 100 12 1 7 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
staticfield java/lang/ref/ReferenceQueue $assertionsDisabled Z 1
instanceKlass java/util/logging/LogManager$Cleaner
instanceKlass java/lang/ref/Finalizer$FinalizerThread
instanceKlass java/lang/ref/Reference$ReferenceHandler
ciInstanceKlass java/lang/Thread 1 1 608 9 9 9 9 100 8 10 3 8 3 10 10 100 8 10 9 10 10 10 10 10 10 10 9 10 10 9 10 9 10 9 10 9 10 9 9 10 9 10 9 10 9 100 10 10 9 9 9 7 7 10 8 10 10 10 10 10 100 10 10 10 10 100 11 9 10 10 10 9 10 9 10 100 10 10 100 10 10 11 10 100 10 10 10 7 10 10 10 10 10 10 10 10 10 10 100 8 10 10 10 8 10 8 10 8 8 10 10 7 8 10 9 9 10 10 10 9 10 100 10 11 9 9 10 100 10 11 100 10 10 11 10 100 10 10 10 8 9 10 11 10 11 10 7 8 100 1 1 100 1 100 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 3 1 3 1 3 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 100 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 12 12 12 12 1 1 12 1 12 12 1 1 12 12 7 12 100 12 7 12 12 12 12 12 12 12 12 12 12 12 12 12 7 12 12 12 12 12 100 12 12 12 12 1 12 12 12 12 1 1 1 12 12 12 12 12 1 12 12 12 1 12 100 12 12 12 12 12 100 12 12 1 12 1 12 100 12 12 1 12 12 1 12 12 12 12 12 12 12 12 12 1 1 12 12 1 12 1 1 1 100 12 100 12 1 12 12 12 12 12 12 1 12 100 12 12 12 12 1 12 100 12 1 12 12 12 12 1 12 12 100 12 12 12 12 100 12 12 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
staticfield java/lang/Thread EMPTY_STACK_TRACE [Ljava/lang/StackTraceElement; 0 [Ljava/lang/StackTraceElement;
staticfield java/lang/Thread SUBCLASS_IMPLEMENTATION_PERMISSION Ljava/lang/RuntimePermission; java/lang/RuntimePermission
ciInstanceKlass java/lang/ThreadGroup 1 1 302 10 9 8 9 7 9 9 10 10 10 10 10 9 9 10 10 9 10 9 9 10 100 10 10 10 9 10 10 9 10 10 10 10 10 10 10 10 10 10 10 100 10 10 10 7 10 100 10 9 10 8 10 10 10 10 11 100 9 100 10 8 10 10 8 10 10 10 10 10 8 10 8 10 8 7 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 100 1 1 1 1 1 12 12 1 12 1 12 12 12 12 12 12 12 12 12 12 12 12 100 12 12 12 100 12 12 7 12 100 12 12 12 12 12 12 12 12 12 12 12 12 12 12 1 12 12 1 12 12 12 12 1 100 12 12 12 12 1 12 1 1 12 12 1 12 100 12 100 12 12 100 1 1 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
instanceKlass java/util/Hashtable
ciInstanceKlass java/util/Dictionary 1 1 36 10 100 7 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 1 1
instanceKlass java/util/Properties
ciInstanceKlass java/util/Hashtable 1 1 523 100 9 9 9 10 10 100 100 10 8 10 10 10 10 10 8 10 9 7 7 4 10 9 4 10 11 10 10 10 100 10 9 10 9 10 10 3 9 9 3 10 10 10 11 11 11 11 7 11 11 10 10 10 9 9 9 100 100 10 10 8 10 10 8 10 8 10 7 10 10 100 10 10 7 10 100 10 10 7 11 11 100 10 10 10 11 100 10 100 11 11 10 10 10 10 10 8 10 100 8 10 4 10 4 10 8 10 10 100 11 10 10 10 10 7 100 100 100 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 5 0 1 1 1 1 1 1 1 1 1 1 3 1 3 1 3 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 100 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 100 1 1 1 1 100 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 12 12 12 12 1 1 1 12 12 12 12 7 12 1 12 12 1 1 7 12 12 12 12 12 12 12 1 12 7 12 12 12 12 12 12 12 12 12 12 7 12 7 12 12 1 12 12 12 12 12 12 12 1 1 12 1 12 1 1 7 12 1 12 12 1 12 12 1 1 12 1 12 12 1 100 12 100 12 1 100 12 100 12 12 100 12 12 12 100 12 12 1 1 12 12 1 12 100 12 1 100 12 12 12 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
ciInstanceKlass java/util/Properties 1 1 342 10 10 9 10 7 10 10 10 10 9 10 100 3 100 8 10 7 10 10 100 10 10 10 10 10 8 10 10 10 10 10 100 100 10 10 100 8 10 10 100 10 10 100 10 10 10 10 11 11 10 10 8 10 10 100 10 10 8 10 100 10 10 10 7 10 10 10 10 8 10 8 10 10 9 7 100 1 1 1 1 1 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 100 100 1 1 1 100 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 100 100 100 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 12 12 12 1 12 12 12 12 12 12 1 1 1 12 1 12 12 1 12 12 12 12 12 1 12 12 12 12 12 1 1 12 12 1 1 12 12 1 12 1 12 7 12 12 12 12 1 12 100 12 1 12 12 1 12 1 12 12 1 12 12 12 1 100 12 1 100 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
staticfield java/util/Properties hexDigit [C 16
instanceKlass java/lang/reflect/Executable
instanceKlass java/lang/reflect/Field
ciInstanceKlass java/lang/reflect/AccessibleObject 1 1 174 10 9 10 10 7 10 7 100 8 10 9 10 100 8 10 11 10 10 10 9 10 10 100 10 10 7 8 10 7 10 10 7 9 7 7 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 1 1 1 1 1 1 1 7 12 12 100 12 12 1 12 1 1 1 12 12 12 1 1 12 12 12 12 12 12 100 12 12 12 100 12 1 1 1 1 1 7 12 1 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
staticfield java/lang/reflect/AccessibleObject ACCESS_PERMISSION Ljava/security/Permission; java/lang/reflect/ReflectPermission
staticfield java/lang/reflect/AccessibleObject reflectionFactory Lsun/reflect/ReflectionFactory; sun/reflect/ReflectionFactory
ciInstanceKlass java/lang/reflect/Field 1 1 407 9 10 10 10 9 10 10 10 10 9 9 9 9 9 9 9 100 8 10 7 10 9 9 10 100 10 10 10 10 10 10 10 100 10 8 10 10 8 10 10 8 10 11 9 10 10 10 10 11 11 11 11 11 11 11 11 11 11 11 11 11 11 11 11 11 11 10 10 9 10 10 10 10 11 10 100 10 10 9 10 11 10 10 9 10 7 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 100 100 1 1 1 100 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 1 1 1 1 1 1 1 12 12 100 12 100 12 12 12 12 100 12 12 12 12 12 12 12 12 12 1 1 12 1 12 12 12 12 1 12 12 12 12 12 100 100 12 1 1 12 12 1 12 12 1 100 12 100 12 12 12 12 7 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 7 12 12 100 12 12 100 12 1 100 12 100 12 12 100 12 100 12 12 12 100 12 100 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1
ciInstanceKlass java/lang/reflect/Parameter 0 0 231 10 9 9 9 9 9 9 100 10 10 10 100 10 10 11 10 10 10 10 10 8 8 10 10 10 8 10 8 10 10 10 10 10 10 10 10 10 10 11 10 100 10 10 10 10 10 9 100 10 11 11 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 100 100 100 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 12 12 12 12 12 12 12 1 12 12 100 12 1 12 100 12 12 100 12 12 12 12 1 1 100 12 12 12 1 1 12 12 12 12 12 12 12 100 12 12 100 12 100 12 1 100 12 12 12 12 12 12 1 12 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
instanceKlass java/lang/reflect/Constructor
instanceKlass java/lang/reflect/Method
ciInstanceKlass java/lang/reflect/Executable 1 1 446 10 10 10 11 10 10 10 8 10 10 10 100 8 100 10 10 10 10 8 10 100 8 10 8 10 10 8 10 10 11 10 8 8 10 10 100 10 100 10 10 10 10 10 10 100 10 10 10 10 10 100 10 100 8 10 10 3 100 8 10 10 10 10 10 8 8 8 9 10 100 8 9 10 10 10 10 10 10 100 10 10 10 10 11 10 100 10 10 9 10 10 10 9 10 10 9 10 9 10 9 100 7 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 12 100 12 12 100 12 100 12 12 12 1 12 12 12 1 1 1 12 12 12 1 12 1 1 12 1 12 100 1 12 12 12 1 1 100 12 12 1 12 1 12 12 100 12 12 12 1 12 12 12 12 100 12 12 1 1 12 12 1 1 12 12 12 12 1 1 1 12 12 1 1 12 12 12 12 12 12 12 12 12 100 12 12 100 12 12 1 100 12 12 12 12 12 12 100 12 100 12 12 12 12 12 12 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
ciInstanceKlass java/lang/reflect/Method 1 1 378 9 10 10 9 10 10 10 10 9 9 9 9 9 9 9 9 9 9 9 100 8 10 100 10 9 10 10 100 100 10 10 10 100 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 11 9 10 10 10 10 11 10 100 10 10 10 10 9 10 10 10 10 10 11 10 100 100 100 10 8 10 10 10 10 10 10 10 8 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 100 12 100 12 12 12 12 100 12 12 12 12 12 12 12 12 12 12 12 12 12 1 1 12 1 12 12 12 12 1 1 12 12 100 12 12 100 12 12 12 100 12 12 100 100 12 12 12 12 12 12 12 12 12 100 12 100 12 12 12 12 100 12 12 1 12 12 12 12 12 100 12 12 100 12 100 12 100 12 100 12 100 12 1 1 1 1 12 12 12 12 12 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
ciInstanceKlass java/lang/reflect/Constructor 1 1 359 10 10 9 10 10 10 9 10 9 9 9 9 9 9 9 9 100 8 10 7 10 9 10 10 10 10 100 100 10 7 10 10 10 10 10 10 10 10 10 10 10 9 10 10 10 10 100 8 10 11 10 10 10 9 10 10 10 10 10 10 10 10 10 100 8 10 10 10 10 10 10 11 9 10 7 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 100 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 100 12 100 12 12 12 12 100 12 12 12 12 12 12 12 12 12 12 12 1 1 12 1 12 12 12 7 12 12 12 1 1 7 12 12 100 12 12 100 12 12 12 12 100 12 12 12 12 100 12 12 12 12 1 1 12 7 12 12 12 12 12 7 12 12 12 12 12 12 12 12 12 1 1 12 12 12 12 100 12 100 12 100 12 100 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1
instanceKlass sun/reflect/FieldAccessorImpl
instanceKlass sun/reflect/ConstructorAccessorImpl
instanceKlass sun/reflect/MethodAccessorImpl
ciInstanceKlass sun/reflect/MagicAccessorImpl 1 1 16 10 100 7 1 1 1 1 1 1 1 1 1 12 1 1
ciInstanceKlass sun/reflect/MethodAccessorImpl 0 0 25 10 100 100 100 1 1 1 1 1 1 1 1 1 1 100 100 1 1 12 1 1 1 1 1
instanceKlass sun/reflect/DelegatingConstructorAccessorImpl
instanceKlass sun/reflect/NativeConstructorAccessorImpl
ciInstanceKlass sun/reflect/ConstructorAccessorImpl 1 1 27 10 100 7 100 1 1 1 1 1 1 1 1 1 1 100 100 100 1 1 12 1 1 1 1 1 1
ciInstanceKlass sun/reflect/DelegatingClassLoader 0 0 18 10 100 100 1 1 1 1 1 1 1 1 1 1 1 12 1 1
ciInstanceKlass sun/reflect/ConstantPool 0 0 111 10 9 10 10 10 10 10 10 10 10 10 10 10 10 10 10 100 100 8 10 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 1 1 100 12 1 1 1 1
instanceKlass sun/reflect/UnsafeFieldAccessorImpl
ciInstanceKlass sun/reflect/FieldAccessorImpl 1 1 59 10 100 7 100 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 1 1 1 1 1
instanceKlass sun/reflect/UnsafeStaticFieldAccessorImpl
ciInstanceKlass sun/reflect/UnsafeFieldAccessorImpl 1 1 257 10 9 10 10 9 10 9 10 10 9 10 10 10 10 100 10 10 10 8 10 10 100 8 10 8 10 8 10 100 10 10 8 10 8 10 8 10 8 10 8 10 8 10 8 10 8 10 8 10 10 8 8 8 8 8 8 10 8 8 8 10 10 7 7 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 12 7 12 7 12 12 7 12 12 12 12 12 12 100 12 100 12 12 1 12 12 1 12 1 1 12 1 12 1 12 1 12 1 12 1 100 12 1 100 12 1 100 12 1 100 12 1 100 12 1 100 12 1 100 12 1 100 12 12 1 1 1 1 1 1 100 12 1 1 1 12 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
staticfield sun/reflect/UnsafeFieldAccessorImpl unsafe Lsun/misc/Unsafe; sun/misc/Unsafe
instanceKlass sun/reflect/UnsafeQualifiedStaticFieldAccessorImpl
ciInstanceKlass sun/reflect/UnsafeStaticFieldAccessorImpl 1 1 43 10 9 10 9 7 7 8 10 7 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 12 7 12 12 1 1 7 12 1 1 1 1 1 1 1 1 1
ciInstanceKlass sun/reflect/CallerSensitive 0 0 17 100 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1
instanceKlass java/lang/invoke/DirectMethodHandle
ciInstanceKlass java/lang/invoke/MethodHandle 1 1 490 9 10 10 10 9 10 10 10 10 10 10 11 10 10 10 9 10 100 100 10 8 10 10 8 10 10 10 10 10 10 10 10 10 7 10 10 10 8 10 10 10 10 10 8 10 8 10 8 10 9 100 10 9 9 8 10 10 10 10 10 10 10 10 8 10 10 10 10 10 10 9 8 10 10 8 10 10 10 10 10 10 8 10 10 100 9 10 100 10 10 9 10 10 8 9 9 9 10 10 10 10 7 10 10 8 10 10 100 10 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 12 12 12 100 12 12 12 100 12 12 100 12 12 12 100 12 12 12 12 12 12 1 1 1 12 12 1 12 12 7 12 12 12 12 12 100 12 100 12 1 12 12 12 1 7 12 12 12 12 12 1 12 1 12 1 100 12 12 1 100 12 100 1 12 12 12 12 12 12 12 12 1 12 12 12 12 12 12 12 1 12 12 1 12 12 100 12 12 12 1 12 12 1 12 1 100 12 12 12 12 12 1 12 12 12 7 12 12 12 12 1 12 12 12 12 1 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
staticfield java/lang/invoke/MethodHandle FORM_OFFSET J 20
staticfield java/lang/invoke/MethodHandle $assertionsDisabled Z 1
ciInstanceKlass java/lang/invoke/DirectMethodHandle 0 0 799 100 100 100 10 10 10 100 10 10 10 10 10 100 100 10 10 10 10 10 10 10 9 100 10 9 10 10 10 10 10 10 100 10 10 10 10 100 10 100 10 100 10 10 10 100 10 10 100 10 10 10 10 10 10 10 10 8 10 10 10 10 10 9 100 10 10 10 100 10 8 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 8 8 8 8 8 8 8 8 8 8 8 10 10 100 9 100 10 100 10 10 10 10 100 9 10 9 9 9 10 100 10 9 10 10 8 10 10 10 10 9 9 10 10 100 100 100 9 10 10 10 10 9 10 100 10 100 10 10 9 9 10 9 10 10 10 10 10 9 10 10 10 10 9 9 10 10 9 9 9 9 10 9 9 10 10 9 10 9 10 10 100 10 10 10 10 10 8 8 8 9 10 100 10 10 9 9 9 9 9 9 8 8 8 8 10 10 9 9 100 1 100 1 1 1 1 1 1 100 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 12 12 12 1 12 12 12 12 12 1 1 12 12 12 12 12 12 12 12 1 12 12 12 12 12 12 12 1 100 12 12 12 12 1 12 1 12 1 12 12 12 1 12 12 1 12 12 12 12 100 12 100 12 12 12 12 12 12 100 12 1 12 100 12 12 1 1 12 12 12 12 12 12 12 12 12 12 12 12 100 12 12 12 12 12 1 1 1 1 1 1 1 1 1 1 1 12 12 1 12 1 12 1 100 12 12 12 12 1 12 12 12 12 12 12 12 12 100 12 12 1 12 12 12 12 12 12 100 12 12 1 1 1 12 12 12 12 12 12 12 1 12 1 12 12 12 12 12 12 12 12 12 12 12 12 12 100 12 12 100 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 1 12 12 100 12 12 12 1 1 1 100 12 1 12 12 12 12 12 12 12 12 1 1 1 1 12 12 12 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
ciInstanceKlass java/lang/invoke/MemberName 1 1 709 100 7 100 10 10 10 9 9 10 9 10 10 10 10 10 10 10 9 10 100 100 10 8 10 10 10 10 9 8 10 100 100 10 10 100 100 7 10 9 100 8 10 10 10 10 10 10 10 10 10 8 8 8 10 10 9 3 10 10 10 10 10 10 10 10 10 100 8 10 10 8 9 8 9 10 8 10 10 10 10 10 100 10 10 8 10 10 8 10 10 100 10 10 8 8 10 10 10 10 10 10 10 10 10 3 10 3 10 3 3 3 3 3 3 10 100 10 3 10 3 10 10 10 10 10 10 10 10 10 10 10 10 100 10 10 10 100 10 10 10 10 100 10 10 8 10 10 10 10 10 10 10 10 10 10 10 100 10 100 8 10 10 10 10 10 10 10 8 8 8 8 10 10 10 8 8 10 8 10 10 10 8 8 10 10 8 8 100 10 8 8 8 8 10 100 100 100 10 100 10 100 10 9 10 100 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 3 1 3 1 3 1 3 1 3 1 3 1 1 1 1 1 1 1 1 3 1 1 1 1 3 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 12 12 12 12 12 12 12 12 12 12 12 12 12 12 100 12 12 1 1 12 1 12 12 12 12 12 1 100 12 1 1 12 1 12 12 1 1 12 12 12 12 12 12 12 12 12 1 1 1 100 12 12 12 12 12 12 12 12 12 12 12 1 12 12 100 100 12 1 12 12 12 12 12 1 12 12 1 12 12 1 12 12 1 12 12 1 1 12 12 12 12 12 12 12 12 12 12 12 100 1 1 100 12 12 12 12 12 100 12 12 12 12 12 12 1 12 1 12 12 1 12 100 12 100 12 12 12 12 12 12 12 1 12 1 1 100 12 12 100 12 12 12 1 1 1 1 12 12 12 1 1 12 1 12 12 1 1 12 1 1 1 1 1 1 1 12 1 1 1 1 1 100 12 12 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
staticfield java/lang/invoke/MemberName $assertionsDisabled Z 1
ciInstanceKlass java/lang/invoke/MethodHandleNatives 1 1 499 100 10 9 10 100 10 10 10 10 8 8 8 8 8 8 8 8 8 8 100 10 100 10 10 100 10 10 8 10 8 10 8 10 9 8 10 100 10 100 100 8 100 7 10 10 100 9 10 10 10 100 10 10 10 10 100 10 9 8 10 8 10 8 8 8 100 8 10 10 10 10 10 100 10 10 8 8 10 10 10 8 10 8 8 9 10 10 10 100 100 10 10 10 100 100 10 10 100 10 10 100 100 10 10 10 10 100 10 10 10 10 10 10 10 8 8 100 10 100 10 10 10 10 7 10 10 10 9 10 10 10 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 100 1 1 1 1 100 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 100 100 100 100 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 12 12 1 12 12 12 1 1 1 1 1 1 1 1 1 1 1 12 1 12 100 12 1 12 1 12 1 12 1 12 100 12 1 100 12 1 12 1 1 1 1 1 12 1 100 12 12 12 100 12 1 12 100 12 12 12 100 12 12 1 12 1 12 1 1 1 1 1 12 12 12 12 12 1 12 12 1 1 12 12 1 100 12 1 1 12 12 12 12 1 1 12 1 1 1 1 1 100 12 12 1 12 100 12 12 12 12 12 1 1 1 12 1 12 12 12 12 1 12 12 12 12 7 12 12 12 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
staticfield java/lang/invoke/MethodHandleNatives COUNT_GWT Z 1
staticfield java/lang/invoke/MethodHandleNatives $assertionsDisabled Z 1
ciInstanceKlass java/lang/invoke/LambdaForm 0 0 1101 100 100 9 10 10 9 9 10 100 10 9 10 9 10 100 9 10 9 9 9 10 100 10 10 10 10 10 10 10 9 10 8 10 10 10 10 100 10 10 8 10 10 10 100 8 10 10 10 10 10 100 10 100 10 10 9 9 10 10 100 10 10 10 10 10 10 10 10 10 10 8 10 10 8 8 9 9 9 10 10 10 9 10 10 10 10 10 10 10 10 8 8 8 8 8 8 8 8 10 9 10 10 10 10 10 10 10 100 10 10 9 10 10 10 10 10 10 8 10 100 100 10 10 10 10 11 11 11 100 10 10 10 10 100 10 8 10 10 8 10 10 10 100 10 8 10 9 10 10 8 8 10 10 8 8 8 10 10 9 10 8 8 9 10 10 8 8 8 100 8 100 8 100 8 10 8 10 9 10 10 9 10 10 10 10 10 10 10 10 10 10 8 100 10 10 9 10 8 8 100 8 8 9 8 8 8 10 8 8 8 10 10 8 8 8 10 8 10 8 8 8 8 8 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 9 8 10 11 11 9 9 9 9 9 10 10 8 10 8 9 100 10 100 10 100 10 9 10 10 10 10 9 10 10 9 10 9 10 9 100 9 9 10 100 10 10 10 10 9 100 1 100 1 100 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 3 1 3 1 3 1 1 1 3 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 100 1 1 1 1 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 12 12 12 12 12 12 1 12 12 12 100 12 12 12 12 12 12 12 1 12 12 100 12 100 12 12 12 12 12 12 1 12 12 12 100 12 1 12 1 12 12 12 1 1 12 12 12 12 12 1 12 1 12 12 12 12 12 12 1 12 12 12 12 12 12 100 12 12 1 12 12 1 1 12 12 12 12 100 12 12 12 100 12 12 12 12 12 12 12 1 1 1 1 1 1 1 1 12 12 12 12 12 12 12 12 12 1 12 12 12 12 12 12 12 100 12 12 1 1 100 12 12 12 100 12 100 12 12 1 12 12 12 12 1 12 1 12 12 1 12 12 1 12 1 12 12 12 12 1 1 12 12 1 1 1 12 12 100 12 12 1 1 12 12 12 1 1 1 1 1 1 1 1 1 12 1 12 100 12 12 12 12 12 12 12 12 12 12 12 12 1 12 12 12 12 1 1 1 1 1 12 1 1 1 100 12 1 1 1 12 12 1 1 1 12 1 12 1 1 1 1 1 12 12 12 100 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 1 12 12 12 12 12 12 12 12 12 12 1 12 1 12 1 12 1 12 1 12 12 12 12 12 12 12 100 12 12 12 12 12 12 12 12 1 12 12 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
ciInstanceKlass java/lang/invoke/MethodType 0 0 671 100 10 10 10 9 10 100 9 9 10 9 8 10 10 9 9 10 100 10 8 10 10 10 100 8 10 100 10 10 10 10 11 9 11 100 10 9 10 10 10 10 10 9 100 10 100 10 10 10 10 10 10 10 10 10 10 8 8 10 9 100 10 10 10 10 10 10 10 10 10 8 10 10 10 10 10 11 10 10 10 10 10 100 10 10 10 10 9 100 10 10 10 10 10 10 10 10 8 8 10 8 10 10 9 10 10 10 10 10 10 10 10 10 10 10 10 9 100 10 10 10 10 10 8 10 11 9 10 10 10 10 10 9 9 10 9 10 10 100 10 100 10 100 9 8 10 10 8 100 100 10 100 1 1 1 1 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 3 1 3 1 3 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 100 1 1 1 1 1 1 1 1 1 1 100 100 1 1 100 1 1 1 1 1 1 1 1 100 1 1 1 100 1 1 1 1 1 1 100 1 1 1 12 12 12 12 100 12 12 12 100 12 100 12 1 100 12 12 100 100 12 1 1 12 12 12 1 1 12 1 12 12 12 100 12 12 12 1 100 12 12 12 12 12 12 12 12 1 12 1 12 12 100 12 12 12 12 12 12 12 12 1 1 12 12 1 12 12 12 12 100 12 12 12 1 12 12 100 12 12 12 12 12 12 12 12 12 1 12 12 12 12 1 12 100 12 12 100 12 12 12 1 1 12 1 100 12 12 12 12 12 12 12 12 12 100 12 12 12 12 12 12 1 12 12 12 100 12 12 1 100 12 12 12 12 12 100 12 12 12 12 12 100 12 12 100 12 12 12 1 1 12 12 12 1 1 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
ciInstanceKlass java/lang/BootstrapMethodError 0 0 46 10 10 10 10 10 100 100 1 1 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 1 1 12 12 12 100 12 12 1 1 1 1 1 1 1 1
instanceKlass java/lang/invoke/VolatileCallSite
instanceKlass java/lang/invoke/MutableCallSite
instanceKlass java/lang/invoke/ConstantCallSite
ciInstanceKlass java/lang/invoke/CallSite 0 0 367 10 10 9 10 10 100 100 10 100 10 10 10 100 100 10 10 10 8 10 10 10 9 10 10 10 10 100 8 10 10 10 100 10 9 10 10 10 10 9 9 10 10 9 10 10 10 10 10 10 100 10 10 10 10 10 10 100 100 8 10 10 10 10 10 100 100 8 10 10 100 8 10 100 10 10 10 8 10 10 8 10 10 100 10 8 10 10 100 100 10 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 100 100 100 100 100 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 1 1 12 12 12 12 12 1 1 12 1 12 12 12 1 1 100 12 12 1 12 12 12 12 12 100 12 12 1 1 12 12 1 12 12 12 12 12 100 12 100 12 12 100 12 12 12 12 12 12 12 100 12 12 12 12 12 12 12 12 1 1 1 12 12 100 12 12 1 1 1 12 1 1 12 1 12 12 100 12 12 12 12 12 1 12 12 12 1 1 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
ciInstanceKlass java/lang/invoke/ConstantCallSite 0 0 49 10 9 10 100 10 9 100 10 10 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 12 12 12 1 12 12 1 12 1 1 1 1
ciInstanceKlass java/lang/invoke/MutableCallSite 0 0 67 10 10 9 10 10 10 9 10 10 100 10 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 12 12 12 12 12 12 12 100 12 1 12 1 1 1 1 1 1 1 1 1 1 1
ciInstanceKlass java/lang/invoke/VolatileCallSite 0 0 41 10 10 10 10 10 10 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 12 12 12 12 12 1 1 1 1 1 1 1
instanceKlass java/lang/StringBuilder
instanceKlass java/lang/StringBuffer
ciInstanceKlass java/lang/AbstractStringBuilder 1 1 371 7 10 9 9 10 10 10 7 3 10 3 100 10 100 10 10 10 10 100 10 10 10 8 10 10 10 10 10 10 10 10 10 10 10 7 10 11 10 8 100 10 8 10 10 8 8 10 10 11 3 8 10 10 100 5 0 8 10 10 10 10 10 10 10 10 100 10 8 8 10 10 10 8 8 8 10 10 8 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 7 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 12 12 12 12 12 7 12 1 12 1 1 12 12 100 12 12 1 12 12 1 12 100 12 12 12 12 12 12 100 1 12 12 1 1 1 12 12 1 1 12 12 1 12 12 1 1 12 12 100 12 12 12 12 12 1 1 1 12 12 12 1 1 1 12 12 1 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
ciInstanceKlass java/lang/StringBuffer 1 1 425 10 10 10 11 10 10 9 9 10 10 9 10 100 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 7 10 10 8 10 8 10 8 10 10 10 10 7 10 100 8 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 7 10 9 9 9 7 7 100 100 1 1 1 1 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 100 1 1 1 100 1 1 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 12 12 12 12 12 12 12 12 12 1 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 7 12 1 12 100 12 1 12 1 12 1 12 12 100 12 12 12 1 1 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 1 12 7 12 7 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
staticfield java/lang/StringBuffer serialPersistentFields [Ljava/io/ObjectStreamField; 3 [Ljava/io/ObjectStreamField;
ciInstanceKlass java/lang/StringBuilder 1 1 366 10 10 10 11 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 7 9 9 10 10 10 10 10 10 10 100 100 8 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 7 7 100 100 1 1 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 1 12 12 12 100 12 12 12 100 12 12 12 1 1 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
ciInstanceKlass sun/misc/Unsafe 1 1 420 10 10 10 10 100 8 10 9 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 100 10 10 7 7 8 10 10 7 10 9 7 9 7 9 7 9 7 9 7 9 7 9 7 9 7 9 10 9 9 9 9 9 9 9 9 9 10 9 7 1 1 1 1 1 3 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 7 12 7 12 7 12 1 1 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 100 12 100 12 12 12 12 12 12 12 12 12 12 12 1 12 1 1 12 1 12 12 1 12 1 12 1 12 1 12 1 12 1 12 1 12 1 12 12 12 12 12 12 12 12 12 12 12 12 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
staticfield sun/misc/Unsafe theUnsafe Lsun/misc/Unsafe; sun/misc/Unsafe
staticfield sun/misc/Unsafe ARRAY_BOOLEAN_BASE_OFFSET I 16
staticfield sun/misc/Unsafe ARRAY_BYTE_BASE_OFFSET I 16
staticfield sun/misc/Unsafe ARRAY_SHORT_BASE_OFFSET I 16
staticfield sun/misc/Unsafe ARRAY_CHAR_BASE_OFFSET I 16
staticfield sun/misc/Unsafe ARRAY_INT_BASE_OFFSET I 16
staticfield sun/misc/Unsafe ARRAY_LONG_BASE_OFFSET I 16
staticfield sun/misc/Unsafe ARRAY_FLOAT_BASE_OFFSET I 16
staticfield sun/misc/Unsafe ARRAY_DOUBLE_BASE_OFFSET I 16
staticfield sun/misc/Unsafe ARRAY_OBJECT_BASE_OFFSET I 16
staticfield sun/misc/Unsafe ARRAY_BOOLEAN_INDEX_SCALE I 1
staticfield sun/misc/Unsafe ARRAY_BYTE_INDEX_SCALE I 1
staticfield sun/misc/Unsafe ARRAY_SHORT_INDEX_SCALE I 2
staticfield sun/misc/Unsafe ARRAY_CHAR_INDEX_SCALE I 2
staticfield sun/misc/Unsafe ARRAY_INT_INDEX_SCALE I 4
staticfield sun/misc/Unsafe ARRAY_LONG_INDEX_SCALE I 8
staticfield sun/misc/Unsafe ARRAY_FLOAT_INDEX_SCALE I 4
staticfield sun/misc/Unsafe ARRAY_DOUBLE_INDEX_SCALE I 8
staticfield sun/misc/Unsafe ARRAY_OBJECT_INDEX_SCALE I 4
staticfield sun/misc/Unsafe ADDRESS_SIZE I 8
instanceKlass java/util/zip/ZipFile$ZipFileInputStream
instanceKlass java/io/FilterInputStream
instanceKlass java/io/FileInputStream
instanceKlass java/io/ByteArrayInputStream
ciInstanceKlass java/io/InputStream 1 1 78 10 10 100 10 100 10 10 100 100 5 0 10 8 10 7 100 1 1 1 3 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 1 1 12 12 1 1 12 1 1 100 12 1 12 1 1 1 1 1 1
ciInstanceKlass java/io/ByteArrayInputStream 1 1 75 10 9 9 9 9 10 100 10 100 10 10 7 7 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 12 12 12 12 12 100 12 1 1 7 12 1 1 1 1 1 1 1 1 1
ciInstanceKlass java/io/File 1 1 659 9 9 10 9 9 9 10 9 9 100 10 8 10 10 100 10 10 10 10 10 100 8 10 10 8 10 8 10 8 10 8 10 8 10 8 10 8 10 9 10 10 10 10 10 10 10 7 10 10 10 10 10 100 8 10 10 10 8 10 7 10 10 10 10 100 10 100 10 10 10 10 10 8 100 10 100 100 10 10 10 7 10 10 10 10 10 10 10 10 10 10 10 7 100 10 11 11 11 11 100 10 10 10 10 100 11 10 10 10 10 10 10 10 8 10 10 10 10 10 10 10 10 100 8 10 10 10 8 8 10 10 100 8 10 10 10 10 10 10 10 10 8 10 10 9 9 10 9 10 9 10 10 10 10 10 10 9 10 9 9 10 10 10 8 100 7 100 100 100 1 1 7 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 100 100 1 1 100 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 100 100 1 1 1 100 100 100 1 1 1 1 100 1 1 1 1 12 12 12 12 12 12 12 12 12 1 1 12 12 1 12 12 12 12 1 1 12 12 1 12 1 12 1 12 1 12 1 12 1 12 1 12 12 12 12 12 12 12 12 12 1 12 12 12 12 12 1 1 12 12 1 12 1 12 12 12 1 1 12 12 12 12 1 1 12 1 1 12 7 12 100 12 1 12 12 12 12 12 12 12 12 100 12 12 12 1 1 100 12 100 12 12 12 12 100 12 12 12 12 12 12 12 12 1 12 12 12 12 12 12 12 12 1 1 12 12 1 1 12 12 1 1 12 12 12 12 100 12 12 100 12 12 12 12 12 7 12 12 12 12 100 12 100 12 7 12 7 12 12 12 12 12 12 12 12 12 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
staticfield java/io/File fs Ljava/io/FileSystem; java/io/UnixFileSystem
staticfield java/io/File separatorChar C 47
staticfield java/io/File separator Ljava/lang/String; "/"
staticfield java/io/File pathSeparatorChar C 58
staticfield java/io/File pathSeparator Ljava/lang/String; ":"
staticfield java/io/File PATH_OFFSET J 16
staticfield java/io/File PREFIX_LENGTH_OFFSET J 12
staticfield java/io/File UNSAFE Lsun/misc/Unsafe; sun/misc/Unsafe
staticfield java/io/File $assertionsDisabled Z 1
instanceKlass sun/misc/Launcher$ExtClassLoader
instanceKlass sun/misc/Launcher$AppClassLoader
ciInstanceKlass java/net/URLClassLoader 1 1 639 9 10 9 10 7 10 9 10 10 10 7 10 10 10 10 10 10 100 10 10 10 100 100 100 8 10 10 10 10 11 11 11 100 11 11 10 11 11 11 10 10 10 7 10 10 7 100 10 7 10 10 10 10 100 100 10 8 10 8 10 10 10 8 8 10 10 10 100 100 8 10 10 10 10 10 10 10 10 10 7 10 10 10 10 10 10 10 10 8 10 11 9 10 9 9 9 9 9 9 10 8 10 100 10 10 7 10 10 100 10 10 10 10 7 10 9 10 8 100 8 10 10 8 10 10 9 10 10 10 10 100 8 10 100 10 10 100 10 10 7 100 10 7 10 10 10 7 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 100 1 100 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 100 100 100 100 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 100 1 1 1 1 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 100 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 12 12 12 1 12 12 7 12 100 12 7 12 1 12 12 12 12 7 12 1 12 12 12 1 1 1 1 12 12 12 12 100 12 100 12 12 1 12 100 12 12 12 12 12 12 12 1 12 12 1 1 12 1 12 7 12 12 1 1 1 12 1 12 12 1 1 12 12 12 1 1 1 12 12 7 12 7 12 12 12 12 12 12 1 12 7 12 12 12 12 12 7 12 12 1 12 7 12 7 12 7 12 12 12 12 12 12 12 7 12 1 12 1 12 1 12 12 1 12 12 12 12 1 7 12 7 12 12 1 1 1 12 12 1 12 12 12 100 12 12 12 12 1 1 1 12 7 12 1 12 12 1 1 1 12 7 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
ciInstanceKlass java/net/URL 1 1 674 10 10 10 9 9 10 10 10 9 10 8 10 7 10 10 8 10 9 100 8 10 10 8 9 7 10 10 9 10 9 8 9 10 9 10 8 9 10 10 8 10 7 10 10 10 10 10 8 10 10 10 8 9 8 10 10 100 10 10 10 10 9 10 9 10 10 10 10 100 100 10 7 10 10 10 10 10 100 10 10 10 100 10 10 100 8 10 9 10 10 9 10 100 10 10 10 10 10 10 10 10 10 10 10 9 9 100 8 10 10 9 10 10 7 11 7 8 8 10 10 7 8 8 7 10 10 10 10 8 8 10 100 10 10 10 10 10 10 8 10 100 10 8 8 10 8 8 8 8 100 10 9 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 100 8 10 10 10 10 10 7 10 7 7 10 9 9 100 1 1 1 1 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 100 100 100 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 1 1 1 1 1 1 1 100 1 1 1 100 100 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 12 12 12 12 7 12 12 12 12 12 1 12 1 12 1 12 12 1 1 12 12 1 12 1 12 12 12 12 1 12 12 12 12 1 12 12 7 12 1 12 1 12 12 12 12 12 1 12 12 12 1 12 1 12 12 1 12 12 100 12 12 100 12 100 12 12 12 12 12 100 12 1 1 12 1 12 12 12 12 12 1 12 1 12 12 1 1 100 12 100 12 12 100 12 12 1 12 12 12 12 12 12 12 12 100 12 12 12 12 12 1 1 12 12 12 12 1 100 12 1 1 1 7 12 1 1 1 1 12 12 12 1 1 7 12 1 100 12 12 12 12 100 12 100 12 12 1 12 1 12 12 12 12 12 12 12 12 12 12 12 12 12 12 1 1 12 12 100 12 1 1 1 12 7 12 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
staticfield java/net/URL serialPersistentFields [Ljava/io/ObjectStreamField; 7 [Ljava/io/ObjectStreamField;
ciInstanceKlass java/util/jar/Manifest 1 1 307 10 7 10 9 7 10 9 9 10 10 10 10 10 11 11 10 10 100 100 10 8 10 10 10 10 11 100 10 10 11 11 11 11 100 100 8 10 11 7 8 10 10 10 8 10 10 10 11 10 10 10 8 10 7 10 10 10 100 8 10 10 8 10 10 10 10 11 10 10 10 100 7 10 11 10 11 10 7 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 100 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 1 12 1 12 12 12 12 12 12 12 7 12 12 100 12 1 1 1 12 12 12 12 1 12 12 12 100 12 100 12 12 1 1 1 12 1 1 12 12 12 1 12 12 12 12 12 12 1 12 1 12 12 12 1 1 12 1 12 100 12 12 12 12 12 7 12 12 1 1 12 12 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
ciInstanceKlass sun/misc/Launcher 1 1 256 9 10 10 9 9 10 10 100 100 8 10 10 9 8 10 10 8 10 10 8 10 8 100 10 10 10 100 100 100 100 10 100 10 8 10 10 10 9 7 10 9 10 7 10 10 8 10 10 10 10 10 100 10 7 10 7 10 8 7 100 1 1 100 1 7 1 7 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 100 100 100 100 100 100 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 100 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 12 12 12 12 12 12 12 1 1 1 12 12 12 1 7 12 12 1 7 12 100 12 1 7 12 1 1 100 12 100 12 1 1 1 1 12 1 1 12 12 12 12 1 12 12 12 1 12 1 12 12 12 12 7 12 1 12 1 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
ciInstanceKlass sun/misc/Launcher$AppClassLoader 1 1 234 8 10 100 10 7 10 10 7 10 10 10 11 9 10 10 10 10 10 10 10 10 100 10 10 10 7 8 10 10 9 10 100 10 10 10 10 100 10 100 100 10 100 10 10 100 10 7 10 10 7 7 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 7 12 1 12 1 12 7 12 1 12 12 7 12 7 12 12 7 12 7 12 12 12 100 12 12 12 12 1 12 12 12 1 1 7 12 12 100 12 1 12 12 12 1 12 1 1 12 1 12 12 1 12 1 7 12 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
staticfield sun/misc/Launcher$AppClassLoader $assertionsDisabled Z 1
ciInstanceKlass sun/misc/Launcher$ExtClassLoader 1 1 280 10 9 7 10 7 10 10 100 10 100 10 10 10 10 10 11 10 8 10 7 9 10 10 7 10 10 7 10 10 8 10 10 10 10 10 7 10 10 10 10 100 10 11 10 10 8 10 10 10 100 10 100 100 10 100 10 10 100 10 10 7 1 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 1 1 1 100 100 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 12 12 7 1 12 1 12 7 12 1 12 1 12 12 12 12 7 12 7 12 7 12 1 7 12 1 12 12 12 1 12 12 1 12 1 7 12 12 12 12 12 1 12 12 12 12 1 100 12 100 12 12 1 100 12 12 12 1 12 1 1 12 1 12 12 1 12 7 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
ciInstanceKlass java/security/CodeSource 1 1 407 10 9 9 9 9 10 100 10 100 10 7 10 10 10 100 10 10 10 10 10 100 10 10 10 10 10 10 10 10 10 10 10 10 10 8 10 10 10 10 8 10 10 100 10 10 8 10 10 10 8 8 9 100 8 10 10 8 10 8 8 8 10 10 10 10 10 10 100 100 10 10 10 10 10 100 10 10 8 10 10 10 100 10 100 100 8 8 10 10 10 100 10 10 11 10 10 11 10 10 8 100 10 10 100 10 11 11 7 100 1 1 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 100 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 100 100 100 100 100 1 1 1 1 1 1 1 1 1 12 12 12 12 12 100 12 100 7 12 1 12 12 100 1 12 100 12 12 12 1 12 100 100 12 100 12 12 100 12 12 12 12 1 12 12 12 12 1 12 1 12 1 12 12 12 1 1 12 1 1 12 12 1 12 1 1 1 100 12 12 12 12 12 12 1 1 12 12 12 100 12 12 1 12 1 12 12 12 1 12 1 1 1 1 12 100 12 1 12 12 100 12 12 12 100 1 1 12 12 1 12 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
ciInstanceKlass java/lang/StackTraceElement 0 0 108 10 8 10 100 9 8 9 9 9 100 10 10 10 8 10 8 8 8 10 8 10 8 100 10 10 10 10 100 100 1 1 1 1 1 1 1 1 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 100 1 1 1 1 1 1 1 1 1 12 1 100 12 1 12 1 12 12 12 1 12 12 1 12 1 1 1 12 1 12 1 1 12 12 12 12 1 1 1 1 1 1 1 1 1 1 1
instanceKlass java/nio/LongBuffer
instanceKlass java/nio/CharBuffer
instanceKlass java/nio/ByteBuffer
ciInstanceKlass java/nio/Buffer 1 1 122 100 10 9 9 100 100 10 8 10 10 10 10 9 10 10 8 8 8 9 10 100 10 100 10 100 10 100 10 7 7 1 1 1 3 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 12 12 1 1 1 12 12 12 12 12 12 12 1 1 1 12 1 1 1 1 1 1 1 1 1 1 1 1
ciInstanceKlass java/lang/Boolean 1 1 124 10 9 10 10 8 10 9 9 8 10 7 10 10 100 100 10 10 8 10 9 7 100 100 1 1 1 1 1 1 1 1 1 1 1 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 12 12 12 1 7 12 12 12 1 12 1 12 7 12 1 1 12 12 1 7 12 12 1 1 1 1 1 1 1 1 1 1 1 1
staticfield java/lang/Boolean TRUE Ljava/lang/Boolean; java/lang/Boolean
staticfield java/lang/Boolean FALSE Ljava/lang/Boolean; java/lang/Boolean
staticfield java/lang/Boolean TYPE Ljava/lang/Class; java/lang/Class
ciInstanceKlass java/lang/Character 1 1 498 7 100 10 9 9 10 10 10 10 3 3 3 3 3 10 10 3 11 11 10 10 100 10 10 3 10 10 10 100 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 5 0 10 10 10 10 10 10 10 10 10 10 9 100 10 10 10 3 10 10 100 10 10 10 10 8 10 9 10 10 10 10 8 10 9 100 100 100 100 1 1 100 1 100 1 100 1 1 1 1 3 1 3 1 1 3 1 3 1 1 1 1 1 1 1 3 1 1 3 1 3 1 3 1 3 1 3 1 3 1 3 1 3 1 3 1 3 1 3 1 3 1 3 1 3 1 3 1 3 1 3 1 3 1 3 1 3 1 3 1 3 1 3 1 3 1 3 1 3 1 3 1 3 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 3 1 1 1 3 1 1 3 1 1 1 1 1 3 1 1 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 12 12 12 12 12 12 100 12 12 12 100 12 12 12 12 1 12 12 12 12 1 12 12 12 12 12 12 7 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 1 12 12 100 12 12 1 12 12 12 1 100 12 100 12 12 12 7 12 1 12 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
staticfield java/lang/Character TYPE Ljava/lang/Class; java/lang/Class
staticfield java/lang/Character $assertionsDisabled Z 1
instanceKlass java/util/concurrent/atomic/AtomicLong
instanceKlass java/util/concurrent/atomic/AtomicInteger
instanceKlass java/lang/Long
instanceKlass java/lang/Integer
instanceKlass java/lang/Short
instanceKlass java/lang/Byte
instanceKlass java/lang/Double
instanceKlass java/lang/Float
ciInstanceKlass java/lang/Number 1 1 37 10 10 100 7 100 1 1 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 12 1 1 1
ciInstanceKlass java/lang/Float 1 1 193 7 100 10 10 100 4 100 10 10 8 8 10 10 10 10 4 4 4 10 9 10 10 10 10 10 10 3 3 3 10 10 10 10 8 10 9 100 100 1 1 1 1 1 4 1 1 1 4 1 1 3 1 3 1 3 1 3 1 1 1 1 1 1 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 12 100 12 1 1 12 100 12 1 1 100 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 1 7 12 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
staticfield java/lang/Float TYPE Ljava/lang/Class; java/lang/Class
ciInstanceKlass java/lang/Double 1 1 253 7 100 10 10 10 100 10 10 6 0 8 10 8 10 8 100 6 0 10 5 0 5 0 8 8 10 10 8 10 8 8 8 10 10 10 10 10 10 10 10 6 0 6 0 6 0 10 9 10 10 10 10 5 0 5 0 10 10 10 10 8 10 9 100 100 1 1 1 1 1 6 0 1 1 1 6 0 1 1 3 1 3 1 3 1 3 1 1 1 1 1 1 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 12 12 12 1 12 100 12 1 12 1 12 1 1 12 1 1 100 12 100 12 1 12 1 1 1 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 12 1 7 12 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
staticfield java/lang/Double TYPE Ljava/lang/Class; java/lang/Class
ciInstanceKlass java/lang/Byte 1 1 168 7 10 9 10 100 100 10 8 10 8 10 10 10 10 10 10 10 10 8 8 10 9 10 10 10 10 5 0 10 8 10 9 100 100 100 1 1 1 1 1 3 1 3 1 1 1 1 1 1 1 3 1 3 1 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 12 12 12 1 1 12 1 12 1 12 12 12 12 12 12 12 12 1 1 12 12 12 12 12 12 1 7 12 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
staticfield java/lang/Byte TYPE Ljava/lang/Class; java/lang/Class
ciInstanceKlass java/lang/Short 1 1 176 7 100 10 10 100 100 10 8 10 8 10 10 10 10 10 10 9 10 10 10 8 8 10 9 10 10 10 10 3 3 5 0 10 8 10 9 100 100 100 1 1 1 1 1 3 1 3 1 1 1 1 1 1 1 3 1 3 1 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 12 12 1 1 12 1 12 1 12 12 12 12 12 12 12 12 12 12 1 1 12 12 12 12 12 12 1 7 12 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
staticfield java/lang/Short TYPE Ljava/lang/Class; java/lang/Class
ciInstanceKlass java/lang/Integer 1 1 359 7 100 7 10 9 7 10 10 10 10 10 10 10 10 3 8 10 10 10 3 9 9 3 9 100 8 10 100 10 8 10 10 8 10 8 10 3 10 10 10 10 8 100 10 10 5 0 8 10 10 7 9 9 10 10 9 10 10 10 10 100 100 10 8 8 10 8 8 8 8 8 8 10 10 10 5 0 3 3 3 3 3 10 10 8 10 9 3 3 3 3 3 3 7 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 3 1 3 1 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 12 1 12 12 100 12 12 12 100 12 12 12 1 12 12 12 12 12 12 1 1 12 1 12 1 12 12 1 12 1 12 12 12 12 12 1 1 12 12 1 12 12 1 12 12 12 12 12 12 12 7 12 1 1 12 1 1 12 1 1 1 1 1 1 12 12 12 12 12 1 7 12 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
staticfield java/lang/Integer TYPE Ljava/lang/Class; java/lang/Class
staticfield java/lang/Integer digits [C 36
staticfield java/lang/Integer DigitTens [C 100
staticfield java/lang/Integer DigitOnes [C 100
staticfield java/lang/Integer sizeTable [I 10
ciInstanceKlass java/lang/Long 1 1 415 7 100 100 10 9 100 10 10 10 10 10 5 0 5 0 100 10 10 10 10 10 10 10 10 10 10 10 10 10 10 10 5 0 8 10 10 10 100 5 0 5 0 9 9 3 3 100 8 10 8 10 8 8 10 5 0 10 10 10 10 8 100 10 10 8 10 8 10 10 5 0 5 0 9 10 8 8 10 8 8 8 8 8 8 10 10 10 10 9 10 10 10 100 100 10 10 10 10 10 5 0 5 0 5 0 5 0 5 0 10 10 10 8 10 9 100 100 100 1 1 1 1 1 1 5 0 1 1 1 1 1 1 1 3 1 3 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 100 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 12 12 1 12 12 12 12 12 1 12 12 12 12 12 12 100 12 12 12 12 12 12 100 12 12 12 1 12 12 12 1 12 12 1 1 12 1 12 1 1 12 12 12 12 12 1 1 12 12 1 12 1 12 12 12 12 1 1 12 1 1 1 1 1 1 12 12 12 12 12 12 100 12 1 1 12 12 12 12 12 12 12 1 7 12 12 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1 1
staticfield java/lang/Long TYPE Ljava/lang/Class; java/lang/Class
ciInstanceKlass java/lang/NullPointerException 1 1 26 10 10 100 100 1 1 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 12 12 1 1
ciInstanceKlass java/lang/ArithmeticException 1 1 26 10 10 100 100 1 1 1 5 0 1 1 1 1 1 1 1 1 1 1 1 1 12 12 1 1
ciMethod java/lang/String hashCode ()I 2705 32769 393 0 -1
ciMethodData java/lang/String hashCode ()I 1 6429 orig 264 136 116 107 21 29 127 0 0 56 94 128 0 29 127 0 0 152 1 0 0 32 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 77 68 79 32 101 120 116 114 97 32 100 97 116 97 32 108 111 99 107 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 0 16 0 0 185 1 0 0 233 72 0 0 0 0 0 0 0 0 0 0 2 0 0 0 0 0 0 0 0 0 0 0 120 0 0 0 255 255 255 255 7 0 6 0 0 0 0 0 data 15 0x60007 0x11 0x78 0x26 0xe0007 0x0 0x58 0x26 0x1e0007 0x26 0x38 0x902 0x2d0003 0x902 0xffffffffffffffe0 oops 0
compile java/lang/String hashCode ()I -1 3
mykaul commented 1 year ago

JRE version: OpenJDK Runtime Environment (8.0_352-b08) (build 1.8.0_352-b08)

Java VM: OpenJDK 64-Bit Server VM (25.352-b08 mixed mode linux-amd64 compressed oops)

For some reason it still uses the older JDK/JRE.

mykaul commented 1 year ago

https://github.com/scylladb/scylla-cluster-tests/pull/5994 perhaps is needed?

fruch commented 1 year ago

scylladb/scylla-cluster-tests#5994 perhaps is needed?

dtest doesn't use anything from SCT.

dtest is selecting the java 1.8 as default in it's docker image, I think we'll need to rebuild it to switch of latest jvm

mykaul commented 1 year ago

Not a ccm issue?

fruch commented 1 year ago

Not a ccm issue?

Never was a ccm issue, seem like it's an issue with scylla-jmx using old jvm by default, and we were trying to move to newer one, but changes in scylla-jmx are not enough since the the used java is controlled by the environment, and it's not different between different test frameworks. (dtest, SCT, core unittests)

mykaul commented 1 year ago

Not a ccm issue?

Never was a ccm issue, seem like it's an issue with scylla-jmx using old jvm by default, and we were trying to move to newer one, but changes in scylla-jmx are not enough since the the used java is controlled by the environment, and it's not different between different test frameworks. (dtest, SCT, core unittests)

Thanks. I saw https://github.com/scylladb/scylla-ccm/commit/8af126d07e6760b059abbcc2bdd7b6a920f4f2cf and thought it was related. BTW, in sane OS, we should use 'alternatives' to determine which Java binary we wish to use. Regardless, we need to update the toolchains... Do we have open issues for them?

tchaikov commented 1 year ago

Not a ccm issue?

Never was a ccm issue, seem like it's an issue with scylla-jmx using old jvm by default, and we were trying to move to newer one, but changes in scylla-jmx are not enough since the the used java is controlled by the environment, and it's not different between different test frameworks. (dtest, SCT, core unittests)

Thanks. I saw scylladb/scylla-ccm@8af126d and thought it was related. BTW, in sane OS, we should use 'alternatives' to determine which Java binary we wish to use.

i doubt this. alternatives is a user-facing facility. so user can use, for instance neovim instead vim when it he/she runs vim, or use jre-8 instead jre-11 when running java. but when it comes to the behavior of a package, which explicitly depends only on jre-11-headless, the JRE it uses should be the one it chooses, not the one favored by user -- what if user prefers staying on the edge and installs jre-17 ? we should not break and blame user.

Regardless, we need to update the toolchains... Do we have open issues for them?

if Avi's assertion still holds, see https://github.com/scylladb/scylladb/pull/13356#issuecomment-1488893837 , we don't need to update the dbuild docker image.

i will try to create a patch to teach scylla-jmx to use jre-11 even if it's installed from a relocatable package. my previous fix of 82810949183891682c5ec7f8dbc2f020fccc2d33 only works in the non-packaging mode.

fruch commented 1 year ago

Not a ccm issue?

Never was a ccm issue, seem like it's an issue with scylla-jmx using old jvm by default, and we were trying to move to newer one, but changes in scylla-jmx are not enough since the the used java is controlled by the environment, and it's not different between different test frameworks. (dtest, SCT, core unittests)

Thanks. I saw scylladb/scylla-ccm@8af126d and thought it was related. BTW, in sane OS, we should use 'alternatives' to determine which Java binary we wish to use. Regardless, we need to update the toolchains... Do we have open issues for them?

I've opened a PR to remove the change of java alternative that dtest docker image was doing https://github.com/scylladb/scylla-dtest/pull/3115

bhalevy commented 5 months ago

We're seeing something similar in 5.2.15 now. For example, https://jenkins.scylladb.com/job/scylla-5.2/job/dtest-release/40/artifact/logs-full.release.015/1707665686339_auth_test.py%3A%3ATestAuth%3A%3Atest_transitional_auth_from_default/node2_system.log.jmx

Starting scylla-jmx: args=['/jenkins/workspace/scylla-5.2/dtest-release/scylla/.dtest/dtest-wcqq6s0e/test/node2/bin/symlinks/scylla-jmx', '-Dapiaddress=127.0.74.2', '-Djavax.management.builder.initial=com.scylladb.jmx.utils.APIBuilder', '-Djava.rmi.server.hostname=127.0.74.2', '-Dcom.sun.management.jmxremote', '-Dcom.sun.management.jmxremote.host=127.0.74.2', '-Dcom.sun.management.jmxremote.port=7199', '-Dcom.sun.management.jmxremote.rmi.port=7199', '-Dcom.sun.management.jmxremote.local.only=false', '-Xmx256m', '-XX:+UseSerialGC', '-Dcom.sun.management.jmxremote.authenticate=false', '-Dcom.sun.management.jmxremote.ssl=false', '-jar', '/jenkins/workspace/scylla-5.2/dtest-release/scylla/.dtest/dtest-wcqq6s0e/test/node2/bin/scylla-jmx-1.0.jar']
#
# A fatal error has been detected by the Java Runtime Environment:
#
#  SIGSEGV (0xb) at pc=0x00007fb31cae52a0, pid=3238, tid=0x00007fb319cc56c0
#
# JRE version: OpenJDK Runtime Environment (8.0_352-b08) (build 1.8.0_352-b08)
# Java VM: OpenJDK 64-Bit Server VM (25.352-b08 mixed mode linux-amd64 compressed oops)
# Problematic frame:
# V  [libjvm.so+0xb222a0]  StubCodeDesc::desc_for(unsigned char*)+0x10
#
# Core dump written. Default location: /jenkins/workspace/scylla-5.2/dtest-release/scylla-dtest/core or core.3238
#
# An error report file with more information is saved as:
# /jenkins/workspace/scylla-5.2/dtest-release/scylla-dtest/hs_err_pid3238.log
#
# Compiler replay data is saved as:
# /jenkins/workspace/scylla-5.2/dtest-release/scylla-dtest/replay_pid3238.log
#
# If you would like to submit a bug report, please visit:
#   https://bugzilla.redhat.com/enter_bug.cgi?product=Fedora&component=java-1.8.0-openjdk&version=37
#
bhalevy commented 5 months ago

@denesb I'm not exactly sure what triggered the above, but we should probably backport the following pataches to 5.2:

fruch commented 5 months ago

@denesb I'm not exactly sure what triggered the above, but we should probably backport the following pataches to 5.2:

it's would drag lot of other changes across the board (both in dtest and SCT)

mykaul commented 5 months ago

We've updated the JDK version in latest 5.2/2023.1, hoping it'll solve that crash (which doesn't seem to be JMX fault...)

fruch commented 5 months ago

We've updated the JDK version in latest 5.2/2023.1, hoping it'll solve that crash (which doesn't seem to be JMX fault...)

when you said it's updated, what exactly changed, and where ?, cause one wouldn't need to update the docker image of dtest for that. (and I don't think that was done on those branches)

mykaul commented 5 months ago

We've updated the JDK version in latest 5.2/2023.1, hoping it'll solve that crash (which doesn't seem to be JMX fault...)

when you said it's updated, what exactly changed, and where ?, cause one wouldn't need to update the docker image of dtest for that. (and I don't think that was done on those branches)

build 1.8.0_352-b08 updated to build 1.8.0_392, or something like that. If you are running JMX in your own Docker image, then I expect you to update it as well (do you?)

fruch commented 5 months ago

We've updated the JDK version in latest 5.2/2023.1, hoping it'll solve that crash (which doesn't seem to be JMX fault...)

when you said it's updated, what exactly changed, and where ?, cause one wouldn't need to update the docker image of dtest for that. (and I don't think that was done on those branches)

build 1.8.0_352-b08 updated to build 1.8.0_392, or something like that. If you are running JMX in your own Docker image, then I expect you to update it as well (do you?)

we are not updating anything on the branch automatically on it's own, so if something like that is needed, one should raise an issue for dtest for doing it, other no one know about it.

mykaul commented 5 months ago

@fruch - how can you follow https://github.com/scylladb/scylladb/commit/fcfcd6d35a4c525bd2e080c802309ca48679be26 ? I'm not sure you have a diff even... (the request came from https://github.com/scylladb/scylla-enterprise/issues/3872 - and a similar issue exists for 5.2/2023.1.x)

bhalevy commented 5 months ago

In 5.2, it appears like the toolchain change is part of scylladb/scylladb@5a05ccc2f897871df6d877e1d3a52a2c0981cc7c

mykaul commented 5 months ago

In 5.2, it appears like the toolchain change is part of scylladb/scylladb@5a05ccc

That just adds pyudev. But we have an overall update of the toolchain regardless. (or we should have, if we haven't done it yet).

fruch commented 5 months ago

@fruch - how can you follow scylladb/scylladb@fcfcd6d ? I'm not sure you have a diff even... (the request came from scylladb/scylla-enterprise#3872 - and a similar issue exists for 5.2/2023.1.x)

how that change is related to an update of JVM ? regardless there not information there what is this change, and why it was done. so I'm not sure I understand that question and what exactly you think I should follow ? (and why ?)

mykaul commented 5 months ago

@fruch - how can you follow scylladb/scylladb@fcfcd6d ? I'm not sure you have a diff even... (the request came from scylladb/scylla-enterprise#3872 - and a similar issue exists for 5.2/2023.1.x)

how that change is related to an update of JVM ? regardless there not information there what is this change, and why it was done. so I'm not sure I understand that question and what exactly you think I should follow ? (and why ?)

https://github.com/scylladb/scylla-enterprise/issues/3872 (and the corresponding 5.2 one) update the JVM to the latest one, that's all.

bhalevy commented 2 months ago

Apparently seen again in 5.2.18-0.20240419.dae9bef75f66: https://jenkins.scylladb.com/job/scylla-5.2/job/dtest-release/44/artifact/logs-full.release.000/1713536845842_cdc_types_test.py%3A%3ATestCDCNativeType%3A%3Atest_update_with_null_with_postimage%5Bvarint1%5D/node1_system.log.jmx

Starting scylla-jmx: args=['/jenkins/workspace/scylla-5.2/dtest-release/scylla/.dtest/dtest-jur8l3zr/test/node1/bin/symlinks/scylla-jmx', '-Dapiaddress=127.0.22.1', '-Djavax.management.builder.initial=com.scylladb.jmx.utils.APIBuilder', '-Djava.rmi.server.hostname=127.0.22.1', '-Dcom.sun.management.jmxremote', '-Dcom.sun.management.jmxremote.host=127.0.22.1', '-Dcom.sun.management.jmxremote.port=7199', '-Dcom.sun.management.jmxremote.rmi.port=7199', '-Dcom.sun.management.jmxremote.local.only=false', '-Xmx256m', '-XX:+UseSerialGC', '-Dcom.sun.management.jmxremote.authenticate=false', '-Dcom.sun.management.jmxremote.ssl=false', '-jar', '/jenkins/workspace/scylla-5.2/dtest-release/scylla/.dtest/dtest-jur8l3zr/test/node1/bin/scylla-jmx-1.0.jar']
#
# A fatal error has been detected by the Java Runtime Environment:
#
#  SIGSEGV (0xb) at pc=0x00007fba72e4c2a0, pid=96620, tid=0x00007fba5cfff6c0
#
# JRE version: OpenJDK Runtime Environment (8.0_352-b08) (build 1.8.0_352-b08)
# Java VM: OpenJDK 64-Bit Server VM (25.352-b08 mixed mode linux-amd64 compressed oops)
# Problematic frame:
# V  [libjvm.so+0xb222a0]  StubCodeDesc::desc_for(unsigned char*)+0x10
#
# Core dump written. Default location: /jenkins/workspace/scylla-5.2/dtest-release/scylla-dtest/core or core.96620
#
# An error report file with more information is saved as:
# /jenkins/workspace/scylla-5.2/dtest-release/scylla-dtest/hs_err_pid96620.log
#
# Compiler replay data is saved as:
# /jenkins/workspace/scylla-5.2/dtest-release/scylla-dtest/replay_pid96620.log
#
# If you would like to submit a bug report, please visit:
#   https://bugzilla.redhat.com/enter_bug.cgi?product=Fedora&component=java-1.8.0-openjdk&version=37
#
mykaul commented 2 months ago

As I mentioned elsewhere, even FC37 has a newer build (https://koji.fedoraproject.org/koji/buildinfo?buildID=2327378 ) - I'm not sure why we are not updating to it.