You are viewing a plain text version of this content. The canonical link for it is here.
Posted to user@hive.apache.org by Margus Roo <ma...@roo.ee> on 2016/02/10 09:53:07 UTC

hive --service metatool -listFSRoot Unable to open a test connection to the given database. JDBC url = jdbc:mysql://hostnamehive?createDatabaseIfNotExist=true, username = hive

Hi

I have two servers where are same hive configuration bigdata29 and bigdata2.
 From bigdata29 I can connect successfully with metadata:

[hive@bigdata29 ~]$ hive --service metatool -listFSRoot
WARNING: Use "yarn jar" to launch YARN applications.
Initializing HiveMetaTool..
16/02/10 03:34:21 INFO metastore.ObjectStore: ObjectStore, initialize called
16/02/10 03:34:21 INFO DataNucleus.Persistence: Property 
hive.metastore.integral.jdo.pushdown unknown - will be ignored
16/02/10 03:34:21 INFO DataNucleus.Persistence: Property 
datanucleus.cache.level2 unknown - will be ignored
16/02/10 03:34:22 INFO metastore.ObjectStore: Setting MetaStore object 
pin classes with 
hive.metastore.cache.pinobjtypes="Table,Database,Type,FieldSchema,Order"
16/02/10 03:34:23 INFO DataNucleus.Datastore: The class 
"org.apache.hadoop.hive.metastore.model.MFieldSchema" is tagged as 
"embedded-only" so does not have its own datastore table.
16/02/10 03:34:23 INFO DataNucleus.Datastore: The class 
"org.apache.hadoop.hive.metastore.model.MOrder" is tagged as 
"embedded-only" so does not have its own datastore table.
16/02/10 03:34:23 INFO DataNucleus.Datastore: The class 
"org.apache.hadoop.hive.metastore.model.MFieldSchema" is tagged as 
"embedded-only" so does not have its own datastore table.
16/02/10 03:34:23 INFO DataNucleus.Datastore: The class 
"org.apache.hadoop.hive.metastore.model.MOrder" is tagged as 
"embedded-only" so does not have its own datastore table.
16/02/10 03:34:23 INFO DataNucleus.Query: Reading in results for query 
"org.datanucleus.store.rdbms.query.SQLQuery@0" since the connection used 
is closing
16/02/10 03:34:23 INFO metastore.MetaStoreDirectSql: Using direct SQL, 
underlying DB is MYSQL
16/02/10 03:34:23 INFO metastore.ObjectStore: Initialized ObjectStore
Listing FS Roots..
hdfs://mycluster/apps/hive/warehouse


 From bigdata2:
[hive@bigdata2 ~]$ hive --service metatool -listFSRoot
WARNING: Use "yarn jar" to launch YARN applications.
Initializing HiveMetaTool..
16/02/10 03:45:04 INFO metastore.ObjectStore: ObjectStore, initialize called
16/02/10 03:45:05 INFO DataNucleus.Persistence: Property 
hive.metastore.integral.jdo.pushdown unknown - will be ignored
16/02/10 03:45:05 INFO DataNucleus.Persistence: Property 
datanucleus.cache.level2 unknown - will be ignored
16/02/10 03:45:06 ERROR Datastore.Schema: Failed initialising database.
Unable to open a test connection to the given database. JDBC url = 
jdbc:mysql://bigdata29/hive?createDatabaseIfNotExist=true, username = 
hive. Terminating connection pool (set lazyInit to true if you expect to 
start your database after your app). Original Exception: ------
java.sql.SQLException: Access denied for user 'hive'@'bigdata2' (using 
password: YES)

but I can access using mysql client:
[hive@bigdata2 ~]$ mysql -h bigdata29 -P 3306 -u hive -p
Enter password:
Welcome to the MySQL monitor.  Commands end with ; or \g.
Your MySQL connection id is 6018367
Server version: 5.6.28-log MySQL Community Server (GPL)

Copyright (c) 2000, 2016, Oracle and/or its affiliates. All rights reserved.

Oracle is a registered trademark of Oracle Corporation and/or its
affiliates. Other names may be trademarks of their respective
owners.

Type 'help;' or '\h' for help. Type '\c' to clear the current input 
statement.


Any hints where do dig ?

Br, Margus




-- 
Margus (margusja) Roo
http://margus.roo.ee
skype: margusja
+372 51 48 780


Re: hive --service metatool -listFSRoot Unable to open a test connection to the given database. JDBC url = jdbc:mysql://hostnamehive?createDatabaseIfNotExist=true, username = hive

Posted by Margus Roo <ma...@roo.ee>.
Some bits more info

[hive@bigdata29 ~]$ /usr/hdp/2.3.4.0-3485/hive/bin/schematool -dbType 
mysql -info
WARNING: Use "yarn jar" to launch YARN applications.
Metastore connection URL: 
jdbc:mysql://bigdata2.webmedia.int/hive?createDatabaseIfNotExist=true
Metastore Connection Driver :    com.mysql.jdbc.Driver
Metastore connection User:       hive
Hive distribution version:       1.2.0
Metastore schema version:        1.2.0
schemaTool completed
[hive@bigdata29 ~]$

[hive@bigdata2 ~]$ /usr/hdp/2.3.4.0-3485/hive/bin/schematool -dbType 
mysql -info
WARNING: Use "yarn jar" to launch YARN applications.
Metastore connection URL: 
jdbc:mysql://bigdata2.webmedia.int/hive?createDatabaseIfNotExist=true
Metastore Connection Driver :    com.mysql.jdbc.Driver
Metastore connection User:       hive
org.apache.hadoop.hive.metastore.HiveMetaException: Failed to get schema 
version.
*** schemaTool failed ***

hive-site.xml
   <configuration>

     <property>
       <name>ambari.hive.db.schema.name</name>
       <value>hive</value>
     </property>

     <property>
       <name>datanucleus.autoCreateSchema</name>
       <value>false</value>
     </property>

     <property>
       <name>datanucleus.cache.level2.type</name>
       <value>none</value>
     </property>

     <property>
       <name>hive.auto.convert.join</name>
       <value>true</value>
     </property>

     <property>
<name>hive.auto.convert.join.noconditionaltask</name>
       <value>true</value>
     </property>

     <property>
<name>hive.auto.convert.join.noconditionaltask.size</name>
       <value>555745280</value>
     </property>

     <property>
       <name>hive.auto.convert.sortmerge.join</name>
       <value>true</value>
     </property>

     <property>
<name>hive.auto.convert.sortmerge.join.to.mapjoin</name>
       <value>false</value>
     </property>

     <property>
       <name>hive.cbo.enable</name>
       <value>true</value>
     </property>

     <property>
       <name>hive.cli.print.header</name>
       <value>false</value>
     </property>

     <property>
<name>hive.cluster.delegation.token.store.class</name>
<value>org.apache.hadoop.hive.thrift.ZooKeeperTokenStore</value>
     </property>

  <property>
<name>hive.cluster.delegation.token.store.zookeeper.connectString</name>
<value>bigdata29.webmedia.int:2181,bigdata2.webmedia.int:2181</value>
     </property>

     <property>
<name>hive.cluster.delegation.token.store.zookeeper.znode</name>
       <value>/hive/cluster/delegation</value>
     </property>

     <property>
       <name>hive.compactor.abortedtxn.threshold</name>
       <value>1000</value>
     </property>

     <property>
       <name>hive.compactor.check.interval</name>
       <value>300L</value>
     </property>

     <property>
       <name>hive.compactor.delta.num.threshold</name>
       <value>10</value>
     </property>

     <property>
       <name>hive.compactor.delta.pct.threshold</name>
       <value>0.1f</value>
     </property>

     <property>
       <name>hive.compactor.initiator.on</name>
       <value>false</value>
     </property>

     <property>
       <name>hive.compactor.worker.threads</name>
       <value>0</value>
     </property>

     <property>
       <name>hive.compactor.worker.timeout</name>
       <value>86400L</value>
     </property>

     <property>
       <name>hive.compute.query.using.stats</name>
       <value>true</value>
     </property>

     <property>
       <name>hive.conf.restricted.list</name>
<value>hive.security.authenticator.manager,hive.security.authorization.manager,hive.users.in.admin.role,hive.security.authorization.enabled</value>
     </property>

   <property>
       <name>hive.convert.join.bucket.mapjoin.tez</name>
       <value>false</value>
     </property>

     <property>
       <name>hive.default.fileformat</name>
       <value>TextFile</value>
     </property>

     <property>
       <name>hive.default.fileformat.managed</name>
       <value>TextFile</value>
     </property>

     <property>
       <name>hive.enforce.bucketing</name>
       <value>false</value>
     </property>

     <property>
       <name>hive.enforce.sorting</name>
       <value>true</value>
     </property>

     <property>
       <name>hive.enforce.sortmergebucketmapjoin</name>
       <value>true</value>
     </property>

     <property>
       <name>hive.exec.compress.intermediate</name>
       <value>false</value>
     </property>

     <property>
       <name>hive.exec.compress.output</name>
       <value>false</value>
     </property>

     <property>
       <name>hive.exec.dynamic.partition</name>
       <value>true</value>
     </property>

     <property>
       <name>hive.exec.dynamic.partition.mode</name>
       <value>strict</value>
     </property>

     <property>
       <name>hive.exec.failure.hooks</name>
<value>org.apache.hadoop.hive.ql.hooks.ATSHook</value>
     </property>
   <property>
       <name>hive.exec.max.created.files</name>
       <value>100000</value>
     </property>

     <property>
       <name>hive.exec.max.dynamic.partitions</name>
       <value>5000</value>
     </property>

     <property>
<name>hive.exec.max.dynamic.partitions.pernode</name>
       <value>2000</value>
     </property>

     <property>
       <name>hive.exec.orc.compression.strategy</name>
       <value>SPEED</value>
     </property>

     <property>
       <name>hive.exec.orc.default.compress</name>
       <value>ZLIB</value>
     </property>

     <property>
       <name>hive.exec.orc.default.stripe.size</name>
       <value>67108864</value>
     </property>

     <property>
       <name>hive.exec.orc.encoding.strategy</name>
       <value>SPEED</value>
     </property>

     <property>
       <name>hive.exec.parallel</name>
       <value>false</value>
     </property>

     <property>
       <name>hive.exec.parallel.thread.number</name>
       <value>8</value>
     </property>

     <property>
       <name>hive.exec.post.hooks</name>
<value>org.apache.hadoop.hive.ql.hooks.ATSHook</value>
     </property>

     <property>
       <name>hive.exec.pre.hooks</name>
<value>org.apache.hadoop.hive.ql.hooks.ATSHook</value>
     </property>
  <property>
       <name>hive.exec.reducers.bytes.per.reducer</name>
       <value>67108864</value>
     </property>

     <property>
       <name>hive.exec.reducers.max</name>
       <value>1009</value>
     </property>

     <property>
       <name>hive.exec.scratchdir</name>
       <value>/tmp/hive</value>
     </property>

     <property>
       <name>hive.exec.submit.local.task.via.child</name>
       <value>true</value>
     </property>

     <property>
       <name>hive.exec.submitviachild</name>
       <value>false</value>
     </property>

     <property>
       <name>hive.execution.engine</name>
       <value>tez</value>
     </property>

     <property>
       <name>hive.fetch.task.aggr</name>
       <value>false</value>
     </property>

     <property>
       <name>hive.fetch.task.conversion</name>
       <value>more</value>
     </property>

     <property>
       <name>hive.fetch.task.conversion.threshold</name>
       <value>1073741824</value>
     </property>

     <property>
       <name>hive.limit.optimize.enable</name>
       <value>true</value>
     </property>

     <property>
       <name>hive.limit.pushdown.memory.usage</name>
       <value>0.04</value>
     </property>
  <property>
       <name>hive.map.aggr</name>
       <value>true</value>
     </property>

     <property>
<name>hive.map.aggr.hash.force.flush.memory.threshold</name>
       <value>0.9</value>
     </property>

     <property>
       <name>hive.map.aggr.hash.min.reduction</name>
       <value>0.5</value>
     </property>

     <property>
       <name>hive.map.aggr.hash.percentmemory</name>
       <value>0.5</value>
     </property>

     <property>
       <name>hive.mapjoin.bucket.cache.size</name>
       <value>10000</value>
     </property>

     <property>
       <name>hive.mapjoin.optimized.hashtable</name>
       <value>true</value>
     </property>

     <property>
<name>hive.mapred.reduce.tasks.speculative.execution</name>
       <value>false</value>
     </property>

     <property>
       <name>hive.merge.mapfiles</name>
       <value>true</value>
     </property>

     <property>
       <name>hive.merge.mapredfiles</name>
       <value>false</value>
     </property>

     <property>
       <name>hive.merge.orcfile.stripe.level</name>
       <value>true</value>
     </property>

     <property>
       <name>hive.merge.rcfile.block.level</name>
       <value>true</value>
     </property>
  <property>
       <name>hive.merge.size.per.task</name>
       <value>256000000</value>
     </property>

     <property>
       <name>hive.merge.smallfiles.avgsize</name>
       <value>16000000</value>
     </property>

     <property>
       <name>hive.merge.tezfiles</name>
       <value>false</value>
     </property>

     <property>
<name>hive.metastore.authorization.storage.checks</name>
       <value>false</value>
     </property>

     <property>
       <name>hive.metastore.cache.pinobjtypes</name>
<value>Table,Database,Type,FieldSchema,Order</value>
     </property>

     <property>
<name>hive.metastore.client.connect.retry.delay</name>
       <value>5s</value>
     </property>

     <property>
       <name>hive.metastore.client.socket.timeout</name>
       <value>180000s</value>
     </property>

     <property>
       <name>hive.metastore.connect.retries</name>
       <value>24</value>
     </property>

     <property>
       <name>hive.metastore.execute.setugi</name>
       <value>true</value>
     </property>

     <property>
       <name>hive.metastore.failure.retries</name>
       <value>24</value>
     </property>

     <property>
       <name>hive.metastore.kerberos.keytab.file</name>
<value>/etc/security/keytabs/hive.service.keytab</value>
     </property>
  <property>
       <name>hive.metastore.kerberos.principal</name>
       <value>hive/_HOST@TESTHADOOP.COM</value>
     </property>

     <property>
       <name>hive.metastore.pre.event.listeners</name>
<value>org.apache.hadoop.hive.ql.security.authorization.AuthorizationPreEventListener</value>
     </property>

     <property>
       <name>hive.metastore.sasl.enabled</name>
       <value>true</value>
     </property>

     <property>
       <name>hive.metastore.schema.verification</name>
       <value>false</value>
     </property>

     <property>
       <name>hive.metastore.server.max.threads</name>
       <value>100000</value>
     </property>

     <property>
       <name>hive.metastore.uris</name>
<value>thrift://bigdata2.webmedia.int:9083,thrift://bigdata29.webmedia.int:9083</value>
     </property>

     <property>
       <name>hive.metastore.warehouse.dir</name>
       <value>/apps/hive/warehouse</value>
     </property>

     <property>
       <name>hive.optimize.bucketmapjoin</name>
       <value>true</value>
     </property>

     <property>
<name>hive.optimize.bucketmapjoin.sortedmerge</name>
       <value>false</value>
     </property>

     <property>
       <name>hive.optimize.constant.propagation</name>
       <value>true</value>
     </property>

     <property>
       <name>hive.optimize.index.filter</name>
       <value>true</value>
     </property>
  <property>
       <name>hive.optimize.metadataonly</name>
       <value>true</value>
     </property>

     <property>
       <name>hive.optimize.null.scan</name>
       <value>true</value>
     </property>

     <property>
       <name>hive.optimize.reducededuplication</name>
       <value>true</value>
     </property>

     <property>
<name>hive.optimize.reducededuplication.min.reducer</name>
       <value>4</value>
     </property>

     <property>
       <name>hive.optimize.sort.dynamic.partition</name>
       <value>false</value>
     </property>

     <property>
       <name>hive.orc.compute.splits.num.threads</name>
       <value>10</value>
     </property>

     <property>
       <name>hive.orc.splits.include.file.footer</name>
       <value>false</value>
     </property>

     <property>
       <name>hive.prewarm.enabled</name>
       <value>false</value>
     </property>

     <property>
       <name>hive.prewarm.numcontainers</name>
       <value>3</value>
     </property>

     <property>
       <name>hive.security.authenticator.manager</name>
<value>org.apache.hadoop.hive.ql.security.ProxyUserAuthenticator</value>
     </property>

     <property>
       <name>hive.security.authorization.enabled</name>
       <value>true</value>
     </property>
    <property>
       <name>hive.security.authorization.manager</name>
<value>org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdConfOnlyAuthorizerFactory</value>
     </property>

     <property>
<name>hive.security.metastore.authenticator.manager</name>
<value>org.apache.hadoop.hive.ql.security.HadoopDefaultMetastoreAuthenticator</value>
     </property>

     <property>
<name>hive.security.metastore.authorization.auth.reads</name>
       <value>true</value>
     </property>

     <property>
<name>hive.security.metastore.authorization.manager</name>
<value>org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider</value>
     </property>

     <property>
       <name>hive.server2.allow.user.substitution</name>
       <value>true</value>
     </property>

     <property>
       <name>hive.server2.authentication</name>
       <value>KERBEROS</value>
     </property>

     <property>
<name>hive.server2.authentication.kerberos.keytab</name>
<value>/etc/security/keytabs/hive.service.keytab</value>
     </property>

     <property>
<name>hive.server2.authentication.kerberos.principal</name>
       <value>hive/_HOST@TESTHADOOP.COM</value>
     </property>

     <property>
<name>hive.server2.authentication.spnego.keytab</name>
<value>/etc/security/keytabs/spnego.service.keytab</value>
     </property>

     <property>
<name>hive.server2.authentication.spnego.principal</name>
       <value>HTTP/_HOST@TESTHADOOP.COM</value>
     </property>

     <property>
       <name>hive.server2.enable.doAs</name>
       <value>false</value>
     </property>
<property>
<name>hive.server2.logging.operation.enabled</name>
       <value>true</value>
     </property>

     <property>
<name>hive.server2.logging.operation.log.location</name>
<value>${system:java.io.tmpdir}/${system:user.name}/operation_logs</value>
     </property>

     <property>
<name>hive.server2.support.dynamic.service.discovery</name>
       <value>true</value>
     </property>

     <property>
       <name>hive.server2.table.type.mapping</name>
       <value>CLASSIC</value>
     </property>

     <property>
       <name>hive.server2.tez.default.queues</name>
       <value>default</value>
     </property>

     <property>
<name>hive.server2.tez.initialize.default.sessions</name>
       <value>false</value>
     </property>

     <property>
<name>hive.server2.tez.sessions.per.default.queue</name>
       <value>1</value>
     </property>

     <property>
       <name>hive.server2.thrift.http.path</name>
       <value>cliservice</value>
     </property>

     <property>
       <name>hive.server2.thrift.http.port</name>
       <value>10001</value>
     </property>

     <property>
<name>hive.server2.thrift.max.worker.threads</name>
       <value>500</value>
     </property>

     <property>
       <name>hive.server2.thrift.port</name>
       <value>10000</value>
     </property>
  <property>
       <name>hive.server2.thrift.sasl.qop</name>
       <value>auth</value>
     </property>

     <property>
       <name>hive.server2.transport.mode</name>
       <value>binary</value>
     </property>

     <property>
       <name>hive.server2.use.SSL</name>
       <value>false</value>
     </property>

     <property>
       <name>hive.server2.zookeeper.namespace</name>
       <value>hiveserver2</value>
     </property>

     <property>
       <name>hive.smbjoin.cache.rows</name>
       <value>10000</value>
     </property>

     <property>
       <name>hive.stats.autogather</name>
       <value>true</value>
     </property>

     <property>
       <name>hive.stats.dbclass</name>
       <value>fs</value>
     </property>

     <property>
       <name>hive.stats.fetch.column.stats</name>
       <value>true</value>
     </property>

     <property>
       <name>hive.stats.fetch.partition.stats</name>
       <value>true</value>
     </property>

     <property>
       <name>hive.support.concurrency</name>
       <value>false</value>
     </property>

     <property>
       <name>hive.tez.auto.reducer.parallelism</name>
       <value>true</value>
     </property>
   <property>
       <name>hive.tez.container.size</name>
       <value>640</value>
     </property>

     <property>
       <name>hive.tez.cpu.vcores</name>
       <value>-1</value>
     </property>

     <property>
       <name>hive.tez.dynamic.partition.pruning</name>
       <value>true</value>
     </property>

     <property>
<name>hive.tez.dynamic.partition.pruning.max.data.size</name>
       <value>104857600</value>
     </property>

     <property>
<name>hive.tez.dynamic.partition.pruning.max.event.size</name>
       <value>1048576</value>
     </property>

     <property>
       <name>hive.tez.input.format</name>
<value>org.apache.hadoop.hive.ql.io.HiveInputFormat</value>
     </property>

     <property>
       <name>hive.tez.java.opts</name>
       <value>-server -Djava.net.preferIPv4Stack=true -XX:NewRatio=8 
-XX:+UseNUMA -XX:+UseG1GC -XX:+ResizeTLAB -XX:+PrintGCDetails 
-verbose:gc -XX:+PrintGCTimeStamps</value>
     </property>

     <property>
       <name>hive.tez.log.level</name>
       <value>INFO</value>
     </property>

     <property>
       <name>hive.tez.max.partition.factor</name>
       <value>2.0</value>
     </property>

     <property>
       <name>hive.tez.min.partition.factor</name>
       <value>0.25</value>
     </property>

     <property>
       <name>hive.tez.smb.number.waves</name>
       <value>0.5</value>
     </property>
  <property>
       <name>hive.txn.manager</name>
<value>org.apache.hadoop.hive.ql.lockmgr.DummyTxnManager</value>
     </property>

     <property>
       <name>hive.txn.max.open.batch</name>
       <value>1000</value>
     </property>

     <property>
       <name>hive.txn.timeout</name>
       <value>30000</value>
     </property>

     <property>
       <name>hive.user.install.directory</name>
       <value>/user/</value>
     </property>

     <property>
       <name>hive.vectorized.execution.enabled</name>
       <value>true</value>
     </property>

     <property>
<name>hive.vectorized.execution.reduce.enabled</name>
       <value>false</value>
     </property>

     <property>
       <name>hive.vectorized.groupby.checkinterval</name>
       <value>4096</value>
     </property>

     <property>
       <name>hive.vectorized.groupby.flush.percent</name>
       <value>0.1</value>
     </property>

     <property>
       <name>hive.vectorized.groupby.maxentries</name>
       <value>100000</value>
     </property>

     <property>
       <name>hive.zookeeper.client.port</name>
       <value>2181</value>
     </property>

     <property>
       <name>hive.zookeeper.namespace</name>
       <value>hive_zookeeper_namespace</value>
     </property>
<property>
       <name>hive.zookeeper.quorum</name>
<value>bigdata29.webmedia.int:2181,bigdata2.webmedia.int:2181</value>
     </property>

     <property>
       <name>javax.jdo.option.ConnectionDriverName</name>
       <value>com.mysql.jdbc.Driver</value>
     </property>

     <property>
       <name>javax.jdo.option.ConnectionURL</name>
<value>jdbc:mysql://bigdata2.webmedia.int/hive?createDatabaseIfNotExist=true</value>
     </property>

     <property>
       <name>javax.jdo.option.ConnectionUserName</name>
       <value>hive</value>
     </property>

   </configuration>

Margus (margusja) Roo
http://margus.roo.ee
skype: margusja
+372 51 48 780

On 10/02/16 11:17, Mich Talebzadeh wrote:
>
> No mine is on Oracle database on Oracle 11g and says the same. Notice 
> the bold line do you have that?
>
> hive --service metatool -listFSRoot
>
> Initializing HiveMetaTool..
>
> 2016-02-10 09:24:44,784 INFO  [main] metastore.ObjectStore: 
> ObjectStore, initialize called
>
> 2016-02-10 09:24:44,963 INFO  [main] DataNucleus.Persistence: Property 
> datanucleus.cache.level2 unknown - will be ignored
>
> 2016-02-10 09:24:44,964 INFO  [main] DataNucleus.Persistence: Property 
> hive.metastore.integral.jdo.pushdown unknown - will be ignored
>
> 2016-02-10 09:24:45,877 INFO  [main] metastore.ObjectStore: Setting 
> MetaStore object pin classes with 
> hive.metastore.cache.pinobjtypes="Table,StorageDescriptor,SerDeInfo,Partition,Database,Type,FieldSchema,Order"
>
> 2016-02-10 09:24:49,608 INFO  [main] DataNucleus.Datastore: The class 
> "org.apache.hadoop.hive.metastore.model.MFieldSchema" is tagged as 
> "embedded-only" so does not have its own datastore table.
>
> 2016-02-10 09:24:49,609 INFO  [main] DataNucleus.Datastore: The class 
> "org.apache.hadoop.hive.metastore.model.MOrder" is tagged as 
> "embedded-only" so does not have its own datastore table.
>
> 2016-02-10 09:24:51,958 INFO  [main] DataNucleus.Datastore: The class 
> "org.apache.hadoop.hive.metastore.model.MFieldSchema" is tagged as 
> "embedded-only" so does not have its own datastore table.
>
> 2016-02-10 09:24:51,958 INFO  [main] DataNucleus.Datastore: The class 
> "org.apache.hadoop.hive.metastore.model.MOrder" is tagged as 
> "embedded-only" so does not have its own datastore table.
>
> 2016-02-10 09:24:54,182 INFO  [main] DataNucleus.Query: Reading in 
> results for query "org.datanucleus.store.rdbms.query.SQLQuery@0" since 
> the connection used is closing
>
> *2016-02-10 09:24:54,183 INFO  [main] metastore.MetaStoreDirectSql: 
> Using direct SQL, **underlying DB is ORACLE***
>
> 2016-02-10 09:24:54,185 INFO  [main] metastore.ObjectStore: 
> Initialized ObjectStore
>
> Listing FS Roots..
>
> hdfs://rhes564:9000/user/hive/warehouse
>
> hdfs://rhes564:9000/user/hive/warehouse/oraclehadoop.db
>
> hdfs://rhes564:9000/user/hive/warehouse/asehadoop.db
>
> hdfs://rhes564:9000/user/hive/warehouse/test.db
>
> hdfs://rhes564:9000/user/hive/warehouse/iqhadoop.db
>
> Dr Mich Talebzadeh
>
> LinkedIn 
>  https://www.linkedin.com/profile/view?id=AAEAAAAWh2gBxianrbJd6zP6AcPCCdOABUrV8Pw
>
> http://talebzadehmich.wordpress.com
>
> NOTE: The information in this email is proprietary and confidential. 
> This message is for the designated recipient only, if you are not the 
> intended recipient, you should destroy it immediately. Any information 
> in this message shall not be understood as given or endorsed by 
> Peridale Technology Ltd, its subsidiaries or their employees, unless 
> expressly so stated. It is the responsibility of the recipient to 
> ensure that this email is virus free, therefore neither Peridale 
> Technology Ltd, its subsidiaries nor their employees accept any 
> responsibility.
>
> -----Original Message-----
> From: Margus Roo [mailto:margus@roo.ee]
> Sent: 10 February 2016 09:05
> To: user@hive.apache.org
> Subject: Re: hive --service metatool -listFSRoot Unable to open a test 
> connection to the given database. JDBC url = 
> jdbc:mysql://hostnamehive?createDatabaseIfNotExist=true, username = hive
>
> Does thous lines meaning that I have embedded metastore?
>
> 16/02/10 03:34:23 INFO DataNucleus.Datastore: The class 
> "org.apache.hadoop.hive.metastore.model.MFieldSchema" is tagged as 
> "embedded-only" so does not have its own datastore table.
>
> 16/02/10 03:34:23 INFO DataNucleus.Datastore: The class 
> "org.apache.hadoop.hive.metastore.model.MOrder" is tagged as 
> "embedded-only" so does not have its own datastore table.
>
> 16/02/10 03:34:23 INFO DataNucleus.Datastore: The class 
> "org.apache.hadoop.hive.metastore.model.MFieldSchema" is tagged as 
> "embedded-only" so does not have its own datastore table.
>
> 16/02/10 03:34:23 INFO DataNucleus.Datastore: The class 
> "org.apache.hadoop.hive.metastore.model.MOrder" is tagged as 
> "embedded-only" so does not have its own datastore table.
>
> Margus (margusja) Roo
>
> http://margus.roo.ee
>
> skype: margusja
>
> +372 51 48 780
>
> On 10/02/16 10:53, Margus Roo wrote:
>
> > 16/02/10 03:34:23 INFO DataNucleus.Datastore: The class
>
> > "org.apache.hadoop.hive.metastore.model.MFieldSchema" is tagged as
>
> > "embedded-only" so does not have its own datastore table.
>
> > 16/02/10 03:34:23 INFO DataNucleus.Datastore: The class
>
> > "org.apache.hadoop.hive.metastore.model.MOrder" is tagged as
>
> > "embedded-only" so does not have its own datastore table.
>
> > 16/02/10 03:34:23 INFO DataNucleus.Datastore: The class
>
> > "org.apache.hadoop.hive.metastore.model.MFieldSchema" is tagged as
>
> > "embedded-only" so does not have its own datastore table.
>
> > 16/02/10 03:34:23 INFO DataNucleus.Datastore: The class
>
> > "org.apache.hadoop.hive.metastore.model.MOrder" is tagged as
>
> > "embedded-only" so does not have its own datastore table.
>


RE: hive --service metatool -listFSRoot Unable to open a test connection to the given database. JDBC url = jdbc:mysql://hostnamehive?createDatabaseIfNotExist=true, username = hive

Posted by Mich Talebzadeh <mi...@peridale.co.uk>.
No mine is on Oracle database on Oracle 11g and says the same. Notice the bold line do you have that?

 

hive --service metatool -listFSRoot

Initializing HiveMetaTool..

2016-02-10 09:24:44,784 INFO  [main] metastore.ObjectStore: ObjectStore, initialize called

2016-02-10 09:24:44,963 INFO  [main] DataNucleus.Persistence: Property datanucleus.cache.level2 unknown - will be ignored

2016-02-10 09:24:44,964 INFO  [main] DataNucleus.Persistence: Property hive.metastore.integral.jdo.pushdown unknown - will be ignored

2016-02-10 09:24:45,877 INFO  [main] metastore.ObjectStore: Setting MetaStore object pin classes with hive.metastore.cache.pinobjtypes="Table,StorageDescriptor,SerDeInfo,Partition,Database,Type,FieldSchema,Order"

2016-02-10 09:24:49,608 INFO  [main] DataNucleus.Datastore: The class "org.apache.hadoop.hive.metastore.model.MFieldSchema" is tagged as "embedded-only" so does not have its own datastore table.

2016-02-10 09:24:49,609 INFO  [main] DataNucleus.Datastore: The class "org.apache.hadoop.hive.metastore.model.MOrder" is tagged as "embedded-only" so does not have its own datastore table.

2016-02-10 09:24:51,958 INFO  [main] DataNucleus.Datastore: The class "org.apache.hadoop.hive.metastore.model.MFieldSchema" is tagged as "embedded-only" so does not have its own datastore table.

2016-02-10 09:24:51,958 INFO  [main] DataNucleus.Datastore: The class "org.apache.hadoop.hive.metastore.model.MOrder" is tagged as "embedded-only" so does not have its own datastore table.

2016-02-10 09:24:54,182 INFO  [main] DataNucleus.Query: Reading in results for query "org.datanucleus.store.rdbms.query.SQLQuery@0" since the connection used is closing

2016-02-10 09:24:54,183 INFO  [main] metastore.MetaStoreDirectSql: Using direct SQL, underlying DB is ORACLE

2016-02-10 09:24:54,185 INFO  [main] metastore.ObjectStore: Initialized ObjectStore

Listing FS Roots..

hdfs://rhes564:9000/user/hive/warehouse

hdfs://rhes564:9000/user/hive/warehouse/oraclehadoop.db

hdfs://rhes564:9000/user/hive/warehouse/asehadoop.db

hdfs://rhes564:9000/user/hive/warehouse/test.db

hdfs://rhes564:9000/user/hive/warehouse/iqhadoop.db

 

Dr Mich Talebzadeh

 

LinkedIn  https://www.linkedin.com/profile/view?id=AAEAAAAWh2gBxianrbJd6zP6AcPCCdOABUrV8Pw

 

http://talebzadehmich.wordpress.com

 

NOTE: The information in this email is proprietary and confidential. This message is for the designated recipient only, if you are not the intended recipient, you should destroy it immediately. Any information in this message shall not be understood as given or endorsed by Peridale Technology Ltd, its subsidiaries or their employees, unless expressly so stated. It is the responsibility of the recipient to ensure that this email is virus free, therefore neither Peridale Technology Ltd, its subsidiaries nor their employees accept any responsibility.

 

 

 

-----Original Message-----
From: Margus Roo [mailto:margus@roo.ee] 
Sent: 10 February 2016 09:05
To: user@hive.apache.org
Subject: Re: hive --service metatool -listFSRoot Unable to open a test connection to the given database. JDBC url = jdbc:mysql://hostnamehive?createDatabaseIfNotExist=true, username = hive

 

Does thous lines meaning that I have embedded metastore?

16/02/10 03:34:23 INFO DataNucleus.Datastore: The class "org.apache.hadoop.hive.metastore.model.MFieldSchema" is tagged as "embedded-only" so does not have its own datastore table.

16/02/10 03:34:23 INFO DataNucleus.Datastore: The class "org.apache.hadoop.hive.metastore.model.MOrder" is tagged as "embedded-only" so does not have its own datastore table.

16/02/10 03:34:23 INFO DataNucleus.Datastore: The class "org.apache.hadoop.hive.metastore.model.MFieldSchema" is tagged as "embedded-only" so does not have its own datastore table.

16/02/10 03:34:23 INFO DataNucleus.Datastore: The class "org.apache.hadoop.hive.metastore.model.MOrder" is tagged as "embedded-only" so does not have its own datastore table.

 

 

Margus (margusja) Roo

 <http://margus.roo.ee> http://margus.roo.ee

skype: margusja

+372 51 48 780

 

On 10/02/16 10:53, Margus Roo wrote:

> 16/02/10 03:34:23 INFO DataNucleus.Datastore: The class 

> "org.apache.hadoop.hive.metastore.model.MFieldSchema" is tagged as 

> "embedded-only" so does not have its own datastore table.

> 16/02/10 03:34:23 INFO DataNucleus.Datastore: The class 

> "org.apache.hadoop.hive.metastore.model.MOrder" is tagged as 

> "embedded-only" so does not have its own datastore table.

> 16/02/10 03:34:23 INFO DataNucleus.Datastore: The class 

> "org.apache.hadoop.hive.metastore.model.MFieldSchema" is tagged as 

> "embedded-only" so does not have its own datastore table.

> 16/02/10 03:34:23 INFO DataNucleus.Datastore: The class 

> "org.apache.hadoop.hive.metastore.model.MOrder" is tagged as 

> "embedded-only" so does not have its own datastore table. 


Re: hive --service metatool -listFSRoot Unable to open a test connection to the given database. JDBC url = jdbc:mysql://hostnamehive?createDatabaseIfNotExist=true, username = hive

Posted by Margus Roo <ma...@roo.ee>.
Does thous lines meaning that I have embedded metastore?
16/02/10 03:34:23 INFO DataNucleus.Datastore: The class 
"org.apache.hadoop.hive.metastore.model.MFieldSchema" is tagged as 
"embedded-only" so does not have its own datastore table.
16/02/10 03:34:23 INFO DataNucleus.Datastore: The class 
"org.apache.hadoop.hive.metastore.model.MOrder" is tagged as 
"embedded-only" so does not have its own datastore table.
16/02/10 03:34:23 INFO DataNucleus.Datastore: The class 
"org.apache.hadoop.hive.metastore.model.MFieldSchema" is tagged as 
"embedded-only" so does not have its own datastore table.
16/02/10 03:34:23 INFO DataNucleus.Datastore: The class 
"org.apache.hadoop.hive.metastore.model.MOrder" is tagged as 
"embedded-only" so does not have its own datastore table.


Margus (margusja) Roo
http://margus.roo.ee
skype: margusja
+372 51 48 780

On 10/02/16 10:53, Margus Roo wrote:
> 16/02/10 03:34:23 INFO DataNucleus.Datastore: The class 
> "org.apache.hadoop.hive.metastore.model.MFieldSchema" is tagged as 
> "embedded-only" so does not have its own datastore table.
> 16/02/10 03:34:23 INFO DataNucleus.Datastore: The class 
> "org.apache.hadoop.hive.metastore.model.MOrder" is tagged as 
> "embedded-only" so does not have its own datastore table.
> 16/02/10 03:34:23 INFO DataNucleus.Datastore: The class 
> "org.apache.hadoop.hive.metastore.model.MFieldSchema" is tagged as 
> "embedded-only" so does not have its own datastore table.
> 16/02/10 03:34:23 INFO DataNucleus.Datastore: The class 
> "org.apache.hadoop.hive.metastore.model.MOrder" is tagged as 
> "embedded-only" so does not have its own datastore table.