You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@arrow.apache.org by ko...@apache.org on 2020/03/22 00:21:38 UTC

[arrow] branch master updated (0569da4 -> d542482)

This is an automated email from the ASF dual-hosted git repository.

kou pushed a change to branch master
in repository https://gitbox.apache.org/repos/asf/arrow.git.


    from 0569da4  ARROW-7857: [Python] Revert temporary changes to pandas extension array tests
     add d542482  ARROW-7896: [C++] Refactor from #include guards to #pragma once

No new revisions were added by this update.

Summary of changes:
 cpp/src/arrow/adapters/orc/adapter.h                     | 5 +----
 cpp/src/arrow/adapters/tensorflow/convert.h              | 5 +----
 cpp/src/arrow/api.h                                      | 5 +----
 cpp/src/arrow/buffer_builder.h                           | 5 +----
 cpp/src/arrow/compare.h                                  | 5 +----
 cpp/src/arrow/compute/api.h                              | 5 +----
 cpp/src/arrow/compute/context.h                          | 5 +----
 cpp/src/arrow/compute/kernel.h                           | 5 +----
 cpp/src/arrow/compute/kernels/boolean.h                  | 5 +----
 cpp/src/arrow/compute/kernels/hash.h                     | 5 +----
 cpp/src/arrow/compute/test_util.h                        | 5 +----
 cpp/src/arrow/csv/api.h                                  | 5 +----
 cpp/src/arrow/csv/chunker.h                              | 5 +----
 cpp/src/arrow/csv/options.h                              | 5 +----
 cpp/src/arrow/filesystem/api.h                           | 5 +----
 cpp/src/arrow/flight/test_util.h                         | 2 ++
 cpp/src/arrow/gpu/cuda_api.h                             | 5 +----
 cpp/src/arrow/gpu/cuda_arrow_ipc.h                       | 5 +----
 cpp/src/arrow/io/api.h                                   | 5 +----
 cpp/src/arrow/io/buffered.h                              | 5 +----
 cpp/src/arrow/io/compressed.h                            | 5 +----
 cpp/src/arrow/io/file.h                                  | 5 +----
 cpp/src/arrow/io/hdfs.h                                  | 5 +----
 cpp/src/arrow/io/hdfs_internal.h                         | 5 +----
 cpp/src/arrow/io/test_common.h                           | 5 +----
 cpp/src/arrow/ipc/api.h                                  | 5 +----
 cpp/src/arrow/ipc/dictionary.h                           | 5 +----
 cpp/src/arrow/ipc/feather.h                              | 5 +----
 cpp/src/arrow/ipc/feather_internal.h                     | 5 +----
 cpp/src/arrow/ipc/json_internal.h                        | 5 +----
 cpp/src/arrow/ipc/json_simple.h                          | 5 +----
 cpp/src/arrow/ipc/metadata_internal.h                    | 5 +----
 cpp/src/arrow/ipc/test_common.h                          | 5 +----
 cpp/src/arrow/ipc/util.h                                 | 5 +----
 cpp/src/arrow/json/rapidjson_defs.h                      | 2 ++
 cpp/src/arrow/memory_pool.h                              | 5 +----
 cpp/src/arrow/memory_pool_test.h                         | 2 ++
 cpp/src/arrow/pretty_print.h                             | 5 +----
 cpp/src/arrow/python/api.h                               | 5 +----
 cpp/src/arrow/python/benchmark.h                         | 5 +----
 cpp/src/arrow/python/common.h                            | 5 +----
 cpp/src/arrow/python/config.h                            | 4 +---
 cpp/src/arrow/python/datetime.h                          | 5 +----
 cpp/src/arrow/python/decimal.h                           | 5 +----
 cpp/src/arrow/python/deserialize.h                       | 5 +----
 cpp/src/arrow/python/flight.h                            | 5 +----
 cpp/src/arrow/python/helpers.h                           | 5 +----
 cpp/src/arrow/python/inference.h                         | 5 +----
 cpp/src/arrow/python/init.h                              | 5 +----
 cpp/src/arrow/python/io.h                                | 5 +----
 cpp/src/arrow/python/iterators.h                         | 5 +----
 cpp/src/arrow/python/numpy_convert.h                     | 5 +----
 cpp/src/arrow/python/numpy_internal.h                    | 5 +----
 cpp/src/arrow/python/numpy_interop.h                     | 5 +----
 cpp/src/arrow/python/numpy_to_arrow.h                    | 5 +----
 cpp/src/arrow/python/platform.h                          | 4 +---
 cpp/src/arrow/python/pyarrow.h                           | 5 +----
 cpp/src/arrow/python/python_to_arrow.h                   | 5 +----
 cpp/src/arrow/python/serialize.h                         | 5 +----
 cpp/src/arrow/stl.h                                      | 5 +----
 cpp/src/arrow/table_builder.h                            | 5 +----
 cpp/src/arrow/tensor.h                                   | 5 +----
 cpp/src/arrow/testing/gtest_common.h                     | 5 +----
 cpp/src/arrow/util/bit_stream_utils.h                    | 5 +----
 cpp/src/arrow/util/bpacking.h                            | 5 +----
 cpp/src/arrow/util/checked_cast.h                        | 5 +----
 cpp/src/arrow/util/compiler_util.h                       | 5 +----
 cpp/src/arrow/util/compression_brotli.h                  | 5 +----
 cpp/src/arrow/util/compression_bz2.h                     | 5 +----
 cpp/src/arrow/util/compression_lz4.h                     | 5 +----
 cpp/src/arrow/util/compression_snappy.h                  | 5 +----
 cpp/src/arrow/util/compression_zlib.h                    | 5 +----
 cpp/src/arrow/util/compression_zstd.h                    | 5 +----
 cpp/src/arrow/util/cpu_info.h                            | 5 +----
 cpp/src/arrow/util/formatting.h                          | 2 ++
 cpp/src/arrow/util/hash_util.h                           | 5 +----
 cpp/src/arrow/util/int_util.h                            | 5 +----
 cpp/src/arrow/util/io_util.h                             | 5 +----
 cpp/src/arrow/util/key_value_metadata.h                  | 5 +----
 cpp/src/arrow/util/logging.h                             | 5 +----
 cpp/src/arrow/util/macros.h                              | 4 +---
 cpp/src/arrow/util/memory.h                              | 5 +----
 cpp/src/arrow/util/parsing.h                             | 5 +----
 cpp/src/arrow/util/rle_encoding.h                        | 5 +----
 cpp/src/arrow/util/string_builder.h                      | 5 +----
 cpp/src/arrow/util/task_group.h                          | 5 +----
 cpp/src/arrow/util/thread_pool.h                         | 5 +----
 cpp/src/arrow/util/time.h                                | 2 ++
 cpp/src/arrow/util/trie.h                                | 5 +----
 cpp/src/arrow/util/type_traits.h                         | 5 +----
 cpp/src/arrow/util/utf8.h                                | 5 +----
 cpp/src/arrow/util/variant.h                             | 5 +----
 cpp/src/arrow/util/visibility.h                          | 5 +----
 cpp/src/arrow/util/windows_fixup.h                       | 2 +-
 cpp/src/arrow/visitor.h                                  | 5 +----
 cpp/src/gandiva/annotator.h                              | 5 +----
 cpp/src/gandiva/arrow.h                                  | 5 +----
 cpp/src/gandiva/bitmap_accumulator.h                     | 5 +----
 cpp/src/gandiva/cache.h                                  | 4 +---
 cpp/src/gandiva/compiled_expr.h                          | 5 +----
 cpp/src/gandiva/condition.h                              | 5 +----
 cpp/src/gandiva/date_utils.h                             | 5 +----
 cpp/src/gandiva/decimal_ir.h                             | 5 +----
 cpp/src/gandiva/decimal_type_util.h                      | 5 +----
 cpp/src/gandiva/dex.h                                    | 5 +----
 cpp/src/gandiva/dex_visitor.h                            | 5 +----
 cpp/src/gandiva/engine.h                                 | 5 +----
 cpp/src/gandiva/eval_batch.h                             | 5 +----
 cpp/src/gandiva/execution_context.h                      | 4 +---
 cpp/src/gandiva/exported_funcs.h                         | 5 +----
 cpp/src/gandiva/exported_funcs_registry.h                | 5 +----
 cpp/src/gandiva/expr_decomposer.h                        | 5 +----
 cpp/src/gandiva/expr_validator.h                         | 5 +----
 cpp/src/gandiva/expression.h                             | 5 +----
 cpp/src/gandiva/expression_registry.h                    | 4 +---
 cpp/src/gandiva/field_descriptor.h                       | 5 +----
 cpp/src/gandiva/filter_cache_key.h                       | 4 +---
 cpp/src/gandiva/func_descriptor.h                        | 5 +----
 cpp/src/gandiva/function_holder.h                        | 5 +----
 cpp/src/gandiva/function_holder_registry.h               | 5 +----
 cpp/src/gandiva/function_ir_builder.h                    | 5 +----
 cpp/src/gandiva/function_registry.h                      | 5 +----
 cpp/src/gandiva/function_registry_arithmetic.h           | 5 +----
 cpp/src/gandiva/function_registry_common.h               | 5 +----
 cpp/src/gandiva/function_registry_datetime.h             | 5 +----
 cpp/src/gandiva/function_registry_hash.h                 | 5 +----
 cpp/src/gandiva/function_registry_math_ops.h             | 5 +----
 cpp/src/gandiva/function_registry_string.h               | 5 +----
 cpp/src/gandiva/function_registry_timestamp_arithmetic.h | 5 +----
 cpp/src/gandiva/function_signature.h                     | 5 +----
 cpp/src/gandiva/gandiva_aliases.h                        | 5 +----
 cpp/src/gandiva/gdv_function_stubs.h                     | 5 +----
 cpp/src/gandiva/jni/config_holder.h                      | 4 +---
 cpp/src/gandiva/jni/env_helper.h                         | 5 +----
 cpp/src/gandiva/jni/id_to_module_map.h                   | 5 +----
 cpp/src/gandiva/jni/module_holder.h                      | 5 +----
 cpp/src/gandiva/like_holder.h                            | 5 +----
 cpp/src/gandiva/literal_holder.h                         | 5 +----
 cpp/src/gandiva/llvm_generator.h                         | 5 +----
 cpp/src/gandiva/llvm_types.h                             | 5 +----
 cpp/src/gandiva/local_bitmaps_holder.h                   | 5 +----
 cpp/src/gandiva/logging.h                                | 5 +----
 cpp/src/gandiva/lru_cache.h                              | 4 +---
 cpp/src/gandiva/lvalue.h                                 | 5 +----
 cpp/src/gandiva/native_function.h                        | 5 +----
 cpp/src/gandiva/node.h                                   | 5 +----
 cpp/src/gandiva/node_visitor.h                           | 5 +----
 cpp/src/gandiva/precompiled/epoch_time_point.h           | 5 +----
 cpp/src/gandiva/precompiled/time_constants.h             | 5 +----
 cpp/src/gandiva/precompiled/time_fields.h                | 4 +---
 cpp/src/gandiva/precompiled/types.h                      | 5 +----
 cpp/src/gandiva/projector_cache_key.h                    | 4 +---
 cpp/src/gandiva/random_generator_holder.h                | 5 +----
 cpp/src/gandiva/regex_util.h                             | 5 +----
 cpp/src/gandiva/selection_vector.h                       | 5 +----
 cpp/src/gandiva/selection_vector_impl.h                  | 5 +----
 cpp/src/gandiva/simple_arena.h                           | 5 +----
 cpp/src/gandiva/tests/generate_data.h                    | 5 +----
 cpp/src/gandiva/tests/test_util.h                        | 5 +----
 cpp/src/gandiva/tests/timed_evaluate.h                   | 5 +----
 cpp/src/gandiva/to_date_holder.h                         | 4 +---
 cpp/src/gandiva/tree_expr_builder.h                      | 5 +----
 cpp/src/gandiva/value_validity_pair.h                    | 5 +----
 cpp/src/generated/File_generated.h                       | 4 +---
 cpp/src/generated/Message_generated.h                    | 4 +---
 cpp/src/generated/Schema_generated.h                     | 4 +---
 cpp/src/generated/SparseTensor_generated.h               | 4 +---
 cpp/src/generated/Tensor_generated.h                     | 4 +---
 cpp/src/generated/feather_generated.h                    | 4 +---
 cpp/src/jni/orc/concurrent_map.h                         | 5 +----
 cpp/src/parquet/api/io.h                                 | 5 +----
 cpp/src/parquet/api/reader.h                             | 5 +----
 cpp/src/parquet/api/schema.h                             | 5 +----
 cpp/src/parquet/api/writer.h                             | 5 +----
 cpp/src/parquet/arrow/schema.h                           | 5 +----
 cpp/src/parquet/arrow/writer.h                           | 5 +----
 cpp/src/parquet/bloom_filter.h                           | 5 +----
 cpp/src/parquet/column_page.h                            | 5 +----
 cpp/src/parquet/column_scanner.h                         | 5 +----
 cpp/src/parquet/encryption.h                             | 5 +----
 cpp/src/parquet/encryption_internal.h                    | 5 +----
 cpp/src/parquet/exception.h                              | 5 +----
 cpp/src/parquet/file_writer.h                            | 5 +----
 cpp/src/parquet/hasher.h                                 | 5 +----
 cpp/src/parquet/internal_file_decryptor.h                | 5 +----
 cpp/src/parquet/internal_file_encryptor.h                | 5 +----
 cpp/src/parquet/murmur3.h                                | 5 +----
 cpp/src/parquet/printer.h                                | 5 +----
 cpp/src/parquet/stream_reader.h                          | 5 +----
 cpp/src/parquet/stream_writer.h                          | 5 +----
 cpp/src/parquet/types.h                                  | 5 +----
 cpp/src/plasma/client.h                                  | 5 +----
 cpp/src/plasma/common.h                                  | 5 +----
 cpp/src/plasma/common_generated.h                        | 4 +---
 cpp/src/plasma/compat.h                                  | 5 +----
 cpp/src/plasma/events.h                                  | 5 +----
 cpp/src/plasma/eviction_policy.h                         | 5 +----
 cpp/src/plasma/external_store.h                          | 5 +----
 cpp/src/plasma/hash_table_store.h                        | 5 +----
 cpp/src/plasma/io.h                                      | 5 +----
 cpp/src/plasma/malloc.h                                  | 5 +----
 cpp/src/plasma/plasma.h                                  | 5 +----
 cpp/src/plasma/plasma_allocator.h                        | 5 +----
 cpp/src/plasma/plasma_generated.h                        | 4 +---
 cpp/src/plasma/protocol.h                                | 5 +----
 cpp/src/plasma/quota_aware_policy.h                      | 5 +----
 cpp/src/plasma/store.h                                   | 5 +----
 cpp/src/plasma/test_util.h                               | 5 +----
 cpp/src/plasma/thirdparty/ae/ae.h                        | 4 +---
 cpp/src/plasma/thirdparty/ae/config.h                    | 4 +---
 cpp/src/plasma/thirdparty/ae/zmalloc.h                   | 4 +---
 matlab/src/feather_reader.h                              | 4 +---
 matlab/src/feather_writer.h                              | 4 +---
 matlab/src/matlab_traits.h                               | 4 +---
 matlab/src/util/handle_status.h                          | 4 +---
 matlab/src/util/unicode_conversion.h                     | 4 +---
 216 files changed, 221 insertions(+), 813 deletions(-)