1. 19 Mar, 2021 1 commit
    • Daniel Black's avatar
      myseek: AIX has no "tell" · 4ca4d606
      Daniel Black authored
      AIX detects tell in the configure however
      it really isn't there. Use the my_seek aka lseek
      implementation.
      4ca4d606
  2. 18 Mar, 2021 8 commits
    • Igor Babaev's avatar
      MDEV-25112 MIN/MAX aggregation over an indexed column may return wrong result · b34bb81e
      Igor Babaev authored
      If a query with implicit grouping contains in MIN/MAX set function in the
      select list over a column that is a part of an index then the query
      might be subject to MIN/MAX optimization. With this optimization the
      server performs a look-up into an index, fetches a value of the column C
      used in the MIN/MAX function and substitute the MIN/MAX expression for this
      value. This allows to eliminate the table containing C from further join
      processing. In order the optimization to be applied the WHERE condition
      must be a conjunction of simple equality/inequality predicates or/and
      BETWEEN predicates.
      The bug fixed in the patch resulted in fetching a wrong value from the
      index used for MIN/MAX optimization. It may happened when a BETWEEN
      predicate containing the MIN/MAX value followed a strict inequality.
      
      Approved by dmitry.shulga@mariadb.com
      b34bb81e
    • Marko Mäkelä's avatar
      MDEV-10682 Race condition between ANALYZE and STATS_AUTO_RECALC · c557e954
      Marko Mäkelä authored
      ha_innobase::info_low(): While collecting statistics for
      ANALYZE TABLE, ensure that dict_stats_process_entry_from_recalc_pool()
      is not executing on the same table.
      
      We observed result differences for the test innodb.innodb_stats because
      dict_stats_empty_index() was being invoked by the background statistics
      calculation while ha_innobase::analyze() was executing
      dict_stats_analyze_index_level().
      c557e954
    • Marko Mäkelä's avatar
      MDEV-25121: innodb_flush_method=O_DIRECT fails on compressed tables · 6505662c
      Marko Mäkelä authored
      Tests with 4096-byte sector size confirm that it is
      safe to use O_DIRECT with page_compressed tables.
      That had been disabled on Linux, in an attempt to fix MDEV-21584
      which had been filed for the O_DIRECT problems earlier.
      
      The fil_node_t::block_size was being set mostly correctly until
      commit 10dd290b (MDEV-17380)
      introduced a regression in MariaDB Server 10.4.4.
      
      fil_node_t::read_page0(): Initialize fil_node_t::block_size.
      This will probably make similar code in fil_space_extend_must_retry()
      redundant, but we play it safe and will not remove that code.
      
      Thanks to Vladislav Vaintroub for testing this on Microsoft Windows
      using an old-fashioned rotational hard disk with 4KiB sector size.
      
      Reviewed by: Vladislav Vaintroub
      6505662c
    • Vladislav Vaintroub's avatar
      MDEV-21584 - portability fix · 00f620b2
      Vladislav Vaintroub authored
      This patch implements OS_DATA_FILE_NO_O_DIRECT on Windows.
      00f620b2
    • Marko Mäkelä's avatar
      Cleanup: Remove unused OS_DATA_TEMP_FILE · 14a8b700
      Marko Mäkelä authored
      This had been originally added in
      mysql/mysql-server@192bb153b675fe09037a53e456a79eee7211e3a7
      with the motivation to disable O_DIRECT for the dedicated tablespace
      for temporary tables. In MariaDB Server,
      commit 5eb53955 (MDEV-12227)
      should be a better solution.
      
      The code became orphaned later in
      mysql/mysql-server@c61244c0e6c58727cffebfb312ac415a463fa0fe
      and it had been applied to MariaDB Server 10.2.2 in
      commit 2e814d47 and
      commit fec844ac.
      
      Thanks to Vladislav Vaintroub for spotting this.
      14a8b700
    • Jan Lindström's avatar
      MDEV-24916 : Assertion `current_stmt_binlog_format == BINLOG_FORMAT_STMT ||... · c9ba6689
      Jan Lindström authored
      MDEV-24916 : Assertion `current_stmt_binlog_format == BINLOG_FORMAT_STMT || current_stmt_binlog_format == BINLOG_FORMAT_ROW' failed in THD::is_current_stmt_binlog_format_row
      
      Store old value of binlog format before wsrep code so that
      if we bail out because wsrep is not ready for connections
      we can restore binlog format correctly.
      c9ba6689
    • Jan Lindström's avatar
      MDEV-18874 : Galera test MW-286 causes Mutex = TTASEventMutex<GenericPolicy>]:... · f4e14f0e
      Jan Lindström authored
      MDEV-18874 : Galera test MW-286 causes Mutex = TTASEventMutex<GenericPolicy>]: Assertion `!is_owned()' failed. assertion
      
      MDEV-24649 galera.galera_bf_lock_wait MTR failed with sigabrt: Assertion `!is_ow
      ned()' failed in sync0policy.ic on MutexDebug with Mutex = TTASEventMutex<GenericPolicy>
      
      Bug was fixed as part of MDEV-23328, this just adds test cases to
      regression set.
      f4e14f0e
    • Daniel Black's avatar
      mariadb.pc: plugindir is used · 69740581
      Daniel Black authored
      As evidenced by converstation on Zulip,
      knowing where to install a plugin is important too.
      69740581
  3. 17 Mar, 2021 1 commit
  4. 16 Mar, 2021 1 commit
    • Julius Goryavsky's avatar
      MDEV-21039: Server fails to start with unknown mysqld_safe options · bf303e82
      Julius Goryavsky authored
      Adding any unknown option to the "[mysqld_safe]" section makes
      mysqld impossible to start with mysqld_multi. For example, after
      adding the unknown option "numa_interleave" to the "[mysqld_safe]"
      section, mysqld_multi exits with the following diagnostics:
      
      [ERROR] /usr/local/mysql/bin/mysqld: unknown option '--numa_interleave'
      
      To get rid of this behavior, this patch adds the passing of the default
      group suffix from mysqld_multi to the mysqld_safe side.
      bf303e82
  5. 15 Mar, 2021 3 commits
  6. 12 Mar, 2021 2 commits
    • Vladislav Vaintroub's avatar
      update libmariadb · ba7d86a6
      Vladislav Vaintroub authored
      ba7d86a6
    • Varun Gupta's avatar
      MDEV-24519: Server crashes in Charset::set_charset upon SELECT · 390de205
      Varun Gupta authored
      The query causing the issue here has implicit grouping for we
      have to produce one row with special values for the aggregates
      (depending on each aggregate function), and NULL values for all
      non-aggregate fields.
      
      The subselect item where implicit grouping was being done,
      null_value for the subselect item was not being set for
      the case when the implicit grouping produces NULL values
      for the items in the select list of the subquery.
      This which was leading to the crash.
      
      The fix would be to set the null_value when all the values
      for the row column have NULL values.
      
      Further changes are
      
      1) etting null_value for Item_singlerow_subselect only
         after val_* functions have been called.
      2) Introduced a parameter null_value_inside to Item_cache that
         would store be set to TRUE if any of the arguments of the
         Item_cache are null.
      
      Reviewed And co-authored by Monty
      390de205
  7. 11 Mar, 2021 3 commits
    • Ian Gilfillan's avatar
      Update sponsors · 1f3f9031
      Ian Gilfillan authored
      1f3f9031
    • Igor Babaev's avatar
      MDEV-24597 Explicit column name error in CTE of UNION · 374ec82f
      Igor Babaev authored
      This bug manifested itself when executing queries with multiple reference
      to a CTE specified by a query expression with union and having its
      column names explicitly declared. In this case the server returned a bogus
      error message about unknown column name. It happened because while for the
      first reference to the CTE the names of the columns returned by the CTE
      specification were properly changed to match the CTE definition for the
      other references it was not done. This was a consequence  of not quite
      complete code of the function With_element::clone_parsed_spec() that forgot
      to set the reference to the CTE definition for unit structures representing
      non-first CTE references.
      
      Approved by dmitry.shulga@mariadb.com
      374ec82f
    • Igor Babaev's avatar
      MDEV-21104 Wrong result (extra rows and wrong values) with incremental BNLH · 90780bb5
      Igor Babaev authored
      This bug could affect multi-way join queries with embedded outer joins that
      contained a conjunctive IS NULL predicate over a non-nullable column from
      inner table of an outer join. The predicate could occur in WHERE condition
      or in ON condition. Due to this bug a wrong result set could be returned by
      the query. The bug manifested itself only when join buffers were employed
      for join operations.
      
      The problem appeared because
      - a bug in the function JOIN_CACHE::get_match_flag_by_pos that not always
        returned proper match flags for embedding outer joins stored together
        with table rows put a join buffer.
      - bug in the function JOIN_CACHE::join_matching_records that not always
        correctly determined that a row from the buffer could be skipped due
        to applied 'not_exists' optimization.
      Example:
        SELECT * FROM t1 LEFT JOIN ((t2 LEFT JOIN t3 ON c = d) JOIN t4) ON b = e
          WHERE e IS NULL;
      
      The patch introduces a new function that finds the match flag for a record
      from join buffer specifying the buffer where this flag has to be found.
      The function is called JOIN_CACHE::get_match_flag_by_pos_from_join_buffer().
      Now this function rather than JOIN_CACHE::get_match_flag_by_pos() is used
      in JOIN_CACHE::skip_if_matched() to check whether a record from the join
      buffer must be ignored when extending the record by null complements.
      Also the code of the function JOIN_CACHE::skip_if_not_needed_match() has
      been changed. The function checks whether a record from the join buffer
      still may produce some useful extensions.
      Also some clarifying comments has been added.
      
      Approved by monty@mariadb.com.
      90780bb5
  8. 10 Mar, 2021 2 commits
    • Marko Mäkelä's avatar
      MDEV-25101 Assertion !strcmp(field->name, "table_name") failed · 1af85581
      Marko Mäkelä authored
      btr_node_ptr_max_size(): Let us remove the debug assertion that was
      added in MDEV-14637. The assertion assumed that no additional
      indexes exist in mysql.innodb_index_stats or mysql.innodb_table_stats.
      The code path is working around an incorrect definition of a table,
      interpreting VARCHAR(64) as the more correct VARCHAR(199).
      
      No test case will be added, because MDEV-24579 proves that executing
      DDL on the statistics tables involves a race condition. The test
      case included the following:
      
      	ALTER TABLE mysql.innodb_index_stats ADD KEY (stat_name);
      	CREATE TABLE t (a INT) ENGINE=InnoDB STATS_PERSISTENT=1;
      1af85581
    • Alice Sherepa's avatar
      reenable tests from engines/funcs · ee12b055
      Alice Sherepa authored
      ee12b055
  9. 09 Mar, 2021 1 commit
    • Igor Babaev's avatar
      MDEV-25002 ON expressions cannot contain outer references · 4020e4ae
      Igor Babaev authored
      A bogus error message was issued for any outer references occurred in
      ON expressions used in subqueries. This prevented execution of queries
      containing subqueries as soon as they used outer references in their ON
      clauses. This happened because the Name_resolution_context structure
      created for any ON expression erroneously had the field outer_context set
      to NULL. The fields select_lex of this structure was not set correctly
      either.
      
      The idea of the fix was taken from mysql code of the function
      push_new_name_resolution_context().
      
      Approved by dmitry.shulga@mariadb.com
      4020e4ae
  10. 08 Mar, 2021 3 commits
    • Sergei Golubchik's avatar
      Correct the value of global memory_used · dc666780
      Sergei Golubchik authored
      As a special hack global memory_used isn't SHOW_LONG_STATUS
      but still relies on calc_sum_of_all_status() being called.
      
      followup for 63f91927
      dc666780
    • Sergei Golubchik's avatar
      2c0b3141
    • Julius Goryavsky's avatar
      MDEV-24853: Duplicate key generated during cluster configuration change · 7345d371
      Julius Goryavsky authored
      Incorrect processing of an auto-incrementing field in the
      WSREP-related code during applying transactions results in
      a duplicate key being created. This is due to the fact that
      at the beginning of the write_row() and update_row() functions,
      the values of the auto-increment parameters are used, which
      are read from the parameters of the current thread, but further
      along the code other values are used, which are read from global
      variables (when applying a transaction). This can happen when
      the cluster configuration has changed while applying a transaction
      (for example in the high_priority_service mode for Galera 4).
      Further during IST processing duplicating key is detected, and
      processing of the DB_DUPLICATE_KEY return code (inside innodb,
      in the write_row() handler) results in a call to the
      wsrep_thd_self_abort() function.
      7345d371
  11. 05 Mar, 2021 1 commit
  12. 04 Mar, 2021 3 commits
    • Marko Mäkelä's avatar
      fixup 58b56f14: Remove dead code · 7759991a
      Marko Mäkelä authored
      row_prebuilt_t::m_no_prefetch: Remove (it was always false).
      row_prebuilt_t::m_read_virtual_key: Remove (it was always false).
      
      Only ha_innopart ever set these fields.
      7759991a
    • Marko Mäkelä's avatar
      MDEV-25051 Race condition between persistent statistics and RENAME TABLE or TRUNCATE · 978e48c9
      Marko Mäkelä authored
      innobase_rename_table(): Invoke dict_stats_wait_bg_to_stop_using_table()
      to ensure that dict_stats_update() cannot be accessing the table name
      that we will be modifying. If we are executing RENAME rather than TRUNCATE,
      reset the flag at the end so that persistent statistics can be calculated
      again.
      
      The race condition was encountered with ASAN and rr.
      Sorry, there is no test case, like there is for nothing related to
      dict_stats_wait_bg_to_stop_using_table(). The entire code is an ugly
      work-around for the failure of dict_stats_process_entry_from_recalc_pool()
      to acquire MDL.
      
      Note: It appears that an ALTER TABLE that is not rebuilding the table
      will fail to reset the flag that blocks the processing of statistics.
      978e48c9
    • Vicențiu Ciorbaru's avatar
      MDEV-25032: Window functions without column references get removed from ORDER BY · 5da6ffe2
      Vicențiu Ciorbaru authored
      row_number() over () window function can be used without any column in the OVER
      clause. Additionally, the item doesn't reference any tables, as it's not
      effectively referencing any table. Rather it is specifically built based
      on the end temporary table used for window function computation.
      
      This caused remove_const function to wrongly drop it from the ORDER
      list. Effectively, we shouldn't be dropping any window function from the
      ORDER clause, so adjust remove_const to account for that.
      
      Reviewed by: Sergei Petrunia sergey@mariadb.com
      5da6ffe2
  13. 03 Mar, 2021 2 commits
  14. 02 Mar, 2021 2 commits
    • Monty's avatar
      MDEV-24532 Table corruption ER_NO_SUCH_TABLE_IN_ENGINE .. on table with foreign key · 676987c4
      Monty authored
      When doing a truncate on an Innodb under lock tables, InnoDB would rename
      the old table to #sql-... and recreate a new 't1' table. The table lock
      would still be on the #sql-table.
      
      When doing ALTER TABLE, Innodb would do the changes on the #sql table
      (which would disappear on close).
      When the SQL layer, as part of inline alter table, would close the
      original t1 table (#sql in InnoDB) and then reopen the t1 table, Innodb
      would notice that this does not match it's own (old) t1 table and
      generate an error.
      
      Fixed by adding code in truncate table that if we are under lock tables
      and truncating an InnoDB table, we would close, reopen and lock the
      table after truncate. This will remove the #sql table and ensure that
      lock tables is using the new empty table.
      
      Reviewer: Marko Mäkelä
      676987c4
    • Dmitry Shulga's avatar
      MDEV-25006: Failed assertion on executing EXPLAIN DELETE statement as a prepared statement · fc774316
      Dmitry Shulga authored
      Attempt to execute EXPLAIN statement on multi-table DELETE statement
      leads to firing firing of the assertion
        DBUG_ASSERT(! is_set());
      in the method Diagnostics_area::set_eof_status.
      
      For example, above mentioned assertion failure happens
      in case any of the following statements
        EXPLAIN DELETE FROM t1.* USING t1
        EXPLAIN DELETE b FROM t1 AS a JOIN t1 AS b
      are executed in prepared statement mode provided the table t1
      does exist.
      
      This assertion is hit by the reason that a status of
      Diagnostics_area is set twice. The first time it is set from
      the function do_select() when the method multi_delete::send_eof()
      called. The second time it is set when the method
      Explain_query::send_explain() calls the method select_send::send_eof
      (this method invokes the method Diagnostics_area::set_eof_status that
      finally hits assertion)
      
      The second invocation for a setter method of the class Diagnostics_area
      is correct and run to send a response containing explain data.
      
      But first invocation of a setter method of the class Diagnostics_area
      is wrong since the function do_select() shouldn't be called at all
      for handling of the EXPLAIN statement.
      
      The reason by that the function do_select() is called during handling of
      the EXPLAIN statement is that the flag SELECT_DESCRIBE not set in the
      data member JOIN::select_options. The flag SELECT_DESCRIBE
      if is copied from values select_lex->options.
      
      During parsing of EXPLAIN statement this flag is set but latter reset
      from the function reinit_stmt_before_use() that is called on
      execution of prepared statement.
        void reinit_stmt_before_use(THD *thd, LEX *lex)
        {
          ...
          for (; sl; sl= sl->next_select_in_list())
          {
            if (sl->changed_elements & TOUCHED_SEL_COND)
            {
              /* remove option which was put by mysql_explain_union() */
              sl->options&= ~SELECT_DESCRIBE;
            ...
            }
         ...
        }
      
      So, to fix the issue the flag SELECT_DESCRIBE is set forcibly at the
      mysql_select() function in case thd->lex->describe set,
      that is in case EXPLAIN being executed.
      fc774316
  15. 01 Mar, 2021 1 commit
    • Sergei Golubchik's avatar
      mtr --gdb: fix for --rr and for a warning · dd9e5827
      Sergei Golubchik authored
      use _RR_TRACE_DIR=dir instead of -o dir, as the former can store
      multiple traces in dir (if, e.g., the test restarts mysqld)
      
      suppress uninitialized warning when $exe is undefined (--manual-XXX)
      dd9e5827
  16. 25 Feb, 2021 3 commits
    • Dmitry Shulga's avatar
      MDEV-24860: Incorrect behaviour of SET STATEMENT in case it is executed as a prepared statement · 259e5243
      Dmitry Shulga authored
      Running statements with SET STATEMENT FOR clause is handled incorrectly in
      case the whole statement is executed in prepared statement mode.
      For example, running of the following statement
        SET STATEMENT sql_mode = 'NO_ENGINE_SUBSTITUTION' FOR CREATE TABLE t1 AS SELECT CONCAT('abc') AS c1;
      results in different definition of the table t1 depending on whether
      the statement is executed as a prepared or as a regular statement.
      
      In first case the column c1 is defined as
        `c1` varchar(3) DEFAULT NULL
      in the last case the column c1 is defined as
        `c1` varchar(3) NOT NULL
      
      Different definition for the column c1 arise due to the fact that
      a value of the data memeber Item_func_concat::maybe_null depends on
      whether strict mode is on or off. Below is definition of the method
      fix_fields() of the class Item_str_func that is base class for the
      class Item_func_concat that is created on parsing the
      SET STATEMENT FOR clause.
      
      bool Item_str_func::fix_fields(THD *thd, Item **ref)
      {
        bool res= Item_func::fix_fields(thd, ref);
        /*
          In Item_str_func::check_well_formed_result() we may set null_value
          flag on the same condition as in test() below.
        */
        maybe_null= maybe_null || thd->is_strict_mode();
        return res;
      }
      
      Although the clause SET STATEMENT sql_mode = 'NO_ENGINE_SUBSTITUTION' FOR
      is parsed on PREPARE phase during processing of the prepared statement,
      real setting of the sql_mode system variable is done on EXECUTION phase.
      On the other hand, the method Item_str_func::fix_fields is called on PREPARE
      phase. In result, thd->is_strict_mode() returns true during calling the method
      Item_str_func::fix_fields(), the data member maybe_null is assigned the value
      true and column c1 is defined as DEFAULT NULL.
      
      To fix the issue the system variables listed in the SET STATEMENT FOR clause
      are set at the beginning of handling the PREPARE phase just right before
      calling  the function check_prepared_statement() and their original values
      restored immediate after return from this function.
      
      Additionally, to avoid code duplication the source code used in the function
      mysql_execute_command for setting variables, specified by SET STATEMENT
      clause, were extracted to the standalone functions
      run_set_statement_if_requested(). This new function is called from
      the function  mysql_execute_command() and the method
      Prepared_statement::prepare().
      259e5243
    • Varun Gupta's avatar
      0a95c922
    • Daniel Black's avatar
      MDEV-24728: Debian include client caching_sha2_password plugin · 577c970c
      Daniel Black authored
      Backport of 4bc31a90
      
      Include client libraries for auth caching_sha2_password and
      sha256_password in the libmariadb3 client library package.
      577c970c
  17. 24 Feb, 2021 1 commit
    • Daniel Black's avatar
      MDEV-23510: arm64 lf_hash alignment of pointers · 1635686b
      Daniel Black authored
      volatile != atomic.
      
      volatile has no memory barrier schemantics, its for mmaped IO
      so lets allow some optimizer gains and stop pretending it helps
      with memory atomicity.
      
      The MDEV lists a SEGV an assumption is made that an address was
      partially read. As C packs structs strictly in order and on arm64 the
      cache line size is 128 bits. A pointer (link - 64 bits), followed
      by a hashnr (uint32 - 32 bits), leaves the following key (uchar *
      64 bits), neither naturally aligned to any pointer and worse, split
      across a cache line which is the processors view of an atomic
      reservation of memory.
      
      lf_dynarray_lvalue is assumed to return a 64 bit aligned address.
      
      As a solution move the 32bit hashnr to the end so we don't get the
      *key pointer split across two cache lines.
      
      Tested by: Krunal Bauskar
      Reviewer: Marko Mäkelä
      1635686b
  18. 23 Feb, 2021 2 commits