From notifications-return-112-archive-asf-public=cust-asf.ponee.io@nemo.apache.org Thu Feb 14 15:27:02 2019 Return-Path: X-Original-To: archive-asf-public@cust-asf.ponee.io Delivered-To: archive-asf-public@cust-asf.ponee.io Received: from mail.apache.org (hermes.apache.org [140.211.11.3]) by mx-eu-01.ponee.io (Postfix) with SMTP id 2F45B180626 for ; Thu, 14 Feb 2019 16:27:02 +0100 (CET) Received: (qmail 99725 invoked by uid 500); 14 Feb 2019 15:27:01 -0000 Mailing-List: contact notifications-help@nemo.apache.org; run by ezmlm Precedence: bulk List-Help: List-Unsubscribe: List-Post: List-Id: Reply-To: dev@nemo.apache.org Delivered-To: mailing list notifications@nemo.apache.org Received: (qmail 99713 invoked by uid 99); 14 Feb 2019 15:27:01 -0000 Received: from ec2-52-202-80-70.compute-1.amazonaws.com (HELO gitbox.apache.org) (52.202.80.70) by apache.org (qpsmtpd/0.29) with ESMTP; Thu, 14 Feb 2019 15:27:01 +0000 From: GitBox To: notifications@nemo.apache.org Subject: [GitHub] wynot12 commented on a change in pull request #192: [NEMO-335] DB for storing metrics Message-ID: <155015802078.19550.265077887784660420.gitbox@gitbox.apache.org> Date: Thu, 14 Feb 2019 15:27:00 -0000 Content-Type: text/plain; charset=utf-8 Content-Transfer-Encoding: 8bit wynot12 commented on a change in pull request #192: [NEMO-335] DB for storing metrics URL: https://github.com/apache/incubator-nemo/pull/192#discussion_r256881119 ########## File path: runtime/common/src/main/java/org/apache/nemo/runtime/common/metric/MetricUtils.java ########## @@ -0,0 +1,312 @@ +/* + * Licensed to the Apache Software Foundation (ASF) under one + * or more contributor license agreements. See the NOTICE file + * distributed with this work for additional information + * regarding copyright ownership. The ASF licenses this file + * to you under the Apache License, Version 2.0 (the + * "License"); you may not use this file except in compliance + * with the License. You may obtain a copy of the License at + * + * http://www.apache.org/licenses/LICENSE-2.0 + * + * Unless required by applicable law or agreed to in writing, + * software distributed under the License is distributed on an + * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY + * KIND, either express or implied. See the License for the + * specific language governing permissions and limitations + * under the License. + */ + +package org.apache.nemo.runtime.common.metric; + +import com.google.common.collect.HashBiMap; +import org.apache.commons.lang3.SerializationUtils; +import org.apache.nemo.common.Pair; +import org.apache.nemo.common.coder.DecoderFactory; +import org.apache.nemo.common.coder.EncoderFactory; +import org.apache.nemo.common.exception.MetricException; +import org.apache.nemo.common.ir.IRDAG; +import org.apache.nemo.common.ir.executionproperty.ExecutionProperty; +import org.slf4j.Logger; +import org.slf4j.LoggerFactory; + +import java.io.ByteArrayInputStream; +import java.io.IOException; +import java.nio.file.Files; +import java.nio.file.Path; +import java.nio.file.Paths; +import java.sql.*; +import java.util.Enumeration; +import java.util.concurrent.CountDownLatch; +import java.util.stream.Stream; + +/** + * Utility class for metrics. + */ +public final class MetricUtils { + private static final Logger LOG = LoggerFactory.getLogger(MetricUtils.class.getName()); + + private static final CountDownLatch META_DATA_LOADED = new CountDownLatch(1); + private static final CountDownLatch MUST_UPDATE_INDEX_EP_KEY_BI_MAP = new CountDownLatch(1); + private static final CountDownLatch MUST_UPDATE_INDEX_EP_BI_MAP = new CountDownLatch(1); + + private static final Pair>, + HashBiMap, ExecutionProperty>> BI_MAP_BI_MAP_PAIR = loadBiMaps(); + // BiMap of (1) INDEX and (2) the Execution Property class + private static final HashBiMap> + INDEX_EP_KEY_BI_MAP = BI_MAP_BI_MAP_PAIR.left(); + // BiMap of (1) the Execution Property class INDEX and the value INDEX pair and (2) the Execution Property. + private static final HashBiMap, ExecutionProperty> + INDEX_EP_BI_MAP = BI_MAP_BI_MAP_PAIR.right(); + + private static final int VERTEX = 1; + private static final int EDGE = 2; + + public static final String SQLITE_DB_NAME = + "jdbc:sqlite:" + MetricUtils.fetchProjectRootPath() + "/optimization_db.sqlite3"; + public static final String POSTGRESQL_METADATA_DB_NAME = + "jdbc:postgresql://nemo-optimization.cabbufr3evny.us-west-2.rds.amazonaws.com:5432/nemo_optimization"; + private static final String META_TABLE_NAME = "nemo_optimization_meta"; + + /** + * Private constructor. + */ + private MetricUtils() { + } + + /** + * Load the BiMaps (lightweight) Metadata from the DB. + * @return the loaded BiMaps, or initialized ones. + */ + private static Pair>, + HashBiMap, ExecutionProperty>> loadBiMaps() { + deregisterBeamDriver(); + try (final Connection c = DriverManager.getConnection(MetricUtils.POSTGRESQL_METADATA_DB_NAME, + "postgres", "fake_password")) { + try (final Statement statement = c.createStatement()) { + statement.setQueryTimeout(30); // set timeout to 30 sec. + + statement.executeUpdate( + "CREATE TABLE IF NOT EXISTS " + META_TABLE_NAME + + " (key TEXT NOT NULL UNIQUE, data BYTEA NOT NULL);"); + + final ResultSet rsl = statement.executeQuery( + "SELECT * FROM " + META_TABLE_NAME + " WHERE key='INDEX_EP_KEY';"); + LOG.info("Metadata can be loaded."); + if (rsl.next()) { + final HashBiMap> indexEpKeyBiMap = + SerializationUtils.deserialize(rsl.getBytes("Data")); + rsl.close(); + + final ResultSet rsr = statement.executeQuery( + "SELECT * FROM " + META_TABLE_NAME + " WHERE key='INDEX_EP';"); + if (rsr.next()) { + final HashBiMap, ExecutionProperty> indexEpBiMap = + SerializationUtils.deserialize(rsr.getBytes("Data")); + rsr.close(); + + META_DATA_LOADED.countDown(); + LOG.info("Metadata successfully loaded from DB."); + return Pair.of(indexEpKeyBiMap, indexEpBiMap); + } else { + META_DATA_LOADED.countDown(); + LOG.info("No initial metadata for Index-EP map."); + return Pair.of(indexEpKeyBiMap, HashBiMap.create()); + } + } else { + META_DATA_LOADED.countDown(); + LOG.info("No initial metadata."); + return Pair.of(HashBiMap.create(), HashBiMap.create()); + } + } catch (Exception e) { + LOG.warn("Loading metadata from DB failed: ", e); + return Pair.of(HashBiMap.create(), HashBiMap.create()); + } + } catch (Exception e) { + LOG.warn("Loading metadata from DB failed : ", e); + return Pair.of(HashBiMap.create(), HashBiMap.create()); + } + } + + public static Boolean metaDataLoaded() { + return META_DATA_LOADED.getCount() == 0; + } + + /** + * Save the BiMaps to DB if changes are necessary (rarely executed). + */ + private static void saveBiMaps() { + if (!metaDataLoaded() + || (MUST_UPDATE_INDEX_EP_BI_MAP.getCount() + MUST_UPDATE_INDEX_EP_KEY_BI_MAP.getCount() == 2)) { + // no need to update + LOG.info("Not saving Metadata: metadata loaded: {}, Index-EP data: {}, Index-EP Key data: {}", + metaDataLoaded(), MUST_UPDATE_INDEX_EP_BI_MAP.getCount() == 0, MUST_UPDATE_INDEX_EP_KEY_BI_MAP.getCount() == 0); + return; + } + LOG.info("Saving Metadata.."); + + deregisterBeamDriver(); + try (final Connection c = DriverManager.getConnection(MetricUtils.POSTGRESQL_METADATA_DB_NAME, + "postgres", "fake_password")) { + try (final Statement statement = c.createStatement()) { + statement.setQueryTimeout(30); // set timeout to 30 sec. + + if (MUST_UPDATE_INDEX_EP_KEY_BI_MAP.getCount() == 0) { + try (final PreparedStatement pstmt = c.prepareStatement( + "INSERT INTO " + META_TABLE_NAME + " (key, data) " + + "VALUES ('INDEX_EP_KEY', ?) ON CONFLICT (key) DO UPDATE SET data = excluded.data;")) { + pstmt.setBinaryStream(1, + new ByteArrayInputStream(SerializationUtils.serialize(INDEX_EP_KEY_BI_MAP))); + pstmt.executeUpdate(); + LOG.info("Index-EP Key Metadata saved to DB."); + } + } + + if (MUST_UPDATE_INDEX_EP_BI_MAP.getCount() == 0) { + try (final PreparedStatement pstmt = + c.prepareStatement("INSERT INTO " + META_TABLE_NAME + "(key, data) " + + "VALUES ('INDEX_EP', ?) ON CONFLICT (key) DO UPDATE SET data = excluded.data;")) { + pstmt.setBinaryStream(1, + new ByteArrayInputStream(SerializationUtils.serialize(INDEX_EP_BI_MAP))); + pstmt.executeUpdate(); + LOG.info("Index-EP Metadata saved to DB."); + } + } + } + } catch (SQLException e) { + LOG.warn("Saving of Metadata to DB failed: ", e); + } + } + + /** + * Stringify execution properties of an IR DAG. + * @param irdag IR DAG to observe. + * @return the pair of stringified execution properties. Left is for vertices, right is for edges. + */ + static Pair stringifyIRDAGProperties(final IRDAG irdag) { + final StringBuilder vStringBuilder = new StringBuilder(); + final StringBuilder eStringBuilder = new StringBuilder(); + + irdag.getVertices().forEach(v -> + v.getExecutionProperties().forEachProperties(ep -> + epFormatter(vStringBuilder, VERTEX, v.getNumericId(), ep))); + + irdag.getVertices().forEach(v -> + irdag.getIncomingEdgesOf(v).forEach(e -> + e.getExecutionProperties().forEachProperties(ep -> + epFormatter(eStringBuilder, EDGE, e.getNumericId(), ep)))); + + saveBiMaps(); Review comment: Out of context. ---------------------------------------------------------------- This is an automated message from the Apache Git Service. To respond to the message, please log on GitHub and use the URL above to go to the specific comment. For queries about this service, please contact Infrastructure at: users@infra.apache.org With regards, Apache Git Services