You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@tvm.apache.org by GitBox <gi...@apache.org> on 2021/05/12 13:03:09 UTC

[GitHub] [tvm] tqchen commented on a change in pull request #7952: [IR][Pass][Instrument] Pass instrument framework

tqchen commented on a change in pull request #7952:
URL: https://github.com/apache/tvm/pull/7952#discussion_r631011618



##########
File path: python/tvm/ir/instrument.py
##########
@@ -0,0 +1,128 @@
+# 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.
+# pylint: disable=invalid-name,unused-argument
+"""Common pass instrumentation across IR variants."""
+import tvm._ffi
+import tvm.runtime
+
+from . import _ffi_instrument_api
+
+
+@tvm._ffi.register_object("instrument.PassInstrument")
+class PassInstrument(tvm.runtime.Object):

Review comment:
       Would be great to make it more python style(one decorator that registers all functions), see tricks here https://github.com/apache/tvm/blob/main/python/tvm/ir/transform.py#L253

##########
File path: include/tvm/ir/instrument.h
##########
@@ -0,0 +1,244 @@
+/*
+ * 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.
+ */
+
+/*!
+ * \file tvm/ir/instrument.h
+ *
+ * This file implements a pass instrument infrastructure, inspired from LLVM and MLIR.
+ * It inserts instrumentation points between passes run.
+ *
+ * Within a pass context (tvm::transfom::PassContext), the instrumentation call sequence will like:
+ *
+ *   Instrument SetUp
+ *
+ *     if (Instrument Before Pass)
+ *       Pass Run
+ *       Instrument After Pass
+ *
+ *     if (Instrument Before Pass)
+ *       Pass Run
+ *       Instrument After Pass
+ *
+ *   Instrument TearDown
+ *
+ *
+ * Instrument point before pass can determine particular pass is disable or not depends on the
+ * callback registered.
+ */
+#ifndef TVM_IR_INSTRUMENT_H_
+#define TVM_IR_INSTRUMENT_H_
+
+#include <tvm/node/reflection.h>
+#include <tvm/runtime/container.h>
+
+#include <utility>
+#include <vector>
+
+namespace tvm {
+
+class IRModule;
+
+// Forward class for PassInstrumentNode methods
+namespace transform {
+class PassInfo;
+}  // namespace transform
+
+namespace instrument {
+
+/*!
+ * \brief A callback type for set up or clean up instrument environment.
+ */
+using InstrumentEnvFunc = runtime::TypedPackedFunc<void()>;
+
+/*!
+ * \brief A callback template for instrumenting before/after environment.
+ * \tparam RetTy the return type of callback.
+ */
+template <typename RetTy = void>
+using PassInstrumentFunc =
+    runtime::TypedPackedFunc<RetTy(const IRModule&, const transform::PassInfo&)>;
+
+/*!
+ * \brief PassInstrumentNode forms an instrument implementation.
+ * It provides API for users to register callbacks at different instrument point.
+ * \sa PassInstrument
+ */
+class PassInstrumentNode : public Object {
+ public:
+  /*! \brief Name of this pass instrument object. */
+  String name;
+
+  /*! \brief Callback for instrumentation environment set up. */
+  InstrumentEnvFunc set_up_callback;
+  /*! \brief Callback for instrumentation environment clean up. */
+  InstrumentEnvFunc tear_down_callback;
+
+  /*! \brief Callback to run before a pass. */
+  PassInstrumentFunc</* RetTy */ bool> run_before_pass_callback;

Review comment:
       would be good to directly inline the typed packedfunc as they are not too long

##########
File path: include/tvm/ir/instrument.h
##########
@@ -0,0 +1,244 @@
+/*
+ * 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.
+ */
+
+/*!
+ * \file tvm/ir/instrument.h
+ *
+ * This file implements a pass instrument infrastructure, inspired from LLVM and MLIR.
+ * It inserts instrumentation points between passes run.
+ *
+ * Within a pass context (tvm::transfom::PassContext), the instrumentation call sequence will like:
+ *
+ *   Instrument SetUp
+ *
+ *     if (Instrument Before Pass)
+ *       Pass Run
+ *       Instrument After Pass
+ *
+ *     if (Instrument Before Pass)
+ *       Pass Run
+ *       Instrument After Pass
+ *
+ *   Instrument TearDown
+ *
+ *
+ * Instrument point before pass can determine particular pass is disable or not depends on the
+ * callback registered.
+ */
+#ifndef TVM_IR_INSTRUMENT_H_
+#define TVM_IR_INSTRUMENT_H_
+
+#include <tvm/node/reflection.h>
+#include <tvm/runtime/container.h>
+
+#include <utility>
+#include <vector>
+
+namespace tvm {
+
+class IRModule;
+
+// Forward class for PassInstrumentNode methods
+namespace transform {
+class PassInfo;
+}  // namespace transform
+
+namespace instrument {
+
+/*!
+ * \brief A callback type for set up or clean up instrument environment.
+ */
+using InstrumentEnvFunc = runtime::TypedPackedFunc<void()>;
+
+/*!
+ * \brief A callback template for instrumenting before/after environment.
+ * \tparam RetTy the return type of callback.
+ */
+template <typename RetTy = void>
+using PassInstrumentFunc =
+    runtime::TypedPackedFunc<RetTy(const IRModule&, const transform::PassInfo&)>;
+
+/*!
+ * \brief PassInstrumentNode forms an instrument implementation.
+ * It provides API for users to register callbacks at different instrument point.
+ * \sa PassInstrument
+ */
+class PassInstrumentNode : public Object {
+ public:
+  /*! \brief Name of this pass instrument object. */
+  String name;
+
+  /*! \brief Callback for instrumentation environment set up. */
+  InstrumentEnvFunc set_up_callback;
+  /*! \brief Callback for instrumentation environment clean up. */
+  InstrumentEnvFunc tear_down_callback;
+
+  /*! \brief Callback to run before a pass. */
+  PassInstrumentFunc</* RetTy */ bool> run_before_pass_callback;
+  /*! \brief Callback to run after a pass. */
+  PassInstrumentFunc<> run_after_pass_callback;
+
+  /*!
+   * \brief Register a callback to run at set up point.
+   *
+   * \param callback The set up function.
+   */
+  void RegisterSetUpCallback(InstrumentEnvFunc callback) { set_up_callback = std::move(callback); }
+
+  /*
+   * \brief Register a callback to run at clean up point.
+   *
+   * \param callback The clean up function.
+   */
+  void RegisterTearDownCallback(InstrumentEnvFunc callback) {
+    tear_down_callback = std::move(callback);
+  }
+
+  /*!
+   * \brief Register a callback to run before pass run.
+   *
+   * \param callback The function to run before pass: return false to skip pass; return true to
+   * run pass.
+   */
+  void RegisterRunBeforePassCallback(PassInstrumentFunc<bool> callback) {
+    run_before_pass_callback = std::move(callback);
+  }
+
+  /*!
+   * \brief Register a callback to run after pass run.
+   *
+   * \param callback The function to run after pass.
+   */
+  void RegisterRunAfterPassCallback(PassInstrumentFunc<> callback) {
+    run_after_pass_callback = std::move(callback);
+  }
+
+  void VisitAttrs(AttrVisitor* v) { v->Visit("name", &name); }
+
+  /*! \brief Set up environment for instrumentation. */
+  void SetUp() const;
+
+  /*! \brief Clean up instrumentation environment. */
+  void TearDown() const;
+
+  /*!
+   * \brief Instrument before pass run, determine whether to run the pass or not.
+   * \param mod The module that an optimization pass runs on.
+   * \param info The pass information.
+   *
+   * \return true to run the pass; false to skip the pass.
+   */
+  bool RunBeforePass(const IRModule& mod, const transform::PassInfo& info) const;
+
+  /*!
+   * \brief Instrument after pass run.
+   *
+   * \param mod The module that an optimization pass runs on.
+   * \param info The pass information.
+   */
+  void RunAfterPass(const IRModule& mod, const transform::PassInfo& info) const;
+
+  static constexpr const char* _type_key = "instrument.PassInstrument";
+  TVM_DECLARE_FINAL_OBJECT_INFO(PassInstrumentNode, Object);
+};
+
+/*!
+ * \brief Managed reference class for PassInstrumentNode
+ * \sa PassInstrumentNode
+ */
+class PassInstrument : public ObjectRef {
+ public:
+  /*!
+   * \brief Constructor
+   * \param name Name for this instrumentation.
+   */
+  TVM_DLL PassInstrument(String name);
+
+  /*!
+   * \brief mutable accessor.
+   * \return mutable access pointer.
+   */
+  PassInstrumentNode* operator->() {
+    ICHECK(get() != nullptr);
+    return static_cast<PassInstrumentNode*>(get_mutable());
+  }
+
+  TVM_DEFINE_OBJECT_REF_METHODS(PassInstrument, ObjectRef, PassInstrumentNode);
+};
+
+/*!
+ * \brief PassInstrumentorNode collects a set of PassInstrument implementations, invokes the
+ * implementations' methods at different instrument points.
+ * \sa PassInstrumentor
+ */
+class PassInstrumentorNode : public Object {
+ public:
+  Array<PassInstrument> pass_instruments;
+
+  void VisitAttrs(AttrVisitor* v) { v->Visit("pass_instruments", &pass_instruments); }
+
+  /*! \brief Set up environment for instrument implementations. */
+  void SetUp() const;
+
+  /*! \brief Clean up environment for instrument implementations. */
+  void TearDown() const;

Review comment:
       not sure setup and teardown is needed in our case. We can do setup in constructor and teardown in destructors, so likely we can omit these two calls for now.
   
   If we want to keep these two functions, we need to discuss when to call these two functions. Perhaps setup should be called, in PassContext::EnterWithScope and TearDown should be called during PassContext::ExitWithScope

##########
File path: python/tvm/ir/transform.py
##########
@@ -65,12 +65,20 @@ class PassContext(tvm.runtime.Object):
     disabled_pass : Optional[Union[List[str], Set[str], Tuple[str]]]
         The list of passes that are disabled.
 
+    pass_instrumentor : Optional[tvm.instrument.PassInstrumentor]
+        The pass instrumentor that collects pass instrument implementations
+
     config : Optional[Dict[str, Object]]
         Additional configurations for specific passes.
     """
 
     def __init__(
-        self, opt_level=2, required_pass=None, disabled_pass=None, trace=None, config=None
+        self,
+        opt_level=2,
+        required_pass=None,
+        disabled_pass=None,
+        pass_instrumentor=None,

Review comment:
       would be good to delibrate on API namings, per https://tvm.apache.org/docs/contribute/code_review.html#deliberate-on-api-and-data-structures.
   
   For example given we are already in PassCOntext, perhaps we can remove the prefix `pass_`

##########
File path: include/tvm/ir/instrument.h
##########
@@ -0,0 +1,244 @@
+/*
+ * 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.
+ */
+
+/*!
+ * \file tvm/ir/instrument.h
+ *
+ * This file implements a pass instrument infrastructure, inspired from LLVM and MLIR.
+ * It inserts instrumentation points between passes run.
+ *
+ * Within a pass context (tvm::transfom::PassContext), the instrumentation call sequence will like:
+ *
+ *   Instrument SetUp
+ *
+ *     if (Instrument Before Pass)
+ *       Pass Run
+ *       Instrument After Pass
+ *
+ *     if (Instrument Before Pass)
+ *       Pass Run
+ *       Instrument After Pass
+ *
+ *   Instrument TearDown
+ *
+ *
+ * Instrument point before pass can determine particular pass is disable or not depends on the
+ * callback registered.
+ */
+#ifndef TVM_IR_INSTRUMENT_H_
+#define TVM_IR_INSTRUMENT_H_
+
+#include <tvm/node/reflection.h>
+#include <tvm/runtime/container.h>
+
+#include <utility>
+#include <vector>
+
+namespace tvm {
+
+class IRModule;
+
+// Forward class for PassInstrumentNode methods
+namespace transform {
+class PassInfo;
+}  // namespace transform
+
+namespace instrument {
+
+/*!
+ * \brief A callback type for set up or clean up instrument environment.
+ */
+using InstrumentEnvFunc = runtime::TypedPackedFunc<void()>;
+
+/*!
+ * \brief A callback template for instrumenting before/after environment.
+ * \tparam RetTy the return type of callback.
+ */
+template <typename RetTy = void>
+using PassInstrumentFunc =
+    runtime::TypedPackedFunc<RetTy(const IRModule&, const transform::PassInfo&)>;
+
+/*!
+ * \brief PassInstrumentNode forms an instrument implementation.
+ * It provides API for users to register callbacks at different instrument point.
+ * \sa PassInstrument
+ */
+class PassInstrumentNode : public Object {
+ public:

Review comment:
       These callbakcs can sit in implementation of instrument.cc, since from they are only needed for fronend FFIs to provide instructment class. See https://github.com/apache/tvm/blob/main/include/tvm/ir/transform.h#L300 for a similar example. We can make PassInstrumentor a virtual class which allows sub-class overloading in normal C++ style

##########
File path: include/tvm/ir/instrument.h
##########
@@ -0,0 +1,244 @@
+/*
+ * 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.
+ */
+
+/*!
+ * \file tvm/ir/instrument.h
+ *
+ * This file implements a pass instrument infrastructure, inspired from LLVM and MLIR.
+ * It inserts instrumentation points between passes run.
+ *
+ * Within a pass context (tvm::transfom::PassContext), the instrumentation call sequence will like:
+ *
+ *   Instrument SetUp
+ *
+ *     if (Instrument Before Pass)
+ *       Pass Run
+ *       Instrument After Pass
+ *
+ *     if (Instrument Before Pass)
+ *       Pass Run
+ *       Instrument After Pass
+ *
+ *   Instrument TearDown
+ *
+ *
+ * Instrument point before pass can determine particular pass is disable or not depends on the
+ * callback registered.
+ */
+#ifndef TVM_IR_INSTRUMENT_H_
+#define TVM_IR_INSTRUMENT_H_
+
+#include <tvm/node/reflection.h>
+#include <tvm/runtime/container.h>
+
+#include <utility>
+#include <vector>
+
+namespace tvm {
+
+class IRModule;
+
+// Forward class for PassInstrumentNode methods
+namespace transform {
+class PassInfo;
+}  // namespace transform
+
+namespace instrument {
+
+/*!
+ * \brief A callback type for set up or clean up instrument environment.
+ */
+using InstrumentEnvFunc = runtime::TypedPackedFunc<void()>;
+
+/*!
+ * \brief A callback template for instrumenting before/after environment.
+ * \tparam RetTy the return type of callback.
+ */
+template <typename RetTy = void>
+using PassInstrumentFunc =
+    runtime::TypedPackedFunc<RetTy(const IRModule&, const transform::PassInfo&)>;
+
+/*!
+ * \brief PassInstrumentNode forms an instrument implementation.
+ * It provides API for users to register callbacks at different instrument point.
+ * \sa PassInstrument
+ */
+class PassInstrumentNode : public Object {
+ public:
+  /*! \brief Name of this pass instrument object. */
+  String name;
+
+  /*! \brief Callback for instrumentation environment set up. */
+  InstrumentEnvFunc set_up_callback;
+  /*! \brief Callback for instrumentation environment clean up. */
+  InstrumentEnvFunc tear_down_callback;
+
+  /*! \brief Callback to run before a pass. */
+  PassInstrumentFunc</* RetTy */ bool> run_before_pass_callback;
+  /*! \brief Callback to run after a pass. */
+  PassInstrumentFunc<> run_after_pass_callback;
+
+  /*!
+   * \brief Register a callback to run at set up point.
+   *
+   * \param callback The set up function.
+   */
+  void RegisterSetUpCallback(InstrumentEnvFunc callback) { set_up_callback = std::move(callback); }
+
+  /*
+   * \brief Register a callback to run at clean up point.
+   *
+   * \param callback The clean up function.
+   */
+  void RegisterTearDownCallback(InstrumentEnvFunc callback) {
+    tear_down_callback = std::move(callback);
+  }
+
+  /*!
+   * \brief Register a callback to run before pass run.
+   *
+   * \param callback The function to run before pass: return false to skip pass; return true to
+   * run pass.
+   */
+  void RegisterRunBeforePassCallback(PassInstrumentFunc<bool> callback) {
+    run_before_pass_callback = std::move(callback);
+  }
+
+  /*!
+   * \brief Register a callback to run after pass run.
+   *
+   * \param callback The function to run after pass.
+   */
+  void RegisterRunAfterPassCallback(PassInstrumentFunc<> callback) {
+    run_after_pass_callback = std::move(callback);
+  }
+
+  void VisitAttrs(AttrVisitor* v) { v->Visit("name", &name); }
+
+  /*! \brief Set up environment for instrumentation. */
+  void SetUp() const;
+
+  /*! \brief Clean up instrumentation environment. */
+  void TearDown() const;
+
+  /*!
+   * \brief Instrument before pass run, determine whether to run the pass or not.
+   * \param mod The module that an optimization pass runs on.
+   * \param info The pass information.
+   *
+   * \return true to run the pass; false to skip the pass.
+   */
+  bool RunBeforePass(const IRModule& mod, const transform::PassInfo& info) const;
+
+  /*!
+   * \brief Instrument after pass run.
+   *
+   * \param mod The module that an optimization pass runs on.
+   * \param info The pass information.
+   */
+  void RunAfterPass(const IRModule& mod, const transform::PassInfo& info) const;
+
+  static constexpr const char* _type_key = "instrument.PassInstrument";
+  TVM_DECLARE_FINAL_OBJECT_INFO(PassInstrumentNode, Object);
+};
+
+/*!
+ * \brief Managed reference class for PassInstrumentNode
+ * \sa PassInstrumentNode
+ */
+class PassInstrument : public ObjectRef {
+ public:
+  /*!
+   * \brief Constructor
+   * \param name Name for this instrumentation.
+   */
+  TVM_DLL PassInstrument(String name);
+
+  /*!
+   * \brief mutable accessor.
+   * \return mutable access pointer.
+   */
+  PassInstrumentNode* operator->() {
+    ICHECK(get() != nullptr);
+    return static_cast<PassInstrumentNode*>(get_mutable());
+  }
+
+  TVM_DEFINE_OBJECT_REF_METHODS(PassInstrument, ObjectRef, PassInstrumentNode);
+};
+
+/*!
+ * \brief PassInstrumentorNode collects a set of PassInstrument implementations, invokes the
+ * implementations' methods at different instrument points.
+ * \sa PassInstrumentor
+ */
+class PassInstrumentorNode : public Object {

Review comment:
       Assuming we will only have one kind of compositional pattern(list, shall we directly put `Array<PassInstrumentor>` in the PassContext?)




-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to 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