You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@arrow.apache.org by th...@apache.org on 2023/06/28 17:18:59 UTC

[arrow] branch main updated: GH-35545: [R] Re-organise reference page on pkgdown site (#36171)

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

thisisnic pushed a commit to branch main
in repository https://gitbox.apache.org/repos/asf/arrow.git


The following commit(s) were added to refs/heads/main by this push:
     new e2d21c162e GH-35545: [R] Re-organise reference page on pkgdown site (#36171)
e2d21c162e is described below

commit e2d21c162e80e05f26d23ebd600373974606c0a8
Author: Nic Crane <th...@gmail.com>
AuthorDate: Wed Jun 28 18:18:52 2023 +0100

    GH-35545: [R] Re-organise reference page on pkgdown site (#36171)
    
    Fixes #35545
    * Closes: #35545
    
    Authored-by: Nic Crane <th...@gmail.com>
    Signed-off-by: Nic Crane <th...@gmail.com>
---
 r/_pkgdown.yml | 304 +++++++++++++++++++++++++++++++++------------------------
 1 file changed, 174 insertions(+), 130 deletions(-)

diff --git a/r/_pkgdown.yml b/r/_pkgdown.yml
index 6902ae2746..e26362ffdb 100644
--- a/r/_pkgdown.yml
+++ b/r/_pkgdown.yml
@@ -138,146 +138,190 @@ articles:
       - developers/data_object_layout
 
 reference:
-  - title: Multi-file datasets
-    contents:
-      - open_dataset
-      - open_delim_dataset
-      - open_csv_dataset
-      - open_tsv_dataset
-      - write_dataset
-      - dataset_factory
-      - hive_partition
-      - Dataset
-      - Partitioning
-      - Expression
-      - Scanner
-      - FileFormat
-      - CsvFileFormat
-      - JsonFileFormat
-      - FileWriteOptions
-      - FragmentScanOptions
-      - map_batches
+- title: Read datasets
+  desc: >
+    Open multi-file datasets as Arrow Dataset objects.
+  contents:
+  - open_dataset
+  - open_delim_dataset
+  - open_csv_dataset
+  - open_tsv_dataset
 
-  - title: Reading and writing files
-    contents:
-      - read_feather
-      - read_ipc_stream
-      - read_parquet
-      - read_delim_arrow
-      - read_json_arrow
-      - write_feather
-      - write_ipc_stream
-      - write_to_raw
-      - write_parquet
-      - write_csv_arrow
+- title: Write datasets
+  desc: >
+    Write multi-file datasets to disk.
+  contents:
+  - write_dataset
 
-  - title: C++ reader/writer interface
-    contents:
-      - ParquetFileReader
-      - ParquetArrowReaderProperties
-      - ParquetFileWriter
-      - ParquetWriterProperties
-      - FeatherReader
-      - CsvTableReader
-      - RecordBatchReader
-      - RecordBatchWriter
-      - CsvReadOptions
-      - CsvWriteOptions
-      - as_record_batch_reader
+- title: Read files
+  desc: >
+    Read files in a variety of formats in as tibbles or Arrow Tables.
+  contents:
+  - read_delim_arrow
+  - read_parquet
+  - read_feather
+  - read_ipc_stream
+  - read_json_arrow
 
-  - title: Arrow data containers
-    contents:
-      - scalar
-      - array
-      - ChunkedArray
-      - Scalar-class
-      - RecordBatch
-      - Table
-      - ArrayData
-      - buffer
-      - read_message
-      - concat_arrays
-      - concat_tables
-      - ExtensionArray
-      - vctrs_extension_array
-      - as_arrow_array
-      - as_chunked_array
-      - as_record_batch
-      - as_arrow_table
+- title: Write files
+  desc: >
+     Write to files in a variety of formats.
+  contents:
+    - write_csv_arrow
+    - write_parquet
+    - write_feather
+    - write_ipc_stream
+    - write_to_raw
 
-  - title: Arrow data types and schema
-    contents:
-      - schema
-      - infer_schema
-      - schema-class
-      - unify_schemas
-      - infer_type
-      - dictionary
-      - Field
-      - read_schema
-      - data-type
-      - DataType
-      - DictionaryType
-      - FixedWidthType
-      - new_extension_type
-      - vctrs_extension_type
-      - ExtensionType
-      - as_data_type
-      - as_schema
+- title: Creating Arrow data containers
+  desc: >
+   Classes and functions for creating Arrow data containers.
+  contents:
+    - scalar
+    - array
+    - ChunkedArray
+    - RecordBatch
+    - Table
+    - buffer
+    - vctrs_extension_array
 
-  - title: Flight
-    contents:
-      - load_flight_server
-      - flight_connect
-      - flight_disconnect
-      - flight_get
-      - flight_put
-      - list_flights
+- title: Working with Arrow data containers
+  desc: >
+    Functions for converting R objects to Arrow data containers and combining Arrow data containers.
+  contents:
+  - as_arrow_array
+  - as_chunked_array
+  - as_record_batch
+  - as_arrow_table
+  - concat_arrays
+  - concat_tables
 
-  - title: File systems
-    contents:
-      - s3_bucket
-      - gs_bucket
-      - FileSystem
-      - FileInfo
-      - FileSelector
-      - copy_files
+- title: Arrow data types
+  contents:
+  - data-type
+  - dictionary
+  - new_extension_type
+  - vctrs_extension_type
+  - as_data_type
+  - infer_type
 
-  - title: Input/Output
-    contents:
-      - InputStream
-      - mmap_open
-      - mmap_create
-      - OutputStream
-      - Message
-      - MessageReader
-      - compression
-      - Codec
-      - codec_is_available
+- title: Fields and schemas
+  contents:
+  - Field
+  - schema
+  - unify_schemas
+  - as_schema
+  - infer_schema
+  - read_schema
 
-  - title: Computation
-    contents:
-      - acero
-      - call_function
-      - match_arrow
-      - value_counts
-      - list_compute_functions
-      - register_scalar_function
-      - show_exec_plan
+- title: Computation
+  desc: >
+    Functionality for computing values on Arrow data objects.
+  contents:
+  - acero
+  - arrow-functions
+  - arrow-verbs
+  - arrow-dplyr
+  - call_function
+  - match_arrow
+  - value_counts
+  - list_compute_functions
+  - register_scalar_function
+  - show_exec_plan
 
-  - title: Connections to other systems
-    contents:
-      - to_arrow
-      - to_duckdb
+- title: DuckDB
+  desc: >
+    Pass data to and from DuckDB
+  contents:
+  - to_arrow
+  - to_duckdb
 
-  - title: Configuration
-    contents:
-      - arrow_info
-      - cpu_count
-      - io_thread_count
-      - install_arrow
-      - install_pyarrow
-      - create_package_with_all_dependencies
+- title: File systems
+  desc: >
+   Functions for working with files on S3 and GCS
+  contents:
+  - s3_bucket
+  - gs_bucket
+  - copy_files
+
+- title: Flight
+  contents:
+    - load_flight_server
+    - flight_connect
+    - flight_disconnect
+    - flight_get
+    - flight_put
+    - list_flights
+
+- title: Arrow Configuration
+  contents:
+    - arrow_info
+    - cpu_count
+    - io_thread_count
+    - install_arrow
+    - install_pyarrow
+    - create_package_with_all_dependencies
+
+- title: Input/Output
+  contents:
+    - InputStream
+    - read_message
+    - mmap_open
+    - mmap_create
+    - OutputStream
+    - Message
+    - MessageReader
+    - compression
+    - Codec
+    - codec_is_available
+
+- title: File read/writer interface
+  contents:
+  - ParquetFileReader
+  - ParquetArrowReaderProperties
+  - ParquetFileWriter
+  - ParquetWriterProperties
+  - FeatherReader
+  - CsvTableReader
+  - CsvReadOptions
+  - CsvWriteOptions
+  - RecordBatchReader
+  - RecordBatchWriter
+  - as_record_batch_reader
+
+- title: Arrow data types, schemas, and containers - R6 classes
+  desc: >
+    R6 classes for Arrow data types.
+  contents:
+  - Scalar
+  - Schema
+  - DataType
+  - ArrayData
+  - DictionaryType
+  - FixedWidthType
+  - ExtensionType
+  - ArrayData
+  - ExtensionArray
+
+- title: Dataset and Filesystem R6 classes and helper functions
+  desc: >
+    R6 classes and helper functions useful for when working with multi-file datases in Arrow.
+  contents:
+  - Dataset
+  - dataset_factory
+  - Partitioning
+  - Expression
+  - Scanner
+  - FileFormat
+  - CsvFileFormat
+  - JsonFileFormat
+  - FileWriteOptions
+  - FragmentScanOptions
+  - hive_partition
+  - map_batches
+  - FileSystem
+  - FileInfo
+  - FileSelector
 
 repo:
   url: